You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@apex.apache.org by th...@apache.org on 2015/11/03 03:27:36 UTC

[35/50] [abbrv] incubator-apex-core git commit: Fix EOL

Fix EOL


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

Branch: refs/heads/master
Commit: b527b301a29b05a747f6ce1b43f852c8a4d894f5
Parents: 979a0ef
Author: MalharJenkins <je...@datatorrent.com>
Authored: Tue Oct 20 19:54:58 2015 -0700
Committer: Vlad Rozov <v....@datatorrent.com>
Committed: Tue Oct 20 19:54:58 2015 -0700

----------------------------------------------------------------------
 .../datatorrent/common/util/package-info.java   |  38 +++---
 .../com/datatorrent/stram/cli/package-info.java |  66 ++++-----
 .../datatorrent/stram/engine/package-info.java  |  94 ++++++-------
 .../com/datatorrent/stram/package-info.java     |  54 ++++----
 .../datatorrent/stram/stream/package-info.java  | 136 +++++++++----------
 .../datatorrent/stram/util/package-info.java    |  64 ++++-----
 .../datatorrent/stram/webapp/package-info.java  |  76 +++++------
 7 files changed, 264 insertions(+), 264 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/common/src/main/java/com/datatorrent/common/util/package-info.java
----------------------------------------------------------------------
diff --git a/common/src/main/java/com/datatorrent/common/util/package-info.java b/common/src/main/java/com/datatorrent/common/util/package-info.java
index 41134d0..5bfc38f 100644
--- a/common/src/main/java/com/datatorrent/common/util/package-info.java
+++ b/common/src/main/java/com/datatorrent/common/util/package-info.java
@@ -1,22 +1,22 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
 /**
  * Shared utilities
  */
-package com.datatorrent.common.util;
+package com.datatorrent.common.util;

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/engine/src/main/java/com/datatorrent/stram/cli/package-info.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/cli/package-info.java b/engine/src/main/java/com/datatorrent/stram/cli/package-info.java
index 116366b..05b45e2 100644
--- a/engine/src/main/java/com/datatorrent/stram/cli/package-info.java
+++ b/engine/src/main/java/com/datatorrent/stram/cli/package-info.java
@@ -1,33 +1,33 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/**
- *
- * <b>com.datatorrent.stram.cli</b> package deals with code for command line interface for the streaming platform<p>
- * <br>
- * The cli code wraps the webservices layer (<b>com.datatorrent.stream.webapp</b>) and thus accesses the dag
- * via one single point. All webservice calls for streaming data go through to the stram.<br>
- * <br>
- * The com.datatorrent.stram.cli package consists of<br>
- * <b>{@link com.datatorrent.stram.cli.DTCli}</b>: Provides command line interface for a streaming application on hadoop (yarn)<br>
- * <br>
- *
- */
-package com.datatorrent.stram.cli;
-
-
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/**
+ *
+ * <b>com.datatorrent.stram.cli</b> package deals with code for command line interface for the streaming platform<p>
+ * <br>
+ * The cli code wraps the webservices layer (<b>com.datatorrent.stream.webapp</b>) and thus accesses the dag
+ * via one single point. All webservice calls for streaming data go through to the stram.<br>
+ * <br>
+ * The com.datatorrent.stram.cli package consists of<br>
+ * <b>{@link com.datatorrent.stram.cli.DTCli}</b>: Provides command line interface for a streaming application on hadoop (yarn)<br>
+ * <br>
+ *
+ */
+package com.datatorrent.stram.cli;
+
+

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/engine/src/main/java/com/datatorrent/stram/engine/package-info.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/engine/package-info.java b/engine/src/main/java/com/datatorrent/stram/engine/package-info.java
index e7c1d6e..fdad92f 100644
--- a/engine/src/main/java/com/datatorrent/stram/engine/package-info.java
+++ b/engine/src/main/java/com/datatorrent/stram/engine/package-info.java
@@ -1,47 +1,47 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/**
- * Execution layer for data operators, tuple processing, serialization, streams, window boundaries etc.<p>
- * <br>
- * <br>
- * The streaming platform would take care of the following for you<br>(TBD, add "How it will")<br>
- * - Standard partitioning (round robin, sticky key). You can add  your own partitioning.<br>
- * - End of window statistics collection in terms of number of tuples, bandwidth, I/O etc<br>
- * - Ensuring the the emitted tuple reaches the downstream operators<br>
- * - Queueing tuples and retaining them till all future downstream operators have consumed it<br>
- * <br>
- * <br>
- * There are pre-defined library operators that you can use: see ...<br>
- * Examples are in the following packages<br>
-    <ul>
-      <li><a href="../../../datatorrent/lib/algo/package-summary.html">Algorithmic</a>: A set of algorithmic operators</li>
-      <li><a href="../../../datatorrent/lib/io/package-summary.html">Input-Output</a>: A set of operators for Input-Output from Hadoop. Consists of adapters to various message buses</li>
-      <li><a href="../../../datatorrent/lib/logs/package-summary.html">Log Collection</a>: A set of operators for log collection</li>
-      <li><a href="../../../datatorrent/lib/math/package-summary.html">Arithmetic</a>: A set of arithmetic operators</li>
-      <li><a href="../../../datatorrent/lib/stream/package-summary.html">Stream</a>: A set of operators for stream operations</li>
-      <li><a href="../../../datatorrent/lib/testbench/package-summary.html">Testbench</a>: A set of operators for testing your dag, operators </li>
-      <li><a href="../../../datatorrent/lib/util/package-summary.html">Utilities</a>: A set of utility classes</li>
-    </ul>
- * <br>
- *
- */
-
-package com.datatorrent.stram.engine;
-
-
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/**
+ * Execution layer for data operators, tuple processing, serialization, streams, window boundaries etc.<p>
+ * <br>
+ * <br>
+ * The streaming platform would take care of the following for you<br>(TBD, add "How it will")<br>
+ * - Standard partitioning (round robin, sticky key). You can add  your own partitioning.<br>
+ * - End of window statistics collection in terms of number of tuples, bandwidth, I/O etc<br>
+ * - Ensuring the the emitted tuple reaches the downstream operators<br>
+ * - Queueing tuples and retaining them till all future downstream operators have consumed it<br>
+ * <br>
+ * <br>
+ * There are pre-defined library operators that you can use: see ...<br>
+ * Examples are in the following packages<br>
+    <ul>
+      <li><a href="../../../datatorrent/lib/algo/package-summary.html">Algorithmic</a>: A set of algorithmic operators</li>
+      <li><a href="../../../datatorrent/lib/io/package-summary.html">Input-Output</a>: A set of operators for Input-Output from Hadoop. Consists of adapters to various message buses</li>
+      <li><a href="../../../datatorrent/lib/logs/package-summary.html">Log Collection</a>: A set of operators for log collection</li>
+      <li><a href="../../../datatorrent/lib/math/package-summary.html">Arithmetic</a>: A set of arithmetic operators</li>
+      <li><a href="../../../datatorrent/lib/stream/package-summary.html">Stream</a>: A set of operators for stream operations</li>
+      <li><a href="../../../datatorrent/lib/testbench/package-summary.html">Testbench</a>: A set of operators for testing your dag, operators </li>
+      <li><a href="../../../datatorrent/lib/util/package-summary.html">Utilities</a>: A set of utility classes</li>
+    </ul>
+ * <br>
+ *
+ */
+
+package com.datatorrent.stram.engine;
+
+

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/engine/src/main/java/com/datatorrent/stram/package-info.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/package-info.java b/engine/src/main/java/com/datatorrent/stram/package-info.java
index 3e23940..eb337d6 100644
--- a/engine/src/main/java/com/datatorrent/stram/package-info.java
+++ b/engine/src/main/java/com/datatorrent/stram/package-info.java
@@ -1,27 +1,27 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/**
- * <b>com.datatorrent.stram</b> package contains all code for streaming application master<p>
- * <br>
- * The application master is also called <b>STRAM</b><br>
- * (TBD - To explain all functionality)<br>
- *
- */
-
-package com.datatorrent.stram;
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/**
+ * <b>com.datatorrent.stram</b> package contains all code for streaming application master<p>
+ * <br>
+ * The application master is also called <b>STRAM</b><br>
+ * (TBD - To explain all functionality)<br>
+ *
+ */
+
+package com.datatorrent.stram;

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/engine/src/main/java/com/datatorrent/stram/stream/package-info.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/stream/package-info.java b/engine/src/main/java/com/datatorrent/stram/stream/package-info.java
index e83d345..58fd326 100644
--- a/engine/src/main/java/com/datatorrent/stram/stream/package-info.java
+++ b/engine/src/main/java/com/datatorrent/stram/stream/package-info.java
@@ -1,68 +1,68 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/**
- *
- * <b>com.datatorrent.stream</b> package contains all code related to various implementations of Stream interface<p>
- * <br>
- * A stream is a logical unit of a dag that defines the connection between
- * a node and list of listener operators. Stream has the following properties in Malhar's streaming platform<br>
- * - One writer node<br>
- * - Any number of listener operators<br>
- * - Context as defined by the properties specified in the dag<br>
- * A stream definition in the dag is a logical definition. Multiple logical listerner operators means that the emitted tuple
- * would reach each of them. Partitioning is done when a single
- * logical listener node partitions into multilpe physical operators. This may happen due to initial user
- * specification, or dynamic run time constraint enforcement. In such a scenerio the logical stream gets partitioned
- * into physical streams. Each physical stream would retain the
- * characteristics of the logical node (one writer, multiple readers, and context).<br>
- * <br>
- * The streams included in com.datatorrent.stream include<br>
- * <br>
- * <br><b>Buffer Server Streams</b><br>
- * <b>{@link com.datatorrent.stream.BufferServerInputStream}</b>: extends {@link com.datatorrent.stream.SocketInputStream},
- * takes data from buffer server into the node. Every logical stream will have at least two such
- * objects ({@link com.datatorrent.stream.BufferServerInputStream}
- *  and {@link com.datatorrent.stream.BufferServerOutputStream}). If the logical stream gets partitioned
- * into physical streams then each of these physical streams will have these objects. Inlined version of
- *  a logical stream does not go through the buffer server and hence would not have
- * {@link com.datatorrent.stream.BufferServerInputStream} and {@link com.datatorrent.stream.BufferServerOutputStream} objects<br>
- * <b>{@link com.datatorrent.stream.BufferServerOutputStream}</b>: extends {@link com.datatorrent.stream.SocketOutputStream}
- * and in conjunction with {@link com.datatorrent.stream.BufferServerInputStream} forms a complete stream
- * in a node->buffer server->node path<br>
- * <br><b>Inline Stream (Within a Hadoop Container)</b><br>
- * <b>{@link com.datatorrent.stream.InlineStream}</b>: Streams data between two operators in inline mode. This implementation of
- * {@link com.datatorrent.engine.Stream} and {{@link com.datatorrent.api.Sink}
- * interface does not have connection to BufferServer and cannot be persisted.<br>
- *
- * <b>{@link com.datatorrent.stream.MuxStream}</b>: <br>
- * <b>{@link com.datatorrent.stream.PartitionAwareSink}</b>: <br>
- *
- * <br><b>Socket Interface Streams</b><br>
- * <b>{@link com.datatorrent.stream.SocketInputStream}</b>: Implements {@link com.datatorrent.engine.Stream} interface and provides
- * basic stream connection for a node to read from a socket. Users can use this class if they want to directly connect to
- * a outside socket<br>
- * <b>{@link com.datatorrent.stream.SocketOutputStream}</b>: Implements {@link com.datatorrent.engine.Stream} interface and provides
- * basic stream connection for a node to write to a socket. Most likely users would not use it to write to a socket by themselves.
- *   Would be used in adapters and via {@link com.datatorrent.stream.BufferServerOutputStream}<br>
- * <br>
- *
- */
-
-package com.datatorrent.stram.stream;
-
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/**
+ *
+ * <b>com.datatorrent.stream</b> package contains all code related to various implementations of Stream interface<p>
+ * <br>
+ * A stream is a logical unit of a dag that defines the connection between
+ * a node and list of listener operators. Stream has the following properties in Malhar's streaming platform<br>
+ * - One writer node<br>
+ * - Any number of listener operators<br>
+ * - Context as defined by the properties specified in the dag<br>
+ * A stream definition in the dag is a logical definition. Multiple logical listerner operators means that the emitted tuple
+ * would reach each of them. Partitioning is done when a single
+ * logical listener node partitions into multilpe physical operators. This may happen due to initial user
+ * specification, or dynamic run time constraint enforcement. In such a scenerio the logical stream gets partitioned
+ * into physical streams. Each physical stream would retain the
+ * characteristics of the logical node (one writer, multiple readers, and context).<br>
+ * <br>
+ * The streams included in com.datatorrent.stream include<br>
+ * <br>
+ * <br><b>Buffer Server Streams</b><br>
+ * <b>{@link com.datatorrent.stream.BufferServerInputStream}</b>: extends {@link com.datatorrent.stream.SocketInputStream},
+ * takes data from buffer server into the node. Every logical stream will have at least two such
+ * objects ({@link com.datatorrent.stream.BufferServerInputStream}
+ *  and {@link com.datatorrent.stream.BufferServerOutputStream}). If the logical stream gets partitioned
+ * into physical streams then each of these physical streams will have these objects. Inlined version of
+ *  a logical stream does not go through the buffer server and hence would not have
+ * {@link com.datatorrent.stream.BufferServerInputStream} and {@link com.datatorrent.stream.BufferServerOutputStream} objects<br>
+ * <b>{@link com.datatorrent.stream.BufferServerOutputStream}</b>: extends {@link com.datatorrent.stream.SocketOutputStream}
+ * and in conjunction with {@link com.datatorrent.stream.BufferServerInputStream} forms a complete stream
+ * in a node->buffer server->node path<br>
+ * <br><b>Inline Stream (Within a Hadoop Container)</b><br>
+ * <b>{@link com.datatorrent.stream.InlineStream}</b>: Streams data between two operators in inline mode. This implementation of
+ * {@link com.datatorrent.engine.Stream} and {{@link com.datatorrent.api.Sink}
+ * interface does not have connection to BufferServer and cannot be persisted.<br>
+ *
+ * <b>{@link com.datatorrent.stream.MuxStream}</b>: <br>
+ * <b>{@link com.datatorrent.stream.PartitionAwareSink}</b>: <br>
+ *
+ * <br><b>Socket Interface Streams</b><br>
+ * <b>{@link com.datatorrent.stream.SocketInputStream}</b>: Implements {@link com.datatorrent.engine.Stream} interface and provides
+ * basic stream connection for a node to read from a socket. Users can use this class if they want to directly connect to
+ * a outside socket<br>
+ * <b>{@link com.datatorrent.stream.SocketOutputStream}</b>: Implements {@link com.datatorrent.engine.Stream} interface and provides
+ * basic stream connection for a node to write to a socket. Most likely users would not use it to write to a socket by themselves.
+ *   Would be used in adapters and via {@link com.datatorrent.stream.BufferServerOutputStream}<br>
+ * <br>
+ *
+ */
+
+package com.datatorrent.stram.stream;
+

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/engine/src/main/java/com/datatorrent/stram/util/package-info.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/util/package-info.java b/engine/src/main/java/com/datatorrent/stram/util/package-info.java
index a5e1d50..200bf98 100644
--- a/engine/src/main/java/com/datatorrent/stram/util/package-info.java
+++ b/engine/src/main/java/com/datatorrent/stram/util/package-info.java
@@ -1,32 +1,32 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/**
- * 
- * <b>com.datatorrent.util</b> package consists of utilities classes that Malhar provides<p>
- * <br>
- * The current utilities include<br>
- * <b>{@link com.datatorrent.util.CircularBuffer}</b>: Takes a class T and provides a circular buffer<br>
- * <b>{@link com.datatorrent.util.ScheduledExecutorService}</b>: <br>
- * <b>{@link com.datatorrent.util.ScheduledThreadPoolExecutor}</b>: <br>
- * <b>{@link com.datatorrent.util.StablePriorityQueue}</b>: Implements a priority queue (Queue<E>) and is mainly used to queue tuples<br> 
- * <br>
- */
-
-package com.datatorrent.stram.util;
-
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/**
+ * 
+ * <b>com.datatorrent.util</b> package consists of utilities classes that Malhar provides<p>
+ * <br>
+ * The current utilities include<br>
+ * <b>{@link com.datatorrent.util.CircularBuffer}</b>: Takes a class T and provides a circular buffer<br>
+ * <b>{@link com.datatorrent.util.ScheduledExecutorService}</b>: <br>
+ * <b>{@link com.datatorrent.util.ScheduledThreadPoolExecutor}</b>: <br>
+ * <b>{@link com.datatorrent.util.StablePriorityQueue}</b>: Implements a priority queue (Queue<E>) and is mainly used to queue tuples<br> 
+ * <br>
+ */
+
+package com.datatorrent.stram.util;
+

http://git-wip-us.apache.org/repos/asf/incubator-apex-core/blob/b527b301/engine/src/main/java/com/datatorrent/stram/webapp/package-info.java
----------------------------------------------------------------------
diff --git a/engine/src/main/java/com/datatorrent/stram/webapp/package-info.java b/engine/src/main/java/com/datatorrent/stram/webapp/package-info.java
index a3d18bf..947f262 100644
--- a/engine/src/main/java/com/datatorrent/stram/webapp/package-info.java
+++ b/engine/src/main/java/com/datatorrent/stram/webapp/package-info.java
@@ -1,38 +1,38 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *   http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-/**
- *
- * <b>com.datatorrent.stram.webapp</b> package is the web service layer of Malhar's streaming platform<p>
- * <br>
- * The webservices layer interacts with the streaming application master (stram). The internals of Hadoop are taken care
- * off and an common set of functionality is provided for all streaming related runtime data.<br>
- * <br>
- * The webservices layer consists of the following data:<br>
- * <b>{@link com.datatorrent.stram.webapp.AppInfo}</b>: Provides application level data like user, appId, elapsed time, etc.<br>
- * <b>{@link com.datatorrent.stram.webapp.OperatorInfo}</b>: Provides data on the operator. This includes throughput, container id etc.<br>
- * <b>{@link com.datatorrent.stram.webapp.OperatorsInfo}</b>: Provides data on all the operators of the data.<br>
- * <b>{@link com.datatorrent.stram.webapp.StramWebApp}</b>: TBD<br>
- * <b>{@link com.datatorrent.stram.webapp.StramWebServices}</b>: TBD<br>
- * <b>Access and Authoriation</b>: TBD<br>
- * <br>
- *
- */
-
-package com.datatorrent.stram.webapp;
-
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *   http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing,
+ * software distributed under the License is distributed on an
+ * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
+ * KIND, either express or implied.  See the License for the
+ * specific language governing permissions and limitations
+ * under the License.
+ */
+/**
+ *
+ * <b>com.datatorrent.stram.webapp</b> package is the web service layer of Malhar's streaming platform<p>
+ * <br>
+ * The webservices layer interacts with the streaming application master (stram). The internals of Hadoop are taken care
+ * off and an common set of functionality is provided for all streaming related runtime data.<br>
+ * <br>
+ * The webservices layer consists of the following data:<br>
+ * <b>{@link com.datatorrent.stram.webapp.AppInfo}</b>: Provides application level data like user, appId, elapsed time, etc.<br>
+ * <b>{@link com.datatorrent.stram.webapp.OperatorInfo}</b>: Provides data on the operator. This includes throughput, container id etc.<br>
+ * <b>{@link com.datatorrent.stram.webapp.OperatorsInfo}</b>: Provides data on all the operators of the data.<br>
+ * <b>{@link com.datatorrent.stram.webapp.StramWebApp}</b>: TBD<br>
+ * <b>{@link com.datatorrent.stram.webapp.StramWebServices}</b>: TBD<br>
+ * <b>Access and Authoriation</b>: TBD<br>
+ * <br>
+ *
+ */
+
+package com.datatorrent.stram.webapp;
+