Details for spark-master-test-sbt-hadoop-2.7 build #2582

View on Jenkins

Duration
143 minutes
Start time
2017-03-19 20:32:12 ()
Commit
422aa67d1bb84f913b06e6d94615adb6557e2870
Executor
amp-jenkins-worker-05
Status
FAILURE

Failed tests

org.apache.spark.streaming.BasicOperationsSuite: map 1 ms
org.apache.spark.streaming.BasicOperationsSuite: flatMap 2 ms
org.apache.spark.streaming.BasicOperationsSuite: filter 1 ms
org.apache.spark.streaming.BasicOperationsSuite: glom 1 ms
org.apache.spark.streaming.BasicOperationsSuite: mapPartitions 0 ms
org.apache.spark.streaming.BasicOperationsSuite: repartition (more partitions) 0 ms
org.apache.spark.streaming.BasicOperationsSuite: repartition (fewer partitions) 1 ms
org.apache.spark.streaming.BasicOperationsSuite: groupByKey 1 ms
org.apache.spark.streaming.BasicOperationsSuite: reduceByKey 0 ms
org.apache.spark.streaming.BasicOperationsSuite: reduce 0 ms
org.apache.spark.streaming.BasicOperationsSuite: count 1 ms
org.apache.spark.streaming.BasicOperationsSuite: countByValue 1 ms
org.apache.spark.streaming.BasicOperationsSuite: mapValues 0 ms
org.apache.spark.streaming.BasicOperationsSuite: flatMapValues 1 ms
org.apache.spark.streaming.BasicOperationsSuite: union 0 ms
org.apache.spark.streaming.BasicOperationsSuite: transform 1 ms
org.apache.spark.streaming.BasicOperationsSuite: transformWith 1 ms
org.apache.spark.streaming.BasicOperationsSuite: cogroup 1 ms
org.apache.spark.streaming.BasicOperationsSuite: join 0 ms
org.apache.spark.streaming.BasicOperationsSuite: leftOuterJoin 1 ms
org.apache.spark.streaming.BasicOperationsSuite: rightOuterJoin 0 ms
org.apache.spark.streaming.BasicOperationsSuite: fullOuterJoin 1 ms
org.apache.spark.streaming.BasicOperationsSuite: updateStateByKey 0 ms
org.apache.spark.streaming.BasicOperationsSuite: updateStateByKey - simple with initial value RDD 1 ms
org.apache.spark.streaming.BasicOperationsSuite: updateStateByKey - testing time stamps as input 1 ms
org.apache.spark.streaming.BasicOperationsSuite: updateStateByKey - with initial value RDD 0 ms
org.apache.spark.streaming.BasicOperationsSuite: updateStateByKey - object lifecycle 1 ms
org.apache.spark.streaming.BasicOperationsSuite: slice 0 ms
org.apache.spark.streaming.BasicOperationsSuite: slice - has not been initialized 0 ms
org.apache.spark.streaming.BasicOperationsSuite: rdd cleanup - map and window 1 ms
org.apache.spark.streaming.BasicOperationsSuite: rdd cleanup - updateStateByKey 1 ms
org.apache.spark.streaming.BasicOperationsSuite: rdd cleanup - input blocks and persisted RDDs 1 ms
org.apache.spark.streaming.CheckpointSuite: basic rdd checkpoints + dstream graph checkpoint recovery 12 ms
org.apache.spark.streaming.CheckpointSuite: recovery of conf through checkpoints 0 ms
org.apache.spark.streaming.CheckpointSuite: [host|port] from checkpoint 1 ms
org.apache.spark.streaming.CheckpointSuite: recovery with map and reduceByKey operations 2 ms
org.apache.spark.streaming.CheckpointSuite: recovery with invertible reduceByKeyAndWindow operation 2 ms
org.apache.spark.streaming.CheckpointSuite: recovery with saveAsHadoopFiles operation 2 ms
org.apache.spark.streaming.CheckpointSuite: recovery with saveAsNewAPIHadoopFiles operation 2 ms
org.apache.spark.streaming.CheckpointSuite: recovery with saveAsHadoopFile inside transform operation 2 ms
org.apache.spark.streaming.CheckpointSuite: recovery with updateStateByKey operation 2 ms
org.apache.spark.streaming.CheckpointSuite: recovery maintains rate controller 1 ms
org.apache.spark.streaming.CheckpointSuite: recovery with file input stream 1 ms
org.apache.spark.streaming.CheckpointSuite: restore invoking times 0 ms
org.apache.spark.streaming.CheckpointSuite: SPARK-6847: stack overflow when updateStateByKey is followed by a checkpointed dstream 1 ms
org.apache.spark.streaming.DStreamClosureSuite: (It is not a test) 1 ms
org.apache.spark.streaming.DStreamScopeSuite: (It is not a test) 0 ms
org.apache.spark.streaming.InputStreamsSuite: socket input stream 5 ms
org.apache.spark.streaming.InputStreamsSuite: socket input stream - no block in a batch 2 ms
org.apache.spark.streaming.InputStreamsSuite: binary records stream 2 ms
org.apache.spark.streaming.InputStreamsSuite: file input stream - newFilesOnly = true 2 ms
org.apache.spark.streaming.InputStreamsSuite: file input stream - newFilesOnly = false 1 ms
org.apache.spark.streaming.InputStreamsSuite: file input stream - wildcard 1 ms
org.apache.spark.streaming.InputStreamsSuite: multi-thread receiver 2 ms
org.apache.spark.streaming.InputStreamsSuite: queue input stream - oneAtATime = true 0 ms
org.apache.spark.streaming.InputStreamsSuite: queue input stream - oneAtATime = false 1 ms
org.apache.spark.streaming.InputStreamsSuite: test track the number of input stream 0 ms
org.apache.spark.streaming.JavaMapWithStateSuite: testBasicFunction 1 ms
org.apache.spark.streaming.JavaReceiverAPISuite: testReceiver 3 ms
org.apache.spark.streaming.MapWithStateSuite: (It is not a test) 0 ms
org.apache.spark.streaming.ReceivedBlockHandlerSuite: (It is not a test) 18 ms
org.apache.spark.streaming.ReceivedBlockHandlerWithEncryptionSuite: (It is not a test) 17 ms
org.apache.spark.streaming.ReceiverInputDStreamSuite: Without WAL enabled: createBlockRDD creates empty BlockRDD when no block info 1 ms
org.apache.spark.streaming.ReceiverInputDStreamSuite: Without WAL enabled: createBlockRDD creates correct BlockRDD with block info 0 ms
org.apache.spark.streaming.ReceiverInputDStreamSuite: Without WAL enabled: createBlockRDD filters non-existent blocks before creating BlockRDD 0 ms
org.apache.spark.streaming.ReceiverInputDStreamSuite: With WAL enabled: createBlockRDD creates empty WALBackedBlockRDD when no block info 0 ms
org.apache.spark.streaming.ReceiverInputDStreamSuite: With WAL enabled: createBlockRDD creates correct WALBackedBlockRDD with all block info having WAL info 0 ms
org.apache.spark.streaming.ReceiverInputDStreamSuite: With WAL enabled: createBlockRDD creates BlockRDD when some block info don't have WAL info 1 ms
org.apache.spark.streaming.ReceiverSuite: write ahead log - generating and cleaning 3 ms
org.apache.spark.streaming.StreamingContextSuite: SPARK-18560 Receiver data should be deserialized properly 66195 ms
org.apache.spark.streaming.StreamingListenerSuite: batch info reporting 1 ms
org.apache.spark.streaming.StreamingListenerSuite: receiver info reporting 0 ms
org.apache.spark.streaming.StreamingListenerSuite: output operation reporting 0 ms
org.apache.spark.streaming.StreamingListenerSuite: stop in listener 1 ms
org.apache.spark.streaming.StreamingListenerSuite: onBatchCompleted with successful batch 0 ms
org.apache.spark.streaming.StreamingListenerSuite: onBatchCompleted with failed batch and one failed job 0 ms
org.apache.spark.streaming.StreamingListenerSuite: onBatchCompleted with failed batch and multiple failed jobs 0 ms
org.apache.spark.streaming.StreamingListenerSuite: StreamingListener receives no events after stopping StreamingListenerBus 4 ms
org.apache.spark.streaming.rdd.WriteAheadLogBackedBlockRDDSuite: (It is not a test) 1 ms
org.apache.spark.streaming.scheduler.ExecutorAllocationManagerSuite: enabling and disabling 1 ms
org.apache.spark.streaming.scheduler.InputInfoTrackerSuite: (It is not a test) 1 ms
org.apache.spark.streaming.scheduler.JobGeneratorSuite: SPARK-6222: Do not clear received block data too soon 1 ms
org.apache.spark.streaming.scheduler.RateControllerSuite: RateController - rate controller publishes updates after batches complete 1 ms
org.apache.spark.streaming.scheduler.RateControllerSuite: ReceiverRateController - published rates reach receivers 0 ms
org.apache.spark.streaming.scheduler.ReceiverTrackerSuite: send rate update to receivers 1 ms
org.apache.spark.streaming.scheduler.ReceiverTrackerSuite: should restart receiver after stopping it 1 ms
org.apache.spark.streaming.scheduler.ReceiverTrackerSuite: SPARK-11063: TaskSetManager should use Receiver RDD's preferredLocations 0 ms
org.apache.spark.streaming.scheduler.ReceiverTrackerSuite: get allocated executors 0 ms
org.apache.spark.streaming.ui.StreamingJobProgressListenerSuite: onBatchSubmitted, onBatchStarted, onBatchCompleted, onReceiverStarted, onReceiverError, onReceiverStopped 0 ms
org.apache.spark.streaming.ui.StreamingJobProgressListenerSuite: Remove the old completed batches when exceeding the limit 0 ms
org.apache.spark.streaming.ui.StreamingJobProgressListenerSuite: out-of-order onJobStart and onBatchXXX 0 ms
org.apache.spark.streaming.ui.StreamingJobProgressListenerSuite: detect memory leak 0 ms
test.org.apache.spark.streaming.Java8APISuite: testStreamingContextTransform 4 ms
test.org.apache.spark.streaming.Java8APISuite: testFlatMapValues 0 ms
test.org.apache.spark.streaming.Java8APISuite: testMapPartitions 1 ms
test.org.apache.spark.streaming.Java8APISuite: testPairFilter 1 ms
test.org.apache.spark.streaming.Java8APISuite: testCombineByKey 0 ms
test.org.apache.spark.streaming.Java8APISuite: testMap 0 ms
test.org.apache.spark.streaming.Java8APISuite: testPairToNormalRDDTransform 1 ms
test.org.apache.spark.streaming.Java8APISuite: testPairReduceByKey 0 ms
test.org.apache.spark.streaming.Java8APISuite: testPairMap 0 ms
test.org.apache.spark.streaming.Java8APISuite: testFlatMap 0 ms
test.org.apache.spark.streaming.Java8APISuite: testReduceByKeyAndWindowWithInverse 1 ms
test.org.apache.spark.streaming.Java8APISuite: testReduceByWindow 0 ms
test.org.apache.spark.streaming.Java8APISuite: testPairFlatMap 0 ms
test.org.apache.spark.streaming.Java8APISuite: testPairToPairFlatMapWithChangingTypes 1 ms
test.org.apache.spark.streaming.Java8APISuite: testPairMapPartitions 0 ms
test.org.apache.spark.streaming.Java8APISuite: testVariousTransform 0 ms
test.org.apache.spark.streaming.Java8APISuite: testTransformWith 0 ms
test.org.apache.spark.streaming.Java8APISuite: testVariousTransformWith 0 ms
test.org.apache.spark.streaming.Java8APISuite: testReduceByKeyAndWindow 1 ms
test.org.apache.spark.streaming.Java8APISuite: testPairTransform 0 ms
test.org.apache.spark.streaming.Java8APISuite: testFilter 0 ms
test.org.apache.spark.streaming.Java8APISuite: testPairMap2 1 ms
test.org.apache.spark.streaming.Java8APISuite: testMapValues 0 ms
test.org.apache.spark.streaming.Java8APISuite: testReduce 1 ms
test.org.apache.spark.streaming.Java8APISuite: testUpdateStateByKey 0 ms
test.org.apache.spark.streaming.Java8APISuite: testTransform 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testStreamingContextTransform 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testFlatMapValues 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testReduceByWindowWithInverse 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testMapPartitions 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairFilter 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testRepartitionFewerPartitions 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testCombineByKey 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testContextGetOrCreate 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testWindowWithSlideDuration 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testQueueStream 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testCountByValue 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testMap 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairToNormalRDDTransform 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairReduceByKey 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testCount 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testCheckpointMasterRecovery 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairMap 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testUnion 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testFlatMap 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testReduceByKeyAndWindowWithInverse 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testGlom 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testJoin 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairFlatMap 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairToPairFlatMapWithChangingTypes 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairMapPartitions 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testRepartitionMorePartitions 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testReduceByWindowWithoutInverse 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testLeftOuterJoin 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testVariousTransform 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testTransformWith 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testVariousTransformWith 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testTextFileStream 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairGroupByKey 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testCoGroup 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testInitialization 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testSocketString 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testGroupByKeyAndWindow 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testReduceByKeyAndWindow 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testForeachRDD 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testFileStream 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairTransform 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testFilter 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testPairMap2 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testMapValues 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testReduce 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testUpdateStateByKey 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testTransform 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testWindow 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testCountByValueAndWindow 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testRawSocketStream 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testSocketTextStream 0 ms
test.org.apache.spark.streaming.JavaAPISuite: testUpdateStateByKeyWithInitial 1 ms
test.org.apache.spark.streaming.JavaAPISuite: testContextState 0 ms

Test time report

Right click on the visualization to go back up a level. Click on a node to expand it. Hover over a node to see the combined duration of tests under that node.