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/04/10 09:57:50 UTC

Build failed in Jenkins: SystemML-DailyTest #920

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

Changes:

[Matthias Boehm] [SYSTEMML-1363] Rework codegen algorithm tests (use existing algorithms)

------------------------------------------
[...truncated 27635 lines...]
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Adding task set 257.0 with 1 tasks
17/04/10 03:49:54 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_257.0 tasks to pool default
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 257.0 (TID 267, localhost, executor driver, partition 0, PROCESS_LOCAL, 6298 bytes)
17/04/10 03:49:54 INFO executor.Executor: Running task 0.0 in stage 257.0 (TID 267)
17/04/10 03:49:54 INFO executor.Executor: Finished task 0.0 in stage 257.0 (TID 267). 2590 bytes result sent to driver
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 257.0 (TID 267) in 7 ms on localhost (executor driver) (1/1)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 257.0, whose tasks have all completed, from pool default
17/04/10 03:49:54 INFO scheduler.DAGScheduler: ResultStage 257 (first at RDDConverterUtils.java:243) finished in 0.008 s
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Registering RDD 721 (mapPartitionsToPair at RDDConverterUtils.java:262)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Got job 192 (collect at SparkExecutionContext.java:796) with 1 output partitions
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Final stage: ResultStage 259 (collect at SparkExecutionContext.java:796)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 258)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 258)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 258 (MapPartitionsRDD[721] at mapPartitionsToPair at RDDConverterUtils.java:262), which has no missing parents
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_258 stored as values in memory (estimated size 21.5 KB, free 1026.3 MB)
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_258_piece0 stored as bytes in memory (estimated size 9.6 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO storage.BlockManagerInfo: Added broadcast_258_piece0 in memory on 169.54.146.43:49113 (size: 9.6 KB, free: 1026.8 MB)
17/04/10 03:49:54 INFO spark.SparkContext: Created broadcast 258 from broadcast at DAGScheduler.scala:996
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 258 (MapPartitionsRDD[721] at mapPartitionsToPair at RDDConverterUtils.java:262)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Adding task set 258.0 with 1 tasks
17/04/10 03:49:54 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_258.0 tasks to pool default
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 258.0 (TID 268, localhost, executor driver, partition 0, PROCESS_LOCAL, 6289 bytes)
17/04/10 03:49:54 INFO executor.Executor: Running task 0.0 in stage 258.0 (TID 268)
17/04/10 03:49:54 INFO executor.Executor: Finished task 0.0 in stage 258.0 (TID 268). 1804 bytes result sent to driver
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 258.0 (TID 268) in 10 ms on localhost (executor driver) (1/1)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 258.0, whose tasks have all completed, from pool default
17/04/10 03:49:54 INFO scheduler.DAGScheduler: ShuffleMapStage 258 (mapPartitionsToPair at RDDConverterUtils.java:262) finished in 0.010 s
17/04/10 03:49:54 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/04/10 03:49:54 INFO scheduler.DAGScheduler: running: Set()
17/04/10 03:49:54 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 259)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: failed: Set()
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting ResultStage 259 (MapPartitionsRDD[723] at mapValues at SparkUtils.java:156), which has no missing parents
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_259 stored as values in memory (estimated size 3.8 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_259_piece0 stored as bytes in memory (estimated size 2.1 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO storage.BlockManagerInfo: Added broadcast_259_piece0 in memory on 169.54.146.43:49113 (size: 2.1 KB, free: 1026.8 MB)
17/04/10 03:49:54 INFO spark.SparkContext: Created broadcast 259 from broadcast at DAGScheduler.scala:996
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 259 (MapPartitionsRDD[723] at mapValues at SparkUtils.java:156)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Adding task set 259.0 with 1 tasks
17/04/10 03:49:54 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_259.0 tasks to pool default
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 259.0 (TID 269, localhost, executor driver, partition 0, ANY, 5753 bytes)
17/04/10 03:49:54 INFO executor.Executor: Running task 0.0 in stage 259.0 (TID 269)
17/04/10 03:49:54 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/04/10 03:49:54 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/04/10 03:49:54 INFO executor.Executor: Finished task 0.0 in stage 259.0 (TID 269). 2021 bytes result sent to driver
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 259.0 (TID 269) in 4 ms on localhost (executor driver) (1/1)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 259.0, whose tasks have all completed, from pool default
17/04/10 03:49:54 INFO scheduler.DAGScheduler: ResultStage 259 (collect at SparkExecutionContext.java:796) finished in 0.004 s
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Registering RDD 725 (flatMapToPair at RDDConverterUtils.java:280)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Got job 193 (collectAsList at MLContextTest.java:1325) with 1 output partitions
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Final stage: ResultStage 261 (collectAsList at MLContextTest.java:1325)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 260)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 260)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 260 (MapPartitionsRDD[725] at flatMapToPair at RDDConverterUtils.java:280), which has no missing parents
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_260 stored as values in memory (estimated size 3.9 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_260_piece0 stored as bytes in memory (estimated size 2.2 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO storage.BlockManagerInfo: Added broadcast_260_piece0 in memory on 169.54.146.43:49113 (size: 2.2 KB, free: 1026.8 MB)
17/04/10 03:49:54 INFO spark.SparkContext: Created broadcast 260 from broadcast at DAGScheduler.scala:996
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 260 (MapPartitionsRDD[725] at flatMapToPair at RDDConverterUtils.java:280)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Adding task set 260.0 with 1 tasks
17/04/10 03:49:54 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_260.0 tasks to pool default
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 260.0 (TID 270, localhost, executor driver, partition 0, PROCESS_LOCAL, 6218 bytes)
17/04/10 03:49:54 INFO executor.Executor: Running task 0.0 in stage 260.0 (TID 270)
17/04/10 03:49:54 INFO executor.Executor: Finished task 0.0 in stage 260.0 (TID 270). 1253 bytes result sent to driver
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 260.0 (TID 270) in 5 ms on localhost (executor driver) (1/1)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 260.0, whose tasks have all completed, from pool default
17/04/10 03:49:54 INFO scheduler.DAGScheduler: ShuffleMapStage 260 (flatMapToPair at RDDConverterUtils.java:280) finished in 0.010 s
17/04/10 03:49:54 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/04/10 03:49:54 INFO scheduler.DAGScheduler: running: Set()
17/04/10 03:49:54 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 261)
17/04/10 03:49:54 INFO scheduler.DAGScheduler: failed: Set()
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting ResultStage 261 (MapPartitionsRDD[731] at collectAsList at MLContextTest.java:1325), which has no missing parents
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_261 stored as values in memory (estimated size 11.3 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO memory.MemoryStore: Block broadcast_261_piece0 stored as bytes in memory (estimated size 5.6 KB, free 1026.2 MB)
17/04/10 03:49:54 INFO storage.BlockManagerInfo: Added broadcast_261_piece0 in memory on 169.54.146.43:49113 (size: 5.6 KB, free: 1026.8 MB)
17/04/10 03:49:54 INFO spark.SparkContext: Created broadcast 261 from broadcast at DAGScheduler.scala:996
17/04/10 03:49:54 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 261 (MapPartitionsRDD[731] at collectAsList at MLContextTest.java:1325)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Adding task set 261.0 with 1 tasks
17/04/10 03:49:54 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_261.0 tasks to pool default
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 261.0 (TID 271, localhost, executor driver, partition 0, ANY, 5783 bytes)
17/04/10 03:49:54 INFO executor.Executor: Running task 0.0 in stage 261.0 (TID 271)
17/04/10 03:49:54 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/04/10 03:49:54 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/04/10 03:49:54 INFO executor.Executor: Finished task 0.0 in stage 261.0 (TID 271). 2024 bytes result sent to driver
17/04/10 03:49:54 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 261.0 (TID 271) in 7 ms on localhost (executor driver) (1/1)
17/04/10 03:49:54 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 261.0, whose tasks have all completed, from pool default
17/04/10 03:49:54 INFO scheduler.DAGScheduler: ResultStage 261 (collectAsList at MLContextTest.java:1325) finished in 0.008 s
17/04/10 03:49:54 INFO server.ServerConnector: Stopped ServerConnector@20df92bf{HTTP/1.1}{0.0.0.0:4040}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2262431c{/stages/stage/kill,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2dec2b2d{/jobs/job/kill,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7a2789ab{/api,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6a2a4b23{/,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@38e6fcf0{/static,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@4e5339e3{/executors/threadDump/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7dcdba0f{/executors/threadDump,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1f29b6f1{/executors/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1fbd2fc6{/executors,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@232201f4{/environment/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@324a1992{/environment,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@33666e5e{/storage/rdd/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@53ade1cf{/storage/rdd,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2cc7a7c8{/storage/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@74ceac6c{/storage,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2fd9fe4a{/stages/pool/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@47e70e59{/stages/pool,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@4c328c79{/stages/stage/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6e96ab46{/stages/stage,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6d60b6d1{/stages/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1315de3{/stages,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@232024c1{/jobs/job/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7b5f054e{/jobs/job,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@368b56d2{/jobs/json,null,UNAVAILABLE}
17/04/10 03:49:54 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3ec39e18{/jobs,null,UNAVAILABLE}
17/04/10 03:49:54 INFO ui.SparkUI: Stopped Spark web UI at http://169.54.146.43:4040
17/04/10 03:49:54 INFO spark.MapOutputTrackerMasterEndpoint: MapOutputTrackerMasterEndpoint stopped!
17/04/10 03:49:54 INFO memory.MemoryStore: MemoryStore cleared
17/04/10 03:49:54 INFO storage.BlockManager: BlockManager stopped
17/04/10 03:49:54 INFO storage.BlockManagerMaster: BlockManagerMaster stopped
17/04/10 03:49:54 INFO scheduler.OutputCommitCoordinator$OutputCommitCoordinatorEndpoint: OutputCommitCoordinator stopped!
17/04/10 03:49:55 INFO spark.SparkContext: Successfully stopped SparkContext
Running org.apache.sysml.test.integration.mlcontext.MLContextTest
Tests run: 175, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 12.61 sec - in org.apache.sysml.test.integration.mlcontext.MLContextTest
17/04/10 03:49:55 INFO util.ShutdownHookManager: Shutdown hook called
17/04/10 03:49:55 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-bda6ee60-0417-49c3-82bc-61ccc4b88554
Running org.apache.sysml.test.integration.functions.quaternary.WeightedSigmoidTest
Tests run: 56, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,004.111 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedSigmoidTest
17/04/10 03:51:38 INFO util.ShutdownHookManager: Shutdown hook called
17/04/10 03:51:38 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-1b068a22-2139-46bd-86b2-6356019e2cd8
Running org.apache.sysml.test.integration.functions.indexing.LeftIndexingTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 637.481 sec - in org.apache.sysml.test.integration.functions.indexing.LeftIndexingTest
Running org.apache.sysml.test.integration.applications.parfor.ParForCorrelationTest
Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 281.002 sec - in org.apache.sysml.test.integration.applications.parfor.ParForCorrelationTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 333.481 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleDenseTest
Running org.apache.sysml.test.integration.functions.reorg.FullOrderTest
Tests run: 132, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,335.808 sec - in org.apache.sysml.test.integration.functions.reorg.FullOrderTest
Running org.apache.sysml.test.integration.applications.parfor.ParForCorrelationTestLarge
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 42.908 sec - in org.apache.sysml.test.integration.applications.parfor.ParForCorrelationTestLarge
Running org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
Tests run: 90, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,495.319 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
17/04/10 03:58:13 INFO util.ShutdownHookManager: Shutdown hook called
17/04/10 03:58:13 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-a81976f3-4151-46b2-b615-6a09bae7a0d7
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 355.123 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,061.554 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: 525.332 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: 276.676 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: 91.965 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,316.203 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: 334.196 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: 50.092 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.919 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: 50.731 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.645 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: 88.387 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: 82.001 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: 11.241 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: 63.552 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: 299.955 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: 8.25 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: 82.151 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.705 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: 299.407 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: 8.632 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: 588.879 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.634 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: 390.261 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: 861.165 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.031 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.42 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: 88.956 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: 14.852 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.829 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.091 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: 64.741 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.989 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: 60.81 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: 60.041 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.428 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: 14.043 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.716 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: 58.106 sec - in org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest

Results :

Failed tests: 
  FullReblockTest.testTextCellSingeMSparseMR:161->runReblockTest:479 27 values are not in equal

Tests run: 6846, 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:25 h
[INFO] Finished at: 2017-04-10T04:57:50-05:00
[INFO] Final Memory: 61M/2205M
[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 [[]]