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 2017/06/03 06:06:02 UTC

[1/6] flink git commit: [FLINK-6818] Activate checkstyle for runtime/history

Repository: flink
Updated Branches:
  refs/heads/master 121482b88 -> f98a5c733


[FLINK-6818] Activate checkstyle for runtime/history

This closes #4051.


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

Branch: refs/heads/master
Commit: c3ab79966c9d909df7e625a2b3b62aa2f049f8fd
Parents: 121482b
Author: zentol <ch...@apache.org>
Authored: Wed May 31 16:57:08 2017 +0200
Committer: zentol <ch...@apache.org>
Committed: Fri Jun 2 22:21:30 2017 +0200

----------------------------------------------------------------------
 flink-runtime/pom.xml                                   |  1 -
 .../apache/flink/runtime/history/FsJobArchivist.java    | 12 +++++++-----
 2 files changed, 7 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/c3ab7996/flink-runtime/pom.xml
----------------------------------------------------------------------
diff --git a/flink-runtime/pom.xml b/flink-runtime/pom.xml
index 38ab32b..67d8486 100644
--- a/flink-runtime/pom.xml
+++ b/flink-runtime/pom.xml
@@ -435,7 +435,6 @@ under the License.
 						**/runtime/fs/**,
 						**/runtime/heartbeat/**,
 						**/runtime/highavailability/**,
-						**/runtime/history/**,
 						**/runtime/instance/**,
 						**/runtime/io/**,
 						**/runtime/iterative/**,

http://git-wip-us.apache.org/repos/asf/flink/blob/c3ab7996/flink-runtime/src/main/java/org/apache/flink/runtime/history/FsJobArchivist.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/history/FsJobArchivist.java b/flink-runtime/src/main/java/org/apache/flink/runtime/history/FsJobArchivist.java
index 02ca3c4..fe8f4c5 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/history/FsJobArchivist.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/history/FsJobArchivist.java
@@ -15,13 +15,9 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package org.apache.flink.runtime.history;
 
-import com.fasterxml.jackson.core.JsonEncoding;
-import com.fasterxml.jackson.core.JsonFactory;
-import com.fasterxml.jackson.core.JsonGenerator;
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
 import org.apache.flink.configuration.JobManagerOptions;
 import org.apache.flink.core.fs.FSDataInputStream;
 import org.apache.flink.core.fs.FileSystem;
@@ -31,6 +27,12 @@ import org.apache.flink.runtime.webmonitor.WebMonitorUtils;
 import org.apache.flink.runtime.webmonitor.history.ArchivedJson;
 import org.apache.flink.runtime.webmonitor.history.JsonArchivist;
 import org.apache.flink.util.IOUtils;
+
+import com.fasterxml.jackson.core.JsonEncoding;
+import com.fasterxml.jackson.core.JsonFactory;
+import com.fasterxml.jackson.core.JsonGenerator;
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 


[3/6] flink git commit: [FLINK-6824] Activate checkstyle for runtime/event

Posted by ch...@apache.org.
[FLINK-6824] Activate checkstyle for runtime/event

This closes #4056.


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

Branch: refs/heads/master
Commit: 9d9732bf7410e36ac29a884d126294b8c753836e
Parents: 22290dd
Author: zentol <ch...@apache.org>
Authored: Thu Jun 1 12:37:45 2017 +0200
Committer: zentol <ch...@apache.org>
Committed: Fri Jun 2 22:22:09 2017 +0200

----------------------------------------------------------------------
 flink-runtime/pom.xml                              |  1 -
 .../flink/runtime/event/task/IntegerTaskEvent.java | 17 +++++------------
 .../flink/runtime/event/task/StringTaskEvent.java  | 11 ++++-------
 .../flink/runtime/event/task/TaskEventTest.java    | 13 ++++++-------
 4 files changed, 15 insertions(+), 27 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/9d9732bf/flink-runtime/pom.xml
----------------------------------------------------------------------
diff --git a/flink-runtime/pom.xml b/flink-runtime/pom.xml
index 77dfeeb..7ce3de5 100644
--- a/flink-runtime/pom.xml
+++ b/flink-runtime/pom.xml
@@ -428,7 +428,6 @@ under the License.
 						**/runtime/clusterframework/**,       
 						**/runtime/concurrent/**,
 						**/runtime/deployment/**,
-						**/runtime/event/**,
 						**/runtime/execution/**,
 						**/runtime/executiongraph/**,
 						**/runtime/filecache/**,

http://git-wip-us.apache.org/repos/asf/flink/blob/9d9732bf/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/IntegerTaskEvent.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/IntegerTaskEvent.java b/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/IntegerTaskEvent.java
index cc67482..98a14db 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/IntegerTaskEvent.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/IntegerTaskEvent.java
@@ -16,18 +16,16 @@
  * limitations under the License.
  */
 
-
 package org.apache.flink.runtime.event.task;
 
-import java.io.IOException;
-
 import org.apache.flink.core.memory.DataInputView;
 import org.apache.flink.core.memory.DataOutputView;
 import org.apache.flink.runtime.event.TaskEvent;
 
+import java.io.IOException;
+
 /**
  * This class provides a simple implementation of an event that holds an integer value.
- * 
  */
 public class IntegerTaskEvent extends TaskEvent {
 
@@ -46,9 +44,8 @@ public class IntegerTaskEvent extends TaskEvent {
 
 	/**
 	 * Constructs a new integer task event.
-	 * 
-	 * @param value
-	 *        the integer value to be transported inside this integer task event
+	 *
+	 * @param value the integer value to be transported inside this integer task event
 	 */
 	public IntegerTaskEvent(final int value) {
 		this.value = value;
@@ -56,33 +53,29 @@ public class IntegerTaskEvent extends TaskEvent {
 
 	/**
 	 * Returns the stored integer value.
-	 * 
+	 *
 	 * @return the stored integer value or <code>-1</code> if no value has been set
 	 */
 	public int getInteger() {
 		return this.value;
 	}
 
-
 	@Override
 	public void write(final DataOutputView out) throws IOException {
 		out.writeInt(this.value);
 	}
 
-
 	@Override
 	public void read(final DataInputView in) throws IOException {
 		this.value = in.readInt();
 	}
 
-
 	@Override
 	public int hashCode() {
 
 		return this.value;
 	}
 
-
 	@Override
 	public boolean equals(final Object obj) {
 

http://git-wip-us.apache.org/repos/asf/flink/blob/9d9732bf/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/StringTaskEvent.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/StringTaskEvent.java b/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/StringTaskEvent.java
index 9095cc2..6e32e19 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/StringTaskEvent.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/StringTaskEvent.java
@@ -18,13 +18,13 @@
 
 package org.apache.flink.runtime.event.task;
 
-import java.io.IOException;
-
 import org.apache.flink.core.memory.DataInputView;
 import org.apache.flink.core.memory.DataOutputView;
 import org.apache.flink.runtime.event.TaskEvent;
 import org.apache.flink.util.StringUtils;
 
+import java.io.IOException;
+
 /**
  * This class provides a simple implementation of an event that holds a string value.
  */
@@ -42,7 +42,7 @@ public class StringTaskEvent extends TaskEvent {
 
 	/**
 	 * Constructs a new string task event with the given string message.
-	 * 
+	 *
 	 * @param message
 	 *        the string message that shall be stored in this event
 	 */
@@ -52,14 +52,13 @@ public class StringTaskEvent extends TaskEvent {
 
 	/**
 	 * Returns the stored string.
-	 * 
+	 *
 	 * @return the stored string or <code>null</code> if no string is set
 	 */
 	public String getString() {
 		return this.message;
 	}
 
-
 	@Override
 	public void write(DataOutputView out) throws IOException {
 		StringUtils.writeNullableString(this.message, out);
@@ -70,7 +69,6 @@ public class StringTaskEvent extends TaskEvent {
 		this.message = StringUtils.readNullableString(in);
 	}
 
-
 	@Override
 	public int hashCode() {
 		if (this.message == null) {
@@ -80,7 +78,6 @@ public class StringTaskEvent extends TaskEvent {
 		return this.message.hashCode();
 	}
 
-
 	@Override
 	public boolean equals(final Object obj) {
 		if (!(obj instanceof StringTaskEvent)) {

http://git-wip-us.apache.org/repos/asf/flink/blob/9d9732bf/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/TaskEventTest.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/TaskEventTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/TaskEventTest.java
index 902f0bf..1e9233f 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/TaskEventTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/event/task/TaskEventTest.java
@@ -18,20 +18,19 @@
 
 package org.apache.flink.runtime.event.task;
 
-import static org.junit.Assert.assertEquals;
-import static org.junit.Assert.assertTrue;
-import static org.junit.Assert.fail;
-
-import java.io.IOException;
-
 import org.apache.flink.util.InstantiationUtil;
 
 import org.junit.Test;
 
+import java.io.IOException;
+
+import static org.junit.Assert.assertEquals;
+import static org.junit.Assert.assertTrue;
+import static org.junit.Assert.fail;
+
 /**
  * This class contains serialization tests concerning task events derived from
  * {@link org.apache.flink.runtime.event.AbstractEvent}.
- * 
  */
 public class TaskEventTest {
 	/**


[4/6] flink git commit: [FLINK-6827] Activate checkstyle for runtime/webmonitor

Posted by ch...@apache.org.
[FLINK-6827] Activate checkstyle for runtime/webmonitor

This closes #4054.


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

Branch: refs/heads/master
Commit: 156d5e6be8b19dd6380285c9b68f49bdc3c6f058
Parents: 9d9732b
Author: zentol <ch...@apache.org>
Authored: Wed May 31 17:00:57 2017 +0200
Committer: zentol <ch...@apache.org>
Committed: Fri Jun 2 22:22:30 2017 +0200

----------------------------------------------------------------------
 flink-runtime/pom.xml                           |  1 -
 .../flink/runtime/webmonitor/WebMonitor.java    |  6 ++--
 .../runtime/webmonitor/WebMonitorUtils.java     | 38 ++++++++++----------
 .../webmonitor/history/ArchivedJson.java        |  9 ++---
 .../webmonitor/history/JsonArchivist.java       |  7 ++--
 .../webmonitor/history/ArchivedJsonTest.java    |  4 +++
 6 files changed, 34 insertions(+), 31 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/156d5e6b/flink-runtime/pom.xml
----------------------------------------------------------------------
diff --git a/flink-runtime/pom.xml b/flink-runtime/pom.xml
index 7ce3de5..e570d3b 100644
--- a/flink-runtime/pom.xml
+++ b/flink-runtime/pom.xml
@@ -457,7 +457,6 @@ under the License.
 						**/runtime/taskmanager/**,
 						**/runtime/testutils/**,
 						**/runtime/util/**,
-						**/runtime/webmonitor/**,
 						**/runtime/zookeeper/**,
 						**/runtime/*
 					</excludes>

http://git-wip-us.apache.org/repos/asf/flink/blob/156d5e6b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitor.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitor.java b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitor.java
index 63e2cc8..47cdb84 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitor.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitor.java
@@ -25,18 +25,18 @@ public interface WebMonitor {
 
 	/**
 	 * Starts the web monitor.
-	 * 
+	 *
 	 * @throws Exception This method may forward exceptions, if it cannot bring up the web monitor.
 	 */
 	void start(String jobManagerAkkaUrl) throws Exception;
 
 	/**
 	 * Stops the web server.
-	 * 
+	 *
 	 * @throws Exception This method may forward exceptions, if it cannot properly stop the web monitor.
 	 */
 	void stop() throws Exception;
-	
+
 	/**
 	 * Gets the port that the web server actually binds to. If port 0 was given in
 	 * the configuration, then a random free port will be picked. This method can

http://git-wip-us.apache.org/repos/asf/flink/blob/156d5e6b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitorUtils.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitorUtils.java b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitorUtils.java
index 3853b21..12c2d8e 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitorUtils.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/WebMonitorUtils.java
@@ -18,13 +18,6 @@
 
 package org.apache.flink.runtime.webmonitor;
 
-import akka.actor.ActorSystem;
-
-import com.fasterxml.jackson.databind.JsonNode;
-import com.fasterxml.jackson.databind.ObjectMapper;
-import com.fasterxml.jackson.databind.node.ArrayNode;
-
-import java.net.URI;
 import org.apache.flink.configuration.Configuration;
 import org.apache.flink.configuration.JobManagerOptions;
 import org.apache.flink.core.fs.Path;
@@ -39,6 +32,10 @@ import org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService;
 import org.apache.flink.runtime.messages.webmonitor.JobDetails;
 import org.apache.flink.runtime.webmonitor.history.JsonArchivist;
 
+import akka.actor.ActorSystem;
+import com.fasterxml.jackson.databind.JsonNode;
+import com.fasterxml.jackson.databind.ObjectMapper;
+import com.fasterxml.jackson.databind.node.ArrayNode;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -46,6 +43,7 @@ import java.io.File;
 import java.lang.reflect.Constructor;
 import java.lang.reflect.InvocationTargetException;
 import java.lang.reflect.Method;
+import java.net.URI;
 import java.util.HashMap;
 import java.util.Iterator;
 import java.util.Map;
@@ -60,7 +58,7 @@ public final class WebMonitorUtils {
 	private static final Logger LOG = LoggerFactory.getLogger(WebMonitorUtils.class);
 
 	/**
-	 * Singleton to hold the log and stdout file
+	 * Singleton to hold the log and stdout file.
 	 */
 	public static class LogFileLocation {
 
@@ -71,7 +69,6 @@ public final class WebMonitorUtils {
 			this.logFile = logFile;
 			this.stdOutFile = stdOutFile;
 		}
-		
 
 		/**
 		 * Finds the Flink log directory using log.file Java property that is set during startup.
@@ -79,12 +76,12 @@ public final class WebMonitorUtils {
 		public static LogFileLocation find(Configuration config) {
 			final String logEnv = "log.file";
 			String logFilePath = System.getProperty(logEnv);
-			
+
 			if (logFilePath == null) {
 				LOG.warn("Log file environment variable '{}' is not set.", logEnv);
 				logFilePath = config.getString(JobManagerOptions.WEB_LOG_PATH);
 			}
-			
+
 			// not configured, cannot serve log files
 			if (logFilePath == null || logFilePath.length() < 4) {
 				LOG.warn("JobManager log files are unavailable in the web dashboard. " +
@@ -92,17 +89,18 @@ public final class WebMonitorUtils {
 					logEnv, JobManagerOptions.WEB_LOG_PATH.key());
 				return new LogFileLocation(null, null);
 			}
-			
+
 			String outFilePath = logFilePath.substring(0, logFilePath.length() - 3).concat("out");
 
 			LOG.info("Determined location of JobManager log file: {}", logFilePath);
 			LOG.info("Determined location of JobManager stdout file: {}", outFilePath);
-			
+
 			return new LogFileLocation(resolveFileLocation(logFilePath), resolveFileLocation(outFilePath));
 		}
 
 		/**
-		 * Verify log file location
+		 * Verify log file location.
+		 *
 		 * @param logFilePath Path to log file
 		 * @return File or null if not a valid log file
 		 */
@@ -115,8 +113,8 @@ public final class WebMonitorUtils {
 	/**
 	 * Starts the web runtime monitor. Because the actual implementation of the runtime monitor is
 	 * in another project, we load the runtime monitor dynamically.
-	 * <p>
-	 * Because failure to start the web runtime monitor is not considered fatal, this method does
+	 *
+	 * <p>Because failure to start the web runtime monitor is not considered fatal, this method does
 	 * not throw any exceptions, but only logs them.
 	 *
 	 * @param config The configuration for the runtime monitor.
@@ -132,7 +130,7 @@ public final class WebMonitorUtils {
 		try {
 			String classname = "org.apache.flink.runtime.webmonitor.WebRuntimeMonitor";
 			Class<? extends WebMonitor> clazz = Class.forName(classname).asSubclass(WebMonitor.class);
-			
+
 			Constructor<? extends WebMonitor> constructor = clazz.getConstructor(Configuration.class,
 				LeaderRetrievalService.class,
 				BlobView.class,
@@ -179,7 +177,7 @@ public final class WebMonitorUtils {
 			Map<String, String> map = new HashMap<>();
 			ObjectMapper m = new ObjectMapper();
 			ArrayNode array = (ArrayNode) m.readTree(jsonString);
-			
+
 			Iterator<JsonNode> elements = array.elements();
 			while (elements.hasNext()) {
 				JsonNode node = elements.next();
@@ -187,7 +185,7 @@ public final class WebMonitorUtils {
 				String value = node.get("value").asText();
 				map.put(key, value);
 			}
-			
+
 			return map;
 		}
 		catch (Exception e) {
@@ -230,7 +228,7 @@ public final class WebMonitorUtils {
 	 * @param archiveDirUri The URI to check and normalize.
 	 * @return A normalized URI as a Path.
 	 *
-	 * @throws IllegalArgumentException Thrown, if the URI misses scheme or path. 
+	 * @throws IllegalArgumentException Thrown, if the URI misses scheme or path.
 	 */
 	public static Path validateAndNormalizeUri(URI archiveDirUri) {
 		final String scheme = archiveDirUri.getScheme();

http://git-wip-us.apache.org/repos/asf/flink/blob/156d5e6b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/ArchivedJson.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/ArchivedJson.java b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/ArchivedJson.java
index 2e72f1a..23e7676 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/ArchivedJson.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/ArchivedJson.java
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package org.apache.flink.runtime.webmonitor.history;
 
 import org.apache.flink.runtime.jobmanager.MemoryArchivist;
@@ -22,15 +23,15 @@ import org.apache.flink.util.Preconditions;
 
 /**
  * A simple container for a handler's JSON response and the REST URLs for which the response would've been returned.
- * 
- * These are created by {@link JsonArchivist}s, and used by the {@link MemoryArchivist} to create a directory structure
+ *
+ * <p>These are created by {@link JsonArchivist}s, and used by the {@link MemoryArchivist} to create a directory structure
  * resembling the REST API.
  */
 public class ArchivedJson {
 
 	private final String path;
 	private final String json;
-	
+
 	public ArchivedJson(String path, String json) {
 		this.path = Preconditions.checkNotNull(path);
 		this.json = Preconditions.checkNotNull(json);
@@ -56,6 +57,6 @@ public class ArchivedJson {
 
 	@Override
 	public String toString() {
-		return path +":" + json;
+		return path + ":" + json;
 	}
 }

http://git-wip-us.apache.org/repos/asf/flink/blob/156d5e6b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/JsonArchivist.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/JsonArchivist.java b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/JsonArchivist.java
index a87cc47..c0a54c6 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/JsonArchivist.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/webmonitor/history/JsonArchivist.java
@@ -15,6 +15,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package org.apache.flink.runtime.webmonitor.history;
 
 import org.apache.flink.runtime.executiongraph.AccessExecutionGraph;
@@ -24,8 +25,8 @@ import java.util.Collection;
 
 /**
  * Interface for all classes that want to participate in the archiving of job-related json responses.
- * 
- * Note that all JsonArchivists that are to be used for the history server must be added
+ *
+ * <p>Note that all JsonArchivists that are to be used for the history server must be added
  * to {@link WebRuntimeMonitor#getArchivers()}.
  */
 public interface JsonArchivist {
@@ -34,7 +35,7 @@ public interface JsonArchivist {
 	 * Returns a {@link Collection} of {@link ArchivedJson}s containing JSON responses and their respective REST URL
 	 * for a given job.
 	 *
-	 * The collection should contain one entry for every response that could be generated for the given
+	 * <p>The collection should contain one entry for every response that could be generated for the given
 	 * job, for example one entry for each task. The REST URLs should be unique and must not contain placeholders.
 	 *
 	 * @param graph AccessExecutionGraph for which the responses should be generated

http://git-wip-us.apache.org/repos/asf/flink/blob/156d5e6b/flink-runtime/src/test/java/org/apache/flink/runtime/webmonitor/history/ArchivedJsonTest.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/test/java/org/apache/flink/runtime/webmonitor/history/ArchivedJsonTest.java b/flink-runtime/src/test/java/org/apache/flink/runtime/webmonitor/history/ArchivedJsonTest.java
index c3883bc..57ebbc9 100644
--- a/flink-runtime/src/test/java/org/apache/flink/runtime/webmonitor/history/ArchivedJsonTest.java
+++ b/flink-runtime/src/test/java/org/apache/flink/runtime/webmonitor/history/ArchivedJsonTest.java
@@ -15,11 +15,15 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
+
 package org.apache.flink.runtime.webmonitor.history;
 
 import org.junit.Assert;
 import org.junit.Test;
 
+/**
+ * Tests for the {@link ArchivedJson}.
+ */
 public class ArchivedJsonTest {
 
 	@Test


[2/6] flink git commit: [FLINK-6819] Activate checkstyle for runtime/leaderretrieval

Posted by ch...@apache.org.
[FLINK-6819] Activate checkstyle for runtime/leaderretrieval

This closes #4053.


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

Branch: refs/heads/master
Commit: 22290ddcca607ab4e06b136d463994b503d2dd16
Parents: c3ab799
Author: zentol <ch...@apache.org>
Authored: Thu Jun 1 12:27:28 2017 +0200
Committer: zentol <ch...@apache.org>
Committed: Fri Jun 2 22:21:48 2017 +0200

----------------------------------------------------------------------
 flink-runtime/pom.xml                                     |  1 -
 .../runtime/leaderretrieval/LeaderRetrievalService.java   |  4 ++--
 .../leaderretrieval/StandaloneLeaderRetrievalService.java | 10 +++++-----
 .../leaderretrieval/ZooKeeperLeaderRetrievalService.java  |  7 ++++---
 4 files changed, 11 insertions(+), 11 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/22290ddc/flink-runtime/pom.xml
----------------------------------------------------------------------
diff --git a/flink-runtime/pom.xml b/flink-runtime/pom.xml
index 67d8486..77dfeeb 100644
--- a/flink-runtime/pom.xml
+++ b/flink-runtime/pom.xml
@@ -442,7 +442,6 @@ under the License.
 						**/runtime/jobmanager/**,
 						**/runtime/jobmaster/**,
 						**/runtime/leaderelection/**,
-						**/runtime/leaderretrieval/**,
 						**/runtime/memory/**,
 						**/runtime/messages/**,
 						**/runtime/minicluster/**,

http://git-wip-us.apache.org/repos/asf/flink/blob/22290ddc/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/LeaderRetrievalService.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/LeaderRetrievalService.java b/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/LeaderRetrievalService.java
index 97f8843..d52abd2 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/LeaderRetrievalService.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/LeaderRetrievalService.java
@@ -22,11 +22,11 @@ package org.apache.flink.runtime.leaderretrieval;
  * This interface has to be implemented by a service which retrieves the current leader and notifies
  * a listener about it.
  *
- * Prior to using this service it has to be started by calling the start method. The start method
+ * <p>Prior to using this service it has to be started by calling the start method. The start method
  * also takes the {@link LeaderRetrievalListener} as an argument. The service can only be started
  * once.
  *
- * The service should be stopped by calling the stop method.
+ * <p>The service should be stopped by calling the stop method.
  */
 public interface LeaderRetrievalService {
 

http://git-wip-us.apache.org/repos/asf/flink/blob/22290ddc/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/StandaloneLeaderRetrievalService.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/StandaloneLeaderRetrievalService.java b/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/StandaloneLeaderRetrievalService.java
index fefe910..b039262 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/StandaloneLeaderRetrievalService.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/StandaloneLeaderRetrievalService.java
@@ -30,21 +30,21 @@ import static org.apache.flink.util.Preconditions.checkState;
  * assumes that there is only a single contender for leadership
  * (e.g., a single JobManager or ResourceManager process) and that this process is
  * reachable under a constant address.
- * 
+ *
  * <p>As soon as this service is started, it immediately notifies the leader listener
  * of the leader contender with the pre-configured address.
  */
 public class StandaloneLeaderRetrievalService implements LeaderRetrievalService {
 
 	private final Object startStopLock = new Object();
-	
-	/** The fix address of the leader */
+
+	/** The fix address of the leader. */
 	private final String leaderAddress;
 
-	/** The fix leader ID (leader lock fencing token) */
+	/** The fix leader ID (leader lock fencing token). */
 	private final UUID leaderId;
 
-	/** Flag whether this service is started */
+	/** Flag whether this service is started. */
 	private boolean started;
 
 	/**

http://git-wip-us.apache.org/repos/asf/flink/blob/22290ddc/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/ZooKeeperLeaderRetrievalService.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/ZooKeeperLeaderRetrievalService.java b/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/ZooKeeperLeaderRetrievalService.java
index 7f18fd9..c60fe2c 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/ZooKeeperLeaderRetrievalService.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/leaderretrieval/ZooKeeperLeaderRetrievalService.java
@@ -19,6 +19,7 @@
 package org.apache.flink.runtime.leaderretrieval;
 
 import org.apache.flink.util.Preconditions;
+
 import org.apache.curator.framework.CuratorFramework;
 import org.apache.curator.framework.recipes.cache.ChildData;
 import org.apache.curator.framework.recipes.cache.NodeCache;
@@ -46,13 +47,13 @@ public class ZooKeeperLeaderRetrievalService implements LeaderRetrievalService,
 
 	private final Object lock = new Object();
 
-	/** Connection to the used ZooKeeper quorum */
+	/** Connection to the used ZooKeeper quorum. */
 	private final CuratorFramework client;
 
-	/** Curator recipe to watch changes of a specific ZooKeeper node */
+	/** Curator recipe to watch changes of a specific ZooKeeper node. */
 	private final NodeCache cache;
 
-	/** Listener which will be notified about leader changes */
+	/** Listener which will be notified about leader changes. */
 	private volatile LeaderRetrievalListener leaderListener;
 
 	private String lastLeaderAddress;


[6/6] flink git commit: [FLINK-6797][docs] Docs do not build cleanly with new version of bundler

Posted by ch...@apache.org.
[FLINK-6797][docs] Docs do not build cleanly with new version of bundler

This closes #4043.


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

Branch: refs/heads/master
Commit: f98a5c733b8227edbe53ad1fbdab7297d7ceb2b9
Parents: 44090aa
Author: David Anderson <da...@alpinegizmo.com>
Authored: Thu Jun 1 15:48:29 2017 +0200
Committer: zentol <ch...@apache.org>
Committed: Fri Jun 2 22:34:14 2017 +0200

----------------------------------------------------------------------
 docs/Gemfile.lock | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/f98a5c73/docs/Gemfile.lock
----------------------------------------------------------------------
diff --git a/docs/Gemfile.lock b/docs/Gemfile.lock
index bcd107b..0a418c6 100644
--- a/docs/Gemfile.lock
+++ b/docs/Gemfile.lock
@@ -33,7 +33,7 @@ GEM
     jekyll-coffeescript (1.0.1)
       coffee-script (~> 2.2)
     jekyll-gist (1.4.0)
-      octokit (~> 4.3.0)
+      octokit (~> 4.2)
     jekyll-paginate (1.1.0)
     jekyll-sass-converter (1.5.0)
       sass (~> 3.4)
@@ -89,4 +89,4 @@ RUBY VERSION
    ruby 2.3.1p112
 
 BUNDLED WITH
-   1.13.6
+   1.15.0


[5/6] flink git commit: [FLINK-6831] Activate checkstyle for runtime/*

Posted by ch...@apache.org.
[FLINK-6831] Activate checkstyle for runtime/*

This closes #4057.


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

Branch: refs/heads/master
Commit: 44090aab32d677ae49a4438fbc8d313df8556190
Parents: 156d5e6
Author: zentol <ch...@apache.org>
Authored: Wed May 31 17:07:03 2017 +0200
Committer: zentol <ch...@apache.org>
Committed: Fri Jun 2 22:22:50 2017 +0200

----------------------------------------------------------------------
 flink-runtime/pom.xml                                             | 1 -
 .../src/main/java/org/apache/flink/runtime/JobException.java      | 3 +++
 2 files changed, 3 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/44090aab/flink-runtime/pom.xml
----------------------------------------------------------------------
diff --git a/flink-runtime/pom.xml b/flink-runtime/pom.xml
index e570d3b..3cee8d8 100644
--- a/flink-runtime/pom.xml
+++ b/flink-runtime/pom.xml
@@ -458,7 +458,6 @@ under the License.
 						**/runtime/testutils/**,
 						**/runtime/util/**,
 						**/runtime/zookeeper/**,
-						**/runtime/*
 					</excludes>
 				</configuration>
 				<executions>

http://git-wip-us.apache.org/repos/asf/flink/blob/44090aab/flink-runtime/src/main/java/org/apache/flink/runtime/JobException.java
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/java/org/apache/flink/runtime/JobException.java b/flink-runtime/src/main/java/org/apache/flink/runtime/JobException.java
index b98e669..d5a5bb9 100644
--- a/flink-runtime/src/main/java/org/apache/flink/runtime/JobException.java
+++ b/flink-runtime/src/main/java/org/apache/flink/runtime/JobException.java
@@ -18,6 +18,9 @@
 
 package org.apache.flink.runtime;
 
+/**
+ * Indicates that a job has failed.
+ */
 public class JobException extends Exception {
 
 	private static final long serialVersionUID = 1275864691743020176L;