You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@mahout.apache.org by "Suneel Marthi (JIRA)" <ji...@apache.org> on 2013/09/03 00:57:52 UTC

[jira] [Commented] (MAHOUT-1323) ParallelALSFactorizationJobTest.completeJobToyExample is unstable

    [ https://issues.apache.org/jira/browse/MAHOUT-1323?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=13756257#comment-13756257 ] 

Suneel Marthi commented on MAHOUT-1323:
---------------------------------------

[~sslavic], these are random test failures that happen when you enable parallel tests. The same tests don't fail always deterministically on every run. We had seen this behavior in prep for 0.8 release and had disabled parallel tests execution. 
When I run a build locally with parallel tests enabled the same tests does not fail always. We didn't have the time to troubleshoot this for 0.8 release but nevertheless this is one thing that needs to be ironed out before the next release. 

Thinking loud here, we may have to redo all our present unit tests to work when parallel tests are enabled.
                
> ParallelALSFactorizationJobTest.completeJobToyExample is unstable
> -----------------------------------------------------------------
>
>                 Key: MAHOUT-1323
>                 URL: https://issues.apache.org/jira/browse/MAHOUT-1323
>             Project: Mahout
>          Issue Type: Bug
>          Components: Collaborative Filtering
>    Affects Versions: 0.8
>         Environment: ubuntu3 Apache Jenkins CI node
>            Reporter: Stevo Slavic
>            Assignee: Stevo Slavic
>            Priority: Minor
>             Fix For: 0.9
>
>
> Mahout-Quality build #2224 failed because of this test.
> Relevant build log:
> {noformat}
> [INFO] --- maven-surefire-plugin:2.16:test (default-test) @ mahout-core ---
> [INFO] Surefire report directory: /x1/jenkins/jenkins-slave/workspace/Mahout-Quality/trunk/core/target/surefire-reports
> -------------------------------------------------------
>  T E S T S
> -------------------------------------------------------
> -------------------------------------------------------
>  T E S T S
> -------------------------------------------------------
> Running org.apache.mahout.math.VarintTest
> Running org.apache.mahout.math.hadoop.similarity.cooccurrence.RowSimilarityJobTest
> Running org.apache.mahout.math.hadoop.solver.TestDistributedConjugateGradientSolver
> Running org.apache.mahout.math.hadoop.decomposer.TestDistributedLanczosSolverCLI
> Running org.apache.mahout.math.hadoop.similarity.cooccurrence.measures.VectorSimilarityMeasuresTest
> Running org.apache.mahout.math.hadoop.TestDistributedRowMatrix
> Running org.apache.mahout.math.hadoop.stochasticsvd.LocalSSVDSolverDenseTest
> Running org.apache.mahout.math.VectorWritableTest
> Running org.apache.mahout.math.neighborhood.LocalitySensitiveHashSearchTest
> Running org.apache.mahout.cf.taste.impl.model.file.FileIDMigratorTest
> Running org.apache.mahout.math.neighborhood.SearchQualityTest
> Running org.apache.mahout.math.hadoop.stochasticsvd.LocalSSVDSolverSparseSequentialTest
> Running org.apache.mahout.cf.taste.impl.model.MemoryIDMigratorTest
> Running org.apache.mahout.math.hadoop.stats.BasicStatsTest
> Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.09 sec - in org.apache.mahout.math.VarintTest
> Running org.apache.mahout.math.ssvd.SequentialOutOfCoreSvdTest
> Running org.apache.mahout.ep.EvolutionaryProcessTest
> Running org.apache.mahout.cf.taste.hadoop.item.RecommenderJobTest
> Running org.apache.mahout.math.hadoop.similarity.TestVectorDistanceSimilarityJob
> Running org.apache.mahout.math.neighborhood.SearchSanityTest
> Running org.apache.mahout.math.hadoop.solver.TestDistributedConjugateGradientSolverCLI
> Running org.apache.mahout.math.stats.SamplerTest
> Running org.apache.mahout.math.MatrixWritableTest
> Running org.apache.mahout.math.hadoop.stochasticsvd.SSVDCommonTest
> Running org.apache.mahout.math.hadoop.stochasticsvd.LocalSSVDPCASparseTest
> Running org.apache.mahout.cf.taste.hadoop.item.ToUserVectorsReducerTest
> Running org.apache.mahout.cf.taste.impl.model.PlusAnonymousConcurrentUserDataModelTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.211 sec - in org.apache.mahout.math.hadoop.similarity.cooccurrence.measures.VectorSimilarityMeasuresTest
> Running org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJobTest
> Running org.apache.mahout.cf.taste.impl.model.GenericItemPreferenceArrayTest
> Running org.apache.mahout.cf.taste.impl.model.BooleanItemPreferenceArrayTest
> Running org.apache.mahout.math.stats.OnlineAucTest
> Running org.apache.mahout.cf.taste.hadoop.similarity.item.ItemSimilarityJobTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.317 sec - in org.apache.mahout.cf.taste.impl.model.MemoryIDMigratorTest
> Running org.apache.mahout.cf.taste.impl.model.GenericDataModelTest
> Running org.apache.mahout.cf.taste.impl.model.GenericUserPreferenceArrayTest
> Running org.apache.mahout.cf.taste.impl.model.file.FileDataModelTest
> Tests run: 15, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.297 sec - in org.apache.mahout.cf.taste.impl.model.PlusAnonymousConcurrentUserDataModelTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.429 sec - in org.apache.mahout.math.stats.SamplerTest
> Running org.apache.mahout.cf.taste.hadoop.TopItemsQueueTest
> Running org.apache.mahout.cf.taste.impl.model.BooleanUserPreferenceArrayTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.315 sec - in org.apache.mahout.cf.taste.impl.model.BooleanItemPreferenceArrayTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.469 sec - in org.apache.mahout.math.MatrixWritableTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.337 sec - in org.apache.mahout.cf.taste.impl.model.GenericItemPreferenceArrayTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.469 sec - in org.apache.mahout.math.hadoop.stochasticsvd.SSVDCommonTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.341 sec - in org.apache.mahout.cf.taste.impl.model.GenericUserPreferenceArrayTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.201 sec - in org.apache.mahout.cf.taste.impl.model.BooleanUserPreferenceArrayTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.244 sec - in org.apache.mahout.cf.taste.hadoop.TopItemsQueueTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.559 sec - in org.apache.mahout.cf.taste.impl.model.GenericDataModelTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.81 sec - in org.apache.mahout.cf.taste.hadoop.item.ToUserVectorsReducerTest
> Running org.apache.mahout.cf.taste.impl.recommender.GenericItemBasedRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.ItemUserAverageRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.svd.FilePersistenceStrategyTest
> Running org.apache.mahout.cf.taste.impl.recommender.svd.ParallelSGDFactorizerTest
> Running org.apache.mahout.cf.taste.impl.recommender.CachingRecommenderTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.346 sec - in org.apache.mahout.cf.taste.impl.recommender.svd.FilePersistenceStrategyTest
> Running org.apache.mahout.cf.taste.impl.recommender.ItemAverageRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.AllUnknownItemsCandidateItemsStrategyTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.539 sec - in org.apache.mahout.cf.taste.impl.recommender.ItemUserAverageRecommenderTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.652 sec - in org.apache.mahout.ep.EvolutionaryProcessTest
> Running org.apache.mahout.cf.taste.impl.recommender.svd.SVDRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.GenericUserBasedRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.svd.ALSWRFactorizerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.327 sec - in org.apache.mahout.cf.taste.impl.recommender.AllUnknownItemsCandidateItemsStrategyTest
> Running org.apache.mahout.cf.taste.impl.recommender.SamplingCandidateItemsStrategyTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.43 sec - in org.apache.mahout.cf.taste.impl.recommender.ItemAverageRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.RandomRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.PreferredItemsNeighborhoodCandidateItemsStrategyTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.853 sec - in org.apache.mahout.cf.taste.impl.recommender.CachingRecommenderTest
> Running org.apache.mahout.cf.taste.impl.recommender.TopItemsTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.477 sec - in org.apache.mahout.cf.taste.impl.recommender.GenericUserBasedRecommenderTest
> Tests run: 11, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.268 sec - in org.apache.mahout.cf.taste.impl.recommender.GenericItemBasedRecommenderTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.286 sec - in org.apache.mahout.cf.taste.impl.recommender.PreferredItemsNeighborhoodCandidateItemsStrategyTest
> Running org.apache.mahout.cf.taste.impl.recommender.NullRescorerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.621 sec - in org.apache.mahout.cf.taste.impl.recommender.SamplingCandidateItemsStrategyTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.487 sec - in org.apache.mahout.cf.taste.impl.recommender.RandomRecommenderTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.452 sec - in org.apache.mahout.cf.taste.impl.recommender.TopItemsTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.854 sec - in org.apache.mahout.cf.taste.impl.recommender.svd.SVDRecommenderTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.203 sec - in org.apache.mahout.cf.taste.impl.recommender.NullRescorerTest
> Running org.apache.mahout.cf.taste.impl.similarity.EuclideanDistanceSimilarityTest
> Running org.apache.mahout.cf.taste.impl.similarity.file.FileItemSimilarityTest
> Running org.apache.mahout.cf.taste.impl.similarity.GenericItemSimilarityTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.179 sec - in org.apache.mahout.cf.taste.impl.similarity.GenericItemSimilarityTest
> Running org.apache.mahout.cf.taste.impl.similarity.AveragingPreferenceInferrerTest
> Tests run: 100, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.897 sec - in org.apache.mahout.math.VectorWritableTest
> Running org.apache.mahout.cf.taste.impl.similarity.TanimotoCoefficientSimilarityTest
> Running org.apache.mahout.cf.taste.impl.similarity.PearsonCorrelationSimilarityTest
> Running org.apache.mahout.cf.taste.impl.similarity.SpearmanCorrelationSimilarityTest
> Tests run: 17, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.455 sec - in org.apache.mahout.cf.taste.impl.similarity.EuclideanDistanceSimilarityTest
> Running org.apache.mahout.cf.taste.impl.similarity.LogLikelihoodSimilarityTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.481 sec - in org.apache.mahout.cf.taste.impl.similarity.AveragingPreferenceInferrerTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.324 sec - in org.apache.mahout.cf.taste.impl.similarity.SpearmanCorrelationSimilarityTest
> Running org.apache.mahout.cf.taste.impl.common.WeightedRunningAverageTest
> Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.559 sec - in org.apache.mahout.cf.taste.impl.similarity.TanimotoCoefficientSimilarityTest
> Running org.apache.mahout.cf.taste.impl.neighborhood.NearestNNeighborhoodTest
> Running org.apache.mahout.cf.taste.impl.eval.GenericRecommenderIRStatsEvaluatorImplTest
> Running org.apache.mahout.cf.taste.impl.neighborhood.ThresholdNeighborhoodTest
> Running org.apache.mahout.cf.taste.impl.common.SamplingLongPrimitiveIteratorTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.426 sec - in org.apache.mahout.cf.taste.impl.similarity.LogLikelihoodSimilarityTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.265 sec - in org.apache.mahout.cf.taste.impl.common.WeightedRunningAverageTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.264 sec - in org.apache.mahout.cf.taste.impl.neighborhood.ThresholdNeighborhoodTest
> Running org.apache.mahout.cf.taste.impl.common.BitSetTest
> Tests run: 18, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.793 sec - in org.apache.mahout.cf.taste.impl.similarity.PearsonCorrelationSimilarityTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.312 sec - in org.apache.mahout.cf.taste.impl.eval.GenericRecommenderIRStatsEvaluatorImplTest
> Running org.apache.mahout.cf.taste.impl.common.RunningAverageAndStdDevTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.086 sec - in org.apache.mahout.cf.taste.impl.recommender.svd.ALSWRFactorizerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.399 sec - in org.apache.mahout.cf.taste.impl.neighborhood.NearestNNeighborhoodTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.188 sec - in org.apache.mahout.cf.taste.impl.common.BitSetTest
> Running org.apache.mahout.cf.taste.impl.common.FastIDSetTest
> Running org.apache.mahout.cf.taste.impl.common.CacheTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.299 sec - in org.apache.mahout.cf.taste.impl.common.RunningAverageAndStdDevTest
> Running org.apache.mahout.cf.taste.impl.common.RefreshHelperTest
> Running org.apache.mahout.cf.taste.impl.common.RunningAverageTest
> Running org.apache.mahout.cf.taste.impl.common.FastByIDMapTest
> Tests run: 10, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 3.9 sec - in org.apache.mahout.cf.taste.impl.model.file.FileDataModelTest
> Running org.apache.mahout.classifier.sequencelearning.hmm.HMMModelTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 4.441 sec - in org.apache.mahout.cf.taste.impl.model.file.FileIDMigratorTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.146 sec - in org.apache.mahout.cf.taste.impl.common.RunningAverageTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.351 sec - in org.apache.mahout.cf.taste.impl.common.RefreshHelperTest
> Running org.apache.mahout.cf.taste.impl.common.LongPrimitiveArrayIteratorTest
> Running org.apache.mahout.cf.taste.impl.common.FastMapTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.125 sec - in org.apache.mahout.cf.taste.impl.common.LongPrimitiveArrayIteratorTest
> Running org.apache.mahout.classifier.sequencelearning.hmm.HMMAlgorithmsTest
> Running org.apache.mahout.cf.taste.impl.common.InvertedRunningAverageTest
> Running org.apache.mahout.cf.taste.common.CommonTest
> Running org.apache.mahout.classifier.sequencelearning.hmm.HMMTrainerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.483 sec - in org.apache.mahout.classifier.sequencelearning.hmm.HMMModelTest
> Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.172 sec - in org.apache.mahout.cf.taste.impl.common.InvertedRunningAverageTest
> Running org.apache.mahout.classifier.sequencelearning.hmm.HMMUtilsTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.218 sec - in org.apache.mahout.classifier.sequencelearning.hmm.HMMAlgorithmsTest
> Tests run: 10, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.992 sec - in org.apache.mahout.cf.taste.impl.common.FastIDSetTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.289 sec - in org.apache.mahout.classifier.sequencelearning.hmm.HMMTrainerTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.222 sec - in org.apache.mahout.classifier.sequencelearning.hmm.HMMUtilsTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.365 sec - in org.apache.mahout.cf.taste.common.CommonTest
> Running org.apache.mahout.classifier.sgd.OnlineLogisticRegressionTest
> Running org.apache.mahout.classifier.sequencelearning.hmm.HMMEvaluatorTest
> Running org.apache.mahout.classifier.sgd.AdaptiveLogisticRegressionTest
> Running org.apache.mahout.classifier.sgd.PassiveAggressiveTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.781 sec - in org.apache.mahout.cf.taste.impl.common.SamplingLongPrimitiveIteratorTest
> Running org.apache.mahout.classifier.sgd.ModelSerializerTest
> Tests run: 9, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.072 sec - in org.apache.mahout.cf.taste.impl.common.FastByIDMapTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.173 sec - in org.apache.mahout.classifier.sequencelearning.hmm.HMMEvaluatorTest
> Running org.apache.mahout.classifier.sgd.CsvRecordFactoryTest
> Tests run: 14, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.072 sec - in org.apache.mahout.cf.taste.impl.common.FastMapTest
> Running org.apache.mahout.classifier.sgd.GradientMachineTest
> Running org.apache.mahout.classifier.df.split.DefaultIgSplitTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.502 sec - in org.apache.mahout.classifier.sgd.PassiveAggressiveTest
> Running org.apache.mahout.classifier.df.data.DatasetTest
> Running org.apache.mahout.classifier.df.split.RegressionSplitTest
> Running org.apache.mahout.classifier.df.split.OptIgSplitTest
> Running org.apache.mahout.classifier.df.data.DescriptorUtilsTest
> Running org.apache.mahout.classifier.df.data.DataLoaderTest
> Running org.apache.mahout.classifier.df.data.DataConverterTest
> Running org.apache.mahout.classifier.df.data.DataTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.237 sec - in org.apache.mahout.classifier.df.data.DescriptorUtilsTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.532 sec - in org.apache.mahout.classifier.sgd.GradientMachineTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.667 sec - in org.apache.mahout.classifier.sgd.CsvRecordFactoryTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.383 sec - in org.apache.mahout.cf.taste.impl.common.CacheTest
> Running org.apache.mahout.classifier.df.mapreduce.partial.Step1MapperTest
> Running org.apache.mahout.classifier.df.mapreduce.partial.TreeIDTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.872 sec - in org.apache.mahout.classifier.df.split.RegressionSplitTest
> Running org.apache.mahout.classifier.df.mapreduce.partial.PartialBuilderTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.916 sec - in org.apache.mahout.math.hadoop.similarity.TestVectorDistanceSimilarityJob
> Running org.apache.mahout.classifier.df.mapreduce.inmem.InMemInputSplitTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.248 sec - in org.apache.mahout.classifier.df.split.DefaultIgSplitTest
> Running org.apache.mahout.classifier.df.mapreduce.inmem.InMemInputFormatTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.2 sec - in org.apache.mahout.classifier.df.data.DatasetTest
> Running org.apache.mahout.classifier.df.builder.DecisionTreeBuilderTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.039 sec - in org.apache.mahout.classifier.df.data.DataConverterTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.208 sec - in org.apache.mahout.classifier.df.mapreduce.inmem.InMemInputSplitTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.292 sec - in org.apache.mahout.classifier.df.split.OptIgSplitTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.648 sec - in org.apache.mahout.classifier.df.mapreduce.partial.TreeIDTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 7.047 sec - in org.apache.mahout.math.stats.OnlineAucTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 4.639 sec - in org.apache.mahout.cf.taste.impl.similarity.file.FileItemSimilarityTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.215 sec - in org.apache.mahout.classifier.df.builder.DecisionTreeBuilderTest
> Running org.apache.mahout.classifier.df.builder.DefaultTreeBuilderTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.536 sec - in org.apache.mahout.classifier.df.mapreduce.inmem.InMemInputFormatTest
> Running org.apache.mahout.classifier.df.node.NodeTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.259 sec - in org.apache.mahout.classifier.sgd.ModelSerializerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.223 sec - in org.apache.mahout.classifier.df.builder.DefaultTreeBuilderTest
> Running org.apache.mahout.classifier.df.builder.InfiniteRecursionTest
> Running org.apache.mahout.classifier.df.tools.VisualizerTest
> Running org.apache.mahout.classifier.RegressionResultAnalyzerTest
> Running org.apache.mahout.classifier.df.DecisionForestTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.403 sec - in org.apache.mahout.classifier.df.mapreduce.partial.Step1MapperTest
> Running org.apache.mahout.classifier.ConfusionMatrixTest
> Running org.apache.mahout.classifier.naivebayes.ComplementaryNaiveBayesClassifierTest
> Running org.apache.mahout.classifier.naivebayes.NaiveBayesTest
> Running org.apache.mahout.classifier.naivebayes.StandardNaiveBayesClassifierTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.329 sec - in org.apache.mahout.classifier.df.node.NodeTest
> Running org.apache.mahout.classifier.naivebayes.NaiveBayesModelTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.226 sec - in org.apache.mahout.classifier.RegressionResultAnalyzerTest
> Tests run: 10, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.938 sec - in org.apache.mahout.classifier.df.data.DataTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.295 sec - in org.apache.mahout.classifier.ConfusionMatrixTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.286 sec - in org.apache.mahout.classifier.naivebayes.ComplementaryNaiveBayesClassifierTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.264 sec - in org.apache.mahout.classifier.naivebayes.StandardNaiveBayesClassifierTest
> Running org.apache.mahout.classifier.naivebayes.training.WeightsMapperTest
> Running org.apache.mahout.classifier.naivebayes.training.IndexInstancesMapperTest
> Running org.apache.mahout.classifier.naivebayes.training.ThetaMapperTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.344 sec - in org.apache.mahout.classifier.naivebayes.NaiveBayesModelTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.639 sec - in org.apache.mahout.classifier.df.mapreduce.partial.PartialBuilderTest
> Running org.apache.mahout.clustering.kmeans.TestKmeansClustering
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.8 sec - in org.apache.mahout.classifier.df.DecisionForestTest
> Running org.apache.mahout.clustering.kmeans.TestRandomSeedGenerator
> Running org.apache.mahout.clustering.TestClusterInterface
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.009 sec - in org.apache.mahout.classifier.df.builder.InfiniteRecursionTest
> Running org.apache.mahout.classifier.evaluation.AucTest
> Running org.apache.mahout.clustering.kmeans.TestEigenSeedGenerator
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.769 sec - in org.apache.mahout.classifier.df.data.DataLoaderTest
> Running org.apache.mahout.clustering.streaming.cluster.BallKMeansTest
> Running org.apache.mahout.clustering.streaming.cluster.StreamingKMeansTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.708 sec - in org.apache.mahout.classifier.naivebayes.training.WeightsMapperTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.678 sec - in org.apache.mahout.classifier.naivebayes.training.IndexInstancesMapperTest
> Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.283 sec - in org.apache.mahout.clustering.TestClusterInterface
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.264 sec - in org.apache.mahout.classifier.df.tools.VisualizerTest
> Running org.apache.mahout.clustering.lda.cvb.TestCVBModelTrainer
> Running org.apache.mahout.clustering.spectral.TestAffinityMatrixInputJob
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.957 sec - in org.apache.mahout.classifier.naivebayes.training.ThetaMapperTest
> Running org.apache.mahout.clustering.spectral.TestVectorCache
> Running org.apache.mahout.clustering.TestGaussianAccumulators
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.854 sec - in org.apache.mahout.classifier.evaluation.AucTest
> Running org.apache.mahout.clustering.spectral.TestUnitVectorizerJob
> Running org.apache.mahout.clustering.spectral.TestVectorMatrixMultiplicationJob
> Running org.apache.mahout.clustering.spectral.TestMatrixDiagonalizeJob
> Running org.apache.mahout.clustering.iterator.TestClusterClassifier
> Running org.apache.mahout.clustering.topdown.PathDirectoryTest
> Running org.apache.mahout.clustering.topdown.postprocessor.ClusterOutputPostProcessorTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.502 sec - in org.apache.mahout.clustering.topdown.PathDirectoryTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.955 sec - in org.apache.mahout.clustering.kmeans.TestRandomSeedGenerator
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.579 sec - in org.apache.mahout.clustering.spectral.TestAffinityMatrixInputJob
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.162 sec - in org.apache.mahout.clustering.spectral.TestVectorMatrixMultiplicationJob
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.237 sec - in org.apache.mahout.clustering.spectral.TestUnitVectorizerJob
> Running org.apache.mahout.clustering.topdown.postprocessor.ClusterCountReaderTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.236 sec - in org.apache.mahout.clustering.kmeans.TestEigenSeedGenerator
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.559 sec - in org.apache.mahout.clustering.spectral.TestMatrixDiagonalizeJob
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.05 sec - in org.apache.mahout.clustering.spectral.TestVectorCache
> Running org.apache.mahout.clustering.fuzzykmeans.TestFuzzyKmeansClustering
> Running org.apache.mahout.clustering.classify.ClusterClassificationDriverTest
> Running org.apache.mahout.vectorizer.encoders.InteractionValueEncoderTest
> Running org.apache.mahout.clustering.canopy.TestCanopyCreation
> Running org.apache.mahout.vectorizer.encoders.ContinuousValueEncoderTest
> Running org.apache.mahout.vectorizer.encoders.TextValueEncoderTest
> Running org.apache.mahout.vectorizer.encoders.ConstantValueEncoderTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.355 sec - in org.apache.mahout.vectorizer.encoders.ContinuousValueEncoderTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.565 sec - in org.apache.mahout.vectorizer.encoders.InteractionValueEncoderTest
> Running org.apache.mahout.vectorizer.encoders.WordLikeValueEncoderTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.733 sec - in org.apache.mahout.vectorizer.encoders.ConstantValueEncoderTest
> Running org.apache.mahout.vectorizer.HighDFWordsPrunerTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.964 sec - in org.apache.mahout.vectorizer.encoders.TextValueEncoderTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.225 sec - in org.apache.mahout.vectorizer.encoders.WordLikeValueEncoderTest
> Running org.apache.mahout.vectorizer.DocumentProcessorTest
> Running org.apache.mahout.vectorizer.SparseVectorsFromSequenceFilesTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.903 sec - in org.apache.mahout.clustering.topdown.postprocessor.ClusterCountReaderTest
> Running org.apache.mahout.vectorizer.collocations.llr.CollocMapperTest
> Running org.apache.mahout.vectorizer.DictionaryVectorizerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 3.716 sec - in org.apache.mahout.clustering.topdown.postprocessor.ClusterOutputPostProcessorTest
> Running org.apache.mahout.vectorizer.collocations.llr.GramKeyGroupComparatorTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.341 sec - in org.apache.mahout.vectorizer.collocations.llr.GramKeyGroupComparatorTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.255 sec - in org.apache.mahout.vectorizer.collocations.llr.CollocMapperTest
> Running org.apache.mahout.vectorizer.collocations.llr.GramTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 2.462 sec - in org.apache.mahout.vectorizer.HighDFWordsPrunerTest
> Tests run: 7, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.523 sec - in org.apache.mahout.vectorizer.collocations.llr.GramTest
> Running org.apache.mahout.vectorizer.collocations.llr.LLRReducerTest
> Running org.apache.mahout.vectorizer.collocations.llr.GramKeyTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.285 sec - in org.apache.mahout.vectorizer.collocations.llr.GramKeyTest
> Running org.apache.mahout.vectorizer.collocations.llr.GramKeyPartitionerTest
> Running org.apache.mahout.vectorizer.collocations.llr.CollocReducerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.789 sec - in org.apache.mahout.vectorizer.collocations.llr.LLRReducerTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.259 sec - in org.apache.mahout.vectorizer.collocations.llr.GramKeyPartitionerTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 11.443 sec - in org.apache.mahout.classifier.sgd.AdaptiveLogisticRegressionTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 16.796 sec - in org.apache.mahout.math.hadoop.similarity.cooccurrence.RowSimilarityJobTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.491 sec - in org.apache.mahout.vectorizer.collocations.llr.CollocReducerTest
> Running org.apache.mahout.vectorizer.EncodedVectorsFromSequenceFilesTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 3.474 sec - in org.apache.mahout.vectorizer.DocumentProcessorTest
> Running org.apache.mahout.common.StringUtilsTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 17.035 sec - in org.apache.mahout.math.hadoop.stats.BasicStatsTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 7.665 sec - in org.apache.mahout.clustering.TestGaussianAccumulators
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 5.392 sec - in org.apache.mahout.clustering.classify.ClusterClassificationDriverTest
> Running org.apache.mahout.common.distance.TestMahalanobisDistanceMeasure
> Running org.apache.mahout.common.distance.TestManhattanDistanceMeasure
> Running org.apache.mahout.common.distance.TestChebyshevMeasure
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.262 sec - in org.apache.mahout.common.distance.TestMahalanobisDistanceMeasure
> Running org.apache.mahout.common.distance.CosineDistanceMeasureTest
> Running org.apache.mahout.common.distance.TestWeightedEuclideanDistanceMeasureTest
> Running org.apache.mahout.common.distance.TestWeightedManhattanDistanceMeasure
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.272 sec - in org.apache.mahout.common.distance.TestManhattanDistanceMeasure
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.274 sec - in org.apache.mahout.common.distance.TestChebyshevMeasure
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 9.682 sec - in org.apache.mahout.classifier.naivebayes.NaiveBayesTest
> Running org.apache.mahout.common.distance.TestMinkowskiMeasure
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.561 sec - in org.apache.mahout.common.StringUtilsTest
> Running org.apache.mahout.common.distance.TestEuclideanDistanceMeasure
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.203 sec - in org.apache.mahout.common.distance.CosineDistanceMeasureTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.261 sec - in org.apache.mahout.common.distance.TestWeightedEuclideanDistanceMeasureTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.205 sec - in org.apache.mahout.common.distance.TestMinkowskiMeasure
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.314 sec - in org.apache.mahout.common.distance.TestEuclideanDistanceMeasure
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.387 sec - in org.apache.mahout.common.distance.TestWeightedManhattanDistanceMeasure
> Running org.apache.mahout.common.distance.TestTanimotoDistanceMeasure
> Running org.apache.mahout.common.DummyRecordWriterTest
> Running org.apache.mahout.common.lucene.AnalyzerUtilsTest
> Running org.apache.mahout.common.IntPairWritableTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.263 sec - in org.apache.mahout.common.distance.TestTanimotoDistanceMeasure
> Running org.apache.mahout.common.iterator.TestStableFixedSizeSampler
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.204 sec - in org.apache.mahout.common.DummyRecordWriterTest
> Running org.apache.mahout.common.iterator.TestFixedSizeSampler
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.135 sec - in org.apache.mahout.common.IntPairWritableTest
> Running org.apache.mahout.common.iterator.CountingIteratorTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.277 sec - in org.apache.mahout.common.lucene.AnalyzerUtilsTest
> Running org.apache.mahout.common.iterator.TestSamplingIterator
> Running org.apache.mahout.common.AbstractJobTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.27 sec - in org.apache.mahout.common.iterator.TestFixedSizeSampler
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.293 sec - in org.apache.mahout.common.iterator.TestStableFixedSizeSampler
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.259 sec - in org.apache.mahout.common.iterator.CountingIteratorTest
> Running org.apache.mahout.driver.MahoutDriverTest
> Tests run: 12, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 9.239 sec - in org.apache.mahout.clustering.iterator.TestClusterClassifier
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.54 sec - in org.apache.mahout.driver.MahoutDriverTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 0.926 sec - in org.apache.mahout.common.AbstractJobTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 1.321 sec - in org.apache.mahout.common.iterator.TestSamplingIterator
> Tests run: 11, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 19.886 sec - in org.apache.mahout.math.hadoop.TestDistributedRowMatrix
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 20.864 sec - in org.apache.mahout.math.hadoop.solver.TestDistributedConjugateGradientSolverCLI
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 20.716 sec - in org.apache.mahout.cf.taste.hadoop.similarity.item.ItemSimilarityJobTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 23.076 sec - in org.apache.mahout.math.hadoop.solver.TestDistributedConjugateGradientSolver
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 6.249 sec - in org.apache.mahout.vectorizer.EncodedVectorsFromSequenceFilesTest
> Tests run: 17, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 13.486 sec - in org.apache.mahout.clustering.canopy.TestCanopyCreation
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 21.179 sec - in org.apache.mahout.classifier.sgd.OnlineLogisticRegressionTest
> Tests run: 1, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 26.884 sec - in org.apache.mahout.math.hadoop.stochasticsvd.LocalSSVDSolverSparseSequentialTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 21.12 sec - in org.apache.mahout.clustering.kmeans.TestKmeansClustering
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 34.232 sec - in org.apache.mahout.math.hadoop.stochasticsvd.LocalSSVDPCASparseTest
> Tests run: 21, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 35.159 sec - in org.apache.mahout.cf.taste.hadoop.item.RecommenderJobTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 37.022 sec - in org.apache.mahout.math.ssvd.SequentialOutOfCoreSvdTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 39.79 sec - in org.apache.mahout.math.hadoop.decomposer.TestDistributedLanczosSolverCLI
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 40.81 sec - in org.apache.mahout.math.neighborhood.LocalitySensitiveHashSearchTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 33.451 sec - in org.apache.mahout.clustering.fuzzykmeans.TestFuzzyKmeansClustering
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 47.251 sec - in org.apache.mahout.math.hadoop.stochasticsvd.LocalSSVDSolverDenseTest
> Tests run: 4, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 33.506 sec - in org.apache.mahout.vectorizer.DictionaryVectorizerTest
> Tests run: 3, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 42.832 sec - in org.apache.mahout.clustering.streaming.cluster.BallKMeansTest
> Tests run: 18, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 56.141 sec - in org.apache.mahout.math.neighborhood.SearchSanityTest
> Tests run: 5, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 55.249 sec - in org.apache.mahout.cf.taste.impl.recommender.svd.ParallelSGDFactorizerTest
> Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 58.046 sec - in org.apache.mahout.clustering.streaming.cluster.StreamingKMeansTest
> Tests run: 6, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 60.057 sec - in org.apache.mahout.vectorizer.SparseVectorsFromSequenceFilesTest
> Tests run: 2, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 73.216 sec - in org.apache.mahout.clustering.lda.cvb.TestCVBModelTrainer
> Tests run: 6, Failures: 0, Errors: 1, Skipped: 0, Time elapsed: 96.559 sec <<< FAILURE! - in org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJobTest
> completeJobToyExample(org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJobTest)  Time elapsed: 22.164 sec  <<< ERROR!
> java.lang.IllegalStateException: Job failed!
> 	at org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJob.runSolver(ParallelALSFactorizationJob.java:351)
> 	at org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJob.run(ParallelALSFactorizationJob.java:214)
> 	at org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJobTest.explicitExample(ParallelALSFactorizationJobTest.java:111)
> 	at org.apache.mahout.cf.taste.hadoop.als.ParallelALSFactorizationJobTest.completeJobToyExample(ParallelALSFactorizationJobTest.java:70)
> Tests run: 8, Failures: 0, Errors: 0, Skipped: 0, Time elapsed: 101.111 sec - in org.apache.mahout.math.neighborhood.SearchQualityTest
> Results :
> Tests in error: 
>   ParallelALSFactorizationJobTest.completeJobToyExample:70->explicitExample:111 ? IllegalState
> Tests run: 734, Failures: 0, Errors: 1, Skipped: 0
> [INFO] ------------------------------------------------------------------------
> [INFO] Reactor Summary:
> [INFO] 
> [INFO] Mahout Build Tools ................................ SUCCESS [5.637s]
> [INFO] Apache Mahout ..................................... SUCCESS [1.875s]
> [INFO] Mahout Math ....................................... SUCCESS [1:18.085s]
> [INFO] Mahout Core ....................................... FAILURE [1:47.266s]
> [INFO] Mahout Integration ................................ SKIPPED
> [INFO] Mahout Examples ................................... SKIPPED
> [INFO] Mahout Release Package ............................ SKIPPED
> [INFO] ------------------------------------------------------------------------
> [INFO] BUILD FAILURE
> [INFO] ------------------------------------------------------------------------
> [INFO] Total time: 3:14.686s
> [INFO] Finished at: Mon Sep 02 22:07:54 UTC 2013
> [INFO] Final Memory: 58M/454M
> [INFO] ------------------------------------------------------------------------
> {noformat}

--
This message is automatically generated by JIRA.
If you think it was sent incorrectly, please contact your JIRA administrators
For more information on JIRA, see: http://www.atlassian.com/software/jira