You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by se...@apache.org on 2015/09/21 13:30:29 UTC

[2/7] flink git commit: [hotfix] [taskmanager] Add chain failure cause to exception when updating task execution state on JobManager

[hotfix] [taskmanager] Add chain failure cause to exception when updating task execution state on JobManager


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

Branch: refs/heads/master
Commit: 116cec0d353a1a55ad1cfe6486c2707850550bee
Parents: 930c08e
Author: Stephan Ewen <se...@apache.org>
Authored: Sun Sep 20 16:04:13 2015 +0200
Committer: Stephan Ewen <se...@apache.org>
Committed: Mon Sep 21 11:50:16 2015 +0200

----------------------------------------------------------------------
 .../scala/org/apache/flink/runtime/taskmanager/TaskManager.scala  | 3 +--
 1 file changed, 1 insertion(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/flink/blob/116cec0d/flink-runtime/src/main/scala/org/apache/flink/runtime/taskmanager/TaskManager.scala
----------------------------------------------------------------------
diff --git a/flink-runtime/src/main/scala/org/apache/flink/runtime/taskmanager/TaskManager.scala b/flink-runtime/src/main/scala/org/apache/flink/runtime/taskmanager/TaskManager.scala
index 1563a7a..9c0bd7d 100644
--- a/flink-runtime/src/main/scala/org/apache/flink/runtime/taskmanager/TaskManager.scala
+++ b/flink-runtime/src/main/scala/org/apache/flink/runtime/taskmanager/TaskManager.scala
@@ -40,7 +40,6 @@ import org.apache.flink.configuration._
 import org.apache.flink.core.memory.{HybridMemorySegment, HeapMemorySegment, MemorySegmentFactory, MemoryType}
 import org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 import org.apache.flink.runtime.leaderretrieval.{LeaderRetrievalListener, LeaderRetrievalService}
-import org.apache.flink.runtime.memory.MemoryManager.HeapMemoryPool
 import org.apache.flink.runtime.messages.TaskMessages._
 import org.apache.flink.runtime.messages.checkpoint.{NotifyCheckpointComplete, TriggerCheckpoint, AbstractCheckpointMessage}
 import org.apache.flink.runtime.{FlinkActor, LeaderSessionMessageFilter, LogMessages, StreamingMode}
@@ -395,7 +394,7 @@ class TaskManager(
                   FailTask(
                     executionID,
                     new Exception(
-                      "Failed to send ExecutionStateChange notification to JobManager"))
+                      "Failed to send ExecutionStateChange notification to JobManager", t))
                 )
               }(context.dispatcher)
             }