You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by ad...@apache.org on 2017/04/12 12:18:07 UTC

[1/3] ambari git commit: AMBARI-20741. Hadoop QA should directly link to Maven output if build fails

Repository: ambari
Updated Branches:
  refs/heads/trunk 4d297f5aa -> 754d6c872


AMBARI-20741. Hadoop QA should directly link to Maven output if build fails


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

Branch: refs/heads/trunk
Commit: dc180f693f13113fc2d27c5587fa12fe1f2e5044
Parents: 4d297f5
Author: Attila Doroszlai <ad...@hortonworks.com>
Authored: Wed Apr 12 11:39:54 2017 +0200
Committer: Attila Doroszlai <ad...@hortonworks.com>
Committed: Wed Apr 12 14:17:20 2017 +0200

----------------------------------------------------------------------
 dev-support/test-patch.sh | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/dc180f69/dev-support/test-patch.sh
----------------------------------------------------------------------
diff --git a/dev-support/test-patch.sh b/dev-support/test-patch.sh
index 9b6d83e..934e092 100755
--- a/dev-support/test-patch.sh
+++ b/dev-support/test-patch.sh
@@ -267,7 +267,7 @@ prebuildWithoutPatch () {
     echo "Top-level trunk compilation is broken?"
     JIRA_COMMENT="$JIRA_COMMENT
 
-    {color:red}-1 patch{color}.  Top-level trunk compilation may be broken."
+    {color:red}-1 patch{color}.  Top-level [trunk compilation|$BUILD_URL/artifact/patch-work/trunkJavacWarnings.txt] may be broken."
     return 1
   fi
 
@@ -390,7 +390,7 @@ checkJavacWarnings () {
   if [[ $? != 0 ]] ; then
     JIRA_COMMENT="$JIRA_COMMENT
 
-    {color:red}-1 javac{color}.  The patch appears to cause the build to fail."
+    {color:red}-1 javac{color}.  The patch appears to cause the [build to fail|$BUILD_URL/artifact/patch-work/patchJavacWarnings.txt]."
     return 2
   fi
   ### Compare trunk and patch javac warning numbers


[3/3] ambari git commit: AMBARI-19149. Code cleanup: redundant modifiers (interfaces, enums)

Posted by ad...@apache.org.
AMBARI-19149. Code cleanup: redundant modifiers (interfaces, enums)


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

Branch: refs/heads/trunk
Commit: 754d6c8723e577ded6adc2448730a3c7ead8f7a2
Parents: dc180f6
Author: Attila Doroszlai <ad...@hortonworks.com>
Authored: Wed Apr 12 13:24:15 2017 +0200
Committer: Attila Doroszlai <ad...@hortonworks.com>
Committed: Wed Apr 12 14:17:48 2017 +0200

----------------------------------------------------------------------
 .../ambari/annotations/TransactionalLock.java   |  6 +--
 .../server/actionmanager/ActionDBAccessor.java  | 50 ++++++++---------
 .../ambari/server/agent/ExecutionCommand.java   |  2 +-
 .../alerts/AmbariPerformanceRunnable.java       |  4 +-
 .../server/api/handlers/RequestHandler.java     |  2 +-
 .../api/predicate/expressions/Expression.java   | 14 ++---
 .../predicate/operators/LogicalOperator.java    |  2 +-
 .../api/predicate/operators/Operator.java       |  8 +--
 .../predicate/operators/RelationalOperator.java |  2 +-
 .../apache/ambari/server/api/query/Query.java   | 18 +++----
 .../server/api/query/render/Renderer.java       | 12 ++---
 .../server/api/resources/ResourceInstance.java  | 12 ++---
 .../api/resources/ResourceInstanceFactory.java  |  2 +-
 .../api/services/ResultPostProcessor.java       |  2 +-
 .../server/api/services/ResultStatus.java       |  4 +-
 .../api/services/parsers/RequestBodyParser.java | 12 ++---
 .../persistence/PersistenceManager.java         |  6 +--
 .../stackadvisor/StackAdvisorRequest.java       |  2 +-
 .../commands/StackAdvisorCommandType.java       |  2 +-
 .../apache/ambari/server/api/util/TreeNode.java | 28 +++++-----
 .../ambari/server/checks/UpgradeCheckGroup.java |  2 +-
 .../server/configuration/Configuration.java     |  8 +--
 .../controller/AmbariManagementController.java  | 12 ++---
 .../server/controller/KerberosHelper.java       |  2 +-
 .../controller/MaintenanceStateHelper.java      |  4 +-
 .../gsinstaller/GSInstallerStateProvider.java   |  2 +-
 .../internal/AbstractResourceProvider.java      |  2 +-
 .../internal/ArtifactResourceProvider.java      | 20 +++----
 .../BlueprintConfigurationProcessor.java        |  2 +-
 .../internal/JobResourceProvider.java           |  8 +--
 .../internal/ObservableResourceProvider.java    |  4 +-
 .../internal/ResourceProviderObserver.java      |  2 +-
 .../internal/TaskAttemptResourceProvider.java   | 10 ++--
 .../internal/WidgetLayoutResourceProvider.java  |  2 +-
 .../internal/WidgetResourceProvider.java        |  2 +-
 .../internal/WorkflowResourceProvider.java      |  8 +--
 .../server/controller/ivory/IvoryService.java   | 34 ++++++------
 .../controller/jdbc/ConnectionFactory.java      |  2 +-
 .../server/controller/jmx/JMXHostProvider.java  | 10 ++--
 .../logging/LoggingRequestHelper.java           |  8 +--
 .../controller/metrics/MetricHostProvider.java  | 10 ++--
 .../metrics/MetricsPaddingMethod.java           |  2 +-
 .../metrics/MetricsServiceProvider.java         |  4 +-
 .../controller/predicate/BasePredicate.java     |  2 +-
 .../controller/predicate/PredicateVisitor.java  | 10 ++--
 .../predicate/PredicateVisitorAcceptor.java     |  2 +-
 .../spi/ExtendedResourceProvider.java           |  2 +-
 .../server/controller/spi/PageRequest.java      | 10 ++--
 .../server/controller/spi/PageResponse.java     | 10 ++--
 .../ambari/server/controller/spi/Predicate.java |  2 +-
 .../server/controller/spi/PropertyProvider.java |  4 +-
 .../server/controller/spi/ProviderModule.java   |  4 +-
 .../server/controller/spi/QueryResponse.java    |  8 +--
 .../server/controller/spi/RequestStatus.java    |  8 +--
 .../spi/ResourcePredicateEvaluator.java         |  2 +-
 .../ambari/server/controller/spi/Schema.java    |  4 +-
 .../server/controller/spi/SchemaFactory.java    |  2 +-
 .../server/controller/spi/SortRequest.java      |  6 +--
 .../controller/utilities/StreamProvider.java    |  4 +-
 .../server/notifications/DispatchCallback.java  |  4 +-
 .../server/orm/JPATableGenerationStrategy.java  |  2 +-
 .../orm/cache/ConfigGroupHostMapping.java       | 16 +++---
 .../server/orm/cache/HostConfigMapping.java     | 32 +++++------
 .../orm/entities/BlueprintConfiguration.java    | 16 +++---
 .../ambari/server/scheduler/ExecutionJob.java   | 10 ++--
 .../server/scheduler/ExecutionScheduler.java    | 16 +++---
 .../ambari/server/security/SecurityHelper.java  |  4 +-
 .../security/authorization/ResourceType.java    |  2 +-
 .../security/encryption/MasterKeyService.java   |  4 +-
 .../kerberos/KerberosConfigDataFile.java        | 14 ++---
 .../kerberos/KerberosIdentityDataFile.java      | 24 ++++-----
 .../ambari/server/stack/ConfigurationInfo.java  |  6 +--
 .../server/stack/StackDefinitionModule.java     | 16 +++---
 .../apache/ambari/server/stack/Validable.java   | 10 ++--
 .../org/apache/ambari/server/state/Cluster.java |  4 +-
 .../server/state/CommandScriptDefinition.java   |  2 +-
 .../org/apache/ambari/server/state/Config.java  | 22 ++++----
 .../ambari/server/state/HostHealthStatus.java   |  2 +-
 .../ambari/server/state/UpgradeHelper.java      |  4 +-
 .../ambari/server/state/action/Action.java      | 14 ++---
 .../server/state/configgroup/ConfigGroup.java   | 32 +++++------
 .../server/state/fsm/MultipleArcTransition.java |  2 +-
 .../server/state/fsm/SingleArcTransition.java   |  2 +-
 .../ambari/server/state/fsm/StateMachine.java   |  6 +--
 .../kerberos/AbstractKerberosDescriptor.java    |  2 +-
 .../state/scheduler/RequestExecution.java       | 56 ++++++++++----------
 .../state/stack/upgrade/UpgradeFunction.java    |  2 +-
 .../ambari/server/topology/Blueprint.java       | 34 ++++++------
 .../server/topology/BlueprintFactory.java       |  2 +-
 .../server/topology/BlueprintValidator.java     |  4 +-
 .../ambari/server/topology/HostGroup.java       | 28 +++++-----
 .../ambari/server/topology/TopologyRequest.java | 16 +++---
 .../server/topology/TopologyRequestFactory.java |  2 +-
 .../server/topology/TopologyValidator.java      |  2 +-
 .../server/topology/tasks/TopologyTask.java     |  4 +-
 .../server/upgrade/AbstractUpgradeCatalog.java  |  2 +-
 .../server/view/ViewInstanceHandlerList.java    |  4 +-
 .../view/persistence/SchemaManagerFactory.java  |  2 +-
 .../AbstractJDBCResourceProviderTest.java       |  2 +-
 .../state/cluster/AlertDataManagerTest.java     |  4 +-
 .../ambari/server/upgrade/SectionDDL.java       |  4 +-
 101 files changed, 433 insertions(+), 433 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/annotations/TransactionalLock.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/annotations/TransactionalLock.java b/ambari-server/src/main/java/org/apache/ambari/annotations/TransactionalLock.java
index a8b89a9..7c8485c 100644
--- a/ambari-server/src/main/java/org/apache/ambari/annotations/TransactionalLock.java
+++ b/ambari-server/src/main/java/org/apache/ambari/annotations/TransactionalLock.java
@@ -60,7 +60,7 @@ public @interface TransactionalLock {
    * The area that the lock is being applied to. There is exactly 1
    * {@link ReadWriteLock} for every area defined.
    */
-  public enum LockArea {
+  enum LockArea {
     /**
      * Joinpoint lock around work performed on caching the host role command
      * status in a given stage and request.
@@ -89,7 +89,7 @@ public @interface TransactionalLock {
      *
      * @param configurationProperty
      */
-    private LockArea(String configurationProperty) {
+    LockArea(String configurationProperty) {
       m_configurationProperty = configurationProperty;
     }
 
@@ -134,7 +134,7 @@ public @interface TransactionalLock {
   /**
    * The type of lock which should be acquired.
    */
-  public enum LockType {
+  enum LockType {
     /**
      * Read Lock.
      */

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/actionmanager/ActionDBAccessor.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/actionmanager/ActionDBAccessor.java b/ambari-server/src/main/java/org/apache/ambari/server/actionmanager/ActionDBAccessor.java
index b0550c0..47a74b2 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/actionmanager/ActionDBAccessor.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/actionmanager/ActionDBAccessor.java
@@ -32,12 +32,12 @@ public interface ActionDBAccessor {
   /**
    * Given an action id of the form requestId-stageId, retrieve the Stage
    */
-  public Stage getStage(String actionId);
+  Stage getStage(String actionId);
 
   /**
    * Get all stages associated with a single request id
    */
-  public List<Stage> getAllStages(long requestId);
+  List<Stage> getAllStages(long requestId);
 
   /**
    * Gets the request entity by id.  Will not load the entire
@@ -62,12 +62,12 @@ public interface ActionDBAccessor {
    *
    * Returns the list of the aborted operations.
    */
-  public Collection<HostRoleCommandEntity> abortOperation(long requestId);
+  Collection<HostRoleCommandEntity> abortOperation(long requestId);
 
   /**
    * Mark the task as to have timed out
    */
-  public void timeoutHostRole(String host, long requestId, long stageId, String role);
+  void timeoutHostRole(String host, long requestId, long stageId, String role);
 
   /**
    * Mark the task as to have timed out
@@ -88,7 +88,7 @@ public interface ActionDBAccessor {
    *
    * @see HostRoleStatus#IN_PROGRESS_STATUSES
    */
-  public List<Stage> getFirstStageInProgressPerRequest();
+  List<Stage> getFirstStageInProgressPerRequest();
 
   /**
    * Returns all the pending stages in a request, including queued and not-queued. A stage is
@@ -101,14 +101,14 @@ public interface ActionDBAccessor {
    *
    * @see HostRoleStatus#IN_PROGRESS_STATUSES
    */
-  public List<Stage> getStagesInProgressForRequest(Long requestId);
+  List<Stage> getStagesInProgressForRequest(Long requestId);
 
   /**
    * Gets the number of commands in progress.
    *
    * @return the number of commands in progress.
    */
-  public int getCommandsInProgressCount();
+  int getCommandsInProgressCount();
 
   /**
    * Persists all tasks for a given request
@@ -135,19 +135,19 @@ public interface ActionDBAccessor {
   /**
    * For the given host, update all the tasks based on the command report
    */
-  public void updateHostRoleState(String hostname, long requestId,
-                                  long stageId, String role, CommandReport report);
+  void updateHostRoleState(String hostname, long requestId,
+                           long stageId, String role, CommandReport report);
 
   /**
    * Mark the task as to have been aborted
    */
-  public void abortHostRole(String host, long requestId, long stageId, String role);
+  void abortHostRole(String host, long requestId, long stageId, String role);
 
   /**
    * Mark the task as to have been aborted. Reason should be specified manually.
    */
-  public void abortHostRole(String host, long requestId, long stageId,
-                            String role, String reason);
+  void abortHostRole(String host, long requestId, long stageId,
+                     String role, String reason);
 
   /**
    * Return the last persisted Request ID as seen when the DBAccessor object
@@ -156,7 +156,7 @@ public interface ActionDBAccessor {
    *
    * @return Request Id seen at init time
    */
-  public long getLastPersistedRequestIdWhenInitialized();
+  long getLastPersistedRequestIdWhenInitialized();
 
   /**
    * Bulk update scheduled commands
@@ -171,37 +171,37 @@ public interface ActionDBAccessor {
   /**
    * Updates scheduled stage.
    */
-  public void hostRoleScheduled(Stage s, String hostname, String roleStr);
+  void hostRoleScheduled(Stage s, String hostname, String roleStr);
 
   /**
    * Given a request id, get all the tasks that belong to this request
    */
-  public List<HostRoleCommand> getRequestTasks(long requestId);
+  List<HostRoleCommand> getRequestTasks(long requestId);
 
   /**
    * Given a list of request ids, get all the tasks that belong to these requests
    */
-  public List<HostRoleCommand> getAllTasksByRequestIds(Collection<Long> requestIds);
+  List<HostRoleCommand> getAllTasksByRequestIds(Collection<Long> requestIds);
 
   /**
    * Given a list of task ids, get all the host role commands
    */
-  public Collection<HostRoleCommand> getTasks(Collection<Long> taskIds);
+  Collection<HostRoleCommand> getTasks(Collection<Long> taskIds);
 
   /**
    * Get a List of host role commands where the host, role and status are as specified
    */
-  public List<HostRoleCommand> getTasksByHostRoleAndStatus(String hostname, String role, HostRoleStatus status);
+  List<HostRoleCommand> getTasksByHostRoleAndStatus(String hostname, String role, HostRoleStatus status);
 
   /**
    * Get a List of host role commands where the role and status are as specified
    */
-  public List<HostRoleCommand> getTasksByRoleAndStatus(String role, HostRoleStatus status);
+  List<HostRoleCommand> getTasksByRoleAndStatus(String role, HostRoleStatus status);
 
   /**
    * Gets the host role command corresponding to the task id
    */
-  public HostRoleCommand getTask(long taskId);
+  HostRoleCommand getTask(long taskId);
 
   /**
    * Get first or last maxResults requests that are in the specified status
@@ -215,28 +215,28 @@ public interface ActionDBAccessor {
    * @return First or last maxResults request id's if ascOrder is true or false,
    *         respectively
    */
-  public List<Long> getRequestsByStatus(RequestStatus status, int maxResults, boolean ascOrder);
+  List<Long> getRequestsByStatus(RequestStatus status, int maxResults, boolean ascOrder);
 
   /**
    * Gets request contexts associated with the list of request id
    */
-  public Map<Long, String> getRequestContext(List<Long> requestIds);
+  Map<Long, String> getRequestContext(List<Long> requestIds);
 
   /**
    * Gets the request context associated with the request id
    */
-  public String getRequestContext(long requestId);
+  String getRequestContext(long requestId);
 
   /**
    * Gets request objects by ids
    */
-  public List<Request> getRequests(Collection<Long> requestIds);
+  List<Request> getRequests(Collection<Long> requestIds);
 
   /**
    * Resubmits a series of tasks
    * @param taskIds
    */
-  public void resubmitTasks(List<Long> taskIds);
+  void resubmitTasks(List<Long> taskIds);
 
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java b/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
index 0d1ef13..8c726a0 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
@@ -398,7 +398,7 @@ public class ExecutionCommand extends AgentCommand {
    * Contains key name strings. These strings are used inside maps
    * incapsulated inside command.
    */
-  public static interface KeyNames {
+  public interface KeyNames {
     String COMMAND_TIMEOUT = "command_timeout";
     String SCRIPT = "script";
     String SCRIPT_TYPE = "script_type";

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/alerts/AmbariPerformanceRunnable.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/alerts/AmbariPerformanceRunnable.java b/ambari-server/src/main/java/org/apache/ambari/server/alerts/AmbariPerformanceRunnable.java
index 8faa2a1..a35e6fd 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/alerts/AmbariPerformanceRunnable.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/alerts/AmbariPerformanceRunnable.java
@@ -221,8 +221,8 @@ public class AmbariPerformanceRunnable extends AlertRunnable {
      *          the default value to use if the definition does not have a
      *          critical threshold paramter.
      */
-    private PerformanceArea(String label, String warningParameter, int defaultWarningThreshold,
-        String criticalParameter, int defaultCriticalThreshold) {
+    PerformanceArea(String label, String warningParameter, int defaultWarningThreshold,
+                    String criticalParameter, int defaultCriticalThreshold) {
       m_label = label;
       m_warningParameter = warningParameter;
       m_defaultWarningThreshold = defaultWarningThreshold;

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/handlers/RequestHandler.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/handlers/RequestHandler.java b/ambari-server/src/main/java/org/apache/ambari/server/api/handlers/RequestHandler.java
index 9e2d923..1c7a220 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/handlers/RequestHandler.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/handlers/RequestHandler.java
@@ -31,5 +31,5 @@ public interface RequestHandler {
    * @param request the request to handle
    * @return the result of the request
    */
-  public Result handleRequest(Request request);
+  Result handleRequest(Request request);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/expressions/Expression.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/expressions/Expression.java b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/expressions/Expression.java
index 206f267..6412799 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/expressions/Expression.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/expressions/Expression.java
@@ -43,47 +43,47 @@ public interface Expression<T> {
    *
    * @return a list of expressions after merging.  Do not return any null elements.
    */
-  public List<Expression> merge(Expression left, Expression right, int precedence);
+  List<Expression> merge(Expression left, Expression right, int precedence);
 
 
   /**
    * Get the predicate representation of the expression.
    * @return a predicate instance for the expression
    */
-  public Predicate toPredicate() throws InvalidQueryException;
+  Predicate toPredicate() throws InvalidQueryException;
 
   /**
    * Set the expressions left operand.
    *
    * @param left  the left operand
    */
-  public void setLeftOperand(T left);
+  void setLeftOperand(T left);
 
   /**
    * Set the expressions right operand.
    *
    * @param right  the right operand
    */
-  public void setRightOperand(T right);
+  void setRightOperand(T right);
 
   /**
    * Get the left operand expression.
    *
    * @return the left operand
    */
-  public T getLeftOperand();
+  T getLeftOperand();
 
   /**
    * Get the right operand expression.
    *
    * @return the right operand.
    */
-  public T getRightOperand();
+  T getRightOperand();
 
   /**
    * Get the expression operator.
    *
    * @return the logical operator for the expression
    */
-  public Operator getOperator();
+  Operator getOperator();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/LogicalOperator.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/LogicalOperator.java b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/LogicalOperator.java
index 8881aad..80e9a69 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/LogicalOperator.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/LogicalOperator.java
@@ -31,5 +31,5 @@ public interface LogicalOperator extends Operator {
    * @param right  right operand
    * @return a predicate instance for this operator
    */
-  public Predicate toPredicate(Predicate left, Predicate right);
+  Predicate toPredicate(Predicate left, Predicate right);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/Operator.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/Operator.java b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/Operator.java
index f9c3acc..a1c0622 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/Operator.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/Operator.java
@@ -26,7 +26,7 @@ public interface Operator {
   /**
    * Operator types.
    */
-  public enum TYPE {
+  enum TYPE {
     LESS,
     LESS_EQUAL,
     GREATER,
@@ -44,14 +44,14 @@ public interface Operator {
   /**
    * The highest base operator precedence level.
    */
-  public static final int MAX_OP_PRECEDENCE = 3;
+  int MAX_OP_PRECEDENCE = 3;
 
   /**
    * Get the operator type.
    *
    * @return the operator type
    */
-  public TYPE getType();
+  TYPE getType();
 
   /**
    * Obtain the precedence of the operator.
@@ -60,5 +60,5 @@ public interface Operator {
    *
    * @return  the precedence of this operator in it's current context
    */
-  public int getPrecedence();
+  int getPrecedence();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/RelationalOperator.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/RelationalOperator.java b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/RelationalOperator.java
index cbcba0c..f1d2fb4 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/RelationalOperator.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/predicate/operators/RelationalOperator.java
@@ -33,5 +33,5 @@ public interface RelationalOperator extends Operator {
    * @return  a predicate instance for this operator.
    * @throws  InvalidQueryException if unable to build the predicate because of invalid operands
    */
-  public Predicate toPredicate(String prop, String val) throws InvalidQueryException;
+  Predicate toPredicate(String prop, String val) throws InvalidQueryException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/query/Query.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/query/Query.java b/ambari-server/src/main/java/org/apache/ambari/server/api/query/Query.java
index 8ac38ac..dc9b82c 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/query/Query.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/query/Query.java
@@ -45,7 +45,7 @@ public interface Query {
    * @param propertyId    the property id
    * @param temporalInfo  temporal information for the property
    */
-  public void addProperty(String propertyId, TemporalInfo temporalInfo);
+  void addProperty(String propertyId, TemporalInfo temporalInfo);
 
   /**
    * Add a local (not sub-resource) property to the query.
@@ -54,7 +54,7 @@ public interface Query {
    * @param property the property id which contains the group, property name
    *                 and whether the property is temporal
    */
-  public void addLocalProperty(String property);
+  void addLocalProperty(String property);
 
   /**
    * Obtain the properties of the query.
@@ -63,7 +63,7 @@ public interface Query {
    *
    * @return the query properties
    */
-  public Set<String> getProperties();
+  Set<String> getProperties();
 
   /**
    * Execute the query.
@@ -75,7 +75,7 @@ public interface Query {
    * @throws NoSuchResourceException the query didn't match any resources
    * @throws NoSuchParentResourceException a specified parent resource doesn't exist
    */
-  public Result execute()
+  Result execute()
       throws UnsupportedPropertyException, SystemException, NoSuchResourceException, NoSuchParentResourceException;
 
   /**
@@ -84,7 +84,7 @@ public interface Query {
    *
    * @return the predicate used to identify the associated resource
    */
-  public Predicate getPredicate();
+  Predicate getPredicate();
 
   /**
    * Set the user provided predicated on this query.
@@ -92,21 +92,21 @@ public interface Query {
    *
    * @param predicate  the user provided predicate
    */
-  public void setUserPredicate(Predicate predicate);
+  void setUserPredicate(Predicate predicate);
 
   /**
    * Set the page request information for this query.
    *
    * @param pageRequest  the page request information
    */
-  public void setPageRequest(PageRequest pageRequest);
+  void setPageRequest(PageRequest pageRequest);
 
   /**
    * Set the order request information on the query
    *
    * @param sortRequest the ordering info
    */
-  public void setSortRequest(SortRequest sortRequest);
+  void setSortRequest(SortRequest sortRequest);
 
   /**
    * Set the corresponding renderer.
@@ -115,7 +115,7 @@ public interface Query {
    *
    * @param renderer  renderer for the query
    */
-  public void setRenderer(Renderer renderer);
+  void setRenderer(Renderer renderer);
 
   /**
    * Set this Query's requestInfoProperties from the original request.  This will contain information

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/query/render/Renderer.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/query/render/Renderer.java b/ambari-server/src/main/java/org/apache/ambari/server/api/query/render/Renderer.java
index b71d96f..0eea056 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/query/render/Renderer.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/query/render/Renderer.java
@@ -43,7 +43,7 @@ public interface Renderer {
    *
    * @param schemaFactory  factory of schema instances
    */
-  public void init(SchemaFactory schemaFactory);
+  void init(SchemaFactory schemaFactory);
 
   /**
    * Finalize which properties are requested by the query.
@@ -57,8 +57,8 @@ public interface Renderer {
    *
    * @return tree of sets of string properties for each query including any sub-queries
    */
-  public TreeNode<Set<String>> finalizeProperties(
-      TreeNode<QueryInfo> queryProperties, boolean isCollection);
+  TreeNode<Set<String>> finalizeProperties(
+    TreeNode<QueryInfo> queryProperties, boolean isCollection);
 
   /**
    * Finalize the query results.
@@ -67,7 +67,7 @@ public interface Renderer {
    *
    * @return result in the format dictated by the renderer
    */
-  public Result finalizeResult(Result queryResult);
+  Result finalizeResult(Result queryResult);
 
   /**
    * Obtain the associated post processor.
@@ -79,7 +79,7 @@ public interface Renderer {
    *
    * @return associated post processor
    */
-  public ResultPostProcessor getResultPostProcessor(Request request);
+  ResultPostProcessor getResultPostProcessor(Request request);
 
 
   /**
@@ -89,5 +89,5 @@ public interface Renderer {
    * @return true if property provider support is required
    *         false if property provider support is not required
    */
-  public boolean requiresPropertyProviderInput();
+  boolean requiresPropertyProviderInput();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstance.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstance.java b/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstance.java
index 3695807..ca4357f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstance.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstance.java
@@ -33,14 +33,14 @@ public interface ResourceInstance {
    *
    * @param keyValueMap  map of all parent foreign keys. Map from resource type to id value.
    */
-  public void setKeyValueMap(Map<Resource.Type, String> keyValueMap);
+  void setKeyValueMap(Map<Resource.Type, String> keyValueMap);
 
   /**
    * Obtain the primary and foreign key properties for the resource.
    *
    * @return map of primary and foreign key values keyed by resource type
    */
-  public Map<Resource.Type, String> getKeyValueMap();
+  Map<Resource.Type, String> getKeyValueMap();
 
   /**
    * Return the query associated with the resource.
@@ -48,7 +48,7 @@ public interface ResourceInstance {
    *
    * @return the associated query
    */
-  public Query getQuery();
+  Query getQuery();
 
   /**
    * Return the resource definition for this resource type.
@@ -57,7 +57,7 @@ public interface ResourceInstance {
    *
    * @return  the associated resource definition
    */
-  public ResourceDefinition getResourceDefinition();
+  ResourceDefinition getResourceDefinition();
 
   /**
    * Return all sub-resource instances.
@@ -66,12 +66,12 @@ public interface ResourceInstance {
    *
    * @return all sub-resource instances
    */
-  public Map<String, ResourceInstance> getSubResources();
+  Map<String, ResourceInstance> getSubResources();
 
   /**
    * Determine if resource is a collection resource.
    *
    * @return true if the resource is a collection resource; false otherwise
    */
-  public boolean isCollectionResource();
+  boolean isCollectionResource();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstanceFactory.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstanceFactory.java b/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstanceFactory.java
index 0b5859b..0b154fb 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstanceFactory.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/resources/ResourceInstanceFactory.java
@@ -35,5 +35,5 @@ public interface ResourceInstanceFactory {
    *
    * @return  a new resource instance of the specified type
    */
-  public ResourceInstance createResource(Resource.Type type, Map<Resource.Type, String> mapIds);
+  ResourceInstance createResource(Resource.Type type, Map<Resource.Type, String> mapIds);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultPostProcessor.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultPostProcessor.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultPostProcessor.java
index ab25bb2..9bba025 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultPostProcessor.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultPostProcessor.java
@@ -29,5 +29,5 @@ public interface ResultPostProcessor {
    *
    * @param result the result to process.
    */
-  public void process(Result result);
+  void process(Result result);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultStatus.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultStatus.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultStatus.java
index 6284879..1e0e24a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultStatus.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/ResultStatus.java
@@ -26,7 +26,7 @@ public class ResultStatus {
   /**
    * STATUS enum. Maps a status to a status code.
    */
-  public static enum STATUS { OK(200, "OK", false), CREATED(201, "Created", false), ACCEPTED(202, "Accepted", false),
+  public enum STATUS { OK(200, "OK", false), CREATED(201, "Created", false), ACCEPTED(202, "Accepted", false),
     CONFLICT(409, "Resource Conflict", true), NOT_FOUND(404, "Not Found", true), BAD_REQUEST(400, "Bad Request", true),
     UNAUTHORIZED(401, "Unauthorized", true), FORBIDDEN(403, "Forbidden", true),
     SERVER_ERROR(500, "Internal Server Error", true);
@@ -53,7 +53,7 @@ public class ResultStatus {
      * @param description  description
      * @param isErrorState whether this is an error state
      */
-    private STATUS(int code, String description, boolean isErrorState) {
+    STATUS(int code, String description, boolean isErrorState) {
       m_code = code;
       m_desc = description;
       m_isErrorState = isErrorState;

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/services/parsers/RequestBodyParser.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/parsers/RequestBodyParser.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/parsers/RequestBodyParser.java
index dc16b3e..49465c5 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/parsers/RequestBodyParser.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/parsers/RequestBodyParser.java
@@ -30,27 +30,27 @@ public interface RequestBodyParser {
   /**
    * RequestInfo category path.
    */
-  public static final String REQUEST_INFO_PATH = "RequestInfo";
+  String REQUEST_INFO_PATH = "RequestInfo";
 
   /**
    * Slash symbol
    */
-  public static final String SLASH = "/";
+  String SLASH = "/";
 
   /**
    * Category path to ignore parsing of the child node
    */
-  public static final String REQUEST_BLOB_TITLE = "RequestBodyInfo";
+  String REQUEST_BLOB_TITLE = "RequestBodyInfo";
 
   /**
    * Name of the query property which may exist under REQUEST_INFO_PATH.
    */
-  public static final String QUERY_FIELD_NAME = "query";
+  String QUERY_FIELD_NAME = "query";
 
   /**
    * Path to the body object.
    */
-  public static final String BODY_TITLE = "Body";
+  String BODY_TITLE = "Body";
 
   /**
    * Parse the provided string into request bodies based on the
@@ -60,5 +60,5 @@ public interface RequestBodyParser {
    *
    * @return a set of {@link RequestBody} instances
    */
-  public Set<RequestBody> parse(String body) throws BodyParseException;
+  Set<RequestBody> parse(String body) throws BodyParseException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/services/persistence/PersistenceManager.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/persistence/PersistenceManager.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/persistence/PersistenceManager.java
index 9a8b677..4cc4fa0 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/persistence/PersistenceManager.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/persistence/PersistenceManager.java
@@ -45,7 +45,7 @@ public interface PersistenceManager {
    * @throws NoSuchParentResourceException
    * @throws SystemException
    */
-  public RequestStatus create(ResourceInstance resource, RequestBody requestBody)
+  RequestStatus create(ResourceInstance resource, RequestBody requestBody)
       throws UnsupportedPropertyException,
              ResourceAlreadyExistsException,
              NoSuchParentResourceException,
@@ -62,7 +62,7 @@ public interface PersistenceManager {
    * @throws NoSuchParentResourceException
    * @throws NoSuchResourceException
    */
-  public RequestStatus update(ResourceInstance resource, RequestBody requestBody)
+  RequestStatus update(ResourceInstance resource, RequestBody requestBody)
       throws UnsupportedPropertyException, SystemException, NoSuchParentResourceException, NoSuchResourceException;
 
   /**
@@ -76,6 +76,6 @@ public interface PersistenceManager {
    * @throws NoSuchParentResourceException
    * @throws NoSuchResourceException
    */
-  public RequestStatus delete(ResourceInstance resource, RequestBody requestBody)
+  RequestStatus delete(ResourceInstance resource, RequestBody requestBody)
       throws UnsupportedPropertyException, SystemException, NoSuchParentResourceException, NoSuchResourceException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/StackAdvisorRequest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/StackAdvisorRequest.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/StackAdvisorRequest.java
index f5677c1..1f3e96e 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/StackAdvisorRequest.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/StackAdvisorRequest.java
@@ -200,7 +200,7 @@ public class StackAdvisorRequest {
 
     private String type;
 
-    private StackAdvisorRequestType(String type) {
+    StackAdvisorRequestType(String type) {
       this.type = type;
     }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandType.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandType.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandType.java
index 5aa1ea9..317b848 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandType.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandType.java
@@ -35,7 +35,7 @@ public enum StackAdvisorCommandType {
 
   private final String name;
 
-  private StackAdvisorCommandType(String name) {
+  StackAdvisorCommandType(String name) {
     this.name = name;
   }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/api/util/TreeNode.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/util/TreeNode.java b/ambari-server/src/main/java/org/apache/ambari/server/api/util/TreeNode.java
index 60d365f..144132f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/util/TreeNode.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/util/TreeNode.java
@@ -29,42 +29,42 @@ public interface TreeNode<T> {
    *
    * @return the parent node or null if this node is the root
    */
-  public TreeNode<T> getParent();
+  TreeNode<T> getParent();
 
   /**
    * Obtain the list of child nodes.
    *
    * @return a list of child nodes or an empty list if a leaf node
    */
-  public Collection<TreeNode<T>> getChildren();
+  Collection<TreeNode<T>> getChildren();
 
   /**
    * Obtain the object associated with this node.
    *
    * @return the object associated with this node or null
    */
-  public T getObject();
+  T getObject();
 
   /**
    * Obtain the name of the node.
    *
    * @return the name of the node or null
    */
-  public String getName();
+  String getName();
 
   /**
    * Set the name of the node.
    *
    * @param name the name to set
    */
-  public void setName(String name);
+  void setName(String name);
 
   /**
    * Set the parent node.
    *
    * @param parent the parent node to set
    */
-  public void setParent(TreeNode<T> parent);
+  void setParent(TreeNode<T> parent);
 
   /**
    * Add a child node for the provided object.
@@ -73,7 +73,7 @@ public interface TreeNode<T> {
    * @param name  the name of the child node
    * @return the newly created child node
    */
-  public TreeNode<T> addChild(T child, String name);
+  TreeNode<T> addChild(T child, String name);
 
   /**
    * Add the specified child node.
@@ -81,7 +81,7 @@ public interface TreeNode<T> {
    * @param child the child node to add
    * @return the added child node
    */
-  public TreeNode<T> addChild(TreeNode<T> child);
+  TreeNode<T> addChild(TreeNode<T> child);
 
   /**
    * Remove a child from this resource.
@@ -90,7 +90,7 @@ public interface TreeNode<T> {
    *
    * @return the previous value associated with key, or null if there was no mapping for key
    */
-  public TreeNode<T> removeChild(String name);
+  TreeNode<T> removeChild(String name);
 
   /**
    * Set a property on the node.
@@ -98,7 +98,7 @@ public interface TreeNode<T> {
    * @param name  the name of the property
    * @param value the value of the property
    */
-  public void setProperty(String name, Object value);
+  void setProperty(String name, Object value);
 
   /**
    * Get the specified node property.
@@ -106,7 +106,7 @@ public interface TreeNode<T> {
    * @param name property name
    * @return the requested property value or null
    */
-  public Object getProperty(String name);
+  Object getProperty(String name);
 
   /**
    * Get the specified node property as a String.
@@ -114,14 +114,14 @@ public interface TreeNode<T> {
    * @param name property name
    * @return the requested property value (as a String) or null
    */
-  public String getStringProperty(String name);
+  String getStringProperty(String name);
 
   /**
    * Remove a property from the node.
    *
    * @param name  name of property to be removed
    */
-  public void removeProperty(String name);
+  void removeProperty(String name);
 
   /**
    * Find a child node by name.
@@ -132,5 +132,5 @@ public interface TreeNode<T> {
    *
    * @return the requested node or null if the child was not found
    */
-  public TreeNode<T> getChild(String name);
+  TreeNode<T> getChild(String name);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/checks/UpgradeCheckGroup.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/checks/UpgradeCheckGroup.java b/ambari-server/src/main/java/org/apache/ambari/server/checks/UpgradeCheckGroup.java
index 67cf4f1..28ec1b1 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/checks/UpgradeCheckGroup.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/checks/UpgradeCheckGroup.java
@@ -99,7 +99,7 @@ public enum UpgradeCheckGroup {
    *
    * @param order
    */
-  private UpgradeCheckGroup(Float order) {
+  UpgradeCheckGroup(Float order) {
     m_order = order;
   }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/configuration/Configuration.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/configuration/Configuration.java b/ambari-server/src/main/java/org/apache/ambari/server/configuration/Configuration.java
index a8bfbf0..6f592f0 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/configuration/Configuration.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/configuration/Configuration.java
@@ -2770,7 +2770,7 @@ public class Configuration {
      * Constructor.
      *
      */
-    private DatabaseType(String databaseType) {
+    DatabaseType(String databaseType) {
       m_databaseType = databaseType;
     }
 
@@ -2805,7 +2805,7 @@ public class Configuration {
      *
      * @param name
      */
-    private ConnectionPoolType(String name) {
+    ConnectionPoolType(String name) {
       m_name = name;
     }
 
@@ -5914,7 +5914,7 @@ public class Configuration {
    */
   @Retention(RetentionPolicy.RUNTIME)
   @Target({ ElementType.TYPE, ElementType.FIELD, ElementType.METHOD })
-  static @interface ConfigurationMarkdown {
+  @interface ConfigurationMarkdown {
     /**
      * The base Markdown.
      *
@@ -5944,7 +5944,7 @@ public class Configuration {
    */
   @Retention(RetentionPolicy.RUNTIME)
   @Target({ ElementType.TYPE, ElementType.FIELD, ElementType.METHOD })
-  private static @interface ClusterScale {
+  private @interface ClusterScale {
     ClusterSizeType clusterSize();
     String value();
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementController.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementController.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementController.java
index 91bfe09..96bab85 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementController.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementController.java
@@ -365,28 +365,28 @@ public interface AmbariManagementController {
    *
    * @throws AmbariException if we fail to link the extension to the stack
    */
-  public void createExtensionLink(ExtensionLinkRequest request) throws AmbariException;
+  void createExtensionLink(ExtensionLinkRequest request) throws AmbariException;
 
   /**
    * Update a link between an extension and a stack
    *
    * @throws AmbariException if we fail to link the extension to the stack
    */
-  public void updateExtensionLink(ExtensionLinkRequest request) throws AmbariException;
+  void updateExtensionLink(ExtensionLinkRequest request) throws AmbariException;
 
   /**
    * Update a link between an extension and a stack
    *
    * @throws AmbariException if we fail to link the extension to the stack
    */
-  public void updateExtensionLink(ExtensionLinkEntity linkEntity) throws AmbariException;
+  void updateExtensionLink(ExtensionLinkEntity linkEntity) throws AmbariException;
 
   /**
    * Delete a link between an extension and a stack
    *
    * @throws AmbariException if we fail to unlink the extension from the stack
    */
-  public void deleteExtensionLink(ExtensionLinkRequest request) throws AmbariException;
+  void deleteExtensionLink(ExtensionLinkRequest request) throws AmbariException;
 
   /**
    * Get supported extensions.
@@ -395,7 +395,7 @@ public interface AmbariManagementController {
    * @return a set of extensions responses
    * @throws  AmbariException if the resources cannot be read
    */
-  public Set<ExtensionResponse> getExtensions(Set<ExtensionRequest> requests) throws AmbariException;
+  Set<ExtensionResponse> getExtensions(Set<ExtensionRequest> requests) throws AmbariException;
 
   /**
    * Get supported extension versions.
@@ -404,7 +404,7 @@ public interface AmbariManagementController {
    * @return a set of extension versions responses
    * @throws  AmbariException if the resources cannot be read
    */
-  public Set<ExtensionVersionResponse> getExtensionVersions(Set<ExtensionVersionRequest> requests) throws AmbariException;
+  Set<ExtensionVersionResponse> getExtensionVersions(Set<ExtensionVersionRequest> requests) throws AmbariException;
 
   /**
    * Get supported stacks versions.

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/KerberosHelper.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/KerberosHelper.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/KerberosHelper.java
index d000571..ca2dda5 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/KerberosHelper.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/KerberosHelper.java
@@ -680,6 +680,6 @@ public interface KerberosHelper {
      * @return the response
      * @throws AmbariException thrown if a problem occurred during invocation
      */
-    public T invoke(A arg) throws AmbariException;
+    T invoke(A arg) throws AmbariException;
   }
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/MaintenanceStateHelper.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/MaintenanceStateHelper.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/MaintenanceStateHelper.java
index f72f476..fd1d957 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/MaintenanceStateHelper.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/MaintenanceStateHelper.java
@@ -435,7 +435,7 @@ public class MaintenanceStateHelper {
    * {@link MaintenanceStateHelper#isOperationAllowed(org.apache.ambari.server.controller.spi.Resource.Type, Service)}
    * methods.
    */
-  public static interface HostPredicate {
+  public interface HostPredicate {
     /**
      * Gets whether the specified host should not be included in a result set.
      *
@@ -445,6 +445,6 @@ public class MaintenanceStateHelper {
      *         choice, {@code false} otherwise.
      * @throws AmbariException
      */
-    public boolean shouldHostBeRemoved(String hostname) throws AmbariException;
+    boolean shouldHostBeRemoved(String hostname) throws AmbariException;
   }
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/gsinstaller/GSInstallerStateProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/gsinstaller/GSInstallerStateProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/gsinstaller/GSInstallerStateProvider.java
index aef907c..3f9e272 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/gsinstaller/GSInstallerStateProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/gsinstaller/GSInstallerStateProvider.java
@@ -31,5 +31,5 @@ public interface GSInstallerStateProvider {
    *
    * @return true if the host component is healthy
    */
-  public boolean isHealthy(String hostName, String componentName);
+  boolean isHealthy(String hostName, String componentName);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/AbstractResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/AbstractResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/AbstractResourceProvider.java
index 01cf79a..8f23484 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/AbstractResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/AbstractResourceProvider.java
@@ -500,6 +500,6 @@ public abstract class AbstractResourceProvider extends BaseProvider implements R
      *
      * @throws AmbariException thrown if a problem occurred during invocation
      */
-    public T invoke() throws AmbariException, AuthorizationException;
+    T invoke() throws AmbariException, AuthorizationException;
   }
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ArtifactResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ArtifactResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ArtifactResourceProvider.java
index a6a731c..9e1fa53 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ArtifactResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ArtifactResourceProvider.java
@@ -549,7 +549,7 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
   /**
    * Used to register a dynamic sub-resource with an existing resource type.
    */
-  public static interface TypeRegistration {
+  public interface TypeRegistration {
     /**
      * Allows the management controller to be set on the registration.
      * This is called as part of the registration process.
@@ -558,14 +558,14 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      *
      * @param  controller  management controller
      */
-    public void setManagementController(AmbariManagementController controller);
+    void setManagementController(AmbariManagementController controller);
 
     /**
      * Get the type of the registering resource.
      *
      * @return type of the register resource
      */
-    public Resource.Type getType();
+    Resource.Type getType();
 
     /**
      * Full foreign key property name to use in the artifact resource.
@@ -575,7 +575,7 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      *          For example: "Artifacts/cluster_name
      */
     //todo: use relative property names
-    public String getFKPropertyName();
+    String getFKPropertyName();
 
     /**
      * Shortened foreign key name that is written to the database.
@@ -584,7 +584,7 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      *
      * @return short fk name.  For example: "cluster_name"
      */
-    public String getShortFKPropertyName();
+    String getShortFKPropertyName();
 
     /**
      * Convert the foreign key value to a value that is persisted to the database.
@@ -604,7 +604,7 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      *
      * @throws AmbariException if unable to convert the value
      */
-    public String toPersistId(String value) throws AmbariException;
+    String toPersistId(String value) throws AmbariException;
 
     /**
      * Convert the persist id form of the foreign key which is written to the database
@@ -624,7 +624,7 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      *
      * @throws AmbariException if unable to convert the value
      */
-    public String fromPersistId(String value) throws AmbariException;
+    String fromPersistId(String value) throws AmbariException;
 
     /**
      * Get a map of ancestor type to foreign key.
@@ -636,7 +636,7 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      * @return map of ancestor type to foreign key
      */
     //todo: look at the need to use the same name as specified by ancestors
-    public Map<Resource.Type, String> getForeignKeyInfo();
+    Map<Resource.Type, String> getForeignKeyInfo();
 
     /**
      * Determine if the instance identified by the provided properties exists.
@@ -648,8 +648,8 @@ public class ArtifactResourceProvider extends AbstractResourceProvider {
      *
      * @throws AmbariException  an exception occurs trying to determine if the instance exists
      */
-    public boolean instanceExists(Map<Resource.Type, String> keyMap,
-                                  Map<String, Object> properties) throws AmbariException;
+    boolean instanceExists(Map<Resource.Type, String> keyMap,
+                           Map<String, Object> properties) throws AmbariException;
   }
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/BlueprintConfigurationProcessor.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/BlueprintConfigurationProcessor.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/BlueprintConfigurationProcessor.java
index 88a8f80..bb771a5 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/BlueprintConfigurationProcessor.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/BlueprintConfigurationProcessor.java
@@ -2945,7 +2945,7 @@ public class BlueprintConfigurationProcessor {
    * if a given property should be included in an external
    * collection of properties.
    */
-  private static interface PropertyFilter {
+  private interface PropertyFilter {
 
     /**
      * Query to determine if a given property should be included in a collection of

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/JobResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/JobResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/JobResourceProvider.java
index 2c5741f..906f33c 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/JobResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/JobResourceProvider.java
@@ -177,7 +177,7 @@ public class JobResourceProvider extends
   /**
    * Simple interface for fetching jobs from db.
    */
-  public static interface JobFetcher {
+  public interface JobFetcher {
     /**
      * Fetch job resources.
      * 
@@ -191,8 +191,8 @@ public class JobResourceProvider extends
      *          the job id
      * @return a set of job resources
      */
-    public Set<Resource> fetchJobDetails(Set<String> requestedIds,
-        String clusterName, String workflowId, String jobId);
+    Set<Resource> fetchJobDetails(Set<String> requestedIds,
+                                  String clusterName, String workflowId, String jobId);
   }
 
   /**
@@ -315,7 +315,7 @@ public class JobResourceProvider extends
   /**
    * Enumeration of db fields for the job table.
    */
-  static enum JobFields {
+  enum JobFields {
     JOBID,
     JOBNAME,
     STATUS,

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ObservableResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ObservableResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ObservableResourceProvider.java
index c0c1dc4..77a9bbd 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ObservableResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ObservableResourceProvider.java
@@ -28,12 +28,12 @@ public interface ObservableResourceProvider {
    *
    * @param event  the event
    */
-  public void updateObservers(ResourceProviderEvent event);
+  void updateObservers(ResourceProviderEvent event);
 
   /**
    * Add an observer.
    *
    * @param observer  the observer
    */
-  public void addObserver(ResourceProviderObserver observer);
+  void addObserver(ResourceProviderObserver observer);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ResourceProviderObserver.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ResourceProviderObserver.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ResourceProviderObserver.java
index a5dd3df..d5dd199 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ResourceProviderObserver.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/ResourceProviderObserver.java
@@ -27,5 +27,5 @@ public interface ResourceProviderObserver {
    *
    * @param event the event
    */
-  public void update(ResourceProviderEvent event);
+  void update(ResourceProviderEvent event);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/TaskAttemptResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/TaskAttemptResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/TaskAttemptResourceProvider.java
index 32b7fec..5528480 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/TaskAttemptResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/TaskAttemptResourceProvider.java
@@ -182,7 +182,7 @@ public class TaskAttemptResourceProvider extends
   /**
    * Simple interface for fetching task attempts from db.
    */
-  public static interface TaskAttemptFetcher {
+  public interface TaskAttemptFetcher {
     /**
      * Fetch task attempt resources
      * 
@@ -198,9 +198,9 @@ public class TaskAttemptResourceProvider extends
      *          the task attempt id
      * @return a set of task attempt resources
      */
-    public Set<Resource> fetchTaskAttemptDetails(Set<String> requestedIds,
-        String clusterName, String workflowId, String jobId,
-        String taskAttemptId);
+    Set<Resource> fetchTaskAttemptDetails(Set<String> requestedIds,
+                                          String clusterName, String workflowId, String jobId,
+                                          String taskAttemptId);
   }
 
   /**
@@ -318,7 +318,7 @@ public class TaskAttemptResourceProvider extends
   /**
    * Enumeration of db fields for the task attempt table.
    */
-  static enum TaskAttemptFields {
+  enum TaskAttemptFields {
     JOBID,
     TASKATTEMPTID,
     TASKTYPE,

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetLayoutResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetLayoutResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetLayoutResourceProvider.java
index a40f165..77b9c4a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetLayoutResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetLayoutResourceProvider.java
@@ -70,7 +70,7 @@ public class WidgetLayoutResourceProvider extends AbstractControllerResourceProv
   public static final String WIDGETLAYOUT_WIDGETS_PROPERTY_ID = PropertyHelper.getPropertyId("WidgetLayoutInfo", "widgets");
   public static final String WIDGETLAYOUT_USERNAME_PROPERTY_ID = PropertyHelper.getPropertyId("WidgetLayoutInfo", "user_name");
   public static final String WIDGETLAYOUT_DISPLAY_NAME_PROPERTY_ID = PropertyHelper.getPropertyId("WidgetLayoutInfo", "display_name");
-  public static enum SCOPE {
+  public enum SCOPE {
     CLUSTER,
     USER
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetResourceProvider.java
index a3d3ab5..7ab5588 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WidgetResourceProvider.java
@@ -74,7 +74,7 @@ public class WidgetResourceProvider extends AbstractControllerResourceProvider {
   public static final String WIDGET_METRICS_PROPERTY_ID                 = PropertyHelper.getPropertyId("WidgetInfo", "metrics");
   public static final String WIDGET_VALUES_PROPERTY_ID                 = PropertyHelper.getPropertyId("WidgetInfo", "values");
   public static final String WIDGET_PROPERTIES_PROPERTY_ID                 = PropertyHelper.getPropertyId("WidgetInfo", "properties");
-  public static enum SCOPE {
+  public enum SCOPE {
     CLUSTER,
     USER
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WorkflowResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WorkflowResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WorkflowResourceProvider.java
index 9737aaa..4d082ddb 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WorkflowResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/internal/WorkflowResourceProvider.java
@@ -173,7 +173,7 @@ public class WorkflowResourceProvider extends
   /**
    * Simple interface for fetching workflows from db.
    */
-  public static interface WorkflowFetcher {
+  public interface WorkflowFetcher {
     /**
      * Fetch workflow resources.
      * 
@@ -185,8 +185,8 @@ public class WorkflowResourceProvider extends
      *          the workflow id
      * @return a set of workflow resources
      */
-    public Set<Resource> fetchWorkflows(Set<String> requestedIds,
-        String clusterName, String workflowId);
+    Set<Resource> fetchWorkflows(Set<String> requestedIds,
+                                 String clusterName, String workflowId);
   }
 
   /**
@@ -292,7 +292,7 @@ public class WorkflowResourceProvider extends
   /**
    * Enumeration of db fields for the workflow table.
    */
-  static enum WorkflowFields {
+  enum WorkflowFields {
     WORKFLOWID,
     WORKFLOWNAME,
     USERNAME,

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/ivory/IvoryService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/ivory/IvoryService.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/ivory/IvoryService.java
index aeeed0a..e089041 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/ivory/IvoryService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/ivory/IvoryService.java
@@ -31,7 +31,7 @@ public interface IvoryService {
    *
    * @param feed  the feed
    */
-  public void submitFeed(Feed feed);
+  void submitFeed(Feed feed);
 
   /**
    * Get a feed for the given name.
@@ -40,49 +40,49 @@ public interface IvoryService {
    *
    * @return a feed that matches the given name; null if none is found
    */
-  public Feed getFeed(String feedName);
+  Feed getFeed(String feedName);
 
   /**
    * Get all the known feed names.
    *
    * @return a list of feed names; may not be null
    */
-  public List<String> getFeedNames();
+  List<String> getFeedNames();
 
   /**
    * Update a feed based on the given {@link Feed} object.
    *
    * @param feed the feed object
    */
-  public void updateFeed(Feed feed);
+  void updateFeed(Feed feed);
 
   /**
    * Suspend the feed with the given feed name.
    *
    * @param feedName  the feed name
    */
-  public void suspendFeed(String feedName);
+  void suspendFeed(String feedName);
 
   /**
    * Resume the feed with the given feed name.
    *
    * @param feedName  the feed name
    */
-  public void resumeFeed(String feedName);
+  void resumeFeed(String feedName);
 
   /**
    * Schedule the feed with the given feed name.
    *
    * @param feedName  the feed name
    */
-  public void scheduleFeed(String feedName);
+  void scheduleFeed(String feedName);
 
   /**
    * Delete the feed with the given feed name.
    *
    * @param feedName the feed name
    */
-  public void deleteFeed(String feedName);
+  void deleteFeed(String feedName);
 
 
   // ----- Cluster operations ------------------------------------------------
@@ -92,7 +92,7 @@ public interface IvoryService {
    *
    * @param cluster  the cluster
    */
-  public void submitCluster(Cluster cluster);
+  void submitCluster(Cluster cluster);
 
   /**
    * Get a cluster for the given name.
@@ -101,28 +101,28 @@ public interface IvoryService {
    *
    * @return a cluster that matches the given name; null if none is found
    */
-  public Cluster getCluster(String clusterName);
+  Cluster getCluster(String clusterName);
 
   /**
    * Get all the known cluster names.
    *
    * @return a list of cluster names; may not be null
    */
-  public List<String> getClusterNames();
+  List<String> getClusterNames();
 
   /**
    * Update a cluster based on the given {@link Cluster} object.
    *
    * @param cluster  the cluster
    */
-  public void updateCluster(Cluster cluster);
+  void updateCluster(Cluster cluster);
 
   /**
    * Delete the cluster with the given name.
    *
    * @param clusterName  the cluster name
    */
-  public void deleteCluster(String clusterName);
+  void deleteCluster(String clusterName);
 
 
   // ----- Instance operations -----------------------------------------------
@@ -134,7 +134,7 @@ public interface IvoryService {
    *
    * @return the list of instances for the given feed
    */
-  public List<Instance> getInstances(String feedName); //read
+  List<Instance> getInstances(String feedName); //read
 
   /**
    * Suspend the instance for the given feed name and id.
@@ -142,7 +142,7 @@ public interface IvoryService {
    * @param feedName    the feed name
    * @param instanceId  the id
    */
-  public void suspendInstance(String feedName, String instanceId);
+  void suspendInstance(String feedName, String instanceId);
 
   /**
    * Resume the instance for the given feed name and id.
@@ -150,7 +150,7 @@ public interface IvoryService {
    * @param feedName    the feed name
    * @param instanceId  the id
    */
-  public void resumeInstance(String feedName, String instanceId);
+  void resumeInstance(String feedName, String instanceId);
 
   /**
    * Kill the instance for the given feed name and id.
@@ -158,5 +158,5 @@ public interface IvoryService {
    * @param feedName    the feed name
    * @param instanceId  the id
    */
-  public void killInstance(String feedName, String instanceId);
+  void killInstance(String feedName, String instanceId);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/jdbc/ConnectionFactory.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/jdbc/ConnectionFactory.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/jdbc/ConnectionFactory.java
index c8444b1..c65a4b2 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/jdbc/ConnectionFactory.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/jdbc/ConnectionFactory.java
@@ -32,5 +32,5 @@ public interface ConnectionFactory {
    *
    * @throws SQLException thrown if the connection cannot be obtained
    */
-  public Connection getConnection() throws SQLException;
+  Connection getConnection() throws SQLException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/jmx/JMXHostProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/jmx/JMXHostProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/jmx/JMXHostProvider.java
index bffe600..566d882 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/jmx/JMXHostProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/jmx/JMXHostProvider.java
@@ -35,7 +35,7 @@ public interface JMXHostProvider {
    * @return set of JMX host names
    *
    */
-  public Set<String> getHostNames(String clusterName, String componentName);
+  Set<String> getHostNames(String clusterName, String componentName);
 
   /**
    * Get the port for the specified cluster name and component.
@@ -48,7 +48,7 @@ public interface JMXHostProvider {
    *
    * @throws SystemException if unable to get the JMX port
    */
-  public String getPort(String clusterName, String componentName, String hostName)
+  String getPort(String clusterName, String componentName, String hostName)
       throws SystemException;
 
   /**
@@ -63,7 +63,7 @@ public interface JMXHostProvider {
    *
    * @throws SystemException if unable to get the JMX port
    */
-  public String getPort(String clusterName, String componentName, String hostName,  boolean httpsEnabled)
+  String getPort(String clusterName, String componentName, String hostName, boolean httpsEnabled)
       throws SystemException;
   
   /**
@@ -75,7 +75,7 @@ public interface JMXHostProvider {
    * @return the JMX protocol for the specified cluster name and component, one of http or https
    *
    */
-  public String getJMXProtocol(String clusterName, String componentName) ;
+  String getJMXProtocol(String clusterName, String componentName) ;
   
   /**
    * Get the rpc tag for the specified cluster name, component and port number
@@ -87,6 +87,6 @@ public interface JMXHostProvider {
    * @return the RPC tag for the specified cluster name, component and port number(client/healthcheck/etc.).
    *
    */
-  public String getJMXRpcMetricTag(String clusterName, String componentName, String port);
+  String getJMXRpcMetricTag(String clusterName, String componentName, String port);
 
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/logging/LoggingRequestHelper.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/logging/LoggingRequestHelper.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/logging/LoggingRequestHelper.java
index 7833e01..aa98715 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/logging/LoggingRequestHelper.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/logging/LoggingRequestHelper.java
@@ -29,7 +29,7 @@ public interface LoggingRequestHelper {
    *
    * @return a LogQueryResponse, containing the results of the search
    */
-  public LogQueryResponse sendQueryRequest(Map<String, String> queryParameters);
+  LogQueryResponse sendQueryRequest(Map<String, String> queryParameters);
 
   /**
    * Sends a request to obtain the log file name for a given component, on
@@ -41,7 +41,7 @@ public interface LoggingRequestHelper {
    * @return a Set of Strings that include the log file names associated
    *         with this component/host combination
    */
-  public Set<String> sendGetLogFileNamesRequest(String componentName, String hostName);
+  Set<String> sendGetLogFileNamesRequest(String componentName, String hostName);
 
   /**
    * Sends a request to obtain the log level counts for a given component on
@@ -53,7 +53,7 @@ public interface LoggingRequestHelper {
    * @return a LogLevelQueryResponse, containing the log level counts for this
    *         component/host combination
    */
-  public LogLevelQueryResponse sendLogLevelQueryRequest(String componentName, String hostName);
+  LogLevelQueryResponse sendLogLevelQueryRequest(String componentName, String hostName);
 
   /**
    * Appends the required LogSearch query parameters to a base URI
@@ -68,6 +68,6 @@ public interface LoggingRequestHelper {
    *         the log file associated with this component/host
    *         combination
    */
-  public String createLogFileTailURI(String baseURI, String componentName, String hostName);
+  String createLogFileTailURI(String baseURI, String componentName, String hostName);
 
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricHostProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricHostProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricHostProvider.java
index 8f1fc8e..9cfd1b2 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricHostProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricHostProvider.java
@@ -31,7 +31,7 @@ public interface MetricHostProvider {
    *
    * @throws org.apache.ambari.server.controller.spi.SystemException if unable to get the metrics server host name
    */
-  public String getCollectorHostName(String clusterName, MetricsService service) throws SystemException;
+  String getCollectorHostName(String clusterName, MetricsService service) throws SystemException;
 
   /**
    * Get the host name for the given cluster name and component name.
@@ -42,7 +42,7 @@ public interface MetricHostProvider {
    * @throws org.apache.ambari.server.controller.spi.SystemException
    *          if unable to get the JMX host name
    */
-  public String getHostName(String clusterName, String componentName) throws SystemException;
+  String getHostName(String clusterName, String componentName) throws SystemException;
 
   /**
    * Get the metrics server port for the given cluster name.
@@ -53,7 +53,7 @@ public interface MetricHostProvider {
    *
    * @throws org.apache.ambari.server.controller.spi.SystemException if unable to get the metrics server port
    */
-  public String getCollectorPort(String clusterName, MetricsService service) throws SystemException;
+  String getCollectorPort(String clusterName, MetricsService service) throws SystemException;
 
   /**
    * Get the status of metrics server host for the given cluster name.
@@ -64,7 +64,7 @@ public interface MetricHostProvider {
    *
    * @throws SystemException if unable to get the status of metrics server host
    */
-  public boolean isCollectorHostLive(String clusterName, MetricsService service) throws SystemException;
+  boolean isCollectorHostLive(String clusterName, MetricsService service) throws SystemException;
 
   /**
    * Get the status of metrics server component for the given cluster name.
@@ -75,5 +75,5 @@ public interface MetricHostProvider {
    *
    * @throws SystemException if unable to get the status of metrics server component
    */
-  public boolean isCollectorComponentLive(String clusterName, MetricsService service) throws SystemException;
+  boolean isCollectorComponentLive(String clusterName, MetricsService service) throws SystemException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsPaddingMethod.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsPaddingMethod.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsPaddingMethod.java
index 2fb2f18..cceaafb 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsPaddingMethod.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsPaddingMethod.java
@@ -29,7 +29,7 @@ public class MetricsPaddingMethod {
   private final PADDING_STRATEGY strategy;
   public static final String ZERO_PADDING_PARAM = "params/padding";
   private static final long MINIMUM_STEP_INTERVAL = 999l; // ~ 1 second
-  public static enum PADDING_STRATEGY {
+  public enum PADDING_STRATEGY {
     ZEROS,
     NULLS,
     NONE

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsServiceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsServiceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsServiceProvider.java
index f9f9dc6..c207de7 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsServiceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/metrics/MetricsServiceProvider.java
@@ -22,7 +22,7 @@ public interface MetricsServiceProvider {
   /**
    * Enumeration to distinguish metrics service installed for a cluster
    */
-  public enum MetricsService {
+  enum MetricsService {
     GANGLIA,
     TIMELINE_METRICS
   }
@@ -31,5 +31,5 @@ public interface MetricsServiceProvider {
    * Provide type of metrics service installed.
    * @return @MetricsService
    */
-  public MetricsService getMetricsServiceType();
+  MetricsService getMetricsServiceType();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/BasePredicate.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/BasePredicate.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/BasePredicate.java
index 9b3fbfe..6b14035 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/BasePredicate.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/BasePredicate.java
@@ -27,5 +27,5 @@ import org.apache.ambari.server.controller.spi.Predicate;
  * associated property ids.
  */
 public interface BasePredicate extends Predicate, PredicateVisitorAcceptor {
-  public Set<String> getPropertyIds();
+  Set<String> getPropertyIds();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitor.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitor.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitor.java
index 3316a00..061d79d 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitor.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitor.java
@@ -22,13 +22,13 @@ package org.apache.ambari.server.controller.predicate;
  */
 public interface PredicateVisitor {
 
-  public void acceptComparisonPredicate(ComparisonPredicate predicate);
+  void acceptComparisonPredicate(ComparisonPredicate predicate);
 
-  public void acceptArrayPredicate(ArrayPredicate predicate);
+  void acceptArrayPredicate(ArrayPredicate predicate);
 
-  public void acceptUnaryPredicate(UnaryPredicate predicate);
+  void acceptUnaryPredicate(UnaryPredicate predicate);
 
-  public void acceptAlwaysPredicate(AlwaysPredicate predicate);
+  void acceptAlwaysPredicate(AlwaysPredicate predicate);
 
-  public void acceptCategoryPredicate(CategoryPredicate predicate);
+  void acceptCategoryPredicate(CategoryPredicate predicate);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitorAcceptor.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitorAcceptor.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitorAcceptor.java
index 6af2cb8..0e90b27 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitorAcceptor.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/predicate/PredicateVisitorAcceptor.java
@@ -27,5 +27,5 @@ public interface PredicateVisitorAcceptor {
    *
    * @param visitor  the visitor
    */
-  public void accept(PredicateVisitor visitor);
+  void accept(PredicateVisitor visitor);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ExtendedResourceProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ExtendedResourceProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ExtendedResourceProvider.java
index 134ff2c..5d30226 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ExtendedResourceProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ExtendedResourceProvider.java
@@ -41,7 +41,7 @@ public interface ExtendedResourceProvider extends ResourceProvider {
    * @throws NoSuchResourceException the requested resource instance doesn't exist
    * @throws NoSuchParentResourceException a parent resource of the requested resource doesn't exist
    */
-  public QueryResponse queryForResources(Request request, Predicate predicate)
+  QueryResponse queryForResources(Request request, Predicate predicate)
       throws SystemException,
       UnsupportedPropertyException,
       NoSuchResourceException,


[2/3] ambari git commit: AMBARI-19149. Code cleanup: redundant modifiers (interfaces, enums)

Posted by ad...@apache.org.
http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageRequest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageRequest.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageRequest.java
index bb30ac2..c225d4d 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageRequest.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageRequest.java
@@ -28,14 +28,14 @@ public interface PageRequest {
    *
    * @return the starting point
    */
-  public StartingPoint getStartingPoint();
+  StartingPoint getStartingPoint();
 
   /**
    * Get the desired page size.
    *
    * @return the page size; -1 means from the starting point to the end of the resource set
    */
-  public int getPageSize();
+  int getPageSize();
 
   /**
    * Get the offset (zero based) of the resource that should be used as the start or end
@@ -43,7 +43,7 @@ public interface PageRequest {
    *
    * @return the offset
    */
-  public int getOffset();
+  int getOffset();
 
   /**
    * Return the predicate that identifies the single resource to be used
@@ -51,12 +51,12 @@ public interface PageRequest {
    *
    * @return the associated predicate
    */
-  public Predicate getPredicate();
+  Predicate getPredicate();
 
   /**
    * The desired starting point of the page being requested.
    */
-  public enum StartingPoint {
+  enum StartingPoint {
     Beginning,      // start the page from the beginning of the resource set
     End,            // end the page at the end of the resource set
     OffsetStart,    // start the page from the associated offset point

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageResponse.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageResponse.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageResponse.java
index 9e4d6ab..3bc5b58 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageResponse.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PageResponse.java
@@ -27,32 +27,32 @@ public interface PageResponse {
    *
    * @return the iterable set of resources
    */
-  public Iterable<Resource> getIterable();
+  Iterable<Resource> getIterable();
 
   /**
    * Get the offset of the first resource of the page.
    *
    * @return the offset
    */
-  public int getOffset();
+  int getOffset();
 
   /**
    * Get the last resource before this page.
    *
    * @return the last resource before this page; null if this is the first page
    */
-  public Resource getPreviousResource();
+  Resource getPreviousResource();
 
   /**
    * Get the next resource after this page.
    *
    * @return the next resource after this page; null if this is the last page
    */
-  public Resource getNextResource();
+  Resource getNextResource();
 
   /**
    * Get the count of total resources without account for paging request.
    * @return total count
    */
-  public Integer getTotalResourceCount();
+  Integer getTotalResourceCount();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Predicate.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Predicate.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Predicate.java
index ae24b06..52b668f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Predicate.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Predicate.java
@@ -29,5 +29,5 @@ public interface Predicate {
    * @param resource the resource to evaluate the predicate against
    * @return the result of applying the predicate to the given resource
    */
-  public boolean evaluate(Resource resource);
+  boolean evaluate(Resource resource);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PropertyProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PropertyProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PropertyProvider.java
index 6829c1b..1b72b24 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PropertyProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/PropertyProvider.java
@@ -40,7 +40,7 @@ public interface PropertyProvider {
    *
    * @throws SystemException thrown if resources cannot be populated
    */
-  public Set<Resource> populateResources(Set<Resource> resources, Request request, Predicate predicate)
+  Set<Resource> populateResources(Set<Resource> resources, Request request, Predicate predicate)
       throws SystemException;
 
   /**
@@ -51,5 +51,5 @@ public interface PropertyProvider {
    *         supported by this resource provider.  An empty return set indicates
    *         that all of the given property ids are supported.
    */
-  public Set<String> checkPropertyIds(Set<String> propertyIds);
+  Set<String> checkPropertyIds(Set<String> propertyIds);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ProviderModule.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ProviderModule.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ProviderModule.java
index 33dfc24..27c60a2 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ProviderModule.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ProviderModule.java
@@ -31,7 +31,7 @@ public interface ProviderModule {
    *
    * @return the resource adapter
    */
-  public ResourceProvider getResourceProvider(Resource.Type type);
+  ResourceProvider getResourceProvider(Resource.Type type);
 
   /**
    * Get the list of property providers for the given resource type.
@@ -40,5 +40,5 @@ public interface ProviderModule {
    *
    * @return the list of property providers
    */
-  public List<PropertyProvider> getPropertyProviders(Resource.Type type);
+  List<PropertyProvider> getPropertyProviders(Resource.Type type);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/QueryResponse.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/QueryResponse.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/QueryResponse.java
index 66bd3b0..9ce8559 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/QueryResponse.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/QueryResponse.java
@@ -31,21 +31,21 @@ public interface QueryResponse {
    *
    * @return the set of resources
    */
-  public Set<Resource> getResources();
+  Set<Resource> getResources();
 
   /**
    * Determine whether or not the response is sorted.
    *
    * @return {@code true} if the response is sorted
    */
-  public boolean isSortedResponse();
+  boolean isSortedResponse();
 
   /**
    * Determine whether or not the response is paginated.
    *
    * @return {@code true} if the response is paginated
    */
-  public boolean isPagedResponse();
+  boolean isPagedResponse();
 
   /**
    * Get the the total number of resources for the query result.
@@ -54,5 +54,5 @@ public interface QueryResponse {
    *
    * @return total the total number of resources in the query result
    */
-  public int getTotalResourceCount();
+  int getTotalResourceCount();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/RequestStatus.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/RequestStatus.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/RequestStatus.java
index 0ebf93a..6c80273 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/RequestStatus.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/RequestStatus.java
@@ -31,28 +31,28 @@ public interface RequestStatus {
    *
    * @return the set of resources
    */
-  public Set<Resource> getAssociatedResources();
+  Set<Resource> getAssociatedResources();
 
   /**
    * Get the resource of type request for the asynchronous request.
    *
    * @return the request resource
    */
-  public Resource getRequestResource();
+  Resource getRequestResource();
 
   /**
    * Get the status of the operation initiated by the request.
    *
    * @return the status
    */
-  public Status getStatus();
+  Status getStatus();
 
   RequestStatusMetaData getStatusMetadata();
 
   /**
    * Request status.
    */
-  public enum Status {
+  enum Status {
     Accepted,
     InProgress,
     Complete

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ResourcePredicateEvaluator.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ResourcePredicateEvaluator.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ResourcePredicateEvaluator.java
index 425ef45..abd933a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ResourcePredicateEvaluator.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/ResourcePredicateEvaluator.java
@@ -26,5 +26,5 @@ public interface ResourcePredicateEvaluator {
    *
    * @return true if the predicate evaluates to true for the resource
    */
-  public boolean evaluate(Predicate predicate, Resource resource);
+  boolean evaluate(Predicate predicate, Resource resource);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Schema.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Schema.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Schema.java
index bcb3291..c97df46 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Schema.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/Schema.java
@@ -39,7 +39,7 @@ public interface Schema {
    * @param type the resource type
    * @return the key property id for the given resource type
    */
-  public String getKeyPropertyId(Resource.Type type);
+  String getKeyPropertyId(Resource.Type type);
 
   /**
    * Get the set of resource types used in the key that uniquely identifies
@@ -52,5 +52,5 @@ public interface Schema {
    * @return the set of resource types used in the key that uniquely identifies
    *         the resource type described by this schema.
    */
-  public Set<Resource.Type> getKeyTypes();
+  Set<Resource.Type> getKeyTypes();
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SchemaFactory.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SchemaFactory.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SchemaFactory.java
index 290b508..d591630 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SchemaFactory.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SchemaFactory.java
@@ -28,5 +28,5 @@ public interface SchemaFactory {
    * @param type  resource type
    * @return schema instance for the specified type
    */
-  public Schema getSchema(Resource.Type type);
+  Schema getSchema(Resource.Type type);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SortRequest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SortRequest.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SortRequest.java
index 9f7f6ab..e2bbd51 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SortRequest.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/spi/SortRequest.java
@@ -27,17 +27,17 @@ public interface SortRequest {
   /**
    * Get a list of @SortRequestProperty.
    */
-  public List<SortRequestProperty> getProperties();
+  List<SortRequestProperty> getProperties();
 
   /**
    * Get a list of propertyIds
    */
-  public List<String> getPropertyIds();
+  List<String> getPropertyIds();
 
   /**
    * Enumeration for order of sorting
    */
-  public enum Order {
+  enum Order {
     ASC,
     DESC
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/controller/utilities/StreamProvider.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/utilities/StreamProvider.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/utilities/StreamProvider.java
index 098393f..350c4da 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/utilities/StreamProvider.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/utilities/StreamProvider.java
@@ -25,6 +25,6 @@ import java.io.InputStream;
  * A provider of input stream from a property source.
  */
 public interface StreamProvider {
-  public InputStream readFrom(String spec) throws IOException;
-  public InputStream readFrom(String spec, String requestMethod, String params) throws IOException;
+  InputStream readFrom(String spec) throws IOException;
+  InputStream readFrom(String spec, String requestMethod, String params) throws IOException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/notifications/DispatchCallback.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/notifications/DispatchCallback.java b/ambari-server/src/main/java/org/apache/ambari/server/notifications/DispatchCallback.java
index e4e944d..b9861b4 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/notifications/DispatchCallback.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/notifications/DispatchCallback.java
@@ -36,7 +36,7 @@ public interface DispatchCallback {
    *          a list of unique IDs that the caller can use to identify the
    *          {@link Notification} that was dispatched.
    */
-  public void onSuccess(List<String> callbackIds);
+  void onSuccess(List<String> callbackIds);
 
   /**
    * Invoked when a {@link Notification} failed to be dispatched.
@@ -45,6 +45,6 @@ public interface DispatchCallback {
    *          a list of unique IDs that the caller can use to identify the
    *          {@link Notification} that was dispatched.
    */
-  public void onFailure(List<String> callbackIds);
+  void onFailure(List<String> callbackIds);
 
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/orm/JPATableGenerationStrategy.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/orm/JPATableGenerationStrategy.java b/ambari-server/src/main/java/org/apache/ambari/server/orm/JPATableGenerationStrategy.java
index 9316c10..ccc8db8 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/orm/JPATableGenerationStrategy.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/orm/JPATableGenerationStrategy.java
@@ -30,7 +30,7 @@ public enum JPATableGenerationStrategy {
 
   private String value;
 
-  private JPATableGenerationStrategy(String value) {
+  JPATableGenerationStrategy(String value) {
     this.value = value;
   }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/ConfigGroupHostMapping.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/ConfigGroupHostMapping.java b/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/ConfigGroupHostMapping.java
index ae3f076..16af596 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/ConfigGroupHostMapping.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/ConfigGroupHostMapping.java
@@ -23,13 +23,13 @@ import org.apache.ambari.server.state.configgroup.ConfigGroup;
 
 public interface ConfigGroupHostMapping {
   
-  public Long getConfigGroupId();
-  public Long getHostId();
-  public Host getHost();
-  public ConfigGroup getConfigGroup();
+  Long getConfigGroupId();
+  Long getHostId();
+  Host getHost();
+  ConfigGroup getConfigGroup();
   
-  public void setConfigGroupId(Long configGroupId);
-  public void setHostId(Long setHostId);
-  public void setHost(Host host);
-  public void setConfigGroup(ConfigGroup configGroup);
+  void setConfigGroupId(Long configGroupId);
+  void setHostId(Long setHostId);
+  void setHost(Host host);
+  void setConfigGroup(ConfigGroup configGroup);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/HostConfigMapping.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/HostConfigMapping.java b/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/HostConfigMapping.java
index d5afc15..27f2da4 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/HostConfigMapping.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/orm/cache/HostConfigMapping.java
@@ -19,27 +19,27 @@ package org.apache.ambari.server.orm.cache;
 
 public interface HostConfigMapping {
   
-  public Long getClusterId();
-  public void setClusterId(Long clusterId);
+  Long getClusterId();
+  void setClusterId(Long clusterId);
 
-  public Long getHostId();
-  public void setHostId(Long hostId);
+  Long getHostId();
+  void setHostId(Long hostId);
   
-  public String getType();
-  public void setType(String type);
+  String getType();
+  void setType(String type);
   
-  public Long getCreateTimestamp();
-  public void setCreateTimestamp(Long createTimestamp);
+  Long getCreateTimestamp();
+  void setCreateTimestamp(Long createTimestamp);
   
-  public String getVersion();
-  public void setVersion(String version);
+  String getVersion();
+  void setVersion(String version);
   
-  public String getServiceName();
-  public void setServiceName(String serviceName);
+  String getServiceName();
+  void setServiceName(String serviceName);
   
-  public String getUser();
-  public void setUser(String user);
+  String getUser();
+  void setUser(String user);
   
-  public Integer getSelected();
-  public void setSelected(Integer selected);
+  Integer getSelected();
+  void setSelected(Integer selected);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/orm/entities/BlueprintConfiguration.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/orm/entities/BlueprintConfiguration.java b/ambari-server/src/main/java/org/apache/ambari/server/orm/entities/BlueprintConfiguration.java
index 36dde73..cddac9b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/orm/entities/BlueprintConfiguration.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/orm/entities/BlueprintConfiguration.java
@@ -27,28 +27,28 @@ public interface BlueprintConfiguration {
    *
    * @param type configuration type
    */
-  public void setType(String type);
+  void setType(String type);
 
   /**
    * Get the configuration type.
    *
    * @return configuration type
    */
-  public String getType();
+  String getType();
 
   /**
    * Set the blueprint name.
    *
    * @param blueprintName  blueprint name
    */
-  public void setBlueprintName(String blueprintName);
+  void setBlueprintName(String blueprintName);
 
   /**
    * Get the blueprint name.
    *
    * @return blueprint name
    */
-  public String getBlueprintName();
+  String getBlueprintName();
 
   /**
    * Set the configuration properties.
@@ -57,21 +57,21 @@ public interface BlueprintConfiguration {
    *
    * @param configData json representation of property map
    */
-  public void setConfigData(String configData);
+  void setConfigData(String configData);
 
   /**
    * Get the configuration properties.
    *
    * @return json representation of property map
    */
-  public String getConfigData();
+  String getConfigData();
 
   /**
    * Get the configuration attributes.
    *
    * @return json representation of attributes map
    */
-  public String getConfigAttributes();
+  String getConfigAttributes();
 
   /**
    * Set the configuration attributes.
@@ -80,5 +80,5 @@ public interface BlueprintConfiguration {
    *
    * @param configAttributes json representation of attributes map
    */
-  public void setConfigAttributes(String configAttributes);
+  void setConfigAttributes(String configAttributes);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionJob.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionJob.java b/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionJob.java
index ff83729..6180c53 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionJob.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionJob.java
@@ -23,12 +23,12 @@ import org.quartz.Job;
  * Type of Quartz Job that can be executed by the @ExecutionScheduleManager
  */
 public interface ExecutionJob extends Job {
-  public static final String NEXT_EXECUTION_JOB_NAME_KEY = "ExecutionJob.Name";
-  public static final String NEXT_EXECUTION_JOB_GROUP_KEY = "ExecutionJob.Group";
-  public static final String NEXT_EXECUTION_SEPARATION_SECONDS =
+  String NEXT_EXECUTION_JOB_NAME_KEY = "ExecutionJob.Name";
+  String NEXT_EXECUTION_JOB_GROUP_KEY = "ExecutionJob.Group";
+  String NEXT_EXECUTION_SEPARATION_SECONDS =
     "ExecutionJob.SeparationMinutes";
-  public static final String LINEAR_EXECUTION_JOB_GROUP =
+  String LINEAR_EXECUTION_JOB_GROUP =
     "LinearExecutionJobs";
-  public static final String LINEAR_EXECUTION_TRIGGER_GROUP =
+  String LINEAR_EXECUTION_TRIGGER_GROUP =
     "LinearExecutionTriggers";
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionScheduler.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionScheduler.java b/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionScheduler.java
index bb0a6c0..c184f08 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionScheduler.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/scheduler/ExecutionScheduler.java
@@ -30,27 +30,27 @@ public interface ExecutionScheduler {
    * Initialize and start the scheduler to accept jobs.
    * @throws AmbariException
    */
-  public void startScheduler(Integer delay) throws AmbariException;
+  void startScheduler(Integer delay) throws AmbariException;
 
   /**
    * Shutdown the scheduler threads and do not accept any more jobs.
    * @throws AmbariException
    */
-  public void stopScheduler() throws AmbariException;
+  void stopScheduler() throws AmbariException;
 
   /**
    * Add a trigger to the execution scheduler
    * @param trigger
    * @throws SchedulerException
    */
-  public void scheduleJob(Trigger trigger) throws SchedulerException;
+  void scheduleJob(Trigger trigger) throws SchedulerException;
 
   /**
    * Persist job data
    * @param job
    * @throws SchedulerException
    */
-  public void addJob(JobDetail job) throws SchedulerException;
+  void addJob(JobDetail job) throws SchedulerException;
 
 
   /**
@@ -58,14 +58,14 @@ public interface ExecutionScheduler {
    * @param jobKey
    * @throws SchedulerException
    */
-  public void deleteJob(JobKey jobKey) throws SchedulerException;
+  void deleteJob(JobKey jobKey) throws SchedulerException;
 
   /**
    * Get details for a job from scheduler.
    * @param jobKey
    * @return
    */
-  public JobDetail getJobDetail(JobKey jobKey) throws SchedulerException;
+  JobDetail getJobDetail(JobKey jobKey) throws SchedulerException;
 
   /**
    * Get all triggers created for a job.
@@ -73,12 +73,12 @@ public interface ExecutionScheduler {
    * @return
    * @throws SchedulerException
    */
-  public List<? extends Trigger> getTriggersForJob(JobKey jobKey)
+  List<? extends Trigger> getTriggersForJob(JobKey jobKey)
     throws SchedulerException;
 
   /**
    * Check whether the scheduler is already running.
    * @return
    */
-  public boolean isSchedulerStarted() throws SchedulerException;
+  boolean isSchedulerStarted() throws SchedulerException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/security/SecurityHelper.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/security/SecurityHelper.java b/ambari-server/src/main/java/org/apache/ambari/server/security/SecurityHelper.java
index d4fdcf5..cb7413f 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/security/SecurityHelper.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/security/SecurityHelper.java
@@ -32,12 +32,12 @@ public interface SecurityHelper {
    *
    * @return the current user.
    */
-  public String getCurrentUserName();
+  String getCurrentUserName();
 
   /**
    * Get the granted authorities for the current user.
    *
    * @return the granted authorities
    */
-  public Collection<? extends GrantedAuthority> getCurrentAuthorities();
+  Collection<? extends GrantedAuthority> getCurrentAuthorities();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/security/authorization/ResourceType.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/security/authorization/ResourceType.java b/ambari-server/src/main/java/org/apache/ambari/server/security/authorization/ResourceType.java
index 40a10e9..9b94437 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/security/authorization/ResourceType.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/security/authorization/ResourceType.java
@@ -37,7 +37,7 @@ public enum ResourceType {
    *
    * @param id the ID value for this ResourceType
    */
-  private ResourceType(int id) {
+  ResourceType(int id) {
     this.id = id;
   }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/security/encryption/MasterKeyService.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/security/encryption/MasterKeyService.java b/ambari-server/src/main/java/org/apache/ambari/server/security/encryption/MasterKeyService.java
index 895b8a3..ef3779d 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/security/encryption/MasterKeyService.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/security/encryption/MasterKeyService.java
@@ -18,6 +18,6 @@
 package org.apache.ambari.server.security.encryption;
 
 public interface MasterKeyService {
-  public char[] getMasterSecret();
-  public boolean isMasterKeyInitialized();
+  char[] getMasterSecret();
+  boolean isMasterKeyInitialized();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosConfigDataFile.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosConfigDataFile.java b/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosConfigDataFile.java
index 82b9225..b2bba22 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosConfigDataFile.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosConfigDataFile.java
@@ -23,13 +23,13 @@ package org.apache.ambari.server.serveraction.kerberos;
  * for the Kerberos configuration data files.
  */
 public interface KerberosConfigDataFile extends KerberosDataFile {
-  public static final String DATA_FILE_NAME = "configs.dat";
+  String DATA_FILE_NAME = "configs.dat";
 
-  public static final String CONFIGURATION_TYPE = "config";
-  public static final String KEY = "key";
-  public static final String VALUE = "value";
-  public static final String OPERATION = "operation";
+  String CONFIGURATION_TYPE = "config";
+  String KEY = "key";
+  String VALUE = "value";
+  String OPERATION = "operation";
 
-  public static final String OPERATION_TYPE_SET = "SET";
-  public static final String OPERATION_TYPE_REMOVE = "REMOVE";
+  String OPERATION_TYPE_SET = "SET";
+  String OPERATION_TYPE_REMOVE = "REMOVE";
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosIdentityDataFile.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosIdentityDataFile.java b/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosIdentityDataFile.java
index 3c14627..81e345a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosIdentityDataFile.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/serveraction/kerberos/KerberosIdentityDataFile.java
@@ -23,19 +23,19 @@ package org.apache.ambari.server.serveraction.kerberos;
  * for the Kerberos action (metadata) data files.
  */
 public interface KerberosIdentityDataFile extends KerberosDataFile {
-  public static final String DATA_FILE_NAME = "identity.dat";
+  String DATA_FILE_NAME = "identity.dat";
 
-  public static final String HOSTNAME = "hostname";
-  public static final String SERVICE = "service";
-  public static final String COMPONENT = "component";
-  public static final String PRINCIPAL = "principal";
-  public static final String PRINCIPAL_TYPE = "principal_type";
-  public static final String KEYTAB_FILE_PATH = "keytab_file_path";
-  public static final String KEYTAB_FILE_OWNER_NAME = "keytab_file_owner_name";
-  public static final String KEYTAB_FILE_OWNER_ACCESS = "keytab_file_owner_access";
-  public static final String KEYTAB_FILE_GROUP_NAME = "keytab_file_group_name";
-  public static final String KEYTAB_FILE_GROUP_ACCESS = "keytab_file_group_access";
-  public static final String KEYTAB_FILE_IS_CACHABLE = "keytab_file_is_cachable";
+  String HOSTNAME = "hostname";
+  String SERVICE = "service";
+  String COMPONENT = "component";
+  String PRINCIPAL = "principal";
+  String PRINCIPAL_TYPE = "principal_type";
+  String KEYTAB_FILE_PATH = "keytab_file_path";
+  String KEYTAB_FILE_OWNER_NAME = "keytab_file_owner_name";
+  String KEYTAB_FILE_OWNER_ACCESS = "keytab_file_owner_access";
+  String KEYTAB_FILE_GROUP_NAME = "keytab_file_group_name";
+  String KEYTAB_FILE_GROUP_ACCESS = "keytab_file_group_access";
+  String KEYTAB_FILE_IS_CACHABLE = "keytab_file_is_cachable";
 
 
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/stack/ConfigurationInfo.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/stack/ConfigurationInfo.java b/ambari-server/src/main/java/org/apache/ambari/server/stack/ConfigurationInfo.java
index f8a19ac..51deeb7 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/stack/ConfigurationInfo.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/stack/ConfigurationInfo.java
@@ -153,7 +153,7 @@ public class ConfigurationInfo implements Validable{
    * For example, Hadoop configuration types like 'core-site' and 'hdfs-site'
    * can support the ability to define certain configs as 'final'.
    */
-  public static enum Supports {
+  public enum Supports {
 
     FINAL("supports_final"),
     ADDING_FORBIDDEN("supports_adding_forbidden"),
@@ -164,11 +164,11 @@ public class ConfigurationInfo implements Validable{
     private String defaultValue;
     private String xmlAttributeName;
 
-    private Supports(String xmlAttributeName) {
+    Supports(String xmlAttributeName) {
       this(xmlAttributeName, Boolean.FALSE.toString());
     }
 
-    private Supports(String xmlAttributeName, String defaultValue) {
+    Supports(String xmlAttributeName, String defaultValue) {
       this.defaultValue = defaultValue;
       this.xmlAttributeName = xmlAttributeName;
     }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/stack/StackDefinitionModule.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/stack/StackDefinitionModule.java b/ambari-server/src/main/java/org/apache/ambari/server/stack/StackDefinitionModule.java
index c5ce976..5e095a1 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/stack/StackDefinitionModule.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/stack/StackDefinitionModule.java
@@ -41,33 +41,33 @@ public interface StackDefinitionModule <T, I> {
    *
    * @throws AmbariException if resolution fails
    */
-  public void resolve(T parent, Map<String, StackModule> allStacks, Map<String, ServiceModule> commonServices, Map<String, ExtensionModule> extensions) throws AmbariException;
+  void resolve(T parent, Map<String, StackModule> allStacks, Map<String, ServiceModule> commonServices, Map<String, ExtensionModule> extensions) throws AmbariException;
 
   /**
    * Obtain the associated module information.
    *
    * @return associated module information
    */
-  public I getModuleInfo();
+  I getModuleInfo();
 
   /**
    * Determine whether the module has been marked for deletion.
    *
    * @return true if the module is marked for deletion; otherwise false
    */
-  public boolean isDeleted();
+  boolean isDeleted();
 
   /**
    * Obtain the id of the module.
    *
    * @return module id
    */
-  public String getId();
+  String getId();
 
   /**
    * Lifecycle even which is called when the associated stack has been fully resolved.
    */
-  public void finalizeModule();
+  void finalizeModule();
 
   /**
    * Module state.
@@ -77,17 +77,17 @@ public interface StackDefinitionModule <T, I> {
    *
    * @return the module state
    */
-  public ModuleState getModuleState();
+  ModuleState getModuleState();
   
   /**
    * 
    * @return valid module flag
    */
-  public boolean isValid();
+  boolean isValid();
 
   /**
    * 
    * @param valid set validity flag
    */
-  public void setValid(boolean valid);
+  void setValid(boolean valid);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/stack/Validable.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/stack/Validable.java b/ambari-server/src/main/java/org/apache/ambari/server/stack/Validable.java
index 0a557b4..0f9b367 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/stack/Validable.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/stack/Validable.java
@@ -30,19 +30,19 @@ public interface Validable {
    * 
    * @return valid xml flag
    */
-  public boolean isValid();
+  boolean isValid();
 
   /**
    * 
    * @param valid set validity flag
    */
-  public void setValid(boolean valid);
+  void setValid(boolean valid);
   
-  public void addError(String error);
+  void addError(String error);
   
-  public void addErrors(Collection<String> errors);
+  void addErrors(Collection<String> errors);
   
-  public Collection<String> getErrors();
+  Collection<String> getErrors();
   
   
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/Cluster.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/Cluster.java b/ambari-server/src/main/java/org/apache/ambari/server/state/Cluster.java
index 9594803..c961995 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/Cluster.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/Cluster.java
@@ -200,7 +200,7 @@ public interface Cluster {
    * @param stackId the stack id
    * @param cascade {@code true} to cascade the desired version
    */
-  public void setDesiredStackVersion(StackId stackId, boolean cascade) throws AmbariException;
+  void setDesiredStackVersion(StackId stackId, boolean cascade) throws AmbariException;
 
 
   /**
@@ -437,7 +437,7 @@ public interface Cluster {
    * @param serviceName service name
    * @return
    */
-  public List<ServiceConfigVersionResponse> getActiveServiceConfigVersionResponse(String serviceName);
+  List<ServiceConfigVersionResponse> getActiveServiceConfigVersionResponse(String serviceName);
 
   /**
    * Get service config version history

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/CommandScriptDefinition.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/CommandScriptDefinition.java b/ambari-server/src/main/java/org/apache/ambari/server/state/CommandScriptDefinition.java
index cee55fa..ed565d0 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/CommandScriptDefinition.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/CommandScriptDefinition.java
@@ -57,7 +57,7 @@ public class CommandScriptDefinition {
     return timeout;
   }
 
-  public static enum Type {
+  public enum Type {
     PYTHON
   }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/Config.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/Config.java b/ambari-server/src/main/java/org/apache/ambari/server/state/Config.java
index 67570f4..4346cf5 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/Config.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/Config.java
@@ -33,53 +33,53 @@ public interface Config {
   /**
    * @return Config Type
    */
-  public String getType();
+  String getType();
 
   /**
    * @return Version Tag this config instance is mapped to
    */
-  public String getTag();
+  String getTag();
 
   /**
    * Gets the stack that this configuration belongs to.
    *
    * @return the stack (not {@code null).
    */
-  public StackId getStackId();
+  StackId getStackId();
 
   /**
    *
    * @return version of config by type
    */
-  public Long getVersion();
+  Long getVersion();
 
   /**
    * @return Properties that define this config instance
    */
-  public Map<String, String> getProperties();
+  Map<String, String> getProperties();
 
   /**
    * @return Map of attributes in this config-type to value per property
    */
-  public Map<String, Map<String, String>> getPropertiesAttributes();
+  Map<String, Map<String, String>> getPropertiesAttributes();
 
   /**
    * Replace properties with new provided set
    * @param properties Property Map to replace existing one
    */
-  public void setProperties(Map<String, String> properties);
+  void setProperties(Map<String, String> properties);
 
   /**
    * Replace property attributes with new provided set
    * @param propertiesAttributes Property Attributes Map to replace existing one
    */
-  public void setPropertiesAttributes(Map<String, Map<String, String>> propertiesAttributes);
+  void setPropertiesAttributes(Map<String, Map<String, String>> propertiesAttributes);
 
   /**
    * Update provided properties' values.
    * @param properties Property Map with updated values
    */
-  public void updateProperties(Map<String, String> properties);
+  void updateProperties(Map<String, String> properties);
 
   /**
    * Ger service config versions containing this config
@@ -91,10 +91,10 @@ public interface Config {
    * Delete certain properties
    * @param properties Property keys to be deleted
    */
-  public void deleteProperties(List<String> properties);
+  void deleteProperties(List<String> properties);
 
   /**
    * Persist the configuration.
    */
-  public void save();
+  void save();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/HostHealthStatus.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/HostHealthStatus.java b/ambari-server/src/main/java/org/apache/ambari/server/state/HostHealthStatus.java
index fb8fe96..0893548 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/HostHealthStatus.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/HostHealthStatus.java
@@ -46,7 +46,7 @@ public class HostHealthStatus {
     return healthReport;
   }
 
-  public static enum HealthStatus {
+  public enum HealthStatus {
     UNKNOWN,      // lost heartbeat
     HEALTHY,      // all masters and slaves are live
     UNHEALTHY,    // at least one master is dead

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/UpgradeHelper.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/UpgradeHelper.java b/ambari-server/src/main/java/org/apache/ambari/server/state/UpgradeHelper.java
index 5a8c25e..92e01c2 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/UpgradeHelper.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/UpgradeHelper.java
@@ -98,7 +98,7 @@ public class UpgradeHelper {
   /**
    * Enum used to define placeholder text for replacement
    */
-  private static enum Placeholder {
+  private enum Placeholder {
     /**
      * No placeholder defined
      */
@@ -154,7 +154,7 @@ public class UpgradeHelper {
     DIRECTION_VERB_PROPER("direction.verb.proper");
 
     private String pattern;
-    private Placeholder(String key) {
+    Placeholder(String key) {
       pattern = "{{" + key + "}}";
     }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/action/Action.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/action/Action.java b/ambari-server/src/main/java/org/apache/ambari/server/state/action/Action.java
index 6d00813..e79d0df 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/action/Action.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/action/Action.java
@@ -26,7 +26,7 @@ public interface Action {
    * Get the Action ID for the action
    * @return ActionId
    */
-  public ActionId getId();
+  ActionId getId();
 
   // TODO requires some form of ActionType to ensure only one running
   // action per action type
@@ -38,38 +38,38 @@ public interface Action {
    * Get Start Time of the action
    * @return Start time as a unix timestamp
    */
-  public long getStartTime();
+  long getStartTime();
 
   /**
    * Get the last update time of the Action when its progress status
    * was updated
    * @return Last Update Time as a unix timestamp
    */
-  public long getLastUpdateTime();
+  long getLastUpdateTime();
 
   /**
    * Time when the Action completed
    * @return Completion Time as a unix timestamp
    */
-  public long getCompletionTime();
+  long getCompletionTime();
 
   /**
    * Get the current state of the Action
    * @return ActionState
    */
-  public ActionState getState();
+  ActionState getState();
 
   /**
    * Set the State of the Action
    * @param state ActionState
    */
-  public void setState(ActionState state);
+  void setState(ActionState state);
 
   /**
    * Send a ActionEvent to the Action's StateMachine
    * @param event ActionEvent
    * @throws InvalidStateTransitionException
    */
-  public void handleEvent(ActionEvent event)
+  void handleEvent(ActionEvent event)
       throws InvalidStateTransitionException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/configgroup/ConfigGroup.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/configgroup/ConfigGroup.java b/ambari-server/src/main/java/org/apache/ambari/server/state/configgroup/ConfigGroup.java
index 5a9c574..60780dd 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/configgroup/ConfigGroup.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/configgroup/ConfigGroup.java
@@ -35,76 +35,76 @@ public interface ConfigGroup {
    * Primary key of config group
    * @return
    */
-  public Long getId();
+  Long getId();
 
   /**
    * Unique config group name
    * @return
    */
-  public String getName();
+  String getName();
 
   /**
    * Update Group name
    * @param name
    */
-  public void setName(String name);
+  void setName(String name);
 
   /**
    * Cluster name to which config group belongs
    * @return
    */
-  public String getClusterName();
+  String getClusterName();
 
   /**
    * Tag which associates config group to service
    * @return
    */
-  public String getTag();
+  String getTag();
 
   /**
    * Update tag
    * @param tag
    */
-  public void setTag(String tag);
+  void setTag(String tag);
 
   /**
    * Config group description
    * @return
    */
-  public String getDescription();
+  String getDescription();
 
   /**
    * Update description
    * @param description
    */
-  public void setDescription(String description);
+  void setDescription(String description);
 
   /**
    * Gets an unmodifiable list of {@link Host}s.
    *
    * @return
    */
-  public Map<Long, Host> getHosts();
+  Map<Long, Host> getHosts();
 
   /**
    * Gets an unmodifiable map of {@link Config}s.
    *
    * @return
    */
-  public Map<String, Config> getConfigurations();
+  Map<String, Config> getConfigurations();
 
   /**
    * Delete config group and the related host and config mapping
    * entities from the persistence store
    */
-  public void delete();
+  void delete();
 
   /**
    * Add host to Config group
    * @param host
    * @throws AmbariException
    */
-  public void addHost(Host host) throws AmbariException;
+  void addHost(Host host) throws AmbariException;
 
   /**
    * Return @ConfigGroupResponse for the config group
@@ -112,24 +112,24 @@ public interface ConfigGroup {
    * @return @ConfigGroupResponse
    * @throws AmbariException
    */
-  public ConfigGroupResponse convertToResponse() throws AmbariException;
+  ConfigGroupResponse convertToResponse() throws AmbariException;
 
   /**
    * Reassign the set of hosts associated with this config group
    * @param hosts
    */
-  public void setHosts(Map<Long, Host> hosts);
+  void setHosts(Map<Long, Host> hosts);
 
   /**
    * Reassign the set of configs associated with this config group
    * @param configs
    */
-  public void setConfigurations(Map<String, Config> configs);
+  void setConfigurations(Map<String, Config> configs);
 
   /**
    * Remove host mapping
    */
-  public void removeHost(Long hostId) throws AmbariException;
+  void removeHost(Long hostId) throws AmbariException;
 
   /**
    * Name of service which config group is wired to

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/MultipleArcTransition.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/MultipleArcTransition.java b/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/MultipleArcTransition.java
index b4c688f..5cf6308 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/MultipleArcTransition.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/MultipleArcTransition.java
@@ -34,6 +34,6 @@ public interface MultipleArcTransition
    *                state may change.
    * @param event causal event
    */
-  public STATE transition(OPERAND operand, EVENT event);
+  STATE transition(OPERAND operand, EVENT event);
 
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/SingleArcTransition.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/SingleArcTransition.java b/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/SingleArcTransition.java
index c802e2a..a8ca919 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/SingleArcTransition.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/SingleArcTransition.java
@@ -30,6 +30,6 @@ public interface SingleArcTransition<OPERAND, EVENT> {
    *                state may change.
    * @param event causal event
    */
-  public void transition(OPERAND operand, EVENT event);
+  void transition(OPERAND operand, EVENT event);
 
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/StateMachine.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/StateMachine.java b/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/StateMachine.java
index e8e2813..60201ef 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/StateMachine.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/fsm/StateMachine.java
@@ -21,8 +21,8 @@ package org.apache.ambari.server.state.fsm;
 public interface StateMachine
                  <STATE extends Enum<STATE>,
                   EVENTTYPE extends Enum<EVENTTYPE>, EVENT> {
-  public STATE getCurrentState();
-  public void setCurrentState(STATE state);
-  public STATE doTransition(EVENTTYPE eventType, EVENT event)
+  STATE getCurrentState();
+  void setCurrentState(STATE state);
+  STATE doTransition(EVENTTYPE eventType, EVENT event)
         throws InvalidStateTransitionException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/kerberos/AbstractKerberosDescriptor.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/kerberos/AbstractKerberosDescriptor.java b/ambari-server/src/main/java/org/apache/ambari/server/state/kerberos/AbstractKerberosDescriptor.java
index 9b1fd6b..ae5540e 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/kerberos/AbstractKerberosDescriptor.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/kerberos/AbstractKerberosDescriptor.java
@@ -222,7 +222,7 @@ public abstract class AbstractKerberosDescriptor {
     private final String descriptorName;
     private final String descriptorPluralName;
 
-    private Type(String descriptorName, String descriptorPluralName) {
+    Type(String descriptorName, String descriptorPluralName) {
       this.descriptorName = descriptorName;
       this.descriptorPluralName = descriptorPluralName;
     }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/scheduler/RequestExecution.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/scheduler/RequestExecution.java b/ambari-server/src/main/java/org/apache/ambari/server/state/scheduler/RequestExecution.java
index 8a325f4..d979cc4 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/scheduler/RequestExecution.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/scheduler/RequestExecution.java
@@ -28,137 +28,137 @@ public interface RequestExecution {
    * Primary key of Request Execution
    * @return
    */
-  public Long getId();
+  Long getId();
 
   /**
    * Cluster name to which request schedule belongs
    * @return
    */
-  public String getClusterName();
+  String getClusterName();
 
   /**
    * Get the batch of requests along with batch settings
    * @return
    */
-  public Batch getBatch();
+  Batch getBatch();
 
   /**
    * Set batch of requests and batch settings
    */
-  public void setBatch(Batch batch);
+  void setBatch(Batch batch);
 
   /**
    * Get schedule for the execution
    * @return
    */
-  public Schedule getSchedule();
+  Schedule getSchedule();
 
   /**
    * Set schedule for the execution
    */
-  public void setSchedule(Schedule schedule);
+  void setSchedule(Schedule schedule);
 
   /**
    * Get @RequestScheduleResponse for this Request Execution
    * @return
    */
-  public RequestScheduleResponse convertToResponse();
+  RequestScheduleResponse convertToResponse();
 
   /**
    * Persist the Request Execution and schedule
    */
-  public void persist();
+  void persist();
 
   /**
    * Refresh entity from DB.
    */
-  public void refresh();
+  void refresh();
 
   /**
    * Delete Request Schedule entity
    */
-  public void delete();
+  void delete();
 
   /**
    * Get status of schedule
    */
-  public String getStatus();
+  String getStatus();
 
   /**
    * Set request execution description
    */
-  public void setDescription(String description);
+  void setDescription(String description);
 
   /**
    * Get description of the request execution
    */
-  public String getDescription();
+  String getDescription();
 
   /**
    * Set status of the schedule
    */
-  public void setStatus(Status status);
+  void setStatus(Status status);
 
   /**
    * Set datetime:status of last request that was executed
    */
-  public void setLastExecutionStatus(String status);
+  void setLastExecutionStatus(String status);
 
   /**
    * Set authenticated user
    */
-  public void setAuthenticatedUserId(Integer username);
+  void setAuthenticatedUserId(Integer username);
 
   /**
    * Set create username
    */
-  public void setCreateUser(String username);
+  void setCreateUser(String username);
 
   /**
    * Set create username
    */
-  public void setUpdateUser(String username);
+  void setUpdateUser(String username);
 
   /**
    * Get created time
    */
-  public String getCreateTime();
+  String getCreateTime();
 
   /**
    * Get updated time
    */
-  public String getUpdateTime();
+  String getUpdateTime();
 
   /**
    * Get authenticated user
    */
-  public Integer getAuthenticatedUserId();
+  Integer getAuthenticatedUserId();
 
   /**
    * Get create user
    */
-  public String getCreateUser();
+  String getCreateUser();
 
   /**
    * Get update user
    */
-  public String getUpdateUser();
+  String getUpdateUser();
 
   /**
    * Get status of the last batch of requests
    * @return
    */
-  public String getLastExecutionStatus();
+  String getLastExecutionStatus();
 
   /**
    * Get response with request body
    */
-  public RequestScheduleResponse convertToResponseWithBody();
+  RequestScheduleResponse convertToResponseWithBody();
 
   /**
    * Get the request body for a batch request
    */
-  public String getRequestBody(Long batchId);
+  String getRequestBody(Long batchId);
 
   /**
    * Get batch request with specified order id
@@ -176,12 +176,12 @@ public interface RequestExecution {
   /**
    * Update status and save RequestExecution
    */
-  public void updateStatus(Status status);
+  void updateStatus(Status status);
 
   /**
    * Status of the Request execution
    */
-  public enum Status {
+  enum Status {
     SCHEDULED,
     COMPLETED,
     DISABLED

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/state/stack/upgrade/UpgradeFunction.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/state/stack/upgrade/UpgradeFunction.java b/ambari-server/src/main/java/org/apache/ambari/server/state/stack/upgrade/UpgradeFunction.java
index d58316d..c472ea1 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/state/stack/upgrade/UpgradeFunction.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/state/stack/upgrade/UpgradeFunction.java
@@ -22,5 +22,5 @@ public interface UpgradeFunction {
   /**
    * @return Return the function that the group must provide.
    */
-  public Task.Type getFunction();
+  Task.Type getFunction();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/Blueprint.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/Blueprint.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/Blueprint.java
index 346268f..6189b99 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/Blueprint.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/Blueprint.java
@@ -34,13 +34,13 @@ public interface Blueprint {
    *
    * @return blueprint name
    */
-  public String getName();
+  String getName();
 
   /**
    * Get the hot groups contained in the blueprint.
    * @return map of host group name to host group
    */
-  public Map<String, HostGroup> getHostGroups();
+  Map<String, HostGroup> getHostGroups();
 
   /**
    * Get a hostgroup specified by name.
@@ -49,7 +49,7 @@ public interface Blueprint {
    *
    * @return the host group with the given name or null
    */
-  public HostGroup getHostGroup(String name);
+  HostGroup getHostGroup(String name);
 
   /**
    * Get the Blueprint cluster scoped configuration.
@@ -59,7 +59,7 @@ public interface Blueprint {
    *
    * @return blueprint cluster scoped configuration
    */
-  public Configuration getConfiguration();
+  Configuration getConfiguration();
 
   /**
    * Get the Blueprint cluster scoped setting.
@@ -68,14 +68,14 @@ public interface Blueprint {
    *
    * @return blueprint cluster scoped setting
    */
-  public Setting getSetting();
+  Setting getSetting();
 
   /**
    * Get all of the services represented in the blueprint.
    *
    * @return collection of all represented service names
    */
-  public Collection<String> getServices();
+  Collection<String> getServices();
 
   /**
    * Get the components that are included in the blueprint for the specified service.
@@ -84,7 +84,7 @@ public interface Blueprint {
    *
    * @return collection of component names for the service.  Will not return null.
    */
-  public Collection<String> getComponents(String service);
+  Collection<String> getComponents(String service);
 
   /**
    * Get whether a component is enabled for auto start.
@@ -94,7 +94,7 @@ public interface Blueprint {
    *
    * @return null if value is not specified; true or false if specified.
    */
-  public String getRecoveryEnabled(String serviceName, String componentName);
+  String getRecoveryEnabled(String serviceName, String componentName);
 
   /**
    * Get whether a service is enabled for credential store use.
@@ -103,20 +103,20 @@ public interface Blueprint {
    *
    * @return null if value is not specified; true or false if specified.
    */
-  public String getCredentialStoreEnabled(String serviceName);
+  String getCredentialStoreEnabled(String serviceName);
 
   /**
    * Check if auto skip failure is enabled.
    * @return true if enabled, otherwise false.
    */
-  public boolean shouldSkipFailure();
+  boolean shouldSkipFailure();
 
   /**
    * Get the stack associated with the blueprint.
    *
    * @return associated stack
    */
-  public Stack getStack();
+  Stack getStack();
 
   /**
    * Get the host groups which contain components for the specified service.
@@ -126,7 +126,7 @@ public interface Blueprint {
    * @return collection of host groups containing components for the specified service;
    *         will not return null
    */
-  public Collection<HostGroup> getHostGroupsForService(String service);
+  Collection<HostGroup> getHostGroupsForService(String service);
 
   /**
    * Get the host groups which contain the give component.
@@ -135,28 +135,28 @@ public interface Blueprint {
    *
    * @return collection of host groups containing the specified component; will not return null
    */
-  public Collection<HostGroup> getHostGroupsForComponent(String component);
+  Collection<HostGroup> getHostGroupsForComponent(String component);
 
-  public SecurityConfiguration getSecurity();
+  SecurityConfiguration getSecurity();
 
   /**
    * Validate the blueprint topology.
    *
    * @throws InvalidTopologyException if the topology is invalid
    */
-  public void validateTopology() throws InvalidTopologyException;
+  void validateTopology() throws InvalidTopologyException;
 
   /**
    * Validate that the blueprint contains all of the required properties.
    *
    * @throws InvalidTopologyException if the blueprint doesn't contain all required properties
    */
-  public void validateRequiredProperties() throws InvalidTopologyException;
+  void validateRequiredProperties() throws InvalidTopologyException;
 
   /**
    * Obtain the blueprint as an entity.
    *
    * @return entity representation of the blueprint
    */
-  public BlueprintEntity toEntity();
+  BlueprintEntity toEntity();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintFactory.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintFactory.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintFactory.java
index 40fa2d3..857061b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintFactory.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintFactory.java
@@ -228,7 +228,7 @@ public class BlueprintFactory {
    * simulate various Stack or error conditions.
    */
   interface StackFactory {
-      public Stack createStack(String stackName, String stackVersion, AmbariManagementController managementController) throws AmbariException;
+      Stack createStack(String stackName, String stackVersion, AmbariManagementController managementController) throws AmbariException;
   }
 
   /**

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintValidator.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintValidator.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintValidator.java
index 206d161..3e6fa94 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintValidator.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/BlueprintValidator.java
@@ -29,7 +29,7 @@ public interface BlueprintValidator {
    *
    * @throws InvalidTopologyException if the topology is invalid
    */
-  public void validateTopology() throws InvalidTopologyException;
+  void validateTopology() throws InvalidTopologyException;
 
   /**
    * Validate that required properties are provided.
@@ -37,5 +37,5 @@ public interface BlueprintValidator {
    *
    * @throws InvalidTopologyException if required properties are not set in blueprint
    */
-  public void validateRequiredProperties() throws InvalidTopologyException;
+  void validateRequiredProperties() throws InvalidTopologyException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/HostGroup.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/HostGroup.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/HostGroup.java
index 4353963..2d464aa 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/HostGroup.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/HostGroup.java
@@ -38,14 +38,14 @@ public interface HostGroup {
    *
    * @return the host group name
    */
-  public String getName();
+  String getName();
 
   /**
    * Get the name of the associated blueprint
    *
    * @return associated blueprint name
    */
-  public String getBlueprintName();
+  String getBlueprintName();
 
   /**
    * Get the fully qualified host group name in the form of
@@ -53,21 +53,21 @@ public interface HostGroup {
    *
    * @return fully qualified host group name
    */
-  public String getFullyQualifiedName();
+  String getFullyQualifiedName();
 
   /**
    * Get all of the host group components.
    *
    * @return collection of component instances
    */
-  public Collection<Component> getComponents();
+  Collection<Component> getComponents();
 
   /**
    * Get all of the host group component names
    *
    * @return collection of component names as String
    */
-  public Collection<String> getComponentNames();
+  Collection<String> getComponentNames();
 
   /**
    * Get all host group component names for instances
@@ -79,7 +79,7 @@ public interface HostGroup {
    * @return collection of component names as String that are associated with
    *           the specified provision action
    */
-  public Collection<String> getComponentNames(ProvisionAction provisionAction);
+  Collection<String> getComponentNames(ProvisionAction provisionAction);
 
   /**
    * Get the host group components which belong to the specified service.
@@ -88,7 +88,7 @@ public interface HostGroup {
    *
    * @return collection of component names for the specified service; will not return null
    */
-  public Collection<String> getComponents(String service);
+  Collection<String> getComponents(String service);
 
   /**
    * Add a component to the host group.
@@ -97,7 +97,7 @@ public interface HostGroup {
    *
    * @return true if the component didn't already exist
    */
-  public boolean addComponent(String component);
+  boolean addComponent(String component);
 
   /**
    * Add a component to the host group, with the specified name
@@ -107,21 +107,21 @@ public interface HostGroup {
    * @param provisionAction provision action for this component
    * @return
    */
-  public boolean addComponent(String component, ProvisionAction provisionAction);
+  boolean addComponent(String component, ProvisionAction provisionAction);
 
   /**
    * Determine if the host group contains a master component.
    *
    * @return true if the host group contains a master component; false otherwise
    */
-  public boolean containsMasterComponent();
+  boolean containsMasterComponent();
 
   /**
    * Get all of the services associated with the host group components.
    *
    * @return collection of service names
    */
-  public Collection<String> getServices();
+  Collection<String> getServices();
 
   /**
    * Get the configuration associated with the host group.
@@ -130,14 +130,14 @@ public interface HostGroup {
    *
    * @return host group configuration
    */
-  public Configuration getConfiguration();
+  Configuration getConfiguration();
 
   /**
    * Get the stack associated with the host group.
    *
    * @return associated stack
    */
-  public Stack getStack();
+  Stack getStack();
 
   /**
    * Get the cardinality value that was specified for the host group.
@@ -146,6 +146,6 @@ public interface HostGroup {
    *
    * @return the cardinality specified for the hostgroup
    */
-  public String getCardinality();
+  String getCardinality();
 }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequest.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequest.java
index 516ea14..cbc6642 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequest.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequest.java
@@ -28,21 +28,21 @@ public interface TopologyRequest {
   /**
    * Request types.
    */
-  public enum Type { PROVISION, SCALE, EXPORT }
+  enum Type { PROVISION, SCALE, EXPORT }
 
   /**
    * Get the cluster id associated with the request. Can be <code>null</code>.
    *
    * @return associated cluster id
    */
-  public Long getClusterId();
+  Long getClusterId();
 
   /**
    * Get the request type.
    *
    * @return the type of request
    */
-  public Type getType();
+  Type getType();
 
   //todo: only a single BP may be specified so all host groups have the same bp.
   //todo: BP really needs to be associated with the HostGroupInfo, even for create which will have a single BP
@@ -53,33 +53,33 @@ public interface TopologyRequest {
    *
    * @return associated blueprint instance
    */
-  public Blueprint getBlueprint();
+  Blueprint getBlueprint();
 
   /**
    * Get the cluster scoped configuration for the request.
    *
    * @return cluster scoped configuration
    */
-  public Configuration getConfiguration();
+  Configuration getConfiguration();
 
   /**
    * Get host group info.
    *
    * @return map of host group name to group info
    */
-  public Map<String, HostGroupInfo> getHostGroupInfo();
+  Map<String, HostGroupInfo> getHostGroupInfo();
 
   /**
    * Get request topology validators.
    *
    * @return list of topology validators
    */
-  public List<TopologyValidator> getTopologyValidators();
+  List<TopologyValidator> getTopologyValidators();
 
   /**
    * Get request description.
    *
    * @return string description of the request
    */
-  public String getDescription();
+  String getDescription();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequestFactory.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequestFactory.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequestFactory.java
index e78c5e0..8248536 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequestFactory.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyRequestFactory.java
@@ -28,6 +28,6 @@ import org.apache.ambari.server.controller.internal.ProvisionClusterRequest;
  */
 public interface TopologyRequestFactory {
 
-  public ProvisionClusterRequest createProvisionClusterRequest(Map<String, Object> properties, SecurityConfiguration securityConfiguration) throws InvalidTopologyTemplateException;
+  ProvisionClusterRequest createProvisionClusterRequest(Map<String, Object> properties, SecurityConfiguration securityConfiguration) throws InvalidTopologyTemplateException;
   // todo: use to create other request types
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyValidator.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyValidator.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyValidator.java
index 146b424..58e858c 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyValidator.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/TopologyValidator.java
@@ -22,5 +22,5 @@ package org.apache.ambari.server.topology;
  * Performs topology validation.
  */
 public interface TopologyValidator {
-  public void validate(ClusterTopology topology) throws InvalidTopologyException;
+  void validate(ClusterTopology topology) throws InvalidTopologyException;
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/topology/tasks/TopologyTask.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/topology/tasks/TopologyTask.java b/ambari-server/src/main/java/org/apache/ambari/server/topology/tasks/TopologyTask.java
index 0753c3d..458191b 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/topology/tasks/TopologyTask.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/topology/tasks/TopologyTask.java
@@ -26,7 +26,7 @@ public interface TopologyTask extends Runnable {
   /**
    * Task type.
    */
-  public enum Type {
+  enum Type {
     RESOURCE_CREATION,
     CONFIGURE,
     INSTALL,
@@ -38,5 +38,5 @@ public interface TopologyTask extends Runnable {
    *
    * @return the type of task
    */
-  public Type getType();
+  Type getType();
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/upgrade/AbstractUpgradeCatalog.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/AbstractUpgradeCatalog.java b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/AbstractUpgradeCatalog.java
index 3e1d3b8..9a78ea1 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/AbstractUpgradeCatalog.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/AbstractUpgradeCatalog.java
@@ -695,7 +695,7 @@ public abstract class AbstractUpgradeCatalog implements UpgradeCatalog {
     private final String description;
 
 
-    private ConfigUpdateType(String description) {
+    ConfigUpdateType(String description) {
       this.description = description;
     }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/view/ViewInstanceHandlerList.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/view/ViewInstanceHandlerList.java b/ambari-server/src/main/java/org/apache/ambari/server/view/ViewInstanceHandlerList.java
index 8d2b52a..65c3771 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/view/ViewInstanceHandlerList.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/view/ViewInstanceHandlerList.java
@@ -32,12 +32,12 @@ public interface ViewInstanceHandlerList {
    *
    * @throws SystemException if a handler the view instance can not be added
    */
-  public void addViewInstance(ViewInstanceEntity viewInstanceDefinition) throws SystemException;
+  void addViewInstance(ViewInstanceEntity viewInstanceDefinition) throws SystemException;
 
   /**
    * Remove the handler for the given view instance.
    *
    * @param viewInstanceDefinition  the view instance
    */
-  public void removeViewInstance(ViewInstanceEntity viewInstanceDefinition);
+  void removeViewInstance(ViewInstanceEntity viewInstanceDefinition);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/main/java/org/apache/ambari/server/view/persistence/SchemaManagerFactory.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/view/persistence/SchemaManagerFactory.java b/ambari-server/src/main/java/org/apache/ambari/server/view/persistence/SchemaManagerFactory.java
index ae730d1..54598c2 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/view/persistence/SchemaManagerFactory.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/view/persistence/SchemaManagerFactory.java
@@ -32,5 +32,5 @@ public interface SchemaManagerFactory {
    *
    * @return the schema manager
    */
-  public SchemaManager getSchemaManager(DatabaseSession session);
+  SchemaManager getSchemaManager(DatabaseSession session);
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/test/java/org/apache/ambari/server/controller/internal/AbstractJDBCResourceProviderTest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/java/org/apache/ambari/server/controller/internal/AbstractJDBCResourceProviderTest.java b/ambari-server/src/test/java/org/apache/ambari/server/controller/internal/AbstractJDBCResourceProviderTest.java
index f546aab..07540bf 100644
--- a/ambari-server/src/test/java/org/apache/ambari/server/controller/internal/AbstractJDBCResourceProviderTest.java
+++ b/ambari-server/src/test/java/org/apache/ambari/server/controller/internal/AbstractJDBCResourceProviderTest.java
@@ -88,7 +88,7 @@ public class AbstractJDBCResourceProviderTest {
     verify(rs);
   }
 
-  private static enum TestFields {
+  private enum TestFields {
     field1, field2
   }
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/test/java/org/apache/ambari/server/state/cluster/AlertDataManagerTest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/java/org/apache/ambari/server/state/cluster/AlertDataManagerTest.java b/ambari-server/src/test/java/org/apache/ambari/server/state/cluster/AlertDataManagerTest.java
index 1e74658..8d7d8ad 100644
--- a/ambari-server/src/test/java/org/apache/ambari/server/state/cluster/AlertDataManagerTest.java
+++ b/ambari-server/src/test/java/org/apache/ambari/server/state/cluster/AlertDataManagerTest.java
@@ -508,7 +508,7 @@ public class AlertDataManagerTest {
   /**
    * Test interface collects aggregate alert invocations
    */
-  private static interface TestListener {
-    public void catchIt(AlertReceivedEvent event);
+  private interface TestListener {
+    void catchIt(AlertReceivedEvent event);
   }
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/754d6c87/ambari-server/src/test/java/org/apache/ambari/server/upgrade/SectionDDL.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/java/org/apache/ambari/server/upgrade/SectionDDL.java b/ambari-server/src/test/java/org/apache/ambari/server/upgrade/SectionDDL.java
index bdb8cd9..987a922 100644
--- a/ambari-server/src/test/java/org/apache/ambari/server/upgrade/SectionDDL.java
+++ b/ambari-server/src/test/java/org/apache/ambari/server/upgrade/SectionDDL.java
@@ -33,12 +33,12 @@ public interface SectionDDL {
    * @param dbAccessor
    * @throws SQLException
    */
-  public void execute(DBAccessor dbAccessor) throws SQLException;
+  void execute(DBAccessor dbAccessor) throws SQLException;
 
   /**
    * Retrieve the capture groups and make assertions about tables/columns created.
    * @param dbAccessor
    * @throws SQLException
    */
-  public void verify(DBAccessor dbAccessor) throws SQLException;
+  void verify(DBAccessor dbAccessor) throws SQLException;
 }