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

[JENKINS] Lucene-Solr-trunk-Windows (64bit/jdk1.8.0) - Build # 3909 - Failure!

Build: http://jenkins.thetaphi.de/job/Lucene-Solr-trunk-Windows/3909/
Java: 64bit/jdk1.8.0 -XX:-UseCompressedOops -XX:+UseConcMarkSweepGC

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

Error Message:
waited too long for generation 1197615

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


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

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

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




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

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

Total time: 33 minutes 21 seconds
Build step 'Invoke Ant' marked build as failure
Description set: Java: 64bit/jdk1.8.0 -XX:-UseCompressedOops -XX:+UseConcMarkSweepGC
Archiving artifacts
Recording test results
Email was triggered for: Failure
Sending email for trigger: Failure



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

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: http://jenkins.thetaphi.de/job/Lucene-Solr-trunk-Windows/3910/
Java: 32bit/jdk1.8.0 -server -XX:+UseSerialGC

1 tests failed.
FAILED:  org.apache.solr.cloud.FullSolrCloudDistribCmdsTest.testDistribSearch

Error Message:
Doc Counts do not add up expected:<383> but was:<73>

Stack Trace:
java.lang.AssertionError: Doc Counts do not add up expected:<383> but was:<73>
	at __randomizedtesting.SeedInfo.seed([8E35FA1AF293791D:FD3740285CC1921]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.failNotEquals(Assert.java:647)
	at org.junit.Assert.assertEquals(Assert.java:128)
	at org.junit.Assert.assertEquals(Assert.java:472)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.assertDocCounts(AbstractFullDistribZkTestBase.java:1414)
	at org.apache.solr.cloud.FullSolrCloudDistribCmdsTest.testIndexingWithSuss(FullSolrCloudDistribCmdsTest.java:452)
	at org.apache.solr.cloud.FullSolrCloudDistribCmdsTest.doTest(FullSolrCloudDistribCmdsTest.java:136)
	at org.apache.solr.BaseDistributedSearchTestCase.testDistribSearch(BaseDistributedSearchTestCase.java:867)
	at sun.reflect.GeneratedMethodAccessor47.invoke(Unknown Source)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:483)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1617)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:826)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:862)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:876)
	at 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.TestRuleFieldCacheSanity$1.evaluate(TestRuleFieldCacheSanity.java:51)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:49)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:70)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:359)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:783)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:443)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:835)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$3.evaluate(RandomizedRunner.java:737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$4.evaluate(RandomizedRunner.java:771)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:782)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:53)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:46)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:42)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesInvariantRule$1.evaluate(SystemPropertiesInvariantRule.java:55)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:39)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:43)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:70)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:55)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:359)
	at java.lang.Thread.run(Thread.java:744)




Build Log:
[...truncated 10906 lines...]
   [junit4] Suite: org.apache.solr.cloud.FullSolrCloudDistribCmdsTest
   [junit4]   2> Creating dataDir: C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917
   [junit4]   2> 2019836 T6844 oas.BaseDistributedSearchTestCase.initHostContext Setting hostContext system property: /op_/
   [junit4]   2> 2019841 T6844 oas.SolrTestCaseJ4.setUp ###Starting testDistribSearch
   [junit4]   2> 2019843 T6844 oasc.ZkTestServer.run STARTING ZK TEST SERVER
   [junit4]   2> 2019844 T6845 oasc.ZkTestServer$ZKServerMain.runFromConfig Starting server
   [junit4]   2> 2019916 T6844 oasc.ZkTestServer.run start zk server on port:64752
   [junit4]   2> 2019918 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2019922 T6851 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1a24693 name:ZooKeeperConnection Watcher:127.0.0.1:64752 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2019922 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2019922 T6844 oascc.SolrZkClient.makePath makePath: /solr
   [junit4]   2> 2019926 T6846 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x1451629abe20000, 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:744)
   [junit4]   2> 
   [junit4]   2> 2019927 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2019929 T6853 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@721724 name:ZooKeeperConnection Watcher:127.0.0.1:64752/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2019929 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2019930 T6844 oascc.SolrZkClient.makePath makePath: /collections/collection1
   [junit4]   2> 2019933 T6844 oascc.SolrZkClient.makePath makePath: /collections/collection1/shards
   [junit4]   2> 2019935 T6844 oascc.SolrZkClient.makePath makePath: /collections/control_collection
   [junit4]   2> 2019937 T6844 oascc.SolrZkClient.makePath makePath: /collections/control_collection/shards
   [junit4]   2> 2019940 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\solrconfig-tlog.xml to /configs/conf1/solrconfig.xml
   [junit4]   2> 2019941 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/solrconfig.xml
   [junit4]   2> 2019945 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\schema15.xml to /configs/conf1/schema.xml
   [junit4]   2> 2019945 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/schema.xml
   [junit4]   2> 2019948 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\solrconfig.snippet.randomindexconfig.xml to /configs/conf1/solrconfig.snippet.randomindexconfig.xml
   [junit4]   2> 2019948 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/solrconfig.snippet.randomindexconfig.xml
   [junit4]   2> 2019952 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\stopwords.txt to /configs/conf1/stopwords.txt
   [junit4]   2> 2019952 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/stopwords.txt
   [junit4]   2> 2019955 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\protwords.txt to /configs/conf1/protwords.txt
   [junit4]   2> 2019955 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/protwords.txt
   [junit4]   2> 2019958 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\currency.xml to /configs/conf1/currency.xml
   [junit4]   2> 2019958 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/currency.xml
   [junit4]   2> 2019962 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\enumsConfig.xml to /configs/conf1/enumsConfig.xml
   [junit4]   2> 2019962 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/enumsConfig.xml
   [junit4]   2> 2019965 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\open-exchange-rates.json to /configs/conf1/open-exchange-rates.json
   [junit4]   2> 2019965 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/open-exchange-rates.json
   [junit4]   2> 2019968 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\mapping-ISOLatin1Accent.txt to /configs/conf1/mapping-ISOLatin1Accent.txt
   [junit4]   2> 2019968 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/mapping-ISOLatin1Accent.txt
   [junit4]   2> 2019971 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\old_synonyms.txt to /configs/conf1/old_synonyms.txt
   [junit4]   2> 2019972 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/old_synonyms.txt
   [junit4]   2> 2019975 T6844 oasc.AbstractZkTestCase.putConfig put C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\core\src\test-files\solr\collection1\conf\synonyms.txt to /configs/conf1/synonyms.txt
   [junit4]   2> 2019975 T6844 oascc.SolrZkClient.makePath makePath: /configs/conf1/synonyms.txt
   [junit4]   2> 2019979 T6846 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x1451629abe20001, 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:744)
   [junit4]   2> 
   [junit4]   2> 2021463 T6844 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 2021467 T6844 oejs.AbstractConnector.doStart Started SelectChannelConnector@127.0.0.1:64759
   [junit4]   2> 2021467 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 2021467 T6844 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 2021467 T6844 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060
   [junit4]   2> 2021467 T6844 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060\'
   [junit4]   2> 2021495 T6844 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060\solr.xml
   [junit4]   2> 2021505 T6844 oasc.CoreContainer.<init> New CoreContainer 25537845
   [junit4]   2> 2021505 T6844 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060\]
   [junit4]   2> 2021506 T6844 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 2021506 T6844 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 2021506 T6844 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 2021507 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 2021507 T6844 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 2021507 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 2021507 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 2021507 T6844 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 2021507 T6844 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 2021517 T6844 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 2021517 T6844 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 2021517 T6844 oasc.CoreContainer.load Host Name: 127.0.0.1
   [junit4]   2> 2021517 T6844 oasc.ZkContainer.initZooKeeper Zookeeper client=127.0.0.1:64752/solr
   [junit4]   2> 2021518 T6844 oasc.ZkController.checkChrootPath zkHost includes chroot
   [junit4]   2> 2021519 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2021524 T6864 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1e1cda6 name:ZooKeeperConnection Watcher:127.0.0.1:64752 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2021525 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2021528 T6846 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x1451629abe20002, 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:744)
   [junit4]   2> 
   [junit4]   2> 2021529 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2021531 T6866 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@2dcd99 name:ZooKeeperConnection Watcher:127.0.0.1:64752/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2021531 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2021533 T6844 oascc.SolrZkClient.makePath makePath: /overseer/queue
   [junit4]   2> 2021538 T6844 oascc.SolrZkClient.makePath makePath: /overseer/collection-queue-work
   [junit4]   2> 2021542 T6844 oascc.SolrZkClient.makePath makePath: /overseer/collection-map-running
   [junit4]   2> 2021546 T6844 oascc.SolrZkClient.makePath makePath: /overseer/collection-map-completed
   [junit4]   2> 2021549 T6844 oascc.SolrZkClient.makePath makePath: /overseer/collection-map-failure
   [junit4]   2> 2021553 T6844 oascc.SolrZkClient.makePath makePath: /live_nodes
   [junit4]   2> 2021554 T6844 oasc.ZkController.createEphemeralLiveNode Register node as live in ZooKeeper:/live_nodes/127.0.0.1:64759_op_
   [junit4]   2> 2021555 T6844 oascc.SolrZkClient.makePath makePath: /live_nodes/127.0.0.1:64759_op_
   [junit4]   2> 2021559 T6844 oascc.SolrZkClient.makePath makePath: /overseer_elect
   [junit4]   2> 2021561 T6844 oascc.SolrZkClient.makePath makePath: /overseer_elect/election
   [junit4]   2> 2021566 T6844 oasc.OverseerElectionContext.runLeaderProcess I am going to be the leader 127.0.0.1:64759_op_
   [junit4]   2> 2021566 T6844 oascc.SolrZkClient.makePath makePath: /overseer_elect/leader
   [junit4]   2> 2021568 T6844 oasc.Overseer.start Overseer (id=91503735664148483-127.0.0.1:64759_op_-n_0000000000) starting
   [junit4]   2> 2021571 T6844 oascc.SolrZkClient.makePath makePath: /overseer/queue-work
   [junit4]   2> 2021584 T6868 oasc.OverseerCollectionProcessor.run Process current queue of collection creations
   [junit4]   2> 2021584 T6844 oascc.SolrZkClient.makePath makePath: /clusterstate.json
   [junit4]   2> 2021584 T6868 oasc.OverseerCollectionProcessor.prioritizeOverseerNodes prioritizing overseer nodes
   [junit4]   2> 2021587 T6844 oascc.SolrZkClient.makePath makePath: /aliases.json
   [junit4]   2> 2021589 T6844 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 2021591 T6867 oasc.Overseer$ClusterStateUpdater.run Starting to work on the main queue
   [junit4]   2> 2021595 T6869 oasc.ZkController.publish publishing core=collection1 state=down collection=control_collection
   [junit4]   2> 2021595 T6869 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 2021596 T6869 oasc.ZkController.waitForCoreNodeName look for our core node name
   [junit4]   2> 2021596 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2021598 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2021598 T6867 oasc.Overseer$ClusterStateUpdater.updateState Update state numShards=1 message={
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "state":"down",
   [junit4]   2> 	  "base_url":"http://127.0.0.1:64759/op_",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:64759_op_",
   [junit4]   2> 	  "shard":null,
   [junit4]   2> 	  "collection":"control_collection",
   [junit4]   2> 	  "numShards":"1",
   [junit4]   2> 	  "core_node_name":null}
   [junit4]   2> 2021598 T6867 oasc.Overseer$ClusterStateUpdater.createCollection Create collection control_collection with shards [shard1]
   [junit4]   2> 2021598 T6867 oasc.Overseer$ClusterStateUpdater.updateState Assigning new node to shard shard=shard1
   [junit4]   2> 2021601 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2021602 T6866 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> 2022314 T6869 oasc.ZkController.waitForShardId waiting to find shard id in clusterstate for collection1
   [junit4]   2> 2022314 T6869 oasc.ZkController.createCollectionZkNode Check for collection zkNode:control_collection
   [junit4]   2> 2022315 T6869 oasc.ZkController.createCollectionZkNode Collection zkNode exists
   [junit4]   2> 2022315 T6869 oascc.ZkStateReader.readConfigName Load collection config from:/collections/control_collection
   [junit4]   2> 2022316 T6869 oascc.ZkStateReader.readConfigName path=/collections/control_collection configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 2022316 T6869 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060\collection1\'
   [junit4]   2> 2022316 T6869 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060/collection1/lib/.svn/' to classloader
   [junit4]   2> 2022318 T6869 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060/collection1/lib/classes/' to classloader
   [junit4]   2> 2022318 T6869 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060/collection1/lib/README' to classloader
   [junit4]   2> 2022343 T6869 oasc.SolrConfig.<init> Using Lucene MatchVersion: LUCENE_50
   [junit4]   2> 2022349 T6869 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 2022352 T6869 oass.IndexSchema.readSchema Reading Solr Schema from schema.xml
   [junit4]   2> 2022355 T6869 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 2022439 T6869 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 2022441 T6869 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 2022441 T6869 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 2022445 T6869 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 2022467 T6869 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from collection control_collection
   [junit4]   2> 2022467 T6869 oasc.SolrCore.initDirectoryFactory org.apache.solr.core.MockDirectoryFactory
   [junit4]   2> 2022467 T6869 oasc.SolrCore.<init> [collection1] Opening new SolrCore at ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-controljetty-1396236201060\collection1\, dataDir=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/control/data\
   [junit4]   2> 2022467 T6869 oasc.JmxMonitoredMap.<init> JMX monitoring is enabled. Adding Solr mbeans to JMX Server: com.sun.jmx.mbeanserver.JmxMBeanServer@15e5dee
   [junit4]   2> 2022468 T6869 oasc.CachingDirectoryFactory.get return new directory for .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/control/data\
   [junit4]   2> 2022468 T6869 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/control/data\index/
   [junit4]   2> 2022468 T6869 oasc.SolrCore.initIndex WARN [collection1] Solr index directory '.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922\control\data\index' doesn't exist. Creating new index...
   [junit4]   2> 2022468 T6869 oasc.CachingDirectoryFactory.get return new directory for .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/control/data\index
   [junit4]   2> 2022468 T6869 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=35, maxMergeAtOnceExplicit=26, maxMergedSegmentMB=81.3994140625, floorSegmentMB=1.259765625, forceMergeDeletesPctAllowed=18.51514692898426, segmentsPerTier=20.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.2597174639998315
   [junit4]   2> 2022469 T6869 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=MockDirectoryWrapper(RAMDirectory@15faf85 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@15c3c55),segFN=segments_1,generation=1}
   [junit4]   2> 2022469 T6869 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "nodistrib"
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "dedupe"
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "dedupe"
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "stored_sig"
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "stored_sig"
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-explicit"
   [junit4]   2> 2022471 T6869 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 2022472 T6869 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 2022472 T6869 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 2022472 T6869 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 2022472 T6869 oasc.RequestHandlers.initHandlersFromConfig created /get: solr.RealTimeGetHandler
   [junit4]   2> 2022472 T6869 oasc.RequestHandlers.initHandlersFromConfig adding lazy requestHandler: solr.ReplicationHandler
   [junit4]   2> 2022472 T6869 oasc.RequestHandlers.initHandlersFromConfig created /replication: solr.ReplicationHandler
   [junit4]   2> 2022473 T6869 oasc.RequestHandlers.initHandlersFromConfig created /update: solr.UpdateRequestHandler
   [junit4]   2> 2022473 T6869 oasc.RequestHandlers.initHandlersFromConfig created /admin/: org.apache.solr.handler.admin.AdminHandlers
   [junit4]   2> 2022473 T6869 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: solr.admin.ShowFileRequestHandler
   [junit4]   2> 2022474 T6869 oasc.RequestHandlers.initHandlersFromConfig created /admin/fileedit: solr.admin.EditFileRequestHandler
   [junit4]   2> 2022478 T6869 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 2022480 T6869 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 2022480 T6869 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 2022481 T6869 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogByteSizeMergePolicy: [LogByteSizeMergePolicy: minMergeSize=1677721, mergeFactor=46, maxMergeSize=2147483648, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=true, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.1361210699333685]
   [junit4]   2> 2022481 T6869 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=MockDirectoryWrapper(RAMDirectory@15faf85 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@15c3c55),segFN=segments_1,generation=1}
   [junit4]   2> 2022481 T6869 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 2022481 T6869 oass.SolrIndexSearcher.<init> Opening Searcher@ba0831[collection1] main
   [junit4]   2> 2022481 T6869 oascc.ZkStateReader.readConfigName Load collection config from:/collections/control_collection
   [junit4]   2> 2022483 T6869 oascc.ZkStateReader.readConfigName path=/collections/control_collection configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 2022483 T6869 oasr.ManagedResourceStorage.newStorageIO Setting up ZooKeeper-based storage for the RestManager with znodeBase: /configs/conf1
   [junit4]   2> 2022483 T6869 oasr.ManagedResourceStorage$ZooKeeperStorageIO.configure Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 2022483 T6869 oasr.RestManager.init Initializing RestManager with initArgs: {}
   [junit4]   2> 2022483 T6869 oasr.ManagedResourceStorage.load Reading _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 2022484 T6869 oasr.ManagedResourceStorage$ZooKeeperStorageIO.openInputStream No data found for znode /configs/conf1/_rest_managed.json
   [junit4]   2> 2022484 T6869 oasr.ManagedResourceStorage.load Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 2022484 T6869 oasr.ManagedResource.notifyObserversDuringInit WARN No registered observers for /rest/managed
   [junit4]   2> 2022484 T6869 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 2022486 T6869 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 2022486 T6870 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@ba0831[collection1] main{StandardDirectoryReader(segments_1:1:nrt)}
   [junit4]   2> 2022488 T6844 oass.SolrDispatchFilter.init user.dir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0
   [junit4]   2> 2022488 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init() done
   [junit4]   2> 2022488 T6873 oasc.ZkController.register Register replica - core:collection1 address:http://127.0.0.1:64759/op_ collection:control_collection shard:shard1
   [junit4]   2> 2022489 T6873 oascc.SolrZkClient.makePath makePath: /collections/control_collection/leader_elect/shard1/election
   [junit4]   2> 2022490 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2022492 T6875 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1f42904 name:ZooKeeperConnection Watcher:127.0.0.1:64752/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2022493 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2022495 T6844 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 2022498 T6844 oasc.ChaosMonkey.monkeyLog monkey: init - expire sessions:false cause connection loss:false
   [junit4]   2> 2022500 T6873 oasc.ShardLeaderElectionContext.runLeaderProcess Running the leader process for shard shard1
   [junit4]   2> 2022502 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022503 T6873 oasc.ShardLeaderElectionContext.waitForReplicasToComeUp Enough replicas found to continue.
   [junit4]   2> 2022503 T6873 oasc.ShardLeaderElectionContext.runLeaderProcess I may be the new leader - try and sync
   [junit4]   2> ASYNC  NEW_CORE C2604 name=collection1 org.apache.solr.core.SolrCore@18941f3 url=http://127.0.0.1:64759/op_/collection1 node=127.0.0.1:64759_op_ C2604_STATE=coll:control_collection core:collection1 props:{state=down, base_url=http://127.0.0.1:64759/op_, core=collection1, node_name=127.0.0.1:64759_op_}
   [junit4]   2> 2022503 T6873 C2604 P64759 oasc.SyncStrategy.sync Sync replicas to http://127.0.0.1:64759/op_/collection1/
   [junit4]   2> 2022504 T6873 C2604 P64759 oasc.SyncStrategy.syncReplicas Sync Success - now sync replicas to me
   [junit4]   2> 2022504 T6873 C2604 P64759 oasc.SyncStrategy.syncToMe http://127.0.0.1:64759/op_/collection1/ has no replicas
   [junit4]   2> 2022504 T6873 oasc.ShardLeaderElectionContext.runLeaderProcess I am the new leader: http://127.0.0.1:64759/op_/collection1/ shard1
   [junit4]   2> 2022504 T6873 oascc.SolrZkClient.makePath makePath: /collections/control_collection/leaders/shard1
   [junit4]   2> 2022509 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2022514 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022517 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022521 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022589 T6866 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> 2022589 T6875 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> 2022616 T6873 oasc.ZkController.register We are http://127.0.0.1:64759/op_/collection1/ and leader is http://127.0.0.1:64759/op_/collection1/
   [junit4]   2> 2022616 T6873 oasc.ZkController.register No LogReplay needed for core=collection1 baseURL=http://127.0.0.1:64759/op_
   [junit4]   2> 2022616 T6873 oasc.ZkController.checkRecovery I am the leader, no recovery necessary
   [junit4]   2> 2022616 T6873 oasc.ZkController.publish publishing core=collection1 state=active collection=control_collection
   [junit4]   2> 2022616 T6873 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 2022619 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022619 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022619 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022621 T6873 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2022623 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2022623 T6867 oasc.Overseer$ClusterStateUpdater.updateState Update state numShards=3 message={
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "state":"active",
   [junit4]   2> 	  "base_url":"http://127.0.0.1:64759/op_",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:64759_op_",
   [junit4]   2> 	  "shard":"shard1",
   [junit4]   2> 	  "collection":"control_collection",
   [junit4]   2> 	  "numShards":"3",
   [junit4]   2> 	  "core_node_name":"core_node1"}
   [junit4]   2> 2022632 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2022698 T6875 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> 2022698 T6866 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> 2023856 T6844 oasc.AbstractFullDistribZkTestBase.createJettys create jetty 1
   [junit4]   2> 2023856 T6844 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 2023861 T6844 oejs.AbstractConnector.doStart Started SelectChannelConnector@127.0.0.1:64771
   [junit4]   2> 2023862 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 2023862 T6844 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 2023862 T6844 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579
   [junit4]   2> 2023862 T6844 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579\'
   [junit4]   2> 2023892 T6844 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579\solr.xml
   [junit4]   2> 2023899 T6844 oasc.CoreContainer.<init> New CoreContainer 21528443
   [junit4]   2> 2023900 T6844 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579\]
   [junit4]   2> 2023901 T6844 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 2023901 T6844 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 2023901 T6844 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 2023901 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 2023901 T6844 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 2023901 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 2023902 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 2023902 T6844 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 2023902 T6844 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 2023902 T6844 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 2023902 T6844 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 2023903 T6844 oasc.CoreContainer.load Host Name: 127.0.0.1
   [junit4]   2> 2023903 T6844 oasc.ZkContainer.initZooKeeper Zookeeper client=127.0.0.1:64752/solr
   [junit4]   2> 2023903 T6844 oasc.ZkController.checkChrootPath zkHost includes chroot
   [junit4]   2> 2023905 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2023908 T6886 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1b45a9e name:ZooKeeperConnection Watcher:127.0.0.1:64752 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2023908 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2023910 T6846 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x1451629abe20005, 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:744)
   [junit4]   2> 
   [junit4]   2> 2023911 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2023912 T6888 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@754d05 name:ZooKeeperConnection Watcher:127.0.0.1:64752/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2023913 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2023920 T6844 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 2024569 T6844 oasc.ZkController.createEphemeralLiveNode Register node as live in ZooKeeper:/live_nodes/127.0.0.1:64771_op_
   [junit4]   2> 2024570 T6844 oascc.SolrZkClient.makePath makePath: /live_nodes/127.0.0.1:64771_op_
   [junit4]   2> 2024573 T6866 oascc.ZkStateReader$3.process Updating live nodes... (2)
   [junit4]   2> 2024573 T6875 oascc.ZkStateReader$3.process Updating live nodes... (2)
   [junit4]   2> 2024573 T6888 oascc.ZkStateReader$3.process Updating live nodes... (2)
   [junit4]   2> 2024578 T6889 oasc.ZkController.publish publishing core=collection1 state=down collection=collection1
   [junit4]   2> 2024578 T6889 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 2024579 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2024579 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2024579 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2024579 T6889 oasc.ZkController.waitForCoreNodeName look for our core node name
   [junit4]   2> 2024581 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2024581 T6867 oasc.Overseer$ClusterStateUpdater.updateState Update state numShards=3 message={
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "state":"down",
   [junit4]   2> 	  "base_url":"http://127.0.0.1:64771/op_",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:64771_op_",
   [junit4]   2> 	  "shard":null,
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "numShards":"3",
   [junit4]   2> 	  "core_node_name":null}
   [junit4]   2> 2024581 T6867 oasc.Overseer$ClusterStateUpdater.createCollection Create collection collection1 with shards [shard1, shard2, shard3]
   [junit4]   2> 2024581 T6867 oasc.Overseer$ClusterStateUpdater.updateState Assigning new node to shard shard=shard2
   [junit4]   2> 2024584 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2024585 T6875 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> 2024585 T6888 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> 2024585 T6866 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> 2025225 T6889 oasc.ZkController.waitForShardId waiting to find shard id in clusterstate for collection1
   [junit4]   2> 2025225 T6889 oasc.ZkController.createCollectionZkNode Check for collection zkNode:collection1
   [junit4]   2> 2025226 T6889 oasc.ZkController.createCollectionZkNode Collection zkNode exists
   [junit4]   2> 2025226 T6889 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 2025228 T6889 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 2025228 T6889 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579\collection1\'
   [junit4]   2> 2025228 T6889 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579/collection1/lib/.svn/' to classloader
   [junit4]   2> 2025229 T6889 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579/collection1/lib/classes/' to classloader
   [junit4]   2> 2025230 T6889 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579/collection1/lib/README' to classloader
   [junit4]   2> 2025261 T6889 oasc.SolrConfig.<init> Using Lucene MatchVersion: LUCENE_50
   [junit4]   2> 2025266 T6889 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 2025268 T6889 oass.IndexSchema.readSchema Reading Solr Schema from schema.xml
   [junit4]   2> 2025271 T6889 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 2025351 T6889 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 2025351 T6889 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 2025353 T6889 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 2025355 T6889 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 2025379 T6889 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from collection collection1
   [junit4]   2> 2025379 T6889 oasc.SolrCore.initDirectoryFactory org.apache.solr.core.MockDirectoryFactory
   [junit4]   2> 2025380 T6889 oasc.SolrCore.<init> [collection1] Opening new SolrCore at .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty1-1396236203579\collection1\, dataDir=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty1\
   [junit4]   2> 2025380 T6889 oasc.JmxMonitoredMap.<init> JMX monitoring is enabled. Adding Solr mbeans to JMX Server: com.sun.jmx.mbeanserver.JmxMBeanServer@15e5dee
   [junit4]   2> 2025380 T6889 oasc.CachingDirectoryFactory.get return new directory for .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty1\
   [junit4]   2> 2025380 T6889 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty1\index/
   [junit4]   2> 2025380 T6889 oasc.SolrCore.initIndex WARN [collection1] Solr index directory '.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922\jetty1\index' doesn't exist. Creating new index...
   [junit4]   2> 2025381 T6889 oasc.CachingDirectoryFactory.get return new directory for .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty1\index
   [junit4]   2> 2025381 T6889 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=35, maxMergeAtOnceExplicit=26, maxMergedSegmentMB=81.3994140625, floorSegmentMB=1.259765625, forceMergeDeletesPctAllowed=18.51514692898426, segmentsPerTier=20.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.2597174639998315
   [junit4]   2> 2025381 T6889 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=MockDirectoryWrapper(RAMDirectory@1bbb12e lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@fdf143),segFN=segments_1,generation=1}
   [junit4]   2> 2025381 T6889 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 2025383 T6889 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "nodistrib"
   [junit4]   2> 2025383 T6889 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "dedupe"
   [junit4]   2> 2025384 T6889 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "dedupe"
   [junit4]   2> 2025384 T6889 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "stored_sig"
   [junit4]   2> 2025384 T6889 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "stored_sig"
   [junit4]   2> 2025384 T6889 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-explicit"
   [junit4]   2> 2025385 T6889 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 2025385 T6889 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 2025385 T6889 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 2025385 T6889 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 2025385 T6889 oasc.RequestHandlers.initHandlersFromConfig created /get: solr.RealTimeGetHandler
   [junit4]   2> 2025385 T6889 oasc.RequestHandlers.initHandlersFromConfig adding lazy requestHandler: solr.ReplicationHandler
   [junit4]   2> 2025385 T6889 oasc.RequestHandlers.initHandlersFromConfig created /replication: solr.ReplicationHandler
   [junit4]   2> 2025386 T6889 oasc.RequestHandlers.initHandlersFromConfig created /update: solr.UpdateRequestHandler
   [junit4]   2> 2025386 T6889 oasc.RequestHandlers.initHandlersFromConfig created /admin/: org.apache.solr.handler.admin.AdminHandlers
   [junit4]   2> 2025387 T6889 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: solr.admin.ShowFileRequestHandler
   [junit4]   2> 2025387 T6889 oasc.RequestHandlers.initHandlersFromConfig created /admin/fileedit: solr.admin.EditFileRequestHandler
   [junit4]   2> 2025389 T6889 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 2025392 T6889 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 2025393 T6889 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 2025393 T6889 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogByteSizeMergePolicy: [LogByteSizeMergePolicy: minMergeSize=1677721, mergeFactor=46, maxMergeSize=2147483648, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=true, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.1361210699333685]
   [junit4]   2> 2025394 T6889 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=MockDirectoryWrapper(RAMDirectory@1bbb12e lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@fdf143),segFN=segments_1,generation=1}
   [junit4]   2> 2025394 T6889 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 2025394 T6889 oass.SolrIndexSearcher.<init> Opening Searcher@169c74a[collection1] main
   [junit4]   2> 2025394 T6889 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 2025395 T6889 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 2025395 T6889 oasr.ManagedResourceStorage.newStorageIO Setting up ZooKeeper-based storage for the RestManager with znodeBase: /configs/conf1
   [junit4]   2> 2025395 T6889 oasr.ManagedResourceStorage$ZooKeeperStorageIO.configure Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 2025395 T6889 oasr.RestManager.init Initializing RestManager with initArgs: {}
   [junit4]   2> 2025395 T6889 oasr.ManagedResourceStorage.load Reading _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 2025396 T6889 oasr.ManagedResourceStorage$ZooKeeperStorageIO.openInputStream No data found for znode /configs/conf1/_rest_managed.json
   [junit4]   2> 2025396 T6889 oasr.ManagedResourceStorage.load Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 2025396 T6889 oasr.ManagedResource.notifyObserversDuringInit WARN No registered observers for /rest/managed
   [junit4]   2> 2025396 T6889 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 2025399 T6890 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@169c74a[collection1] main{StandardDirectoryReader(segments_1:1:nrt)}
   [junit4]   2> 2025400 T6889 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 2025401 T6893 oasc.ZkController.register Register replica - core:collection1 address:http://127.0.0.1:64771/op_ collection:collection1 shard:shard2
   [junit4]   2> 2025402 T6844 oass.SolrDispatchFilter.init user.dir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0
   [junit4]   2> 2025402 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init() done
   [junit4]   2> 2025403 T6893 oascc.SolrZkClient.makePath makePath: /collections/collection1/leader_elect/shard2/election
   [junit4]   2> 2025412 T6893 oasc.ShardLeaderElectionContext.runLeaderProcess Running the leader process for shard shard2
   [junit4]   2> 2025416 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025423 T6893 oasc.ShardLeaderElectionContext.waitForReplicasToComeUp Enough replicas found to continue.
   [junit4]   2> 2025423 T6893 oasc.ShardLeaderElectionContext.runLeaderProcess I may be the new leader - try and sync
   [junit4]   2> ASYNC  NEW_CORE C2605 name=collection1 org.apache.solr.core.SolrCore@1d1c1a8 url=http://127.0.0.1:64771/op_/collection1 node=127.0.0.1:64771_op_ C2605_STATE=coll:collection1 core:collection1 props:{state=down, base_url=http://127.0.0.1:64771/op_, core=collection1, node_name=127.0.0.1:64771_op_}
   [junit4]   2> 2025423 T6893 C2605 P64771 oasc.SyncStrategy.sync Sync replicas to http://127.0.0.1:64771/op_/collection1/
   [junit4]   2> 2025423 T6893 C2605 P64771 oasc.SyncStrategy.syncReplicas Sync Success - now sync replicas to me
   [junit4]   2> 2025423 T6893 C2605 P64771 oasc.SyncStrategy.syncToMe http://127.0.0.1:64771/op_/collection1/ has no replicas
   [junit4]   2> 2025423 T6893 oasc.ShardLeaderElectionContext.runLeaderProcess I am the new leader: http://127.0.0.1:64771/op_/collection1/ shard2
   [junit4]   2> 2025423 T6893 oascc.SolrZkClient.makePath makePath: /collections/collection1/leaders/shard2
   [junit4]   2> 2025425 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2025433 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025436 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025442 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025510 T6888 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> 2025511 T6875 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> 2025511 T6866 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> 2025535 T6893 oasc.ZkController.register We are http://127.0.0.1:64771/op_/collection1/ and leader is http://127.0.0.1:64771/op_/collection1/
   [junit4]   2> 2025535 T6893 oasc.ZkController.register No LogReplay needed for core=collection1 baseURL=http://127.0.0.1:64771/op_
   [junit4]   2> 2025535 T6893 oasc.ZkController.checkRecovery I am the leader, no recovery necessary
   [junit4]   2> 2025535 T6893 oasc.ZkController.publish publishing core=collection1 state=active collection=collection1
   [junit4]   2> 2025535 T6893 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 2025539 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025539 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025539 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025540 T6893 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2025542 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2025542 T6867 oasc.Overseer$ClusterStateUpdater.updateState Update state numShards=3 message={
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "state":"active",
   [junit4]   2> 	  "base_url":"http://127.0.0.1:64771/op_",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:64771_op_",
   [junit4]   2> 	  "shard":"shard2",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "numShards":"3",
   [junit4]   2> 	  "core_node_name":"core_node1"}
   [junit4]   2> 2025547 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2025614 T6888 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> 2025615 T6866 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> 2025615 T6875 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> 2026879 T6844 oasc.AbstractFullDistribZkTestBase.createJettys create jetty 2
   [junit4]   2> 2026880 T6844 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 2026883 T6844 oejs.AbstractConnector.doStart Started SelectChannelConnector@127.0.0.1:64780
   [junit4]   2> 2026884 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 2026884 T6844 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 2026884 T6844 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483
   [junit4]   2> 2026884 T6844 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483\'
   [junit4]   2> 2026907 T6844 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483\solr.xml
   [junit4]   2> 2026917 T6844 oasc.CoreContainer.<init> New CoreContainer 32031111
   [junit4]   2> 2026917 T6844 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483\]
   [junit4]   2> 2026918 T6844 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 2026918 T6844 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 2026918 T6844 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 2026918 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 2026919 T6844 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 2026919 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 2026919 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 2026920 T6844 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 2026920 T6844 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 2026920 T6844 oasl.LogWatcher.createWatcher SLF4J impl is org.slf4j.impl.Log4jLoggerFactory
   [junit4]   2> 2026920 T6844 oasl.LogWatcher.newRegisteredLogWatcher Registering Log Listener [Log4j (org.slf4j.impl.Log4jLoggerFactory)]
   [junit4]   2> 2026920 T6844 oasc.CoreContainer.load Host Name: 127.0.0.1
   [junit4]   2> 2026921 T6844 oasc.ZkContainer.initZooKeeper Zookeeper client=127.0.0.1:64752/solr
   [junit4]   2> 2026921 T6844 oasc.ZkController.checkChrootPath zkHost includes chroot
   [junit4]   2> 2026923 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2026947 T6904 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@931ee5 name:ZooKeeperConnection Watcher:127.0.0.1:64752 got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2026948 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2026951 T6846 oazs.NIOServerCnxn.doIO WARN caught end of stream exception EndOfStreamException: Unable to read additional data from client sessionid 0x1451629abe20007, 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:744)
   [junit4]   2> 
   [junit4]   2> 2026952 T6844 oascc.ConnectionManager.waitForConnected Waiting for client to connect to ZooKeeper
   [junit4]   2> 2026954 T6906 oascc.ConnectionManager.process Watcher org.apache.solr.common.cloud.ConnectionManager@1ebe88c name:ZooKeeperConnection Watcher:127.0.0.1:64752/solr got event WatchedEvent state:SyncConnected type:None path:null path:null type:None
   [junit4]   2> 2026954 T6844 oascc.ConnectionManager.waitForConnected Client is connected to ZooKeeper
   [junit4]   2> 2026963 T6844 oascc.ZkStateReader.createClusterStateWatchersAndUpdate Updating cluster state from ZooKeeper... 
   [junit4]   2> 2027612 T6844 oasc.ZkController.createEphemeralLiveNode Register node as live in ZooKeeper:/live_nodes/127.0.0.1:64780_op_
   [junit4]   2> 2027613 T6844 oascc.SolrZkClient.makePath makePath: /live_nodes/127.0.0.1:64780_op_
   [junit4]   2> 2027616 T6866 oascc.ZkStateReader$3.process Updating live nodes... (3)
   [junit4]   2> 2027617 T6906 oascc.ZkStateReader$3.process Updating live nodes... (3)
   [junit4]   2> 2027617 T6875 oascc.ZkStateReader$3.process Updating live nodes... (3)
   [junit4]   2> 2027617 T6888 oascc.ZkStateReader$3.process Updating live nodes... (3)
   [junit4]   2> 2027624 T6907 oasc.ZkController.publish publishing core=collection1 state=down collection=collection1
   [junit4]   2> 2027624 T6907 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 2027625 T6907 oasc.ZkController.waitForCoreNodeName look for our core node name
   [junit4]   2> 2027626 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2027626 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2027626 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2027628 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2027628 T6867 oasc.Overseer$ClusterStateUpdater.updateState Update state numShards=3 message={
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "state":"down",
   [junit4]   2> 	  "base_url":"http://127.0.0.1:64780/op_",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:64780_op_",
   [junit4]   2> 	  "shard":null,
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "numShards":"3",
   [junit4]   2> 	  "core_node_name":null}
   [junit4]   2> 2027628 T6867 oasc.Overseer$ClusterStateUpdater.updateState Collection already exists with numShards=3
   [junit4]   2> 2027628 T6867 oasc.Overseer$ClusterStateUpdater.updateState Assigning new node to shard shard=shard3
   [junit4]   2> 2027632 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2027633 T6866 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> 2027633 T6888 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> 2027633 T6906 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> 2027633 T6875 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> 2028272 T6907 oasc.ZkController.waitForShardId waiting to find shard id in clusterstate for collection1
   [junit4]   2> 2028272 T6907 oasc.ZkController.createCollectionZkNode Check for collection zkNode:collection1
   [junit4]   2> 2028273 T6907 oasc.ZkController.createCollectionZkNode Collection zkNode exists
   [junit4]   2> 2028273 T6907 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 2028274 T6907 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 2028274 T6907 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483\collection1\'
   [junit4]   2> 2028274 T6907 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483/collection1/lib/.svn/' to classloader
   [junit4]   2> 2028275 T6907 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483/collection1/lib/classes/' to classloader
   [junit4]   2> 2028277 T6907 oasc.SolrResourceLoader.replaceClassLoader Adding 'file:/C:/Users/JenkinsSlave/workspace/Lucene-Solr-trunk-Windows/solr/build/solr-core/test/J0/solrtest-FullSolrCloudDistribCmdsTest-1396236200917/org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483/collection1/lib/README' to classloader
   [junit4]   2> 2028309 T6907 oasc.SolrConfig.<init> Using Lucene MatchVersion: LUCENE_50
   [junit4]   2> 2028314 T6907 oasc.SolrConfig.<init> Loaded SolrConfig: solrconfig.xml
   [junit4]   2> 2028317 T6907 oass.IndexSchema.readSchema Reading Solr Schema from schema.xml
   [junit4]   2> 2028319 T6907 oass.IndexSchema.readSchema [collection1] Schema name=test
   [junit4]   2> 2028398 T6907 oass.IndexSchema.readSchema default search field in schema is text
   [junit4]   2> 2028400 T6907 oass.IndexSchema.readSchema unique key field: id
   [junit4]   2> 2028400 T6907 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 2028403 T6907 oass.FileExchangeRateProvider.reload Reloading exchange rates from file currency.xml
   [junit4]   2> 2028427 T6907 oasc.CoreContainer.create Creating SolrCore 'collection1' using configuration from collection collection1
   [junit4]   2> 2028427 T6907 oasc.SolrCore.initDirectoryFactory org.apache.solr.core.MockDirectoryFactory
   [junit4]   2> 2028428 T6907 oasc.SolrCore.<init> [collection1] Opening new SolrCore at ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty2-1396236206483\collection1\, dataDir=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty2\
   [junit4]   2> 2028428 T6907 oasc.JmxMonitoredMap.<init> JMX monitoring is enabled. Adding Solr mbeans to JMX Server: com.sun.jmx.mbeanserver.JmxMBeanServer@15e5dee
   [junit4]   2> 2028428 T6907 oasc.CachingDirectoryFactory.get return new directory for .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty2\
   [junit4]   2> 2028428 T6907 oasc.SolrCore.getNewIndexDir New index directory detected: old=null new=.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty2\index/
   [junit4]   2> 2028428 T6907 oasc.SolrCore.initIndex WARN [collection1] Solr index directory '.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922\jetty2\index' doesn't exist. Creating new index...
   [junit4]   2> 2028429 T6907 oasc.CachingDirectoryFactory.get return new directory for .\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-1396236200922/jetty2\index
   [junit4]   2> 2028429 T6907 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=35, maxMergeAtOnceExplicit=26, maxMergedSegmentMB=81.3994140625, floorSegmentMB=1.259765625, forceMergeDeletesPctAllowed=18.51514692898426, segmentsPerTier=20.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.2597174639998315
   [junit4]   2> 2028429 T6907 oasc.SolrDeletionPolicy.onCommit SolrDeletionPolicy.onCommit: commits: num=1
   [junit4]   2> 		commit{dir=MockDirectoryWrapper(RAMDirectory@ec3e04 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@e61b4c),segFN=segments_1,generation=1}
   [junit4]   2> 2028429 T6907 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 2028431 T6907 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "nodistrib"
   [junit4]   2> 2028431 T6907 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "dedupe"
   [junit4]   2> 2028432 T6907 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "dedupe"
   [junit4]   2> 2028432 T6907 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "stored_sig"
   [junit4]   2> 2028432 T6907 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "stored_sig"
   [junit4]   2> 2028432 T6907 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-explicit"
   [junit4]   2> 2028432 T6907 oasup.UpdateRequestProcessorChain.init creating updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 2028432 T6907 oasup.UpdateRequestProcessorChain.init inserting DistributedUpdateProcessorFactory into updateRequestProcessorChain "distrib-dup-test-chain-implicit"
   [junit4]   2> 2028432 T6907 oasc.SolrCore.loadUpdateProcessorChains no updateRequestProcessorChain defined as default, creating implicit default
   [junit4]   2> 2028433 T6907 oasc.RequestHandlers.initHandlersFromConfig created standard: solr.StandardRequestHandler
   [junit4]   2> 2028433 T6907 oasc.RequestHandlers.initHandlersFromConfig created /get: solr.RealTimeGetHandler
   [junit4]   2> 2028433 T6907 oasc.RequestHandlers.initHandlersFromConfig adding lazy requestHandler: solr.ReplicationHandler
   [junit4]   2> 2028433 T6907 oasc.RequestHandlers.initHandlersFromConfig created /replication: solr.ReplicationHandler
   [junit4]   2> 2028434 T6907 oasc.RequestHandlers.initHandlersFromConfig created /update: solr.UpdateRequestHandler
   [junit4]   2> 2028434 T6907 oasc.RequestHandlers.initHandlersFromConfig created /admin/: org.apache.solr.handler.admin.AdminHandlers
   [junit4]   2> 2028434 T6907 oasc.RequestHandlers.initHandlersFromConfig created /admin/file: solr.admin.ShowFileRequestHandler
   [junit4]   2> 2028435 T6907 oasc.RequestHandlers.initHandlersFromConfig created /admin/fileedit: solr.admin.EditFileRequestHandler
   [junit4]   2> 2028439 T6907 oashl.XMLLoader.init xsltCacheLifetimeSeconds=60
   [junit4]   2> 2028441 T6907 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 2028441 T6907 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 2028442 T6907 oasu.RandomMergePolicy.<init> RandomMergePolicy wrapping class org.apache.lucene.index.LogByteSizeMergePolicy: [LogByteSizeMergePolicy: minMergeSize=1677721, mergeFactor=46, maxMergeSize=2147483648, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=true, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.1361210699333685]
   [junit4]   2> 2028442 T6907 oasc.SolrDeletionPolicy.onInit SolrDeletionPolicy.onInit: commits: num=1
   [junit4]   2> 		commit{dir=MockDirectoryWrapper(RAMDirectory@ec3e04 lockFactory=org.apache.lucene.store.SingleInstanceLockFactory@e61b4c),segFN=segments_1,generation=1}
   [junit4]   2> 2028442 T6907 oasc.SolrDeletionPolicy.updateCommits newest commit generation = 1
   [junit4]   2> 2028443 T6907 oass.SolrIndexSearcher.<init> Opening Searcher@8cadf[collection1] main
   [junit4]   2> 2028443 T6907 oascc.ZkStateReader.readConfigName Load collection config from:/collections/collection1
   [junit4]   2> 2028444 T6907 oascc.ZkStateReader.readConfigName path=/collections/collection1 configName=conf1 specified config exists in ZooKeeper
   [junit4]   2> 2028444 T6907 oasr.ManagedResourceStorage.newStorageIO Setting up ZooKeeper-based storage for the RestManager with znodeBase: /configs/conf1
   [junit4]   2> 2028444 T6907 oasr.ManagedResourceStorage$ZooKeeperStorageIO.configure Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 2028444 T6907 oasr.RestManager.init Initializing RestManager with initArgs: {}
   [junit4]   2> 2028444 T6907 oasr.ManagedResourceStorage.load Reading _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 2028445 T6907 oasr.ManagedResourceStorage$ZooKeeperStorageIO.openInputStream No data found for znode /configs/conf1/_rest_managed.json
   [junit4]   2> 2028445 T6907 oasr.ManagedResourceStorage.load Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 2028445 T6907 oasr.ManagedResource.notifyObserversDuringInit WARN No registered observers for /rest/managed
   [junit4]   2> 2028445 T6907 oasr.RestManager.init Initializing 0 registered ManagedResources
   [junit4]   2> 2028448 T6908 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@8cadf[collection1] main{StandardDirectoryReader(segments_1:1:nrt)}
   [junit4]   2> 2028449 T6907 oasc.CoreContainer.registerCore registering core: collection1
   [junit4]   2> 2028450 T6911 oasc.ZkController.register Register replica - core:collection1 address:http://127.0.0.1:64780/op_ collection:collection1 shard:shard3
   [junit4]   2> 2028451 T6844 oass.SolrDispatchFilter.init user.dir=C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0
   [junit4]   2> 2028451 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init() done
   [junit4]   2> 2028452 T6911 oascc.SolrZkClient.makePath makePath: /collections/collection1/leader_elect/shard3/election
   [junit4]   2> 2028460 T6911 oasc.ShardLeaderElectionContext.runLeaderProcess Running the leader process for shard shard3
   [junit4]   2> 2028463 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028464 T6911 oasc.ShardLeaderElectionContext.waitForReplicasToComeUp Enough replicas found to continue.
   [junit4]   2> 2028464 T6911 oasc.ShardLeaderElectionContext.runLeaderProcess I may be the new leader - try and sync
   [junit4]   2> ASYNC  NEW_CORE C2606 name=collection1 org.apache.solr.core.SolrCore@2a8930 url=http://127.0.0.1:64780/op_/collection1 node=127.0.0.1:64780_op_ C2606_STATE=coll:collection1 core:collection1 props:{state=down, base_url=http://127.0.0.1:64780/op_, core=collection1, node_name=127.0.0.1:64780_op_}
   [junit4]   2> 2028464 T6911 C2606 P64780 oasc.SyncStrategy.sync Sync replicas to http://127.0.0.1:64780/op_/collection1/
   [junit4]   2> 2028465 T6911 C2606 P64780 oasc.SyncStrategy.syncReplicas Sync Success - now sync replicas to me
   [junit4]   2> 2028465 T6911 C2606 P64780 oasc.SyncStrategy.syncToMe http://127.0.0.1:64780/op_/collection1/ has no replicas
   [junit4]   2> 2028465 T6911 oasc.ShardLeaderElectionContext.runLeaderProcess I am the new leader: http://127.0.0.1:64780/op_/collection1/ shard3
   [junit4]   2> 2028466 T6911 oascc.SolrZkClient.makePath makePath: /collections/collection1/leaders/shard3
   [junit4]   2> 2028466 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2028473 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028476 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028480 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028549 T6888 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> 2028550 T6906 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> 2028550 T6866 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> 2028550 T6875 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> 2028576 T6911 oasc.ZkController.register We are http://127.0.0.1:64780/op_/collection1/ and leader is http://127.0.0.1:64780/op_/collection1/
   [junit4]   2> 2028576 T6911 oasc.ZkController.register No LogReplay needed for core=collection1 baseURL=http://127.0.0.1:64780/op_
   [junit4]   2> 2028576 T6911 oasc.ZkController.checkRecovery I am the leader, no recovery necessary
   [junit4]   2> 2028576 T6911 oasc.ZkController.publish publishing core=collection1 state=active collection=collection1
   [junit4]   2> 2028576 T6911 oasc.ZkController.publish numShards not found on descriptor - reading it from system property
   [junit4]   2> 2028577 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028577 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028577 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028579 T6911 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2028581 T6867 oascc.ZkStateReader.updateClusterState Updating cloud state from ZooKeeper... 
   [junit4]   2> 2028581 T6867 oasc.Overseer$ClusterStateUpdater.updateState Update state numShards=3 message={
   [junit4]   2> 	  "operation":"state",
   [junit4]   2> 	  "state":"active",
   [junit4]   2> 	  "base_url":"http://127.0.0.1:64780/op_",
   [junit4]   2> 	  "core":"collection1",
   [junit4]   2> 	  "roles":null,
   [junit4]   2> 	  "node_name":"127.0.0.1:64780_op_",
   [junit4]   2> 	  "shard":"shard3",
   [junit4]   2> 	  "collection":"collection1",
   [junit4]   2> 	  "numShards":"3",
   [junit4]   2> 	  "core_node_name":"core_node2"}
   [junit4]   2> 2028584 T6866 oasc.DistributedQueue$LatchChildWatcher.process LatchChildWatcher fired on path: /overseer/queue state: SyncConnected type NodeChildrenChanged
   [junit4]   2> 2028658 T6888 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> 2028658 T6866 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> 2028658 T6906 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> 2028659 T6875 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> 2029734 T6844 oasc.AbstractFullDistribZkTestBase.createJettys create jetty 3
   [junit4]   2> 2029734 T6844 oejs.Server.doStart jetty-8.1.10.v20130312
   [junit4]   2> 2029738 T6844 oejs.AbstractConnector.doStart Started SelectChannelConnector@127.0.0.1:64789
   [junit4]   2> 2029739 T6844 oass.SolrDispatchFilter.init SolrDispatchFilter.init()
   [junit4]   2> 2029739 T6844 oasc.SolrResourceLoader.locateSolrHome JNDI not configured for solr (NoInitialContextEx)
   [junit4]   2> 2029739 T6844 oasc.SolrResourceLoader.locateSolrHome using system property solr.solr.home: ..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty3-1396236209532
   [junit4]   2> 2029739 T6844 oasc.SolrResourceLoader.<init> new SolrResourceLoader for directory: '..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty3-1396236209532\'
   [junit4]   2> 2029771 T6844 oasc.ConfigSolr.fromFile Loading container configuration from C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty3-1396236209532\solr.xml
   [junit4]   2> 2029781 T6844 oasc.CoreContainer.<init> New CoreContainer 2288538
   [junit4]   2> 2029781 T6844 oasc.CoreContainer.load Loading cores into CoreContainer [instanceDir=..\..\..\..\..\..\..\..\..\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build\solr-core\test\J0\.\solrtest-FullSolrCloudDistribCmdsTest-1396236200917\org.apache.solr.cloud.FullSolrCloudDistribCmdsTest-jetty3-1396236209532\]
   [junit4]   2> 2029784 T6844 oashc.HttpShardHandlerFactory.getParameter Setting socketTimeout to: 90000
   [junit4]   2> 2029784 T6844 oashc.HttpShardHandlerFactory.getParameter Setting urlScheme to: 
   [junit4]   2> 2029784 T6844 oashc.HttpShardHandlerFactory.getParameter Setting connTimeout to: 15000
   [junit4]   2> 2029784 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxConnectionsPerHost to: 20
   [junit4]   2> 2029785 T6844 oashc.HttpShardHandlerFactory.getParameter Setting corePoolSize to: 0
   [junit4]   2> 2029785 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maximumPoolSize to: 2147483647
   [junit4]   2> 2029785 T6844 oashc.HttpShardHandlerFactory.getParameter Setting maxThreadIdleTime to: 5
   [junit4]   2> 2029785 T6844 oashc.HttpShardHandlerFactory.getParameter Setting sizeOfQueue to: -1
   [junit4]   2> 2029786 T6844 oashc.HttpShardHandlerFactory.getParameter Setting fairnessPolicy to: false
   [junit4]   2> 2029787 T6844 oasl.LogWatcher.cre

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

kCmdExecutor.java:73)
   [junit4]   2> 	at org.apache.solr.common.cloud.SolrZkClient.exists(SolrZkClient.java:222)
   [junit4]   2> 	at org.apache.solr.common.cloud.ZkCmdExecutor.ensureExists(ZkCmdExecutor.java:100)
   [junit4]   2> 	at org.apache.solr.common.cloud.ZkCmdExecutor.ensureExists(ZkCmdExecutor.java:94)
   [junit4]   2> 	at org.apache.solr.cloud.OverseerElectionContext.<init>(ElectionContext.java:450)
   [junit4]   2> 	... 2 more
   [junit4]   2> 
   [junit4]   2> NOTE: test params are: codec=Lucene46: {6grand2_s=PostingsFormat(name=Direct), 7grand5_s=PostingsFormat(name=Direct), 5grand1_s=FST41, 6grand4_s=FST41, 4grand0_s=PostingsFormat(name=Direct), 7grand1_s=PostingsFormat(name=Direct), 4grand2_s=FST41, 7grand3_s=FST41, 6parent_f2_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 0parent_f2_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 3grand1_s=PostingsFormat(name=Direct), 4parent_f1_s=PostingsFormat(name=Direct), 9parent_f2_s=PostingsFormat(name=Direct), a_t=FST41, id=PostingsFormat(name=Lucene41VarGapFixedInterval), 5grand3_s=PostingsFormat(name=Direct), 5parent_f1_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 1parent_f1_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 6grand0_s=FST41, 10parent_f2_s=FST41, _root_=FST41, 8parent_f1_s=PostingsFormat(name=Direct), 2parent_f2_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 3child0_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 4child3_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 1grand0_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 4child1_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 2grand1_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 3child2_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 1child0_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 7parent_f1_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 2child1_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 3parent_f2_s=FST41, 6grand3_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 7grand6_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 5grand0_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 6grand5_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 5grand2_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 7grand2_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 4grand1_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 7grand4_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 4grand3_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 3grand0_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 6parent_f1_s=FST41, 0parent_f1_s=PostingsFormat(name=Direct), 3grand2_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 4parent_f2_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 9parent_f1_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 1parent_f2_s=PostingsFormat(name=Direct), 7grand0_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), text_t=FST41, 5grand4_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 6grand1_s=PostingsFormat(name=Lucene41VarGapFixedInterval), type_s=FST41, 5parent_f2_s=PostingsFormat(name=Direct), 8parent_f2_s=PostingsFormat(name=Lucene41VarGapFixedInterval), 10parent_f1_s=Pulsing41(freqCutoff=3 minBlockSize=45 maxBlockSize=126), 2parent_f1_s=FST41, 4child2_s=FST41, rnd_b=PostingsFormat(name=Lucene41VarGapFixedInterval), 4child0_s=PostingsFormat(name=Direct), _version_=FST41, 2grand0_s=FST41, 3child1_s=PostingsFormat(name=Direct), 7parent_f2_s=FST41, 2child0_s=FST41, 3parent_f1_s=PostingsFormat(name=Lucene41VarGapFixedInterval)}, docValues:{}, sim=RandomSimilarityProvider(queryNorm=false,coord=no): {}, locale=el, timezone=Asia/Baku
   [junit4]   2> NOTE: Windows 7 6.1 x86/Oracle Corporation 1.8.0 (32-bit)/cpus=2,threads=1,free=60910408,total=252407808
   [junit4]   2> NOTE: All tests run in this JVM: [BasicDistributedZkTest, TestRestManager, TestLazyCores, TestRangeQuery, TestCharFilters, ConvertedLegacyTest, TestFiltering, CoreAdminHandlerTest, SystemInfoHandlerTest, TestCollapseQParserPlugin, SolrTestCaseJ4Test, OpenExchangeRatesOrgProviderTest, TestModifyConfFiles, EchoParamsTest, TestSolrDeletionPolicy1, TestCloudManagedSchemaAddField, TestDynamicFieldCollectionResource, ExpressionTest, TestFieldTypeCollectionResource, TestMultiCoreConfBootstrap, ShardRoutingCustomTest, MinimalSchemaTest, ZkNodePropsTest, CacheHeaderTest, BJQParserTest, URLClassifyProcessorTest, TestDefaultSearchFieldResource, ModifyConfFileTest, NoCacheHeaderTest, UpdateRequestProcessorFactoryTest, TermVectorComponentTest, TestNoOpRegenerator, DOMUtilTest, HighlighterConfigTest, CoreContainerCoreInitFailuresTest, TestSearchPerf, TestSchemaNameResource, FieldFacetExtrasTest, TestSolrXmlPersistor, FileUtilsTest, SyncSliceTest, CollectionsAPIDistributedZkTest, TestRandomDVFaceting, DeleteReplicaTest, TestSolrJ, PluginInfoTest, TestManagedStopFilterFactory, TestRealTimeGet, TestSuggestSpellingConverter, OutputWriterTest, ReturnFieldsTest, TestSolrIndexConfig, TestExceedMaxTermLength, CurrencyFieldOpenExchangeTest, ResourceLoaderTest, AutoCommitTest, OverseerTest, TestPartialUpdateDeduplication, SimplePostToolTest, CurrencyFieldXmlFileTest, TestIndexingPerformance, ClusterStateUpdateTest, WordBreakSolrSpellCheckerTest, SolrXmlInZkTest, DeleteShardTest, SliceStateUpdateTest, PingRequestHandlerTest, TestSchemaResource, HdfsChaosMonkeySafeLeaderTest, BadCopyFieldTest, UUIDFieldTest, SimpleFacetsTest, HdfsCollectionsAPIDistributedZkTest, DistributedExpandComponentTest, ScriptEngineTest, DefaultValueUpdateProcessorTest, TestQuerySenderListener, TestDocumentBuilder, TestSolrQueryParserDefaultOperatorResource, TestFastWriter, EnumFieldTest, TermVectorComponentDistributedTest, SignatureUpdateProcessorFactoryTest, TestSolrQueryParser, TestZkChroot, ParsingFieldUpdateProcessorsTest, LegacyHTMLStripCharFilterTest, HdfsDirectoryTest, TestWordDelimiterFilterFactory, DebugComponentTest, DistributedSpellCheckComponentTest, AddBlockUpdateTest, DirectSolrConnectionTest, ChangedSchemaMergeTest, TestFreeTextSuggestions, TestDFRSimilarityFactory, TestLMDirichletSimilarityFactory, StatsComponentTest, ConnectionManagerTest, DistributedDebugComponentTest, TestSimpleQParserPlugin, TestLMJelinekMercerSimilarityFactory, TestDocSet, CopyFieldTest, SuggesterTSTTest, TestCopyFieldCollectionResource, TestCodecSupport, ResponseLogComponentTest, DisMaxRequestHandlerTest, SortByFunctionTest, TestSolrXml, TimeZoneUtilsTest, TestPseudoReturnFields, UpdateParamsTest, TestAtomicUpdateErrorCases, TestStressRecovery, TestReload, QueryParsingTest, TestFieldResource, ExternalFileFieldSortTest, ShardSplitTest, TestQueryTypes, TestQuerySenderNoQuery, InfoHandlerTest, TestDistribDocBasedVersion, TestSort, DistributedQueryComponentCustomSortTest, TriLevelCompositeIdRoutingTest, RangeFacetTest, DateMathParserTest, TestStandardQParsers, TestShortCircuitedRequests, TestLFUCache, OverseerCollectionProcessorTest, IndexBasedSpellCheckerTest, AnalysisErrorHandlingTest, PolyFieldTest, PrimitiveFieldTypeTest, TestCollationField, BlockCacheTest, CursorPagingTest, TestWriterPerf, HardAutoCommitTest, UnloadDistributedZkTest, TestCloudManagedSchema, FieldMutatingUpdateProcessorTest, TestRandomMergePolicy, TestStressVersions, TestInitQParser, TestReloadAndDeleteDocs, SolrCmdDistributorTest, DistributedTermsComponentTest, FastVectorHighlighterTest, TestBadConfig, RequiredFieldsTest, TestComponentsName, TestUniqueKeyFieldResource, TestShardHandlerFactory, FieldAnalysisRequestHandlerTest, TestRequestStatusCollectionAPI, TestManagedResourceStorage, NoFacetTest, FileBasedSpellCheckerTest, TestFastOutputStream, TestAddFieldRealTimeGet, DistributedSuggestComponentTest, TestPhraseSuggestions, BadComponentTest, TestIndexSearcher, LoggingHandlerTest, DirectUpdateHandlerOptimizeTest, TestInfoStreamLogging, PreAnalyzedFieldTest, TestMergePolicyConfig, TestJoin, BadIndexSchemaTest, MultiTermTest, AssignTest, SoftAutoCommitTest, TestFieldCollectionResource, TestFieldSortValues, TestOverriddenPrefixQueryForCustomFieldType, TestReversedWildcardFilterFactory, TestDocBasedVersionConstraints, SpatialFilterTest, TestPHPSerializedResponseWriter, QueryFacetTest, TestSolrQueryParserResource, SpellPossibilityIteratorTest, ChaosMonkeySafeLeaderTest, BasicDistributedZk2Test, OpenCloseCoreStressTest, LeaderElectionIntegrationTest, ShardRoutingTest, BasicZkTest, RecoveryZkTest, FullSolrCloudDistribCmdsTest]
   [junit4] Completed in 67.45s, 1 test, 1 failure <<< FAILURES!

[...truncated 585 lines...]
BUILD FAILED
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:467: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:447: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\build.xml:45: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\extra-targets.xml:37: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\build.xml:189: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\solr\common-build.xml:496: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\common-build.xml:1275: The following error occurred while executing this line:
C:\Users\JenkinsSlave\workspace\Lucene-Solr-trunk-Windows\lucene\common-build.xml:907: There were test failures: 394 suites, 1653 tests, 1 failure, 54 ignored (33 assumptions)

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