You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@spark.apache.org by "Davies Liu (JIRA)" <ji...@apache.org> on 2015/08/13 23:02:46 UTC

[jira] [Updated] (SPARK-9946) NPE in TaskMemoryManager

     [ https://issues.apache.org/jira/browse/SPARK-9946?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Davies Liu updated SPARK-9946:
------------------------------
    Summary: NPE in TaskMemoryManager  (was: TaskMemoryManager is not thread safe)

> NPE in TaskMemoryManager
> ------------------------
>
>                 Key: SPARK-9946
>                 URL: https://issues.apache.org/jira/browse/SPARK-9946
>             Project: Spark
>          Issue Type: Bug
>          Components: SQL
>    Affects Versions: 1.5.0
>            Reporter: Davies Liu
>            Assignee: Davies Liu
>            Priority: Blocker
>
> {code}
> Failed to execute query using catalyst:
> [info]   Error: Job aborted due to stage failure: Task 6 in stage 6801.0 failed 1 times, most recent failure: Lost task 6.0 in stage 6801.0 (TID 41123, localhost): java.lang.NullPointerException
> [info]   	at org.apache.spark.unsafe.memory.TaskMemoryManager.getPage(TaskMemoryManager.java:226)
> [info]   	at org.apache.spark.util.collection.unsafe.sort.UnsafeInMemorySorter$SortedIterator.loadNext(UnsafeInMemorySorter.java:165)
> [info]   	at org.apache.spark.sql.execution.UnsafeExternalRowSorter$1.next(UnsafeExternalRowSorter.java:142)
> [info]   	at org.apache.spark.sql.execution.UnsafeExternalRowSorter$1.next(UnsafeExternalRowSorter.java:129)
> [info]   	at org.apache.spark.sql.execution.RowIteratorFromScala.advanceNext(RowIterator.scala:84)
> [info]   	at org.apache.spark.sql.execution.joins.SortMergeJoinScanner.advancedBufferedToRowWithNullFreeJoinKey(SortMergeJoin.scala:302)
> [info]   	at org.apache.spark.sql.execution.joins.SortMergeJoinScanner.findNextInnerJoinRows(SortMergeJoin.scala:218)
> [info]   	at org.apache.spark.sql.execution.joins.SortMergeJoin$$anonfun$doExecute$1$$anon$1.advanceNext(SortMergeJoin.scala:110)
> [info]   	at org.apache.spark.sql.execution.RowIteratorToScala.hasNext(RowIterator.scala:68)
> [info]   	at scala.collection.Iterator$$anon$11.hasNext(Iterator.scala:327)
> [info]   	at scala.collection.Iterator$$anon$11.hasNext(Iterator.scala:327)
> [info]   	at org.apache.spark.shuffle.sort.BypassMergeSortShuffleWriter.insertAll(BypassMergeSortShuffleWriter.java:99)
> [info]   	at org.apache.spark.shuffle.sort.SortShuffleWriter.write(SortShuffleWriter.scala:73)
> [info]   	at org.apache.spark.scheduler.ShuffleMapTask.runTask(ShuffleMapTask.scala:73)
> [info]   	at org.apache.spark.scheduler.ShuffleMapTask.runTask(ShuffleMapTask.scala:41)
> [info]   	at org.apache.spark.scheduler.Task.run(Task.scala:88)
> [info]   	at org.apache.spark.executor.Executor$TaskRunner.run(Executor.scala:214)
> 13:27:17.435 WARN org.apache.spark.scheduler.TaskSetManager: Lost task 23.0 in stage 6801.0 (TID 41140, localhost): TaskKilled (killed intentionally)
> [info]   	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1145)
> [info]   	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:615)
> 13:27:17.436 WARN org.apache.spark.scheduler.TaskSetManager: Lost task 12.0 in stage 6801.0 (TID 41129, localhost): TaskKilled (killed intentionally)
> [info]   	at java.lang.Thread.run(Thread.java:745)
> {code}



--
This message was sent by Atlassian JIRA
(v6.3.4#6332)

---------------------------------------------------------------------
To unsubscribe, e-mail: issues-unsubscribe@spark.apache.org
For additional commands, e-mail: issues-help@spark.apache.org