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

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

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;
 }