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/11/29 11:31:29 UTC

[JENKINS] Lucene-Solr-5.x-Windows (32bit/jdk1.7.0_67) - Build # 4353 - Still Failing!

Build: http://jenkins.thetaphi.de/job/Lucene-Solr-5.x-Windows/4353/
Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: false)

2 tests failed.
FAILED:  org.apache.lucene.util.TestArrayUtil.testInvalidElementSizes

Error Message:
requested array size 2147483637 exceeds maximum array in java (2147483635)

Stack Trace:
java.lang.IllegalArgumentException: requested array size 2147483637 exceeds maximum array in java (2147483635)
	at __randomizedtesting.SeedInfo.seed([52D6B2B0583CB5A9:192D47F69D4199F3]:0)
	at org.apache.lucene.util.ArrayUtil.oversize(ArrayUtil.java:168)
	at org.apache.lucene.util.TestArrayUtil.testInvalidElementSizes(TestArrayUtil.java:71)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)


FAILED:  org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile

Error Message:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-52D6B2B0583CB5A9-001\leftover-001\child.locked

Stack Trace:
java.nio.file.AccessDeniedException: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-52D6B2B0583CB5A9-001\leftover-001\child.locked
	at sun.nio.fs.WindowsException.translateToIOException(WindowsException.java:83)
	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:97)
	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:102)
	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:53)
	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:38)
	at org.apache.lucene.mockfile.WindowsFS.getKey(WindowsFS.java:57)
	at org.apache.lucene.mockfile.WindowsFS.onClose(WindowsFS.java:77)
	at org.apache.lucene.mockfile.HandleTrackingFS$5.close(HandleTrackingFS.java:210)
	at org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile(TestLeaveFilesIfTestFails.java:79)
	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 org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:45)
	at org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:15)
	at org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:42)
	at org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:20)
	at org.junit.internal.runners.statements.RunBefores.evaluate(RunBefores.java:28)
	at org.junit.internal.runners.statements.RunAfters.evaluate(RunAfters.java:30)
	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.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.junit.rules.RunRules.evaluate(RunRules.java:18)
	at org.junit.runners.ParentRunner.runLeaf(ParentRunner.java:263)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:68)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:47)
	at org.junit.runners.ParentRunner$3.run(ParentRunner.java:231)
	at org.junit.runners.ParentRunner$1.schedule(ParentRunner.java:60)
	at org.junit.runners.ParentRunner.runChildren(ParentRunner.java:229)
	at org.junit.runners.ParentRunner.access$000(ParentRunner.java:50)
	at org.junit.runners.ParentRunner$2.evaluate(ParentRunner.java:222)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.junit.rules.RunRules.evaluate(RunRules.java:18)
	at org.junit.runners.ParentRunner.run(ParentRunner.java:300)
	at com.carrotsearch.ant.tasks.junit4.slave.SlaveMain.execute(SlaveMain.java:199)
	at com.carrotsearch.ant.tasks.junit4.slave.SlaveMain.main(SlaveMain.java:310)
	at com.carrotsearch.ant.tasks.junit4.slave.SlaveMainSafe.main(SlaveMainSafe.java:12)




Build Log:
[...truncated 998 lines...]
   [junit4] Suite: org.apache.lucene.util.TestArrayUtil
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestArrayUtil -Dtests.method=testInvalidElementSizes -Dtests.seed=52D6B2B0583CB5A9 -Dtests.slow=true -Dtests.locale=es_AR -Dtests.timezone=Brazil/West -Dtests.asserts=false -Dtests.file.encoding=UTF-8
   [junit4] ERROR   0.02s | TestArrayUtil.testInvalidElementSizes <<<
   [junit4]    > Throwable #1: java.lang.IllegalArgumentException: requested array size 2147483637 exceeds maximum array in java (2147483635)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([52D6B2B0583CB5A9:192D47F69D4199F3]:0)
   [junit4]    > 	at org.apache.lucene.util.ArrayUtil.oversize(ArrayUtil.java:168)
   [junit4]    > 	at org.apache.lucene.util.TestArrayUtil.testInvalidElementSizes(TestArrayUtil.java:71)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:745)
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene50): {}, docValues:{}, sim=RandomSimilarityProvider(queryNorm=true,coord=crazy): {}, locale=es_AR, timezone=Brazil/West
   [junit4]   2> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.7.0_67 (32-bit)/cpus=2,threads=1,free=148703312,total=297533440
   [junit4]   2> NOTE: All tests run in this JVM: [TestPositiveScoresOnlyCollector, InAfterClass, InBeforeClass, InTestMethod, NonStringProperties, TestSameScoresWithThreads, TestTermVectorsReader, TestMultiValuedNumericRangeQuery, Nested, TestSpanExplanationsOfNonMatches, TestEarlyTermination, TestTieredMergePolicy, TestIndexWriterExceptions2, TestNRTReaderWithThreads, ThrowInUncaught, TestTermRangeFilter, TestRamUsageEstimator, TestFastDecompressionMode, TestMmapDirectory, TestOmitPositions, TestDocInverterPerFieldErrorInfo, TestLucene50CompoundFormat, TestByteBlockPool, TestPrefixFilter, TestTimeLimitingCollector, TestRegexpRandom, TestShardSearching, TestSumDocFreq, TestCachingCollector, TestPayloadSpans, TestPayloads, TestSimpleSearchEquivalence, TestLongBitSet, TestIndexWriterMergePolicy, TestDocValuesIndexing, TestPostingsOffsets, TestNumericTokenStream, TestFieldCacheRewriteMethod, TestUTF32ToUTF8, TestIndexWriterLockRelease, TestSegmentMerger, TestScorerPerf, TestTopScoreDocCollector, TestSparseFixedBitSet, TestSpansAdvanced, TestControlledRealTimeReopenThread, TestCompiledAutomaton, TestAutomatonQuery, TestLucene50SegmentInfoFormat, TestBinaryDocument, TestFSTs, TestIdentityHashSet, TestSpanFirstQuery, TestMultiDocValues, TestAssertingDocValuesFormat, TestBoolean2, TestExceedMaxTermLength, TestRegexpRandom2, TestAllFilesHaveChecksumFooter, TestBasics, TestTransactions, TestMutableValues, TestPayloadNearQuery, Nested2, Nested1, Nested3, TestDocumentsWriterDeleteQueue, TestCodecs, TestMockFilesystems, TestOfflineSorter, TestNumericUtils, TestNoMergeScheduler, TestFieldMaskingSpanQuery, TestCheckIndex, TestSimilarityProvider, TestBinaryDocValuesUpdates, TestBytesRefArray, TestIndexableField, Test2BPostingsBytes, TestSpanExplanations, TestPrefixCodedTerms, TestDocument, TestTwoPhaseCommitTool, TestNeverDelete, TestIOUtils, TestFieldsReader, TestRAMDirectory, TestLucene50TermVectorsFormat, Nested2, Nested, TestStressAdvance, TestSetOnce, TestFilteredQuery, TestDocValuesScoring, Nested, Nested, TestAutomatonQueryUnicode, TestMaxTermFrequency, NestedTeardownChain, NestedSetupChain, TestElevationComparator, TestOrdinalMap, TestSegmentTermEnum, TestPriorityQueue, Before3, Before3, TestMockAnalyzer, TestNamedSPILoader, TestLucene50FieldInfoFormat, TestSimpleExplanationsOfNonMatches, TestLockFactory, TestMultiTermQueryRewrites, TestField, TestLock, TestDocTermOrdsRangeFilter, TestIndexReaderClose, TestFilteredSearch, TestNGramPhraseQuery, TestIndexWriterConfig, TestBooleanQuery, TestToken, TestMultiPhraseQuery, TestPayloadExplanations, TestDocCount, TestTermScorer, TestFilterDirectory, TestRollback, TestMixedDocValuesUpdates, TestFilterIterator, TestSearchAfter, TestForUtil, TestOmitTf, TestFieldCacheTermsFilter, TestDemo, TestBooleanCoord, TestNumericDocValuesUpdates, TestQueryBuilder, TestOperations, TestBooleanOr, TestFlex, Test2BPositions, TestAllFilesHaveCodecHeader, TestLookaheadTokenFilter, TestDocIdSetBuilder, TestSpanMultiTermQueryWrapper, TestConstantScoreQuery, Nested, TestIndexWriterUnicode, TestDirectoryReaderReopen, TestSimpleExplanations, TestDuelingCodecs, Test4GBStoredFields, TestManyFields, TestMergeSchedulerExternal, TestMultiTermConstantScore, TestRecyclingByteBlockAllocator, TestPhraseQuery, TestThreadedForceMerge, TestRollingUpdates, TestCachingTokenFilter, TestIndexWriter, TestSparseFixedBitDocIdSet, TestAutomaton, TestBlockPostingsFormat2, Test2BPagedBytes, TestIndexWriterOutOfFileDescriptors, TestTimSorter, TestDirectory, TestRecyclingIntBlockAllocator, TestBagOfPostings, TestSimilarityBase, TestIndexCommit, TestSegmentReader, TestQueryWrapperFilter, TestStressDeletes, TestUnicodeUtil, TestTermRangeQuery, TestDoc, TestWildcardRandom, TestPrefixRandom, TestLRUFilterCache, TestIndexWriterOutOfMemory, MultiCollectorTest, TestSortedSetSortField, TestSearch, TestBooleanScorer, TestReusableStringReader, TestIndexWriterMerging, TestNoDeletionPolicy, TestTerm, TestSimilarity2, TestParallelTermEnum, TestLucene50StoredFieldsFormat, TestEliasFanoDocIdSet, TestSpansAdvanced2, TestLogMergePolicy, TestParallelCompositeReader, TestConsistentFieldNumbers, TestStressIndexing, TestSpanSearchEquivalence, TestTopDocsCollector, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, TestNumericRangeQuery32, TestPersistentSnapshotDeletionPolicy, TestWeakIdentityMap, TestMatchAllDocsQuery, TestBinaryTerms, TestTermsEnum, TestCompressingTermVectorsFormat, TestDateFilter, TestCompressingStoredFieldsFormat, TestPerFieldDocValuesFormat, TestIndexWriterReader, TestNumericRangeQuery64, TestBytesStore, TestPackedInts, TestIndexWriterWithThreads, TestGraphTokenizers, TestAddIndexes, TestIndexWriterExceptions, TestMultiMMap, TestSearcherManager, TestDeletionPolicy, TestFlushByRamOrCountsPolicy, TestSloppyPhraseQuery, TestIndexWriterDelete, TestNRTThreads, TestAtomicUpdate, TestNorms, TestIndexWriterCommit, TestSearchWithThreads, TestConcurrentMergeScheduler, TestHighCompressionMode, TestDocumentsWriterStallControl, TestTopDocsMerge, TestLongPostings, TestMinimize, TestDocTermOrdsRewriteMethod, TestSnapshotDeletionPolicy, TestIndexWriterForceMerge, TestPerFieldPostingsFormat, TestArrayUtil]
   [junit4] Completed in 1.20s, 13 tests, 1 error <<< FAILURES!

[...truncated 297 lines...]
   [junit4] Suite: org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails
   [junit4]   1> sysout from nested test: 
   [junit4]   1> 
   [junit4]   1> syserr from nested test: NOTE: test params are: codec=Asserting(Lucene50): {}, docValues:{}, sim=RandomSimilarityProvider(queryNorm=true,coord=yes): {}, locale=es_HN, timezone=Africa/Lusaka
   [junit4]   1> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.7.0_67 (32-bit)/cpus=2,threads=1,free=100479536,total=340262912
   [junit4]   1> NOTE: All tests run in this JVM: [TestPositiveScoresOnlyCollector, InAfterClass, InBeforeClass, InTestMethod, NonStringProperties, TestSameScoresWithThreads, TestTermVectorsReader, TestMultiValuedNumericRangeQuery, Nested, TestSpanExplanationsOfNonMatches, TestEarlyTermination, TestTieredMergePolicy, TestIndexWriterExceptions2, TestNRTReaderWithThreads, ThrowInUncaught, TestTermRangeFilter, TestRamUsageEstimator, TestFastDecompressionMode, TestMmapDirectory, TestOmitPositions, TestDocInverterPerFieldErrorInfo, TestLucene50CompoundFormat, TestByteBlockPool, TestPrefixFilter, TestTimeLimitingCollector, TestRegexpRandom, TestShardSearching, TestSumDocFreq, TestCachingCollector, TestPayloadSpans, TestPayloads, TestSimpleSearchEquivalence, TestLongBitSet, TestIndexWriterMergePolicy, TestDocValuesIndexing, TestPostingsOffsets, TestNumericTokenStream, TestFieldCacheRewriteMethod, TestUTF32ToUTF8, TestIndexWriterLockRelease, TestSegmentMerger, TestScorerPerf, TestTopScoreDocCollector, TestSparseFixedBitSet, TestSpansAdvanced, TestControlledRealTimeReopenThread, TestCompiledAutomaton, TestAutomatonQuery, TestLucene50SegmentInfoFormat, TestBinaryDocument, TestFSTs, TestIdentityHashSet, TestSpanFirstQuery, TestMultiDocValues, TestAssertingDocValuesFormat, TestBoolean2, TestExceedMaxTermLength, TestRegexpRandom2, TestAllFilesHaveChecksumFooter, TestBasics, TestTransactions, TestMutableValues, TestPayloadNearQuery, Nested2, Nested1, Nested3, TestDocumentsWriterDeleteQueue, TestCodecs, TestMockFilesystems, TestOfflineSorter, TestNumericUtils, TestNoMergeScheduler, TestFieldMaskingSpanQuery, TestCheckIndex, TestSimilarityProvider, TestBinaryDocValuesUpdates, TestBytesRefArray, TestIndexableField, Test2BPostingsBytes, TestSpanExplanations, TestPrefixCodedTerms, TestDocument, TestTwoPhaseCommitTool, TestNeverDelete, TestIOUtils, TestFieldsReader, TestRAMDirectory, TestLucene50TermVectorsFormat, Nested2, Nested, TestStressAdvance, TestSetOnce, TestFilteredQuery, TestDocValuesScoring, Nested, Nested, TestAutomatonQueryUnicode, TestMaxTermFrequency, NestedTeardownChain, NestedSetupChain, TestElevationComparator, TestOrdinalMap, TestSegmentTermEnum, TestPriorityQueue, Before3, Before3, TestMockAnalyzer, TestNamedSPILoader, TestLucene50FieldInfoFormat, TestSimpleExplanationsOfNonMatches, TestLockFactory, TestMultiTermQueryRewrites, TestField, TestLock, TestDocTermOrdsRangeFilter, TestIndexReaderClose, TestFilteredSearch, TestNGramPhraseQuery, TestIndexWriterConfig, TestBooleanQuery, TestToken, TestMultiPhraseQuery, TestPayloadExplanations, TestDocCount, TestTermScorer, TestFilterDirectory, TestRollback, TestMixedDocValuesUpdates, TestFilterIterator, TestSearchAfter, TestForUtil, TestOmitTf, TestFieldCacheTermsFilter, TestDemo, TestBooleanCoord, TestNumericDocValuesUpdates, TestQueryBuilder, TestOperations, TestBooleanOr, TestFlex, Test2BPositions, TestAllFilesHaveCodecHeader, TestLookaheadTokenFilter, TestDocIdSetBuilder, TestSpanMultiTermQueryWrapper, TestConstantScoreQuery, Nested, TestIndexWriterUnicode, TestDirectoryReaderReopen, TestSimpleExplanations, TestDuelingCodecs, Test4GBStoredFields, TestManyFields, TestMergeSchedulerExternal, TestMultiTermConstantScore, TestRecyclingByteBlockAllocator, TestPhraseQuery, TestThreadedForceMerge, TestRollingUpdates, TestCachingTokenFilter, TestIndexWriter, TestSparseFixedBitDocIdSet, TestAutomaton, TestBlockPostingsFormat2, Test2BPagedBytes, TestIndexWriterOutOfFileDescriptors, TestTimSorter, TestDirectory, TestRecyclingIntBlockAllocator, TestBagOfPostings, TestSimilarityBase, TestIndexCommit, TestSegmentReader, TestQueryWrapperFilter, TestStressDeletes, TestUnicodeUtil, TestTermRangeQuery, TestDoc, TestWildcardRandom, TestPrefixRandom, TestLRUFilterCache, TestIndexWriterOutOfMemory, MultiCollectorTest, TestSortedSetSortField, TestSearch, TestBooleanScorer, TestReusableStringReader, TestIndexWriterMerging, TestNoDeletionPolicy, TestTerm, TestSimilarity2, TestParallelTermEnum, TestLucene50StoredFieldsFormat, TestEliasFanoDocIdSet, TestSpansAdvanced2, TestLogMergePolicy, TestParallelCompositeReader, TestConsistentFieldNumbers, TestStressIndexing, TestSpanSearchEquivalence, TestTopDocsCollector, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, TestNumericRangeQuery32, TestPersistentSnapshotDeletionPolicy, TestWeakIdentityMap, TestMatchAllDocsQuery, TestBinaryTerms, TestTermsEnum, TestCompressingTermVectorsFormat, TestDateFilter, TestCompressingStoredFieldsFormat, TestPerFieldDocValuesFormat, TestIndexWriterReader, TestNumericRangeQuery64, TestBytesStore, TestPackedInts, TestIndexWriterWithThreads, TestGraphTokenizers, TestAddIndexes, TestIndexWriterExceptions, TestMultiMMap, TestSearcherManager, TestDeletionPolicy, TestFlushByRamOrCountsPolicy, TestSloppyPhraseQuery, TestIndexWriterDelete, TestNRTThreads, TestAtomicUpdate, TestNorms, TestIndexWriterCommit, TestSearchWithThreads, TestConcurrentMergeScheduler, TestHighCompressionMode, TestDocumentsWriterStallControl, TestTopDocsMerge, TestLongPostings, TestMinimize, TestDocTermOrdsRewriteMethod, TestSnapshotDeletionPolicy, TestIndexWriterForceMerge, TestPerFieldPostingsFormat, TestArrayUtil, TestLevenshteinAutomata, TestByteSlices, TestBufferedIndexInput, TestDirectoryReader, TestCollectionUtil, TestBagOfPositions, TestOmitNorms, TestFixedBitSet, TestComplexExplanations, TestNRTCachingDirectory, TestIndexWriterNRTIsCurrent, TestPagedBytes, TestCrash, TestMultiThreadTermVectors, TestSegmentTermDocs, TestPerFieldPostingsFormat2, TestSort, TestCustomSearcherSort, TestPayloadTermQuery, TestHugeRamFile, TestBooleanMinShouldMatch, TestTermsEnum2, TestDeterminizeLexicon, TestIndexWriterOnDiskFull, TestSpans, TestCustomNorms, TestMixedCodecs, TestTransactionRollback, TestFastCompressionMode, TestStressIndexing2, TestLazyProxSkipping, TestDeterminism, TestDocsAndPositions, TestRamUsageEstimatorOnWildAnimals, TestFieldCacheRangeFilter, TestTermVectorsWriter, TestCharTermAttributeImpl, TestParallelLeafReader, TestBytesRefHash, TestStressNRT, TestIndexInput, TestSloppyPhraseQuery2, TestDisjunctionMaxQuery, TestForceMergeForever, TestNearSpansOrdered, TestMultiFields, TestDocumentWriter, TestCrashCausesCorruptIndex, TestLiveFieldValues, TestForTooMuchCloning, TestFuzzyQuery, TestWildcard, TestExternalCodecs, TestTermVectors, TestRegexpQuery, TestPerSegmentDeletes, TestIntBlockPool, TestPrefixInBooleanQuery, TestUniqueTermCount, TestComplexExplanationsOfNonMatches, TestSortRandom, TestParallelReaderEmptyIndex, TestTopFieldCollector, TestFileSwitchDirectory, TestSentinelIntSet, TestWindowsMMap, TestMultiLevelSkipList, TestPayloadsOnVectors, TestCachingWrapperFilter, TestFieldValueFilter, TestBooleanQueryVisitSubscorers, TestSearchForDuplicates, TestSizeBoundedForceMerge, TestIndexFileDeleter, TestPrefixQuery, TestDocIdSet, TestSubScorerFreqs, TestConjunctions, TestPositionIncrement, TestDateSort, TestSimilarity, TestVirtualMethod, TestRollingBuffer, TestSmallFloat, TestFilterLeafReader, TestDateTools, TestCharsRef, Test2BPostings, TestSameTokenSamePosition, TestAttributeSource, TestTotalHitCountCollector, TestMockDirectoryWrapper, TestIsCurrent, TestNoMergePolicy, TestPhrasePrefixQuery, TestBytesRef, Nested1, Nested2]
   [junit4]   1> NOTE: reproduce with: ant test  -Dtestcase=Nested2 -Dtests.seed=52D6B2B0583CB5A9 -Dtests.slow=true -Dtests.locale=es_HN -Dtests.timezone=Africa/Lusaka -Dtests.asserts=false -Dtests.file.encoding=UTF-8
   [junit4]   1> 
   [junit4] ERROR   0.07s | TestLeaveFilesIfTestFails.testWindowsUnremovableFile <<<
   [junit4]    > Throwable #1: java.nio.file.AccessDeniedException: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-52D6B2B0583CB5A9-001\leftover-001\child.locked
   [junit4]    > 	at sun.nio.fs.WindowsException.translateToIOException(WindowsException.java:83)
   [junit4]    > 	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:97)
   [junit4]    > 	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:102)
   [junit4]    > 	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:53)
   [junit4]    > 	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:38)
   [junit4]    > 	at org.apache.lucene.mockfile.WindowsFS.getKey(WindowsFS.java:57)
   [junit4]    > 	at org.apache.lucene.mockfile.WindowsFS.onClose(WindowsFS.java:77)
   [junit4]    > 	at org.apache.lucene.mockfile.HandleTrackingFS$5.close(HandleTrackingFS.java:210)
   [junit4]    > 	at org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile(TestLeaveFilesIfTestFails.java:79)
   [junit4] Completed in 0.12s, 2 tests, 1 error <<< FAILURES!

[...truncated 270 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:525: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:473: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:61: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\extra-targets.xml:39: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build.xml:49: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:1363: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:970: There were test failures: 405 suites, 3049 tests, 2 errors, 62 ignored (52 assumptions)

Total time: 11 minutes 49 seconds
Build step 'Invoke Ant' marked build as failure
[description-setter] Description set: Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: false)
Archiving artifacts
Recording test results
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any



[JENKINS] Lucene-Solr-5.x-Windows (32bit/jdk1.8.0_20) - Build # 4357 - Still Failing!

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: http://jenkins.thetaphi.de/job/Lucene-Solr-5.x-Windows/4357/
Java: 32bit/jdk1.8.0_20 -client -XX:+UseParallelGC (asserts: true)

No tests ran.

Build Log:
[...truncated 9224 lines...]
FATAL: java.io.IOException: Unexpected termination of the channel
hudson.remoting.RequestAbortedException: java.io.IOException: Unexpected termination of the channel
	at hudson.remoting.Request.abort(Request.java:295)
	at hudson.remoting.Channel.terminate(Channel.java:814)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:69)
	at ......remote call to Windows VBOX(Native Method)
	at hudson.remoting.Channel.attachCallSiteStackTrace(Channel.java:1356)
	at hudson.remoting.Request.call(Request.java:171)
	at hudson.remoting.Channel.call(Channel.java:751)
	at hudson.remoting.RemoteInvocationHandler.invoke(RemoteInvocationHandler.java:179)
	at com.sun.proxy.$Proxy76.join(Unknown Source)
	at hudson.Launcher$RemoteLauncher$ProcImpl.join(Launcher.java:979)
	at hudson.Launcher$ProcStarter.join(Launcher.java:388)
	at hudson.tasks.Ant.perform(Ant.java:217)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:770)
	at hudson.model.Build$BuildExecution.build(Build.java:199)
	at hudson.model.Build$BuildExecution.doRun(Build.java:160)
	at hudson.model.AbstractBuild$AbstractBuildExecution.run(AbstractBuild.java:533)
	at hudson.model.Run.execute(Run.java:1759)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:89)
	at hudson.model.Executor.run(Executor.java:240)
Caused by: java.io.IOException: Unexpected termination of the channel
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:50)
Caused by: java.io.EOFException
	at java.io.ObjectInputStream$PeekInputStream.readFully(ObjectInputStream.java:2325)
	at java.io.ObjectInputStream$BlockDataInputStream.readShort(ObjectInputStream.java:2794)
	at java.io.ObjectInputStream.readStreamHeader(ObjectInputStream.java:801)
	at java.io.ObjectInputStream.<init>(ObjectInputStream.java:299)
	at hudson.remoting.ObjectInputStreamEx.<init>(ObjectInputStreamEx.java:40)
	at hudson.remoting.AbstractSynchronousByteArrayCommandTransport.read(AbstractSynchronousByteArrayCommandTransport.java:34)
	at hudson.remoting.SynchronousCommandTransport$ReaderThread.run(SynchronousCommandTransport.java:48)



[JENKINS] Lucene-Solr-5.x-Windows (32bit/jdk1.7.0_67) - Build # 4356 - Still Failing!

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: http://jenkins.thetaphi.de/job/Lucene-Solr-5.x-Windows/4356/
Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: true)

1 tests failed.
FAILED:  junit.framework.TestSuite.org.apache.solr.schema.TestCloudManagedSchema

Error Message:
1 thread leaked from SUITE scope at org.apache.solr.schema.TestCloudManagedSchema:     1) Thread[id=17475, name=SessionTracker, state=TIMED_WAITING, group=TGRP-TestCloudManagedSchema]         at java.lang.Object.wait(Native Method)         at org.apache.zookeeper.server.SessionTrackerImpl.run(SessionTrackerImpl.java:146)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: 1 thread leaked from SUITE scope at org.apache.solr.schema.TestCloudManagedSchema: 
   1) Thread[id=17475, name=SessionTracker, state=TIMED_WAITING, group=TGRP-TestCloudManagedSchema]
        at java.lang.Object.wait(Native Method)
        at org.apache.zookeeper.server.SessionTrackerImpl.run(SessionTrackerImpl.java:146)
	at __randomizedtesting.SeedInfo.seed([BC6BE21FDE93BCBD]:0)




Build Log:
[...truncated 10211 lines...]
   [junit4] Suite: org.apache.solr.schema.TestCloudManagedSchema
   [junit4]   2> Creating dataDir: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\init-core-data-001
   [junit4]   2> 6809656 T17472 oas.SolrTestCaseJ4.buildSSLConfig Randomized ssl (true) and clientAuth (false)
   [junit4]   2> 6809656 T17472 oas.BaseDistributedSearchTestCase.initHostContext Setting hostContext system property: /xl_yb/hh
   [junit4]   2> 6809661 T17472 oas.SolrTestCaseJ4.setUp ###Starting testDistribSearch
   [junit4]   2> 6809663 T17472 oasc.ZkTestServer.run STARTING ZK TEST SERVER
   [junit4]   1> client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 6809664 T17473 oasc.ZkTestServer$ZKServerMain.runFromConfig Starting server
   [junit4]   2> 6809765 T17472 oasc.ZkTestServer.run start zk server on port:56161
   [junit4]   2> 6809765 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6809767 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6809772 T17480 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1ed51e1 name:ZooKeeperConnection Watcher:127.0.0.1:56161 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6809773 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6809774 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6809774 T17472 oascc.SolrZkClient.makePath makePath: /solr
   [junit4]   2> 6809778 T17474 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x14a00b728370000, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:228)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:208)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:745)
   [junit4]   2> 
   [junit4]   2> 6809778 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6809782 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6809785 T17483 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@960f73 name:ZooKeeperConnection Watcher:127.0.0.1:56161/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6809785 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6809785 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6809785 T17472 oascc.SolrZkClient.makePath makePath: /collections/collection1
   [junit4]   2> 6809789 T17472 oascc.SolrZkClient.makePath makePath: /collections/collection1/shards
   [junit4]   2> 6809794 T17472 oascc.SolrZkClient.makePath makePath: /collections/control_collection
   [junit4]   2> 6809799 T17472 oascc.SolrZkClient.makePath makePath: /collections/control_collection/shards
   [junit4]   2> 6809805 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\solrconfig-managed-schema.xml to /configs/conf1/solrconfig.xml
   [junit4]   2> 6809806 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/solrconfig.xml
   [junit4]   2> 6809813 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\schema.xml to /configs/conf1/schema.xml
   [junit4]   2> 6809813 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/schema.xml
   [junit4]   2> 6809819 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\solrconfig.snippet.randomindexconfig.xml to /configs/conf1/solrconfig.snippet.randomindexconfig.xml
   [junit4]   2> 6809819 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/solrconfig.snippet.randomindexconfig.xml
   [junit4]   2> 6809824 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\stopwords.txt to /configs/conf1/stopwords.txt
   [junit4]   2> 6809825 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/stopwords.txt
   [junit4]   2> 6809830 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\protwords.txt to /configs/conf1/protwords.txt
   [junit4]   2> 6809830 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/protwords.txt
   [junit4]   2> 6809838 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\currency.xml to /configs/conf1/currency.xml
   [junit4]   2> 6809839 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/currency.xml
   [junit4]   2> 6809846 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\enumsConfig.xml to /configs/conf1/enumsConfig.xml
   [junit4]   2> 6809847 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/enumsConfig.xml
   [junit4]   2> 6809852 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\open-exchange-rates.json to /configs/conf1/open-exchange-rates.json
   [junit4]   2> 6809853 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/open-exchange-rates.json
   [junit4]   2> 6809858 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\mapping-ISOLatin1Accent.txt to /configs/conf1/mapping-ISOLatin1Accent.txt
   [junit4]   2> 6809859 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/mapping-ISOLatin1Accent.txt
   [junit4]   2> 6809863 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\old_synonyms.txt to /configs/conf1/old_synonyms.txt
   [junit4]   2> 6809864 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/old_synonyms.txt
   [junit4]   2> 6809869 T17472 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\synonyms.txt to /configs/conf1/synonyms.txt
   [junit4]   2> 6809870 T17472 oascc.SolrZkClient.makePath makePath: /configs/conf1/synonyms.txt
   [junit4]   2> 6809876 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6809878 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6809882 T17486 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1dd7af9 name:ZooKeeperConnection Watcher:127.0.0.1:56161/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6809884 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6809885 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6811251 T17472 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 6811258 T17472 oejus.SslContextFactory.doStart Enabled Protocols [SSLv2Hello, SSLv3, TLSv1, TLSv1.1, TLSv1.2] of [SSLv2Hello, SSLv3, TLSv1, TLSv1.1, TLSv1.2]
   [junit4]   2> 6811260 T17472 oejs.AbstractConnector.doStart Started SslSelectChannelConnector@127.0.0.1:?????
   [junit4]   2> 6811262 T17472 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 6811262 T17472 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 6811262 T17472 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002
   [junit4]   2> 6811262 T17472 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\'
   [junit4]   2> 6811286 T17472 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\solr.xml
   [junit4]   2> 6811325 T17472 oasc.CoreContainer.<init> New CoreContainer 264149
   [junit4]   2> 6811325 T17472 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\]
   [junit4]   2> 6811326 T17472 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 6811326 T17472 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 6811326 T17472 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 6811326 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 6811326 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxConnections to: 10000
   [junit4]   2> 6811326 T17472 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 6811327 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 6811327 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 6811327 T17472 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 6811327 T17472 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 6811329 T17472 oasu.UpdateShardHandler.<init> Creating UpdateShardHandler HTTP client with params: socketTimeout=340000&connTimeout=45000&retry=false
   [junit4]   2> 6811331 T17472 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 6811331 T17472 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 6811331 T17472 oasc.CoreContainer.load Host Name: 127.0.0.1
   [junit4]   2> 6811331 T17472 oasc.ZkContainer.initZooKeeper Zookeeper client=127.0.0.1:56161/solr
   [junit4]   2> 6811332 T17472 oasc.ZkController.checkChrootPath zkHost includes chroot
   [junit4]   2> 6811332 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6811334 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6811336 T17498 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@4ae179 name:ZooKeeperConnection Watcher:127.0.0.1:56161 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6811337 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6811337 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6811341 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6811343 T17501 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@e0788f name:ZooKeeperConnection Watcher:127.0.0.1:56161/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6811343 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6811346 T17472 oascc.SolrZkClient.makePath makePath: /overseer/queue
   [junit4]   2> 6811352 T17472 oascc.SolrZkClient.makePath makePath: /overseer/collection-queue-work
   [junit4]   2> 6811358 T17472 oascc.SolrZkClient.makePath makePath: /overseer/collection-map-running
   [junit4]   2> 6811362 T17472 oascc.SolrZkClient.makePath makePath: /overseer/collection-map-completed
   [junit4]   2> 6811367 T17472 oascc.SolrZkClient.makePath makePath: /overseer/collection-map-failure
   [junit4]   2> 6811373 T17472 oascc.SolrZkClient.makePath makePath: /live_nodes
   [junit4]   2> 6811376 T17472 oasc.ZkController.createEphemeralLiveNode Register node as live in ZooKeeper:/live_nodes/127.0.0.1:56171_xl_yb%2Fhh
   [junit4]   2> 6811377 T17472 oascc.SolrZkClient.makePath makePath: /live_nodes/127.0.0.1:56171_xl_yb%2Fhh
   [junit4]   2> 6811382 T17472 oascc.SolrZkClient.makePath makePath: /overseer_elect
   [junit4]   2> 6811386 T17472 oascc.SolrZkClient.makePath makePath: /overseer_elect/election
   [junit4]   2> 6811390 T17472 oasc.Overseer.close Overseer (id=null) closing
   [junit4]   2> 6811393 T17472 oasc.OverseerElectionContext.runLeaderProcess I am going to be the leader 127.0.0.1:56171_xl_yb%2Fhh
   [junit4]   2> 6811394 T17472 oascc.SolrZkClient.makePath makePath: /overseer_elect/leader
   [junit4]   2> 6811398 T17472 oasc.Overseer.start Overseer (id=92887528968224772-127.0.0.1:56171_xl_yb%2Fhh-n_0000000000) starting
   [junit4]   2> 6811402 T17472 oascc.SolrZkClient.makePath makePath: /overseer/queue-work
   [junit4]   2> 6811419 T17472 oasc.OverseerAutoReplicaFailoverThread.<init> Starting OverseerAutoReplicaFailoverThread autoReplicaFailoverWorkLoopDelay=10000 autoReplicaFailoverWaitAfterExpiration=30000 autoReplicaFailoverBadNodeExpiration=60000
   [junit4]   2> 6811421 T17503 oasc.OverseerCollectionProcessor.run Process current queue of collection creations
   [junit4]   2> 6811422 T17472 oascc.SolrZkClient.makePath makePath: /clusterstate.json
   [junit4]   2> 6811426 T17472 oascc.SolrZkClient.makePath makePath: /aliases.json
   [junit4]   2> 6811429 T17472 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 6811438 T17502 oasc.Overseer$ClusterStateUpdater.run Starting to work on the main queue
   [junit4]   2> 6811444 T17505 oasc.ZkController.publish publishing core=collection1 state=down collection=control_collection
   [junit4]   2> 6811445 T17505 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 6811446 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6811446 T17505 oasc.ZkController.waitForCoreNodeName look for our core node name
   [junit4]   2> 6811454 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "shard":null,
   [junit4]   2> 	  "state":"down",
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56171/xl_yb/hh",
   [junit4]   2> 	  "numShards":"1",
   [junit4]   2> 	  "collection":"control_collection",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:56171_xl_yb%2Fhh"}
   [junit4]   2> 6811454 T17502 oasc.Overseer$ClusterStateUpdater.createCollection Create collection control_collection with shards [shard1]
   [junit4]   2> 6811455 T17502 oasc.Overseer$ClusterStateUpdater.createCollection state version control_collection 1
   [junit4]   2> 6811455 T17502 oasc.Overseer$ClusterStateUpdater.updateState Assigning new node to shard shard=shard1
   [junit4]   2> 6811460 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 1)
   [junit4]   2> 6812447 T17505 oasc.ZkController.waitForShardId waiting to find shard id in clusterstate for collection1
   [junit4]   2> 6812448 T17505 oasc.ZkController.createCollectionZkNode Check for collection zkNode:control_collection
   [junit4]   2> 6812451 T17505 oasc.ZkController.createCollectionZkNode Collection zkNode exists
   [junit4]   2> 6812452 T17505 oascc.ZkStateReader.readConfigName Load collection config from:/collections/control_collection
   [junit4]   2> 6812456 T17505 oascc.ZkStateReader.readConfigName path=/collections/control_collection configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 6812457 T17505 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\'
   [junit4]   2> 6812464 T17505 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-002/collection1/lib/.svn/' to classloader
   [junit4]   2> 6812468 T17505 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-002/collection1/lib/classes/' to classloader
   [junit4]   2> 6812471 T17505 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-002/collection1/lib/README' to classloader
   [junit4]   2> 6812501 T17505 oasc.ZkController.watchZKConfDir watch zkdir /configs/conf1
   [junit4]   2> 6812507 T17505 oasc.Config.<init> loaded config solrconfig.xml with version 0 
   [junit4]   2> 6812539 T17505 oasc.SolrConfig.<init> Using Lucene MatchVersion: 5.0.0
   [junit4]   2> 6812569 T17505 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 6812571 T17505 oass.ManagedIndexSchemaFactory.create The schema is configured as managed, but managed schema resource managed-schema not found - loading non-managed schema schema.xml instead
   [junit4]   2> 6812573 T17505 oass.IndexSchema.readSchema Reading Solr Schema from /configs/conf1/schema.xml
   [junit4]   2> 6812587 T17505 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 6813029 T17505 oass.OpenExchangeRatesOrgProvider.init Initialized with rates=open-exchange-rates.json, refreshInterval=1440.
   [junit4]   2> 6813035 T17505 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 6813037 T17505 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 6813054 T17505 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 6813061 T17505 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 6813067 T17505 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 6813069 T17505 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 6813069 T17505 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 6813069 T17505 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 6813071 T17505 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 6813071 T17505 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 6813074 T17505 oass.ManagedIndexSchema.persistManagedSchemaToZooKeeper Created and persisted managed schema znode at /configs/conf1/managed-schema
   [junit4]   2> 6813077 T17505 oascc.SolrZkClient.makePath makePath: /configs/conf1/schema.xml.bak
   [junit4]   2> 6813085 T17505 oass.ManagedIndexSchemaFactory.zkUgradeToManagedSchema After upgrading to managed schema in ZooKeeper, renamed the non-managed schema /configs/conf1/schema.xml to /configs/conf1/schema.xml.bak
   [junit4]   2> 6813085 T17505 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from collection control_collection
   [junit4]   2> 6813085 T17505 oasc.SolrCore.initDirectoryFactory solr.NRTCachingDirectoryFactory
   [junit4]   2> 6813086 T17505 oasc.SolrCore.<init> [collection1] Opening new SolrCore at C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\, dataDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data\
   [junit4]   2> 6813087 T17505 oasc.SolrCore.<init> JMX monitoring not detected for core: collection1
   [junit4]   2> 6813089 T17505 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data
   [junit4]   2> 6813090 T17505 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data\index/
   [junit4]   2> 6813091 T17505 oasc.SolrCore.initIndex WARN [collection1] Solr index directory 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data\index' doesn't exist. Creating new index...
   [junit4]   2> 6813093 T17505 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data\index
   [junit4]   2> 6813093 T17505 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogDocMergePolicy: [LogDocMergePolicy: minMergeSize=1000, mergeFactor=28, maxMergeSize=9223372036854775807, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=false, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.0]
   [junit4]   2> 6813098 T17505 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=NRTCachingDirectory(SimpleFSDirectory@C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data\index lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@e91a17; maxCacheMB=48.0 maxMergeSizeMB=4.0),segFN=segments_1,generation=1}
   [junit4]   2> 6813098 T17505 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 6813100 T17505 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 6813100 T17505 oasc.RequestHandlers.initHandlersFromConfig created /update: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6813100 T17505 oasc.RequestHandlers.initHandlersFromConfig created /update/json: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6813101 T17505 oasc.RequestHandlers.initHandlersFromConfig created /update/csv: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6813101 T17505 oasc.RequestHandlers.initHandlersFromConfig created /update/json/docs: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6813102 T17505 oasc.RequestHandlers.initHandlersFromConfig created /config: org.apache.solr.handler.SolrConfigHandler
   [junit4]   2> 6813102 T17505 oasc.RequestHandlers.initHandlersFromConfig created /replication: org.apache.solr.handler.ReplicationHandler
   [junit4]   2> 6813103 T17505 oasc.RequestHandlers.initHandlersFromConfig created /get: org.apache.solr.handler.RealTimeGetHandler
   [junit4]   2> 6813103 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/luke: org.apache.solr.handler.admin.LukeRequestHandler
   [junit4]   2> 6813104 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/system: org.apache.solr.handler.admin.SystemInfoHandler
   [junit4]   2> 6813104 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/mbeans: org.apache.solr.handler.admin.SolrInfoMBeanHandler
   [junit4]   2> 6813105 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/plugins: org.apache.solr.handler.admin.PluginInfoHandler
   [junit4]   2> 6813105 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/threads: org.apache.solr.handler.admin.ThreadDumpHandler
   [junit4]   2> 6813106 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/properties: org.apache.solr.handler.admin.PropertiesRequestHandler
   [junit4]   2> 6813106 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/logging: org.apache.solr.handler.admin.LoggingHandler
   [junit4]   2> 6813107 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: org.apache.solr.handler.admin.ShowFileRequestHandler
   [junit4]   2> 6813107 T17505 oasc.RequestHandlers.initHandlersFromConfig created /admin/ping: org.apache.solr.handler.PingRequestHandler
   [junit4]   2> 6813107 T17505 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 6813108 T17505 oasc.RequestHandlers.initHandlersFromConfig created /dump: DumpRequestHandler
   [junit4]   2> 6813118 T17505 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6813120 T17505 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6813123 T17505 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6813126 T17505 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6813126 T17505 oasc.RequestHandlers.applyInitParams WARN INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,args = {defaults={a=A,b=B}}}
   [junit4]   2> 6813130 T17505 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 6813130 T17505 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 6813130 T17505 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=47, maxMergeAtOnceExplicit=28, maxMergedSegmentMB=2.6611328125, floorSegmentMB=0.3896484375, forceMergeDeletesPctAllowed=8.818717996916746, segmentsPerTier=14.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.0
   [junit4]   2> 6813132 T17505 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=NRTCachingDirectory(SimpleFSDirectory@C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-002\collection1\data\index lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@e91a17; maxCacheMB=48.0 maxMergeSizeMB=4.0),segFN=segments_1,generation=1}
   [junit4]   2> 6813132 T17505 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 6813132 T17505 oass.SolrIndexSearcher.<init> Opening Searcher@79893a[collection1] main
   [junit4]   2> 6813133 T17505 oascc.ZkStateReader.readConfigName Load collection config from:/collections/control_collection
   [junit4]   2> 6813134 T17505 oascc.ZkStateReader.readConfigName path=/collections/control_collection configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 6813135 T17505 oasr.ManagedResourceStorage.newStorageIO Setting up ZooKeeper-based storage for the RestManager with znodeBase: /configs/conf1
   [junit4]   2> 6813135 T17505 oasr.ManagedResourceStorage$ZooKeeperStorageIO.configure Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 6813136 T17505 oasr.RestManager.init Initializing RestManager with initArgs: {}
   [junit4]   2> 6813136 T17505 oasr.ManagedResourceStorage.load Reading _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6813137 T17505 oasr.ManagedResourceStorage$ZooKeeperStorageIO.openInputStream No data found for znode /configs/conf1/_rest_managed.json
   [junit4]   2> 6813137 T17505 oasr.ManagedResourceStorage.load Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6813138 T17505 oascc.SolrZkClient.makePath makePath: /configs/conf1/_rest_managed.json
   [junit4]   2> 6813142 T17505 oasr.ManagedResourceStorage$ZooKeeperStorageIO$1.close Wrote 38 bytes to new znode /configs/conf1/_rest_managed.json
   [junit4]   2> 6813142 T17505 oasr.ManagedResourceStorage$JsonStorage.store Saved JSON object to path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6813143 T17505 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 6813149 T17505 oass.ZkIndexSchemaReader.createSchemaWatcher Creating ZooKeeper watch for the managed schema at /configs/conf1/managed-schema
   [junit4]   2> 6813154 T17505 oash.ReplicationHandler.inform Commits will be reserved for  10000
   [junit4]   2> 6813154 T17505 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 6813154 T17506 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@79893a[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 6813156 T17509 oasc.ZkController.register Register replica - core:collection1 address:https://127.0.0.1:56171/xl_yb/hh collection:control_collection shard:shard1
   [junit4]   2> 6813157 T17472 oass.SolrDispatchFilter.init user.dir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0
   [junit4]   2> 6813157 T17472 oass.SolrDispatchFilter.init SolrDispatchFilter.init() done
   [junit4]   2> 6813159 T17509 oascc.SolrZkClient.makePath makePath: /collections/control_collection/leader_elect/shard1/election
   [junit4]   2> 6813169 T17509 oasc.ShardLeaderElectionContext.runLeaderProcess Running the leader process for shard shard1
   [junit4]   2> 6813172 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6813172 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6813173 T17509 oasc.ShardLeaderElectionContext.waitForReplicasToComeUp Enough replicas found to continue.
   [junit4]   2> 6813173 T17509 oasc.ShardLeaderElectionContext.runLeaderProcess I may be the new leader - try and sync
   [junit4]   2> ASYNC  NEW_CORE C2575 name=collection1 org.apache.solr.core.SolrCore@39fdba url=https://127.0.0.1:56171/xl_yb/hh/collection1 node=127.0.0.1:56171_xl_yb%2Fhh C2575_STATE=coll:control_collection core:collection1 props:{state=down, core=collection1, base_url=https://127.0.0.1:56171/xl_yb/hh, node_name=127.0.0.1:56171_xl_yb%2Fhh}
   [junit4]   2> 6813174 T17509 C2575 P56171 oasc.SyncStrategy.sync Sync replicas to https://127.0.0.1:56171/xl_yb/hh/collection1/
   [junit4]   2> 6813174 T17509 C2575 P56171 oasc.SyncStrategy.syncReplicas Sync Success - now sync replicas to me
   [junit4]   2> 6813174 T17509 C2575 P56171 oasc.SyncStrategy.syncToMe https://127.0.0.1:56171/xl_yb/hh/collection1/ has no replicas
   [junit4]   2> 6813174 T17509 oasc.ShardLeaderElectionContext.runLeaderProcess I am the new leader: https://127.0.0.1:56171/xl_yb/hh/collection1/ shard1
   [junit4]   2> 6813175 T17509 oascc.SolrZkClient.makePath makePath: /collections/control_collection/leaders/shard1
   [junit4]   2> 6813176 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6813178 T17512 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@17d24aa name:ZooKeeperConnection Watcher:127.0.0.1:56161/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6813179 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6813179 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6813182 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "operation":"leader",
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "collection":"control_collection"}
   [junit4]   2> 6813182 T17472 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 6813187 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 0)
   [junit4]   2> 6813187 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 1)
   [junit4]   2> 6813189 T17472 oasc.ChaosMonkey.monkeyLog monkey: init - expire sessions:false cause connection loss:false
   [junit4]   2> 6813201 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "operation":"leader",
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "collection":"control_collection",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56171/xl_yb/hh",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "state":"active"}
   [junit4]   2> 6813204 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6813307 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 1)
   [junit4]   2> 6813308 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 1)
   [junit4]   2> 6813344 T17509 oasc.ZkController.register We are https://127.0.0.1:56171/xl_yb/hh/collection1/ and leader is https://127.0.0.1:56171/xl_yb/hh/collection1/
   [junit4]   2> 6813344 T17509 oasc.ZkController.register No LogReplay needed for core=collection1 baseURL=https://127.0.0.1:56171/xl_yb/hh
   [junit4]   2> 6813344 T17509 oasc.ZkController.checkRecovery I am the leader, no recovery necessary
   [junit4]   2> 6813344 T17509 oasc.ZkController.publish publishing core=collection1 state=active collection=control_collection
   [junit4]   2> 6813344 T17509 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 6813346 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6813358 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "state":"active",
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "core_node_name":"core_node1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56171/xl_yb/hh",
   [junit4]   2> 	  "numShards":"2",
   [junit4]   2> 	  "collection":"control_collection",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:56171_xl_yb%2Fhh"}
   [junit4]   2> 6813463 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 1)
   [junit4]   2> 6813463 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 1)
   [junit4]   2> 6814512 T17472 oasc.AbstractFullDistribZkTestBase.createJettys create jetty 1
   [junit4]   2> 6814512 T17472 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 6814518 T17472 oejus.SslContextFactory.doStart Enabled Protocols [SSLv2Hello, SSLv3, TLSv1, TLSv1.1, TLSv1.2] of [SSLv2Hello, SSLv3, TLSv1, TLSv1.1, TLSv1.2]
   [junit4]   2> 6814519 T17472 oejs.AbstractConnector.doStart Started SslSelectChannelConnector@127.0.0.1:?????
   [junit4]   2> 6814522 T17472 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 6814522 T17472 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 6814523 T17472 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003
   [junit4]   2> 6814523 T17472 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\'
   [junit4]   2> 6814544 T17472 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\solr.xml
   [junit4]   2> 6814591 T17472 oasc.CoreContainer.<init> New CoreContainer 30285722
   [junit4]   2> 6814591 T17472 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\]
   [junit4]   2> 6814592 T17472 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 6814592 T17472 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 6814592 T17472 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 6814592 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 6814592 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxConnections to: 10000
   [junit4]   2> 6814593 T17472 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 6814593 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 6814593 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 6814593 T17472 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 6814593 T17472 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 6814597 T17472 oasu.UpdateShardHandler.<init> Creating UpdateShardHandler HTTP client with params: socketTimeout=340000&connTimeout=45000&retry=false
   [junit4]   2> 6814599 T17472 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 6814600 T17472 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 6814600 T17472 oasc.CoreContainer.load Host Name: 127.0.0.1
   [junit4]   2> 6814600 T17472 oasc.ZkContainer.initZooKeeper Zookeeper client=127.0.0.1:56161/solr
   [junit4]   2> 6814600 T17472 oasc.ZkController.checkChrootPath zkHost includes chroot
   [junit4]   2> 6814600 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6814602 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6814607 T17524 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@a57642 name:ZooKeeperConnection Watcher:127.0.0.1:56161 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6814608 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6814608 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6814610 T17474 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x14a00b728370006, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:228)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:208)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:745)
   [junit4]   2> 
   [junit4]   2> 6814611 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6814613 T17527 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1d3bf2 name:ZooKeeperConnection Watcher:127.0.0.1:56161/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6814614 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6814626 T17472 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 6815635 T17472 oasc.ZkController.createEphemeralLiveNode Register node as live in ZooKeeper:/live_nodes/127.0.0.1:56183_xl_yb%2Fhh
   [junit4]   2> 6815637 T17472 oascc.SolrZkClient.makePath makePath: /live_nodes/127.0.0.1:56183_xl_yb%2Fhh
   [junit4]   2> 6815650 T17472 oasc.Overseer.close Overseer (id=null) closing
   [junit4]   2> 6815661 T17528 oasc.ZkController.publish publishing core=collection1 state=down collection=collection1
   [junit4]   2> 6815661 T17528 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 6815663 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6815663 T17528 oasc.ZkController.waitForCoreNodeName look for our core node name
   [junit4]   2> 6815672 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "shard":null,
   [junit4]   2> 	  "state":"down",
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56183/xl_yb/hh",
   [junit4]   2> 	  "numShards":"2",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:56183_xl_yb%2Fhh"}
   [junit4]   2> 6815672 T17502 oasc.Overseer$ClusterStateUpdater.createCollection Create collection collection1 with shards [shard1, shard2]
   [junit4]   2> 6815673 T17502 oasc.Overseer$ClusterStateUpdater.createCollection state version collection1 1
   [junit4]   2> 6815674 T17502 oasc.Overseer$ClusterStateUpdater.updateState Assigning new node to shard shard=shard1
   [junit4]   2> 6815679 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6815679 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6815679 T17527 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6816664 T17528 oasc.ZkController.waitForShardId waiting to find shard id in clusterstate for collection1
   [junit4]   2> 6816665 T17528 oasc.ZkController.createCollectionZkNode Check for collection zkNode:collection1
   [junit4]   2> 6816668 T17528 oasc.ZkController.createCollectionZkNode Collection zkNode exists
   [junit4]   2> 6816668 T17528 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 6816673 T17528 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 6816674 T17528 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\'
   [junit4]   2> 6816682 T17528 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-003/collection1/lib/.svn/' to classloader
   [junit4]   2> 6816686 T17528 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-003/collection1/lib/classes/' to classloader
   [junit4]   2> 6816688 T17528 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-003/collection1/lib/README' to classloader
   [junit4]   2> 6816717 T17528 oasc.ZkController.watchZKConfDir watch zkdir /configs/conf1
   [junit4]   2> 6816723 T17528 oasc.Config.<init> loaded config solrconfig.xml with version 0 
   [junit4]   2> 6816754 T17528 oasc.SolrConfig.<init> Using Lucene MatchVersion: 5.0.0
   [junit4]   2> 6816782 T17528 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 6816785 T17528 oass.IndexSchema.readSchema Reading Solr Schema from /configs/conf1/managed-schema
   [junit4]   2> 6816797 T17528 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 6817215 T17528 oass.OpenExchangeRatesOrgProvider.init Initialized with rates=open-exchange-rates.json, refreshInterval=1440.
   [junit4]   2> 6817221 T17528 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 6817223 T17528 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 6817226 T17528 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 6817232 T17528 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 6817246 T17528 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 6817247 T17528 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 6817248 T17528 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 6817249 T17528 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 6817251 T17528 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 6817251 T17528 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 6817255 T17528 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from collection collection1
   [junit4]   2> 6817256 T17528 oasc.SolrCore.initDirectoryFactory solr.NRTCachingDirectoryFactory
   [junit4]   2> 6817257 T17528 oasc.SolrCore.<init> [collection1] Opening new SolrCore at ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\, dataDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data\
   [junit4]   2> 6817257 T17528 oasc.SolrCore.<init> JMX monitoring not detected for core: collection1
   [junit4]   2> 6817259 T17528 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data
   [junit4]   2> 6817260 T17528 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data\index/
   [junit4]   2> 6817262 T17528 oasc.SolrCore.initIndex WARN [collection1] Solr index directory 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data\index' doesn't exist. Creating new index...
   [junit4]   2> 6817263 T17528 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data\index
   [junit4]   2> 6817264 T17528 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogDocMergePolicy: [LogDocMergePolicy: minMergeSize=1000, mergeFactor=28, maxMergeSize=9223372036854775807, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=false, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.0]
   [junit4]   2> 6817269 T17528 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=NRTCachingDirectory(SimpleFSDirectory@C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data\index lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@64ae1e; maxCacheMB=48.0 maxMergeSizeMB=4.0),segFN=segments_1,generation=1}
   [junit4]   2> 6817270 T17528 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 6817272 T17528 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 6817272 T17528 oasc.RequestHandlers.initHandlersFromConfig created /update: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6817273 T17528 oasc.RequestHandlers.initHandlersFromConfig created /update/json: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6817273 T17528 oasc.RequestHandlers.initHandlersFromConfig created /update/csv: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6817274 T17528 oasc.RequestHandlers.initHandlersFromConfig created /update/json/docs: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6817274 T17528 oasc.RequestHandlers.initHandlersFromConfig created /config: org.apache.solr.handler.SolrConfigHandler
   [junit4]   2> 6817275 T17528 oasc.RequestHandlers.initHandlersFromConfig created /replication: org.apache.solr.handler.ReplicationHandler
   [junit4]   2> 6817275 T17528 oasc.RequestHandlers.initHandlersFromConfig created /get: org.apache.solr.handler.RealTimeGetHandler
   [junit4]   2> 6817276 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/luke: org.apache.solr.handler.admin.LukeRequestHandler
   [junit4]   2> 6817278 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/system: org.apache.solr.handler.admin.SystemInfoHandler
   [junit4]   2> 6817278 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/mbeans: org.apache.solr.handler.admin.SolrInfoMBeanHandler
   [junit4]   2> 6817279 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/plugins: org.apache.solr.handler.admin.PluginInfoHandler
   [junit4]   2> 6817279 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/threads: org.apache.solr.handler.admin.ThreadDumpHandler
   [junit4]   2> 6817279 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/properties: org.apache.solr.handler.admin.PropertiesRequestHandler
   [junit4]   2> 6817280 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/logging: org.apache.solr.handler.admin.LoggingHandler
   [junit4]   2> 6817280 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: org.apache.solr.handler.admin.ShowFileRequestHandler
   [junit4]   2> 6817281 T17528 oasc.RequestHandlers.initHandlersFromConfig created /admin/ping: org.apache.solr.handler.PingRequestHandler
   [junit4]   2> 6817281 T17528 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 6817281 T17528 oasc.RequestHandlers.initHandlersFromConfig created /dump: DumpRequestHandler
   [junit4]   2> 6817289 T17528 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6817290 T17528 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6817292 T17528 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6817294 T17528 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6817294 T17528 oasc.RequestHandlers.applyInitParams WARN INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,args = {defaults={a=A,b=B}}}
   [junit4]   2> 6817299 T17528 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 6817299 T17528 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 6817300 T17528 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=47, maxMergeAtOnceExplicit=28, maxMergedSegmentMB=2.6611328125, floorSegmentMB=0.3896484375, forceMergeDeletesPctAllowed=8.818717996916746, segmentsPerTier=14.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.0
   [junit4]   2> 6817301 T17528 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=NRTCachingDirectory(SimpleFSDirectory@C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-003\collection1\data\index lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@64ae1e; maxCacheMB=48.0 maxMergeSizeMB=4.0),segFN=segments_1,generation=1}
   [junit4]   2> 6817301 T17528 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 6817302 T17528 oass.SolrIndexSearcher.<init> Opening Searcher@1addd23[collection1] main
   [junit4]   2> 6817302 T17528 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 6817304 T17528 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 6817304 T17528 oasr.ManagedResourceStorage.newStorageIO Setting up ZooKeeper-based storage for the RestManager with znodeBase: /configs/conf1
   [junit4]   2> 6817305 T17528 oasr.ManagedResourceStorage$ZooKeeperStorageIO.configure Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 6817305 T17528 oasr.RestManager.init Initializing RestManager with initArgs: {}
   [junit4]   2> 6817306 T17528 oasr.ManagedResourceStorage.load Reading _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6817308 T17528 oasr.ManagedResourceStorage$ZooKeeperStorageIO.openInputStream Read 38 bytes from znode /configs/conf1/_rest_managed.json
   [junit4]   2> 6817308 T17528 oasr.ManagedResourceStorage.load Loaded LinkedHashMap at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6817308 T17528 oasr.ManagedResource.reloadFromStorage Loaded initArgs {} for /rest/managed
   [junit4]   2> 6817308 T17528 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 6817308 T17528 oass.ZkIndexSchemaReader.createSchemaWatcher Creating ZooKeeper watch for the managed schema at /configs/conf1/managed-schema
   [junit4]   2> 6817311 T17528 oash.ReplicationHandler.inform Commits will be reserved for  10000
   [junit4]   2> 6817311 T17529 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@1addd23[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 6817311 T17528 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 6817314 T17532 oasc.ZkController.register Register replica - core:collection1 address:https://127.0.0.1:56183/xl_yb/hh collection:collection1 shard:shard1
   [junit4]   2> 6817315 T17472 oass.SolrDispatchFilter.init user.dir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0
   [junit4]   2> 6817316 T17472 oass.SolrDispatchFilter.init SolrDispatchFilter.init() done
   [junit4]   2> 6817317 T17532 oascc.SolrZkClient.makePath makePath: /collections/collection1/leader_elect/shard1/election
   [junit4]   2> 6817330 T17532 oasc.ShardLeaderElectionContext.runLeaderProcess Running the leader process for shard shard1
   [junit4]   2> 6817334 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6817335 T17532 oasc.ShardLeaderElectionContext.waitForReplicasToComeUp Enough replicas found to continue.
   [junit4]   2> 6817335 T17532 oasc.ShardLeaderElectionContext.runLeaderProcess I may be the new leader - try and sync
   [junit4]   2> ASYNC  NEW_CORE C2576 name=collection1 org.apache.solr.core.SolrCore@1a8466a url=https://127.0.0.1:56183/xl_yb/hh/collection1 node=127.0.0.1:56183_xl_yb%2Fhh C2576_STATE=coll:collection1 core:collection1 props:{state=down, core=collection1, base_url=https://127.0.0.1:56183/xl_yb/hh, node_name=127.0.0.1:56183_xl_yb%2Fhh}
   [junit4]   2> 6817335 T17532 C2576 P56183 oasc.SyncStrategy.sync Sync replicas to https://127.0.0.1:56183/xl_yb/hh/collection1/
   [junit4]   2> 6817336 T17532 C2576 P56183 oasc.SyncStrategy.syncReplicas Sync Success - now sync replicas to me
   [junit4]   2> 6817336 T17532 C2576 P56183 oasc.SyncStrategy.syncToMe https://127.0.0.1:56183/xl_yb/hh/collection1/ has no replicas
   [junit4]   2> 6817336 T17532 oasc.ShardLeaderElectionContext.runLeaderProcess I am the new leader: https://127.0.0.1:56183/xl_yb/hh/collection1/ shard1
   [junit4]   2> 6817336 T17532 oascc.SolrZkClient.makePath makePath: /collections/collection1/leaders/shard1
   [junit4]   2> 6817343 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "operation":"leader",
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "collection":"collection1"}
   [junit4]   2> 6817351 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817351 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817352 T17527 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817370 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "operation":"leader",
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56183/xl_yb/hh",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "state":"active"}
   [junit4]   2> 6817374 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6817376 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817376 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817378 T17527 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817402 T17532 oasc.ZkController.register We are https://127.0.0.1:56183/xl_yb/hh/collection1/ and leader is https://127.0.0.1:56183/xl_yb/hh/collection1/
   [junit4]   2> 6817402 T17532 oasc.ZkController.register No LogReplay needed for core=collection1 baseURL=https://127.0.0.1:56183/xl_yb/hh
   [junit4]   2> 6817402 T17532 oasc.ZkController.checkRecovery I am the leader, no recovery necessary
   [junit4]   2> 6817402 T17532 oasc.ZkController.publish publishing core=collection1 state=active collection=collection1
   [junit4]   2> 6817402 T17532 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 6817404 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6817410 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "state":"active",
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "core_node_name":"core_node1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56183/xl_yb/hh",
   [junit4]   2> 	  "numShards":"2",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:56183_xl_yb%2Fhh"}
   [junit4]   2> 6817516 T17527 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817517 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6817517 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 2)
   [junit4]   2> 6818533 T17472 oasc.AbstractFullDistribZkTestBase.createJettys create jetty 2
   [junit4]   2> 6818534 T17472 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 6818541 T17472 oejus.SslContextFactory.doStart Enabled Protocols [SSLv2Hello, SSLv3, TLSv1, TLSv1.1, TLSv1.2] of [SSLv2Hello, SSLv3, TLSv1, TLSv1.1, TLSv1.2]
   [junit4]   2> 6818543 T17472 oejs.AbstractConnector.doStart Started SslSelectChannelConnector@127.0.0.1:?????
   [junit4]   2> 6818546 T17472 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 6818546 T17472 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 6818547 T17472 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004
   [junit4]   2> 6818547 T17472 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\'
   [junit4]   2> 6818569 T17472 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\solr.xml
   [junit4]   2> 6818609 T17472 oasc.CoreContainer.<init> New CoreContainer 5050503
   [junit4]   2> 6818609 T17472 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\]
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxConnections to: 10000
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 6818610 T17472 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 6818613 T17472 oasu.UpdateShardHandler.<init> Creating UpdateShardHandler HTTP client with params: socketTimeout=340000&connTimeout=45000&retry=false
   [junit4]   2> 6818615 T17472 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 6818615 T17472 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 6818615 T17472 oasc.CoreContainer.load Host Name: 127.0.0.1
   [junit4]   2> 6818615 T17472 oasc.ZkContainer.initZooKeeper Zookeeper client=127.0.0.1:56161/solr
   [junit4]   2> 6818616 T17472 oasc.ZkController.checkChrootPath zkHost includes chroot
   [junit4]   2> 6818616 T17472 oascc.SolrZkClient.createZkCredentialsToAddAutomatically Using default ZkCredentialsProvider
   [junit4]   2> 6818618 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6818620 T17544 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@7ec2c9 name:ZooKeeperConnection Watcher:127.0.0.1:56161 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6818621 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6818622 T17472 oascc.SolrZkClient.createZkACLProvider Using default ZkACLProvider
   [junit4]   2> 6818624 T17474 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x14a00b728370008, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:228)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:208)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:745)
   [junit4]   2> 
   [junit4]   2> 6818625 T17472 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 6818627 T17547 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@4e9e18 name:ZooKeeperConnection Watcher:127.0.0.1:56161/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 6818628 T17472 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 6818641 T17472 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 6819651 T17472 oasc.ZkController.createEphemeralLiveNode Register node as live in ZooKeeper:/live_nodes/127.0.0.1:56192_xl_yb%2Fhh
   [junit4]   2> 6819652 T17472 oascc.SolrZkClient.makePath makePath: /live_nodes/127.0.0.1:56192_xl_yb%2Fhh
   [junit4]   2> 6819666 T17472 oasc.Overseer.close Overseer (id=null) closing
   [junit4]   2> 6819677 T17548 oasc.ZkController.publish publishing core=collection1 state=down collection=collection1
   [junit4]   2> 6819677 T17548 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 6819678 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6819679 T17548 oasc.ZkController.waitForCoreNodeName look for our core node name
   [junit4]   2> 6819685 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "shard":null,
   [junit4]   2> 	  "state":"down",
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56192/xl_yb/hh",
   [junit4]   2> 	  "numShards":"2",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:56192_xl_yb%2Fhh"}
   [junit4]   2> 6819685 T17502 oasc.Overseer$ClusterStateUpdater.updateState Collection already exists with numShards=2
   [junit4]   2> 6819686 T17502 oasc.Overseer$ClusterStateUpdater.updateState Assigning new node to shard shard=shard2
   [junit4]   2> 6819691 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6819691 T17527 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6819692 T17547 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6819692 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6820679 T17548 oasc.ZkController.waitForShardId waiting to find shard id in clusterstate for collection1
   [junit4]   2> 6820679 T17548 oasc.ZkController.createCollectionZkNode Check for collection zkNode:collection1
   [junit4]   2> 6820681 T17548 oasc.ZkController.createCollectionZkNode Collection zkNode exists
   [junit4]   2> 6820681 T17548 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 6820684 T17548 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 6820685 T17548 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\'
   [junit4]   2> 6820693 T17548 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-004/collection1/lib/.svn/' to classloader
   [junit4]   2> 6820696 T17548 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-004/collection1/lib/classes/' to classloader
   [junit4]   2> 6820697 T17548 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/build/solr-core/test/J0/temp/solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001/tempDir-004/collection1/lib/README' to classloader
   [junit4]   2> 6820726 T17548 oasc.ZkController.watchZKConfDir watch zkdir /configs/conf1
   [junit4]   2> 6820731 T17548 oasc.Config.<init> loaded config solrconfig.xml with version 0 
   [junit4]   2> 6820761 T17548 oasc.SolrConfig.<init> Using Lucene MatchVersion: 5.0.0
   [junit4]   2> 6820796 T17548 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 6820798 T17548 oass.IndexSchema.readSchema Reading Solr Schema from /configs/conf1/managed-schema
   [junit4]   2> 6820804 T17548 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 6821099 T17548 oass.OpenExchangeRatesOrgProvider.init Initialized with rates=open-exchange-rates.json, refreshInterval=1440.
   [junit4]   2> 6821104 T17548 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 6821106 T17548 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 6821110 T17548 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 6821115 T17548 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 6821133 T17548 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 6821136 T17548 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 6821137 T17548 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 6821137 T17548 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 6821139 T17548 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 6821140 T17548 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 6821146 T17548 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from collection collection1
   [junit4]   2> 6821146 T17548 oasc.SolrCore.initDirectoryFactory solr.NRTCachingDirectoryFactory
   [junit4]   2> 6821148 T17548 oasc.SolrCore.<init> [collection1] Opening new SolrCore at C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\, dataDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data\
   [junit4]   2> 6821148 T17548 oasc.SolrCore.<init> JMX monitoring not detected for core: collection1
   [junit4]   2> 6821150 T17548 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data
   [junit4]   2> 6821151 T17548 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data\index/
   [junit4]   2> 6821152 T17548 oasc.SolrCore.initIndex WARN [collection1] Solr index directory 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data\index' doesn't exist. Creating new index...
   [junit4]   2> 6821153 T17548 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data\index
   [junit4]   2> 6821154 T17548 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogDocMergePolicy: [LogDocMergePolicy: minMergeSize=1000, mergeFactor=28, maxMergeSize=9223372036854775807, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=false, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.0]
   [junit4]   2> 6821160 T17548 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=NRTCachingDirectory(SimpleFSDirectory@C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data\index lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@1628bfb; maxCacheMB=48.0 maxMergeSizeMB=4.0),segFN=segments_1,generation=1}
   [junit4]   2> 6821160 T17548 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 6821162 T17548 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 6821162 T17548 oasc.RequestHandlers.initHandlersFromConfig created /update: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6821163 T17548 oasc.RequestHandlers.initHandlersFromConfig created /update/json: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6821163 T17548 oasc.RequestHandlers.initHandlersFromConfig created /update/csv: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6821164 T17548 oasc.RequestHandlers.initHandlersFromConfig created /update/json/docs: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 6821164 T17548 oasc.RequestHandlers.initHandlersFromConfig created /config: org.apache.solr.handler.SolrConfigHandler
   [junit4]   2> 6821165 T17548 oasc.RequestHandlers.initHandlersFromConfig created /replication: org.apache.solr.handler.ReplicationHandler
   [junit4]   2> 6821165 T17548 oasc.RequestHandlers.initHandlersFromConfig created /get: org.apache.solr.handler.RealTimeGetHandler
   [junit4]   2> 6821166 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/luke: org.apache.solr.handler.admin.LukeRequestHandler
   [junit4]   2> 6821167 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/system: org.apache.solr.handler.admin.SystemInfoHandler
   [junit4]   2> 6821168 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/mbeans: org.apache.solr.handler.admin.SolrInfoMBeanHandler
   [junit4]   2> 6821168 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/plugins: org.apache.solr.handler.admin.PluginInfoHandler
   [junit4]   2> 6821169 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/threads: org.apache.solr.handler.admin.ThreadDumpHandler
   [junit4]   2> 6821170 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/properties: org.apache.solr.handler.admin.PropertiesRequestHandler
   [junit4]   2> 6821170 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/logging: org.apache.solr.handler.admin.LoggingHandler
   [junit4]   2> 6821171 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: org.apache.solr.handler.admin.ShowFileRequestHandler
   [junit4]   2> 6821171 T17548 oasc.RequestHandlers.initHandlersFromConfig created /admin/ping: org.apache.solr.handler.PingRequestHandler
   [junit4]   2> 6821172 T17548 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 6821172 T17548 oasc.RequestHandlers.initHandlersFromConfig created /dump: DumpRequestHandler
   [junit4]   2> 6821176 T17548 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6821177 T17548 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6821178 T17548 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6821179 T17548 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 6821179 T17548 oasc.RequestHandlers.applyInitParams WARN INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,args = {defaults={a=A,b=B}}}
   [junit4]   2> 6821182 T17548 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 6821182 T17548 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 6821183 T17548 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=47, maxMergeAtOnceExplicit=28, maxMergedSegmentMB=2.6611328125, floorSegmentMB=0.3896484375, forceMergeDeletesPctAllowed=8.818717996916746, segmentsPerTier=14.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.0
   [junit4]   2> 6821183 T17548 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=NRTCachingDirectory(SimpleFSDirectory@C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.schema.TestCloudManagedSchema-BC6BE21FDE93BCBD-001\tempDir-004\collection1\data\index lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@1628bfb; maxCacheMB=48.0 maxMergeSizeMB=4.0),segFN=segments_1,generation=1}
   [junit4]   2> 6821183 T17548 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 6821184 T17548 oass.SolrIndexSearcher.<init> Opening Searcher@992600[collection1] main
   [junit4]   2> 6821184 T17548 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 6821186 T17548 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 6821186 T17548 oasr.ManagedResourceStorage.newStorageIO Setting up ZooKeeper-based storage for the RestManager with znodeBase: /configs/conf1
   [junit4]   2> 6821187 T17548 oasr.ManagedResourceStorage$ZooKeeperStorageIO.configure Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 6821187 T17548 oasr.RestManager.init Initializing RestManager with initArgs: {}
   [junit4]   2> 6821188 T17548 oasr.ManagedResourceStorage.load Reading _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6821189 T17548 oasr.ManagedResourceStorage$ZooKeeperStorageIO.openInputStream Read 38 bytes from znode /configs/conf1/_rest_managed.json
   [junit4]   2> 6821190 T17548 oasr.ManagedResourceStorage.load Loaded LinkedHashMap at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 6821190 T17548 oasr.ManagedResource.reloadFromStorage Loaded initArgs {} for /rest/managed
   [junit4]   2> 6821190 T17548 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 6821191 T17548 oass.ZkIndexSchemaReader.createSchemaWatcher Creating ZooKeeper watch for the managed schema at /configs/conf1/managed-schema
   [junit4]   2> 6821192 T17548 oash.ReplicationHandler.inform Commits will be reserved for  10000
   [junit4]   2> 6821192 T17549 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@992600[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 6821192 T17548 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 6821194 T17552 oasc.ZkController.register Register replica - core:collection1 address:https://127.0.0.1:56192/xl_yb/hh collection:collection1 shard:shard2
   [junit4]   2> 6821194 T17472 oass.SolrDispatchFilter.init user.dir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0
   [junit4]   2> 6821194 T17472 oass.SolrDispatchFilter.init SolrDispatchFilter.init() done
   [junit4]   2> 6821195 T17552 oascc.SolrZkClient.makePath makePath: /collections/collection1/leader_elect/shard2/election
   [junit4]   2> 6821204 T17552 oasc.ShardLeaderElectionContext.runLeaderProcess Running the leader process for shard shard2
   [junit4]   2> 6821207 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6821208 T17552 oasc.ShardLeaderElectionContext.waitForReplicasToComeUp Enough replicas found to continue.
   [junit4]   2> 6821208 T17552 oasc.ShardLeaderElectionContext.runLeaderProcess I may be the new leader - try and sync
   [junit4]   2> ASYNC  NEW_CORE C2577 name=collection1 org.apache.solr.core.SolrCore@1a0f44b url=https://127.0.0.1:56192/xl_yb/hh/collection1 node=127.0.0.1:56192_xl_yb%2Fhh C2577_STATE=coll:collection1 core:collection1 props:{state=down, core=collection1, base_url=https://127.0.0.1:56192/xl_yb/hh, node_name=127.0.0.1:56192_xl_yb%2Fhh}
   [junit4]   2> 6821208 T17552 C2577 P56192 oasc.SyncStrategy.sync Sync replicas to https://127.0.0.1:56192/xl_yb/hh/collection1/
   [junit4]   2> 6821208 T17552 C2577 P56192 oasc.SyncStrategy.syncReplicas Sync Success - now sync replicas to me
   [junit4]   2> 6821208 T17552 C2577 P56192 oasc.SyncStrategy.syncToMe https://127.0.0.1:56192/xl_yb/hh/collection1/ has no replicas
   [junit4]   2> 6821208 T17552 oasc.ShardLeaderElectionContext.runLeaderProcess I am the new leader: https://127.0.0.1:56192/xl_yb/hh/collection1/ shard2
   [junit4]   2> 6821209 T17552 oascc.SolrZkClient.makePath makePath: /collections/collection1/leaders/shard2
   [junit4]   2> 6821219 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "operation":"leader",
   [junit4]   2> 	  "shard":"shard2",
   [junit4]   2> 	  "collection":"collection1"}
   [junit4]   2> 6821227 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6821227 T17547 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6821228 T17512 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6821229 T17527 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6821246 T17502 oasc.Overseer$ClusterStateUpdater.processMessage processMessage: queueSize: 1, message = {
   [junit4]   2> 	  "operation":"leader",
   [junit4]   2> 	  "shard":"shard2",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "base_url":"https://127.0.0.1:56192/xl_yb/hh",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "state":"active"}
   [junit4]   2> 6821250 T17501 oasc.DistributedQueue$LatchWatcher.process NodeChildrenChanged fired on path /overseer/queue state SyncConnected
   [junit4]   2> 6821252 T17501 oascc.ZkStateReader$2.process A cluster state change: WatchedEvent state:SyncConnected type:NodeDataChanged path:/clusterstate.json, has occurred - updating... (live nodes size: 3)
   [junit4]   2> 6821252 T17512 oascc.ZkStateReader$2.process A cluster state change: Watche

[...truncated too long message...]

, TestUniqueKeyFieldResource, TestPseudoReturnFields, DebugComponentTest, CachingDirectoryFactoryTest, TermVectorComponentTest, SchemaVersionSpecificBehaviorTest, SyncSliceTest, CursorMarkTest, TestBadConfig, TestStandardQParsers, SimpleCollectionCreateDeleteTest, SolrCoreCheckLockOnStartupTest, TestRestManager, TestSchemaVersionResource, URLClassifyProcessorTest, SuggesterFSTTest, TestPerFieldSimilarity, RollingRestartTest, BlockDirectoryTest, TestMissingGroups, TestFaceting, TestCollapseQParserPlugin, TestReversedWildcardFilterFactory, DeleteInactiveReplicaTest, BasicFunctionalityTest, HdfsBasicDistributedZkTest, VMParamsZkACLAndCredentialsProvidersTest, TestInitQParser, DisMaxRequestHandlerTest, DistributedFacetPivotSmallTest, TestSolrDeletionPolicy2, TestInfoStreamLogging, CoreAdminHandlerTest, TestXIncludeConfig, WordBreakSolrSpellCheckerTest, TestReloadAndDeleteDocs, TestDefaultSimilarityFactory, CacheHeaderTest, HdfsRecoveryZkTest, HdfsWriteToMultipleCollectionsTest, DateMathParserTest, ExitableDirectoryReaderTest, TestSweetSpotSimilarityFactory, SpellCheckComponentTest, TestArbitraryIndexDir, TestHighFrequencyDictionaryFactory, DeleteShardTest, TestSuggestSpellingConverter, TestTolerantSearch, TestCollectionAPI, SSLMigrationTest, EchoParamsTest, SampleTest, TestCoreDiscovery, RequiredFieldsTest, NotRequiredUniqueKeyTest, ResourceLoaderTest, DistanceFunctionTest, TestSearchPerf, TestReplicationHandlerBackup, TestComponentsName, LoggingHandlerTest, JsonLoaderTest, TestRTGBase, OutputWriterTest, HardAutoCommitTest, AnalysisErrorHandlingTest, AlternateDirectoryTest, TestNRTOpen, CurrencyFieldOpenExchangeTest, TestSolrDynamicMBean, AddBlockUpdateTest, AtomicUpdatesTest, TestSolrXmlPersistence, DirectSolrConnectionTest, TestFastLRUCache, TestFastWriter, TestZkChroot, ShardRoutingTest, ChaosMonkeyNothingIsSafeTest, SolrCoreTest, TestBulkSchemaAPI, HighlighterConfigTest, DistributedFacetPivotLargeTest, TestConfigOverlay, DefaultValueUpdateProcessorTest, TestReload, CoreMergeIndexesAdminHandlerTest, TestPHPSerializedResponseWriter, TestRandomMergePolicy, IndexBasedSpellCheckerTest, TestWriterPerf, SuggestComponentTest, TestIntervalFaceting, SpellPossibilityIteratorTest, SuggesterTest, ZkCLITest, TestFileDictionaryLookup, BadCopyFieldTest, CurrencyFieldXmlFileTest, TestShardHandlerFactory, TestStressUserVersions, TestDistributedMissingSort, PluginInfoTest, ZkNodePropsTest, QueryEqualityTest, AliasIntegrationTest, CSVRequestHandlerTest, SpellingQueryConverterTest, TestUtils, DistributedSuggestComponentTest, SimplePostToolTest, TestSolrXml, SuggesterTSTTest, FileUtilsTest, TestSortingResponseWriter, ClusterStateUpdateTest, IndexSchemaRuntimeFieldTest, StandardRequestHandlerTest, TestSolrConfigHandlerCloud, PreAnalyzedFieldTest, TestDocumentBuilder, ConvertedLegacyTest, FileBasedSpellCheckerTest, TestSolrXmlPersistor, TestSchemaResource, SystemInfoHandlerTest, SolrInfoMBeanTest, TestAtomicUpdateErrorCases, CustomCollectionTest, TestReRankQParserPlugin, TestCloudPivotFacet, BasicDistributedZkTest, ChaosMonkeySafeLeaderTest, BasicDistributedZk2Test, UnloadDistributedZkTest, CollectionsAPIDistributedZkTest, LeaderElectionIntegrationTest, RecoveryZkTest, TestReplicationHandler, TestRandomFaceting, LeaderElectionTest, ZkSolrClientTest, TestRandomDVFaceting, TestDistributedSearch, AutoCommitTest, TestDistributedGrouping, TestRecovery, TestHashPartitioner, DistributedSpellCheckComponentTest, ZkControllerTest, TestStressReorder, TestJoin, TestRangeQuery, TestCoreContainer, SimpleFacetsTest, TestSolr4Spatial, StatsComponentTest, SolrCmdDistributorTest, QueryElevationComponentTest, PeerSyncTest, TestSort, TestFunctionQuery, TestLazyCores, DirectUpdateHandlerTest, OverseerCollectionProcessorTest, TestIndexSearcher, HighlighterTest, ShowFileRequestHandlerTest, DistributedQueryElevationComponentTest, SolrIndexSplitterTest, AnalysisAfterCoreReloadTest, SignatureUpdateProcessorFactoryTest, TestExtendedDismaxParser, SpellCheckCollatorTest, TestFoldingMultitermQuery, TestStressLucene, SpatialFilterTest, SuggesterWFSTTest, PolyFieldTest, TestUpdate, FieldMutatingUpdateProcessorTest, TestWordDelimiterFilterFactory, DirectUpdateHandlerOptimizeTest, StatelessScriptUpdateProcessorFactoryTest, SortByFunctionTest, TestRemoteStreaming, DocValuesMultiTest, TestSolrDeletionPolicy1, XsltUpdateRequestHandlerTest, TestSurroundQueryParser, LukeRequestHandlerTest, TestQueryUtils, DocumentAnalysisRequestHandlerTest, PrimitiveFieldTypeTest, TermsComponentTest, XmlUpdateRequestHandlerTest, DocumentBuilderTest, TestValueSourceCache, PathHierarchyTokenizerFactoryTest, TestIndexingPerformance, MoreLikeThisHandlerTest, TestSolrQueryParser, SolrPluginUtilsTest, TestCollationField, ReturnFieldsTest, JSONWriterTest, TestCSVResponseWriter, MBeansHandlerTest, TestAnalyzedSuggestions, UniqFieldsUpdateProcessorFactoryTest, BinaryUpdateRequestHandlerTest, TestPartialUpdateDeduplication, TestBinaryResponseWriter, TestLFUCache, TestQuerySenderListener, TestSolrIndexConfig, ResponseLogComponentTest, TestStressRecovery, TestMergePolicyConfig, MultiTermTest, TestDocSet, TestBinaryField, TestElisionMultitermQuery, TestConfig, TestFuzzyAnalyzedSuggestions, TestSolrCoreProperties, TestPostingsSolrHighlighter, TestLuceneMatchVersion, TestPhraseSuggestions, TestCharFilters, TestCodecSupport, SynonymTokenizerTest, TestLMDirichletSimilarityFactory, TestIBSimilarityFactory, TestBM25SimilarityFactory, LegacyHTMLStripCharFilterTest, TestJmxMonitoredMap, TimeZoneUtilsTest, TestFastOutputStream, OpenExchangeRatesOrgProviderTest, TestSystemIdResolver, DateFieldTest, RAMDirectoryFactoryTest, ClusterStateTest, TestLRUCache, SliceStateTest, UUIDFieldTest, CursorPagingTest, DistributedIntervalFacetingTest, SolrTestCaseJ4Test, TestCursorMarkWithoutUniqueKey, TestHighlightDedupGrouping, AsyncMigrateRouteKeyTest, ConnectionManagerTest, DeleteLastCustomShardedReplicaTest, DeleteReplicaTest, DistribCursorPagingTest, HttpPartitionTest, LeaderFailoverAfterPartitionTest, LeaderInitiatedRecoveryOnCommitTest, MigrateRouteKeyTest, MultiThreadedOCPTest, OutOfBoxZkACLAndCredentialsProvidersTest, OverriddenZkACLAndCredentialsProvidersTest, OverseerStatusTest, RemoteQueryErrorTest, ReplicationFactorTest, ShardSplitTest, SharedFSAutoReplicaFailoverTest, SharedFSAutoReplicaFailoverUtilsTest, SolrXmlInZkTest, TestCloudInspectUtil, TestDistribDocBasedVersion, TestLeaderElectionZkExpiry, TestMiniSolrCloudCluster, TestReplicaProperties, TriLevelCompositeIdRoutingTest, HdfsBasicDistributedZk2Test, HdfsChaosMonkeySafeLeaderTest, HdfsSyncSliceTest, StressHdfsTest, QueryResultKeyTest, TestInitParams, TestSolrConfigHandler, TestSolrConfigHandlerConcurrent, CoreAdminRequestStatusTest, DistributedDebugComponentTest, DistributedFacetPivotLongTailTest, DistributedFacetPivotSmallAdvancedTest, DistributedFacetPivotWhiteBoxTest, DistributedQueryComponentOptimizationTest, FacetPivotSmallTest, TestPivotHelperCode, TestChildDocTransformer, TestRawResponseWriter, TestManagedResource, TestClassNameShortening, TestCopyFieldCollectionResource, TestDefaultSearchFieldResource, TestDynamicFieldCollectionResource, TestDynamicFieldResource, TestFieldCollectionResource, TestFieldTypeCollectionResource, TestFieldTypeResource, TestManagedSchemaFieldResource, TestManagedSchemaFieldTypeResource, TestSchemaNameResource, TestSchemaSimilarityResource, TestSerializedLuceneMatchVersion, TestSolrQueryParserResource, TestManagedStopFilterFactory, TestManagedSynonymFilterFactory, ChangedSchemaMergeTest, DateRangeFieldTest, EnumFieldTest, TestBulkSchemaConcurrent, TestCloudManagedSchema]
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestCloudManagedSchema -Dtests.seed=BC6BE21FDE93BCBD -Dtests.slow=true -Dtests.locale=th_TH_TH_#u-nu-thai -Dtests.timezone=Europe/Busingen -Dtests.asserts=true -Dtests.file.encoding=Cp1252
   [junit4] ERROR   0.00s | TestCloudManagedSchema (suite) <<<
   [junit4]    > Throwable #1: com.carrotsearch.randomizedtesting.ThreadLeakError: 1 thread leaked from SUITE scope at org.apache.solr.schema.TestCloudManagedSchema: 
   [junit4]    >    1) Thread[id=17475, name=SessionTracker, state=TIMED_WAITING, group=TGRP-TestCloudManagedSchema]
   [junit4]    >         at java.lang.Object.wait(Native Method)
   [junit4]    >         at org.apache.zookeeper.server.SessionTrackerImpl.run(SessionTrackerImpl.java:146)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([BC6BE21FDE93BCBD]:0)
   [junit4] Completed in -1003.46s, 1 test, 1 error <<< FAILURES!

[...truncated 117 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:529: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:477: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:61: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\extra-targets.xml:39: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build.xml:192: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\common-build.xml:508: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:1363: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:970: There were test failures: 450 suites, 1841 tests, 1 suite-level error, 55 ignored (31 assumptions)

Total time: 157 minutes 34 seconds
Build step 'Invoke Ant' marked build as failure
[description-setter] Description set: Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: true)
Archiving artifacts
Recording test results
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any



[JENKINS] Lucene-Solr-5.x-Windows (32bit/jdk1.7.0_67) - Build # 4355 - Still Failing!

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: http://jenkins.thetaphi.de/job/Lucene-Solr-5.x-Windows/4355/
Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: true)

9 tests failed.
FAILED:  org.apache.solr.highlight.HighlighterTest.testTwoFieldHighlight

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:60700BA9F56FFC07]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testTwoFieldHighlight(HighlighterTest.java:391)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">18</int></lst><result name="response" numFound="1" start="0"><doc><arr name="t_text"><str>a long day's night</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><arr name="tv_text"><str>a long night's day</str></arr><long name="_version_">1486142760499019776</long><date name="timestamp">2014-11-29T21:23:01.2Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"><arr name="t_text"><str>a &lt;em&gt;long&lt;/em&gt; day's night</str></arr></lst></lst>
</response>

	request was:start=0&qt=standard&hl=true&rows=200&q=t_text:long&hl.fl=t_text+tv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testTermVecHighlight

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:3822B67A1B4A7EAE]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testTermVecHighlight(HighlighterTest.java:145)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str[.='a <em>long</em> days night this should be a piece of text which']
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">0</int></lst><result name="response" numFound="1" start="0"><doc><arr name="tv_text"><str>a long days night this should be a piece of text which is is is is is is is is is is is is is is is is is is is is is is is is isis is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is sufficiently lengthly to produce multiple fragments which are not concatenated at all--we want two disjoint long fragments.</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142760686714880</long><date name="timestamp">2014-11-29T21:23:01.38Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:start=0&qt=standard&hl=true&rows=200&hl.snippets=2&q=tv_text:long&hl.fl=tv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testDisMaxHighlight

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:3AAE12F53C75B2C]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testDisMaxHighlight(HighlighterTest.java:262)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">37</int></lst><result name="response" numFound="1" start="0"><doc><arr name="tv_text"><str>a long day's night</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142760707686400</long><date name="timestamp">2014-11-29T21:23:01.4Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:start=0&qt=dismax&q.alt=*:*&qf=tv_text&hl=true&rows=200&q=long&hl.fl=tv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testVariableFragsize

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:1E4ECEDAF0A7062F]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testVariableFragsize(HighlighterTest.java:592)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str[.='a <em>long</em> days night this should be a piece of text which']
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">0</int></lst><result name="response" numFound="1" start="0"><doc><arr name="tv_text"><str>a long days night this should be a piece of text which is is is is is is is is is is is is is is is is is is is is is is is is isis is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is sufficiently lengthly to produce multiple fragments which are not concatenated at all</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142760952004608</long><date name="timestamp">2014-11-29T21:23:01.633Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:start=0&qt=standard&hl=true&rows=200&q=tv_text:long&hl.fl=tv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testLongFragment

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:81C5B20C1D35A175]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testLongFragment(HighlighterTest.java:496)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">1</int></lst><result name="response" numFound="1" start="0"><doc><arr name="tv_text"><str>junit: [mkdir] Created dir: /home/klaas/worio/backend/trunk/build-src/solr-nightly/build/test-results [junit] Running org.apache.solr.BasicFunctionalityTest [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 5.36 sec [junit] Running org.apache.solr.ConvertedLegacyTest [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 8.268 sec [junit] Running org.apache.solr.DisMaxRequestHandlerTest [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.56 sec [junit] Running org.apache.solr.HighlighterTest [junit] Tests run: 7, Failures: 0, Errors: 0, Time elapsed: 4.979 sec [junit] Running org.apache.solr.OutputWriterTest [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.797 sec [junit] Running org.apache.solr.SampleTest [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 1.021 sec [junit] Running org.apache.solr.analysis.TestBufferedTokenStream [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.05 sec [junit] Running org.apache.solr.analysis.TestRemoveDuplicatesTokenFilter [junit] Tests run: 3, Failures: 0, Errors: 0, Time elapsed: 0.054 sec [junit] Running org.apache.solr.analysis.TestSynonymFilter [junit] Tests run: 6, Failures: 0, Errors: 0, Time elapsed: 0.081 sec [junit] Running org.apache.solr.analysis.TestWordDelimiterFilter [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 1.714 sec [junit] Running org.apache.solr.search.TestDocSet [junit] Tests run: 1, Failures: 0, Errors: 0, Time elapsed: 0.788 sec [junit] Running org.apache.solr.util.SolrPluginUtilsTest [junit] Tests run: 5, Failures: 0, Errors: 0, Time elapsed: 3.519 sec [junit] Running org.apache.solr.util.TestOpenBitSet [junit] Tests run: 2, Failures: 0, Errors: 0, Time elapsed: 0.533 sec</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142761066299392</long><date name="timestamp">2014-11-29T21:23:01.742Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:start=0&qt=standard&hl=true&rows=200&q=tv_text:dir&hl.fl=tv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testSubwordWildcardHighlightWithTermOffsets

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:26A42A68E7BCC8C0]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testSubwordWildcardHighlightWithTermOffsets(HighlighterTest.java:834)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='highlighting']/lst[@name='1']/arr[@name='subword_offsets']/str='lorem <em>PowerShot.com</em> ipsum'
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">1</int></lst><result name="response" numFound="1" start="0"><doc><arr name="subword_offsets"><str>lorem PowerShot.com ipsum</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142761112436736</long><date name="timestamp">2014-11-29T21:23:01.785Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:hl=true&wt=xml&q=subword_offsets:pow*&hl.fl=subword_offsets
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testTermVecMultiValuedHighlight

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:B35CCAC7A7F3BEA5]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testTermVecMultiValuedHighlight(HighlighterTest.java:211)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_mv_text']/str[.='a <em>long</em> days night this should be a piece of text which']
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">0</int></lst><result name="response" numFound="1" start="0"><doc><arr name="tv_mv_text"><str>a long days night this should be a piece of text which is is is is is is is is is is is is is is is is is is is is is is is is isis is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is sufficiently lengthly to produce multiple fragments which are not concatenated at all--we want two disjoint long fragments.</str><str>a long days night this should be a piece of text which is is is is is is is is is is is is is is is is is is is is is is is is isis is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is sufficiently lengthly to produce multiple fragments which are not concatenated at all--we want two disjoint long fragments.</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142761272868864</long><date name="timestamp">2014-11-29T21:23:01.939Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:start=0&qt=standard&hl=true&rows=200&hl.snippets=2&q=tv_mv_text:long&hl.fl=tv_mv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testSubwordWildcardHighlightWithTermOffsets2

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:2BA19522D2B550D3]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testSubwordWildcardHighlightWithTermOffsets2(HighlighterTest.java:843)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='highlighting']/lst[@name='1']/arr[@name='subword_offsets']/str='lorem <em>PowerShot</em> ipsum'
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">1</int></lst><result name="response" numFound="1" start="0"><doc><arr name="subword_offsets"><str>lorem PowerShot ipsum</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142761335783424</long><date name="timestamp">2014-11-29T21:23:01.999Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:hl=true&wt=xml&q=subword_offsets:pow*&hl.fl=subword_offsets
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more


FAILED:  org.apache.solr.highlight.HighlighterTest.testTermVecMultiValuedHighlight2

Error Message:
Exception during query

Stack Trace:
java.lang.RuntimeException: Exception during query
	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:18BF3778CCA3F8F]:0)
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
	at org.apache.solr.highlight.HighlighterTest.testTermVecMultiValuedHighlight2(HighlighterTest.java:239)
	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:1618)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
	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:65)
	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:365)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
	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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
	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:365)
	at java.lang.Thread.run(Thread.java:745)
Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_mv_text']/str[.='a <em>long</em> days night this should be a piece of text which']
	xml response was: <?xml version="1.0" encoding="UTF-8"?>
<response>
<lst name="responseHeader"><int name="status">0</int><int name="QTime">1</int></lst><result name="response" numFound="1" start="0"><doc><arr name="tv_mv_text"><str>short</str><str>a long days night this should be a piece of text which is is is is is is is is is is is is is is is is is is is is is is is is isis is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is is sufficiently lengthly to produce multiple fragments which are not concatenated at all--we want two disjoint long fragments.</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><long name="_version_">1486142761394503680</long><date name="timestamp">2014-11-29T21:23:02.055Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"/></lst>
</response>

	request was:start=0&qt=standard&hl=true&rows=200&hl.snippets=2&q=tv_mv_text:long&hl.fl=tv_mv_text
	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
	... 41 more




Build Log:
[...truncated 8868 lines...]
   [junit4] Suite: org.apache.solr.highlight.HighlighterTest
   [junit4]   2> Creating dataDir: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001
   [junit4]   2> 942098 T2038 oas.SolrTestCaseJ4.buildSSLConfig Randomized ssl (true) and clientAuth (false)
   [junit4]   2> 942101 T2038 oas.SolrTestCaseJ4.initCore ####initCore
   [junit4]   2> 942101 T2038 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\'
   [junit4]   2> 942104 T2038 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/core/src/test-files/solr/collection1/lib/.svn/' to classloader
   [junit4]   2> 942104 T2038 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/core/src/test-files/solr/collection1/lib/classes/' to classloader
   [junit4]   2> 942104 T2038 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/core/src/test-files/solr/collection1/lib/README' to classloader
   [junit4]   2> 942193 T2038 oasc.SolrConfig.<init> Using Lucene MatchVersion: 5.0.0
   [junit4]   2> 942242 T2038 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 942242 T2038 oass.IndexSchema.readSchema Reading Solr Schema from C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1\conf\schema.xml
   [junit4]   2> 942249 T2038 oass.IndexSchema.readSchema [null] Schema name=test
   [junit4]   2> 942544 T2038 oass.OpenExchangeRatesOrgProvider.init Initialized with rates=open-exchange-rates.json, refreshInterval=1440.
   [junit4]   2> 942551 T2038 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 942553 T2038 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 942559 T2038 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 942563 T2038 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 942566 T2038 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 942566 T2038 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 942567 T2038 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 942567 T2038 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 942568 T2038 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 942568 T2038 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 942568 T2038 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 942568 T2038 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr
   [junit4]   2> 942568 T2038 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\'
   [junit4]   2> 942641 T2038 oasc.CoreContainer.<init> New CoreContainer 6672514
   [junit4]   2> 942641 T2038 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\]
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 0
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: null
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 0
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting maxConnections to: 10000
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 942642 T2038 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 942648 T2038 oasu.UpdateShardHandler.<init> Creating UpdateShardHandler HTTP client with params: socketTimeout=30000&connTimeout=30000&retry=false
   [junit4]   2> 942651 T2038 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 942652 T2038 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 942652 T2038 oasc.CoreContainer.load Host Name: 
   [junit4]   2> 942656 T2039 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1/'
   [junit4]   2> 942657 T2039 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/core/src/test-files/solr/collection1/lib/.svn/' to classloader
   [junit4]   2> 942657 T2039 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/core/src/test-files/solr/collection1/lib/classes/' to classloader
   [junit4]   2> 942657 T2039 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-5.x-Windows/solr/core/src/test-files/solr/collection1/lib/README' to classloader
   [junit4]   2> 942703 T2039 oasc.SolrConfig.<init> Using Lucene MatchVersion: 5.0.0
   [junit4]   2> 942805 T2039 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 942807 T2039 oass.IndexSchema.readSchema Reading Solr Schema from C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1/conf\schema.xml
   [junit4]   2> 942825 T2039 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 943283 T2039 oass.OpenExchangeRatesOrgProvider.init Initialized with rates=open-exchange-rates.json, refreshInterval=1440.
   [junit4]   2> 943289 T2039 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 943290 T2039 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 943296 T2039 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 943300 T2039 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 943303 T2039 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 943303 T2039 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 943303 T2039 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 943303 T2039 oass.OpenExchangeRatesOrgProvider.reload Reloading exchange rates from open-exchange-rates.json
   [junit4]   2> 943304 T2039 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Unknown key IMPORTANT NOTE
   [junit4]   2> 943304 T2039 oass.OpenExchangeRatesOrgProvider$OpenExchangeRates.<init> WARN Expected key, got STRING
   [junit4]   2> 943304 T2039 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from instancedir C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1/
   [junit4]   2> 943304 T2039 oasc.SolrCore.initDirectoryFactory org.apache.solr.core.MockDirectoryFactory
   [junit4]   2> 943305 T2039 oasc.SolrCore.<init> [collection1] Opening new SolrCore at C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\core\src\test-files\solr\collection1/, dataDir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\
   [junit4]   2> 943305 T2039 oasc.JmxMonitoredMap.<init> JMX monitoring is enabled. Adding Solr mbeans to JMX Server: com.sun.jmx.mbeanserver.JmxMBeanServer@96519f
   [junit4]   2> 943306 T2039 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\
   [junit4]   2> 943306 T2039 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\index/
   [junit4]   2> 943306 T2039 oasc.SolrCore.initIndex WARN [collection1] Solr index directory 'C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\index' doesn't exist. Creating new index...
   [junit4]   2> 943307 T2039 oasc.CachingDirectoryFactory.get return new directory for C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\index
   [junit4]   2> 943307 T2039 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogByteSizeMergePolicy: [LogByteSizeMergePolicy: minMergeSize=1677721, mergeFactor=32, maxMergeSize=2147483648, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=false, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.41749862043111907]
   [junit4]   2> 943308 T2039 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_1,generation=1}
   [junit4]   2> 943308 T2039 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 943308 T2039 oasc.SolrCore.initWriters created xml: solr.XMLResponseWriter
   [junit4]   2> 943311 T2039 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "dedupe"
   [junit4]   2> 943312 T2039 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "dedupe"
   [junit4]   2> 943312 T2039 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "dedupe-allfields"
   [junit4]   2> 943312 T2039 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "dedupe-allfields"
   [junit4]   2> 943312 T2039 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "stored_sig"
   [junit4]   2> 943313 T2039 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "stored_sig"
   [junit4]   2> 943313 T2039 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "uniq-fields"
   [junit4]   2> 943314 T2039 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "uniq-fields"
   [junit4]   2> 943314 T2039 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-explicit"
   [junit4]   2> 943315 T2039 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 943315 T2039 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 943315 T2039 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 943315 T2039 oasc.RequestHandlers.initHandlersFromConfig created /update: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 943315 T2039 oasc.RequestHandlers.initHandlersFromConfig created /update/json: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 943316 T2039 oasc.RequestHandlers.initHandlersFromConfig created /update/csv: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 943316 T2039 oasc.RequestHandlers.initHandlersFromConfig created /update/json/docs: org.apache.solr.handler.UpdateRequestHandler
   [junit4]   2> 943317 T2039 oasc.RequestHandlers.initHandlersFromConfig created /config: org.apache.solr.handler.SolrConfigHandler
   [junit4]   2> 943317 T2039 oasc.RequestHandlers.initHandlersFromConfig created /replication: org.apache.solr.handler.ReplicationHandler
   [junit4]   2> 943318 T2039 oasc.RequestHandlers.initHandlersFromConfig created /get: org.apache.solr.handler.RealTimeGetHandler
   [junit4]   2> 943319 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/luke: org.apache.solr.handler.admin.LukeRequestHandler
   [junit4]   2> 943320 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/system: org.apache.solr.handler.admin.SystemInfoHandler
   [junit4]   2> 943321 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/mbeans: org.apache.solr.handler.admin.SolrInfoMBeanHandler
   [junit4]   2> 943321 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/plugins: org.apache.solr.handler.admin.PluginInfoHandler
   [junit4]   2> 943321 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/threads: org.apache.solr.handler.admin.ThreadDumpHandler
   [junit4]   2> 943322 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/properties: org.apache.solr.handler.admin.PropertiesRequestHandler
   [junit4]   2> 943322 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/logging: org.apache.solr.handler.admin.LoggingHandler
   [junit4]   2> 943323 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/ping: org.apache.solr.handler.PingRequestHandler
   [junit4]   2> 943323 T2039 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 943324 T2039 oasc.RequestHandlers.initHandlersFromConfig created dismax: solr.SearchHandler
   [junit4]   2> 943325 T2039 oasc.RequestHandlers.initHandlersFromConfig created mock: org.apache.solr.core.MockQuerySenderListenerReqHandler
   [junit4]   2> 943325 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: solr.admin.ShowFileRequestHandler
   [junit4]   2> 943326 T2039 oasc.RequestHandlers.initHandlersFromConfig created /admin/fileedit: solr.admin.EditFileRequestHandler
   [junit4]   2> 943326 T2039 oasc.RequestHandlers.initHandlersFromConfig created defaults: solr.StandardRequestHandler
   [junit4]   2> 943326 T2039 oasc.RequestHandlers.initHandlersFromConfig adding lazy requestHandler: solr.StandardRequestHandler
   [junit4]   2> 943327 T2039 oasc.RequestHandlers.initHandlersFromConfig created lazy: solr.StandardRequestHandler
   [junit4]   2> 943327 T2039 oasc.RequestHandlers.initHandlersFromConfig created /terms: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943328 T2039 oasc.RequestHandlers.initHandlersFromConfig created spellCheckCompRH: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943328 T2039 oasc.RequestHandlers.initHandlersFromConfig created spellCheckCompRH_Direct: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943328 T2039 oasc.RequestHandlers.initHandlersFromConfig created spellCheckWithWordbreak: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943328 T2039 oasc.RequestHandlers.initHandlersFromConfig created spellCheckWithWordbreak_Direct: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943329 T2039 oasc.RequestHandlers.initHandlersFromConfig created spellCheckCompRH1: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943329 T2039 oasc.RequestHandlers.initHandlersFromConfig created mltrh: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943330 T2039 oasc.RequestHandlers.initHandlersFromConfig created tvrh: org.apache.solr.handler.component.SearchHandler
   [junit4]   2> 943330 T2039 oasc.RequestHandlers.initHandlersFromConfig created /mlt: solr.MoreLikeThisHandler
   [junit4]   2> 943331 T2039 oasc.RequestHandlers.initHandlersFromConfig created /debug/dump: solr.DumpRequestHandler
   [junit4]   2> 943338 T2039 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 943340 T2039 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 943341 T2039 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 943343 T2039 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 943345 T2039 oasc.SolrCore.initDeprecatedSupport WARN solrconfig.xml uses deprecated <admin/gettableFiles>, Please update your config to use the ShowFileRequestHandler.
   [junit4]   2> 943347 T2039 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 943347 T2039 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 943348 T2039 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=20, maxMergeAtOnceExplicit=16, maxMergedSegmentMB=29.505859375, floorSegmentMB=0.78515625, forceMergeDeletesPctAllowed=11.643978634262908, segmentsPerTier=22.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.19027042848405157
   [junit4]   2> 943349 T2039 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_1,generation=1}
   [junit4]   2> 943349 T2039 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 943349 T2039 oass.SolrIndexSearcher.<init> Opening Searcher@d5d9ed[collection1] main
   [junit4]   2> 943350 T2039 oasr.RestManager.init Initializing RestManager with initArgs: {storageIO=org.apache.solr.rest.ManagedResourceStorage$InMemoryStorageIO}
   [junit4]   2> 943350 T2039 oasr.ManagedResourceStorage.load Reading _rest_managed.json using InMemoryStorage
   [junit4]   2> 943351 T2039 oasr.ManagedResource.reloadFromStorage WARN No stored data found for /rest/managed
   [junit4]   2> 943351 T2039 oasr.ManagedResourceStorage$JsonStorage.store Saved JSON object to path _rest_managed.json using InMemoryStorage
   [junit4]   2> 943351 T2039 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 943351 T2039 oashc.SpellCheckComponent.inform Initializing spell checkers
   [junit4]   2> 943360 T2039 oass.DirectSolrSpellChecker.init init: {name=direct,classname=DirectSolrSpellChecker,field=lowerfilt,minQueryLength=3}
   [junit4]   2> 943398 T2039 oash.ReplicationHandler.inform Commits will be reserved for  10000
   [junit4]   2> 943399 T2039 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 943400 T2040 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@d5d9ed[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 943402 T2038 oas.SolrTestCaseJ4.initCore ####initCore end
   [junit4]   2> 943408 T2038 oas.SolrTestCaseJ4.setUp ###Starting testDefaultFieldPrefixWildcardHighlight
   [junit4]   2> ASYNC  NEW_CORE C300 name=collection1 org.apache.solr.core.SolrCore@1304af7
   [junit4]   2> 943411 T2038 C300 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {add=[1 (1486142760243167232)]} 0 2
   [junit4]   2> ASYNC  NEW_CORE C301 name=collection1 org.apache.solr.core.SolrCore@1304af7
   [junit4]   2> 943418 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=false,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943423 T2038 C301 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=2
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_1,generation=1}
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_2,generation=2}
   [junit4]   2> 943424 T2038 C301 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 2
   [junit4]   2> 943426 T2038 C301 oass.SolrIndexSearcher.<init> Opening Searcher@14dbc72[collection1] main
   [junit4]   2> 943427 T2038 C301 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 943429 T2040 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@14dbc72[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader(Uninverting(_0(5.0.0):C1)))}
   [junit4]   2> 943430 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {commit=} 0 12
   [junit4]   2> 943431 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=true,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943432 T2038 C301 oasu.DirectUpdateHandler2.commit No uncommitted changes. Skipping IW.commit.
   [junit4]   2> 943433 T2038 C301 oasc.SolrCore.openNewSearcher SolrIndexSearcher has not changed - not re-opening: org.apache.solr.search.SolrIndexSearcher
   [junit4]   2> 943434 T2038 C301 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 943434 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {optimize=} 0 3
   [junit4]   2> 943611 T2038 C301 oasc.SolrCore.execute [collection1] webapp=null path=null params={start=0&qt=standard&hl=true&rows=200&hl.usePhraseHighlighter=true&hl.highlightMultiTerm=true&q=lon*&df=t_text&hl.fl=} hits=1 status=0 QTime=175 
   [junit4]   2> 943616 T2038 C301 oass.SolrIndexSearcher.<init> Opening Searcher@f40da1[collection1] realtime
   [junit4]   2> 943617 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {deleteByQuery=*:* (-1486142760459173888)} 0 2
   [junit4]   2> 943619 T2038 oas.SolrTestCaseJ4.tearDown ###Ending testDefaultFieldPrefixWildcardHighlight
   [junit4]   2> 943624 T2038 oas.SolrTestCaseJ4.setUp ###Starting testHighlightDisabled
   [junit4]   2> 943625 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {add=[1 (1486142760468611072)]} 0 1
   [junit4]   2> 943627 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=false,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943629 T2038 C301 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=2
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_2,generation=2}
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_3,generation=3}
   [junit4]   2> 943629 T2038 C301 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 3
   [junit4]   2> 943631 T2038 C301 oass.SolrIndexSearcher.<init> Opening Searcher@d3b7ef[collection1] main
   [junit4]   2> 943632 T2038 C301 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 943633 T2040 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@d3b7ef[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader(Uninverting(_1(5.0.0):C1)))}
   [junit4]   2> 943634 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {commit=} 0 7
   [junit4]   2> 943636 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=true,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943636 T2038 C301 oasu.DirectUpdateHandler2.commit No uncommitted changes. Skipping IW.commit.
   [junit4]   2> 943637 T2038 C301 oasc.SolrCore.openNewSearcher SolrIndexSearcher has not changed - not re-opening: org.apache.solr.search.SolrIndexSearcher
   [junit4]   2> 943638 T2038 C301 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 943638 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {optimize=} 0 2
   [junit4]   2> 943641 T2038 C301 oasc.SolrCore.execute [collection1] webapp=null path=null params={start=0&qt=standard&hl=false&rows=200&q=t_text:long&hl.fl=t_text} hits=1 status=0 QTime=1 
   [junit4]   2> 943644 T2038 C301 oass.SolrIndexSearcher.<init> Opening Searcher@12ab353[collection1] realtime
   [junit4]   2> 943644 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {deleteByQuery=*:* (-1486142760487485440)} 0 2
   [junit4]   2> 943646 T2038 oas.SolrTestCaseJ4.tearDown ###Ending testHighlightDisabled
   [junit4]   2> 943652 T2038 oas.SolrTestCaseJ4.setUp ###Starting testTwoFieldHighlight
   [junit4]   2> 943665 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {add=[1 (1486142760499019776)]} 0 13
   [junit4]   2> 943667 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=false,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943670 T2038 C301 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=2
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_3,generation=3}
   [junit4]   2> 		commit{dir=RateLimitedDirectoryWrapper(MockDirectoryWrapper(RAMDirectory@1596556 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@c19cc)),segFN=segments_4,generation=4}
   [junit4]   2> 943670 T2038 C301 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 4
   [junit4]   2> 943679 T2038 C301 oass.SolrIndexSearcher.<init> Opening Searcher@1ed5d50[collection1] main
   [junit4]   2> 943680 T2038 C301 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 943681 T2040 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@1ed5d50[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader(Uninverting(_2(5.0.0):C1)))}
   [junit4]   2> 943683 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {commit=} 0 16
   [junit4]   2> 943685 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=true,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943686 T2038 C301 oasu.DirectUpdateHandler2.commit No uncommitted changes. Skipping IW.commit.
   [junit4]   2> 943686 T2038 C301 oasc.SolrCore.openNewSearcher SolrIndexSearcher has not changed - not re-opening: org.apache.solr.search.SolrIndexSearcher
   [junit4]   2> 943686 T2038 C301 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 943686 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {optimize=} 0 1
   [junit4]   2> 943705 T2038 C301 oasc.SolrCore.execute [collection1] webapp=null path=null params={start=0&qt=standard&hl=true&rows=200&q=t_text:long&hl.fl=t_text+tv_text} hits=1 status=0 QTime=18 
   [junit4]   2> 943709 T2038 oas.SolrTestCaseJ4.assertQ ERROR REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str
   [junit4]   2> 		xml response was: <?xml version="1.0" encoding="UTF-8"?>
   [junit4]   2> 	<response>
   [junit4]   2> 	<lst name="responseHeader"><int name="status">0</int><int name="QTime">18</int></lst><result name="response" numFound="1" start="0"><doc><arr name="t_text"><str>a long day's night</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><arr name="tv_text"><str>a long night's day</str></arr><long name="_version_">1486142760499019776</long><date name="timestamp">2014-11-29T21:23:01.2Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"><arr name="t_text"><str>a &lt;em&gt;long&lt;/em&gt; day's night</str></arr></lst></lst>
   [junit4]   2> 	</response>
   [junit4]   2> 	
   [junit4]   2> 		request was:start=0&qt=standard&hl=true&rows=200&q=t_text:long&hl.fl=t_text+tv_text
   [junit4]   2> 943710 T2038 oasc.SolrException.log ERROR REQUEST FAILED: start=0&qt=standard&hl=true&rows=200&q=t_text:long&hl.fl=t_text+tv_text:java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str
   [junit4]   2> 		xml response was: <?xml version="1.0" encoding="UTF-8"?>
   [junit4]   2> 	<response>
   [junit4]   2> 	<lst name="responseHeader"><int name="status">0</int><int name="QTime">18</int></lst><result name="response" numFound="1" start="0"><doc><arr name="t_text"><str>a long day's night</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><arr name="tv_text"><str>a long night's day</str></arr><long name="_version_">1486142760499019776</long><date name="timestamp">2014-11-29T21:23:01.2Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"><arr name="t_text"><str>a &lt;em&gt;long&lt;/em&gt; day's night</str></arr></lst></lst>
   [junit4]   2> 	</response>
   [junit4]   2> 	
   [junit4]   2> 		request was:start=0&qt=standard&hl=true&rows=200&q=t_text:long&hl.fl=t_text+tv_text
   [junit4]   2> 		at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
   [junit4]   2> 		at org.apache.solr.highlight.HighlighterTest.testTwoFieldHighlight(HighlighterTest.java:391)
   [junit4]   2> 		at sun.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   [junit4]   2> 		at sun.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:57)
   [junit4]   2> 		at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   [junit4]   2> 		at java.lang.reflect.Method.invoke(Method.java:606)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1618)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
   [junit4]   2> 		at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:49)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:365)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
   [junit4]   2> 		at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:42)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
   [junit4]   2> 		at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:55)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 		at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:365)
   [junit4]   2> 		at java.lang.Thread.run(Thread.java:745)
   [junit4]   2> 	
   [junit4]   2> 943714 T2038 C301 oass.SolrIndexSearcher.<init> Opening Searcher@74b015[collection1] realtime
   [junit4]   2> 943715 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {deleteByQuery=*:* (-1486142760560885760)} 0 3
   [junit4]   2> 943717 T2038 oas.SolrTestCaseJ4.tearDown ###Ending testTwoFieldHighlight
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=HighlighterTest -Dtests.method=testTwoFieldHighlight -Dtests.seed=1902CEAB1219AABD -Dtests.slow=true -Dtests.locale=en_US -Dtests.timezone=America/Indiana/Indianapolis -Dtests.asserts=true -Dtests.file.encoding=ISO-8859-1
   [junit4] ERROR   0.09s | HighlighterTest.testTwoFieldHighlight <<<
   [junit4]    > Throwable #1: java.lang.RuntimeException: Exception during query
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([1902CEAB1219AABD:60700BA9F56FFC07]:0)
   [junit4]    > 	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:729)
   [junit4]    > 	at org.apache.solr.highlight.HighlighterTest.testTwoFieldHighlight(HighlighterTest.java:391)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:745)
   [junit4]    > Caused by: java.lang.RuntimeException: REQUEST FAILED: xpath=//lst[@name='1']/arr[@name='tv_text']/str
   [junit4]    > 	xml response was: <?xml version="1.0" encoding="UTF-8"?>
   [junit4]    > <response>
   [junit4]    > <lst name="responseHeader"><int name="status">0</int><int name="QTime">18</int></lst><result name="response" numFound="1" start="0"><doc><arr name="t_text"><str>a long day's night</str></arr><int name="id">1</int><arr name="range_facet_l"><long>1</long></arr><arr name="tv_text"><str>a long night's day</str></arr><long name="_version_">1486142760499019776</long><date name="timestamp">2014-11-29T21:23:01.2Z</date><int name="intDefault">42</int><arr name="multiDefault"><str>muLti-Default</str></arr></doc></result><lst name="highlighting"><lst name="1"><arr name="t_text"><str>a &lt;em&gt;long&lt;/em&gt; day's night</str></arr></lst></lst>
   [junit4]    > </response>
   [junit4]    > 	request was:start=0&qt=standard&hl=true&rows=200&q=t_text:long&hl.fl=t_text+tv_text
   [junit4]    > 	at org.apache.solr.SolrTestCaseJ4.assertQ(SolrTestCaseJ4.java:722)
   [junit4]    > 	... 41 more
   [junit4]   2> 943746 T2038 oas.SolrTestCaseJ4.setUp ###Starting testRegexFragmenter
   [junit4]   2> 943748 T2038 C301 oasup.LogUpdateProcessor.finish [collection1] webapp=null path=null params={} {add=[1 (1486142760597585920)]} 0 2
   [junit4]   2> 943750 T2038 C301 oasu.DirectUpdateHandler2.commit start commit{,optimize=false,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 943753 T2038 C301 oasc.SolrDeletionPolicy.onCom

[...truncated too long message...]

rcher(SolrCore.java:1461)
   [junit4]   2> 	at org.apache.solr.core.SolrCore.getSearcher(SolrCore.java:1699)
   [junit4]   2> 	at org.apache.solr.core.SolrCore.getSearcher(SolrCore.java:1444)
   [junit4]   2> 	at org.apache.solr.core.SolrCore.getSearcher(SolrCore.java:1379)
   [junit4]   2> 	at org.apache.solr.handler.ReplicationHandler.getIndexVersion(ReplicationHandler.java:558)
   [junit4]   2> 	at org.apache.solr.handler.ReplicationHandler.getStatistics(ReplicationHandler.java:575)
   [junit4]   2> 	at org.apache.solr.core.JmxMonitoredMap$SolrDynamicMBean.getMBeanInfo(JmxMonitoredMap.java:257)
   [junit4]   2> 	at com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.getClassName(DefaultMBeanServerInterceptor.java:1804)
   [junit4]   2> 	at com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.safeGetClassName(DefaultMBeanServerInterceptor.java:1595)
   [junit4]   2> 	at com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.checkMBeanPermission(DefaultMBeanServerInterceptor.java:1813)
   [junit4]   2> 	at com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.exclusiveUnregisterMBean(DefaultMBeanServerInterceptor.java:430)
   [junit4]   2> 	at com.sun.jmx.interceptor.DefaultMBeanServerInterceptor.unregisterMBean(DefaultMBeanServerInterceptor.java:415)
   [junit4]   2> 	at com.sun.jmx.mbeanserver.JmxMBeanServer.unregisterMBean(JmxMBeanServer.java:546)
   [junit4]   2> 	at org.apache.solr.core.JmxMonitoredMap.clear(JmxMonitoredMap.java:124)
   [junit4]   2> 	at org.apache.solr.core.SolrCore.close(SolrCore.java:1124)
   [junit4]   2> 	at org.apache.solr.core.SolrCores.close(SolrCores.java:117)
   [junit4]   2> 	at org.apache.solr.core.CoreContainer.shutdown(CoreContainer.java:365)
   [junit4]   2> 	at org.apache.solr.util.TestHarness.close(TestHarness.java:337)
   [junit4]   2> 	at org.apache.solr.SolrTestCaseJ4.deleteCore(SolrTestCaseJ4.java:640)
   [junit4]   2> 	at org.apache.solr.SolrTestCaseJ4.afterClass(SolrTestCaseJ4.java:185)
   [junit4]   2> 	at sun.reflect.GeneratedMethodAccessor32.invoke(Unknown Source)
   [junit4]   2> 	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   [junit4]   2> 	at java.lang.reflect.Method.invoke(Method.java:606)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1618)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:790)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
   [junit4]   2> 	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
   [junit4]   2> 	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:42)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
   [junit4]   2> 	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
   [junit4]   2> 	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
   [junit4]   2> 	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:55)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
   [junit4]   2> 	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:365)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:745)
   [junit4]   2> 
   [junit4]   2> 944554 T2038 oasc.CachingDirectoryFactory.close Closing MockDirectoryFactory - 2 directories currently being tracked
   [junit4]   2> 944554 T2038 oasc.CachingDirectoryFactory.closeCacheValue looking to close C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\index [CachedDir<<refCount=0;path=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\index;done=false>>]
   [junit4]   2> 944554 T2038 oasc.CachingDirectoryFactory.close Closing directory: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\index
   [junit4]   2> 944554 T2038 oasc.CachingDirectoryFactory.closeCacheValue looking to close C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\ [CachedDir<<refCount=0;path=C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\;done=false>>]
   [junit4]   2> 944554 T2038 oasc.CachingDirectoryFactory.close Closing directory: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001\init-core-data-001\
   [junit4]   2> NOTE: leaving temporary files on disk at: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build\solr-core\test\J0\temp\solr.highlight.HighlighterTest-1902CEAB1219AABD-001
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene50): {t_text2=Lucene50(blocksize=128), subword=Lucene50(blocksize=128), textgap=BlockTreeOrds(blocksize=128), timestamp=Lucene50(blocksize=128), tv_no_off_text=Lucene50(blocksize=128), subword_offsets=TestBloomFilteredLucenePostings(BloomFilteringPostingsFormat(Lucene50(blocksize=128))), _version_=Lucene50(blocksize=128), t_text=FST50, foo_sI=TestBloomFilteredLucenePostings(BloomFilteringPostingsFormat(Lucene50(blocksize=128))), weight=FST50, cat=Lucene50(blocksize=128), range_facet_l=Lucene50(blocksize=128), title=FST50, title_stringNoNorms=Lucene50(blocksize=128), intDefault=Lucene50(blocksize=128), tv_text=Lucene50(blocksize=128), t_text1=BlockTreeOrds(blocksize=128), foo_t=BlockTreeOrds(blocksize=128), text=TestBloomFilteredLucenePostings(BloomFilteringPostingsFormat(Lucene50(blocksize=128))), foo_s=Lucene50(blocksize=128), id=BlockTreeOrds(blocksize=128), title_stemmed=FST50, title_lettertok=BlockTreeOrds(blocksize=128), tv_mv_text=Lucene50(blocksize=128), multiDefault=FST50}, docValues:{timestamp=DocValuesFormat(name=Direct)}, sim=DefaultSimilarity, locale=en_US, timezone=America/Indiana/Indianapolis
   [junit4]   2> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.7.0_67 (32-bit)/cpus=2,threads=1,free=55383472,total=260308992
   [junit4]   2> NOTE: All tests run in this JVM: [TestHighFrequencyDictionaryFactory, DistributedFacetPivotWhiteBoxTest, DistributedDebugComponentTest, TestAnalyzedSuggestions, TestChildDocTransformer, DefaultValueUpdateProcessorTest, SSLMigrationTest, SuggestComponentTest, MultiThreadedOCPTest, ReplicationFactorTest, TestPivotHelperCode, TestFaceting, TestFieldTypeCollectionResource, DistributedSpellCheckComponentTest, CloudExitableDirectoryReaderTest, DeleteReplicaTest, TestZkChroot, QueryResultKeyTest, MoreLikeThisHandlerTest, BlockCacheTest, DeleteInactiveReplicaTest, TestGroupingSearch, DateFieldTest, TestRequestStatusCollectionAPI, TestConfig, AsyncMigrateRouteKeyTest, CoreAdminRequestStatusTest, TestTrie, TestManagedSchemaDynamicFieldResource, XmlUpdateRequestHandlerTest, TestElisionMultitermQuery, AlternateDirectoryTest, HighlighterTest]
   [junit4] Completed in 2.49s, 31 tests, 9 errors <<< FAILURES!

[...truncated 1351 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:525: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:473: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:61: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\extra-targets.xml:39: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\build.xml:189: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\solr\common-build.xml:508: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:1363: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:970: There were test failures: 450 suites, 1841 tests, 9 errors, 55 ignored (31 assumptions)

Total time: 167 minutes 36 seconds
Build step 'Invoke Ant' marked build as failure
[description-setter] Description set: Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: true)
Archiving artifacts
Recording test results
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any



[JENKINS] Lucene-Solr-5.x-Windows (32bit/jdk1.8.0_20) - Build # 4354 - Still Failing!

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: http://jenkins.thetaphi.de/job/Lucene-Solr-5.x-Windows/4354/
Java: 32bit/jdk1.8.0_20 -client -XX:+UseParallelGC (asserts: false)

1 tests failed.
FAILED:  org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile

Error Message:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-6DE9E9B37AF85AFD-001\leftover-001\child.locked

Stack Trace:
java.nio.file.AccessDeniedException: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-6DE9E9B37AF85AFD-001\leftover-001\child.locked
	at sun.nio.fs.WindowsException.translateToIOException(WindowsException.java:83)
	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:97)
	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:102)
	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:53)
	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:38)
	at org.apache.lucene.mockfile.WindowsFS.getKey(WindowsFS.java:57)
	at org.apache.lucene.mockfile.WindowsFS.onClose(WindowsFS.java:77)
	at org.apache.lucene.mockfile.HandleTrackingFS$5.close(HandleTrackingFS.java:210)
	at org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile(TestLeaveFilesIfTestFails.java:79)
	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 org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:45)
	at org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:15)
	at org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:42)
	at org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:20)
	at org.junit.internal.runners.statements.RunBefores.evaluate(RunBefores.java:28)
	at org.junit.internal.runners.statements.RunAfters.evaluate(RunAfters.java:30)
	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.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.junit.rules.RunRules.evaluate(RunRules.java:18)
	at org.junit.runners.ParentRunner.runLeaf(ParentRunner.java:263)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:68)
	at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:47)
	at org.junit.runners.ParentRunner$3.run(ParentRunner.java:231)
	at org.junit.runners.ParentRunner$1.schedule(ParentRunner.java:60)
	at org.junit.runners.ParentRunner.runChildren(ParentRunner.java:229)
	at org.junit.runners.ParentRunner.access$000(ParentRunner.java:50)
	at org.junit.runners.ParentRunner$2.evaluate(ParentRunner.java:222)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.junit.rules.RunRules.evaluate(RunRules.java:18)
	at org.junit.runners.ParentRunner.run(ParentRunner.java:300)
	at com.carrotsearch.ant.tasks.junit4.slave.SlaveMain.execute(SlaveMain.java:199)
	at com.carrotsearch.ant.tasks.junit4.slave.SlaveMain.main(SlaveMain.java:310)
	at com.carrotsearch.ant.tasks.junit4.slave.SlaveMainSafe.main(SlaveMainSafe.java:12)




Build Log:
[...truncated 513 lines...]
   [junit4] Suite: org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails
   [junit4]   1> sysout from nested test: 
   [junit4]   1> 
   [junit4]   1> syserr from nested test: NOTE: test params are: codec=Asserting(Lucene50): {}, docValues:{}, sim=RandomSimilarityProvider(queryNorm=true,coord=crazy): {}, locale=hu_HU, timezone=Asia/Bahrain
   [junit4]   1> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.8.0_20 (32-bit)/cpus=2,threads=1,free=182243224,total=202113024
   [junit4]   1> NOTE: All tests run in this JVM: [TestLogMergePolicy, TestIndexCommit, TestRegexpRandom2, TestFilterLeafReader, TestAutomaton, TestAtomicUpdate, TestPayloadSpans, TestElevationComparator, TestAssertingTermVectorsFormat, TestManyFields, TestSearchAfter, TestTermsEnum2, TestCrash, TestAssertingPostingsFormat, TestBlockPostingsFormat, TestDirectoryReader, TestBooleanQuery, TestFrequencyTrackingRingBuffer, TestSmallFloat, TestControlledRealTimeReopenThread, TestPriorityQueue, TestNumericRangeQuery32, TestIndexWriterMaxDocs, TestPositiveScoresOnlyCollector, TestExitableDirectoryReader, TestEliasFanoDocIdSet, TestAssertingDocValuesFormat, TestNoDeletionPolicy, TestSpanMultiTermQueryWrapper, TestPrefixInBooleanQuery, TestSizeBoundedForceMerge, TestBufferedChecksum, TestTieredMergePolicy, TestCodecHoldsOpenFiles, TestFlex, TestRollingBuffer, TestSimpleExplanationsOfNonMatches, TestTimSorter, TestLucene50NormsFormat, TestMatchAllDocsQuery, TestExternalCodecs, TestTermScorer, TestNeverDelete, TestNRTThreads, TestNot, TestOrdinalMap, TestStringHelper, TestComplexExplanations, TestIndexInput, TestTotalHitCountCollector, TestAutomatonQuery, TestOfflineSorter, TestLucene50DocValuesFormat, TestSimilarityProvider, TestNRTCachingDirectory, TestCompiledAutomaton, TestNotDocIdSet, TestSubScorerFreqs, TestSameScoresWithThreads, TestFlushByRamOrCountsPolicy, TestIndexWriter, TestEliasFanoSequence, TestCachingTokenFilter, TestCheckIndex, TestPayloadTermQuery, TestSimpleExplanations, Test2BNumericDocValues, Nested1, Test2BPostings, TestLookaheadTokenFilter, TestTryDelete, TestPackedInts, TestUniqueTermCount, TestMultiValuedNumericRangeQuery, TestLucene50TermVectorsFormat, TestBinaryDocument, TestDeterminizeLexicon, TestBasics, TestLongBitSet, TestByteBlockPool, TestCloseableThreadLocal, TestFilteredQuery, TestBitUtil, TestLongPostings, TestOmitTf, TestSearcherManager, TestConsistentFieldNumbers, TestInPlaceMergeSorter, TestMockAnalyzer, TestAllFilesHaveChecksumFooter, TestMultiLevelSkipList, TestMockDirectoryWrapper, TestIndexWriterMergePolicy, TestSearch, TestAutomatonQueryUnicode, TestDocument, TestDemo, TestBooleanQueryVisitSubscorers, TestTerm, TestDocValuesIndexing, TestFSTs, TestDirectPacked, TestFieldReuse, TestSort, TestIndexWriterForceMerge, TestPrefixFilter, TestBytesRef, Nested, TestMaxTermFrequency, TestIndexWriterCommit, TestFieldsReader, TestTermVectors, Nested1, Nested2]
   [junit4]   1> NOTE: reproduce with: ant test  -Dtestcase=Nested2 -Dtests.seed=6DE9E9B37AF85AFD -Dtests.slow=true -Dtests.locale=hu_HU -Dtests.timezone=Asia/Bahrain -Dtests.asserts=false -Dtests.file.encoding=ISO-8859-1
   [junit4]   1> 
   [junit4] ERROR   0.08s | TestLeaveFilesIfTestFails.testWindowsUnremovableFile <<<
   [junit4]    > Throwable #1: java.nio.file.AccessDeniedException: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-6DE9E9B37AF85AFD-001\leftover-001\child.locked
   [junit4]    > 	at sun.nio.fs.WindowsException.translateToIOException(WindowsException.java:83)
   [junit4]    > 	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:97)
   [junit4]    > 	at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:102)
   [junit4]    > 	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:53)
   [junit4]    > 	at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:38)
   [junit4]    > 	at org.apache.lucene.mockfile.WindowsFS.getKey(WindowsFS.java:57)
   [junit4]    > 	at org.apache.lucene.mockfile.WindowsFS.onClose(WindowsFS.java:77)
   [junit4]    > 	at org.apache.lucene.mockfile.HandleTrackingFS$5.close(HandleTrackingFS.java:210)
   [junit4]    > 	at org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile(TestLeaveFilesIfTestFails.java:79)
   [junit4] Completed in 0.12s, 2 tests, 1 error <<< FAILURES!

[...truncated 959 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:525: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:473: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:61: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\extra-targets.xml:39: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build.xml:49: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:1363: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:970: There were test failures: 405 suites, 3050 tests, 1 error, 64 ignored (54 assumptions)

Total time: 12 minutes 57 seconds
Build step 'Invoke Ant' marked build as failure
[description-setter] Description set: Java: 32bit/jdk1.8.0_20 -client -XX:+UseParallelGC (asserts: false)
Archiving artifacts
Recording test results
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any



Re: [JENKINS] Lucene-Solr-5.x-Windows (32bit/jdk1.7.0_67) - Build # 4353 - Still Failing!

Posted by Michael McCandless <lu...@mikemccandless.com>.
Test bug, I committed a fix.

Mike McCandless

http://blog.mikemccandless.com


On Sat, Nov 29, 2014 at 5:31 AM, Policeman Jenkins Server
<je...@thetaphi.de> wrote:
> Build: http://jenkins.thetaphi.de/job/Lucene-Solr-5.x-Windows/4353/
> Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: false)
>
> 2 tests failed.
> FAILED:  org.apache.lucene.util.TestArrayUtil.testInvalidElementSizes
>
> Error Message:
> requested array size 2147483637 exceeds maximum array in java (2147483635)
>
> Stack Trace:
> java.lang.IllegalArgumentException: requested array size 2147483637 exceeds maximum array in java (2147483635)
>         at __randomizedtesting.SeedInfo.seed([52D6B2B0583CB5A9:192D47F69D4199F3]:0)
>         at org.apache.lucene.util.ArrayUtil.oversize(ArrayUtil.java:168)
>         at org.apache.lucene.util.TestArrayUtil.testInvalidElementSizes(TestArrayUtil.java:71)
>         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:1618)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:827)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:863)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:877)
>         at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:50)
>         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:65)
>         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:365)
>         at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:798)
>         at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:458)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:836)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:738)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:772)
>         at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:783)
>         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 com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
>         at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
>         at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:54)
>         at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
>         at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:65)
>         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:365)
>         at java.lang.Thread.run(Thread.java:745)
>
>
> FAILED:  org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile
>
> Error Message:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-52D6B2B0583CB5A9-001\leftover-001\child.locked
>
> Stack Trace:
> java.nio.file.AccessDeniedException: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-52D6B2B0583CB5A9-001\leftover-001\child.locked
>         at sun.nio.fs.WindowsException.translateToIOException(WindowsException.java:83)
>         at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:97)
>         at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:102)
>         at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:53)
>         at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:38)
>         at org.apache.lucene.mockfile.WindowsFS.getKey(WindowsFS.java:57)
>         at org.apache.lucene.mockfile.WindowsFS.onClose(WindowsFS.java:77)
>         at org.apache.lucene.mockfile.HandleTrackingFS$5.close(HandleTrackingFS.java:210)
>         at org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile(TestLeaveFilesIfTestFails.java:79)
>         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 org.junit.runners.model.FrameworkMethod$1.runReflectiveCall(FrameworkMethod.java:45)
>         at org.junit.internal.runners.model.ReflectiveCallable.run(ReflectiveCallable.java:15)
>         at org.junit.runners.model.FrameworkMethod.invokeExplosively(FrameworkMethod.java:42)
>         at org.junit.internal.runners.statements.InvokeMethod.evaluate(InvokeMethod.java:20)
>         at org.junit.internal.runners.statements.RunBefores.evaluate(RunBefores.java:28)
>         at org.junit.internal.runners.statements.RunAfters.evaluate(RunAfters.java:30)
>         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.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
>         at org.junit.rules.RunRules.evaluate(RunRules.java:18)
>         at org.junit.runners.ParentRunner.runLeaf(ParentRunner.java:263)
>         at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:68)
>         at org.junit.runners.BlockJUnit4ClassRunner.runChild(BlockJUnit4ClassRunner.java:47)
>         at org.junit.runners.ParentRunner$3.run(ParentRunner.java:231)
>         at org.junit.runners.ParentRunner$1.schedule(ParentRunner.java:60)
>         at org.junit.runners.ParentRunner.runChildren(ParentRunner.java:229)
>         at org.junit.runners.ParentRunner.access$000(ParentRunner.java:50)
>         at org.junit.runners.ParentRunner$2.evaluate(ParentRunner.java:222)
>         at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
>         at org.junit.rules.RunRules.evaluate(RunRules.java:18)
>         at org.junit.runners.ParentRunner.run(ParentRunner.java:300)
>         at com.carrotsearch.ant.tasks.junit4.slave.SlaveMain.execute(SlaveMain.java:199)
>         at com.carrotsearch.ant.tasks.junit4.slave.SlaveMain.main(SlaveMain.java:310)
>         at com.carrotsearch.ant.tasks.junit4.slave.SlaveMainSafe.main(SlaveMainSafe.java:12)
>
>
>
>
> Build Log:
> [...truncated 998 lines...]
>    [junit4] Suite: org.apache.lucene.util.TestArrayUtil
>    [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestArrayUtil -Dtests.method=testInvalidElementSizes -Dtests.seed=52D6B2B0583CB5A9 -Dtests.slow=true -Dtests.locale=es_AR -Dtests.timezone=Brazil/West -Dtests.asserts=false -Dtests.file.encoding=UTF-8
>    [junit4] ERROR   0.02s | TestArrayUtil.testInvalidElementSizes <<<
>    [junit4]    > Throwable #1: java.lang.IllegalArgumentException: requested array size 2147483637 exceeds maximum array in java (2147483635)
>    [junit4]    >        at __randomizedtesting.SeedInfo.seed([52D6B2B0583CB5A9:192D47F69D4199F3]:0)
>    [junit4]    >        at org.apache.lucene.util.ArrayUtil.oversize(ArrayUtil.java:168)
>    [junit4]    >        at org.apache.lucene.util.TestArrayUtil.testInvalidElementSizes(TestArrayUtil.java:71)
>    [junit4]    >        at java.lang.Thread.run(Thread.java:745)
>    [junit4]   2> NOTE: test params are: codec=Asserting(Lucene50): {}, docValues:{}, sim=RandomSimilarityProvider(queryNorm=true,coord=crazy): {}, locale=es_AR, timezone=Brazil/West
>    [junit4]   2> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.7.0_67 (32-bit)/cpus=2,threads=1,free=148703312,total=297533440
>    [junit4]   2> NOTE: All tests run in this JVM: [TestPositiveScoresOnlyCollector, InAfterClass, InBeforeClass, InTestMethod, NonStringProperties, TestSameScoresWithThreads, TestTermVectorsReader, TestMultiValuedNumericRangeQuery, Nested, TestSpanExplanationsOfNonMatches, TestEarlyTermination, TestTieredMergePolicy, TestIndexWriterExceptions2, TestNRTReaderWithThreads, ThrowInUncaught, TestTermRangeFilter, TestRamUsageEstimator, TestFastDecompressionMode, TestMmapDirectory, TestOmitPositions, TestDocInverterPerFieldErrorInfo, TestLucene50CompoundFormat, TestByteBlockPool, TestPrefixFilter, TestTimeLimitingCollector, TestRegexpRandom, TestShardSearching, TestSumDocFreq, TestCachingCollector, TestPayloadSpans, TestPayloads, TestSimpleSearchEquivalence, TestLongBitSet, TestIndexWriterMergePolicy, TestDocValuesIndexing, TestPostingsOffsets, TestNumericTokenStream, TestFieldCacheRewriteMethod, TestUTF32ToUTF8, TestIndexWriterLockRelease, TestSegmentMerger, TestScorerPerf, TestTopScoreDocCollector, TestSparseFixedBitSet, TestSpansAdvanced, TestControlledRealTimeReopenThread, TestCompiledAutomaton, TestAutomatonQuery, TestLucene50SegmentInfoFormat, TestBinaryDocument, TestFSTs, TestIdentityHashSet, TestSpanFirstQuery, TestMultiDocValues, TestAssertingDocValuesFormat, TestBoolean2, TestExceedMaxTermLength, TestRegexpRandom2, TestAllFilesHaveChecksumFooter, TestBasics, TestTransactions, TestMutableValues, TestPayloadNearQuery, Nested2, Nested1, Nested3, TestDocumentsWriterDeleteQueue, TestCodecs, TestMockFilesystems, TestOfflineSorter, TestNumericUtils, TestNoMergeScheduler, TestFieldMaskingSpanQuery, TestCheckIndex, TestSimilarityProvider, TestBinaryDocValuesUpdates, TestBytesRefArray, TestIndexableField, Test2BPostingsBytes, TestSpanExplanations, TestPrefixCodedTerms, TestDocument, TestTwoPhaseCommitTool, TestNeverDelete, TestIOUtils, TestFieldsReader, TestRAMDirectory, TestLucene50TermVectorsFormat, Nested2, Nested, TestStressAdvance, TestSetOnce, TestFilteredQuery, TestDocValuesScoring, Nested, Nested, TestAutomatonQueryUnicode, TestMaxTermFrequency, NestedTeardownChain, NestedSetupChain, TestElevationComparator, TestOrdinalMap, TestSegmentTermEnum, TestPriorityQueue, Before3, Before3, TestMockAnalyzer, TestNamedSPILoader, TestLucene50FieldInfoFormat, TestSimpleExplanationsOfNonMatches, TestLockFactory, TestMultiTermQueryRewrites, TestField, TestLock, TestDocTermOrdsRangeFilter, TestIndexReaderClose, TestFilteredSearch, TestNGramPhraseQuery, TestIndexWriterConfig, TestBooleanQuery, TestToken, TestMultiPhraseQuery, TestPayloadExplanations, TestDocCount, TestTermScorer, TestFilterDirectory, TestRollback, TestMixedDocValuesUpdates, TestFilterIterator, TestSearchAfter, TestForUtil, TestOmitTf, TestFieldCacheTermsFilter, TestDemo, TestBooleanCoord, TestNumericDocValuesUpdates, TestQueryBuilder, TestOperations, TestBooleanOr, TestFlex, Test2BPositions, TestAllFilesHaveCodecHeader, TestLookaheadTokenFilter, TestDocIdSetBuilder, TestSpanMultiTermQueryWrapper, TestConstantScoreQuery, Nested, TestIndexWriterUnicode, TestDirectoryReaderReopen, TestSimpleExplanations, TestDuelingCodecs, Test4GBStoredFields, TestManyFields, TestMergeSchedulerExternal, TestMultiTermConstantScore, TestRecyclingByteBlockAllocator, TestPhraseQuery, TestThreadedForceMerge, TestRollingUpdates, TestCachingTokenFilter, TestIndexWriter, TestSparseFixedBitDocIdSet, TestAutomaton, TestBlockPostingsFormat2, Test2BPagedBytes, TestIndexWriterOutOfFileDescriptors, TestTimSorter, TestDirectory, TestRecyclingIntBlockAllocator, TestBagOfPostings, TestSimilarityBase, TestIndexCommit, TestSegmentReader, TestQueryWrapperFilter, TestStressDeletes, TestUnicodeUtil, TestTermRangeQuery, TestDoc, TestWildcardRandom, TestPrefixRandom, TestLRUFilterCache, TestIndexWriterOutOfMemory, MultiCollectorTest, TestSortedSetSortField, TestSearch, TestBooleanScorer, TestReusableStringReader, TestIndexWriterMerging, TestNoDeletionPolicy, TestTerm, TestSimilarity2, TestParallelTermEnum, TestLucene50StoredFieldsFormat, TestEliasFanoDocIdSet, TestSpansAdvanced2, TestLogMergePolicy, TestParallelCompositeReader, TestConsistentFieldNumbers, TestStressIndexing, TestSpanSearchEquivalence, TestTopDocsCollector, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, TestNumericRangeQuery32, TestPersistentSnapshotDeletionPolicy, TestWeakIdentityMap, TestMatchAllDocsQuery, TestBinaryTerms, TestTermsEnum, TestCompressingTermVectorsFormat, TestDateFilter, TestCompressingStoredFieldsFormat, TestPerFieldDocValuesFormat, TestIndexWriterReader, TestNumericRangeQuery64, TestBytesStore, TestPackedInts, TestIndexWriterWithThreads, TestGraphTokenizers, TestAddIndexes, TestIndexWriterExceptions, TestMultiMMap, TestSearcherManager, TestDeletionPolicy, TestFlushByRamOrCountsPolicy, TestSloppyPhraseQuery, TestIndexWriterDelete, TestNRTThreads, TestAtomicUpdate, TestNorms, TestIndexWriterCommit, TestSearchWithThreads, TestConcurrentMergeScheduler, TestHighCompressionMode, TestDocumentsWriterStallControl, TestTopDocsMerge, TestLongPostings, TestMinimize, TestDocTermOrdsRewriteMethod, TestSnapshotDeletionPolicy, TestIndexWriterForceMerge, TestPerFieldPostingsFormat, TestArrayUtil]
>    [junit4] Completed in 1.20s, 13 tests, 1 error <<< FAILURES!
>
> [...truncated 297 lines...]
>    [junit4] Suite: org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails
>    [junit4]   1> sysout from nested test:
>    [junit4]   1>
>    [junit4]   1> syserr from nested test: NOTE: test params are: codec=Asserting(Lucene50): {}, docValues:{}, sim=RandomSimilarityProvider(queryNorm=true,coord=yes): {}, locale=es_HN, timezone=Africa/Lusaka
>    [junit4]   1> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.7.0_67 (32-bit)/cpus=2,threads=1,free=100479536,total=340262912
>    [junit4]   1> NOTE: All tests run in this JVM: [TestPositiveScoresOnlyCollector, InAfterClass, InBeforeClass, InTestMethod, NonStringProperties, TestSameScoresWithThreads, TestTermVectorsReader, TestMultiValuedNumericRangeQuery, Nested, TestSpanExplanationsOfNonMatches, TestEarlyTermination, TestTieredMergePolicy, TestIndexWriterExceptions2, TestNRTReaderWithThreads, ThrowInUncaught, TestTermRangeFilter, TestRamUsageEstimator, TestFastDecompressionMode, TestMmapDirectory, TestOmitPositions, TestDocInverterPerFieldErrorInfo, TestLucene50CompoundFormat, TestByteBlockPool, TestPrefixFilter, TestTimeLimitingCollector, TestRegexpRandom, TestShardSearching, TestSumDocFreq, TestCachingCollector, TestPayloadSpans, TestPayloads, TestSimpleSearchEquivalence, TestLongBitSet, TestIndexWriterMergePolicy, TestDocValuesIndexing, TestPostingsOffsets, TestNumericTokenStream, TestFieldCacheRewriteMethod, TestUTF32ToUTF8, TestIndexWriterLockRelease, TestSegmentMerger, TestScorerPerf, TestTopScoreDocCollector, TestSparseFixedBitSet, TestSpansAdvanced, TestControlledRealTimeReopenThread, TestCompiledAutomaton, TestAutomatonQuery, TestLucene50SegmentInfoFormat, TestBinaryDocument, TestFSTs, TestIdentityHashSet, TestSpanFirstQuery, TestMultiDocValues, TestAssertingDocValuesFormat, TestBoolean2, TestExceedMaxTermLength, TestRegexpRandom2, TestAllFilesHaveChecksumFooter, TestBasics, TestTransactions, TestMutableValues, TestPayloadNearQuery, Nested2, Nested1, Nested3, TestDocumentsWriterDeleteQueue, TestCodecs, TestMockFilesystems, TestOfflineSorter, TestNumericUtils, TestNoMergeScheduler, TestFieldMaskingSpanQuery, TestCheckIndex, TestSimilarityProvider, TestBinaryDocValuesUpdates, TestBytesRefArray, TestIndexableField, Test2BPostingsBytes, TestSpanExplanations, TestPrefixCodedTerms, TestDocument, TestTwoPhaseCommitTool, TestNeverDelete, TestIOUtils, TestFieldsReader, TestRAMDirectory, TestLucene50TermVectorsFormat, Nested2, Nested, TestStressAdvance, TestSetOnce, TestFilteredQuery, TestDocValuesScoring, Nested, Nested, TestAutomatonQueryUnicode, TestMaxTermFrequency, NestedTeardownChain, NestedSetupChain, TestElevationComparator, TestOrdinalMap, TestSegmentTermEnum, TestPriorityQueue, Before3, Before3, TestMockAnalyzer, TestNamedSPILoader, TestLucene50FieldInfoFormat, TestSimpleExplanationsOfNonMatches, TestLockFactory, TestMultiTermQueryRewrites, TestField, TestLock, TestDocTermOrdsRangeFilter, TestIndexReaderClose, TestFilteredSearch, TestNGramPhraseQuery, TestIndexWriterConfig, TestBooleanQuery, TestToken, TestMultiPhraseQuery, TestPayloadExplanations, TestDocCount, TestTermScorer, TestFilterDirectory, TestRollback, TestMixedDocValuesUpdates, TestFilterIterator, TestSearchAfter, TestForUtil, TestOmitTf, TestFieldCacheTermsFilter, TestDemo, TestBooleanCoord, TestNumericDocValuesUpdates, TestQueryBuilder, TestOperations, TestBooleanOr, TestFlex, Test2BPositions, TestAllFilesHaveCodecHeader, TestLookaheadTokenFilter, TestDocIdSetBuilder, TestSpanMultiTermQueryWrapper, TestConstantScoreQuery, Nested, TestIndexWriterUnicode, TestDirectoryReaderReopen, TestSimpleExplanations, TestDuelingCodecs, Test4GBStoredFields, TestManyFields, TestMergeSchedulerExternal, TestMultiTermConstantScore, TestRecyclingByteBlockAllocator, TestPhraseQuery, TestThreadedForceMerge, TestRollingUpdates, TestCachingTokenFilter, TestIndexWriter, TestSparseFixedBitDocIdSet, TestAutomaton, TestBlockPostingsFormat2, Test2BPagedBytes, TestIndexWriterOutOfFileDescriptors, TestTimSorter, TestDirectory, TestRecyclingIntBlockAllocator, TestBagOfPostings, TestSimilarityBase, TestIndexCommit, TestSegmentReader, TestQueryWrapperFilter, TestStressDeletes, TestUnicodeUtil, TestTermRangeQuery, TestDoc, TestWildcardRandom, TestPrefixRandom, TestLRUFilterCache, TestIndexWriterOutOfMemory, MultiCollectorTest, TestSortedSetSortField, TestSearch, TestBooleanScorer, TestReusableStringReader, TestIndexWriterMerging, TestNoDeletionPolicy, TestTerm, TestSimilarity2, TestParallelTermEnum, TestLucene50StoredFieldsFormat, TestEliasFanoDocIdSet, TestSpansAdvanced2, TestLogMergePolicy, TestParallelCompositeReader, TestConsistentFieldNumbers, TestStressIndexing, TestSpanSearchEquivalence, TestTopDocsCollector, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, Nested, TestNumericRangeQuery32, TestPersistentSnapshotDeletionPolicy, TestWeakIdentityMap, TestMatchAllDocsQuery, TestBinaryTerms, TestTermsEnum, TestCompressingTermVectorsFormat, TestDateFilter, TestCompressingStoredFieldsFormat, TestPerFieldDocValuesFormat, TestIndexWriterReader, TestNumericRangeQuery64, TestBytesStore, TestPackedInts, TestIndexWriterWithThreads, TestGraphTokenizers, TestAddIndexes, TestIndexWriterExceptions, TestMultiMMap, TestSearcherManager, TestDeletionPolicy, TestFlushByRamOrCountsPolicy, TestSloppyPhraseQuery, TestIndexWriterDelete, TestNRTThreads, TestAtomicUpdate, TestNorms, TestIndexWriterCommit, TestSearchWithThreads, TestConcurrentMergeScheduler, TestHighCompressionMode, TestDocumentsWriterStallControl, TestTopDocsMerge, TestLongPostings, TestMinimize, TestDocTermOrdsRewriteMethod, TestSnapshotDeletionPolicy, TestIndexWriterForceMerge, TestPerFieldPostingsFormat, TestArrayUtil, TestLevenshteinAutomata, TestByteSlices, TestBufferedIndexInput, TestDirectoryReader, TestCollectionUtil, TestBagOfPositions, TestOmitNorms, TestFixedBitSet, TestComplexExplanations, TestNRTCachingDirectory, TestIndexWriterNRTIsCurrent, TestPagedBytes, TestCrash, TestMultiThreadTermVectors, TestSegmentTermDocs, TestPerFieldPostingsFormat2, TestSort, TestCustomSearcherSort, TestPayloadTermQuery, TestHugeRamFile, TestBooleanMinShouldMatch, TestTermsEnum2, TestDeterminizeLexicon, TestIndexWriterOnDiskFull, TestSpans, TestCustomNorms, TestMixedCodecs, TestTransactionRollback, TestFastCompressionMode, TestStressIndexing2, TestLazyProxSkipping, TestDeterminism, TestDocsAndPositions, TestRamUsageEstimatorOnWildAnimals, TestFieldCacheRangeFilter, TestTermVectorsWriter, TestCharTermAttributeImpl, TestParallelLeafReader, TestBytesRefHash, TestStressNRT, TestIndexInput, TestSloppyPhraseQuery2, TestDisjunctionMaxQuery, TestForceMergeForever, TestNearSpansOrdered, TestMultiFields, TestDocumentWriter, TestCrashCausesCorruptIndex, TestLiveFieldValues, TestForTooMuchCloning, TestFuzzyQuery, TestWildcard, TestExternalCodecs, TestTermVectors, TestRegexpQuery, TestPerSegmentDeletes, TestIntBlockPool, TestPrefixInBooleanQuery, TestUniqueTermCount, TestComplexExplanationsOfNonMatches, TestSortRandom, TestParallelReaderEmptyIndex, TestTopFieldCollector, TestFileSwitchDirectory, TestSentinelIntSet, TestWindowsMMap, TestMultiLevelSkipList, TestPayloadsOnVectors, TestCachingWrapperFilter, TestFieldValueFilter, TestBooleanQueryVisitSubscorers, TestSearchForDuplicates, TestSizeBoundedForceMerge, TestIndexFileDeleter, TestPrefixQuery, TestDocIdSet, TestSubScorerFreqs, TestConjunctions, TestPositionIncrement, TestDateSort, TestSimilarity, TestVirtualMethod, TestRollingBuffer, TestSmallFloat, TestFilterLeafReader, TestDateTools, TestCharsRef, Test2BPostings, TestSameTokenSamePosition, TestAttributeSource, TestTotalHitCountCollector, TestMockDirectoryWrapper, TestIsCurrent, TestNoMergePolicy, TestPhrasePrefixQuery, TestBytesRef, Nested1, Nested2]
>    [junit4]   1> NOTE: reproduce with: ant test  -Dtestcase=Nested2 -Dtests.seed=52D6B2B0583CB5A9 -Dtests.slow=true -Dtests.locale=es_HN -Dtests.timezone=Africa/Lusaka -Dtests.asserts=false -Dtests.file.encoding=UTF-8
>    [junit4]   1>
>    [junit4] ERROR   0.07s | TestLeaveFilesIfTestFails.testWindowsUnremovableFile <<<
>    [junit4]    > Throwable #1: java.nio.file.AccessDeniedException: C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build\core\test\J0\temp\lucene.util.junitcompat.TestLeaveFilesIfTestFails$Nested2-52D6B2B0583CB5A9-001\leftover-001\child.locked
>    [junit4]    >        at sun.nio.fs.WindowsException.translateToIOException(WindowsException.java:83)
>    [junit4]    >        at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:97)
>    [junit4]    >        at sun.nio.fs.WindowsException.rethrowAsIOException(WindowsException.java:102)
>    [junit4]    >        at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:53)
>    [junit4]    >        at sun.nio.fs.WindowsFileAttributeViews$Basic.readAttributes(WindowsFileAttributeViews.java:38)
>    [junit4]    >        at org.apache.lucene.mockfile.WindowsFS.getKey(WindowsFS.java:57)
>    [junit4]    >        at org.apache.lucene.mockfile.WindowsFS.onClose(WindowsFS.java:77)
>    [junit4]    >        at org.apache.lucene.mockfile.HandleTrackingFS$5.close(HandleTrackingFS.java:210)
>    [junit4]    >        at org.apache.lucene.util.junitcompat.TestLeaveFilesIfTestFails.testWindowsUnremovableFile(TestLeaveFilesIfTestFails.java:79)
>    [junit4] Completed in 0.12s, 2 tests, 1 error <<< FAILURES!
>
> [...truncated 270 lines...]
> BUILD FAILED
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:525: The following error occurred while executing this line:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:473: The following error occurred while executing this line:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\build.xml:61: The following error occurred while executing this line:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\extra-targets.xml:39: The following error occurred while executing this line:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\build.xml:49: The following error occurred while executing this line:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:1363: The following error occurred while executing this line:
> C:\Users\JenkinsSlave\workspace\Lucene-Solr-5.x-Windows\lucene\common-build.xml:970: There were test failures: 405 suites, 3049 tests, 2 errors, 62 ignored (52 assumptions)
>
> Total time: 11 minutes 49 seconds
> Build step 'Invoke Ant' marked build as failure
> [description-setter] Description set: Java: 32bit/jdk1.7.0_67 -client -XX:+UseParallelGC (asserts: false)
> Archiving artifacts
> Recording test results
> Email was triggered for: Failure - Any
> Sending email for trigger: Failure - Any
>
>
>
>
> ---------------------------------------------------------------------
> To unsubscribe, e-mail: dev-unsubscribe@lucene.apache.org
> For additional commands, e-mail: dev-help@lucene.apache.org

---------------------------------------------------------------------
To unsubscribe, e-mail: dev-unsubscribe@lucene.apache.org
For additional commands, e-mail: dev-help@lucene.apache.org