You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by uc...@apache.org on 2015/09/23 22:07:01 UTC

[1/2] flink git commit: [jobmanager] Fix indentation

Repository: flink
Updated Branches:
  refs/heads/master 717d54c82 -> bc21de2e4


[jobmanager] Fix indentation


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

Branch: refs/heads/master
Commit: 3c08eec954b0f891e160be6f60069489220bd980
Parents: 717d54c
Author: Ufuk Celebi <uc...@apache.org>
Authored: Wed Sep 23 22:04:59 2015 +0200
Committer: Ufuk Celebi <uc...@apache.org>
Committed: Wed Sep 23 22:05:08 2015 +0200

----------------------------------------------------------------------
 .../flink/runtime/jobmanager/JobManager.scala   | 47 +++++++++++---------
 1 file changed, 25 insertions(+), 22 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/3c08eec9/flink-runtime/src/main/scala/org/apache/flink/runtime/jobmanager/JobManager.scala
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/scala/org/apache/flink/runtime/jobmanager/JobManager.scala b/flink-runtime/src/main/scala/org/apache/flink/runtime/jobmanager/JobManager.scala
index 444ab0b..07a5977 100644
--- a/flink-runtime/src/main/scala/org/apache/flink/runtime/jobmanager/JobManager.scala
+++ b/flink-runtime/src/main/scala/org/apache/flink/runtime/jobmanager/JobManager.scala
@@ -383,7 +383,7 @@ class JobManager(
             jobInfo.end = timeStamp
 
             // is the client waiting for the job result?
-            if(jobInfo.client != ActorRef.noSender) {
+            if (jobInfo.client != ActorRef.noSender) {
               newJobStatus match {
                 case JobStatus.FINISHED =>
                   val accumulatorResults: java.util.Map[String, SerializedValue[AnyRef]] = try {
@@ -391,44 +391,47 @@ class JobManager(
                   } catch {
                     case e: Exception =>
                       log.error(s"Cannot fetch final accumulators for job $jobID", e)
+
                       val exception = new JobExecutionException(jobID,
                         "Failed to retrieve accumulator results.", e)
+
                       jobInfo.client ! decorateMessage(JobResultFailure(
                         new SerializedThrowable(exception)))
+
                       Collections.emptyMap()
                   }
-                val result = new SerializedJobExecutionResult(
-                  jobID,
-                  jobInfo.duration,
-                  accumulatorResults)
+
+                  val result = new SerializedJobExecutionResult(
+                    jobID,
+                    jobInfo.duration,
+                    accumulatorResults)
                   jobInfo.client ! decorateMessage(JobResultSuccess(result))
 
                 case JobStatus.CANCELED =>
-                // the error may be packed as a serialized throwable
-                val unpackedError = SerializedThrowable.get(
-                  error, executionGraph.getUserClassLoader())
-                
-                jobInfo.client ! decorateMessage(JobResultFailure(
-                  new SerializedThrowable(
-                    new JobCancellationException(jobID, "Job was cancelled.", unpackedError))))
+                  // the error may be packed as a serialized throwable
+                  val unpackedError = SerializedThrowable.get(
+                    error, executionGraph.getUserClassLoader())
+
+                  jobInfo.client ! decorateMessage(JobResultFailure(
+                    new SerializedThrowable(
+                      new JobCancellationException(jobID, "Job was cancelled.", unpackedError))))
 
                 case JobStatus.FAILED =>
-                val unpackedError = SerializedThrowable.get(
-                  error, executionGraph.getUserClassLoader())
-                
-                jobInfo.client ! decorateMessage(JobResultFailure(
-                  new SerializedThrowable(
-                    new JobExecutionException(jobID, "Job execution failed.", unpackedError))))
+                  val unpackedError = SerializedThrowable.get(
+                    error, executionGraph.getUserClassLoader())
+
+                  jobInfo.client ! decorateMessage(JobResultFailure(
+                    new SerializedThrowable(
+                      new JobExecutionException(jobID, "Job execution failed.", unpackedError))))
 
                 case x =>
-                val exception = new JobExecutionException(jobID, s"$x is not a terminal state.")
-                jobInfo.client ! decorateMessage(JobResultFailure(
-                  new SerializedThrowable(exception)))
+                  val exception = new JobExecutionException(jobID, s"$x is not a terminal state.")
+                  jobInfo.client ! decorateMessage(JobResultFailure(
+                    new SerializedThrowable(exception)))
                   throw exception
               }
             }
 
-
             if (jobInfo.sessionAlive) {
               jobInfo.setLastActive()
               val lastActivity = jobInfo.lastActive


[2/2] flink git commit: Adjust Netty version in flink-dist/LICENSE

Posted by uc...@apache.org.
Adjust Netty version in flink-dist/LICENSE


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

Branch: refs/heads/master
Commit: bc21de2e49d0860032045a8d263a8c45dbf7e22d
Parents: 3c08eec
Author: Ufuk Celebi <uc...@apache.org>
Authored: Wed Sep 23 22:06:33 2015 +0200
Committer: Ufuk Celebi <uc...@apache.org>
Committed: Wed Sep 23 22:06:33 2015 +0200

----------------------------------------------------------------------
 flink-dist/src/main/flink-bin/LICENSE | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/bc21de2e/flink-dist/src/main/flink-bin/LICENSE
----------------------------------------------------------------------
diff --git a/flink-dist/src/main/flink-bin/LICENSE b/flink-dist/src/main/flink-bin/LICENSE
index 88a1cd1..c709c5f 100644
--- a/flink-dist/src/main/flink-bin/LICENSE
+++ b/flink-dist/src/main/flink-bin/LICENSE
@@ -233,7 +233,7 @@ under the Apache License (v 2.0):
  - Apache Sling (org.apache.sling:org.apache.sling.commons.json:2.0.6 - http://sling.apache.org)
  - Google Guava (com.google.guava:guava:18.0 - https://code.google.com/p/guava-libraries/)
  - Google Protocol Buffers Java API (com.google.protobuf:protobuf-java:2.5.0 - https://github.com/google/protobuf/)
- - Netty (io.netty:netty-all:4.0.27.Final - http://netty.io)
+ - Netty (io.netty:netty-all:4.0.31.Final - http://netty.io)
  - Netty (io.netty:netty:3.8.0.Final - http://netty.io)
  - Javassist (org.javassist:javassist:3.18.1-GA - http://www.javassist.org)
  - Kryo-Serializers (de.javakaffee:kryo-serializers:0.27 - https://github.com/magro/kryo-serializers/) - Copyright 2010 Martin Grotzke