You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@lucene.apache.org by Policeman Jenkins Server <je...@thetaphi.de> on 2014/03/27 15:54:41 UTC

[JENKINS] Lucene-Solr-trunk-Windows (32bit/jdk1.8.0) - Build # 3900 - Still Failing!

Build: http://jenkins.thetaphi.de/job/Lucene-Solr-trunk-Windows/3900/
Java: 32bit/jdk1.8.0 -client -XX:+UseParallelGC

2 tests failed.
REGRESSION:  org.apache.lucene.search.TestControlledRealTimeReopenThread.testCRTReopen

Error Message:
waited too long for generation 1204287

Stack Trace:
java.lang.AssertionError: waited too long for generation 1204287
	at __randomizedtesting.SeedInfo.seed([801B7377FFF2F131:D23BEE432B354948]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.lucene.search.TestControlledRealTimeReopenThread.testCRTReopen(TestControlledRealTimeReopenThread.java:520)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:483)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1617)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:826)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:862)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:876)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	at org.apache.lucene.util.TestRuleFieldCacheSanity$1.evaluate(TestRuleFieldCacheSanity.java:51)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:49)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:70)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:359)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:783)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:443)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:835)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:771)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:782)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:42)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:43)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:70)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:55)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:359)
	at java.lang.Thread.run(Thread.java:744)


FAILED:  junit.framework.TestSuite.org.apache.lucene.search.TestControlledRealTimeReopenThread

Error Message:
1 thread leaked from SUITE scope at org.apache.lucene.search.TestControlledRealTimeReopenThread:     1) Thread[id=2963, name=Thread-2082, state=TIMED_WAITING, group=TGRP-TestControlledRealTimeReopenThread]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.awaitNanos(AbstractQueuedSynchronizer.java:2078)         at org.apache.lucene.search.ControlledRealTimeReopenThread.run(ControlledRealTimeReopenThread.java:223)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: 1 thread leaked from SUITE scope at org.apache.lucene.search.TestControlledRealTimeReopenThread: 
   1) Thread[id=2963, name=Thread-2082, state=TIMED_WAITING, group=TGRP-TestControlledRealTimeReopenThread]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.awaitNanos(AbstractQueuedSynchronizer.java:2078)
        at org.apache.lucene.search.ControlledRealTimeReopenThread.run(ControlledRealTimeReopenThread.java:223)
	at __randomizedtesting.SeedInfo.seed([801B7377FFF2F131]:0)




Build Log:
[...truncated 1490 lines...]
   [junit4] Suite: org.apache.lucene.search.TestControlledRealTimeReopenThread
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestControlledRealTimeReopenThread -Dtests.method=testCRTReopen -Dtests.seed=801B7377FFF2F131 -Dtests.slow=true -Dtests.locale=fi_FI -Dtests.timezone=Asia/Magadan -Dtests.file.encoding=US-ASCII
   [junit4] FAILURE 1209s | TestControlledRealTimeReopenThread.testCRTReopen <<<
   [junit4]    > Throwable #1: java.lang.AssertionError: waited too long for generation 1204287
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([801B7377FFF2F131:D23BEE432B354948]:0)
   [junit4]    > 	at org.apache.lucene.search.TestControlledRealTimeReopenThread.testCRTReopen(TestControlledRealTimeReopenThread.java:520)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:744)
   [junit4]   2> NOTE: test params are: codec=Lucene42, sim=DefaultSimilarity, locale=fi_FI, timezone=Asia/Magadan
   [junit4]   2> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.8.0 (32-bit)/cpus=2,threads=1,free=131651536,total=251658240
   [junit4]   2> NOTE: All tests run in this JVM: [Nested1, TestTryDelete, TestDocumentsWriterDeleteQueue, TestFileSwitchDirectory, TestBroadWord, TestTopScoreDocCollector, TestUniqueTermCount, TestWorstCaseTestBehavior, TestMultiTermConstantScore, TestCharsRef, TestOfflineSorter, TestBinaryDocument, Nested3, Nested1, Nested2, TestPrefixQuery, TestNearSpansOrdered, TestDocument, TestDocValuesScoring, TestFieldCache, TestDoubleBarrelLRUCache, TestWildcardRandom, TestDocumentWriter, TestFilterDirectory, TestMultiLevelSkipList, Test2BPostings, TestIntroSorter, TestTwoPhaseCommitTool, TestFieldsReader, TestTermsEnum, TestHugeRamFile, TestIndexWriterCommit, TestParallelTermEnum, TestMergeSchedulerExternal, TestBooleanScorer, TestDeterminizeLexicon, TestShardSearching, TestPerFieldDocValuesFormat, TestFlex, Nested1, TestAssertions, Nested1, TestNeverDelete, ThrowInUncaught, TestPerFieldPostingsFormat, NestedSetupChain, NestedTeardownChain, TestCrash, TestNamedSPILoader, TestSearchAfter, TestIndexWriterWithThreads, TestTieredMergePolicy, TestAutomatonQuery, TestLucene42DocValuesFormat, TestDateSort, TestTermVectorsFormat, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, TestExternalCodecs, TestToken, TestIndexWriterForceMerge, TestBasicOperations, TestSimpleAttributeImpl, TestBagOfPostings, TestBooleanOr, TestLucene40DocValuesFormat, TestPForDeltaDocIdSet, TestByteSlices, TestSpecialOperations, TestPayloadExplanations, TestTimSorter, TestSegmentTermEnum, TestNumericRangeQuery32, TestRollingUpdates, TestPhrasePrefixQuery, TestDirectoryReaderReopen, TestPagedBytes, TestLookaheadTokenFilter, TestIntBlockPool, TestStressIndexing2, TestDocValuesIndexing, TestIndexReaderClose, TestRamUsageEstimatorOnWildAnimals, TestPerSegmentDeletes, TestDeterminism, TestDirectoryReader, TestNGramPhraseQuery, TestSmallFloat, TestInPlaceMergeSorter, TestTermScorer, TestSpanExplanations, TestLazyProxSkipping, TestEarlyTermination, TestFastCompressionMode, TestFieldCacheRewriteMethod, TestBlockPostingsFormat, Nested1, TestBooleanQuery, TestScorerPerf, TestMockDirectoryWrapper, TestSimilarityProvider, TestByteBlockPool, TestIndexableField, TestDemo, TestTermRangeQuery, TestSortRandom, TestTotalHitCountCollector, TestDocTermOrdsRangeFilter, TestDoc, TestNRTReaderWithThreads, TestMultiMMap, TestSimpleExplanations, TestDateFilter, TestIntsRef, TestMixedDocValuesUpdates, TestPrefixRandom, TestFieldInfos, TestPriorityQueue, TestMultiDocValues, TestSloppyMath, TestSpanExplanationsOfNonMatches, TestUnicodeUtil, TestTransactions, TestDocTermOrds, TestNumericTokenStream, TestFlushByRamOrCountsPolicy, TestIndexWriterOutOfFileDescriptors, TestBooleanMinShouldMatch, TestScoreCachingWrappingScorer, TestNumericRangeQuery64, TestTermsEnum2, InBeforeClass, InAfterClass, InTestMethod, NonStringProperties, TestStoredFieldsFormat, TestSimpleSearchEquivalence, TestIndexWriterDelete, TestBytesRefHash, TestAttributeSource, TestLockFactory, TestRamUsageEstimator, TestMatchAllDocsQuery, TestDuelingCodecs, TestIndexWriterLockRelease, Test4GBStoredFields, TestBytesRef, TestForUtil, TestMockCharFilter, TestSpanSearchEquivalence, TestEliasFanoDocIdSet, TestIndexWriterOnJRECrash, TestVirtualMethod, TestEliasFanoSequence, Test2BPositions, TestMinShouldMatch2, TestSearch, Test2BDocs, TestMultiThreadTermVectors, TestIndexWriter, TestSegmentReader, TestCloseableThreadLocal, TestPayloadTermQuery, TestIndexFileDeleter, TestMixedCodecs, TestIndexWriterMergePolicy, TestByteArrayDataInput, TestReaderClosed, TestWeakIdentityMap, TestSpans, TestUTF32ToUTF8, TestTermVectors, TestIndexCommit, TestIndexWriterUnicode, TestBlockPostingsFormat3, Test2BTerms, TestSpansAdvanced2, TestAutomatonQueryUnicode, TestWildcard, TestLucene40TermVectorsFormat, TestNot, TestReusableStringReader, TestFieldMaskingSpanQuery, TestLock, MultiCollectorTest, TestPositiveScoresOnlyCollector, TestOmitTf, TestConsistentFieldNumbers, TestAtomicUpdate, TestFilterAtomicReader, TestStressAdvance, Nested, TestRAMDirectory, TestSearcherManager, Nested, Nested, TestTermdocPerf, TestCompressingTermVectorsFormat, TestIndexWriterConfig, TestDocValuesFormat, TestIndexWriterReader, TestIndexWriterMerging, TestFSTs, TestBytesStore, TestPackedInts, TestBackwardsCompatibility, TestGraphTokenizers, TestAddIndexes, TestIndexWriterExceptions, TestDeletionPolicy, TestBasics, TestSloppyPhraseQuery, TestNRTThreads, TestBoolean2, TestPersistentSnapshotDeletionPolicy, TestNorms, TestTimeLimitingCollector, TestSearchWithThreads, TestConcurrentMergeScheduler, TestHighCompressionMode, TestOpenBitSet, TestDocumentsWriterStallControl, TestTopDocsMerge, TestCompoundFile, TestLongPostings, TestStressIndexing, TestMinimize, TestBlockPostingsFormat2, TestDocTermOrdsRewriteMethod, TestSnapshotDeletionPolicy, TestLucene40PostingsReader, TestArrayUtil, TestLevenshteinAutomata, TestBufferedIndexInput, TestCompressingStoredFieldsFormat, TestSegmentMerger, TestPhraseQuery, TestCollectionUtil, TestBagOfPositions, TestOmitNorms, TestFixedBitSet, TestComplexExplanations, TestMockAnalyzer, TestRegexpRandom2, TestNRTCachingDirectory, TestFastDecompressionMode, TestParallelCompositeReader, TestIndexWriterNRTIsCurrent, TestSegmentTermDocs, TestPerFieldPostingsFormat2, TestSort, TestBitVector, TestReuseDocsEnum, TestFieldCacheSanityChecker, TestCustomSearcherSort, TestPostingsFormat, TestSimilarityBase, TestNumericUtils, TestIndexWriterOnDiskFull, TestCustomNorms, TestPostingsOffsets, TestPayloadSpans, TestTransactionRollback, TestLucene40PostingsFormat, TestSortDocValues, Nested, TestMultiPhraseQuery, TestDocsAndPositions, TestFieldCacheRangeFilter, TestTermVectorsWriter, TestCodecs, TestCharTermAttributeImpl, TestOmitPositions, TestParallelAtomicReader, TestThreadedForceMerge, TestStressNRT, TestIndexInput, TestCopyBytes, TestFilteredQuery, TestSloppyPhraseQuery2, TestDisjunctionMaxQuery, TestForceMergeForever, TestSameScoresWithThreads, TestQueryWrapperFilter, TestMultiFields, TestPayloadNearQuery, TestCrashCausesCorruptIndex, TestLiveFieldValues, TestForTooMuchCloning, TestFuzzyQuery, TestPayloads, TestSimilarity2, TestTermRangeFilter, TestNoDeletionPolicy, TestSimpleExplanationsOfNonMatches, TestRegexpQuery, TestTermVectorsReader, TestMultiValuedNumericRangeQuery, TestPrefixInBooleanQuery, TestTopDocsCollector, TestComplexExplanationsOfNonMatches, TestPrefixCodedTerms, TestAllFilesHaveCodecHeader, TestParallelReaderEmptyIndex, TestMaxTermFrequency, TestTopFieldCollector, TestSumDocFreq, TestSentinelIntSet, TestWindowsMMap, TestDirectory, TestRegexpRandom, TestCheckIndex, TestPayloadsOnVectors, TestCachingWrapperFilter, TestFieldValueFilter, TestSpanMultiTermQueryWrapper, TestBooleanQueryVisitSubscorers, TestSearchForDuplicates, TestSizeBoundedForceMerge, TestCompiledAutomaton, TestConstantScoreQuery, TestDocValuesWithThreads, Before3, Before3, TestDocIdSet, TestElevationComparator, TestFilteredSearch, TestBinaryTerms, TestSubScorerFreqs, TestRecyclingIntBlockAllocator, TestConjunctions, TestMultiTermQueryRewrites, TestPositionIncrement, TestField, TestSimilarity, TestIdentityHashSet, TestRollingBuffer, TestSetOnce, TestCachingTokenFilter, TestSpansAdvanced, TestFilterIterator, TestDateTools, TestSameTokenSamePosition, TestDocCount, TestCachingCollector, TestFieldCacheTermsFilter, Nested1, TestRecyclingByteBlockAllocator, TestSpanFirstQuery, Nested, TestIsCurrent, TestNoMergePolicy, TestNoMergeScheduler, TestCharFilter, TestRollback, TestExplanations, TestVersionComparator, TestPrefixFilter, TestVersion, TestCodecHoldsOpenFiles, TestDocBoost, TestTerm, Test2BPostingsBytes, TestIOUtils, TestNewestSegment, TestLucene40StoredFieldsFormat, TestLucene41StoredFieldsFormat, TestLucene45DocValuesFormat, TestBinaryDocValuesUpdates, TestDocInverterPerFieldErrorInfo, TestExceedMaxTermLength, TestLogMergePolicy, TestNumericDocValuesUpdates, FuzzyTermOnShortTermsTest, TestControlledRealTimeReopenThread]
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestControlledRealTimeReopenThread -Dtests.seed=801B7377FFF2F131 -Dtests.slow=true -Dtests.locale=fi_FI -Dtests.timezone=Asia/Magadan -Dtests.file.encoding=US-ASCII
   [junit4] ERROR   0.00s | TestControlledRealTimeReopenThread (suite) <<<
   [junit4]    > Throwable #1: com.carrotsearch.randomizedtesting.ThreadLeakError: 1 thread leaked from SUITE scope at org.apache.lucene.search.TestControlledRealTimeReopenThread: 
   [junit4]    >    1) Thread[id=2963, name=Thread-2082, state=TIMED_WAITING, group=TGRP-TestControlledRealTimeReopenThread]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.awaitNanos(AbstractQueuedSynchronizer.java:2078)
   [junit4]    >         at org.apache.lucene.search.ControlledRealTimeReopenThread.run(ControlledRealTimeReopenThread.java:223)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([801B7377FFF2F131]:0)
   [junit4] Completed in 1231.10s, 5 tests, 1 failure, 1 error <<< FAILURES!

[...truncated 57 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:467: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:447: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:45: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\extra-targets.xml:37: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\build.xml:49: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\common-build.xml:1275: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\common-build.xml:907: There were test failures: 385 suites, 2796 tests, 1 suite-level error, 1 failure, 82 ignored (69 assumptions)

Total time: 34 minutes 23 seconds
Build step 'Invoke Ant' marked build as failure
Description set: Java: 32bit/jdk1.8.0 -client -XX:+UseParallelGC
Archiving artifacts
Recording test results
Email was triggered for: Failure
Sending email for trigger: Failure



[JENKINS] Lucene-Solr-trunk-Windows (32bit/jdk1.7.0_51) - Build # 3901 - Still Failing!

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: http://jenkins.thetaphi.de/job/Lucene-Solr-trunk-Windows/3901/
Java: 32bit/jdk1.7.0_51 -client -XX:+UseG1GC

1 tests failed.
FAILED:  junit.framework.TestSuite.org.apache.solr.common.util.ContentStreamTest

Error Message:
!!!! WARNING: best effort to remove C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-solrj\test\J0\.\solrtest-ContentStreamTest-1395962448800 FAILED !!!!!

Stack Trace:
java.lang.AssertionError: !!!! WARNING: best effort to remove C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-solrj\test\J0\.\solrtest-ContentStreamTest-1395962448800 FAILED !!!!!
	at __randomizedtesting.SeedInfo.seed([32A8B44CEE4187EC]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.SolrTestCaseJ4.afterClass(SolrTestCaseJ4.java:217)
	at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:606)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1617)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:789)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:42)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:43)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:70)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:55)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:359)
	at java.lang.Thread.run(Thread.java:744)




Build Log:
[...truncated 11572 lines...]
   [junit4] Suite: org.apache.solr.common.util.ContentStreamTest
   [junit4]   2> Creating dataDir: C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-solrj\test\J0\.\solrtest-ContentStreamTest-1395962448800
   [junit4]   2> 68449 T207 oas.SolrTestCaseJ4.buildSSLConfig Randomized ssl (true) and clientAuth (false)
   [junit4]   2> 68452 T207 oas.SolrTestCaseJ4.setUp ###Starting testURLStream
   [junit4]   2> 68453 T207 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 68453 T207 oasc.SolrResourceLoader.locateSolrHome solr home defaulted to 'solr/' (could not find system property or JNDI)
   [junit4]   2> 68453 T207 oasc.SolrResourceLoader.<init> new SolrResourceLoader for deduced Solr Home: 'solr/'
   [junit4]   2> 68554 T207 oas.SolrTestCaseJ4.tearDown ###Ending testURLStream
   [junit4]   2> 68565 T207 oas.SolrTestCaseJ4.setUp ###Starting testFileStream
   [junit4]   2> 68566 T207 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 68566 T207 oasc.SolrResourceLoader.locateSolrHome solr home defaulted to 'solr/' (could not find system property or JNDI)
   [junit4]   2> 68567 T207 oasc.SolrResourceLoader.<init> new SolrResourceLoader for deduced Solr Home: 'solr/'
   [junit4]   2> 68615 T207 oas.SolrTestCaseJ4.tearDown ###Ending testFileStream
   [junit4]   2> 68622 T207 oas.SolrTestCaseJ4.setUp ###Starting testStringStream
   [junit4]   2> 68623 T207 oas.SolrTestCaseJ4.tearDown ###Ending testStringStream
   [junit4]   2> 68624 T207 oas.SolrTestCaseJ4.deleteCore ###deleteCore
   [junit4]   2> !!!! WARNING: best effort to remove C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-solrj\test\J0\.\solrtest-ContentStreamTest-1395962448800\README FAILED !!!!!
   [junit4]   2> NOTE: test params are: codec=FastCompressingStoredFields(storedFieldsFormat=CompressingStoredFieldsFormat(compressionMode=FAST, chunkSize=271), termVectorsFormat=CompressingTermVectorsFormat(compressionMode=FAST, chunkSize=271)), sim=DefaultSimilarity, locale=en_IE, timezone=America/Vancouver
   [junit4]   2> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.7.0_51 (32-bit)/cpus=2,threads=1,free=17354576,total=84934656
   [junit4]   2> NOTE: All tests run in this JVM: [TestXMLEscaping, JettyWebappTest, CloudSolrServerTest, LargeVolumeJettyTest, TestHash, SolrExampleStreamingTest, IteratorChainTest, TestFastInputStream, ContentStreamTest]
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=ContentStreamTest -Dtests.seed=32A8B44CEE4187EC -Dtests.slow=true -Dtests.locale=en_IE -Dtests.timezone=America/Vancouver -Dtests.file.encoding=UTF-8
   [junit4] ERROR   0.00s | ContentStreamTest (suite) <<<
   [junit4]    > Throwable #1: java.lang.AssertionError: !!!! WARNING: best effort to remove C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-solrj\test\J0\.\solrtest-ContentStreamTest-1395962448800 FAILED !!!!!
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([32A8B44CEE4187EC]:0)
   [junit4]    > 	at org.apache.solr.SolrTestCaseJ4.afterClass(SolrTestCaseJ4.java:217)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:744)
   [junit4] Completed in 0.41s, 3 tests, 1 failure <<< FAILURES!

[...truncated 126 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:467: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:447: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:45: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\extra-targets.xml:37: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build.xml:202: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\common-build.xml:490: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\common-build.xml:1275: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\common-build.xml:907: There were test failures: 49 suites, 284 tests, 1 suite-level error

Total time: 111 minutes 12 seconds
Build step 'Invoke Ant' marked build as failure
Description set: Java: 32bit/jdk1.7.0_51 -client -XX:+UseG1GC
Archiving artifacts
Recording test results
Email was triggered for: Failure
Sending email for trigger: Failure