You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@systemml.apache.org by je...@spark.tc on 2017/07/10 22:04:35 UTC

Build failed in Jenkins: SystemML-DailyTest #1103

See <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/1103/>

------------------------------------------
[...truncated 28639 lines...]
17/07/10 16:04:07 INFO scheduler.DAGScheduler: running: Set(ShuffleMapStage 1)
17/07/10 16:04:07 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 2)
17/07/10 16:04:07 INFO scheduler.DAGScheduler: failed: Set()
17/07/10 16:04:07 INFO scheduler.DAGScheduler: ShuffleMapStage 1 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.316 s
17/07/10 16:04:07 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/10 16:04:07 INFO scheduler.DAGScheduler: running: Set()
17/07/10 16:04:07 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 2)
17/07/10 16:04:07 INFO scheduler.DAGScheduler: failed: Set()
17/07/10 16:04:07 INFO scheduler.DAGScheduler: Submitting ResultStage 2 (MapPartitionsRDD[5] at mapValues at BinarySPInstruction.java:117), which has no missing parents
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_2 stored as values in memory (estimated size 4.2 KB, free 1033.8 MB)
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_2_piece0 stored as bytes in memory (estimated size 2.3 KB, free 1033.8 MB)
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Added broadcast_2_piece0 in memory on 169.54.146.43:37197 (size: 2.3 KB, free: 1033.8 MB)
17/07/10 16:04:08 INFO spark.SparkContext: Created broadcast 2 from broadcast at DAGScheduler.scala:996
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 2 (MapPartitionsRDD[5] at mapValues at BinarySPInstruction.java:117)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Adding task set 2.0 with 1 tasks
17/07/10 16:04:08 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_2.0 tasks to pool default
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 2.0 (TID 2, localhost, executor driver, partition 0, PROCESS_LOCAL, 5813 bytes)
17/07/10 16:04:08 INFO executor.Executor: Running task 0.0 in stage 2.0 (TID 2)
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 7 ms
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 1 ms
17/07/10 16:04:08 INFO executor.Executor: Finished task 0.0 in stage 2.0 (TID 2). 2077 bytes result sent to driver
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 2.0 (TID 2) in 156 ms on localhost (executor driver) (1/1)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 2.0, whose tasks have all completed, from pool default
17/07/10 16:04:08 INFO scheduler.DAGScheduler: ResultStage 2 (collect at SparkExecutionContext.java:789) finished in 0.158 s
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Removed broadcast_0_piece0 on 169.54.146.43:37197 in memory (size: 1302.0 B, free: 1033.8 MB)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Registering RDD 7 (parallelizePairs at SparkExecutionContext.java:699)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Registering RDD 6 (parallelizePairs at SparkExecutionContext.java:699)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Got job 1 (collect at SparkExecutionContext.java:789) with 1 output partitions
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Final stage: ResultStage 5 (collect at SparkExecutionContext.java:789)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_3 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_3_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Added broadcast_3_piece0 in memory on 169.54.146.43:37197 (size: 1305.0 B, free: 1033.8 MB)
17/07/10 16:04:08 INFO spark.SparkContext: Created broadcast 3 from broadcast at DAGScheduler.scala:996
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Adding task set 3.0 with 1 tasks
17/07/10 16:04:08 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_3.0 tasks to pool default
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_4 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_4_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Added broadcast_4_piece0 in memory on 169.54.146.43:37197 (size: 1305.0 B, free: 1033.8 MB)
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 3.0 (TID 3, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/10 16:04:08 INFO executor.Executor: Running task 0.0 in stage 3.0 (TID 3)
17/07/10 16:04:08 INFO spark.SparkContext: Created broadcast 4 from broadcast at DAGScheduler.scala:996
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Adding task set 4.0 with 1 tasks
17/07/10 16:04:08 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_4.0 tasks to pool default
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Removed broadcast_2_piece0 on 169.54.146.43:37197 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/10 16:04:08 INFO executor.Executor: Finished task 0.0 in stage 3.0 (TID 3). 1253 bytes result sent to driver
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Removed broadcast_1_piece0 on 169.54.146.43:37197 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 4.0 (TID 4, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/10 16:04:08 INFO executor.Executor: Running task 0.0 in stage 4.0 (TID 4)
17/07/10 16:04:08 INFO spark.ContextCleaner: Cleaned shuffle 1
17/07/10 16:04:08 INFO spark.ContextCleaner: Cleaned shuffle 0
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 3.0 (TID 3) in 36 ms on localhost (executor driver) (1/1)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 3.0, whose tasks have all completed, from pool default
17/07/10 16:04:08 INFO scheduler.DAGScheduler: ShuffleMapStage 3 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.038 s
17/07/10 16:04:08 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/10 16:04:08 INFO scheduler.DAGScheduler: running: Set(ShuffleMapStage 4)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: failed: Set()
17/07/10 16:04:08 INFO executor.Executor: Finished task 0.0 in stage 4.0 (TID 4). 1253 bytes result sent to driver
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 4.0 (TID 4) in 13 ms on localhost (executor driver) (1/1)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 4.0, whose tasks have all completed, from pool default
17/07/10 16:04:08 INFO scheduler.DAGScheduler: ShuffleMapStage 4 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.026 s
17/07/10 16:04:08 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/10 16:04:08 INFO scheduler.DAGScheduler: running: Set()
17/07/10 16:04:08 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/10 16:04:08 INFO scheduler.DAGScheduler: failed: Set()
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117), which has no missing parents
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_5 stored as values in memory (estimated size 4.2 KB, free 1033.8 MB)
17/07/10 16:04:08 INFO memory.MemoryStore: Block broadcast_5_piece0 stored as bytes in memory (estimated size 2.3 KB, free 1033.8 MB)
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Added broadcast_5_piece0 in memory on 169.54.146.43:37197 (size: 2.3 KB, free: 1033.8 MB)
17/07/10 16:04:08 INFO spark.SparkContext: Created broadcast 5 from broadcast at DAGScheduler.scala:996
17/07/10 16:04:08 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Adding task set 5.0 with 1 tasks
17/07/10 16:04:08 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_5.0 tasks to pool default
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 5.0 (TID 5, localhost, executor driver, partition 0, PROCESS_LOCAL, 5814 bytes)
17/07/10 16:04:08 INFO executor.Executor: Running task 0.0 in stage 5.0 (TID 5)
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/10 16:04:08 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/07/10 16:04:08 INFO executor.Executor: Finished task 0.0 in stage 5.0 (TID 5). 2240 bytes result sent to driver
17/07/10 16:04:08 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 5.0 (TID 5) in 18 ms on localhost (executor driver) (1/1)
17/07/10 16:04:08 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 5.0, whose tasks have all completed, from pool default
17/07/10 16:04:08 INFO scheduler.DAGScheduler: ResultStage 5 (collect at SparkExecutionContext.java:789) finished in 0.020 s
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Removed broadcast_5_piece0 on 169.54.146.43:37197 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Removed broadcast_4_piece0 on 169.54.146.43:37197 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/10 16:04:08 INFO storage.BlockManagerInfo: Removed broadcast_3_piece0 on 169.54.146.43:37197 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/10 16:04:08 INFO spark.ContextCleaner: Cleaned shuffle 2
17/07/10 16:04:08 INFO spark.ContextCleaner: Cleaned shuffle 3
Running org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
Tests run: 90, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,457.642 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
17/07/10 16:06:07 INFO util.ShutdownHookManager: Shutdown hook called
17/07/10 16:06:07 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-e5d8919d-ad32-41fe-a679-25d045140911
17/07/10 16:06:15 INFO server.ServerConnector: Stopped ServerConnector@29d67a9e{HTTP/1.1}{0.0.0.0:4040}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@943a04b{/stages/stage/kill,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7522e7d9{/jobs/job/kill,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2e3e1866{/api,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@47b71f39{/,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2abac4e2{/static,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@17e995c5{/executors/threadDump/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3f1adf46{/executors/threadDump,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@64112e32{/executors/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@354105e7{/executors,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@69e83666{/environment/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@c7ae54b{/environment,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@68a724d1{/storage/rdd/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@f6a63e7{/storage/rdd,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@399b8d97{/storage/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@55563deb{/storage,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@398bc427{/stages/pool/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1074d67d{/stages/pool,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@13bfe3dd{/stages/stage/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2ec85f32{/stages/stage,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1b664602{/stages/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@ab12f38{/stages,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1f144bd5{/jobs/job/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1a55f9cd{/jobs/job,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@10b02ed2{/jobs/json,null,UNAVAILABLE}
17/07/10 16:06:15 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@618e87c8{/jobs,null,UNAVAILABLE}
17/07/10 16:06:15 INFO ui.SparkUI: Stopped Spark web UI at http://169.54.146.43:4040
17/07/10 16:06:15 INFO spark.MapOutputTrackerMasterEndpoint: MapOutputTrackerMasterEndpoint stopped!
17/07/10 16:06:15 INFO memory.MemoryStore: MemoryStore cleared
17/07/10 16:06:15 INFO storage.BlockManager: BlockManager stopped
17/07/10 16:06:15 INFO storage.BlockManagerMaster: BlockManagerMaster stopped
17/07/10 16:06:15 INFO scheduler.OutputCommitCoordinator$OutputCommitCoordinatorEndpoint: OutputCommitCoordinator stopped!
17/07/10 16:06:16 INFO spark.SparkContext: Successfully stopped SparkContext
Running org.apache.sysml.test.integration.scripts.nn.NNTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 664.912 sec - in org.apache.sysml.test.integration.scripts.nn.NNTest
17/07/10 16:06:16 INFO util.ShutdownHookManager: Shutdown hook called
17/07/10 16:06:16 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-885d2389-a4dc-47e8-aa13-78b89984a984
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 355.538 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Running org.apache.sysml.test.integration.functions.append.AppendChainTest
Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,070.609 sec - in org.apache.sysml.test.integration.functions.append.AppendChainTest
Running org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Tests run: 10, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 518.421 sec - in org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleSparseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 278.136 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleSparseTest
Running org.apache.sysml.test.integration.applications.parfor.ParForSampleTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 105.669 sec - in org.apache.sysml.test.integration.applications.parfor.ParForSampleTest
Running org.apache.sysml.test.integration.applications.parfor.ParForUnivariateStatsTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 7.871 sec - in org.apache.sysml.test.integration.applications.parfor.ParForUnivariateStatsTest
Running org.apache.sysml.test.integration.applications.dml.HITSDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 92.052 sec - in org.apache.sysml.test.integration.applications.dml.HITSDMLTest
Running org.apache.sysml.test.integration.functions.append.AppendMatrixTest
Tests run: 22, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,432.23 sec - in org.apache.sysml.test.integration.functions.append.AppendMatrixTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleSparseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 353.476 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleSparseTest
Running org.apache.sysml.test.integration.applications.pydml.ArimaPyDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 47.45 sec - in org.apache.sysml.test.integration.applications.pydml.ArimaPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.HITSPyDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 77.997 sec - in org.apache.sysml.test.integration.applications.pydml.HITSPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.LinearRegressionDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 51.063 sec - in org.apache.sysml.test.integration.applications.dml.LinearRegressionDMLTest
Running org.apache.sysml.test.integration.applications.pydml.CsplineDSPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.657 sec - in org.apache.sysml.test.integration.applications.pydml.CsplineDSPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.LinearLogRegPyDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 81.494 sec - in org.apache.sysml.test.integration.applications.pydml.LinearLogRegPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.NaiveBayesPyDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 80.666 sec - in org.apache.sysml.test.integration.applications.pydml.NaiveBayesPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.CsplineCGDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 12.597 sec - in org.apache.sysml.test.integration.applications.dml.CsplineCGDMLTest
Running org.apache.sysml.test.integration.applications.dml.L2SVMDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 64.281 sec - in org.apache.sysml.test.integration.applications.dml.L2SVMDMLTest
Running org.apache.sysml.test.integration.applications.pydml.MDABivariateStatsPyDMLTest
Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 293.941 sec - in org.apache.sysml.test.integration.applications.pydml.MDABivariateStatsPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.PageRankPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.109 sec - in org.apache.sysml.test.integration.applications.pydml.PageRankPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.NaiveBayesParforPyDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 80.6 sec - in org.apache.sysml.test.integration.applications.pydml.NaiveBayesParforPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.NaiveBayesDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 80.797 sec - in org.apache.sysml.test.integration.applications.dml.NaiveBayesDMLTest
Running org.apache.sysml.test.integration.applications.dml.MDABivariateStatsDMLTest
Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 293.656 sec - in org.apache.sysml.test.integration.applications.dml.MDABivariateStatsDMLTest
Running org.apache.sysml.test.integration.applications.dml.PageRankDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.069 sec - in org.apache.sysml.test.integration.applications.dml.PageRankDMLTest
Running org.apache.sysml.test.integration.applications.pydml.GLMPyDMLTest
Tests run: 30, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 583.056 sec - in org.apache.sysml.test.integration.applications.pydml.GLMPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.MultiClassSVMPyDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 88.212 sec - in org.apache.sysml.test.integration.applications.pydml.MultiClassSVMPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.ID3DMLTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 398.526 sec - in org.apache.sysml.test.integration.applications.dml.ID3DMLTest
Running org.apache.sysml.test.integration.applications.dml.GLMDMLTest
Tests run: 30, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 871.055 sec - in org.apache.sysml.test.integration.applications.dml.GLMDMLTest
Running org.apache.sysml.test.integration.applications.pydml.CsplineCGPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.063 sec - in org.apache.sysml.test.integration.applications.pydml.CsplineCGPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.WelchTPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.374 sec - in org.apache.sysml.test.integration.applications.pydml.WelchTPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.MultiClassSVMDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 87.819 sec - in org.apache.sysml.test.integration.applications.dml.MultiClassSVMDMLTest
Running org.apache.sysml.test.integration.applications.dml.CsplineDSDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 12.468 sec - in org.apache.sysml.test.integration.applications.dml.CsplineDSDMLTest
Running org.apache.sysml.test.integration.applications.pydml.ApplyTransformPyDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.838 sec - in org.apache.sysml.test.integration.applications.pydml.ApplyTransformPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.NaiveBayesParforDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 81.114 sec - in org.apache.sysml.test.integration.applications.dml.NaiveBayesParforDMLTest
Running org.apache.sysml.test.integration.applications.pydml.L2SVMPyDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 63.975 sec - in org.apache.sysml.test.integration.applications.pydml.L2SVMPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.LinearRegressionPyDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 50.973 sec - in org.apache.sysml.test.integration.applications.pydml.LinearRegressionPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.LinearLogRegDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 61.387 sec - in org.apache.sysml.test.integration.applications.dml.LinearLogRegDMLTest
Running org.apache.sysml.test.integration.applications.dml.GNMFDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 62.926 sec - in org.apache.sysml.test.integration.applications.dml.GNMFDMLTest
Running org.apache.sysml.test.integration.applications.dml.WelchTDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.412 sec - in org.apache.sysml.test.integration.applications.dml.WelchTDMLTest
Running org.apache.sysml.test.integration.applications.dml.ApplyTransformDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 13.848 sec - in org.apache.sysml.test.integration.applications.dml.ApplyTransformDMLTest
Running org.apache.sysml.test.integration.applications.pydml.ID3PyDMLTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 387.581 sec - in org.apache.sysml.test.integration.applications.pydml.ID3PyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 56.876 sec - in org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest

Results :

Failed tests: 
  FrameMatrixReblockTest.testFrameWriteMultipleSparseBinarySpark:169->runFrameReblockTest:225 25 values are not in equal

Tests run: 7195, Failures: 1, Errors: 0, Skipped: 0

[INFO] 
[INFO] --- maven-failsafe-plugin:2.17:verify (default) @ systemml ---
[INFO] Failsafe report directory: <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/ws/target/failsafe-reports>
[INFO] ------------------------------------------------------------------------
[INFO] BUILD FAILURE
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 02:28 h
[INFO] Finished at: 2017-07-10T17:04:34-05:00
[INFO] Final Memory: 61M/2604M
[INFO] ------------------------------------------------------------------------
[ERROR] Failed to execute goal org.apache.maven.plugins:maven-failsafe-plugin:2.17:verify (default) on project systemml: There are test failures.
[ERROR] 
[ERROR] Please refer to <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/ws/target/failsafe-reports> for the individual test results.
[ERROR] -> [Help 1]
[ERROR] 
[ERROR] To see the full stack trace of the errors, re-run Maven with the -e switch.
[ERROR] Re-run Maven using the -X switch to enable full debug logging.
[ERROR] 
[ERROR] For more information about the errors and possible solutions, please read the following articles:
[ERROR] [Help 1] http://cwiki.apache.org/confluence/display/MAVEN/MojoFailureException
Build step 'Execute shell' marked build as failure
Run condition [Always] enabling perform for step [[]]

Jenkins build is back to normal : SystemML-DailyTest #1105

Posted by je...@spark.tc.
See <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/1105/>


Build failed in Jenkins: SystemML-DailyTest #1104

Posted by je...@spark.tc.
See <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/1104/>

------------------------------------------
[...truncated 28696 lines...]
17/07/11 04:00:00 INFO scheduler.DAGScheduler: running: Set(ShuffleMapStage 1)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 2)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: failed: Set()
17/07/11 04:00:00 INFO scheduler.DAGScheduler: ShuffleMapStage 1 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.201 s
17/07/11 04:00:00 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/11 04:00:00 INFO scheduler.DAGScheduler: running: Set()
17/07/11 04:00:00 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 2)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: failed: Set()
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting ResultStage 2 (MapPartitionsRDD[5] at mapValues at BinarySPInstruction.java:117), which has no missing parents
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_2 stored as values in memory (estimated size 4.2 KB, free 1033.8 MB)
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_2_piece0 stored as bytes in memory (estimated size 2.3 KB, free 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Added broadcast_2_piece0 in memory on 169.54.146.43:58932 (size: 2.3 KB, free: 1033.8 MB)
17/07/11 04:00:00 INFO spark.SparkContext: Created broadcast 2 from broadcast at DAGScheduler.scala:996
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 2 (MapPartitionsRDD[5] at mapValues at BinarySPInstruction.java:117)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Adding task set 2.0 with 1 tasks
17/07/11 04:00:00 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_2.0 tasks to pool default
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 2.0 (TID 2, localhost, executor driver, partition 0, PROCESS_LOCAL, 5813 bytes)
17/07/11 04:00:00 INFO executor.Executor: Running task 0.0 in stage 2.0 (TID 2)
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 7 ms
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/07/11 04:00:00 INFO executor.Executor: Finished task 0.0 in stage 2.0 (TID 2). 2077 bytes result sent to driver
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 2.0 (TID 2) in 72 ms on localhost (executor driver) (1/1)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 2.0, whose tasks have all completed, from pool default
17/07/11 04:00:00 INFO scheduler.DAGScheduler: ResultStage 2 (collect at SparkExecutionContext.java:789) finished in 0.073 s
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Removed broadcast_2_piece0 on 169.54.146.43:58932 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Removed broadcast_1_piece0 on 169.54.146.43:58932 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Removed broadcast_0_piece0 on 169.54.146.43:58932 in memory (size: 1302.0 B, free: 1033.8 MB)
17/07/11 04:00:00 INFO spark.ContextCleaner: Cleaned shuffle 0
17/07/11 04:00:00 INFO spark.ContextCleaner: Cleaned shuffle 1
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Registering RDD 7 (parallelizePairs at SparkExecutionContext.java:699)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Registering RDD 6 (parallelizePairs at SparkExecutionContext.java:699)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Got job 1 (collect at SparkExecutionContext.java:789) with 1 output partitions
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Final stage: ResultStage 5 (collect at SparkExecutionContext.java:789)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_3 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_3_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Added broadcast_3_piece0 in memory on 169.54.146.43:58932 (size: 1305.0 B, free: 1033.8 MB)
17/07/11 04:00:00 INFO spark.SparkContext: Created broadcast 3 from broadcast at DAGScheduler.scala:996
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Adding task set 3.0 with 1 tasks
17/07/11 04:00:00 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_3.0 tasks to pool default
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 3.0 (TID 3, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/11 04:00:00 INFO executor.Executor: Running task 0.0 in stage 3.0 (TID 3)
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_4 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_4_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Added broadcast_4_piece0 in memory on 169.54.146.43:58932 (size: 1305.0 B, free: 1033.8 MB)
17/07/11 04:00:00 INFO spark.SparkContext: Created broadcast 4 from broadcast at DAGScheduler.scala:996
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Adding task set 4.0 with 1 tasks
17/07/11 04:00:00 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_4.0 tasks to pool default
17/07/11 04:00:00 INFO executor.Executor: Finished task 0.0 in stage 3.0 (TID 3). 1253 bytes result sent to driver
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 4.0 (TID 4, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/11 04:00:00 INFO executor.Executor: Running task 0.0 in stage 4.0 (TID 4)
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 3.0 (TID 3) in 14 ms on localhost (executor driver) (1/1)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 3.0, whose tasks have all completed, from pool default
17/07/11 04:00:00 INFO scheduler.DAGScheduler: ShuffleMapStage 3 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.016 s
17/07/11 04:00:00 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/11 04:00:00 INFO scheduler.DAGScheduler: running: Set(ShuffleMapStage 4)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: failed: Set()
17/07/11 04:00:00 INFO executor.Executor: Finished task 0.0 in stage 4.0 (TID 4). 1253 bytes result sent to driver
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 4.0 (TID 4) in 9 ms on localhost (executor driver) (1/1)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 4.0, whose tasks have all completed, from pool default
17/07/11 04:00:00 INFO scheduler.DAGScheduler: ShuffleMapStage 4 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.015 s
17/07/11 04:00:00 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/11 04:00:00 INFO scheduler.DAGScheduler: running: Set()
17/07/11 04:00:00 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/11 04:00:00 INFO scheduler.DAGScheduler: failed: Set()
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117), which has no missing parents
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_5 stored as values in memory (estimated size 4.2 KB, free 1033.8 MB)
17/07/11 04:00:00 INFO memory.MemoryStore: Block broadcast_5_piece0 stored as bytes in memory (estimated size 2.3 KB, free 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Added broadcast_5_piece0 in memory on 169.54.146.43:58932 (size: 2.3 KB, free: 1033.8 MB)
17/07/11 04:00:00 INFO spark.SparkContext: Created broadcast 5 from broadcast at DAGScheduler.scala:996
17/07/11 04:00:00 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Adding task set 5.0 with 1 tasks
17/07/11 04:00:00 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_5.0 tasks to pool default
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 5.0 (TID 5, localhost, executor driver, partition 0, PROCESS_LOCAL, 5814 bytes)
17/07/11 04:00:00 INFO executor.Executor: Running task 0.0 in stage 5.0 (TID 5)
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 1 ms
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/11 04:00:00 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/07/11 04:00:00 INFO executor.Executor: Finished task 0.0 in stage 5.0 (TID 5). 2240 bytes result sent to driver
17/07/11 04:00:00 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 5.0 (TID 5) in 18 ms on localhost (executor driver) (1/1)
17/07/11 04:00:00 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 5.0, whose tasks have all completed, from pool default
17/07/11 04:00:00 INFO scheduler.DAGScheduler: ResultStage 5 (collect at SparkExecutionContext.java:789) finished in 0.020 s
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Removed broadcast_5_piece0 on 169.54.146.43:58932 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/11 04:00:00 INFO spark.ContextCleaner: Cleaned shuffle 2
17/07/11 04:00:00 INFO spark.ContextCleaner: Cleaned shuffle 3
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Removed broadcast_4_piece0 on 169.54.146.43:58932 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/11 04:00:00 INFO storage.BlockManagerInfo: Removed broadcast_3_piece0 on 169.54.146.43:58932 in memory (size: 1305.0 B, free: 1033.8 MB)
Running org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
Tests run: 90, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,481.692 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
17/07/11 04:02:16 INFO util.ShutdownHookManager: Shutdown hook called
17/07/11 04:02:16 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-e5845f05-34e3-4920-b2cf-5f0a246f054e
17/07/11 04:02:20 INFO server.ServerConnector: Stopped ServerConnector@448c9c95{HTTP/1.1}{0.0.0.0:4040}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@76932e1b{/stages/stage/kill,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7d06b2fe{/jobs/job/kill,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@72b5e1e4{/api,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@b0ed694{/,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@9f05dd8{/static,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2775092d{/executors/threadDump/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7721cc75{/executors/threadDump,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@44c8d684{/executors/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@974fbe0{/executors,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@abb47e3{/environment/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@491f58b0{/environment,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@225df587{/storage/rdd/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@d81d9a5{/storage/rdd,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3c2fe911{/storage/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1caef0ec{/storage,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@26812e5c{/stages/pool/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6e1bf089{/stages/pool,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7d3ba353{/stages/stage/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7fa8b7af{/stages/stage,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3d1ea987{/stages/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@684f7f92{/stages,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2e059283{/jobs/job/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3c1fdd66{/jobs/job,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@233ed753{/jobs/json,null,UNAVAILABLE}
17/07/11 04:02:20 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@8e9ccb5{/jobs,null,UNAVAILABLE}
17/07/11 04:02:20 INFO ui.SparkUI: Stopped Spark web UI at http://169.54.146.43:4040
17/07/11 04:02:20 INFO spark.MapOutputTrackerMasterEndpoint: MapOutputTrackerMasterEndpoint stopped!
17/07/11 04:02:20 INFO memory.MemoryStore: MemoryStore cleared
17/07/11 04:02:20 INFO storage.BlockManager: BlockManager stopped
17/07/11 04:02:20 INFO storage.BlockManagerMaster: BlockManagerMaster stopped
17/07/11 04:02:20 INFO scheduler.OutputCommitCoordinator$OutputCommitCoordinatorEndpoint: OutputCommitCoordinator stopped!
17/07/11 04:02:21 INFO spark.SparkContext: Successfully stopped SparkContext
Running org.apache.sysml.test.integration.scripts.nn.NNTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 668.008 sec - in org.apache.sysml.test.integration.scripts.nn.NNTest
17/07/11 04:02:21 INFO util.ShutdownHookManager: Shutdown hook called
17/07/11 04:02:21 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-5b3bde3c-a818-4fcf-9a12-2d51227d2668
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 375.515 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Running org.apache.sysml.test.integration.functions.append.AppendChainTest
Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,082.614 sec - in org.apache.sysml.test.integration.functions.append.AppendChainTest
Running org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Tests run: 10, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 536.977 sec - in org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Running org.apache.sysml.test.integration.applications.parfor.ParForSampleTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 109.332 sec - in org.apache.sysml.test.integration.applications.parfor.ParForSampleTest
Running org.apache.sysml.test.integration.applications.parfor.ParForUnivariateStatsTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 7.401 sec - in org.apache.sysml.test.integration.applications.parfor.ParForUnivariateStatsTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleSparseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 291.031 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleSparseTest
Running org.apache.sysml.test.integration.applications.dml.HITSDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 87.492 sec - in org.apache.sysml.test.integration.applications.dml.HITSDMLTest
Running org.apache.sysml.test.integration.functions.append.AppendMatrixTest
Tests run: 22, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,514.941 sec - in org.apache.sysml.test.integration.functions.append.AppendMatrixTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleSparseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 343.947 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleSparseTest
Running org.apache.sysml.test.integration.applications.pydml.ArimaPyDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 48.258 sec - in org.apache.sysml.test.integration.applications.pydml.ArimaPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.HITSPyDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 78.822 sec - in org.apache.sysml.test.integration.applications.pydml.HITSPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.LinearRegressionDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 51.542 sec - in org.apache.sysml.test.integration.applications.dml.LinearRegressionDMLTest
Running org.apache.sysml.test.integration.applications.pydml.CsplineDSPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.744 sec - in org.apache.sysml.test.integration.applications.pydml.CsplineDSPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.LinearLogRegPyDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 85.499 sec - in org.apache.sysml.test.integration.applications.pydml.LinearLogRegPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.NaiveBayesPyDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 80.855 sec - in org.apache.sysml.test.integration.applications.pydml.NaiveBayesPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.CsplineCGDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 13.938 sec - in org.apache.sysml.test.integration.applications.dml.CsplineCGDMLTest
Running org.apache.sysml.test.integration.applications.dml.L2SVMDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 64.718 sec - in org.apache.sysml.test.integration.applications.dml.L2SVMDMLTest
Running org.apache.sysml.test.integration.applications.pydml.MDABivariateStatsPyDMLTest
Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 294.253 sec - in org.apache.sysml.test.integration.applications.pydml.MDABivariateStatsPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.PageRankPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.257 sec - in org.apache.sysml.test.integration.applications.pydml.PageRankPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.NaiveBayesParforPyDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 80.983 sec - in org.apache.sysml.test.integration.applications.pydml.NaiveBayesParforPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.NaiveBayesDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 81.29 sec - in org.apache.sysml.test.integration.applications.dml.NaiveBayesDMLTest
Running org.apache.sysml.test.integration.applications.dml.MDABivariateStatsDMLTest
Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 294.105 sec - in org.apache.sysml.test.integration.applications.dml.MDABivariateStatsDMLTest
Running org.apache.sysml.test.integration.applications.dml.PageRankDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.071 sec - in org.apache.sysml.test.integration.applications.dml.PageRankDMLTest
Running org.apache.sysml.test.integration.applications.pydml.GLMPyDMLTest
Tests run: 30, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 584.509 sec - in org.apache.sysml.test.integration.applications.pydml.GLMPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.MultiClassSVMPyDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 89.115 sec - in org.apache.sysml.test.integration.applications.pydml.MultiClassSVMPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.ID3DMLTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 401.158 sec - in org.apache.sysml.test.integration.applications.dml.ID3DMLTest
Running org.apache.sysml.test.integration.applications.dml.GLMDMLTest
Tests run: 30, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 856.543 sec - in org.apache.sysml.test.integration.applications.dml.GLMDMLTest
Running org.apache.sysml.test.integration.applications.pydml.CsplineCGPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.045 sec - in org.apache.sysml.test.integration.applications.pydml.CsplineCGPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.WelchTPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.336 sec - in org.apache.sysml.test.integration.applications.pydml.WelchTPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.MultiClassSVMDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 87.598 sec - in org.apache.sysml.test.integration.applications.dml.MultiClassSVMDMLTest
Running org.apache.sysml.test.integration.applications.dml.CsplineDSDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 11.634 sec - in org.apache.sysml.test.integration.applications.dml.CsplineDSDMLTest
Running org.apache.sysml.test.integration.applications.pydml.ApplyTransformPyDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.851 sec - in org.apache.sysml.test.integration.applications.pydml.ApplyTransformPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.NaiveBayesParforDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 80.97 sec - in org.apache.sysml.test.integration.applications.dml.NaiveBayesParforDMLTest
Running org.apache.sysml.test.integration.applications.pydml.L2SVMPyDMLTest
Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 63.987 sec - in org.apache.sysml.test.integration.applications.pydml.L2SVMPyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.LinearRegressionPyDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 51.029 sec - in org.apache.sysml.test.integration.applications.pydml.LinearRegressionPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.LinearLogRegDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 61.446 sec - in org.apache.sysml.test.integration.applications.dml.LinearLogRegDMLTest
Running org.apache.sysml.test.integration.applications.dml.GNMFDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 67.424 sec - in org.apache.sysml.test.integration.applications.dml.GNMFDMLTest
Running org.apache.sysml.test.integration.applications.dml.WelchTDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.511 sec - in org.apache.sysml.test.integration.applications.dml.WelchTDMLTest
Running org.apache.sysml.test.integration.applications.dml.ApplyTransformDMLTest
Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 15.786 sec - in org.apache.sysml.test.integration.applications.dml.ApplyTransformDMLTest
Running org.apache.sysml.test.integration.applications.pydml.ID3PyDMLTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 385.053 sec - in org.apache.sysml.test.integration.applications.pydml.ID3PyDMLTest
Running org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 56.729 sec - in org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest

Results :

Failed tests: 
  FullReblockTest.testBinaryBlockMultipleMSparseMR:260->runReblockTest:468 34 values are not in equal

Tests run: 7195, Failures: 1, Errors: 0, Skipped: 0

[INFO] 
[INFO] --- maven-failsafe-plugin:2.17:verify (default) @ systemml ---
[INFO] Failsafe report directory: <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/ws/target/failsafe-reports>
[INFO] ------------------------------------------------------------------------
[INFO] BUILD FAILURE
[INFO] ------------------------------------------------------------------------
[INFO] Total time: 02:28 h
[INFO] Finished at: 2017-07-11T05:00:46-05:00
[INFO] Final Memory: 62M/2677M
[INFO] ------------------------------------------------------------------------
[ERROR] Failed to execute goal org.apache.maven.plugins:maven-failsafe-plugin:2.17:verify (default) on project systemml: There are test failures.
[ERROR] 
[ERROR] Please refer to <https://sparktc.ibmcloud.com/jenkins/job/SystemML-DailyTest/ws/target/failsafe-reports> for the individual test results.
[ERROR] -> [Help 1]
[ERROR] 
[ERROR] To see the full stack trace of the errors, re-run Maven with the -e switch.
[ERROR] Re-run Maven using the -X switch to enable full debug logging.
[ERROR] 
[ERROR] For more information about the errors and possible solutions, please read the following articles:
[ERROR] [Help 1] http://cwiki.apache.org/confluence/display/MAVEN/MojoFailureException
Build step 'Execute shell' marked build as failure
Run condition [Always] enabling perform for step [[]]