You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by ch...@apache.org on 2018/09/05 14:48:33 UTC

[flink] branch master updated (8dfbf96 -> e5ff2de)

This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a change to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git.


    from 8dfbf96  [hotfix][checkstyle] Enable checkstyle for flink-core/api.java.functions
     new 7b3b8af  [hotfix][checkstyle] Remove suppression for runtime/test.runtime.zookeeper
     new 289bd86  [hotfix][checkstyle] Remove suppression for runtime/io.disk
     new 82c0db7  [hotfix][checkstyle] Remove suppression for runtime/network.buffer
     new 9cb4679  [hotfix][checkstyle] Remove suppression for runtime/minicluster
     new 0e8a36d  [hotfix][checkstyle] Remove suppression for runtime/test.runtime.testutils
     new b53a333  [hotfix][checkstyle] Remove suppression for runtime/network.serialization
     new e5ff2de  [hotfix][checkstyle] Remove suppression for runtime/concurrent

The 7 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.


Summary of changes:
 .../runtime/io/network/buffer/BufferConsumer.java  |  5 ++--
 .../runtime/io/network/buffer/BufferPool.java      |  8 +++---
 .../io/network/buffer/BufferPoolFactory.java       |  2 +-
 .../runtime/io/network/buffer/BufferPoolOwner.java |  3 +++
 .../runtime/io/network/buffer/BufferRecycler.java  |  3 +++
 .../io/network/buffer/FreeingBufferRecycler.java   |  6 ++---
 .../minicluster/OneTimeLeaderListenerFuture.java   |  6 ++---
 .../runtime/minicluster/StandaloneMiniCluster.java |  2 +-
 .../runtime/concurrent/ConjunctFutureTest.java     |  2 +-
 .../flink/runtime/concurrent/FutureUtilsTest.java  |  2 +-
 .../network/buffer/LocalBufferPoolDestroyTest.java |  3 +++
 .../io/network/buffer/LocalBufferPoolTest.java     |  9 ++++---
 .../serialization/types/LargeObjectType.java       | 18 +++++++------
 tools/maven/suppressions-runtime.xml               | 30 +++-------------------
 14 files changed, 46 insertions(+), 53 deletions(-)


[flink] 07/07: [hotfix][checkstyle] Remove suppression for runtime/concurrent

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit e5ff2de8b81243739dde82969ede9bcd71cd773b
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 16:40:11 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/concurrent
---
 .../org/apache/flink/runtime/concurrent/ConjunctFutureTest.java    | 2 +-
 .../java/org/apache/flink/runtime/concurrent/FutureUtilsTest.java  | 2 +-
 tools/maven/suppressions-runtime.xml                               | 7 -------
 3 files changed, 2 insertions(+), 9 deletions(-)

diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/ConjunctFutureTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/ConjunctFutureTest.java
index f92504e..9f33866 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/ConjunctFutureTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/ConjunctFutureTest.java
@@ -193,7 +193,7 @@ public class ConjunctFutureTest extends TestLogger {
 	}
 
 	/**
-	 * Tests that the conjunct future returns upon completion the collection of all future values
+	 * Tests that the conjunct future returns upon completion the collection of all future values.
 	 */
 	@Test
 	public void testConjunctFutureValue() throws ExecutionException, InterruptedException {
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/FutureUtilsTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/FutureUtilsTest.java
index 1639c91..c386952 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/FutureUtilsTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/concurrent/FutureUtilsTest.java
@@ -535,7 +535,7 @@ public class FutureUtilsTest extends TestLogger {
 			final FlinkException suppressedException;
 
 			if (actual.equals(testException1)) {
-				 suppressedException = testException2;
+				suppressedException = testException2;
 			} else {
 				suppressedException = testException1;
 			}
diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index c145d9b..5efc974 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -45,13 +45,6 @@ under the License.
 		files="(.*)test[/\\](.*)runtime[/\\]clusterframework[/\\](.*)"
 		checks="AvoidStarImport"/>
 	<suppress
-		files="(.*)runtime[/\\]concurrent[/\\](.*)"
-		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
-	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
-	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]concurrent[/\\](.*)"
-		checks="AvoidStarImport"/>
-	<suppress
 		files="(.*)runtime[/\\]execution[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
 	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->


[flink] 02/07: [hotfix][checkstyle] Remove suppression for runtime/io.disk

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit 289bd86e07653cfc7ae5c23bec33e8d9318131d4
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 16:31:08 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/io.disk
---
 tools/maven/suppressions-runtime.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)

diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index b7ba6b1..16f48a1 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -80,11 +80,11 @@ under the License.
 		files="(.*)test[/\\](.*)runtime[/\\]instance[/\\](.*)"
 		checks="AvoidStarImport"/>
 	<suppress
-		files="(.*)runtime[/\\]io[/\\](async|disk)[/\\](.*)"
+		files="(.*)runtime[/\\]io[/\\]disk[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
 	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
 	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]io[/\\](async|disk)[/\\](.*)"
+		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]disk[/\\](.*)"
 		checks="AvoidStarImport|UnusedImports"/>
 	<suppress
 		files="(.*)runtime[/\\]io[/\\]network[/\\](buffer|netty|partition|serialization|util)[/\\](.*)"


[flink] 01/07: [hotfix][checkstyle] Remove suppression for runtime/test.runtime.zookeeper

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit 7b3b8afcae0e205a38695149c32d7158fb26f605
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 15:32:50 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/test.runtime.zookeeper
---
 tools/maven/suppressions-runtime.xml | 4 ----
 1 file changed, 4 deletions(-)

diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index 33a92e3..b7ba6b1 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -198,10 +198,6 @@ under the License.
 	<suppress
 		files="(.*)runtime[/\\]zookeeper[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
-	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
-	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]zookeeper[/\\](.*)"
-		checks="AvoidStarImport"/>
 	<suppress
 		files="(.*)StateBackendTestBase.java"
 		checks="FileLength"/>


[flink] 03/07: [hotfix][checkstyle] Remove suppression for runtime/network.buffer

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit 82c0db7e52586f501b905b67fa1297a9fb610e40
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 16:31:36 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/network.buffer
---
 .../apache/flink/runtime/io/network/buffer/BufferConsumer.java   | 5 +++--
 .../org/apache/flink/runtime/io/network/buffer/BufferPool.java   | 8 ++++----
 .../flink/runtime/io/network/buffer/BufferPoolFactory.java       | 2 +-
 .../apache/flink/runtime/io/network/buffer/BufferPoolOwner.java  | 3 +++
 .../apache/flink/runtime/io/network/buffer/BufferRecycler.java   | 3 +++
 .../flink/runtime/io/network/buffer/FreeingBufferRecycler.java   | 6 +++---
 .../runtime/io/network/buffer/LocalBufferPoolDestroyTest.java    | 3 +++
 .../flink/runtime/io/network/buffer/LocalBufferPoolTest.java     | 9 ++++++---
 tools/maven/suppressions-runtime.xml                             | 4 ++--
 9 files changed, 28 insertions(+), 15 deletions(-)

diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferConsumer.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferConsumer.java
index 4bad92f..f368ff0 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferConsumer.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferConsumer.java
@@ -90,11 +90,12 @@ public class BufferConsumer implements Closeable {
 	}
 
 	/**
-	 * @return a retained copy of self with separate indexes - it allows two read from the same {@link MemorySegment}
-	 * twice.
+	 * Returns a retained copy with separate indexes. This allows to read from the same {@link MemorySegment} twice.
 	 *
 	 * <p>WARNING: newly returned {@link BufferConsumer} will have reader index copied from the original buffer. In
 	 * other words, data already consumed before copying will not be visible to the returned copies.
+	 *
+	 * @return a retained copy of self with separate indexes
 	 */
 	public BufferConsumer copy() {
 		return new BufferConsumer(buffer.retainBuffer(), writerPosition.positionMarker, currentReaderPosition);
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPool.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPool.java
index a4928ed..2927fae 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPool.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPool.java
@@ -34,7 +34,7 @@ public interface BufferPool extends BufferProvider, BufferRecycler {
 	/**
 	 * Destroys this buffer pool.
 	 *
-	 * <p> If not all buffers are available, they are recycled lazily as soon as they are recycled.
+	 * <p>If not all buffers are available, they are recycled lazily as soon as they are recycled.
 	 */
 	void lazyDestroy();
 
@@ -50,7 +50,7 @@ public interface BufferPool extends BufferProvider, BufferRecycler {
 	int getNumberOfRequiredMemorySegments();
 
 	/**
-	 * Returns the maximum number of memory segments this buffer pool should use
+	 * Returns the maximum number of memory segments this buffer pool should use.
 	 *
 	 * @return maximum number of memory segments to use or <tt>-1</tt> if unlimited
 	 */
@@ -59,14 +59,14 @@ public interface BufferPool extends BufferProvider, BufferRecycler {
 	/**
 	 * Returns the current size of this buffer pool.
 	 *
-	 * <p> The size of the buffer pool can change dynamically at runtime.
+	 * <p>The size of the buffer pool can change dynamically at runtime.
 	 */
 	int getNumBuffers();
 
 	/**
 	 * Sets the current size of this buffer pool.
 	 *
-	 * <p> The size needs to be greater or equal to the guaranteed number of memory segments.
+	 * <p>The size needs to be greater or equal to the guaranteed number of memory segments.
 	 */
 	void setNumBuffers(int numBuffers) throws IOException;
 
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolFactory.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolFactory.java
index ffed432..c90e302 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolFactory.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolFactory.java
@@ -29,7 +29,7 @@ public interface BufferPoolFactory {
 	 * Tries to create a buffer pool, which is guaranteed to provide at least the number of required
 	 * buffers.
 	 *
-	 * <p> The buffer pool is of dynamic size with at least <tt>numRequiredBuffers</tt> buffers.
+	 * <p>The buffer pool is of dynamic size with at least <tt>numRequiredBuffers</tt> buffers.
 	 *
 	 * @param numRequiredBuffers
 	 * 		minimum number of network buffers in this pool
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolOwner.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolOwner.java
index 66a6995..acfe240 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolOwner.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferPoolOwner.java
@@ -20,6 +20,9 @@ package org.apache.flink.runtime.io.network.buffer;
 
 import java.io.IOException;
 
+/**
+ * Interface for releasing memory buffers.
+ */
 public interface BufferPoolOwner {
 
 	void releaseMemory(int numBuffersToRecycle) throws IOException;
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferRecycler.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferRecycler.java
index a6495d0..66b1fa2 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferRecycler.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/BufferRecycler.java
@@ -20,6 +20,9 @@ package org.apache.flink.runtime.io.network.buffer;
 
 import org.apache.flink.core.memory.MemorySegment;
 
+/**
+ * Interface for recycling {@link MemorySegment}s.
+ */
 public interface BufferRecycler {
 
 	/**
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/FreeingBufferRecycler.java b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/FreeingBufferRecycler.java
index fdce883..548c0cc 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/FreeingBufferRecycler.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/io/network/buffer/FreeingBufferRecycler.java
@@ -24,11 +24,11 @@ import org.apache.flink.core.memory.MemorySegment;
  * A simple buffer recycler that frees the memory segments.
  */
 public class FreeingBufferRecycler implements BufferRecycler {
-	
+
 	public static final BufferRecycler INSTANCE = new FreeingBufferRecycler();
-	
+
 	// ------------------------------------------------------------------------
-	
+
 	// Not instantiable
 	private FreeingBufferRecycler() {}
 
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolDestroyTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolDestroyTest.java
index fcbf9d5..5e8e42e 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolDestroyTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolDestroyTest.java
@@ -26,6 +26,9 @@ import static org.junit.Assert.assertNotNull;
 import static org.junit.Assert.assertNull;
 import static org.junit.Assert.assertTrue;
 
+/**
+ * Tests for the destruction of a {@link LocalBufferPool}.
+ */
 public class LocalBufferPoolDestroyTest {
 
 	/**
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolTest.java
index 7a6fe6a..537d167 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/buffer/LocalBufferPoolTest.java
@@ -50,17 +50,20 @@ import static org.mockito.Mockito.times;
 import static org.mockito.Mockito.verify;
 import static org.powermock.api.mockito.PowerMockito.spy;
 
+/**
+ * Tests for the {@link LocalBufferPool}.
+ */
 public class LocalBufferPoolTest extends TestLogger {
 
-	private final static int numBuffers = 1024;
+	private static final int numBuffers = 1024;
 
-	private final static int memorySegmentSize = 128;
+	private static final int memorySegmentSize = 128;
 
 	private NetworkBufferPool networkBufferPool;
 
 	private BufferPool localBufferPool;
 
-	private final static ExecutorService executor = Executors.newCachedThreadPool();
+	private static final ExecutorService executor = Executors.newCachedThreadPool();
 
 	@Before
 	public void setupLocalBufferPool() {
diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index 16f48a1..7d6f60c 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -87,11 +87,11 @@ under the License.
 		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]disk[/\\](.*)"
 		checks="AvoidStarImport|UnusedImports"/>
 	<suppress
-		files="(.*)runtime[/\\]io[/\\]network[/\\](buffer|netty|partition|serialization|util)[/\\](.*)"
+		files="(.*)runtime[/\\]io[/\\]network[/\\](netty|partition|serialization|util)[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
 	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
 	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]network[/\\](buffer|netty|partition|serialization|util)[/\\](.*)"
+		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]network[/\\](netty|partition|serialization|util)[/\\](.*)"
 		checks="AvoidStarImport|UnusedImports"/>
 	<!--Test class copied from the netty project-->
 	<suppress


[flink] 04/07: [hotfix][checkstyle] Remove suppression for runtime/minicluster

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit 9cb46791348c830b56177a7b70855402f82951e9
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 16:32:03 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/minicluster
---
 .../flink/runtime/minicluster/OneTimeLeaderListenerFuture.java     | 6 +++---
 .../apache/flink/runtime/minicluster/StandaloneMiniCluster.java    | 2 +-
 tools/maven/suppressions-runtime.xml                               | 7 -------
 3 files changed, 4 insertions(+), 11 deletions(-)

diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/OneTimeLeaderListenerFuture.java b/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/OneTimeLeaderListenerFuture.java
index 77b9847..c328dd5 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/OneTimeLeaderListenerFuture.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/OneTimeLeaderListenerFuture.java
@@ -25,8 +25,8 @@ import java.util.UUID;
 import java.util.concurrent.CompletableFuture;
 
 /**
- * A leader listener that exposes a future for the first leader notification.  
- * 
+ * A leader listener that exposes a future for the first leader notification.
+ *
  * <p>The future can be obtained via the {@link #future()} method.
  */
 public class OneTimeLeaderListenerFuture implements LeaderRetrievalListener {
@@ -38,7 +38,7 @@ public class OneTimeLeaderListenerFuture implements LeaderRetrievalListener {
 	}
 
 	/**
-	 * Gets the future that is completed with the leader address and ID. 
+	 * Gets the future that is completed with the leader address and ID.
 	 * @return The future.
 	 */
 	public CompletableFuture<LeaderAddressAndId> future() {
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/StandaloneMiniCluster.java b/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/StandaloneMiniCluster.java
index 808de22..1ef1f3b 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/StandaloneMiniCluster.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/minicluster/StandaloneMiniCluster.java
@@ -43,8 +43,8 @@ import akka.pattern.Patterns;
 import java.util.concurrent.CompletableFuture;
 import java.util.concurrent.ScheduledExecutorService;
 import java.util.concurrent.ScheduledThreadPoolExecutor;
-import java.util.concurrent.TimeoutException;
 import java.util.concurrent.TimeUnit;
+import java.util.concurrent.TimeoutException;
 
 import scala.Option;
 import scala.concurrent.Await;
diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index 7d6f60c..4259451 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -133,13 +133,6 @@ under the License.
 		files="(.*)test[/\\](.*)runtime[/\\]messages[/\\](.*)"
 		checks="AvoidStarImport"/>
 	<suppress
-		files="(.*)runtime[/\\]minicluster[/\\](.*)"
-		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
-	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
-	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]minicluster[/\\](.*)"
-		checks="AvoidStarImport"/>
-	<suppress
 		files="(.*)runtime[/\\]operators[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
 	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->


[flink] 06/07: [hotfix][checkstyle] Remove suppression for runtime/network.serialization

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit b53a333c1701fb616c9e0adb36b44cfbd0af7a4c
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 16:34:23 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/network.serialization
---
 .../network/serialization/types/LargeObjectType.java   | 18 ++++++++++--------
 tools/maven/suppressions-runtime.xml                   |  4 ++--
 2 files changed, 12 insertions(+), 10 deletions(-)

diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/serialization/types/LargeObjectType.java b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/serialization/types/LargeObjectType.java
index 8efd2bb..dfea937 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/serialization/types/LargeObjectType.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/io/network/serialization/types/LargeObjectType.java
@@ -16,20 +16,22 @@
  * limitations under the License.
  */
 
-
 package org.apache.flink.runtime.io.network.serialization.types;
 
-import java.io.IOException;
-import java.util.Random;
-
 import org.apache.flink.core.memory.DataInputView;
 import org.apache.flink.core.memory.DataOutputView;
 import org.apache.flink.testutils.serialization.types.SerializationTestType;
 
+import java.io.IOException;
+import java.util.Random;
+
+/**
+ * A large {@link SerializationTestType}.
+ */
 public class LargeObjectType implements SerializationTestType {
 
 	private static final int MIN_LEN = 12 * 1000 * 1000;
-	
+
 	private static final int MAX_LEN = 40 * 1000 * 1000;
 
 	private int len;
@@ -68,13 +70,13 @@ public class LargeObjectType implements SerializationTestType {
 	public void read(DataInputView in) throws IOException {
 		final int len = in.readInt();
 		this.len = len;
-		
+
 		for (int i = 0; i < len / 8; i++) {
 			if (in.readLong() != i) {
 				throw new IOException("corrupt serialization");
 			}
 		}
-		
+
 		for (int i = 0; i < len % 8; i++) {
 			if (in.readByte() != i) {
 				throw new IOException("corrupt serialization");
@@ -91,7 +93,7 @@ public class LargeObjectType implements SerializationTestType {
 	public boolean equals(Object obj) {
 		return (obj instanceof LargeObjectType) && ((LargeObjectType) obj).len == this.len;
 	}
-	
+
 	@Override
 	public String toString() {
 		return "Large Object " + len;
diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index 641c73a..c145d9b 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -87,11 +87,11 @@ under the License.
 		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]disk[/\\](.*)"
 		checks="AvoidStarImport|UnusedImports"/>
 	<suppress
-		files="(.*)runtime[/\\]io[/\\]network[/\\](netty|partition|serialization|util)[/\\](.*)"
+		files="(.*)runtime[/\\]io[/\\]network[/\\](netty|partition|util)[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
 	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
 	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]network[/\\](netty|partition|serialization|util)[/\\](.*)"
+		files="(.*)test[/\\](.*)runtime[/\\]io[/\\]network[/\\](netty|partition|util)[/\\](.*)"
 		checks="AvoidStarImport|UnusedImports"/>
 	<!--Test class copied from the netty project-->
 	<suppress


[flink] 05/07: [hotfix][checkstyle] Remove suppression for runtime/test.runtime.testutils

Posted by ch...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

chesnay pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit 0e8a36d7f9537ac849e5b7289f76b20e3ad97894
Author: zentol <ch...@apache.org>
AuthorDate: Wed Sep 5 16:33:34 2018 +0200

    [hotfix][checkstyle] Remove suppression for runtime/test.runtime.testutils
---
 tools/maven/suppressions-runtime.xml | 4 ----
 1 file changed, 4 deletions(-)

diff --git a/tools/maven/suppressions-runtime.xml b/tools/maven/suppressions-runtime.xml
index 4259451..641c73a 100644
--- a/tools/maven/suppressions-runtime.xml
+++ b/tools/maven/suppressions-runtime.xml
@@ -177,10 +177,6 @@ under the License.
 	<suppress
 		files="(.*)runtime[/\\]testutils[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]
-	<!--Only additional checks for test sources. Those checks were present in the "pre-strict" checkstyle but were not applied to test sources. We do not want to suppress them for sources directory-->
-	<suppress
-		files="(.*)test[/\\](.*)runtime[/\\]testutils[/\\](.*)"
-		checks="AvoidStarImport"/>
 	<suppress
 		files="(.*)runtime[/\\]util[/\\](.*)"
 		checks="NewlineAtEndOfFile|RegexpSingleline|TodoComment|RedundantImport|ImportOrder|RedundantModifier|JavadocMethod|JavadocParagraph|JavadocType|JavadocStyle|PackageName|TypeNameCheck|ConstantNameCheck|StaticVariableNameCheck|MemberNameCheck|MethodNameCheck|ParameterName|LocalFinalVariableName|LocalVariableName|LeftCurly|UpperEll|FallThrough|reliefPattern|SimplifyBooleanExpression|EmptyStatement|ModifierOrder|EmptyLineSeparator|WhitespaceAround|WhitespaceAfter|NoWhitespaceAfter|NoWhite [...]