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/01/25 00:12:00 UTC

Build failed in Jenkins: SystemML-DailyTest #769

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

Changes:

[Luciano Resende] [MINOR] prompt for PGP passphrase if not exported

[Glenn Weidner] [SYSTEMML-1110] Run functions.data tests as suite

------------------------------------------
[...truncated 9488 lines...]
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Got job 180 (collectAsList at MLContextTest.java:1337) with 1 output partitions
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Final stage: ResultStage 243 (collectAsList at MLContextTest.java:1337)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 242)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 242)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 242 (MapPartitionsRDD[663] at flatMapToPair at RDDConverterUtils.java:273), which has no missing parents
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_242 stored as values in memory (estimated size 3.9 KB, free 1045.5 MB)
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_242_piece0 stored as bytes in memory (estimated size 2.2 KB, free 1045.5 MB)
17/01/24 16:21:55 INFO storage.BlockManagerInfo: Added broadcast_242_piece0 in memory on localhost:52271 (size: 2.2 KB, free: 1045.8 MB)
17/01/24 16:21:55 INFO spark.SparkContext: Created broadcast 242 from broadcast at DAGScheduler.scala:1012
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 242 (MapPartitionsRDD[663] at flatMapToPair at RDDConverterUtils.java:273)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Adding task set 242.0 with 1 tasks
17/01/24 16:21:55 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_242 tasks to pool default
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 242.0 (TID 252, localhost, partition 0, PROCESS_LOCAL, 5637 bytes)
17/01/24 16:21:55 INFO executor.Executor: Running task 0.0 in stage 242.0 (TID 252)
17/01/24 16:21:55 INFO executor.Executor: Finished task 0.0 in stage 242.0 (TID 252). 1079 bytes result sent to driver
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 242.0 (TID 252) in 4 ms on localhost (1/1)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 242.0, whose tasks have all completed, from pool default
17/01/24 16:21:55 INFO scheduler.DAGScheduler: ShuffleMapStage 242 (flatMapToPair at RDDConverterUtils.java:273) finished in 0.005 s
17/01/24 16:21:55 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/01/24 16:21:55 INFO scheduler.DAGScheduler: running: Set()
17/01/24 16:21:55 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 243)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: failed: Set()
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting ResultStage 243 (MapPartitionsRDD[669] at collectAsList at MLContextTest.java:1337), which has no missing parents
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_243 stored as values in memory (estimated size 10.5 KB, free 1045.4 MB)
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_243_piece0 stored as bytes in memory (estimated size 5.3 KB, free 1045.4 MB)
17/01/24 16:21:55 INFO storage.BlockManagerInfo: Added broadcast_243_piece0 in memory on localhost:52271 (size: 5.3 KB, free: 1045.8 MB)
17/01/24 16:21:55 INFO spark.SparkContext: Created broadcast 243 from broadcast at DAGScheduler.scala:1012
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 243 (MapPartitionsRDD[669] at collectAsList at MLContextTest.java:1337)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Adding task set 243.0 with 1 tasks
17/01/24 16:21:55 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_243 tasks to pool default
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 243.0 (TID 253, localhost, partition 0, NODE_LOCAL, 5202 bytes)
17/01/24 16:21:55 INFO executor.Executor: Running task 0.0 in stage 243.0 (TID 253)
17/01/24 16:21:55 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/01/24 16:21:55 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/01/24 16:21:55 INFO executor.Executor: Finished task 0.0 in stage 243.0 (TID 253). 1855 bytes result sent to driver
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 243.0 (TID 253) in 7 ms on localhost (1/1)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 243.0, whose tasks have all completed, from pool default
17/01/24 16:21:55 INFO scheduler.DAGScheduler: ResultStage 243 (collectAsList at MLContextTest.java:1337) finished in 0.007 s
17/01/24 16:21:55 INFO storage.BlockManagerInfo: Removed broadcast_243_piece0 on localhost:52271 in memory (size: 5.3 KB, free: 1045.8 MB)
17/01/24 16:21:55 INFO storage.BlockManagerInfo: Removed broadcast_242_piece0 on localhost:52271 in memory (size: 2.2 KB, free: 1045.8 MB)
17/01/24 16:21:55 INFO spark.ContextCleaner: Cleaned accumulator 14817
17/01/24 16:21:55 INFO spark.ContextCleaner: Cleaned shuffle 62
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Registering RDD 671 (flatMapToPair at RDDConverterUtils.java:273)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Got job 181 (collectAsList at MLContextTest.java:1225) with 1 output partitions
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Final stage: ResultStage 245 (collectAsList at MLContextTest.java:1225)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Parents of final stage: List(ShuffleMapStage 244)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Missing parents: List(ShuffleMapStage 244)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting ShuffleMapStage 244 (MapPartitionsRDD[671] at flatMapToPair at RDDConverterUtils.java:273), which has no missing parents
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_244 stored as values in memory (estimated size 3.9 KB, free 1045.5 MB)
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_244_piece0 stored as bytes in memory (estimated size 2.2 KB, free 1045.5 MB)
17/01/24 16:21:55 INFO storage.BlockManagerInfo: Added broadcast_244_piece0 in memory on localhost:52271 (size: 2.2 KB, free: 1045.8 MB)
17/01/24 16:21:55 INFO spark.SparkContext: Created broadcast 244 from broadcast at DAGScheduler.scala:1012
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ShuffleMapStage 244 (MapPartitionsRDD[671] at flatMapToPair at RDDConverterUtils.java:273)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Adding task set 244.0 with 1 tasks
17/01/24 16:21:55 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_244 tasks to pool default
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 244.0 (TID 254, localhost, partition 0, PROCESS_LOCAL, 5637 bytes)
17/01/24 16:21:55 INFO executor.Executor: Running task 0.0 in stage 244.0 (TID 254)
17/01/24 16:21:55 INFO executor.Executor: Finished task 0.0 in stage 244.0 (TID 254). 1079 bytes result sent to driver
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 244.0 (TID 254) in 5 ms on localhost (1/1)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 244.0, whose tasks have all completed, from pool default
17/01/24 16:21:55 INFO scheduler.DAGScheduler: ShuffleMapStage 244 (flatMapToPair at RDDConverterUtils.java:273) finished in 0.001 s
17/01/24 16:21:55 INFO scheduler.DAGScheduler: looking for newly runnable stages
17/01/24 16:21:55 INFO scheduler.DAGScheduler: running: Set()
17/01/24 16:21:55 INFO scheduler.DAGScheduler: waiting: Set(ResultStage 245)
17/01/24 16:21:55 INFO scheduler.DAGScheduler: failed: Set()
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting ResultStage 245 (MapPartitionsRDD[677] at collectAsList at MLContextTest.java:1225), which has no missing parents
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_245 stored as values in memory (estimated size 10.5 KB, free 1045.4 MB)
17/01/24 16:21:55 INFO memory.MemoryStore: Block broadcast_245_piece0 stored as bytes in memory (estimated size 5.3 KB, free 1045.4 MB)
17/01/24 16:21:55 INFO storage.BlockManagerInfo: Added broadcast_245_piece0 in memory on localhost:52271 (size: 5.3 KB, free: 1045.8 MB)
17/01/24 16:21:55 INFO spark.SparkContext: Created broadcast 245 from broadcast at DAGScheduler.scala:1012
17/01/24 16:21:55 INFO scheduler.DAGScheduler: Submitting 1 missing tasks from ResultStage 245 (MapPartitionsRDD[677] at collectAsList at MLContextTest.java:1225)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Adding task set 245.0 with 1 tasks
17/01/24 16:21:55 INFO scheduler.FairSchedulableBuilder: Added task set TaskSet_245 tasks to pool default
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Starting task 0.0 in stage 245.0 (TID 255, localhost, partition 0, NODE_LOCAL, 5202 bytes)
17/01/24 16:21:55 INFO executor.Executor: Running task 0.0 in stage 245.0 (TID 255)
17/01/24 16:21:55 INFO storage.ShuffleBlockFetcherIterator: Getting 1 non-empty blocks out of 1 blocks
17/01/24 16:21:55 INFO storage.ShuffleBlockFetcherIterator: Started 0 remote fetches in 0 ms
17/01/24 16:21:55 INFO executor.Executor: Finished task 0.0 in stage 245.0 (TID 255). 1855 bytes result sent to driver
17/01/24 16:21:55 INFO scheduler.TaskSetManager: Finished task 0.0 in stage 245.0 (TID 255) in 8 ms on localhost (1/1)
17/01/24 16:21:55 INFO scheduler.TaskSchedulerImpl: Removed TaskSet 245.0, whose tasks have all completed, from pool default
17/01/24 16:21:55 INFO scheduler.DAGScheduler: ResultStage 245 (collectAsList at MLContextTest.java:1225) finished in 0.001 s
17/01/24 16:21:56 INFO storage.BlockManagerInfo: Removed broadcast_245_piece0 on localhost:52271 in memory (size: 5.3 KB, free: 1045.8 MB)
17/01/24 16:21:56 INFO storage.BlockManagerInfo: Removed broadcast_244_piece0 on localhost:52271 in memory (size: 2.2 KB, free: 1045.8 MB)
17/01/24 16:21:56 INFO spark.ContextCleaner: Cleaned accumulator 14906
17/01/24 16:21:56 INFO spark.ContextCleaner: Cleaned shuffle 63
17/01/24 16:21:57 INFO server.ServerConnector: Stopped ServerConnector@57aca973{HTTP/1.1}{0.0.0.0:4040}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@64cc8e9d{/stages/stage/kill,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@75441b4c{/api,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@2e86e4c7{/,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@4ade263f{/static,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@674ecaeb{/executors/threadDump/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7a0423b8{/executors/threadDump,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@56865754{/executors/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3f524df0{/executors,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@4cda31b2{/environment/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@45ad306c{/environment,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3f3ad0ee{/storage/rdd/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1a4d26c7{/storage/rdd,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@3946070c{/storage/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@dfee27f{/storage,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@452c0fd7{/stages/pool/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@7c9be66d{/stages/pool,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@5ecd5834{/stages/stage/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@63656ff2{/stages/stage,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@5a8c6041{/stages/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@743ad9d1{/stages,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@15651e14{/jobs/job/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@1675e4b6{/jobs/job,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@21e1ef38{/jobs/json,null,UNAVAILABLE}
17/01/24 16:21:57 INFO handler.ContextHandler: Stopped o.s.j.s.ServletContextHandler@72626b92{/jobs,null,UNAVAILABLE}
17/01/24 16:21:57 INFO ui.SparkUI: Stopped Spark web UI at http://localhost:4040
17/01/24 16:21:57 INFO spark.MapOutputTrackerMasterEndpoint: MapOutputTrackerMasterEndpoint stopped!
17/01/24 16:21:57 INFO memory.MemoryStore: MemoryStore cleared
17/01/24 16:21:57 INFO storage.BlockManager: BlockManager stopped
17/01/24 16:21:57 INFO storage.BlockManagerMaster: BlockManagerMaster stopped
17/01/24 16:21:57 INFO scheduler.OutputCommitCoordinator$OutputCommitCoordinatorEndpoint: OutputCommitCoordinator stopped!
17/01/24 16:21:57 INFO spark.SparkContext: Successfully stopped SparkContext
Running org.apache.sysml.test.integration.mlcontext.MLContextTest
Tests run: 161, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 53.138 sec - in org.apache.sysml.test.integration.mlcontext.MLContextTest
17/01/24 16:21:57 INFO util.ShutdownHookManager: Shutdown hook called
17/01/24 16:21:57 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-cb04b3c1-2b9a-4296-8313-29c66363888c
Running org.apache.sysml.test.integration.applications.dml.ArimaDMLTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 188.45 sec - in org.apache.sysml.test.integration.applications.dml.ArimaDMLTest
Running org.apache.sysml.test.integration.functions.quaternary.WeightedSigmoidTest
Tests run: 56, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,017.588 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedSigmoidTest
17/01/24 16:23:37 INFO util.ShutdownHookManager: Shutdown hook called
17/01/24 16:23:37 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-0b36c56c-bb30-4a13-ad0f-44aeeeb006b7
Running org.apache.sysml.test.integration.functions.indexing.LeftIndexingTest
Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 678.207 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: 266.954 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: 315.501 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,393.149 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: 47.103 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,527.347 sec - in org.apache.sysml.test.integration.functions.quaternary.WeightedDivMatrixMultTest
17/01/24 16:30:20 INFO util.ShutdownHookManager: Shutdown hook called
17/01/24 16:30:20 INFO util.ShutdownHookManager: Deleting directory /tmp/spark-a4364609-5b0d-43bf-9458-97d775731d30
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleDenseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 359.185 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,086.134 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: 553.184 sec - in org.apache.sysml.test.integration.applications.parfor.ParForNaiveBayesTest
Running org.apache.sysml.test.integration.functions.append.AppendMatrixTest
Tests run: 22, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,174.419 sec - in org.apache.sysml.test.integration.functions.append.AppendMatrixTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleSparseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 273.542 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateUnweightedScaleSparseTest
Running org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleSparseTest
Tests run: 24, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 337.939 sec - in org.apache.sysml.test.integration.applications.descriptivestats.UnivariateWeightedScaleSparseTest
Running org.apache.sysml.test.integration.applications.dml.HITSDMLTest
Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 155.494 sec - in org.apache.sysml.test.integration.applications.dml.HITSDMLTest
Running org.apache.sysml.test.integration.applications.pydml.ArimaPyDMLTest
Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 48.473 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.213 sec - in org.apache.sysml.test.integration.applications.pydml.HITSPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.LinearRegressionDMLTest
Tests run: 14, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 102.319 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.791 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: 152.094 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: 191.755 sec - in org.apache.sysml.test.integration.applications.pydml.NaiveBayesPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.CsplineCGDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 25.132 sec - in org.apache.sysml.test.integration.applications.dml.CsplineCGDMLTest
Running org.apache.sysml.test.integration.applications.dml.L2SVMDMLTest
Tests run: 18, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 127.198 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: 559.886 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: 16.286 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: 198.966 sec - in org.apache.sysml.test.integration.applications.pydml.NaiveBayesParforPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.NaiveBayesDMLTest
Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 165.024 sec - in org.apache.sysml.test.integration.applications.dml.NaiveBayesDMLTest
Running org.apache.sysml.test.integration.applications.dml.MDABivariateStatsDMLTest
Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 608.799 sec - in org.apache.sysml.test.integration.applications.dml.MDABivariateStatsDMLTest
Running org.apache.sysml.test.integration.applications.dml.PageRankDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 12.067 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: 586.483 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: 196.782 sec - in org.apache.sysml.test.integration.applications.pydml.MultiClassSVMPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.ID3DMLTest
Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 660.616 sec - in org.apache.sysml.test.integration.applications.dml.ID3DMLTest
Running org.apache.sysml.test.integration.applications.dml.GLMDMLTest
Tests run: 60, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1,449.948 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.194 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: 17.651 sec - in org.apache.sysml.test.integration.applications.pydml.WelchTPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.MultiClassSVMDMLTest
Tests run: 18, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 177.425 sec - in org.apache.sysml.test.integration.applications.dml.MultiClassSVMDMLTest
Running org.apache.sysml.test.integration.applications.dml.CsplineDSDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 27.613 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: 1.361 sec - in org.apache.sysml.test.integration.applications.pydml.ApplyTransformPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.NaiveBayesParforDMLTest
Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 162.453 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: 73.778 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: 107.905 sec - in org.apache.sysml.test.integration.applications.pydml.LinearRegressionPyDMLTest
Running org.apache.sysml.test.integration.applications.dml.LinearLogRegDMLTest
Tests run: 14, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 122.982 sec - in org.apache.sysml.test.integration.applications.dml.LinearLogRegDMLTest
Running org.apache.sysml.test.integration.applications.dml.GNMFDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 114.058 sec - in org.apache.sysml.test.integration.applications.dml.GNMFDMLTest
Running org.apache.sysml.test.integration.applications.dml.WelchTDMLTest
Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 12.889 sec - in org.apache.sysml.test.integration.applications.dml.WelchTDMLTest
Running org.apache.sysml.test.integration.applications.dml.ApplyTransformDMLTest
Tests run: 14, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 19.666 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: 331.817 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.012 sec - in org.apache.sysml.test.integration.applications.pydml.GNMFPyDMLTest

Results :

Failed tests: 
  FrameMatrixReblockTest.testFrameWriteMultipleSparseBinarySpark:170->runFrameReblockTest:230 37 values are not in equal

Tests run: 6541, 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: 03:33 h
[INFO] Finished at: 2017-01-24T18:11:59-06:00
[INFO] Final Memory: 62M/2374M
[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 #770

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