You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apex.apache.org by vr...@apache.org on 2017/04/11 16:08:34 UTC

apex-core git commit: APEXCORE-695 Remove unnecessary interface modifiers

Repository: apex-core
Updated Branches:
  refs/heads/master 88bf33627 -> 077009e4c


APEXCORE-695 Remove unnecessary interface modifiers


Project: http://git-wip-us.apache.org/repos/asf/apex-core/repo
Commit: http://git-wip-us.apache.org/repos/asf/apex-core/commit/077009e4
Tree: http://git-wip-us.apache.org/repos/asf/apex-core/tree/077009e4
Diff: http://git-wip-us.apache.org/repos/asf/apex-core/diff/077009e4

Branch: refs/heads/master
Commit: 077009e4cc80d1988bfcec50ceb8b4e27ec577bd
Parents: 88bf336
Author: Apex Dev <de...@apex.apache.org>
Authored: Sun Apr 9 17:22:11 2017 -0700
Committer: Vlad Rozov <v....@datatorrent.com>
Committed: Tue Apr 11 08:54:51 2017 -0700

----------------------------------------------------------------------
 .../java/com/datatorrent/api/Attribute.java     |  6 +-
 .../java/com/datatorrent/api/AutoMetric.java    |  6 +-
 .../java/com/datatorrent/api/Component.java     | 10 +--
 .../main/java/com/datatorrent/api/Context.java  | 10 +--
 .../api/ControlTupleEnabledSink.java            |  4 +-
 api/src/main/java/com/datatorrent/api/DAG.java  | 78 ++++++++++----------
 .../java/com/datatorrent/api/InputOperator.java |  2 +-
 .../java/com/datatorrent/api/LocalMode.java     | 10 +--
 .../main/java/com/datatorrent/api/Operator.java | 18 ++---
 .../java/com/datatorrent/api/Partitioner.java   | 18 ++---
 api/src/main/java/com/datatorrent/api/Sink.java |  8 +-
 .../main/java/com/datatorrent/api/Stats.java    |  4 +-
 .../java/com/datatorrent/api/StatsListener.java | 20 ++---
 .../java/com/datatorrent/api/StorageAgent.java  | 12 +--
 .../api/annotation/ApplicationAnnotation.java   |  2 +-
 .../annotation/InputPortFieldAnnotation.java    |  4 +-
 .../api/annotation/OperatorAnnotation.java      |  4 +-
 .../annotation/OutputPortFieldAnnotation.java   |  6 +-
 .../datatorrent/api/annotation/RecordField.java |  4 +-
 .../org/apache/apex/api/DAGSetupPlugin.java     |  2 +-
 .../bufferserver/storage/Storage.java           |  8 +-
 .../bufferserver/support/Subscriber.java        |  6 +-
 .../common/experimental/AppData.java            | 18 ++---
 .../common/util/NumberAggregate.java            | 14 ++--
 .../common/util/ScheduledExecutorService.java   |  2 +-
 .../apex/common/util/AsyncStorageAgent.java     |  4 +-
 .../com/datatorrent/stram/EventRecorder.java    |  2 +-
 .../datatorrent/stram/LicensingProtocol.java    |  4 +-
 .../com/datatorrent/stram/StatsRecorder.java    |  4 +-
 .../datatorrent/stram/api/ContainerContext.java |  8 +-
 .../stram/api/NodeActivationListener.java       |  4 +-
 .../StreamingContainerUmbilicalProtocol.java    |  2 +-
 .../stram/client/StramClientUtils.java          |  2 +-
 .../stram/codec/StatefulStreamCodec.java        |  6 +-
 .../stram/engine/ByteCounterStream.java         |  2 +-
 .../com/datatorrent/stram/engine/Stream.java    |  4 +-
 .../stram/util/SharedPubSubWebSocketClient.java |  4 +-
 .../engine/api/DAGExecutionPluginContext.java   | 18 ++---
 .../stram/webapp/TypeDiscoveryTest.java         |  2 +-
 39 files changed, 171 insertions(+), 171 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Attribute.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Attribute.java b/api/src/main/java/com/datatorrent/api/Attribute.java
index 821ecb2..a3b2f97 100644
--- a/api/src/main/java/com/datatorrent/api/Attribute.java
+++ b/api/src/main/java/com/datatorrent/api/Attribute.java
@@ -107,7 +107,7 @@ public class Attribute<T> implements Serializable
    *
    * @since 0.3.2
    */
-  public static interface AttributeMap extends Cloneable
+  public interface AttributeMap extends Cloneable
   {
     /**
      * Return the attribute value for the given key. If the map does not have an
@@ -150,7 +150,7 @@ public class Attribute<T> implements Serializable
     /**
      * DefaultAttributeMap is the default implementation of AttributeMap. It's backed by a map internally.
      */
-    public static class DefaultAttributeMap implements AttributeMap, Serializable
+    class DefaultAttributeMap implements AttributeMap, Serializable
     {
       private HashMap<Attribute<?>, Object> map;
 
@@ -234,7 +234,7 @@ public class Attribute<T> implements Serializable
      *
      * Engine uses it internally to initialize the Interfaces that may have Attributes defined in them.
      */
-    public static class AttributeInitializer
+    class AttributeInitializer
     {
       static final HashMap<Class<?>, Set<Attribute<Object>>> map = new HashMap<>();
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/AutoMetric.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/AutoMetric.java b/api/src/main/java/com/datatorrent/api/AutoMetric.java
index b487e04..8369b87 100644
--- a/api/src/main/java/com/datatorrent/api/AutoMetric.java
+++ b/api/src/main/java/com/datatorrent/api/AutoMetric.java
@@ -42,7 +42,7 @@ public @interface AutoMetric
   /**
    * Represents collection of physical metrics.
    */
-  public static interface PhysicalMetricsContext
+  interface PhysicalMetricsContext
   {
     /**
      * @return map of metric name to value
@@ -60,7 +60,7 @@ public @interface AutoMetric
    * An aggregator is provided as operator attribute. By default, when there isn't any aggregator set explicitly,
    * the application master sums up all the number metrics.
    */
-  public static interface Aggregator
+  interface Aggregator
   {
     /**
      * Aggregates values of a specific metric.
@@ -77,7 +77,7 @@ public @interface AutoMetric
    * Application data tracker by default does certain aggregations for 1m, 1h,& 1d time buckets unless it overridden by
    * the app developer by providing a dimension scheme as operator attribute.
    */
-  public static interface DimensionsScheme
+  interface DimensionsScheme
   {
     /**
      * Time buckets for eg. {1m, 1h}. Application data tracker by default does 1m, 1h & 1d aggregations but this

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Component.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Component.java b/api/src/main/java/com/datatorrent/api/Component.java
index 05c1a30..e98ade4 100644
--- a/api/src/main/java/com/datatorrent/api/Component.java
+++ b/api/src/main/java/com/datatorrent/api/Component.java
@@ -32,13 +32,13 @@ public interface Component<CONTEXT extends Context>
    * It's recommended to use this separator to create scoped names for the components.
    * e.g. Port p on Operator o can be identified as o.concat(CONCAT_SEPARATOR).concat(p).
    */
-  public static final String CONCAT_SEPARATOR = ".";
+  String CONCAT_SEPARATOR = ".";
   /**
    * It's recommended to use this separator to split the scoped names into individual components.
    * e.g. o.concat(CONCAT_SEPARATOR).concat(p).split(SPLIT_SEPARATOR) will return String[]{o, p}.
    *
    */
-  public static final String SPLIT_SEPARATOR = "\\.";
+  String SPLIT_SEPARATOR = "\\.";
 
   /**
    * Callback to give the component a chance to perform tasks required as part of setting itself up.
@@ -47,13 +47,13 @@ public interface Component<CONTEXT extends Context>
    *
    * @param context - context in which the operator executues.
    */
-  public void setup(CONTEXT context);
+  void setup(CONTEXT context);
 
   /**
    * Callback to give the component a chance to perform tasks required as part of tearing itself down.
    * A recommended practice is to reciprocate the tasks in setup by doing exactly opposite.
    */
-  public void teardown();
+  void teardown();
 
   /**
    * A utility class to club component along with the entity such as context or configuration.
@@ -65,7 +65,7 @@ public interface Component<CONTEXT extends Context>
    * @param <COMPLEMENT>
    * @since 0.3.2
    */
-  public abstract static class ComponentComplementPair<COMPONENT extends Component<?>, COMPLEMENT>
+  abstract class ComponentComplementPair<COMPONENT extends Component<?>, COMPLEMENT>
   {
     public final COMPONENT component;
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Context.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Context.java b/api/src/main/java/com/datatorrent/api/Context.java
index 3f7d96c..eb241d6 100644
--- a/api/src/main/java/com/datatorrent/api/Context.java
+++ b/api/src/main/java/com/datatorrent/api/Context.java
@@ -48,7 +48,7 @@ public interface Context
    *
    * @return attributes defined for the current context.
    */
-  public AttributeMap getAttributes();
+  AttributeMap getAttributes();
 
   /**
    * Get the value of the attribute associated with the current key by recursively traversing the contexts upwards to
@@ -58,7 +58,7 @@ public interface Context
    * @param key - Attribute to identify the attribute.
    * @return The value for the attribute if found or the defaultValue passed in as argument.
    */
-  public <T> T getValue(Attribute<T> key);
+  <T> T getValue(Attribute<T> key);
 
   /**
    * Custom stats provided by the operator implementation. Reported as part of operator stats in the context of the
@@ -92,7 +92,7 @@ public interface Context
   /**
    * The interface to control the container JVM Opts based on the operator(s) configuration
    */
-  public interface ContainerOptConfigurator extends Serializable
+  interface ContainerOptConfigurator extends Serializable
   {
     /**
      * Get the container JVM opts based on the operator(s) configuration.
@@ -116,7 +116,7 @@ public interface Context
     ENABLE, FOLLOW_HADOOP_AUTH, FOLLOW_HADOOP_HTTP_AUTH, DISABLE
   }
 
-  public interface PortContext extends Context
+  interface PortContext extends Context
   {
     /**
      * Number of tuples the poll buffer can cache without blocking the input stream to the port.
@@ -185,7 +185,7 @@ public interface Context
     long serialVersionUID = AttributeMap.AttributeInitializer.initialize(PortContext.class);
   }
 
-  public interface OperatorContext extends Context
+  interface OperatorContext extends Context
   {
     /**
      * The windowId at which the operator's current run got activated.

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/ControlTupleEnabledSink.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/ControlTupleEnabledSink.java b/api/src/main/java/com/datatorrent/api/ControlTupleEnabledSink.java
index eeb952a..40b7436 100644
--- a/api/src/main/java/com/datatorrent/api/ControlTupleEnabledSink.java
+++ b/api/src/main/java/com/datatorrent/api/ControlTupleEnabledSink.java
@@ -27,7 +27,7 @@ import org.apache.hadoop.classification.InterfaceStability;
 @InterfaceStability.Evolving
 public interface ControlTupleEnabledSink<T> extends Sink<T>
 {
-  public static final ControlTupleEnabledSink<Object> BLACKHOLE = new ControlTupleEnabledSink<Object>()
+  ControlTupleEnabledSink<Object> BLACKHOLE = new ControlTupleEnabledSink<Object>()
   {
     @Override
     public void put(Object tuple)
@@ -52,5 +52,5 @@ public interface ControlTupleEnabledSink<T> extends Sink<T>
    *
    * @param payload the control tuple payload
    */
-  public boolean putControl(ControlTuple payload);
+  boolean putControl(ControlTuple payload);
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/DAG.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/DAG.java b/api/src/main/java/com/datatorrent/api/DAG.java
index 532ff72..96420a3 100644
--- a/api/src/main/java/com/datatorrent/api/DAG.java
+++ b/api/src/main/java/com/datatorrent/api/DAG.java
@@ -47,9 +47,9 @@ public interface DAG extends DAGContext, Serializable
      * Return port object represented by this InputPortMeta
      * @return
      */
-    public Operator.InputPort<?> getPort();
+    Operator.InputPort<?> getPort();
 
-    public <T extends OperatorMeta> T getOperatorMeta();
+    <T extends OperatorMeta> T getOperatorMeta();
   }
 
   interface OutputPortMeta extends Serializable, PortContext
@@ -60,9 +60,9 @@ public interface DAG extends DAGContext, Serializable
      * Return port object represented by this OutputPortMeta
      * @return
      */
-    public Operator.OutputPort<?> getPort();
+    Operator.OutputPort<?> getPort();
 
-    public <T extends OperatorMeta> T getOperatorMeta();
+    <T extends OperatorMeta> T getOperatorMeta();
   }
 
   /**
@@ -105,15 +105,15 @@ public interface DAG extends DAGContext, Serializable
   /**
    * Representation of streams in the logical layer. Instances are created through {@link DAG#addStream}.
    */
-  public interface StreamMeta extends Serializable
+  interface StreamMeta extends Serializable
   {
-    public String getName();
+    String getName();
 
     /**
      * Returns the locality for this stream.
      * @return locality for this stream, default is null.
      */
-    public Locality getLocality();
+    Locality getLocality();
 
     /**
      * Set locality for the stream. The setting is best-effort, engine can
@@ -122,11 +122,11 @@ public interface DAG extends DAGContext, Serializable
      * @param locality
      * @return Object that describes the meta for the stream.
      */
-    public StreamMeta setLocality(Locality locality);
+    StreamMeta setLocality(Locality locality);
 
-    public StreamMeta setSource(Operator.OutputPort<?> port);
+    StreamMeta setSource(Operator.OutputPort<?> port);
 
-    public StreamMeta addSink(Operator.InputPort<?> port);
+    StreamMeta addSink(Operator.InputPort<?> port);
 
     /**
      * Persist entire stream using operator passed.
@@ -136,7 +136,7 @@ public interface DAG extends DAGContext, Serializable
      * @param Input port to use for persisting
      * @return Object that describes the meta for the stream.
      */
-    public StreamMeta persistUsing(String name, Operator persistOperator, Operator.InputPort<?> persistOperatorInputPort);
+    StreamMeta persistUsing(String name, Operator persistOperator, Operator.InputPort<?> persistOperatorInputPort);
 
     /**
      * Set locality for the stream. The setting is best-effort, engine can
@@ -146,7 +146,7 @@ public interface DAG extends DAGContext, Serializable
      * @param Operator to use for persisting
      * @return Object that describes the meta for the stream.
      */
-    public StreamMeta persistUsing(String name, Operator persistOperator);
+    StreamMeta persistUsing(String name, Operator persistOperator);
 
     /**
      * Set locality for the stream. The setting is best-effort, engine can
@@ -158,35 +158,35 @@ public interface DAG extends DAGContext, Serializable
      * @param Sink to persist
      * @return Object that describes the meta for the stream.
      */
-    public StreamMeta persistUsing(String name, Operator persistOperator, Operator.InputPort<?> persistOperatorInputPort, Operator.InputPort<?> sinkToPersist);
+    StreamMeta persistUsing(String name, Operator persistOperator, Operator.InputPort<?> persistOperatorInputPort, Operator.InputPort<?> sinkToPersist);
 
     /**
      * Return source of the stream.
      * @param <T>
      * @return
      */
-    public <T extends OutputPortMeta> T getSource();
+    <T extends OutputPortMeta> T getSource();
 
     /**
      * Return all sinks connected to this stream.
      * @param <T>
      * @return
      */
-    public <T extends InputPortMeta> Collection<T> getSinks();
+    <T extends InputPortMeta> Collection<T> getSinks();
   }
 
   /**
    * Operator meta object.
    */
-  public interface OperatorMeta extends Serializable, Context
+  interface OperatorMeta extends Serializable, Context
   {
-    public String getName();
+    String getName();
 
-    public Operator getOperator();
+    Operator getOperator();
 
-    public InputPortMeta getMeta(Operator.InputPort<?> port);
+    InputPortMeta getMeta(Operator.InputPort<?> port);
 
-    public OutputPortMeta getMeta(Operator.OutputPort<?> port);
+    OutputPortMeta getMeta(Operator.OutputPort<?> port);
 
     /**
      * Return collection of stream which are connected to this operator's
@@ -194,7 +194,7 @@ public interface DAG extends DAGContext, Serializable
      * @param <T>
      * @return
      */
-    public <K extends InputPortMeta, V extends StreamMeta> Map<K, V> getInputStreams();
+    <K extends InputPortMeta, V extends StreamMeta> Map<K, V> getInputStreams();
 
     /**
      * Return collection of stream which are connected to this operator's
@@ -202,7 +202,7 @@ public interface DAG extends DAGContext, Serializable
      * @param <T>
      * @return
      */
-    public <K extends OutputPortMeta, V extends StreamMeta> Map<K, V> getOutputStreams();
+    <K extends OutputPortMeta, V extends StreamMeta> Map<K, V> getOutputStreams();
   }
 
   /**
@@ -216,7 +216,7 @@ public interface DAG extends DAGContext, Serializable
    * @param clazz Concrete class with default constructor so that instance of it can be initialized and added to the DAG.
    * @return Instance of the operator that has been added to the DAG.
    */
-  public abstract <T extends Operator> T addOperator(String name, Class<T> clazz);
+  <T extends Operator> T addOperator(String name, Class<T> clazz);
 
   /**
    * <p>addOperator.</p>
@@ -225,7 +225,7 @@ public interface DAG extends DAGContext, Serializable
    * @param operator Instance of the operator that needs to be added to the DAG
    * @return Instance of the operator that has been added to the DAG.
    */
-  public abstract <T extends Operator> T addOperator(String name, T operator);
+  <T extends Operator> T addOperator(String name, T operator);
 
   @InterfaceStability.Evolving
   <T extends Module> T addModule(String name, Class<T> moduleClass);
@@ -238,7 +238,7 @@ public interface DAG extends DAGContext, Serializable
    * @param id Identifier of the stream that will be used to identify stream in DAG
    * @return
    */
-  public abstract StreamMeta addStream(String id);
+  StreamMeta addStream(String id);
 
   /**
    * Add identified stream for given source and sinks. Multiple sinks can be
@@ -256,7 +256,7 @@ public interface DAG extends DAGContext, Serializable
    * @param sinks
    * @return StreamMeta
    */
-  public abstract <T> StreamMeta addStream(String id, Operator.OutputPort<? extends T> source, Operator.InputPort<? super T>... sinks);
+  <T> StreamMeta addStream(String id, Operator.OutputPort<? extends T> source, Operator.InputPort<? super T>... sinks);
 
   /**
    * Overload varargs version to avoid generic array type safety warnings in calling code.
@@ -269,24 +269,24 @@ public interface DAG extends DAGContext, Serializable
    * @param sink1
    * @return StreamMeta
    */
-  public abstract <T> StreamMeta addStream(String id, Operator.OutputPort<? extends T> source, Operator.InputPort<? super T> sink1);
+  <T> StreamMeta addStream(String id, Operator.OutputPort<? extends T> source, Operator.InputPort<? super T> sink1);
 
   /**
    * <p>addStream.</p>
    */
-  public abstract <T> StreamMeta addStream(String id, Operator.OutputPort<? extends T> source, Operator.InputPort<? super T> sink1, Operator.InputPort<? super T> sink2);
+  <T> StreamMeta addStream(String id, Operator.OutputPort<? extends T> source, Operator.InputPort<? super T> sink1, Operator.InputPort<? super T> sink2);
 
   /**
    * <p>setAttribute.</p>
    */
-  public abstract <T> void setAttribute(Attribute<T> key, T value);
+  <T> void setAttribute(Attribute<T> key, T value);
 
   /**
    * @Deprecated
    * Use {@link #setOperatorAttribute} instead
    */
   @Deprecated
-  public abstract <T> void setAttribute(Operator operator, Attribute<T> key, T value);
+  <T> void setAttribute(Operator operator, Attribute<T> key, T value);
 
   /**
    * Set an attribute for an operator.
@@ -295,12 +295,12 @@ public interface DAG extends DAGContext, Serializable
    * @param key The attribute which needs to be tuned.
    * @param value The new value of the attribute.
    */
-  public abstract <T> void setOperatorAttribute(Operator operator, Attribute<T> key, T value);
+  <T> void setOperatorAttribute(Operator operator, Attribute<T> key, T value);
 
   /**
    * <p>setOutputPortAttribute.</p>
    */
-  public abstract <T> void setOutputPortAttribute(Operator.OutputPort<?> port, Attribute<T> key, T value);
+  <T> void setOutputPortAttribute(Operator.OutputPort<?> port, Attribute<T> key, T value);
 
   /**
    * Set an attribute on the unifier for an output of an operator.
@@ -309,29 +309,29 @@ public interface DAG extends DAGContext, Serializable
    * @param key The attribute which needs to be tuned.
    * @param value The new value of the attribute.
    */
-  public abstract <T> void setUnifierAttribute(Operator.OutputPort<?> port, Attribute<T> key, T value);
+  <T> void setUnifierAttribute(Operator.OutputPort<?> port, Attribute<T> key, T value);
 
   /**
    * <p>setInputPortAttribute.</p>
    */
-  public abstract <T> void setInputPortAttribute(Operator.InputPort<?> port, Attribute<T> key, T value);
+  <T> void setInputPortAttribute(Operator.InputPort<?> port, Attribute<T> key, T value);
 
   /**
    * <p>getOperatorMeta.</p>
    */
-  public abstract OperatorMeta getOperatorMeta(String operatorId);
+  OperatorMeta getOperatorMeta(String operatorId);
 
   /**
    * <p>getMeta.</p>
    */
-  public abstract OperatorMeta getMeta(Operator operator);
+  OperatorMeta getMeta(Operator operator);
 
   /**
    * Return all operators present in the DAG.
    * @param <T>
    * @return
    */
-  public <T extends OperatorMeta> Collection<T> getAllOperatorsMeta();
+  <T extends OperatorMeta> Collection<T> getAllOperatorsMeta();
 
   /**
    * Get all input operators in the DAG. This method returns operators which are
@@ -342,14 +342,14 @@ public interface DAG extends DAGContext, Serializable
    * @param <T>
    * @return list of {@see OperatorMeta} for root operators in the DAG.
    */
-  public <T extends OperatorMeta> Collection<T> getRootOperatorsMeta();
+  <T extends OperatorMeta> Collection<T> getRootOperatorsMeta();
 
   /**
    * Returns all Streams present in the DAG.
    * @param <T>
    * @return
    */
-  public <T extends StreamMeta> Collection<T> getAllStreamsMeta();
+  <T extends StreamMeta> Collection<T> getAllStreamsMeta();
 
   /**
    * Marker interface for the Node in the DAG. Any object which can be added as a Node in the DAG

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/InputOperator.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/InputOperator.java b/api/src/main/java/com/datatorrent/api/InputOperator.java
index e6a0a65..d9847cd 100644
--- a/api/src/main/java/com/datatorrent/api/InputOperator.java
+++ b/api/src/main/java/com/datatorrent/api/InputOperator.java
@@ -40,6 +40,6 @@ public interface InputOperator extends Operator
    * engine will make sure to call emitTuples multiple times within a giving streaming
    * window if it can. When it cannot, it will call endWindow.
    */
-  public void emitTuples();
+  void emitTuples();
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/LocalMode.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/LocalMode.java b/api/src/main/java/com/datatorrent/api/LocalMode.java
index 0387506..9669fdd 100644
--- a/api/src/main/java/com/datatorrent/api/LocalMode.java
+++ b/api/src/main/java/com/datatorrent/api/LocalMode.java
@@ -39,15 +39,15 @@ public abstract class LocalMode<H extends EmbeddedAppLauncher.EmbeddedAppHandle>
 
   public interface Controller
   {
-    public void run();
+    void run();
 
-    public void run(long runMillis);
+    void run(long runMillis);
 
-    public void runAsync();
+    void runAsync();
 
-    public void shutdown();
+    void shutdown();
 
-    public void setHeartbeatMonitoringEnabled(boolean enabled);
+    void setHeartbeatMonitoringEnabled(boolean enabled);
 
   }
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Operator.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Operator.java b/api/src/main/java/com/datatorrent/api/Operator.java
index c016799..dd694d0 100644
--- a/api/src/main/java/com/datatorrent/api/Operator.java
+++ b/api/src/main/java/com/datatorrent/api/Operator.java
@@ -199,7 +199,7 @@ public interface Operator extends Component<OperatorContext>, GenericOperator
    * window and then call deactivate method on it if present.
    *
    */
-  static class ShutdownException extends RuntimeException
+  class ShutdownException extends RuntimeException
   {
     private static final long serialVersionUID = 201401081529L;
 
@@ -223,20 +223,20 @@ public interface Operator extends Component<OperatorContext>, GenericOperator
    * @param <CONTEXT> Context for the current run during which the operator is getting de/activated.
    * @since 0.3.2
    */
-  public static interface ActivationListener<CONTEXT extends Context>
+  interface ActivationListener<CONTEXT extends Context>
   {
     /**
      * Do the operations just before the operator starts processing tasks within the windows.
      * e.g. establish a network connection.
      * @param context - the context in which the operator is executing.
      */
-    public void activate(CONTEXT context);
+    void activate(CONTEXT context);
 
     /**
      * Do the opposite of the operations the operator did during activate.
      * e.g. close the network connection.
      */
-    public void deactivate();
+    void deactivate();
 
   }
 
@@ -247,21 +247,21 @@ public interface Operator extends Component<OperatorContext>, GenericOperator
    * @deprecated Use {@link CheckpointNotificationListener} instead
    * @since 0.3.2
    */
-  public static interface CheckpointListener
+  interface CheckpointListener
   {
     /**
      * Inform the operator that it's checkpointed.
      *
      * @param windowId Id of the window after which the operator was checkpointed.
      */
-    public void checkpointed(long windowId);
+    void checkpointed(long windowId);
 
     /**
      * Inform the operator that a particular windowId is processed successfully by all the operators in the DAG.
      *
      * @param windowId Id of the window which is processed by each operator.
      */
-    public void committed(long windowId);
+    void committed(long windowId);
 
   }
 
@@ -280,14 +280,14 @@ public interface Operator extends Component<OperatorContext>, GenericOperator
    *
    * @since 0.3.2
    */
-  public static interface IdleTimeHandler
+  interface IdleTimeHandler
   {
     /**
      * Callback for operators to implement if they are interested in using the idle cycles to do auxiliary processing.
      * If this method detects that it does not have any work to do, it should block the call for a short duration
      * to prevent busy loop. handleIdleTime is called over and over until operator has tuples to process.
      */
-    public void handleIdleTime();
+    void handleIdleTime();
 
   }
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Partitioner.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Partitioner.java b/api/src/main/java/com/datatorrent/api/Partitioner.java
index d743821..42b6dbb 100644
--- a/api/src/main/java/com/datatorrent/api/Partitioner.java
+++ b/api/src/main/java/com/datatorrent/api/Partitioner.java
@@ -52,7 +52,7 @@ public interface Partitioner<T>
    * @return New partitioning. Partitions from input list which should not be
    * changed can be returned as they are.
    */
-  public Collection<Partition<T>> definePartitions(Collection<Partition<T>> partitions, PartitioningContext context);
+  Collection<Partition<T>> definePartitions(Collection<Partition<T>> partitions, PartitioningContext context);
 
   /**
    * The engine calls this method to notify partitioner of the changes to partitioning.
@@ -64,7 +64,7 @@ public interface Partitioner<T>
    */
   void partitioned(Map<Integer, Partition<T>> partitions);
 
-  public class PartitionKeys implements java.io.Serializable
+  class PartitionKeys implements java.io.Serializable
   {
     private static final long serialVersionUID = 201312271835L;
     public final int mask;
@@ -109,7 +109,7 @@ public interface Partitioner<T>
 
   }
 
-  public interface Partition<T>
+  interface Partition<T>
   {
     /**
      * Return the partition keys for this partition.
@@ -117,7 +117,7 @@ public interface Partitioner<T>
      *
      * @return Map<InputPort<?>, PartitionKeys>
      */
-    public Map<InputPort<?>, PartitionKeys> getPartitionKeys();
+    Map<InputPort<?>, PartitionKeys> getPartitionKeys();
 
     /**
      * Get an indication of the load handled by this partition. The indicator
@@ -129,7 +129,7 @@ public interface Partitioner<T>
      *
      * @return Integer indicative of the load handled by the partition.
      */
-    public int getLoad();
+    int getLoad();
 
     /**
      * Get the latest statistics for this partition. Null when no stats have been collected yet.
@@ -140,14 +140,14 @@ public interface Partitioner<T>
      *
      * @return
      */
-    public BatchedOperatorStats getStats();
+    BatchedOperatorStats getStats();
 
     /**
      * Get the frozen state of the operator which is currently handling the partition.
      *
      * @return frozen operator instance
      */
-    public T getPartitionedInstance();
+    T getPartitionedInstance();
 
     /**
      * Get the attributes associated with this partition.
@@ -155,14 +155,14 @@ public interface Partitioner<T>
      *
      * @return attributes defined for the current context.
      */
-    public com.datatorrent.api.Attribute.AttributeMap getAttributes();
+    com.datatorrent.api.Attribute.AttributeMap getAttributes();
 
   }
 
   /**
    * Contextual information presented to the partitioner.
    */
-  public interface PartitioningContext
+  interface PartitioningContext
   {
     /**
      * Number of partitions required for an operator that was configured to be parallel partitioned.

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Sink.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Sink.java b/api/src/main/java/com/datatorrent/api/Sink.java
index 1e7b1b3..e0c37c3 100644
--- a/api/src/main/java/com/datatorrent/api/Sink.java
+++ b/api/src/main/java/com/datatorrent/api/Sink.java
@@ -38,7 +38,7 @@ public interface Sink<T>
    * pass null otherwise.
    */
   @SuppressWarnings("unchecked")
-  public static final Sink<Object>[] NO_SINKS = (Sink<Object>[])Array.newInstance(Sink.class, 0);
+  Sink<Object>[] NO_SINKS = (Sink<Object>[])Array.newInstance(Sink.class, 0);
   /**
    * Constant
    * <code>BLACKHOLE</code>
@@ -46,7 +46,7 @@ public interface Sink<T>
    * This sink discards anything that's put into it silently. Use this sink if you need a sink that
    * discards everything with super low cost.
    */
-  public static final Sink<Object> BLACKHOLE = new Sink<Object>()
+  Sink<Object> BLACKHOLE = new Sink<Object>()
   {
     @Override
     public void put(Object tuple)
@@ -66,7 +66,7 @@ public interface Sink<T>
    *
    * @param tuple payload to be processed by this sink.
    */
-  public void put(T tuple);
+  void put(T tuple);
 
   /**
    * Give the count of the tuples processed since the last reset.
@@ -74,6 +74,6 @@ public interface Sink<T>
    * @param reset reset the count if true.
    * @return the count of tuples processed since the last reset.
    */
-  public int getCount(boolean reset);
+  int getCount(boolean reset);
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/Stats.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/Stats.java b/api/src/main/java/com/datatorrent/api/Stats.java
index 0e4377d..b50c3d7 100644
--- a/api/src/main/java/com/datatorrent/api/Stats.java
+++ b/api/src/main/java/com/datatorrent/api/Stats.java
@@ -29,7 +29,7 @@ import java.util.Map;
  */
 public interface Stats extends Serializable
 {
-  public static final long INVALID_TIME_MILLIS = -1;
+  long INVALID_TIME_MILLIS = -1;
 
   interface Checkpoint extends Serializable
   {
@@ -48,7 +48,7 @@ public interface Stats extends Serializable
     }
   }
 
-  public static class OperatorStats implements Stats
+  class OperatorStats implements Stats
   {
     public long windowId;
     public Checkpoint checkpoint;

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/StatsListener.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StatsListener.java b/api/src/main/java/com/datatorrent/api/StatsListener.java
index 624a095..ec4d5a0 100644
--- a/api/src/main/java/com/datatorrent/api/StatsListener.java
+++ b/api/src/main/java/com/datatorrent/api/StatsListener.java
@@ -44,7 +44,7 @@ public interface StatsListener
    * Command to be executed at subsequent end of window on the operator instance that is deployed in the container.
    * Provides the opportunity to define operator specific actions such as method invocation or property set.
    */
-  public interface OperatorRequest
+  interface OperatorRequest
   {
     /**
      * Execute the command.
@@ -54,14 +54,14 @@ public interface StatsListener
      * @param windowId
      * @throws IOException
      */
-    public OperatorResponse execute(Operator operator, int operatorId, long windowId) throws IOException;
+    OperatorResponse execute(Operator operator, int operatorId, long windowId) throws IOException;
   }
 
   /**
    * Use {@link OperatorRequest}
    */
   @Deprecated
-  public interface OperatorCommand
+  interface OperatorCommand
   {
     /**
      * Execute the command.
@@ -71,28 +71,28 @@ public interface StatsListener
      * @param windowId
      * @throws IOException
      */
-    public void execute(Operator operator, int operatorId, long windowId) throws IOException;
+    void execute(Operator operator, int operatorId, long windowId) throws IOException;
   }
 
-  public interface OperatorResponse
+  interface OperatorResponse
   {
 
     /*
      * The Object to identify the response
      */
-    public Object getResponseId();
+    Object getResponseId();
 
     /*
      * The data payload that needs to be sent back
      */
-    public Object getResponse();
+    Object getResponse();
 
   }
 
   /**
    * List of recent, per window operator stats and moving averages.
    */
-  public interface BatchedOperatorStats
+  interface BatchedOperatorStats
   {
     /**
       Stats list will typically contain multiple entries, depending on streaming window size and heartbeat interval.
@@ -115,7 +115,7 @@ public interface StatsListener
     List<OperatorResponse> getOperatorResponse();
   }
 
-  public class Response implements Serializable
+  class Response implements Serializable
   {
     /**
      * Set true to request repartition of the logical operator.
@@ -160,7 +160,7 @@ public interface StatsListener
    */
   @Target(ElementType.TYPE)
   @Retention(RetentionPolicy.RUNTIME)
-  public @interface DataQueueSize
+  @interface DataQueueSize
   {
   }
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/StorageAgent.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/StorageAgent.java b/api/src/main/java/com/datatorrent/api/StorageAgent.java
index ed3681f..e2cc3b9 100644
--- a/api/src/main/java/com/datatorrent/api/StorageAgent.java
+++ b/api/src/main/java/com/datatorrent/api/StorageAgent.java
@@ -42,7 +42,7 @@ public interface StorageAgent
    * @param windowId - Identifier for the specific state of the operator.
    * @throws IOException
    */
-  public void save(Object object, int operatorId, long windowId) throws IOException;
+  void save(Object object, int operatorId, long windowId) throws IOException;
 
   /**
    * Get the input stream from which can be used to retrieve the stored objects back.
@@ -52,7 +52,7 @@ public interface StorageAgent
    * @return object (or a copy of it) which was saved earlier using the save call.
    * @throws IOException
    */
-  public Object load(int operatorId, long windowId) throws IOException;
+  Object load(int operatorId, long windowId) throws IOException;
 
   /**
    * Delete the artifacts related to store call of the operatorId and the windowId.
@@ -64,7 +64,7 @@ public interface StorageAgent
    * @param windowId
    * @throws IOException
    */
-  public void delete(int operatorId, long windowId) throws IOException;
+  void delete(int operatorId, long windowId) throws IOException;
 
   /**
    * Return an array windowId for which the object was saved but not deleted.
@@ -77,13 +77,13 @@ public interface StorageAgent
    * @return Collection of windowIds for available states that can be retrieved through load.
    * @throws IOException
    */
-  public long[] getWindowIds(int operatorId) throws IOException;
+  long[] getWindowIds(int operatorId) throws IOException;
 
   /**
    * Interface to pass application attributes to storage agent
    *
    */
-  public interface ApplicationAwareStorageAgent extends StorageAgent
+  interface ApplicationAwareStorageAgent extends StorageAgent
   {
 
     /**
@@ -91,7 +91,7 @@ public interface StorageAgent
      *
      * @param map attributes of application
      */
-    public void setApplicationAttributes(AttributeMap map);
+    void setApplicationAttributes(AttributeMap map);
   }
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java b/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
index 7393cd5..cafe4b7 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/ApplicationAnnotation.java
@@ -44,6 +44,6 @@ public @interface ApplicationAnnotation
    * <li>Runtime application alias -- specified in application code</li>
    *
    */
-  public String name();
+  String name();
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java b/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
index 76fe497..3c6da18 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/InputPortFieldAnnotation.java
@@ -39,7 +39,7 @@ public @interface InputPortFieldAnnotation
    *
    * @return - true if port is optional, false otherwise.
    */
-  public boolean optional() default false;
+  boolean optional() default false;
 
   /**
    * Whether this port needs to know the tuple class. When true, application will have to set
@@ -47,5 +47,5 @@ public @interface InputPortFieldAnnotation
    *
    * @return true if schema is required; false otherwise.
    */
-  public boolean schemaRequired() default false;
+  boolean schemaRequired() default false;
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/annotation/OperatorAnnotation.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/OperatorAnnotation.java b/api/src/main/java/com/datatorrent/api/annotation/OperatorAnnotation.java
index 8c708f3..16fd370 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/OperatorAnnotation.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/OperatorAnnotation.java
@@ -39,7 +39,7 @@ public @interface OperatorAnnotation
    * Default value is true indicating operator can be partitioned.
    * @return Whether operator can be partitioned or not
    */
-  public boolean partitionable() default true;
+  boolean partitionable() default true;
 
   /**
    * Element specifying whether an operator can be check-pointed in the middle of an application window.
@@ -48,5 +48,5 @@ public @interface OperatorAnnotation
    *
    * @return whether operator can be checkpointed in middle of an application window.
    */
-  public boolean checkpointableWithinAppWindow() default true;
+  boolean checkpointableWithinAppWindow() default true;
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/annotation/OutputPortFieldAnnotation.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/OutputPortFieldAnnotation.java b/api/src/main/java/com/datatorrent/api/annotation/OutputPortFieldAnnotation.java
index 62b43c6..749c59f 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/OutputPortFieldAnnotation.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/OutputPortFieldAnnotation.java
@@ -38,11 +38,11 @@ public @interface OutputPortFieldAnnotation
   /**
    * <p>optional.</p>
    */
-  public boolean optional() default true;
+  boolean optional() default true;
   /**
    * <p>error.</p>
    */
-  public boolean error() default false;
+  boolean error() default false;
 
   /**
    * Whether this port needs to know the tuple class. When true, application will have to set
@@ -50,6 +50,6 @@ public @interface OutputPortFieldAnnotation
    *
    * @return  true if schema is required; false otherwise.
    */
-  public boolean schemaRequired() default false;
+  boolean schemaRequired() default false;
 }
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/com/datatorrent/api/annotation/RecordField.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/com/datatorrent/api/annotation/RecordField.java b/api/src/main/java/com/datatorrent/api/annotation/RecordField.java
index 1675c54..4d6c126 100644
--- a/api/src/main/java/com/datatorrent/api/annotation/RecordField.java
+++ b/api/src/main/java/com/datatorrent/api/annotation/RecordField.java
@@ -37,7 +37,7 @@ public @interface RecordField
    /**
     * <p>type.</p>
     */
-   public String type();
+   String type();
 
-   public boolean publish() default true;
+   boolean publish() default true;
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/api/src/main/java/org/apache/apex/api/DAGSetupPlugin.java
----------------------------------------------------------------------
diff --git a/api/src/main/java/org/apache/apex/api/DAGSetupPlugin.java b/api/src/main/java/org/apache/apex/api/DAGSetupPlugin.java
index 6c54bed..3fc46bc 100644
--- a/api/src/main/java/org/apache/apex/api/DAGSetupPlugin.java
+++ b/api/src/main/java/org/apache/apex/api/DAGSetupPlugin.java
@@ -87,7 +87,7 @@ public interface DAGSetupPlugin extends ApexPlugin<DAGSetupPlugin.DAGSetupPlugin
    */
   void postValidateDAG();
 
-  public static class DAGSetupPluginContext implements ApexPluginContext
+  class DAGSetupPluginContext implements ApexPluginContext
   {
     private final DAG dag;
     private final Configuration conf;

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/bufferserver/src/main/java/com/datatorrent/bufferserver/storage/Storage.java
----------------------------------------------------------------------
diff --git a/bufferserver/src/main/java/com/datatorrent/bufferserver/storage/Storage.java b/bufferserver/src/main/java/com/datatorrent/bufferserver/storage/Storage.java
index 1a3a7fb..19ef681 100644
--- a/bufferserver/src/main/java/com/datatorrent/bufferserver/storage/Storage.java
+++ b/bufferserver/src/main/java/com/datatorrent/bufferserver/storage/Storage.java
@@ -43,7 +43,7 @@ public interface Storage
    * @return instance of storage.
    * @throws IOException
    */
-  public Storage getInstance() throws IOException;
+  Storage getInstance() throws IOException;
 
   /**
    * Store memory block represented by block in non memory storage.
@@ -60,7 +60,7 @@ public interface Storage
    * @param end - the offset of the last byte in the array.
    * @return unique identifier for the stored block.
    */
-  public int store(String Identifier, byte[] bytes, int start, int end);
+  int store(String Identifier, byte[] bytes, int start, int end);
 
   /**
    *
@@ -68,7 +68,7 @@ public interface Storage
    * @param uniqueIdentifier secondary and unique identifier of the block which needs to be retrived.
    * @return memory block which was stored with the passed parameters as identifying information.
    */
-  public byte[] retrieve(String identifier, int uniqueIdentifier);
+  byte[] retrieve(String identifier, int uniqueIdentifier);
 
   /**
    * Discard the block stored from the secondary storage.
@@ -76,5 +76,5 @@ public interface Storage
    * @param identifier
    * @param uniqueIdentifier
    */
-  public void discard(String identifier, int uniqueIdentifier);
+  void discard(String identifier, int uniqueIdentifier);
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/bufferserver/src/test/java/com/datatorrent/bufferserver/support/Subscriber.java
----------------------------------------------------------------------
diff --git a/bufferserver/src/test/java/com/datatorrent/bufferserver/support/Subscriber.java b/bufferserver/src/test/java/com/datatorrent/bufferserver/support/Subscriber.java
index d6e9b1a..f44ef1a 100644
--- a/bufferserver/src/test/java/com/datatorrent/bufferserver/support/Subscriber.java
+++ b/bufferserver/src/test/java/com/datatorrent/bufferserver/support/Subscriber.java
@@ -134,15 +134,15 @@ public class Subscriber extends com.datatorrent.bufferserver.client.Subscriber
 
   public interface WindowIdHolder
   {
-    public int getWindowId();
+    int getWindowId();
 
   }
 
   public interface ResetHolder
   {
-    public int getBaseSeconds();
+    int getBaseSeconds();
 
-    public int getWindowWidth();
+    int getWindowWidth();
 
   }
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/common/src/main/java/com/datatorrent/common/experimental/AppData.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/com/datatorrent/common/experimental/AppData.java b/common/src/main/java/com/datatorrent/common/experimental/AppData.java
index bbf9753..dd1b7c3 100644
--- a/common/src/main/java/com/datatorrent/common/experimental/AppData.java
+++ b/common/src/main/java/com/datatorrent/common/experimental/AppData.java
@@ -50,7 +50,7 @@ public interface AppData
      * null then this Store should have a separate query operator connected to it.
      * @return The query connector which is used by the store operator to receive queries.
      */
-    public EmbeddableQueryInfoProvider<QUERY_TYPE> getEmbeddableQueryInfoProvider();
+    EmbeddableQueryInfoProvider<QUERY_TYPE> getEmbeddableQueryInfoProvider();
 
     /**
      * Sets the query connector which is used by the store operator to receive queries. The store operator will call
@@ -58,7 +58,7 @@ public interface AppData
      * its {@link Operator#setup} method is called.
      * @param embeddableQueryInfoProvider The query connector which is used by the store operator to receive queries.
      */
-    public void setEmbeddableQueryInfoProvider(EmbeddableQueryInfoProvider<QUERY_TYPE> embeddableQueryInfoProvider);
+    void setEmbeddableQueryInfoProvider(EmbeddableQueryInfoProvider<QUERY_TYPE> embeddableQueryInfoProvider);
   }
 
   /**
@@ -77,7 +77,7 @@ public interface AppData
      * Gets the output port for queries.
      * @return The output port for queries.
      */
-    public DefaultOutputPort<QUERY_TYPE> getOutputPort();
+    DefaultOutputPort<QUERY_TYPE> getOutputPort();
 
     /**
      * If this method is called at least once then this operator will work as if it were embedded in an {@link AppData.Store}.
@@ -85,7 +85,7 @@ public interface AppData
      * is set on an {@link AppData.Store} then the {@link AppData.Store} will call the {@link EmbeddableQueryInfoProvider#enableEmbeddedMode}
      * method once before the {@link Operator.setup} is called.
      */
-    public void enableEmbeddedMode();
+    void enableEmbeddedMode();
   }
 
   /**
@@ -97,13 +97,13 @@ public interface AppData
      * Returns the connection url used by the appdata Query or Result operator.
      * @return The connection url used by the AppData Query or Result operator.
      */
-    public String getAppDataURL();
+    String getAppDataURL();
 
     /**
      * Returns the topic that the appdata Query or Result operator sends data to.
      * @return The topic that the appdata Query or Result operator sends data to.
      */
-    public String getTopic();
+    String getTopic();
   }
 
   /**
@@ -113,7 +113,7 @@ public interface AppData
   @Target(ElementType.TYPE)
   @Retention(RetentionPolicy.RUNTIME)
   @Inherited
-  public @interface AppendQueryIdToTopic
+  @interface AppendQueryIdToTopic
   {
     boolean value() default false;
   }
@@ -124,7 +124,7 @@ public interface AppData
   @Documented
   @Target(ElementType.FIELD)
   @Retention(RetentionPolicy.RUNTIME)
-  public @interface QueryPort
+  @interface QueryPort
   {
   }
 
@@ -134,7 +134,7 @@ public interface AppData
   @Documented
   @Target(ElementType.FIELD)
   @Retention(RetentionPolicy.RUNTIME)
-  public @interface ResultPort
+  @interface ResultPort
   {
   }
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/common/src/main/java/com/datatorrent/common/util/NumberAggregate.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/com/datatorrent/common/util/NumberAggregate.java b/common/src/main/java/com/datatorrent/common/util/NumberAggregate.java
index 9a89e83..6c4c31e 100644
--- a/common/src/main/java/com/datatorrent/common/util/NumberAggregate.java
+++ b/common/src/main/java/com/datatorrent/common/util/NumberAggregate.java
@@ -30,40 +30,40 @@ public interface NumberAggregate
    *
    * @return The min
    */
-  public Number getMin();
+  Number getMin();
 
   /**
    * Gets the maximum of the given numbers
    *
    * @return The max
    */
-  public Number getMax();
+  Number getMax();
 
   /**
    * Gets the sum of the given numbers
    *
    * @return The sum
    */
-  public Number getSum();
+  Number getSum();
 
   /**
    * Gets the average of the given numbers
    *
    * @return The avg
    */
-  public Number getAvg();
+  Number getAvg();
 
   /**
    * Add a long to the number set
    *
    * @param num the number
    */
-  public void addNumber(Number num);
+  void addNumber(Number num);
 
   /**
    * This is the aggregate class for Long.
    */
-  public static class LongAggregate implements NumberAggregate
+  class LongAggregate implements NumberAggregate
   {
     private int count = 0;
     private long min = Long.MAX_VALUE;
@@ -134,7 +134,7 @@ public interface NumberAggregate
   /**
    * This is the aggregate class for Double.
    */
-  public static class DoubleAggregate implements NumberAggregate
+  class DoubleAggregate implements NumberAggregate
   {
     private int count = 0;
     private double min = Double.MAX_VALUE;

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/common/src/main/java/com/datatorrent/common/util/ScheduledExecutorService.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/com/datatorrent/common/util/ScheduledExecutorService.java b/common/src/main/java/com/datatorrent/common/util/ScheduledExecutorService.java
index 961dbed..3ab24e9 100644
--- a/common/src/main/java/com/datatorrent/common/util/ScheduledExecutorService.java
+++ b/common/src/main/java/com/datatorrent/common/util/ScheduledExecutorService.java
@@ -29,5 +29,5 @@ public interface ScheduledExecutorService extends java.util.concurrent.Scheduled
    *
    * @return long
    */
-  public long getCurrentTimeMillis();
+  long getCurrentTimeMillis();
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/common/src/main/java/org/apache/apex/common/util/AsyncStorageAgent.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/org/apache/apex/common/util/AsyncStorageAgent.java b/common/src/main/java/org/apache/apex/common/util/AsyncStorageAgent.java
index 632a7f2..337ccdd 100644
--- a/common/src/main/java/org/apache/apex/common/util/AsyncStorageAgent.java
+++ b/common/src/main/java/org/apache/apex/common/util/AsyncStorageAgent.java
@@ -41,7 +41,7 @@ public interface AsyncStorageAgent extends StorageAgent
    * @param windowId
    * @throws IOException
    */
-  public void finalize(int operatorId, long windowId) throws IOException;
+  void finalize(int operatorId, long windowId) throws IOException;
 
   /**
    * Check if StorageAgent is configured to take synchronous checkpoints.
@@ -49,6 +49,6 @@ public interface AsyncStorageAgent extends StorageAgent
    * @return true if StorageAgent is configured to take synchronous checkpoints.
    * @return false otherwise.
    */
-  public boolean isSyncCheckpoint();
+  boolean isSyncCheckpoint();
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/EventRecorder.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/EventRecorder.java b/engine/src/main/java/com/datatorrent/stram/EventRecorder.java
index d313693..2994af1 100644
--- a/engine/src/main/java/com/datatorrent/stram/EventRecorder.java
+++ b/engine/src/main/java/com/datatorrent/stram/EventRecorder.java
@@ -27,6 +27,6 @@ import com.datatorrent.stram.api.StramEvent;
  */
 public interface EventRecorder
 {
-  public void recordEventAsync(StramEvent event);
+  void recordEventAsync(StramEvent event);
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/LicensingProtocol.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/LicensingProtocol.java b/engine/src/main/java/com/datatorrent/stram/LicensingProtocol.java
index 5ff255d..4853414 100644
--- a/engine/src/main/java/com/datatorrent/stram/LicensingProtocol.java
+++ b/engine/src/main/java/com/datatorrent/stram/LicensingProtocol.java
@@ -27,7 +27,7 @@ import org.apache.hadoop.ipc.VersionedProtocol;
  */
 public interface LicensingProtocol extends VersionedProtocol
 {
-  public static final long versionID = 201401310447L;
+  long versionID = 201401310447L;
 
-  public byte[] processRequest(byte[] request);
+  byte[] processRequest(byte[] request);
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/StatsRecorder.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/StatsRecorder.java b/engine/src/main/java/com/datatorrent/stram/StatsRecorder.java
index d293ca8..7263529 100644
--- a/engine/src/main/java/com/datatorrent/stram/StatsRecorder.java
+++ b/engine/src/main/java/com/datatorrent/stram/StatsRecorder.java
@@ -31,8 +31,8 @@ import com.datatorrent.stram.webapp.OperatorInfo;
  */
 public interface StatsRecorder
 {
-  public void recordContainers(Map<String, StreamingContainerAgent> containerMap, long timestamp) throws IOException;
+  void recordContainers(Map<String, StreamingContainerAgent> containerMap, long timestamp) throws IOException;
 
-  public void recordOperators(List<OperatorInfo> operatorList, long timestamp) throws IOException;
+  void recordOperators(List<OperatorInfo> operatorList, long timestamp) throws IOException;
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/api/ContainerContext.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/api/ContainerContext.java b/engine/src/main/java/com/datatorrent/stram/api/ContainerContext.java
index 605944e..bc3a187 100644
--- a/engine/src/main/java/com/datatorrent/stram/api/ContainerContext.java
+++ b/engine/src/main/java/com/datatorrent/stram/api/ContainerContext.java
@@ -29,10 +29,10 @@ import com.datatorrent.api.Context;
  */
 public interface ContainerContext extends Context
 {
-  public static final Attribute<String> IDENTIFIER = new Attribute<>("unknown_container_id");
-  public static final Attribute<Integer> BUFFER_SERVER_MB = new Attribute<>(8 * 64);
-  public static final Attribute<byte[]> BUFFER_SERVER_TOKEN = new Attribute<>(null, null);
-  public static final Attribute<RequestFactory> REQUEST_FACTORY = new Attribute<>(null, null);
+  Attribute<String> IDENTIFIER = new Attribute<>("unknown_container_id");
+  Attribute<Integer> BUFFER_SERVER_MB = new Attribute<>(8 * 64);
+  Attribute<byte[]> BUFFER_SERVER_TOKEN = new Attribute<>(null, null);
+  Attribute<RequestFactory> REQUEST_FACTORY = new Attribute<>(null, null);
   @SuppressWarnings("FieldNameHidesFieldInSuperclass")
   long serialVersionUID = AttributeInitializer.initialize(ContainerContext.class);
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/api/NodeActivationListener.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/api/NodeActivationListener.java b/engine/src/main/java/com/datatorrent/stram/api/NodeActivationListener.java
index dd9ac30..f5b2576 100644
--- a/engine/src/main/java/com/datatorrent/stram/api/NodeActivationListener.java
+++ b/engine/src/main/java/com/datatorrent/stram/api/NodeActivationListener.java
@@ -32,13 +32,13 @@ public interface NodeActivationListener
    *
    * @param node node which got activated.
    */
-  public void activated(Node<?> node);
+  void activated(Node<?> node);
 
   /**
    * Callback to notify the listner that the node has been activated.
    *
    * @param node node which got deactivated.
    */
-  public void deactivated(Node<?> node);
+  void deactivated(Node<?> node);
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/api/StreamingContainerUmbilicalProtocol.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/api/StreamingContainerUmbilicalProtocol.java b/engine/src/main/java/com/datatorrent/stram/api/StreamingContainerUmbilicalProtocol.java
index b78e8f2..eba10db 100644
--- a/engine/src/main/java/com/datatorrent/stram/api/StreamingContainerUmbilicalProtocol.java
+++ b/engine/src/main/java/com/datatorrent/stram/api/StreamingContainerUmbilicalProtocol.java
@@ -54,7 +54,7 @@ import com.datatorrent.stram.util.AbstractWritableAdapter;
 @InterfaceStability.Stable
 public interface StreamingContainerUmbilicalProtocol extends VersionedProtocol
 {
-  public static final long versionID = 201208081755L;
+  long versionID = 201208081755L;
 
   /**
    * Initialization parameters for StramChild container. Container

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/client/StramClientUtils.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/client/StramClientUtils.java b/engine/src/main/java/com/datatorrent/stram/client/StramClientUtils.java
index 8076d4a..15adab4 100644
--- a/engine/src/main/java/com/datatorrent/stram/client/StramClientUtils.java
+++ b/engine/src/main/java/com/datatorrent/stram/client/StramClientUtils.java
@@ -197,7 +197,7 @@ public class StramClientUtils
       this.conf = conf;
     }
 
-    public static interface AppStatusCallback
+    public interface AppStatusCallback
     {
       boolean exitLoop(ApplicationReport report);
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/codec/StatefulStreamCodec.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/codec/StatefulStreamCodec.java b/engine/src/main/java/com/datatorrent/stram/codec/StatefulStreamCodec.java
index 3797830..dc47b4e 100644
--- a/engine/src/main/java/com/datatorrent/stram/codec/StatefulStreamCodec.java
+++ b/engine/src/main/java/com/datatorrent/stram/codec/StatefulStreamCodec.java
@@ -32,7 +32,7 @@ public interface StatefulStreamCodec<T> extends StreamCodec<T>
   /**
    * A convenience class which is used to hold 2 different values associated with each serialize/deserialize operation.
    */
-  public class DataStatePair
+  class DataStatePair
   {
     /**
      * This byte array corresponds to serialized form of the tuple of type T.
@@ -85,7 +85,7 @@ public interface StatefulStreamCodec<T> extends StreamCodec<T>
    * should not be confused with the resetState operation of upstream operator.
    *
    */
-  public void resetState();
+  void resetState();
 
   /**
    * Provide a new instance of the current object.
@@ -96,5 +96,5 @@ public interface StatefulStreamCodec<T> extends StreamCodec<T>
    *
    * @return new instance of this codec for which the state has been reset.
    */
-  public StatefulStreamCodec<T> newInstance();
+  StatefulStreamCodec<T> newInstance();
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/engine/ByteCounterStream.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/engine/ByteCounterStream.java b/engine/src/main/java/com/datatorrent/stram/engine/ByteCounterStream.java
index d71ae69..e217f64 100644
--- a/engine/src/main/java/com/datatorrent/stram/engine/ByteCounterStream.java
+++ b/engine/src/main/java/com/datatorrent/stram/engine/ByteCounterStream.java
@@ -25,5 +25,5 @@ package com.datatorrent.stram.engine;
  */
 public interface ByteCounterStream extends Stream
 {
-  public long getByteCount(boolean reset);
+  long getByteCount(boolean reset);
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/engine/Stream.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/engine/Stream.java b/engine/src/main/java/com/datatorrent/stram/engine/Stream.java
index 196134f..1aa0641 100644
--- a/engine/src/main/java/com/datatorrent/stram/engine/Stream.java
+++ b/engine/src/main/java/com/datatorrent/stram/engine/Stream.java
@@ -35,9 +35,9 @@ import com.datatorrent.api.Sink;
  */
 public interface Stream extends Component<StreamContext>, ActivationListener<StreamContext>, ControlTupleEnabledSink<Object>
 {
-  public interface MultiSinkCapableStream extends Stream
+  interface MultiSinkCapableStream extends Stream
   {
-    public void setSink(String id, Sink<Object> sink);
+    void setSink(String id, Sink<Object> sink);
   }
 
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/com/datatorrent/stram/util/SharedPubSubWebSocketClient.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/util/SharedPubSubWebSocketClient.java b/engine/src/main/java/com/datatorrent/stram/util/SharedPubSubWebSocketClient.java
index ad5a423..73572f2 100644
--- a/engine/src/main/java/com/datatorrent/stram/util/SharedPubSubWebSocketClient.java
+++ b/engine/src/main/java/com/datatorrent/stram/util/SharedPubSubWebSocketClient.java
@@ -51,9 +51,9 @@ public class SharedPubSubWebSocketClient extends PubSubWebSocketClient
 
   public interface Handler
   {
-    public void onMessage(String type, String topic, Object data);
+    void onMessage(String type, String topic, Object data);
 
-    public void onClose();
+    void onClose();
 
   }
 

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/main/java/org/apache/apex/engine/api/DAGExecutionPluginContext.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/org/apache/apex/engine/api/DAGExecutionPluginContext.java b/engine/src/main/java/org/apache/apex/engine/api/DAGExecutionPluginContext.java
index dc3153e..d466b23 100644
--- a/engine/src/main/java/org/apache/apex/engine/api/DAGExecutionPluginContext.java
+++ b/engine/src/main/java/org/apache/apex/engine/api/DAGExecutionPluginContext.java
@@ -69,21 +69,21 @@ public interface DAGExecutionPluginContext extends Context
     void handle(T data);
   }
 
-  public StramAppContext getApplicationContext();
+  StramAppContext getApplicationContext();
 
-  public AppInfo.AppStats getApplicationStats();
+  AppInfo.AppStats getApplicationStats();
 
-  public Configuration getLaunchConfig();
+  Configuration getLaunchConfig();
 
-  public DAG getDAG();
+  DAG getDAG();
 
-  public String getOperatorName(int id);
+  String getOperatorName(int id);
 
-  public BatchedOperatorStats getPhysicalOperatorStats(int id);
+  BatchedOperatorStats getPhysicalOperatorStats(int id);
 
-  public List<LogicalOperatorInfo> getLogicalOperatorInfoList();
+  List<LogicalOperatorInfo> getLogicalOperatorInfoList();
 
-  public Queue<Pair<Long, Map<String, Object>>> getWindowMetrics(String operatorName);
+  Queue<Pair<Long, Map<String, Object>>> getWindowMetrics(String operatorName);
 
-  public long windowIdToMillis(long windowId);
+  long windowIdToMillis(long windowId);
 }

http://git-wip-us.apache.org/repos/asf/apex-core/blob/077009e4/engine/src/test/java/com/datatorrent/stram/webapp/TypeDiscoveryTest.java
----------------------------------------------------------------------
diff --git a/engine/src/test/java/com/datatorrent/stram/webapp/TypeDiscoveryTest.java b/engine/src/test/java/com/datatorrent/stram/webapp/TypeDiscoveryTest.java
index 8674e9f..2f0b018 100644
--- a/engine/src/test/java/com/datatorrent/stram/webapp/TypeDiscoveryTest.java
+++ b/engine/src/test/java/com/datatorrent/stram/webapp/TypeDiscoveryTest.java
@@ -39,7 +39,7 @@ import com.datatorrent.common.util.BaseOperator;
 public class TypeDiscoveryTest
 {
 
-  private static interface GenericInterface<T>
+  private interface GenericInterface<T>
   {
   }