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/14 11:43:48 UTC

Build failed in Jenkins: SystemML-DailyTest #1110

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

Changes:

[npansar] [HOTFIX] [SYSTEMML-540] Bugfix in validation of convolution operations.

[Nakul Jindal] [MINOR] Performance test bug fixes

[Nakul Jindal] [SYSTEML-1758] added cbind and rbind for GPU

[Nakul Jindal] [SYSTEMML-1713] Added mem estimates for various GPU ops

[Nakul Jindal] [MINOR][DOC] Performance Test Documentation

[Deron Eriksson] [MINOR] Remove unnecessary imports

[Matthias Boehm] [SYSTEMML-1765] Support for reading dml scripts from object stores

[Matthias Boehm] [SYSTEMML-1768] Cleanup properties of systemml-config file

------------------------------------------
[...truncated 28678 lines...]
17/07/14 05:43:39 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 2.0, whose tasks have all completed, from pool default
17/07/14 05:43:39 INFO scheduler.DAGScheduler: ResultStage 2 (collect at SparkExecutionContext.java:789) finished in 0.139 s
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Registering RDD 7 (parallelizePairs at SparkExecutionContext.java:699)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Registering RDD 6 (parallelizePairs at SparkExecutionContext.java:699)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Got job 1 (collect at SparkExecutionContext.java:789) with 1 output partitions
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Final stage: ResultStage 5 (collect at SparkExecutionContext.java:789)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/14 05:43:40 INFO memory.MemoryStore: Block broadcast_3 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/14 05:43:40 INFO memory.MemoryStore: Block broadcast_3_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Added broadcast_3_piece0 in memory on 169.54.146.43:40262 (size: 1305.0 B, free: 1033.8 MB)
17/07/14 05:43:40 INFO spark.SparkContext: Created broadcast 3 from broadcast at DAGScheduler.scala:996
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699)
17/07/14 05:43:40 INFO scheduler.TaskSchedulerImpl: Adding task set 3.0 with 1 tasks
17/07/14 05:43:40 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_3.0 tasks to pool default
17/07/14 05:43:40 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 3.0 (TID 3, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/14 05:43:40 INFO executor.Executor: Running task 0.0 in stage 3.0 (TID 3)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/14 05:43:40 INFO memory.MemoryStore: Block broadcast_4 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/14 05:43:40 INFO memory.MemoryStore: Block broadcast_4_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Added broadcast_4_piece0 in memory on 169.54.146.43:40262 (size: 1305.0 B, free: 1033.8 MB)
17/07/14 05:43:40 INFO spark.SparkContext: Created broadcast 4 from broadcast at DAGScheduler.scala:996
17/07/14 05:43:40 INFO executor.Executor: Finished task 0.0 in stage 3.0 (TID 3). 1253 bytes result sent to driver
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699)
17/07/14 05:43:40 INFO scheduler.TaskSchedulerImpl: Adding task set 4.0 with 1 tasks
17/07/14 05:43:40 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_4.0 tasks to pool default
17/07/14 05:43:40 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 4.0 (TID 4, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/14 05:43:40 INFO executor.Executor: Running task 0.0 in stage 4.0 (TID 4)
17/07/14 05:43:40 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 3.0 (TID 3) in 28 ms on localhost (executor driver) (1/1)
17/07/14 05:43:40 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 3.0, whose tasks have all completed, from pool default
17/07/14 05:43:40 INFO scheduler.DAGScheduler: ShuffleMapStage 3 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.027 s
17/07/14 05:43:40 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/14 05:43:40 INFO scheduler.DAGScheduler: running: Set(ShuffleMapStage 4)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: failed: Set()
17/07/14 05:43:40 INFO executor.Executor: Finished task 0.0 in stage 4.0 (TID 4). 1253 bytes result sent to driver
17/07/14 05:43:40 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 4.0 (TID 4) in 15 ms on localhost (executor driver) (1/1)
17/07/14 05:43:40 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 4.0, whose tasks have all completed, from pool default
17/07/14 05:43:40 INFO scheduler.DAGScheduler: ShuffleMapStage 4 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.017 s
17/07/14 05:43:40 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/14 05:43:40 INFO scheduler.DAGScheduler: running: Set()
17/07/14 05:43:40 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/14 05:43:40 INFO scheduler.DAGScheduler: failed: Set()
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Submitting ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117), which has no missing parents
17/07/14 05:43:40 INFO memory.MemoryStore: Block broadcast_5 stored as values in memory (estimated size 4.2 KB, free 1033.8 MB)
17/07/14 05:43:40 INFO memory.MemoryStore: Block broadcast_5_piece0 stored as bytes in memory (estimated size 2.3 KB, free 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Added broadcast_5_piece0 in memory on 169.54.146.43:40262 (size: 2.3 KB, free: 1033.8 MB)
17/07/14 05:43:40 INFO spark.SparkContext: Created broadcast 5 from broadcast at DAGScheduler.scala:996
17/07/14 05:43:40 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117)
17/07/14 05:43:40 INFO scheduler.TaskSchedulerImpl: Adding task set 5.0 with 1 tasks
17/07/14 05:43:40 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_5.0 tasks to pool default
17/07/14 05:43:40 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 5.0 (TID 5, localhost, executor driver, partition 0, PROCESS_LOCAL, 5814 bytes)
17/07/14 05:43:40 INFO executor.Executor: Running task 0.0 in stage 5.0 (TID 5)
17/07/14 05:43:40 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/14 05:43:40 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/07/14 05:43:40 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/14 05:43:40 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 4 ms
17/07/14 05:43:40 INFO executor.Executor: Finished task 0.0 in stage 5.0 (TID 5). 2240 bytes result sent to driver
17/07/14 05:43:40 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 5.0 (TID 5) in 18 ms on localhost (executor driver) (1/1)
17/07/14 05:43:40 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 5.0, whose tasks have all completed, from pool default
17/07/14 05:43:40 INFO scheduler.DAGScheduler: ResultStage 5 (collect at SparkExecutionContext.java:789) finished in 0.020 s
17/07/14 05:43:40 INFO spark.ContextCleaner: Cleaned shuffle 3
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Removed broadcast_3_piece0 on 169.54.146.43:40262 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Removed broadcast_4_piece0 on 169.54.146.43:40262 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Removed broadcast_5_piece0 on 169.54.146.43:40262 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Removed broadcast_1_piece0 on 169.54.146.43:40262 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Removed broadcast_2_piece0 on 169.54.146.43:40262 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/14 05:43:40 INFO spark.ContextCleaner: Cleaned shuffle 2
17/07/14 05:43:40 INFO storage.BlockManagerInfo: Removed broadcast_0_piece0 on 169.54.146.43:40262 in memory (size: 1302.0 B, free: 1033.8 MB)
17/07/14 05:43:40 INFO spark.ContextCleaner: Cleaned shuffle 0
17/07/14 05:43:40 INFO spark.ContextCleaner: Cleaned shuffle 1
17/07/14 05:45:27 INFO server.ServerConnector: Stopped ServerConnector@7b88467b{HTTP/1.1}{0.0.0.0:4040}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@76932e1b{/stages/stage/kill,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7d06b2fe{/jobs/job/kill,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@72b5e1e4{/api,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@b0ed694{/,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@9f05dd8{/static,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2775092d{/executors/threadDump/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7721cc75{/executors/threadDump,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@44c8d684{/executors/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@974fbe0{/executors,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@abb47e3{/environment/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@491f58b0{/environment,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@225df587{/storage/rdd/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@d81d9a5{/storage/rdd,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3c2fe911{/storage/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1caef0ec{/storage,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@26812e5c{/stages/pool/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6e1bf089{/stages/pool,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7d3ba353{/stages/stage/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7fa8b7af{/stages/stage,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3d1ea987{/stages/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@684f7f92{/stages,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2e059283{/jobs/job/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3c1fdd66{/jobs/job,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@233ed753{/jobs/json,null,UNAVAILABLE}
17/07/14 05:45:27 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@8e9ccb5{/jobs,null,UNAVAILABLE}
17/07/14 05:45:27 INFO ui.SparkUI: Stopped Spark web UI at http://169.54.146.43:4040
17/07/14 05:45:27 INFO spark.MapOutputTrackerMasterEndpoint: MapOutputTrackerMasterEndpoint stopped!
17/07/14 05:45:27 INFO memory.MemoryStore: MemoryStore cleared
17/07/14 05:45:27 INFO storage.BlockManager: BlockManager stopped
17/07/14 05:45:27 INFO storage.BlockManagerMaster: BlockManagerMaster stopped
17/07/14 05:45:27 INFO scheduler.OutputCommitCoordinator$OutputCommitCoordinatorEndpoint: OutputCommitCoordinator stopped!
17/07/14 05:45:27 INFO spark.SparkContext: Successfully stopped SparkContext
Running org.apache.sysml.test.integration.scripts.nn.NNTest
Tests run: 1, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 658.46 sec <<< FAILURE! - in org.apache.sysml.test.integration.scripts.nn.NNTest
testNNLibrary(org.apache.sysml.test.integration.scripts.nn.NNTest)  Time elapsed: 658.46 sec  <<< ERROR!
org.apache.sysml.api.mlcontext.MLContextException: Exception when executing script
	at org.apache.sysml.runtime.matrix.data.MatrixBlock.sliceOperations(MatrixBlock.java:3794)
	at org.apache.sysml.runtime.matrix.data.MatrixBlock.sliceOperations(MatrixBlock.java:3770)
	at org.apache.sysml.runtime.instructions.cp.MatrixIndexingCPInstruction.processInstruction(MatrixIndexingCPInstruction.java:65)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeSingleInstruction(ProgramBlock.java:286)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeInstructions(ProgramBlock.java:217)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.execute(ProgramBlock.java:163)
	at org.apache.sysml.runtime.controlprogram.ForProgramBlock.execute(ForProgramBlock.java:145)
	at org.apache.sysml.runtime.controlprogram.ForProgramBlock.execute(ForProgramBlock.java:145)
	at org.apache.sysml.runtime.controlprogram.FunctionProgramBlock.execute(FunctionProgramBlock.java:115)
	at org.apache.sysml.runtime.instructions.cp.FunctionCallCPInstruction.processInstruction(FunctionCallCPInstruction.java:180)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeSingleInstruction(ProgramBlock.java:286)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeInstructions(ProgramBlock.java:217)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.execute(ProgramBlock.java:163)
	at org.apache.sysml.runtime.controlprogram.Program.execute(Program.java:123)
	at org.apache.sysml.api.ScriptExecutorUtils.executeRuntimeProgram(ScriptExecutorUtils.java:95)
	at org.apache.sysml.api.ScriptExecutorUtils.executeRuntimeProgram(ScriptExecutorUtils.java:54)
	at org.apache.sysml.api.mlcontext.ScriptExecutor.executeRuntimeProgram(ScriptExecutor.java:395)
	at org.apache.sysml.api.mlcontext.ScriptExecutor.execute(ScriptExecutor.java:311)
	at org.apache.sysml.api.mlcontext.MLContext.execute(MLContext.java:316)
	at org.apache.sysml.api.mlcontext.MLContext.execute(MLContext.java:293)
	at org.apache.sysml.test.integration.scripts.nn.NNTest.testNNLibrary(NNTest.java:62)

17/07/14 05:45:27 INFO util.ShutdownHookManager: Shutdown hook called
17/07/14 05:45:27 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-be0fa768-37a0-4c57-bc02-7978c10e01c4
Running org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
Tests run: 90, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,468.371 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
17/07/14 05:45:41 INFO util.ShutdownHookManager: Shutdown hook called
17/07/14 05:45:41 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-f77fcd20-393c-4259-994c-683c489b0fa7
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 362.593 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,075.088 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: 530.467 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: 103.365 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.545 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: 272.325 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: 92.412 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,480.955 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.093 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.315 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.716 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.498 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.654 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: 84.062 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.593 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: 15.706 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.364 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.022 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.143 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.805 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.914 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: 295.107 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.131 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.576 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: 87.988 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: 399.235 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: 853.5 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.054 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.362 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.299 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: 15.184 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.798 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.268 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.425 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.305 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.846 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: 65.757 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.38 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: 17.495 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.516 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: 55.453 sec - in org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest

Results :

Tests in error: 
  NNTest.testNNLibrary:62 » MLContext Exception when executing script

Tests run: 7201, Failures: 0, Errors: 1, 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-14T06:43:47-05:00
[INFO] Final Memory: 63M/2984M
[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 #1112

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


Build failed in Jenkins: SystemML-DailyTest #1111

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

Changes:

[Deron Eriksson] [SYSTEMML-1419] Cleanup nested if-elses in GLM and GLM-predict

------------------------------------------
[...truncated 28646 lines...]
17/07/14 16:04:17 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/14 16:04:17 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 1 ms
17/07/14 16:04:17 INFO executor.Executor: Finished task 0.0 in stage 2.0 (TID 2). 2077 bytes result sent to driver
17/07/14 16:04:17 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 2.0 (TID 2) in 113 ms on localhost (executor driver) (1/1)
17/07/14 16:04:17 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 2.0, whose tasks have all completed, from pool default
17/07/14 16:04:17 INFO scheduler.DAGScheduler: ResultStage 2 (collect at SparkExecutionContext.java:789) finished in 0.115 s
17/07/14 16:04:18 INFO storage.BlockManagerInfo: Removed broadcast_2_piece0 on 169.54.146.43:53348 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Registering RDD 7 (parallelizePairs at SparkExecutionContext.java:699)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Registering RDD 6 (parallelizePairs at SparkExecutionContext.java:699)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Got job 1 (collect at SparkExecutionContext.java:789) with 1 output partitions
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Final stage: ResultStage 5 (collect at SparkExecutionContext.java:789)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 3, ShuffleMapStage 4)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/14 16:04:18 INFO memory.MemoryStore: Block broadcast_3 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/14 16:04:18 INFO memory.MemoryStore: Block broadcast_3_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/14 16:04:18 INFO storage.BlockManagerInfo: Added broadcast_3_piece0 in memory on 169.54.146.43:53348 (size: 1305.0 B, free: 1033.8 MB)
17/07/14 16:04:18 INFO spark.SparkContext: Created broadcast 3 from broadcast at DAGScheduler.scala:996
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 3 (ParallelCollectionRDD[7] at parallelizePairs at SparkExecutionContext.java:699)
17/07/14 16:04:18 INFO scheduler.TaskSchedulerImpl: Adding task set 3.0 with 1 tasks
17/07/14 16:04:18 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_3.0 tasks to pool default
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699), which has no missing parents
17/07/14 16:04:18 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 3.0 (TID 3, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/14 16:04:18 INFO executor.Executor: Running task 0.0 in stage 3.0 (TID 3)
17/07/14 16:04:18 INFO memory.MemoryStore: Block broadcast_4 stored as values in memory (estimated size 2032.0 B, free 1033.8 MB)
17/07/14 16:04:18 INFO executor.Executor: Finished task 0.0 in stage 3.0 (TID 3). 1253 bytes result sent to driver
17/07/14 16:04:18 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 3.0 (TID 3) in 18 ms on localhost (executor driver) (1/1)
17/07/14 16:04:18 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 3.0, whose tasks have all completed, from pool default
17/07/14 16:04:18 INFO memory.MemoryStore: Block broadcast_4_piece0 stored as bytes in memory (estimated size 1305.0 B, free 1033.8 MB)
17/07/14 16:04:18 INFO storage.BlockManagerInfo: Added broadcast_4_piece0 in memory on 169.54.146.43:53348 (size: 1305.0 B, free: 1033.8 MB)
17/07/14 16:04:18 INFO spark.SparkContext: Created broadcast 4 from broadcast at DAGScheduler.scala:996
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 4 (ParallelCollectionRDD[6] at parallelizePairs at SparkExecutionContext.java:699)
17/07/14 16:04:18 INFO scheduler.TaskSchedulerImpl: Adding task set 4.0 with 1 tasks
17/07/14 16:04:18 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_4.0 tasks to pool default
17/07/14 16:04:18 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 4.0 (TID 4, localhost, executor driver, partition 0, PROCESS_LOCAL, 6445 bytes)
17/07/14 16:04:18 INFO executor.Executor: Running task 0.0 in stage 4.0 (TID 4)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: ShuffleMapStage 3 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.032 s
17/07/14 16:04:18 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/14 16:04:18 INFO scheduler.DAGScheduler: running: Set(ShuffleMapStage 4)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: failed: Set()
17/07/14 16:04:18 INFO executor.Executor: Finished task 0.0 in stage 4.0 (TID 4). 1253 bytes result sent to driver
17/07/14 16:04:18 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 4.0 (TID 4) in 12 ms on localhost (executor driver) (1/1)
17/07/14 16:04:18 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 4.0, whose tasks have all completed, from pool default
17/07/14 16:04:18 INFO scheduler.DAGScheduler: ShuffleMapStage 4 (parallelizePairs at SparkExecutionContext.java:699) finished in 0.012 s
17/07/14 16:04:18 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/07/14 16:04:18 INFO scheduler.DAGScheduler: running: Set()
17/07/14 16:04:18 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 5)
17/07/14 16:04:18 INFO scheduler.DAGScheduler: failed: Set()
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Submitting ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117), which has no missing parents
17/07/14 16:04:18 INFO memory.MemoryStore: Block broadcast_5 stored as values in memory (estimated size 4.2 KB, free 1033.8 MB)
17/07/14 16:04:18 INFO memory.MemoryStore: Block broadcast_5_piece0 stored as bytes in memory (estimated size 2.3 KB, free 1033.8 MB)
17/07/14 16:04:18 INFO storage.BlockManagerInfo: Added broadcast_5_piece0 in memory on 169.54.146.43:53348 (size: 2.3 KB, free: 1033.8 MB)
17/07/14 16:04:18 INFO spark.SparkContext: Created broadcast 5 from broadcast at DAGScheduler.scala:996
17/07/14 16:04:18 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 5 (MapPartitionsRDD[11] at mapValues at BinarySPInstruction.java:117)
17/07/14 16:04:18 INFO scheduler.TaskSchedulerImpl: Adding task set 5.0 with 1 tasks
17/07/14 16:04:18 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_5.0 tasks to pool default
17/07/14 16:04:18 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 5.0 (TID 5, localhost, executor driver, partition 0, PROCESS_LOCAL, 5814 bytes)
17/07/14 16:04:18 INFO executor.Executor: Running task 0.0 in stage 5.0 (TID 5)
17/07/14 16:04:18 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/14 16:04:18 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 1 ms
17/07/14 16:04:18 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/07/14 16:04:18 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/07/14 16:04:18 INFO executor.Executor: Finished task 0.0 in stage 5.0 (TID 5). 2240 bytes result sent to driver
17/07/14 16:04:18 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 5.0 (TID 5) in 15 ms on localhost (executor driver) (1/1)
17/07/14 16:04:18 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 5.0, whose tasks have all completed, from pool default
17/07/14 16:04:18 INFO scheduler.DAGScheduler: ResultStage 5 (collect at SparkExecutionContext.java:789) finished in 0.024 s
17/07/14 16:04:19 INFO storage.BlockManagerInfo: Removed broadcast_3_piece0 on 169.54.146.43:53348 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/14 16:04:19 INFO storage.BlockManagerInfo: Removed broadcast_5_piece0 on 169.54.146.43:53348 in memory (size: 2.3 KB, free: 1033.8 MB)
17/07/14 16:04:19 INFO storage.BlockManagerInfo: Removed broadcast_4_piece0 on 169.54.146.43:53348 in memory (size: 1305.0 B, free: 1033.8 MB)
17/07/14 16:04:19 INFO spark.ContextCleaner: Cleaned shuffle 2
17/07/14 16:04:19 INFO spark.ContextCleaner: Cleaned shuffle 3
17/07/14 16:06:13 INFO server.ServerConnector: Stopped ServerConnector@164eeab8{HTTP/1.1}{0.0.0.0:4040}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@71f32751{/stages/stage/kill,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@74116685{/jobs/job/kill,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@57769ec4{/api,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3fb7ebed{/,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@72058fe{/static,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@20b06e89{/executors/threadDump/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@63f16b14{/executors/threadDump,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@5e0cc46b{/executors/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6298a5e4{/executors,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@9595b78{/environment/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@ce624ca{/environment,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@38409d09{/storage/rdd/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@6501c562{/storage/rdd,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@691d94ea{/storage/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1c3514e7{/storage,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3f9c4013{/stages/pool/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3337e4f7{/stages/pool,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@a6fe645{/stages/stage/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2640a95e{/stages/stage,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@754f2d17{/stages/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@31b10a1d{/stages,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3083800b{/jobs/job/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3cedf626{/jobs/job,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@5d232327{/jobs/json,null,UNAVAILABLE}
17/07/14 16:06:13 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@528a6729{/jobs,null,UNAVAILABLE}
17/07/14 16:06:13 INFO ui.SparkUI: Stopped Spark web UI at http://169.54.146.43:4040
17/07/14 16:06:13 INFO spark.MapOutputTrackerMasterEndpoint: MapOutputTrackerMasterEndpoint stopped!
17/07/14 16:06:13 INFO memory.MemoryStore: MemoryStore cleared
17/07/14 16:06:13 INFO storage.BlockManager: BlockManager stopped
17/07/14 16:06:13 INFO storage.BlockManagerMaster: BlockManagerMaster stopped
17/07/14 16:06:13 INFO scheduler.OutputCommitCoordinator$OutputCommitCoordinatorEndpoint: OutputCommitCoordinator stopped!
17/07/14 16:06:13 INFO spark.SparkContext: Successfully stopped SparkContext
Running org.apache.sysml.test.integration.scripts.nn.NNTest
Tests run: 1, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 664.813 sec <<< FAILURE! - in org.apache.sysml.test.integration.scripts.nn.NNTest
testNNLibrary(org.apache.sysml.test.integration.scripts.nn.NNTest)  Time elapsed: 664.813 sec  <<< ERROR!
org.apache.sysml.api.mlcontext.MLContextException: Exception when executing script
	at org.apache.sysml.runtime.matrix.data.MatrixBlock.sliceOperations(MatrixBlock.java:3794)
	at org.apache.sysml.runtime.matrix.data.MatrixBlock.sliceOperations(MatrixBlock.java:3770)
	at org.apache.sysml.runtime.instructions.cp.MatrixIndexingCPInstruction.processInstruction(MatrixIndexingCPInstruction.java:65)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeSingleInstruction(ProgramBlock.java:286)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeInstructions(ProgramBlock.java:217)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.execute(ProgramBlock.java:163)
	at org.apache.sysml.runtime.controlprogram.ForProgramBlock.execute(ForProgramBlock.java:145)
	at org.apache.sysml.runtime.controlprogram.ForProgramBlock.execute(ForProgramBlock.java:145)
	at org.apache.sysml.runtime.controlprogram.FunctionProgramBlock.execute(FunctionProgramBlock.java:115)
	at org.apache.sysml.runtime.instructions.cp.FunctionCallCPInstruction.processInstruction(FunctionCallCPInstruction.java:180)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeSingleInstruction(ProgramBlock.java:286)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.executeInstructions(ProgramBlock.java:217)
	at org.apache.sysml.runtime.controlprogram.ProgramBlock.execute(ProgramBlock.java:163)
	at org.apache.sysml.runtime.controlprogram.Program.execute(Program.java:123)
	at org.apache.sysml.api.ScriptExecutorUtils.executeRuntimeProgram(ScriptExecutorUtils.java:95)
	at org.apache.sysml.api.ScriptExecutorUtils.executeRuntimeProgram(ScriptExecutorUtils.java:54)
	at org.apache.sysml.api.mlcontext.ScriptExecutor.executeRuntimeProgram(ScriptExecutor.java:395)
	at org.apache.sysml.api.mlcontext.ScriptExecutor.execute(ScriptExecutor.java:311)
	at org.apache.sysml.api.mlcontext.MLContext.execute(MLContext.java:316)
	at org.apache.sysml.api.mlcontext.MLContext.execute(MLContext.java:293)
	at org.apache.sysml.test.integration.scripts.nn.NNTest.testNNLibrary(NNTest.java:62)

17/07/14 16:06:13 INFO util.ShutdownHookManager: Shutdown hook called
17/07/14 16:06:13 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-1714ff25-2c2a-4c0b-b623-429c54c887fa
Running org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
Tests run: 90, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,477.779 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
17/07/14 16:06:21 INFO util.ShutdownHookManager: Shutdown hook called
17/07/14 16:06:21 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-a20067d2-2635-4dd1-8870-0bd8d778e61f
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 354.965 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Running org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Tests run: 10, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 526.696 sec - in org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Running org.apache.sysml.test.integration.functions.append.AppendChainTest
Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,079.313 sec - in org.apache.sysml.test.integration.functions.append.AppendChainTest
Running org.apache.sysml.test.integration.applications.parfor.ParForSampleTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 104.448 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.895 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: 281.472 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.049 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,491.933 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: 350.442 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.886 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.484 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.912 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.616 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: 82.692 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.304 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: 16.817 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.549 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.982 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.131 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.726 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.748 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: 297.669 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.19 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.379 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: 87.445 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: 397.314 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: 869.747 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.036 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.383 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.311 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.721 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.922 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.78 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.279 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.315 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.1 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: 58.655 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.384 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: 16.476 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: 383.613 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.312 sec - in org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest

Results :

Tests in error: 
  NNTest.testNNLibrary:62 » MLContext Exception when executing script

Tests run: 7201, Failures: 0, Errors: 1, 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-14T17:04:34-05:00
[INFO] Final Memory: 63M/2776M
[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 [[]]