You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@lucene.apache.org by Apache Jenkins Server <je...@builds.apache.org> on 2017/12/12 13:35:48 UTC

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 10 - Still Unstable

Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/10/

1 tests failed.
FAILED:  org.apache.solr.store.blockcache.BlockDirectoryTest.testRandomAccessWrites

Error Message:
Direct buffer memory

Stack Trace:
java.lang.OutOfMemoryError: Direct buffer memory
	at java.nio.Bits.reserveMemory(Bits.java:694)
	at java.nio.DirectByteBuffer.<init>(DirectByteBuffer.java:123)
	at java.nio.ByteBuffer.allocateDirect(ByteBuffer.java:311)
	at org.apache.solr.store.blockcache.BlockCache.<init>(BlockCache.java:71)
	at org.apache.solr.store.blockcache.BlockDirectoryTest.setUp(BlockDirectoryTest.java:119)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:968)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 14099 lines...]
   [junit4] Suite: org.apache.solr.store.blockcache.BlockDirectoryTest
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.store.blockcache.BlockDirectoryTest_F30493D96233D566-001/init-core-data-001
   [junit4]   2> 7022120 WARN  (SUITE-BlockDirectoryTest-seed#[F30493D96233D566]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=69 numCloses=69
   [junit4]   2> 7022121 INFO  (SUITE-BlockDirectoryTest-seed#[F30493D96233D566]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 7022208 INFO  (SUITE-BlockDirectoryTest-seed#[F30493D96233D566]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (true) and clientAuth (false) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 7022208 INFO  (SUITE-BlockDirectoryTest-seed#[F30493D96233D566]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 7022211 INFO  (TEST-BlockDirectoryTest.testRandomAccessWrites-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testRandomAccessWrites
   [junit4]   2> 7028952 INFO  (TEST-BlockDirectoryTest.testRandomAccessWrites-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testRandomAccessWrites
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=BlockDirectoryTest -Dtests.method=testRandomAccessWrites -Dtests.seed=F30493D96233D566 -Dtests.multiplier=2 -Dtests.slow=true -Dtests.locale=mk -Dtests.timezone=Etc/GMT+1 -Dtests.asserts=true -Dtests.file.encoding=UTF-8
   [junit4] ERROR   6.75s J2 | BlockDirectoryTest.testRandomAccessWrites <<<
   [junit4]    > Throwable #1: java.lang.OutOfMemoryError: Direct buffer memory
   [junit4]    > 	at java.nio.Bits.reserveMemory(Bits.java:694)
   [junit4]    > 	at java.nio.DirectByteBuffer.<init>(DirectByteBuffer.java:123)
   [junit4]    > 	at java.nio.ByteBuffer.allocateDirect(ByteBuffer.java:311)
   [junit4]    > 	at org.apache.solr.store.blockcache.BlockCache.<init>(BlockCache.java:71)
   [junit4]    > 	at org.apache.solr.store.blockcache.BlockDirectoryTest.setUp(BlockDirectoryTest.java:119)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:748)Throwable #2: java.lang.NullPointerException
   [junit4]    > 	at org.apache.solr.store.blockcache.BlockDirectoryTest.tearDown(BlockDirectoryTest.java:131)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 7028999 INFO  (TEST-BlockDirectoryTest.ensureCacheConfigurable-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Starting ensureCacheConfigurable
   [junit4]   2> 7033516 INFO  (TEST-BlockDirectoryTest.ensureCacheConfigurable-seed#[F30493D96233D566]) [    ] o.a.s.s.b.BlockDirectory Block cache on write is disabled
   [junit4]   2> 7033517 INFO  (TEST-BlockDirectoryTest.ensureCacheConfigurable-seed#[F30493D96233D566]) [    ] o.a.s.s.b.BlockDirectory Block cache on write is disabled
   [junit4]   2> 7033517 INFO  (TEST-BlockDirectoryTest.ensureCacheConfigurable-seed#[F30493D96233D566]) [    ] o.a.s.s.b.BlockDirectory Block cache on read is disabled
   [junit4]   2> 7033517 INFO  (TEST-BlockDirectoryTest.ensureCacheConfigurable-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Ending ensureCacheConfigurable
   [junit4]   2> 7033532 INFO  (TEST-BlockDirectoryTest.testEOF-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testEOF
   [junit4]   2> 7034455 INFO  (TEST-BlockDirectoryTest.testEOF-seed#[F30493D96233D566]) [    ] o.a.s.s.b.BlockDirectory Block cache on write is disabled
   [junit4]   2> 7034958 INFO  (TEST-BlockDirectoryTest.testEOF-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testEOF
   [junit4]   2> 7034977 INFO  (TEST-BlockDirectoryTest.testRandomAccessWritesLargeCache-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testRandomAccessWritesLargeCache
   [junit4]   2> 7037816 INFO  (TEST-BlockDirectoryTest.testRandomAccessWritesLargeCache-seed#[F30493D96233D566]) [    ] o.a.s.s.b.BlockDirectory Block cache on write is disabled
   [junit4]   1> Total time is 10943ms
   [junit4]   2> 7048760 INFO  (TEST-BlockDirectoryTest.testRandomAccessWritesLargeCache-seed#[F30493D96233D566]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testRandomAccessWritesLargeCache
   [junit4]   2> NOTE: leaving temporary files on disk at: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.store.blockcache.BlockDirectoryTest_F30493D96233D566-001
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70): {}, docValues:{}, maxPointsInLeafNode=897, maxMBSortInHeap=6.706237207029636, sim=RandomSimilarity(queryNorm=false): {}, locale=mk, timezone=Etc/GMT+1
   [junit4]   2> NOTE: Linux 4.4.0-83-generic amd64/Oracle Corporation 1.8.0_152 (64-bit)/cpus=4,threads=1,free=333007912,total=531103744
   [junit4]   2> NOTE: All tests run in this JVM: [CurrencyFieldTypeTest, ChaosMonkeyNothingIsSafeTest, TestFiltering, SegmentsInfoRequestHandlerTest, UniqFieldsUpdateProcessorFactoryTest, LoggingHandlerTest, OverseerStatusTest, DistribJoinFromCollectionTest, BadComponentTest, QueryElevationComponentTest, CSVRequestHandlerTest, TestLFUCache, TestNumericTerms32, IndexSchemaTest, SimplePostToolTest, FileBasedSpellCheckerTest, TestEmbeddedSolrServerConstructors, SolrCloudExampleTest, CloudMLTQParserTest, DistanceUnitsTest, TestGroupingSearch, CdcrRequestHandlerTest, TestFieldCacheVsDocValues, TestFunctionQuery, TestPayloadScoreQParserPlugin, HdfsBasicDistributedZkTest, HLLUtilTest, SortByFunctionTest, TestCloudSearcherWarming, TestSchemalessBufferedUpdates, DistributedDebugComponentTest, TestSQLHandler, SolrGangliaReporterTest, EchoParamsTest, TestFieldResource, TestCoreContainer, TestHashQParserPlugin, ComputePlanActionTest, InfixSuggestersTest, TestComplexPhraseLeadingWildcard, TestConfigReload, TestLMDirichletSimilarityFactory, SpellPossibilityIteratorTest, TestSubQueryTransformerDistrib, TestDistribDocBasedVersion, TestSmileRequest, TestTrieFacet, TestSchemaNameResource, SolrShardReporterTest, TestStressLiveNodes, TestCharFilters, AlternateDirectoryTest, OverseerCollectionConfigSetProcessorTest, MigrateRouteKeyTest, TestSearchPerf, TestDistributedGrouping, TestMaxScoreQueryParser, DataDrivenBlockJoinTest, ExplicitHLLTest, TestOrdValues, SearchRateTriggerTest, MoveReplicaHDFSTest, CoreSorterTest, SSLMigrationTest, TestSolrDeletionPolicy2, OverseerTest, TestRandomRequestDistribution, RequiredFieldsTest, SuggesterWFSTTest, SolrMetricManagerTest, CoreAdminRequestStatusTest, BadCopyFieldTest, TestSha256AuthenticationProvider, BasicAuthIntegrationTest, HighlighterTest, TestCloudPivotFacet, TestDFISimilarityFactory, TestLRUCache, TestRealTimeGet, TestNoOpRegenerator, AtomicUpdatesTest, HdfsRecoveryZkTest, UUIDFieldTest, TestScoreJoinQPNoScore, TestRestManager, SolrCoreCheckLockOnStartupTest, TestDocBasedVersionConstraints, TestConfigOverlay, TestMacroExpander, RecoveryAfterSoftCommitTest, TestSchemaVersionResource, TestCollectionAPIs, TestJsonFacetRefinement, TestConfigSets, SharedFSAutoReplicaFailoverTest, TestFieldSortValues, DistributedSpellCheckComponentTest, TestFieldCacheReopen, TestSystemIdResolver, LargeFieldTest, TestPivotHelperCode, TestDynamicFieldCollectionResource, UninvertDocValuesMergePolicyTest, LeaderElectionContextKeyTest, TestHdfsCloudBackupRestore, FieldAnalysisRequestHandlerTest, TestDynamicLoading, ClassificationUpdateProcessorTest, UnloadDistributedZkTest, TestQueryTypes, DefaultValueUpdateProcessorTest, DisMaxRequestHandlerTest, TestDistributedMissingSort, CopyFieldTest, DocValuesNotIndexedTest, HdfsLockFactoryTest, TestInitParams, TestLeaderInitiatedRecoveryThread, TestExactSharedStatsCache, RequestLoggingTest, DistributedFacetPivotLargeTest, TestHalfAndHalfDocValues, AliasIntegrationTest, TestRequestForwarding, ChaosMonkeySafeLeaderTest, BasicDistributedZk2Test, CollectionsAPIDistributedZkTest, TestReplicationHandler, ZkCLITest, ShardRoutingCustomTest, TestDistributedSearch, TestSolr4Spatial, SpellCheckComponentTest, BadIndexSchemaTest, ConvertedLegacyTest, TestSort, DirectUpdateHandlerTest, TestBadConfig, SoftAutoCommitTest, DebugComponentTest, IndexBasedSpellCheckerTest, DocumentAnalysisRequestHandlerTest, XmlUpdateRequestHandlerTest, DocumentBuilderTest, TermVectorComponentTest, FastVectorHighlighterTest, SolrPluginUtilsTest, ReturnFieldsTest, BinaryUpdateRequestHandlerTest, TestPHPSerializedResponseWriter, UpdateParamsTest, TestDocSet, TestElisionMultitermQuery, TestFuzzyAnalyzedSuggestions, NotRequiredUniqueKeyTest, SynonymTokenizerTest, TestXIncludeConfig, TestPerFieldSimilarity, TestLMJelinekMercerSimilarityFactory, TestBM25SimilarityFactory, ScriptEngineTest, PrimUtilsTest, TestSuggestSpellingConverter, ClusterStateTest, TestUtils, ZkNodePropsTest, SystemInfoHandlerTest, TestRTGBase, TestCrossCoreJoin, TestTolerantSearch, TestLuceneIndexBackCompat, AssignBackwardCompatibilityTest, ChaosMonkeySafeLeaderWithPullReplicasTest, ConcurrentDeleteAndCreateCollectionTest, ConfigSetsAPITest, DeleteInactiveReplicaTest, DeleteNodeTest, DeleteShardTest, DeleteStatusTest, DistribCursorPagingTest, LeaderFailureAfterFreshStartTest, NodeMutatorTest, OutOfBoxZkACLAndCredentialsProvidersTest, OverriddenZkACLAndCredentialsProvidersTest, OverseerModifyCollectionTest, ReplicationFactorTest, RestartWhileUpdatingTest, RollingRestartTest, SolrCLIZkUtilsTest, SolrXmlInZkTest, TestCloudDeleteByQuery, TestClusterProperties, TestCollectionAPI, TestConfigSetsAPI, TestDownShardTolerantSearch, TestLockTree, TestMiniSolrCloudClusterSSL, TestRandomFlRTGCloud, TestSizeLimitedDistributedMap, TestSolrCloudWithSecureImpersonation, TestTolerantUpdateProcessorCloud, TlogReplayBufferedWhileIndexingTest, TriLevelCompositeIdRoutingTest, AutoAddReplicasPlanActionTest, ExecutePlanActionTest, HttpTriggerListenerTest, SystemLogListenerTest, BaseCdcrDistributedZkTest, CdcrBidirectionalTest, CdcrBootstrapTest, HdfsThreadLeakTest, BlobRepositoryCloudTest, CachingDirectoryFactoryTest, HdfsDirectoryFactoryTest, TestImplicitCoreProperties, TestShardHandlerFactory, TestSimpleTextCodec, TestSolrConfigHandler, TestReqParamsAPI, TestRestoreCore, TestSolrConfigHandlerConcurrent, CoreAdminCreateDiscoverTest, CoreMergeIndexesAdminHandlerTest, InfoHandlerTest, MetricsHandlerTest, SecurityConfHandlerTest, TestConfigsApi, DistributedExpandComponentTest, DistributedFacetExistsSmallTest, DistributedFacetPivotWhiteBoxTest, DistributedSuggestComponentTest, TestDistributedStatsComponentCardinality, TestSerializedLuceneMatchVersion, TestManagedStopFilterFactory, ManagedSchemaRoundRobinCloudTest, TestCloudManagedSchema, TestManagedSchemaThreadSafety, TestPointFields, TestLegacyNumericRangeQueryBuilder, TestMissingGroups, TestRecoveryHdfs, BlockDirectoryTest]
   [junit4] Completed [722/751 (1!)] on J2 in 27.44s, 4 tests, 1 error <<< FAILURES!

[...truncated 47453 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 20 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/20/

9 tests failed.
FAILED:  org.apache.solr.cloud.BasicDistributedZkTest.test

Error Message:
Timeout occured while waiting response from server at: http://127.0.0.1:49908/v_

Stack Trace:
org.apache.solr.client.solrj.SolrServerException: Timeout occured while waiting response from server at: http://127.0.0.1:49908/v_
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442:3FDCE4B76DD669BA]:0)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:654)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1103)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
	at org.apache.solr.cloud.BasicDistributedZkTest.testANewCollectionInOneInstanceWithManualShardAssignement(BasicDistributedZkTest.java:801)
	at org.apache.solr.cloud.BasicDistributedZkTest.test(BasicDistributedZkTest.java:374)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: java.net.SocketTimeoutException: Read timed out
	at java.net.SocketInputStream.socketRead0(Native Method)
	at java.net.SocketInputStream.socketRead(SocketInputStream.java:116)
	at java.net.SocketInputStream.read(SocketInputStream.java:171)
	at java.net.SocketInputStream.read(SocketInputStream.java:141)
	at org.apache.http.impl.io.SessionInputBufferImpl.streamRead(SessionInputBufferImpl.java:137)
	at org.apache.http.impl.io.SessionInputBufferImpl.fillBuffer(SessionInputBufferImpl.java:153)
	at org.apache.http.impl.io.SessionInputBufferImpl.readLine(SessionInputBufferImpl.java:282)
	at org.apache.http.impl.conn.DefaultHttpResponseParser.parseHead(DefaultHttpResponseParser.java:138)
	at org.apache.http.impl.conn.DefaultHttpResponseParser.parseHead(DefaultHttpResponseParser.java:56)
	at org.apache.http.impl.io.AbstractMessageParser.parse(AbstractMessageParser.java:259)
	at org.apache.http.impl.DefaultBHttpClientConnection.receiveResponseHeader(DefaultBHttpClientConnection.java:163)
	at org.apache.http.impl.conn.CPoolProxy.receiveResponseHeader(CPoolProxy.java:165)
	at org.apache.http.protocol.HttpRequestExecutor.doReceiveResponse(HttpRequestExecutor.java:273)
	at org.apache.http.protocol.HttpRequestExecutor.execute(HttpRequestExecutor.java:125)
	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:272)
	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:542)
	... 52 more


FAILED:  org.apache.solr.cloud.ChaosMonkeyNothingIsSafeTest.test

Error Message:
shard2 is not consistent.  Got 73 from http://127.0.0.1:44524/collection1_shard2_replica_n61 (previous client) and got 71 from http://127.0.0.1:41856/collection1_shard2_replica_n67

Stack Trace:
java.lang.AssertionError: shard2 is not consistent.  Got 73 from http://127.0.0.1:44524/collection1_shard2_replica_n61 (previous client) and got 71 from http://127.0.0.1:41856/collection1_shard2_replica_n67
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442:3FDCE4B76DD669BA]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.checkShardConsistency(AbstractFullDistribZkTestBase.java:1322)
	at org.apache.solr.cloud.ChaosMonkeyNothingIsSafeTest.test(ChaosMonkeyNothingIsSafeTest.java:234)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.ChaosMonkeyNothingIsSafeTest

Error Message:
9 threads leaked from SUITE scope at org.apache.solr.cloud.ChaosMonkeyNothingIsSafeTest:     1) Thread[id=21799, name=zkCallback-5545-thread-3, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    2) Thread[id=21522, name=Connection evictor, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    3) Thread[id=21527, name=zkCallback-5545-thread-1, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    4) Thread[id=21798, name=zkCallback-5545-thread-2, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    5) Thread[id=21524, name=TEST-ChaosMonkeyNothingIsSafeTest.test-seed#[B788DB6DC32A0442]-EventThread, state=WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)    6) Thread[id=21889, name=zkCallback-5545-thread-5, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    7) Thread[id=21839, name=zkCallback-5545-thread-4, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    8) Thread[id=21523, name=TEST-ChaosMonkeyNothingIsSafeTest.test-seed#[B788DB6DC32A0442]-SendThread(127.0.0.1:34447), state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)         at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)    9) Thread[id=21525, name=zkConnectionManagerCallback-5546-thread-1, state=WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: 9 threads leaked from SUITE scope at org.apache.solr.cloud.ChaosMonkeyNothingIsSafeTest: 
   1) Thread[id=21799, name=zkCallback-5545-thread-3, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   2) Thread[id=21522, name=Connection evictor, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   3) Thread[id=21527, name=zkCallback-5545-thread-1, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   4) Thread[id=21798, name=zkCallback-5545-thread-2, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   5) Thread[id=21524, name=TEST-ChaosMonkeyNothingIsSafeTest.test-seed#[B788DB6DC32A0442]-EventThread, state=WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)
   6) Thread[id=21889, name=zkCallback-5545-thread-5, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   7) Thread[id=21839, name=zkCallback-5545-thread-4, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   8) Thread[id=21523, name=TEST-ChaosMonkeyNothingIsSafeTest.test-seed#[B788DB6DC32A0442]-SendThread(127.0.0.1:34447), state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)
        at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)
        at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)
   9) Thread[id=21525, name=zkConnectionManagerCallback-5546-thread-1, state=WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442]:0)


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.ChaosMonkeyNothingIsSafeTest

Error Message:
There are still zombie threads that couldn't be terminated:    1) Thread[id=21799, name=zkCallback-5545-thread-3, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    2) Thread[id=21527, name=zkCallback-5545-thread-1, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    3) Thread[id=21798, name=zkCallback-5545-thread-2, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    4) Thread[id=21889, name=zkCallback-5545-thread-5, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    5) Thread[id=21839, name=zkCallback-5545-thread-4, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    6) Thread[id=21523, name=TEST-ChaosMonkeyNothingIsSafeTest.test-seed#[B788DB6DC32A0442]-SendThread(127.0.0.1:34447), state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)         at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)    7) Thread[id=21525, name=zkConnectionManagerCallback-5546-thread-1, state=WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: There are still zombie threads that couldn't be terminated:
   1) Thread[id=21799, name=zkCallback-5545-thread-3, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   2) Thread[id=21527, name=zkCallback-5545-thread-1, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   3) Thread[id=21798, name=zkCallback-5545-thread-2, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   4) Thread[id=21889, name=zkCallback-5545-thread-5, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   5) Thread[id=21839, name=zkCallback-5545-thread-4, state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   6) Thread[id=21523, name=TEST-ChaosMonkeyNothingIsSafeTest.test-seed#[B788DB6DC32A0442]-SendThread(127.0.0.1:34447), state=TIMED_WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)
        at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)
        at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)
   7) Thread[id=21525, name=zkConnectionManagerCallback-5546-thread-1, state=WAITING, group=TGRP-ChaosMonkeyNothingIsSafeTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442]:0)


FAILED:  org.apache.solr.cloud.DeleteReplicaTest.deleteLiveReplicaTest

Error Message:
Error from server at http://127.0.0.1:35203/solr: KeeperErrorCode = NoNode for /overseer/collection-queue-work/qnr-0000000004

Stack Trace:
org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at http://127.0.0.1:35203/solr: KeeperErrorCode = NoNode for /overseer/collection-queue-work/qnr-0000000004
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442:1AE86F66DE15AC37]:0)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1103)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
	at org.apache.solr.cloud.DeleteReplicaTest.deleteLiveReplicaTest(DeleteReplicaTest.java:49)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.DeleteStatusTest.testProcessAndWaitDeletesAsyncIds

Error Message:
Request id was not deleted by processAndWait call expected same:<NOT_FOUND> was not:<RUNNING>

Stack Trace:
java.lang.AssertionError: Request id was not deleted by processAndWait call expected same:<NOT_FOUND> was not:<RUNNING>
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442:8C96A143961B0DE5]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.failNotSame(Assert.java:641)
	at org.junit.Assert.assertSame(Assert.java:580)
	at org.apache.solr.cloud.DeleteStatusTest.testProcessAndWaitDeletesAsyncIds(DeleteStatusTest.java:100)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.ShardSplitTest.testSplitAfterFailedSplit

Error Message:
Shard split did not succeed after a previous failed split attempt left sub-shards in construction state

Stack Trace:
java.lang.AssertionError: Shard split did not succeed after a previous failed split attempt left sub-shards in construction state
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442:4EC548C2FF5F49C8]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.ShardSplitTest.testSplitAfterFailedSplit(ShardSplitTest.java:294)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestHdfsCloudBackupRestore.test

Error Message:
expected:<COMPLETED> but was:<RUNNING>

Stack Trace:
java.lang.AssertionError: expected:<COMPLETED> but was:<RUNNING>
	at __randomizedtesting.SeedInfo.seed([B788DB6DC32A0442:3FDCE4B76DD669BA]: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:147)
	at org.apache.solr.cloud.AbstractCloudBackupRestoreTestCase.testBackupAndRestore(AbstractCloudBackupRestoreTestCase.java:287)
	at org.apache.solr.cloud.AbstractCloudBackupRestoreTestCase.test(AbstractCloudBackupRestoreTestCase.java:140)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.common.cloud.TestCollectionStateWatchers.testWaitForStateWatcherIsRetainedOnPredicateFailure

Error Message:
Did not see a fully active cluster after 30 seconds

Stack Trace:
java.lang.AssertionError: Did not see a fully active cluster after 30 seconds
	at __randomizedtesting.SeedInfo.seed([A5621D4BB3FC9A7A:2D54BF186B537268]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.common.cloud.TestCollectionStateWatchers.testWaitForStateWatcherIsRetainedOnPredicateFailure(TestCollectionStateWatchers.java:250)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 12142 lines...]
   [junit4] Suite: org.apache.solr.cloud.TestHdfsCloudBackupRestore
   [junit4]   2> 2648050 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> Creating dataDir: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/init-core-data-001
   [junit4]   2> 2648051 WARN  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=4 numCloses=4
   [junit4]   2> 2648051 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=true
   [junit4]   2> 2648076 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (false) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   1> Formatting using clusterid: testClusterID
   [junit4]   2> 2649492 WARN  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.h.m.i.MetricsConfig Cannot locate configuration: tried hadoop-metrics2-namenode.properties,hadoop-metrics2.properties
   [junit4]   2> 2649572 WARN  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.h.h.HttpRequestLog Jetty request log can only be enabled using Log4j
   [junit4]   2> 2649612 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log jetty-6.1.26
   [junit4]   2> 2649718 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log Extract jar:file:/x1/jenkins/.ivy2/cache/org.apache.hadoop/hadoop-hdfs/tests/hadoop-hdfs-2.7.4-tests.jar!/webapps/hdfs to ./temp/Jetty_localhost_52088_hdfs____.82kkbn/webapp
   [junit4]   2> 2652613 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log Started HttpServer2$SelectChannelConnectorWithSafeStartup@localhost:52088
   [junit4]   2> 2654340 WARN  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.h.h.HttpRequestLog Jetty request log can only be enabled using Log4j
   [junit4]   2> 2654345 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log jetty-6.1.26
   [junit4]   2> 2654829 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log Extract jar:file:/x1/jenkins/.ivy2/cache/org.apache.hadoop/hadoop-hdfs/tests/hadoop-hdfs-2.7.4-tests.jar!/webapps/datanode to ./temp/Jetty_localhost_40874_datanode____.7egbr4/webapp
   [junit4]   2> 2657257 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log Started HttpServer2$SelectChannelConnectorWithSafeStartup@localhost:40874
   [junit4]   2> 2659848 WARN  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.h.h.HttpRequestLog Jetty request log can only be enabled using Log4j
   [junit4]   2> 2659877 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log jetty-6.1.26
   [junit4]   2> 2660239 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log Extract jar:file:/x1/jenkins/.ivy2/cache/org.apache.hadoop/hadoop-hdfs/tests/hadoop-hdfs-2.7.4-tests.jar!/webapps/datanode to ./temp/Jetty_localhost_51880_datanode____hl1zaz/webapp
   [junit4]   2> 2660865 ERROR (DataNode: [[[DISK]file:/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-001/hdfsBaseDir/data/data1/, [DISK]file:/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-001/hdfsBaseDir/data/data2/]]  heartbeating to localhost/127.0.0.1:55997) [    ] o.a.h.h.s.d.DirectoryScanner dfs.datanode.directoryscan.throttle.limit.ms.per.sec set to value below 1 ms/sec. Assuming default value of 1000
   [junit4]   2> 2660940 INFO  (Block report processor) [    ] BlockStateChange BLOCK* processReport 0x38184c8582cdcb: from storage DS-9ff9bed8-1028-4e7d-832a-9450e26d86e2 node DatanodeRegistration(127.0.0.1:60353, datanodeUuid=68a7425b-216b-48ab-9495-a8ee35b956d2, infoPort=46344, infoSecurePort=0, ipcPort=57207, storageInfo=lv=-56;cid=testClusterID;nsid=1882413460;c=0), blocks: 0, hasStaleStorage: true, processing time: 0 msecs
   [junit4]   2> 2660944 INFO  (Block report processor) [    ] BlockStateChange BLOCK* processReport 0x38184c8582cdcb: from storage DS-ca9f2206-2b34-4805-8f78-59114703ef18 node DatanodeRegistration(127.0.0.1:60353, datanodeUuid=68a7425b-216b-48ab-9495-a8ee35b956d2, infoPort=46344, infoSecurePort=0, ipcPort=57207, storageInfo=lv=-56;cid=testClusterID;nsid=1882413460;c=0), blocks: 0, hasStaleStorage: false, processing time: 0 msecs
   [junit4]   2> 2663161 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.m.log Started HttpServer2$SelectChannelConnectorWithSafeStartup@localhost:51880
   [junit4]   2> 2664669 ERROR (DataNode: [[[DISK]file:/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-001/hdfsBaseDir/data/data3/, [DISK]file:/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-001/hdfsBaseDir/data/data4/]]  heartbeating to localhost/127.0.0.1:55997) [    ] o.a.h.h.s.d.DirectoryScanner dfs.datanode.directoryscan.throttle.limit.ms.per.sec set to value below 1 ms/sec. Assuming default value of 1000
   [junit4]   2> 2664836 INFO  (Block report processor) [    ] BlockStateChange BLOCK* processReport 0x38184d6d806384: from storage DS-5287836d-8fa1-4600-90b8-78d4f541c30f node DatanodeRegistration(127.0.0.1:51841, datanodeUuid=1f295162-388a-4544-81c8-63e790f5cd38, infoPort=60996, infoSecurePort=0, ipcPort=59270, storageInfo=lv=-56;cid=testClusterID;nsid=1882413460;c=0), blocks: 0, hasStaleStorage: true, processing time: 4 msecs
   [junit4]   2> 2664844 INFO  (Block report processor) [    ] BlockStateChange BLOCK* processReport 0x38184d6d806384: from storage DS-79e039dc-99dd-42af-83e4-ddbadbbb2683 node DatanodeRegistration(127.0.0.1:51841, datanodeUuid=1f295162-388a-4544-81c8-63e790f5cd38, infoPort=60996, infoSecurePort=0, ipcPort=59270, storageInfo=lv=-56;cid=testClusterID;nsid=1882413460;c=0), blocks: 0, hasStaleStorage: false, processing time: 0 msecs
   [junit4]   2> 2665331 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 2 servers in /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-002
   [junit4]   2> 2665331 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 2665360 INFO  (Thread-1231) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 2665360 INFO  (Thread-1231) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 2665660 ERROR (Thread-1231) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 2665660 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:34714
   [junit4]   2> 2667016 INFO  (zkConnectionManagerCallback-2640-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2667038 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160dd1187480000, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2667063 INFO  (jetty-launcher-2637-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2667041 INFO  (jetty-launcher-2637-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2667181 INFO  (jetty-launcher-2637-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@ec4a7ef{/solr,null,AVAILABLE}
   [junit4]   2> 2667181 INFO  (jetty-launcher-2637-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@3ccb78cd{HTTP/1.1,[http/1.1]}{127.0.0.1:39159}
   [junit4]   2> 2667181 INFO  (jetty-launcher-2637-thread-2) [    ] o.e.j.s.Server Started @2700076ms
   [junit4]   2> 2667181 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=39159}
   [junit4]   2> 2667182 ERROR (jetty-launcher-2637-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2667182 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.1
   [junit4]   2> 2667182 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2667182 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2667182 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2018-01-09T22:36:43.398Z
   [junit4]   2> 2667321 INFO  (jetty-launcher-2637-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@15256e59{/solr,null,AVAILABLE}
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@5590e44{HTTP/1.1,[http/1.1]}{127.0.0.1:43801}
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.e.j.s.Server Started @2700217ms
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=43801}
   [junit4]   2> 2667322 ERROR (jetty-launcher-2637-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.1
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2667322 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2018-01-09T22:36:43.538Z
   [junit4]   2> 2667732 INFO  (zkConnectionManagerCallback-2642-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2667733 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2667754 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.c.SolrXmlConfig MBean server found: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67, but no JMX reporters were configured - adding default JMX reporter.
   [junit4]   2> 2667876 INFO  (jetty-launcher-2637-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:34714/solr
   [junit4]   2> 2667936 INFO  (zkConnectionManagerCallback-2644-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2667984 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2668043 INFO  (zkConnectionManagerCallback-2648-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2668074 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.c.SolrXmlConfig MBean server found: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67, but no JMX reporters were configured - adding default JMX reporter.
   [junit4]   2> 2668105 INFO  (jetty-launcher-2637-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:34714/solr
   [junit4]   2> 2668224 INFO  (zkConnectionManagerCallback-2652-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2668224 INFO  (zkConnectionManagerCallback-2654-thread-1-processing-n:127.0.0.1:39159_solr) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2668428 INFO  (zkConnectionManagerCallback-2656-thread-1-processing-n:127.0.0.1:43801_solr) [n:127.0.0.1:43801_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2668490 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2668661 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:43801_solr
   [junit4]   2> 2668662 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.Overseer Overseer (id=99322259155976198-127.0.0.1:43801_solr-n_0000000000) starting
   [junit4]   2> 2668679 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:43801_solr
   [junit4]   2> 2668688 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2669060 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.b.r.BackupRepositoryFactory Added backup repository with configuration params {type = repository,name = hdfs,class = org.apache.solr.core.backup.repository.HdfsBackupRepository,attributes = {name=hdfs, class=org.apache.solr.core.backup.repository.HdfsBackupRepository},args = {location=/backup,solr.hdfs.home=hdfs://localhost:55997/solr,solr.hdfs.confdir=}}
   [junit4]   2> 2669060 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.b.r.BackupRepositoryFactory Default configuration for backup repository is with configuration params {type = repository,name = hdfs,class = org.apache.solr.core.backup.repository.HdfsBackupRepository,attributes = {name=hdfs, class=org.apache.solr.core.backup.repository.HdfsBackupRepository},args = {location=/backup,solr.hdfs.home=hdfs://localhost:55997/solr,solr.hdfs.confdir=}}
   [junit4]   2> 2669572 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67
   [junit4]   2> 2669616 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2669648 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2669794 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67
   [junit4]   2> 2669794 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67
   [junit4]   2> 2669800 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:39159_solr
   [junit4]   2> 2669847 INFO  (zkCallback-2655-thread-1-processing-n:127.0.0.1:43801_solr) [n:127.0.0.1:43801_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 2669847 INFO  (jetty-launcher-2637-thread-1) [n:127.0.0.1:43801_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-002/node1/.
   [junit4]   2> 2669921 INFO  (zkCallback-2653-thread-1-processing-n:127.0.0.1:39159_solr) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 2670429 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.c.b.r.BackupRepositoryFactory Added backup repository with configuration params {type = repository,name = hdfs,class = org.apache.solr.core.backup.repository.HdfsBackupRepository,attributes = {name=hdfs, class=org.apache.solr.core.backup.repository.HdfsBackupRepository},args = {location=/backup,solr.hdfs.home=hdfs://localhost:55997/solr,solr.hdfs.confdir=}}
   [junit4]   2> 2670432 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.c.b.r.BackupRepositoryFactory Default configuration for backup repository is with configuration params {type = repository,name = hdfs,class = org.apache.solr.core.backup.repository.HdfsBackupRepository,attributes = {name=hdfs, class=org.apache.solr.core.backup.repository.HdfsBackupRepository},args = {location=/backup,solr.hdfs.home=hdfs://localhost:55997/solr,solr.hdfs.confdir=}}
   [junit4]   2> 2670824 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67
   [junit4]   2> 2671072 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67
   [junit4]   2> 2671072 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2a1a67
   [junit4]   2> 2671074 INFO  (jetty-launcher-2637-thread-2) [n:127.0.0.1:39159_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestHdfsCloudBackupRestore_B788DB6DC32A0442-001/tempDir-002/node2/.
   [junit4]   2> 2671444 INFO  (zkConnectionManagerCallback-2661-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2671604 INFO  (zkConnectionManagerCallback-2665-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2671605 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 2671606 INFO  (SUITE-TestHdfsCloudBackupRestore-seed#[B788DB6DC32A0442]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:34714/solr ready
   [junit4]   2> 2671937 INFO  (TEST-TestHdfsCloudBackupRestore.test-seed#[B788DB6DC32A0442]) [    ] o.a.s.SolrTestCaseJ4 ###Starting test
   [junit4]   2> 2671973 INFO  (qtp1174534722-6209) [n:127.0.0.1:39159_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=1&collection.configName=conf1&router.name=implicit&version=2&pullReplicas=1&shards=shard1,shard2&property.customKey=customValue&maxShardsPerNode=3&router.field=shard_s&name=hdfsbackuprestore&nrtReplicas=1&action=CREATE&tlogReplicas=1&wt=javabin and sendToOCPQueue=true
   [junit4]   2> 2671999 INFO  (OverseerThreadFactory-1551-thread-1-processing-n:127.0.0.1:43801_solr) [n:127.0.0.1:43801_solr    ] o.a.s.c.CreateCollectionCmd Create collection hdfsbackuprestore
   [junit4]   2> 2672098 WARN  (OverseerThreadFactory-1551-thread-1-processing-n:127.0.0.1:43801_solr) [n:127.0.0.1:43801_solr    ] o.a.s.c.CreateCollectionCmd Specified number of replicas of 3 on collection hdfsbackuprestore is higher than the number of Solr instances currently live or live and part of your createNodeSet(2). It's unusual to run two replica of the same slice on the same Solr-instance.
   [junit4]   2> 2672317 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"hdfsbackuprestore",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"hdfsbackuprestore_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:43801/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2672368 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"hdfsbackuprestore",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"hdfsbackuprestore_shard1_replica_t2",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:39159/solr",
   [junit4]   2>   "type":"TLOG",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2672417 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"hdfsbackuprestore",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"hdfsbackuprestore_shard1_replica_p4",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:43801/solr",
   [junit4]   2>   "type":"PULL",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2672458 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"hdfsbackuprestore",
   [junit4]   2>   "shard":"shard2",
   [junit4]   2>   "core":"hdfsbackuprestore_shard2_replica_n6",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:39159/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2672564 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"hdfsbackuprestore",
   [junit4]   2>   "shard":"shard2",
   [junit4]   2>   "core":"hdfsbackuprestore_shard2_replica_t8",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:43801/solr",
   [junit4]   2>   "type":"TLOG",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2672574 INFO  (OverseerStateUpdate-99322259155976198-127.0.0.1:43801_solr-n_0000000000) [n:127.0.0.1:43801_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"hdfsbackuprestore",
   [junit4]   2>   "shard":"shard2",
   [junit4]   2>   "core":"hdfsbackuprestore_shard2_replica_p10",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:39159/solr",
   [junit4]   2>   "type":"PULL",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2672894 INFO  (qtp1558578325-6217) [n:127.0.0.1:43801_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&collection=hdfsbackuprestore&version=2&replicaType=NRT&property.customKey=customValue&coreNodeName=core_node3&name=hdfsbackuprestore_shard1_replica_n1&action=CREATE&numShards=2&shard=shard1&wt=javabin
   [junit4]   2> 2672895 INFO  (qtp1558578325-6217) [n:127.0.0.1:43801_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2672916 INFO  (qtp1558578325-6218) [n:127.0.0.1:43801_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&collection=hdfsbackuprestore&version=2&replicaType=TLOG&property.customKey=customValue&coreNodeName=core_node11&name=hdfsbackuprestore_shard2_replica_t8&action=CREATE&numShards=2&shard=shard2&wt=javabin
   [junit4]   2> 2672917 INFO  (qtp1174534722-6207) [n:127.0.0.1:39159_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&collection=hdfsbackuprestore&version=2&replicaType=TLOG&property.customKey=customValue&coreNodeName=core_node5&name=hdfsbackuprestore_shard1_replica_t2&action=CREATE&numShards=2&shard=shard1&wt=javabin
   [junit4]   2> 2672918 INFO  (qtp1174534722-6207) [n:127.0.0.1:39159_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2672996 INFO  (qtp1174534722-6211) [n:127.0.0.1:39159_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&collection=hdfsbackuprestore&version=2&replicaType=PULL&property.customKey=customValue&coreNodeName=core_node12&name=hdfsbackuprestore_shard2_replica_p10&action=CREATE&numShards=2&shard=shard2&wt=javabin
   [junit4]   2> 2672997 INFO  (qtp1558578325-6221) [n:127.0.0.1:43801_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&collection=hdfsbackuprestore&version=2&replicaType=PULL&property.customKey=customValue&coreNodeName=core_node7&name=hdfsbackuprestore_shard1_replica_p4&action=CREATE&numShards=2&shard=shard1&wt=javabin
   [junit4]   2> 2672999 INFO  (qtp1174534722-6212) [n:127.0.0.1:39159_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&collection=hdfsbackuprestore&version=2&replicaType=NRT&property.customKey=customValue&coreNodeName=core_node9&name=hdfsbackuprestore_shard2_replica_n6&action=CREATE&numShards=2&shard=shard2&wt=javabin
   [junit4]   2> 2673142 INFO  (zkCallback-2655-thread-1-processing-n:127.0.0.1:43801_solr) [n:127.0.0.1:43801_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/hdfsbackuprestore/state.json] for collection [hdfsbackuprestore] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 2673143 INFO  (zkCallback-2653-thread-1-processing-n:127.0.0.1:39159_solr) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/hdfsbackuprestore/state.json] for collection [hdfsbackuprestore] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 2673269 INFO  (zkCallback-2653-thread-2-processing-n:127.0.0.1:39159_solr) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/hdfsbackuprestore/state.json] for collection [hdfsbackuprestore] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 2673352 INFO  (zkCallback-2653-thread-2-processing-n:127.0.0.1:39159_solr) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/hdfsbackuprestore/state.json] for collection [hdfsbackuprestore] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 2673352 INFO  (zkCallback-2653-thread-1-processing-n:127.0.0.1:39159_solr) [n:127.0.0.1:39159_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/hdfsbackuprestore/state.json] for collection [hdfsbackuprestore] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 2673368 INFO  (zkCallback-2655-thread-1-processing-n:127.0.0.1:43801_solr) [n:127.0.0.1:43801_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/hdfsbackuprestore/state.json] for collection [hdfsbackuprestore] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 2673994 INFO  (qtp1558578325-6217) [n:127.0.0.1:43801_solr c:hdfsbackuprestore s:shard1 r:core_node3 x:hdfsbackuprestore_shard1_replica_n1] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.1
   [junit4]   2> 2674011 INFO  (qtp1558578325-6218) [n:127.0.0.1:43801_solr c:hdfsbackuprestore s:shard2 r:core_node11 x:hdfsbackuprestore_shard2_replica_t8] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.1
   [junit4]   2> 2674278 INFO  (qtp1558578325-6221) [n:127.0.0.1:43801_solr c:hdfsbackuprestore s:shard1 r:core_node7 x:hdfsbackuprestore_shard1_replica_p4] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.1
   [junit4]   2> 2674359 INFO  (qtp1174534722-6212) [n:127.0.0.1:39159_solr c:hdfsbackuprestore s:shard2 r:core_node9 x:hdfsbackuprestore_shard2_replica_n6] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.1
   [junit4]   2> 2674362 INFO  (qtp1558578325-6221) [n:127.0.0.1:43801_solr c:hdfsbackuprestore s:shard1 r:

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

FO  (coreCloseExecutor-530-thread-1) [n:127.0.0.1:54974_solr c:testcollection s:shard3 r:core_node6 x:testcollection_shard3_replica_n5] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testcollection.shard3.leader, tag=447029509
   [junit4]   2> 522478 INFO  (coreCloseExecutor-530-thread-2) [n:127.0.0.1:54974_solr c:delayed s:shard1 r:core_node2 x:delayed_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.delayed.shard1.leader, tag=1330499324
   [junit4]   2> 522546 INFO  (coreCloseExecutor-532-thread-2) [n:127.0.0.1:45093_solr c:testcollection s:shard1 r:core_node2 x:testcollection_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.testcollection.shard1.replica_n1, tag=1894945288
   [junit4]   2> 522546 INFO  (coreCloseExecutor-532-thread-2) [n:127.0.0.1:45093_solr c:testcollection s:shard1 r:core_node2 x:testcollection_shard1_replica_n1] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@696f484d: rootName = solr_45093, domain = solr.core.testcollection.shard1.replica_n1, service url = null, agent id = null] for registry solr.core.testcollection.shard1.replica_n1 / com.codahale.metrics.MetricRegistry@7623f6f7
   [junit4]   2> 522590 INFO  (coreCloseExecutor-531-thread-2) [n:127.0.0.1:58762_solr c:stateformat1 s:shard1 r:core_node2 x:stateformat1_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.stateformat1.shard1.leader, tag=8977697
   [junit4]   2> 522612 INFO  (coreCloseExecutor-532-thread-2) [n:127.0.0.1:45093_solr c:testcollection s:shard1 r:core_node2 x:testcollection_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testcollection.shard1.leader, tag=1894945288
   [junit4]   2> 522612 INFO  (coreCloseExecutor-533-thread-1) [n:127.0.0.1:47669_solr c:falsepredicate s:shard1 r:core_node2 x:falsepredicate_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.falsepredicate.shard1.leader, tag=34990408
   [junit4]   2> 522646 INFO  (coreCloseExecutor-532-thread-3) [n:127.0.0.1:45093_solr c:falsepredicate s:shard3 r:core_node6 x:falsepredicate_shard3_replica_n5] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.falsepredicate.shard3.replica_n5, tag=723112203
   [junit4]   2> 522646 INFO  (coreCloseExecutor-532-thread-3) [n:127.0.0.1:45093_solr c:falsepredicate s:shard3 r:core_node6 x:falsepredicate_shard3_replica_n5] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@41ecb586: rootName = solr_45093, domain = solr.core.falsepredicate.shard3.replica_n5, service url = null, agent id = null] for registry solr.core.falsepredicate.shard3.replica_n5 / com.codahale.metrics.MetricRegistry@73697d96
   [junit4]   2> 522702 INFO  (coreCloseExecutor-531-thread-1) [n:127.0.0.1:58762_solr c:testcollection s:shard2 r:core_node4 x:testcollection_shard2_replica_n3] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.testcollection.shard2.replica_n3, tag=116782384
   [junit4]   2> 522914 INFO  (AutoscalingActionExecutor-446-thread-1-processing-n:127.0.0.1:45093_solr) [n:127.0.0.1:45093_solr    ] o.a.s.c.ActionThrottle The last action attempt started 7350ms ago.
   [junit4]   2> 522930 INFO  (coreCloseExecutor-531-thread-1) [n:127.0.0.1:58762_solr c:testcollection s:shard2 r:core_node4 x:testcollection_shard2_replica_n3] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@2afbbacc: rootName = solr_58762, domain = solr.core.testcollection.shard2.replica_n3, service url = null, agent id = null] for registry solr.core.testcollection.shard2.replica_n3 / com.codahale.metrics.MetricRegistry@8b10c85
   [junit4]   2> 522935 INFO  (AutoscalingActionExecutor-446-thread-1-processing-n:127.0.0.1:45093_solr) [n:127.0.0.1:45093_solr    ] o.a.s.c.a.ExecutePlanAction No operations to execute for event: {
   [junit4]   2>   "id":"15084bc455016580T3vgfp88w5b996uoieq78oimak",
   [junit4]   2>   "source":".auto_add_replicas",
   [junit4]   2>   "eventTime":1515544581222000000,
   [junit4]   2>   "eventType":"NODELOST",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1515544581222000000],
   [junit4]   2>     "_enqueue_time_":1515544616513000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:56031_solr"]}}
   [junit4]   2> 522999 INFO  (coreCloseExecutor-532-thread-1) [n:127.0.0.1:45093_solr c:currentstate s:shard1 r:core_node2 x:currentstate_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.currentstate.shard1.leader, tag=1754171940
   [junit4]   2> 522999 INFO  (coreCloseExecutor-532-thread-3) [n:127.0.0.1:45093_solr c:falsepredicate s:shard3 r:core_node6 x:falsepredicate_shard3_replica_n5] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.falsepredicate.shard3.leader, tag=723112203
   [junit4]   2> 523023 INFO  (coreCloseExecutor-531-thread-1) [n:127.0.0.1:58762_solr c:testcollection s:shard2 r:core_node4 x:testcollection_shard2_replica_n3] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testcollection.shard2.leader, tag=116782384
   [junit4]   2> 523526 INFO  (jetty-closer-129-thread-1) [    ] o.a.s.c.Overseer Overseer (id=99322722687975434-127.0.0.1:45093_solr-n_0000000001) closing
   [junit4]   2> 523542 INFO  (OverseerStateUpdate-99322722687975434-127.0.0.1:45093_solr-n_0000000001) [n:127.0.0.1:45093_solr    ] o.a.s.c.Overseer Overseer Loop exiting : 127.0.0.1:45093_solr
   [junit4]   2> 523570 WARN  (OverseerAutoScalingTriggerThread-99322722687975434-127.0.0.1:45093_solr-n_0000000001) [n:127.0.0.1:45093_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 523591 INFO  (jetty-closer-129-thread-3) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@20086cb5{/solr,null,UNAVAILABLE}
   [junit4]   2> 523611 INFO  (jetty-closer-129-thread-2) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@10348523{/solr,null,UNAVAILABLE}
   [junit4]   2> 523690 INFO  (jetty-closer-129-thread-1) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@58c5d069{/solr,null,UNAVAILABLE}
   [junit4]   2> 525090 INFO  (jetty-closer-129-thread-4) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@e0dd70b{/solr,null,UNAVAILABLE}
   [junit4]   2> 525122 ERROR (SUITE-TestCollectionStateWatchers-seed#[A5621D4BB3FC9A7A]-worker) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 525123 INFO  (SUITE-TestCollectionStateWatchers-seed#[A5621D4BB3FC9A7A]-worker) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:39319 39319
   [junit4]   2> 525374 INFO  (Thread-106) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:39319 39319
   [junit4]   2> 525375 WARN  (Thread-106) [    ] o.a.s.c.ZkTestServer Watch limit violations: 
   [junit4]   2> Maximum concurrent create/delete watches above limit:
   [junit4]   2> 
   [junit4]   2> 	8	/solr/aliases.json
   [junit4]   2> 	8	/solr/configs/config
   [junit4]   2> 	7	/solr/security.json
   [junit4]   2> 	4	/solr/collections/stateformat1/state.json
   [junit4]   2> 
   [junit4]   2> Maximum concurrent data watches above limit:
   [junit4]   2> 
   [junit4]   2> 	76	/solr/collections/falsepredicate/state.json
   [junit4]   2> 	64	/solr/collections/testcollection/state.json
   [junit4]   2> 	12	/solr/collections/waitforstate/state.json
   [junit4]   2> 	11	/solr/collections/delayed/state.json
   [junit4]   2> 	9	/solr/collections/stateformat1/state.json
   [junit4]   2> 	8	/solr/clusterprops.json
   [junit4]   2> 	8	/solr/clusterstate.json
   [junit4]   2> 	7	/solr/collections/currentstate/state.json
   [junit4]   2> 	6	/solr/collections/tobedeleted/state.json
   [junit4]   2> 	2	/solr/overseer_elect/election/99322722687975435-127.0.0.1:56031_solr-n_0000000002
   [junit4]   2> 	2	/solr/autoscaling.json
   [junit4]   2> 	2	/solr/overseer_elect/election/99322722687975434-127.0.0.1:45093_solr-n_0000000001
   [junit4]   2> 
   [junit4]   2> Maximum concurrent children watches above limit:
   [junit4]   2> 
   [junit4]   2> 	8	/solr/live_nodes
   [junit4]   2> 	8	/solr/collections
   [junit4]   2> 	2	/solr/overseer/queue
   [junit4]   2> 	2	/solr/autoscaling/events/.auto_add_replicas
   [junit4]   2> 	2	/solr/overseer/queue-work
   [junit4]   2> 	2	/solr/overseer/collection-queue-work
   [junit4]   2> 
   [junit4]   2> NOTE: leaving temporary files on disk at: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-solrj/test/J2/temp/solr.common.cloud.TestCollectionStateWatchers_A5621D4BB3FC9A7A-001
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70): {}, docValues:{}, maxPointsInLeafNode=547, maxMBSortInHeap=5.095557124251343, sim=RandomSimilarity(queryNorm=true): {}, locale=ja, timezone=Asia/Omsk
   [junit4]   2> NOTE: Linux 3.13.0-88-generic amd64/Oracle Corporation 1.8.0_144 (64-bit)/cpus=4,threads=1,free=243108832,total=361234432
   [junit4]   2> NOTE: All tests run in this JVM: [TestCoreAdmin, CoalesceEvaluatorTest, TestCloudSolrClientConnections, LessThanEqualToEvaluatorTest, TestJavaBinCodec, TestSuggesterResponse, NormalizeEvaluatorTest, TangentEvaluatorTest, UuidEvaluatorTest, NoOpResponseParserTest, MultiplyEvaluatorTest, SolrExceptionTest, LargeVolumeJettyTest, OperationsTest, ArrayEvaluatorTest, SelectWithEvaluatorsTest, TestJsonRecordReader, PowerEvaluatorTest, RegressionEvaluatorTest, StreamExpressionToExplanationTest, DocumentAnalysisResponseTest, TestCollectionStateWatchers]
   [junit4] Completed [50/146 (1!)] on J2 in 144.83s, 9 tests, 1 failure <<< FAILURES!

[...truncated 46731 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 19 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/19/

3 tests failed.
FAILED:  org.apache.solr.cloud.BasicDistributedZk2Test.test

Error Message:
KeeperErrorCode = Session expired for /clusterstate.json

Stack Trace:
org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /clusterstate.json
	at __randomizedtesting.SeedInfo.seed([59F090994ABB744:8DCB36D33A57DABC]:0)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.refreshLegacyClusterState(ZkStateReader.java:542)
	at org.apache.solr.common.cloud.ZkStateReader.forceUpdateCollection(ZkStateReader.java:352)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.updateMappingsFromZk(AbstractFullDistribZkTestBase.java:673)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.updateMappingsFromZk(AbstractFullDistribZkTestBase.java:668)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.createJettys(AbstractFullDistribZkTestBase.java:463)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.createServers(AbstractFullDistribZkTestBase.java:333)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:991)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.RecoveryZkTest.test

Error Message:


Stack Trace:
java.util.concurrent.TimeoutException
	at __randomizedtesting.SeedInfo.seed([59F090994ABB744:8DCB36D33A57DABC]:0)
	at org.apache.solr.common.cloud.ZkStateReader.waitForState(ZkStateReader.java:1276)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.waitForState(CloudSolrClient.java:448)
	at org.apache.solr.cloud.RecoveryZkTest.test(RecoveryZkTest.java:122)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.security.TestPKIAuthenticationPlugin.test

Error Message:


Stack Trace:
java.lang.NullPointerException
	at __randomizedtesting.SeedInfo.seed([59F090994ABB744:8DCB36D33A57DABC]:0)
	at org.apache.solr.security.TestPKIAuthenticationPlugin.test(TestPKIAuthenticationPlugin.java:102)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 12163 lines...]
   [junit4] Suite: org.apache.solr.cloud.RecoveryZkTest
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/init-core-data-001
   [junit4]   2> 1623084 WARN  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=1 numCloses=1
   [junit4]   2> 1623084 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=true
   [junit4]   2> 1623086 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (true) and clientAuth (false) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 1623086 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 1623087 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 2 servers in /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001
   [junit4]   2> 1623087 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 1623105 INFO  (Thread-1004) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 1623105 INFO  (Thread-1004) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 1623137 ERROR (Thread-1004) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 1623213 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:40818
   [junit4]   2> 1623250 INFO  (zkConnectionManagerCallback-705-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1623273 INFO  (jetty-launcher-702-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1623293 INFO  (jetty-launcher-702-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1623399 INFO  (jetty-launcher-702-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@44b9e289{/solr,null,AVAILABLE}
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@3633b927{/solr,null,AVAILABLE}
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@780223be{SSL,[ssl, http/1.1]}{127.0.0.1:34184}
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-2) [    ] o.e.j.s.Server Started @1647668ms
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=34184}
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@349ca5df{SSL,[ssl, http/1.1]}{127.0.0.1:37634}
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-1) [    ] o.e.j.s.Server Started @1647668ms
   [junit4]   2> 1623413 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=37634}
   [junit4]   2> 1623414 ERROR (jetty-launcher-702-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1623414 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1623414 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1623414 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1623414 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-21T17:58:32.967Z
   [junit4]   2> 1623416 ERROR (jetty-launcher-702-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1623416 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1623416 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1623416 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1623416 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-21T17:58:32.969Z
   [junit4]   2> 1623495 INFO  (zkConnectionManagerCallback-707-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1623502 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1623580 INFO  (zkConnectionManagerCallback-709-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1623671 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1623699 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x1607a3a0be10001, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1623722 INFO  (jetty-launcher-702-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:40818/solr
   [junit4]   2> 1623735 INFO  (zkConnectionManagerCallback-713-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1623760 INFO  (jetty-launcher-702-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:40818/solr
   [junit4]   2> 1623809 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x1607a3a0be10003, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1623844 INFO  (zkConnectionManagerCallback-717-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1624015 INFO  (zkConnectionManagerCallback-721-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1624080 INFO  (zkConnectionManagerCallback-719-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1624413 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1624413 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:37634_solr
   [junit4]   2> 1624426 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.c.Overseer Overseer (id=99213581528137733-127.0.0.1:37634_solr-n_0000000000) starting
   [junit4]   2> 1624520 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:37634_solr
   [junit4]   2> 1624594 INFO  (zkCallback-718-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 1624758 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 1624759 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1624796 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:34184_solr
   [junit4]   2> 1624829 INFO  (zkCallback-718-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 1624922 INFO  (zkCallback-720-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 1625087 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34184.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1625124 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34184.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1625124 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34184.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1625125 INFO  (jetty-launcher-702-thread-2) [n:127.0.0.1:34184_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001/node2/.
   [junit4]   2> 1625330 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_37634.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1625383 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_37634.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1625384 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_37634.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1625385 INFO  (jetty-launcher-702-thread-1) [n:127.0.0.1:37634_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001/node1/.
   [junit4]   2> 1625643 INFO  (zkConnectionManagerCallback-726-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1625697 INFO  (zkConnectionManagerCallback-730-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1625698 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1625699 INFO  (SUITE-RecoveryZkTest-seed#[59F090994ABB744]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:40818/solr ready
   [junit4]   2> 1625842 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.SolrTestCaseJ4 ###Starting test
   [junit4]   2> 1626087 INFO  (qtp1747717070-3537) [n:127.0.0.1:34184_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=2&collection.configName=conf&maxShardsPerNode=1&name=recoverytest&nrtReplicas=2&action=CREATE&numShards=1&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 1626171 INFO  (OverseerThreadFactory-1409-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.CreateCollectionCmd Create collection recoverytest
   [junit4]   2> 1626284 INFO  (OverseerStateUpdate-99213581528137733-127.0.0.1:37634_solr-n_0000000000) [n:127.0.0.1:37634_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"recoverytest",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"recoverytest_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"https://127.0.0.1:37634/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 1626320 INFO  (OverseerStateUpdate-99213581528137733-127.0.0.1:37634_solr-n_0000000000) [n:127.0.0.1:37634_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"recoverytest",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"recoverytest_shard1_replica_n2",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"https://127.0.0.1:34184/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 1626865 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node4&collection.configName=conf&newCollection=true&name=recoverytest_shard1_replica_n2&action=CREATE&numShards=1&collection=recoverytest&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 1626865 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 1627138 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node3&collection.configName=conf&newCollection=true&name=recoverytest_shard1_replica_n1&action=CREATE&numShards=1&collection=recoverytest&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 1627139 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 1627352 INFO  (zkCallback-718-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1627359 INFO  (zkCallback-720-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1627360 INFO  (zkCallback-718-thread-2-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1627360 INFO  (zkCallback-720-thread-2-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1628297 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 1628376 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.s.IndexSchema [recoverytest_shard1_replica_n2] Schema name=minimal
   [junit4]   2> 1628379 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.s.IndexSchema Loaded schema minimal/1.1 with uniqueid field id
   [junit4]   2> 1628379 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.CoreContainer Creating SolrCore 'recoverytest_shard1_replica_n2' using configuration from collection recoverytest, trusted=true
   [junit4]   2> 1628392 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 1628412 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34184.solr.core.recoverytest.shard1.replica_n2' (registry 'solr.core.recoverytest.shard1.replica_n2') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1628412 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 1628412 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.SolrCore [[recoverytest_shard1_replica_n2] ] Opening new SolrCore at [/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001/node2/recoverytest_shard1_replica_n2], dataDir=[/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001/node2/./recoverytest_shard1_replica_n2/data/]
   [junit4]   2> 1628502 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.s.IndexSchema [recoverytest_shard1_replica_n1] Schema name=minimal
   [junit4]   2> 1628504 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.s.IndexSchema Loaded schema minimal/1.1 with uniqueid field id
   [junit4]   2> 1628504 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.c.CoreContainer Creating SolrCore 'recoverytest_shard1_replica_n1' using configuration from collection recoverytest, trusted=true
   [junit4]   2> 1628504 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_37634.solr.core.recoverytest.shard1.replica_n1' (registry 'solr.core.recoverytest.shard1.replica_n1') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5a179470
   [junit4]   2> 1628504 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 1628505 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.c.SolrCore [[recoverytest_shard1_replica_n1] ] Opening new SolrCore at [/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001/node1/recoverytest_shard1_replica_n1], dataDir=[/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.RecoveryZkTest_59F090994ABB744-001/tempDir-001/node1/./recoverytest_shard1_replica_n1/data/]
   [junit4]   2> 1629134 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.u.UpdateHandler Using UpdateLog implementation: org.apache.solr.update.UpdateLog
   [junit4]   2> 1629134 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.u.UpdateLog Initializing UpdateLog: dataDir=null defaultSyncLevel=FLUSH numRecordsToKeep=100 maxNumLogsToKeep=10 numVersionBuckets=65536
   [junit4]   2> 1629135 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.u.CommitTracker Hard AutoCommit: disabled
   [junit4]   2> 1629148 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.u.CommitTracker Soft AutoCommit: disabled
   [junit4]   2> 1629149 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.s.SolrIndexSearcher Opening [Searcher@1a0d1f27[recoverytest_shard1_replica_n1] main]
   [junit4]   2> 1629151 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.r.ManagedResourceStorage Configured ZooKeeperStorageIO with znodeBase: /configs/conf
   [junit4]   2> 1629151 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.r.ManagedResourceStorage Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf
   [junit4]   2> 1629168 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.h.ReplicationHandler Commits will be reserved for 10000ms.
   [junit4]   2> 1629205 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.UpdateHandler Using UpdateLog implementation: org.apache.solr.update.UpdateLog
   [junit4]   2> 1629205 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.UpdateLog Initializing UpdateLog: dataDir=null defaultSyncLevel=FLUSH numRecordsToKeep=100 maxNumLogsToKeep=10 numVersionBuckets=65536
   [junit4]   2> 1629206 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.CommitTracker Hard AutoCommit: disabled
   [junit4]   2> 1629206 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.CommitTracker Soft AutoCommit: disabled
   [junit4]   2> 1629208 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.s.SolrIndexSearcher Opening [Searcher@473dba15[recoverytest_shard1_replica_n2] main]
   [junit4]   2> 1629221 INFO  (searcherExecutor-1415-thread-1-processing-n:127.0.0.1:37634_solr x:recoverytest_shard1_replica_n1 s:shard1 c:recoverytest r:core_node3) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.c.SolrCore [recoverytest_shard1_replica_n1] Registered new searcher Searcher@1a0d1f27[recoverytest_shard1_replica_n1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 1629221 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.u.UpdateLog Could not find max version in index or recent updates, using new clock 1587417310847565824
   [junit4]   2> 1629241 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.r.ManagedResourceStorage Configured ZooKeeperStorageIO with znodeBase: /configs/conf
   [junit4]   2> 1629242 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.r.ManagedResourceStorage Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf
   [junit4]   2> 1629242 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.h.ReplicationHandler Commits will be reserved for 10000ms.
   [junit4]   2> 1629243 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.UpdateLog Could not find max version in index or recent updates, using new clock 1587417310869585920
   [junit4]   2> 1629260 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ShardLeaderElectionContext Waiting until we see more replicas up for shard shard1: total=2 found=1 timeoutin=9999ms
   [junit4]   2> 1629278 INFO  (searcherExecutor-1414-thread-1-processing-n:127.0.0.1:34184_solr x:recoverytest_shard1_replica_n2 s:shard1 c:recoverytest r:core_node4) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.SolrCore [recoverytest_shard1_replica_n2] Registered new searcher Searcher@473dba15[recoverytest_shard1_replica_n2] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 1629468 INFO  (zkCallback-720-thread-2-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1629469 INFO  (zkCallback-720-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1629469 INFO  (zkCallback-718-thread-2-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1629469 INFO  (zkCallback-718-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1629774 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ShardLeaderElectionContext Enough replicas found to continue.
   [junit4]   2> 1629774 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ShardLeaderElectionContext I may be the new leader - try and sync
   [junit4]   2> 1629774 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.SyncStrategy Sync replicas to https://127.0.0.1:34184/solr/recoverytest_shard1_replica_n2/
   [junit4]   2> 1629774 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.PeerSync PeerSync: core=recoverytest_shard1_replica_n2 url=https://127.0.0.1:34184/solr START replicas=[https://127.0.0.1:37634/solr/recoverytest_shard1_replica_n1/] nUpdates=100
   [junit4]   2> 1629865 INFO  (qtp754565780-3525) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.c.S.Request [recoverytest_shard1_replica_n1]  webapp=/solr path=/get params={distrib=false&qt=/get&fingerprint=false&getVersions=100&wt=javabin&version=2} status=0 QTime=0
   [junit4]   2> 1630103 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.PeerSync PeerSync: core=recoverytest_shard1_replica_n2 url=https://127.0.0.1:34184/solr DONE.  We have no versions.  sync failed.
   [junit4]   2> 1630103 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.SyncStrategy Leader's attempt to sync with shard failed, moving to the next candidate
   [junit4]   2> 1630103 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ShardLeaderElectionContext We failed sync, but we have no versions - we can't sync in that case - we were active before, so become leader anyway
   [junit4]   2> 1630103 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ShardLeaderElectionContext Found all replicas participating in election, clear LIR
   [junit4]   2> 1630106 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ShardLeaderElectionContext I am the new leader: https://127.0.0.1:34184/solr/recoverytest_shard1_replica_n2/ shard1
   [junit4]   2> 1630351 INFO  (zkCallback-720-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630351 INFO  (zkCallback-720-thread-2-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630352 INFO  (zkCallback-718-thread-3-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630355 INFO  (zkCallback-718-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630376 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ZkController I am the leader, no recovery necessary
   [junit4]   2> 1630378 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/cores params={qt=/admin/cores&coreNodeName=core_node4&collection.configName=conf&newCollection=true&name=recoverytest_shard1_replica_n2&action=CREATE&numShards=1&collection=recoverytest&shard=shard1&wt=javabin&version=2&replicaType=NRT} status=0 QTime=3513
   [junit4]   2> 1630397 INFO  (qtp754565780-3530) [n:127.0.0.1:37634_solr c:recoverytest s:shard1 r:core_node3 x:recoverytest_shard1_replica_n1] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/cores params={qt=/admin/cores&coreNodeName=core_node3&collection.configName=conf&newCollection=true&name=recoverytest_shard1_replica_n1&action=CREATE&numShards=1&collection=recoverytest&shard=shard1&wt=javabin&version=2&replicaType=NRT} status=0 QTime=3259
   [junit4]   2> 1630478 INFO  (qtp1747717070-3537) [n:127.0.0.1:34184_solr    ] o.a.s.h.a.CollectionsHandler Wait for new collection to be active for at most 30 seconds. Check all shard replicas
   [junit4]   2> 1630603 INFO  (zkCallback-720-thread-2-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630603 INFO  (zkCallback-720-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630609 INFO  (zkCallback-718-thread-1-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1630609 INFO  (zkCallback-718-thread-2-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/recoverytest/state.json] for collection [recoverytest] has occurred - updating... (live nodes size: [2])
   [junit4]   2> 1631485 INFO  (qtp1747717070-3537) [n:127.0.0.1:34184_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={replicationFactor=2&collection.configName=conf&maxShardsPerNode=1&name=recoverytest&nrtReplicas=2&action=CREATE&numShards=1&wt=javabin&version=2} status=0 QTime=5398
   [junit4]   2> 1631584 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.c.RecoveryZkTest Indexing 700 documents
   [junit4]   2> 1632134 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.e.j.s.AbstractConnector Stopped ServerConnector@349ca5df{SSL,[ssl, http/1.1]}{127.0.0.1:0}
   [junit4]   2> 1632133 ERROR (updateExecutor-714-thread-2-processing-https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1 x:recoverytest_shard1_replica_n2 r:core_node4 n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.ErrorReportingConcurrentUpdateSolrClient error
   [junit4]   2> javax.net.ssl.SSLHandshakeException: Remote host closed connection during handshake
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.readRecord(SSLSocketImpl.java:1002)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.performInitialHandshake(SSLSocketImpl.java:1385)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.startHandshake(SSLSocketImpl.java:1413)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.startHandshake(SSLSocketImpl.java:1397)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.createLayeredSocket(SSLConnectionSocketFactory.java:396)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.connectSocket(SSLConnectionSocketFactory.java:355)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:142)
   [junit4]   2> 	at org.apache.http.impl.conn.PoolingHttpClientConnectionManager.connect(PoolingHttpClientConnectionManager.java:359)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.establishRoute(MainClientExec.java:381)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:237)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> Caused by: java.io.EOFException: SSL peer shut down incorrectly
   [junit4]   2> 	at sun.security.ssl.InputRecord.read(InputRecord.java:505)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.readRecord(SSLSocketImpl.java:983)
   [junit4]   2> 	... 22 more
   [junit4]   2> 1632146 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.c.CoreContainer Shutting down CoreContainer instance=1040643164
   [junit4]   2> 1632161 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.node, tag=null
   [junit4]   2> 1632162 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@40f7b247: rootName = solr_37634, domain = solr.node, service url = null, agent id = null] for registry solr.node / com.codahale.metrics.MetricRegistry@78a62b41
   [junit4]   2> 1632222 WARN  (qtp1747717070-3533) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.DistributedUpdateProcessor Error sending update to https://127.0.0.1:37634/solr
   [junit4]   2> javax.net.ssl.SSLHandshakeException: Remote host closed connection during handshake
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.readRecord(SSLSocketImpl.java:1002)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.performInitialHandshake(SSLSocketImpl.java:1385)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.startHandshake(SSLSocketImpl.java:1413)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.startHandshake(SSLSocketImpl.java:1397)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.createLayeredSocket(SSLConnectionSocketFactory.java:396)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.connectSocket(SSLConnectionSocketFactory.java:355)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:142)
   [junit4]   2> 	at org.apache.http.impl.conn.PoolingHttpClientConnectionManager.connect(PoolingHttpClientConnectionManager.java:359)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.establishRoute(MainClientExec.java:381)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:237)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> Caused by: java.io.EOFException: SSL peer shut down incorrectly
   [junit4]   2> 	at sun.security.ssl.InputRecord.read(InputRecord.java:505)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.readRecord(SSLSocketImpl.java:983)
   [junit4]   2> 	... 22 more
   [junit4]   2> 1632223 ERROR (qtp1747717070-3533) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.DistributedUpdateProcessor Setting up to try to start recovery on replica https://127.0.0.1:37634/solr/recoverytest_shard1_replica_n1/
   [junit4]   2> java.io.EOFException: SSL peer shut down incorrectly
   [junit4]   2> 	at sun.security.ssl.InputRecord.read(InputRecord.java:505)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.readRecord(SSLSocketImpl.java:983)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.performInitialHandshake(SSLSocketImpl.java:1385)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.startHandshake(SSLSocketImpl.java:1413)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.startHandshake(SSLSocketImpl.java:1397)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.createLayeredSocket(SSLConnectionSocketFactory.java:396)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.connectSocket(SSLConnectionSocketFactory.java:355)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:142)
   [junit4]   2> 	at org.apache.http.impl.conn.PoolingHttpClientConnectionManager.connect(PoolingHttpClientConnectionManager.java:359)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.establishRoute(MainClientExec.java:381)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:237)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1632236 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jvm, tag=null
   [junit4]   2> 1632236 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@5a6d4453: rootName = solr_37634, domain = solr.jvm, service url = null, agent id = null] for registry solr.jvm / com.codahale.metrics.MetricRegistry@355a5f2b
   [junit4]   2> 1632254 ERROR (updateExecutor-714-thread-1-processing-https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1 x:recoverytest_shard1_replica_n2 r:core_node4 n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.ErrorReportingConcurrentUpdateSolrClient error
   [junit4]   2> java.net.SocketException: Broken pipe (Write failed)
   [junit4]   2> 	at java.net.SocketOutputStream.socketWrite0(Native Method)
   [junit4]   2> 	at java.net.SocketOutputStream.socketWrite(SocketOutputStream.java:111)
   [junit4]   2> 	at java.net.SocketOutputStream.write(SocketOutputStream.java:155)
   [junit4]   2> 	at sun.security.ssl.OutputRecord.writeBuffer(OutputRecord.java:431)
   [junit4]   2> 	at sun.security.ssl.OutputRecord.write(OutputRecord.java:417)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.writeRecordInternal(SSLSocketImpl.java:886)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.writeRecord(SSLSocketImpl.java:857)
   [junit4]   2> 	at sun.security.ssl.AppOutputStream.write(AppOutputStream.java:123)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.streamWrite(SessionOutputBufferImpl.java:124)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.flushBuffer(SessionOutputBufferImpl.java:136)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.flush(SessionOutputBufferImpl.java:144)
   [junit4]   2> 	at org.apache.http.impl.io.ChunkedOutputStream.close(ChunkedOutputStream.java:203)
   [junit4]   2> 	at org.apache.http.impl.DefaultBHttpClientConnection.sendRequestEntity(DefaultBHttpClientConnection.java:157)
   [junit4]   2> 	at org.apache.http.impl.conn.CPoolProxy.sendRequestEntity(CPoolProxy.java:160)
   [junit4]   2> 	at org.apache.http.protocol.HttpRequestExecutor.doSendRequest(HttpRequestExecutor.java:238)
   [junit4]   2> 	at org.apache.http.protocol.HttpRequestExecutor.execute(HttpRequestExecutor.java:123)
   [junit4]   2> 	at org.apache.solr.util.stats.InstrumentedHttpRequestExecutor.execute(InstrumentedHttpRequestExecutor.java:118)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:272)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1632258 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jetty, tag=null
   [junit4]   2> 1632258 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@bb3296b: rootName = solr_37634, domain = solr.jetty, service url = null, agent id = null] for registry solr.jetty / com.codahale.metrics.MetricRegistry@49048b2e
   [junit4]   2> 1632259 WARN  (qtp1747717070-3539) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.DistributedUpdateProcessor Error sending update to https://127.0.0.1:37634/solr
   [junit4]   2> java.net.SocketException: Broken pipe (Write failed)
   [junit4]   2> 	at java.net.SocketOutputStream.socketWrite0(Native Method)
   [junit4]   2> 	at java.net.SocketOutputStream.socketWrite(SocketOutputStream.java:111)
   [junit4]   2> 	at java.net.SocketOutputStream.write(SocketOutputStream.java:155)
   [junit4]   2> 	at sun.security.ssl.OutputRecord.writeBuffer(OutputRecord.java:431)
   [junit4]   2> 	at sun.security.ssl.OutputRecord.write(OutputRecord.java:417)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.writeRecordInternal(SSLSocketImpl.java:886)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.writeRecord(SSLSocketImpl.java:857)
   [junit4]   2> 	at sun.security.ssl.AppOutputStream.write(AppOutputStream.java:123)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.streamWrite(SessionOutputBufferImpl.java:124)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.flushBuffer(SessionOutputBufferImpl.java:136)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.flush(SessionOutputBufferImpl.java:144)
   [junit4]   2> 	at org.apache.http.impl.io.ChunkedOutputStream.close(ChunkedOutputStream.java:203)
   [junit4]   2> 	at org.apache.http.impl.DefaultBHttpClientConnection.sendRequestEntity(DefaultBHttpClientConnection.java:157)
   [junit4]   2> 	at org.apache.http.impl.conn.CPoolProxy.sendRequestEntity(CPoolProxy.java:160)
   [junit4]   2> 	at org.apache.http.protocol.HttpRequestExecutor.doSendRequest(HttpRequestExecutor.java:238)
   [junit4]   2> 	at org.apache.http.protocol.HttpRequestExecutor.execute(HttpRequestExecutor.java:123)
   [junit4]   2> 	at org.apache.solr.util.stats.InstrumentedHttpRequestExecutor.execute(InstrumentedHttpRequestExecutor.java:118)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:272)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1632259 ERROR (qtp1747717070-3539) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.DistributedUpdateProcessor Setting up to try to start recovery on replica https://127.0.0.1:37634/solr/recoverytest_shard1_replica_n1/
   [junit4]   2> java.net.SocketException: Broken pipe (Write failed)
   [junit4]   2> 	at java.net.SocketOutputStream.socketWrite0(Native Method)
   [junit4]   2> 	at java.net.SocketOutputStream.socketWrite(SocketOutputStream.java:111)
   [junit4]   2> 	at java.net.SocketOutputStream.write(SocketOutputStream.java:155)
   [junit4]   2> 	at sun.security.ssl.OutputRecord.writeBuffer(OutputRecord.java:431)
   [junit4]   2> 	at sun.security.ssl.OutputRecord.write(OutputRecord.java:417)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.writeRecordInternal(SSLSocketImpl.java:886)
   [junit4]   2> 	at sun.security.ssl.SSLSocketImpl.writeRecord(SSLSocketImpl.java:857)
   [junit4]   2> 	at sun.security.ssl.AppOutputStream.write(AppOutputStream.java:123)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.streamWrite(SessionOutputBufferImpl.java:124)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.flushBuffer(SessionOutputBufferImpl.java:136)
   [junit4]   2> 	at org.apache.http.impl.io.SessionOutputBufferImpl.flush(SessionOutputBufferImpl.java:144)
   [junit4]   2> 	at org.apache.http.impl.io.ChunkedOutputStream.close(ChunkedOutputStream.java:203)
   [junit4]   2> 	at org.apache.http.impl.DefaultBHttpClientConnection.sendRequestEntity(DefaultBHttpClientConnection.java:157)
   [junit4]   2> 	at org.apache.http.impl.conn.CPoolProxy.sendRequestEntity(CPoolProxy.java:160)
   [junit4]   2> 	at org.apache.http.protocol.HttpRequestExecutor.doSendRequest(HttpRequestExecutor.java:238)
   [junit4]   2> 	at org.apache.http.protocol.HttpRequestExecutor.execute(HttpRequestExecutor.java:123)
   [junit4]   2> 	at org.apache.solr.util.stats.InstrumentedHttpRequestExecutor.execute(InstrumentedHttpRequestExecutor.java:118)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:272)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1632261 INFO  (qtp1747717070-3533) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.ZkController Put replica core=recoverytest_shard1_replica_n1 coreNodeName=core_node3 on 127.0.0.1:37634_solr into leader-initiated recovery.
   [junit4]   2> 1632261 INFO  (qtp1747717070-3539) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-0 (1587417313554989056)]} 0 567
   [junit4]   2> 1632261 INFO  (qtp1747717070-3533) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[1-0 (1587417313554989057)]} 0 458
   [junit4]   2> 1632272 ERROR (updateExecutor-714-thread-2-processing-https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1 x:recoverytest_shard1_replica_n2 r:core_node4 n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.ErrorReportingConcurrentUpdateSolrClient error
   [junit4]   2> org.apache.http.conn.HttpHostConnectException: Connect to 127.0.0.1:37634 [/127.0.0.1] failed: Connection refused (Connection refused)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:159)
   [junit4]   2> 	at org.apache.http.impl.conn.PoolingHttpClientConnectionManager.connect(PoolingHttpClientConnectionManager.java:359)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.establishRoute(MainClientExec.java:381)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:237)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> Caused by: java.net.ConnectException: Connection refused (Connection refused)
   [junit4]   2> 	at java.net.PlainSocketImpl.socketConnect(Native Method)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.doConnect(AbstractPlainSocketImpl.java:350)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.connectToAddress(AbstractPlainSocketImpl.java:206)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.connect(AbstractPlainSocketImpl.java:188)
   [junit4]   2> 	at java.net.SocksSocketImpl.connect(SocksSocketImpl.java:392)
   [junit4]   2> 	at java.net.Socket.connect(Socket.java:589)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.connectSocket(SSLConnectionSocketFactory.java:339)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:142)
   [junit4]   2> 	... 16 more
   [junit4]   2> 1632284 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.c.ZkController Remove node as live in ZooKeeper:/live_nodes/127.0.0.1:37634_solr
   [junit4]   2> 1632285 INFO  (zkCallback-729-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (1)
   [junit4]   2> 1632285 INFO  (TEST-RecoveryZkTest.test-seed#[59F090994ABB744]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.cluster, tag=null
   [junit4]   2> 1632291 WARN  (qtp1747717070-3536) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.DistributedUpdateProcessor Error sending update to https://127.0.0.1:37634/solr
   [junit4]   2> org.apache.http.conn.HttpHostConnectException: Connect to 127.0.0.1:37634 [/127.0.0.1] failed: Connection refused (Connection refused)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:159)
   [junit4]   2> 	at org.apache.http.impl.conn.PoolingHttpClientConnectionManager.connect(PoolingHttpClientConnectionManager.java:359)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.establishRoute(MainClientExec.java:381)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:237)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.sendUpdateStream(ConcurrentUpdateSolrClient.java:347)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.ConcurrentUpdateSolrClient$Runner.run(ConcurrentUpdateSolrClient.java:182)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> Caused by: java.net.ConnectException: Connection refused (Connection refused)
   [junit4]   2> 	at java.net.PlainSocketImpl.socketConnect(Native Method)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.doConnect(AbstractPlainSocketImpl.java:350)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.connectToAddress(AbstractPlainSocketImpl.java:206)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.connect(AbstractPlainSocketImpl.java:188)
   [junit4]   2> 	at java.net.SocksSocketImpl.connect(SocksSocketImpl.java:392)
   [junit4]   2> 	at java.net.Socket.connect(Socket.java:589)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.connectSocket(SSLConnectionSocketFactory.java:339)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:142)
   [junit4]   2> 	... 16 more
   [junit4]   2> 1632291 WARN  (qtp1747717070-3536) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.DistributedUpdateProcessor Core core_node4 belonging to recoverytest shard1, does not have error'd node https://127.0.0.1:37634/solr/recoverytest_shard1_replica_n1/ as a replica. No request recovery command will be sent!
   [junit4]   2> 1632291 INFO  (qtp1747717070-3536) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[1-1 (1587417314046771200)]} 0 19
   [junit4]   2> 1632292 INFO  (OverseerCollectionConfigSetProcessor-99213581528137733-127.0.0.1:37634_solr-n_0000000000) [n:127.0.0.1:37634_solr    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000000 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 1632293 INFO  (qtp1747717070-3540) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[1-2 (1587417314067742720)]} 0 0
   [junit4]   2> 1632291 INFO  (zkCallback-720-thread-1-processing-n:127.0.0.1:34184_solr) [n:127.0.0.1:34184_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (1)
   [junit4]   2> 1632294 INFO  (qtp1747717070-3540) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[1-3 (1587417314069839872)]} 0 0
   [junit4]   2> 1632316 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-1 (1587417314092908544)]} 0 0
   [junit4]   2> 1632317 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-2 (1587417314093957120)]} 0 0
   [junit4]   2> 1632319 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-3 (1587417314096054272)]} 0 0
   [junit4]   2> 1632359 INFO  (zkCallback-718-thread-3-processing-n:127.0.0.1:37634_solr) [n:127.0.0.1:37634_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (1)
   [junit4]   2> 1632364 INFO  (qtp1747717070-3540) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{delete=[1-1 (-1587417314104442880)]} 0 69
   [junit4]   2> 1632373 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[1-4 (1587417314152677376)]} 0 0
   [junit4]   2> 1632373 INFO  (updateExecutor-714-thread-1-processing-x:recoverytest_shard1_replica_n2 r:core_node4 https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1// n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.LeaderInitiatedRecoveryThread Put replica core=recoverytest_shard1_replica_n1 coreNodeName=core_node3 on 127.0.0.1:37634_solr into leader-initiated recovery.
   [junit4]   2> 1632373 WARN  (updateExecutor-714-thread-1-processing-x:recoverytest_shard1_replica_n2 r:core_node4 https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1// n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.LeaderInitiatedRecoveryThread Leader is publishing core=recoverytest_shard1_replica_n1 coreNodeName =core_node3 state=down on behalf of un-reachable replica https://127.0.0.1:37634/solr/recoverytest_shard1_replica_n1/
   [junit4]   2> 1632374 INFO  (qtp1747717070-3539) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{delete=[2-1 (-1587417314153725952)]} 0 0
   [junit4]   2> 1632376 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-4 (1587417314155823104)]} 0 0
   [junit4]   2> 1632376 INFO  (updateExecutor-714-thread-1-processing-x:recoverytest_shard1_replica_n2 r:core_node4 https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1// n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.LeaderInitiatedRecoveryThread LeaderInitiatedRecoveryThread-recoverytest_shard1_replica_n1 started running to send REQUESTRECOVERY command to https://127.0.0.1:37634/solr/recoverytest_shard1_replica_n1/; will try for a max of 600 secs
   [junit4]   2> 1632389 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-5 (1587417314169454592)]} 0 0
   [junit4]   2> 1632390 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-6 (1587417314170503168)]} 0 0
   [junit4]   2> 1632391 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{delete=[2-2 (-1587417314171551744)]} 0 0
   [junit4]   2> 1632391 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-7 (1587417314171551745)]} 0 0
   [junit4]   2> 1632392 INFO  (qtp1747717070-3538) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-8 (1587417314172600320)]} 0 0
   [junit4]   2> 1632555 INFO  (updateExecutor-714-thread-1-processing-x:recoverytest_shard1_replica_n2 r:core_node4 https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1// n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.LeaderInitiatedRecoveryThread Asking core=recoverytest_shard1_replica_n1 coreNodeName=core_node3 on https://127.0.0.1:37634/solr to recover
   [junit4]   2> 1632586 INFO  (qtp1747717070-3540) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-9 (1587417314373926912)]} 0 2
   [junit4]   2> 1632587 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{delete=[2-3 (-1587417314377072640)]} 0 0
   [junit4]   2> 1632600 INFO  (qtp1747717070-3534) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.u.p.LogUpdateProcessorFactory [recoverytest_shard1_replica_n2]  webapp=/solr path=/update params={wt=javabin&version=2}{add=[2-10 (1587417314390704128)]} 0 12
   [junit4]   2> 1632613 ERROR (updateExecutor-714-thread-1-processing-x:recoverytest_shard1_replica_n2 r:core_node4 https:////127.0.0.1:37634//solr//recoverytest_shard1_replica_n1// n:127.0.0.1:34184_solr s:shard1 c:recoverytest) [n:127.0.0.1:34184_solr c:recoverytest s:shard1 r:core_node4 x:recoverytest_shard1_replica_n2] o.a.s.c.LeaderInitiatedRecoveryThread https://127.0.0.1:37634/solr: Could not tell a replica to recover:org.apache.solr.client.solrj.SolrServerException: Server refused connection at: https://127.0.0.1:37634/solr
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:650)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
   [junit4]   2> 	at org.apache.solr.client.solrj.SolrClient.request(SolrClient.java:1219)
   [junit4]   2> 	at org.apache.solr.cloud.LeaderInitiatedRecoveryThread.sendRecoveryCommandWithRetry(LeaderInitiatedRecoveryThread.java:209)
   [junit4]   2> 	at org.apache.solr.cloud.LeaderInitiatedRecoveryThread.run(LeaderInitiatedRecoveryThread.java:95)
   [junit4]   2> 	at com.codahale.metrics.InstrumentedExecutorService$InstrumentedRunnable.run(InstrumentedExecutorService.java:176)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> Caused by: org.apache.http.conn.HttpHostConnectException: Connect to 127.0.0.1:37634 [/127.0.0.1] failed: Connection refused (Connection refused)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(DefaultHttpClientConnectionOperator.java:159)
   [junit4]   2> 	at org.apache.http.impl.conn.PoolingHttpClientConnectionManager.connect(PoolingHttpClientConnectionManager.java:359)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.establishRoute(MainClientExec.java:381)
   [junit4]   2> 	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:237)
   [junit4]   2> 	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
   [junit4]   2> 	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
   [junit4]   2> 	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
   [junit4]   2> 	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
   [junit4]   2> 	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
   [junit4]   2> 	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:542)
   [junit4]   2> 	... 10 more
   [junit4]   2> Caused by: java.net.ConnectException: Connection refused (Connection refused)
   [junit4]   2> 	at java.net.PlainSocketImpl.socketConnect(Native Method)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.doConnect(AbstractPlainSocketImpl.java:350)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.connectToAddress(AbstractPlainSocketImpl.java:206)
   [junit4]   2> 	at java.net.AbstractPlainSocketImpl.connect(AbstractPlainSocketImpl.java:188)
   [junit4]   2> 	at java.net.SocksSocketImpl.connect(SocksSocketImpl.java:392)
   [junit4]   2> 	at java.net.Socket.connect(Socket.java:589)
   [junit4]   2> 	at org.apache.http.conn.ssl.SSLConnectionSocketFactory.connectSocket(SSLConnectionSocketFactory.java:339)
   [junit4]   2> 	at org.apache.http.impl.conn.DefaultHttpClientConnectionOperator.connect(D

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

ache.solr.cloud.AbstractFullDistribZkTestBase.createServers(AbstractFullDistribZkTestBase.java:333)
   [junit4]    > 	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:991)
   [junit4]    > 	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> NOTE: leaving temporary files on disk at: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.BasicDistributedZk2Test_59F090994ABB744-001
   [junit4]   2> Dec 21, 2017 6:33:12 PM com.carrotsearch.randomizedtesting.ThreadLeakControl checkThreadLeaks
   [junit4]   2> WARNING: Will linger awaiting termination of 1 leaked thread(s).
   [junit4]   2> NOTE: test params are: codec=FastCompressingStoredFields(storedFieldsFormat=CompressingStoredFieldsFormat(compressionMode=FAST, chunkSize=21234, maxDocsPerChunk=869, blockSize=612), termVectorsFormat=CompressingTermVectorsFormat(compressionMode=FAST, chunkSize=21234, blockSize=612)), sim=RandomSimilarity(queryNorm=true): {}, locale=is-IS, timezone=Europe/Sofia
   [junit4]   2> NOTE: Linux 4.4.0-83-generic amd64/Oracle Corporation 1.8.0_152 (64-bit)/cpus=4,threads=1,free=282092704,total=527958016
   [junit4]   2> NOTE: All tests run in this JVM: [TestLegacyField, SortSpecParsingTest, DistanceUnitsTest, BlockDirectoryTest, CoreAdminHandlerTest, TestSolrXml, TestSchemaNameResource, HdfsLockFactoryTest, ReturnFieldsTest, TestCloudManagedSchema, HdfsBasicDistributedZkTest, FullSolrCloudDistribCmdsTest, HdfsWriteToMultipleCollectionsTest, TestReplicationHandlerBackup, TestTolerantSearch, WordBreakSolrSpellCheckerTest, TestFiltering, TestSchemaVersionResource, TestFieldCacheVsDocValues, TestConfigSetsAPIZkFailure, DeleteNodeTest, TestMacroExpander, TestAnalyzeInfixSuggestions, TestRealTimeGet, TestDistributedStatsComponentCardinality, LeaderElectionTest, TestSha256AuthenticationProvider, UUIDFieldTest, SolrShardReporterTest, CurrencyFieldTypeTest, SegmentsInfoRequestHandlerTest, TestDistribDocBasedVersion, OverseerStatusTest, SpatialHeatmapFacetsTest, ZkNodePropsTest, SolrJmxReporterTest, TestDFISimilarityFactory, CollectionReloadTest, DefaultValueUpdateProcessorTest, RecoveryZkTest, TestRandomRequestDistribution, TestFieldCacheReopen, TestValueSourceCache, PluginInfoTest, UniqFieldsUpdateProcessorFactoryTest, SharedFSAutoReplicaFailoverTest, MigrateRouteKeyTest, IndexSchemaTest, TestConfigSets, SearchRateTriggerTest, DirectSolrConnectionTest, TestEmbeddedSolrServerConstructors, InfixSuggestersTest, AnalyticsMergeStrategyTest, TriggerIntegrationTest, ConnectionReuseTest, TestTolerantUpdateProcessorRandomCloud, RecoveryAfterSoftCommitTest, MetricsHandlerTest, TestLeaderInitiatedRecoveryThread, ClusterStateTest, SortByFunctionTest, TestFreeTextSuggestions, TestExactSharedStatsCache, TestManagedSchemaThreadSafety, SuggesterWFSTTest, TestHalfAndHalfDocValues, SolrGangliaReporterTest, TestLRUCache, TestDistributedGrouping, TestLFUCache, TestFieldResource, TestDistributedMissingSort, DisMaxRequestHandlerTest, TestSolrCoreProperties, HdfsCollectionsAPIDistributedZkTest, TestConfigOverlay, LeaderElectionContextKeyTest, BlockJoinFacetDistribTest, TestSearchPerf, TestScoreJoinQPNoScore, TestJsonFacetRefinement, HdfsRecoveryZkTest, TestManagedStopFilterFactory, RuleEngineTest, DocValuesNotIndexedTest, TestFunctionQuery, FieldMutatingUpdateProcessorTest, SolrCoreCheckLockOnStartupTest, DistributedDebugComponentTest, TestExtendedDismaxParser, OverseerCollectionConfigSetProcessorTest, SimplePostToolTest, DistributedFacetPivotSmallTest, SystemInfoHandlerTest, TestIndexSearcher, ResponseHeaderTest, TestCollectionsAPIViaSolrCloudCluster, ReplicationFactorTest, TestGroupingSearch, DistributedQueryComponentOptimizationTest, HdfsThreadLeakTest, TestSkipOverseerOperations, SolrMetricManagerTest, BasicDistributedZk2Test]
   [junit4] Completed [330/751 (2!)] on J2 in 45.28s, 1 test, 1 error <<< FAILURES!

[...truncated 32 lines...]
   [junit4] Suite: org.apache.solr.security.TestPKIAuthenticationPlugin
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.security.TestPKIAuthenticationPlugin_59F090994ABB744-001/init-core-data-001
   [junit4]   2> 3873300 WARN  (SUITE-TestPKIAuthenticationPlugin-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=27 numCloses=27
   [junit4]   2> 3873301 INFO  (SUITE-TestPKIAuthenticationPlugin-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 Using TrieFields (NUMERIC_POINTS_SYSPROP=false) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 3873315 INFO  (SUITE-TestPKIAuthenticationPlugin-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (true) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 3873315 INFO  (SUITE-TestPKIAuthenticationPlugin-seed#[59F090994ABB744]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 3873334 INFO  (TEST-TestPKIAuthenticationPlugin.test-seed#[59F090994ABB744]) [    ] o.a.s.SolrTestCaseJ4 ###Starting test
   [junit4]   2> 3886321 ERROR (TEST-TestPKIAuthenticationPlugin.test-seed#[59F090994ABB744]) [    ] o.a.s.s.PKIAuthenticationPlugin Invalid key request timestamp: 1513881360451 , received timestamp: 1513881373078 , TTL: 10000
   [junit4]   2> 3886321 INFO  (TEST-TestPKIAuthenticationPlugin.test-seed#[59F090994ABB744]) [    ] o.a.s.SolrTestCaseJ4 ###Ending test
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestPKIAuthenticationPlugin -Dtests.method=test -Dtests.seed=59F090994ABB744 -Dtests.multiplier=2 -Dtests.slow=true -Dtests.locale=fr-CH -Dtests.timezone=America/Los_Angeles -Dtests.asserts=true -Dtests.file.encoding=UTF-8
   [junit4] ERROR   13.0s J0 | TestPKIAuthenticationPlugin.test <<<
   [junit4]    > Throwable #1: java.lang.NullPointerException
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([59F090994ABB744:8DCB36D33A57DABC]:0)
   [junit4]    > 	at org.apache.solr.security.TestPKIAuthenticationPlugin.test(TestPKIAuthenticationPlugin.java:102)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> NOTE: leaving temporary files on disk at: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.security.TestPKIAuthenticationPlugin_59F090994ABB744-001
   [junit4]   2> NOTE: test params are: codec=Lucene70, sim=RandomSimilarity(queryNorm=true): {}, locale=fr-CH, timezone=America/Los_Angeles
   [junit4]   2> NOTE: Linux 4.4.0-83-generic amd64/Oracle Corporation 1.8.0_152 (64-bit)/cpus=4,threads=1,free=169000968,total=512753664
   [junit4]   2> NOTE: All tests run in this JVM: [TestCorePropertiesReload, LeaderElectionIntegrationTest, FastVectorHighlighterTest, TestCloudPseudoReturnFields, TestConfigSetsAPI, TestPushWriter, TestExpandComponent, NoCacheHeaderTest, TestDFRSimilarityFactory, RAMDirectoryFactoryTest, TestHighlightDedupGrouping, DistributedQueryElevationComponentTest, TestLegacyFieldReuse, RestartWhileUpdatingTest, TestHighFrequencyDictionaryFactory, SparseHLLTest, TestSortByMinMaxFunction, AutoAddReplicasPlanActionTest, FullHLLTest, TestScoreJoinQPScore, TestCodecSupport, TestCloudNestedDocsSort, TestTlogReplica, MultiTermTest, TestSuggestSpellingConverter, DirectoryFactoryTest, TestWordDelimiterFilterFactory, TestCrossCoreJoin, TestReRankQParserPlugin, TestReqParamsAPI, MetricsConfigTest, TestDistributedSearch, TestIntervalFaceting, TestSolrJ, TestUseDocValuesAsStored, TestBinaryResponseWriter, TestManagedSynonymFilterFactory, BooleanFieldTest, DocValuesTest, DistributedFacetPivotWhiteBoxTest, PrimitiveFieldTypeTest, TestFieldTypeCollectionResource, ManagedSchemaRoundRobinCloudTest, SpatialRPTFieldTypeTest, TestComplexPhraseQParserPlugin, TestManagedSchema, MissingSegmentRecoveryTest, IndexSchemaRuntimeFieldTest, AnalysisErrorHandlingTest, SolrXmlInZkTest, SearchHandlerTest, SliceStateTest, TestSubQueryTransformer, TestStandardQParsers, TestShortCircuitedRequests, NumberUtilsTest, AnalysisAfterCoreReloadTest, SimpleMLTQParserTest, QueryParsingTest, TestLuceneIndexBackCompat, TestSolrIndexConfig, ForceLeaderTest, DateMathParserTest, CoreMergeIndexesAdminHandlerTest, AddSchemaFieldsUpdateProcessorFactoryTest, TestJsonFacets, RemoteQueryErrorTest, TestXmlQParser, DateRangeFieldTest, CleanupOldIndexTest, TestImplicitCoreProperties, URLClassifyProcessorTest, UpdateParamsTest, TestLocalFSCloudBackupRestore, SimpleFacetsTest, TestSerializedLuceneMatchVersion, TestNumericTokenStream, TestMacros, TestPostingsSolrHighlighter, TestRandomFaceting, TestConfigSetImmutable, SaslZkACLProviderTest, SyncSliceTest, TestOverriddenPrefixQueryForCustomFieldType, SolrInfoBeanTest, DistribCursorPagingTest, TestMergePolicyConfig, SpellCheckCollatorTest, CollectionStateFormat2Test, TestAddFieldRealTimeGet, TestRequestStatusCollectionAPI, ReplicaListTransformerTest, TestSchemaResource, TestIBSimilarityFactory, MergeStrategyTest, SolrPluginUtilsTest, CdcrReplicationDistributedZkTest, TestFieldCacheWithThreads, DateFieldTest, HdfsChaosMonkeyNothingIsSafeTest, SolrSlf4jReporterTest, TestComponentsName, TestConfig, TestSQLHandlerNonCloud, TestManagedResource, SolrGraphiteReporterTest, TestCloudInspectUtil, TestNRTOpen, VMParamsZkACLAndCredentialsProvidersTest, CursorPagingTest, TestCSVLoader, TestNonDefinedSimilarityFactory, LeaderFailoverAfterPartitionTest, SuggestComponentContextFilterQueryTest, SolrCoreTest, BigEndianAscendingWordSerializerTest, SpellCheckComponentTest, TestPKIAuthenticationPlugin]
   [junit4] Completed [340/751 (3!)] on J0 in 13.22s, 1 test, 1 error <<< FAILURES!

[...truncated 48763 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 18 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/18/

11 tests failed.
FAILED:  org.apache.solr.handler.dataimport.TestContentStreamDataSource.testCommitWithin

Error Message:
expected:<0> but was:<2>

Stack Trace:
java.lang.AssertionError: expected:<0> but was:<2>
	at __randomizedtesting.SeedInfo.seed([C84001AC4330ACF5:72926ED4C01E42E0]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.handler.dataimport.TestContentStreamDataSource.testCommitWithin(TestContentStreamDataSource.java:98)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests

Error Message:
Alias should not exist

Stack Trace:
java.lang.AssertionError: Alias should not exist
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:A4AD31F9D9B1E2AB]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests(CollectionsAPIAsyncDistributedZkTest.java:151)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.HttpPartitionTest.test

Error Message:
Doc with id=2 not found in http://127.0.0.1:36095/i/q/c8n_1x2 due to: Path not found: /id; rsp={doc=null}

Stack Trace:
java.lang.AssertionError: Doc with id=2 not found in http://127.0.0.1:36095/i/q/c8n_1x2 due to: Path not found: /id; rsp={doc=null}
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:C8BD3294D1E5C18C]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.HttpPartitionTest.assertDocExists(HttpPartitionTest.java:604)
	at org.apache.solr.cloud.HttpPartitionTest.assertDocsExistInAllReplicas(HttpPartitionTest.java:559)
	at org.apache.solr.cloud.HttpPartitionTest.testRf2(HttpPartitionTest.java:328)
	at org.apache.solr.cloud.HttpPartitionTest.test(HttpPartitionTest.java:131)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.MoveReplicaHDFSTest.testNormalMove

Error Message:
should be one less core on the source node! expected:<0> but was:<1>

Stack Trace:
java.lang.AssertionError: should be one less core on the source node! expected:<0> but was:<1>
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:E631BAE9FAF86E6E]: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.MoveReplicaTest.test(MoveReplicaTest.java:160)
	at org.apache.solr.cloud.MoveReplicaHDFSTest.testNormalMove(MoveReplicaHDFSTest.java:61)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestCloudPivotFacet.test

Error Message:
dense_pivot_i1,bogus_not_in_any_doc_s: count query failed: {main(rows=0&q=*:*),extra(fq={!term+f%3Ddense_pivot_i1}23)}: No live SolrServers available to handle this request:[http://127.0.0.1:56731/ay/collection1]

Stack Trace:
java.lang.RuntimeException: dense_pivot_i1,bogus_not_in_any_doc_s: count query failed: {main(rows=0&q=*:*),extra(fq={!term+f%3Ddense_pivot_i1}23)}: No live SolrServers available to handle this request:[http://127.0.0.1:56731/ay/collection1]
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:C8BD3294D1E5C18C]:0)
	at org.apache.solr.cloud.TestCloudPivotFacet.assertPivotCountsAreCorrect(TestCloudPivotFacet.java:325)
	at org.apache.solr.cloud.TestCloudPivotFacet.assertPivotCountsAreCorrect(TestCloudPivotFacet.java:290)
	at org.apache.solr.cloud.TestCloudPivotFacet.test(TestCloudPivotFacet.java:247)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.solr.client.solrj.SolrServerException: No live SolrServers available to handle this request:[http://127.0.0.1:56731/ay/collection1]
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:462)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1103)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrClient.query(SolrClient.java:942)
	at org.apache.solr.client.solrj.SolrClient.query(SolrClient.java:957)
	at org.apache.solr.cloud.TestCloudPivotFacet.assertPivotData(TestCloudPivotFacet.java:351)
	at org.apache.solr.cloud.TestCloudPivotFacet.assertPivotCountsAreCorrect(TestCloudPivotFacet.java:321)
	... 43 more
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at http://127.0.0.1:56731/ay/collection1: no servers hosting shard: shard2
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	... 51 more


FAILED:  org.apache.solr.cloud.ZkSolrClientTest.testMultipleWatchesAsync

Error Message:


Stack Trace:
java.lang.AssertionError
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:285FDEECEAFDADEA]:0)
	at org.junit.Assert.fail(Assert.java:92)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.junit.Assert.assertTrue(Assert.java:54)
	at org.apache.solr.cloud.ZkSolrClientTest.testMultipleWatchesAsync(ZkSolrClientTest.java:252)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.autoscaling.AutoScalingHandlerTest.testReadApi

Error Message:
expected:<1> but was:<0>

Stack Trace:
java.lang.AssertionError: expected:<1> but was:<0>
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:17C0F6FBA4EB4E6F]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.cloud.autoscaling.AutoScalingHandlerTest.testReadApi(AutoScalingHandlerTest.java:724)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.autoscaling.SystemLogListenerTest.test

Error Message:
wrong number of events added to .system expected:<9> but was:<10>

Stack Trace:
java.lang.AssertionError: wrong number of events added to .system expected:<9> but was:<10>
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:C8BD3294D1E5C18C]: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.autoscaling.SystemLogListenerTest.test(SystemLogListenerTest.java:166)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testNodeMarkersRegistration

Error Message:
Path /autoscaling/nodeAdded/127.0.0.1:40714_solr wasn't created

Stack Trace:
java.lang.AssertionError: Path /autoscaling/nodeAdded/127.0.0.1:40714_solr wasn't created
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:58538542712C619B]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testNodeMarkersRegistration(TriggerIntegrationTest.java:931)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.update.processor.TimeRoutedAliasUpdateProcessorTest.test

Error Message:
expected:<1> but was:<0>

Stack Trace:
java.lang.AssertionError: expected:<1> but was:<0>
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:C8BD3294D1E5C18C]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.update.processor.TimeRoutedAliasUpdateProcessorTest.assertInvariants(TimeRoutedAliasUpdateProcessorTest.java:245)
	at org.apache.solr.update.processor.TimeRoutedAliasUpdateProcessorTest.test(TimeRoutedAliasUpdateProcessorTest.java:123)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest.testHistory

Error Message:
expected:<8> but was:<10>

Stack Trace:
java.lang.AssertionError: expected:<8> but was:<10>
	at __randomizedtesting.SeedInfo.seed([40E90D4E7F19AC74:2D15A9B3C5515373]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest.testHistory(AutoscalingHistoryHandlerTest.java:259)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 11854 lines...]
   [junit4] Suite: org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest
   [junit4]   2> 1053255 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> Creating dataDir: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_40E90D4E7F19AC74-001/init-core-data-001
   [junit4]   2> 1053256 WARN  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=941 numCloses=941
   [junit4]   2> 1053298 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 1053342 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (true) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 1053343 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 3 servers in /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_40E90D4E7F19AC74-001/tempDir-001
   [junit4]   2> 1053343 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 1053343 INFO  (Thread-127) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 1053343 INFO  (Thread-127) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 1053514 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:51987
   [junit4]   2> 1053546 ERROR (Thread-127) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 1053657 INFO  (zkConnectionManagerCallback-118-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1053689 INFO  (jetty-launcher-115-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1053791 INFO  (jetty-launcher-115-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1053835 INFO  (jetty-launcher-115-thread-3) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1054239 INFO  (jetty-launcher-115-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@7a7763ff{/solr,null,AVAILABLE}
   [junit4]   2> 1054241 INFO  (jetty-launcher-115-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@521464ae{HTTP/1.1,[http/1.1]}{127.0.0.1:44922}
   [junit4]   2> 1054241 INFO  (jetty-launcher-115-thread-2) [    ] o.e.j.s.Server Started @1075014ms
   [junit4]   2> 1054241 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=44922}
   [junit4]   2> 1054242 ERROR (jetty-launcher-115-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1054242 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1054242 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1054242 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1054242 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-21T01:46:48.675Z
   [junit4]   2> 1054447 INFO  (jetty-launcher-115-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@6dbab8a9{/solr,null,AVAILABLE}
   [junit4]   2> 1054447 INFO  (jetty-launcher-115-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@1a804231{HTTP/1.1,[http/1.1]}{127.0.0.1:34933}
   [junit4]   2> 1054447 INFO  (jetty-launcher-115-thread-1) [    ] o.e.j.s.Server Started @1075220ms
   [junit4]   2> 1054448 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=34933}
   [junit4]   2> 1054448 ERROR (jetty-launcher-115-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1054448 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1054448 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1054448 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1054448 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-21T01:46:48.881Z
   [junit4]   2> 1054567 INFO  (jetty-launcher-115-thread-3) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@6471f9ae{/solr,null,AVAILABLE}
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.e.j.s.AbstractConnector Started ServerConnector@1b119853{HTTP/1.1,[http/1.1]}{127.0.0.1:35284}
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.e.j.s.Server Started @1075340ms
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=35284}
   [junit4]   2> 1054568 ERROR (jetty-launcher-115-thread-3) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1054568 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-21T01:46:49.001Z
   [junit4]   2> 1054649 INFO  (zkConnectionManagerCallback-122-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1054683 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1054748 INFO  (jetty-launcher-115-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:51987/solr
   [junit4]   2> 1054749 INFO  (zkConnectionManagerCallback-120-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1054807 INFO  (zkConnectionManagerCallback-124-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1054826 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1055082 INFO  (jetty-launcher-115-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:51987/solr
   [junit4]   2> 1055119 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1055280 INFO  (jetty-launcher-115-thread-3) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:51987/solr
   [junit4]   2> 1055382 INFO  (zkConnectionManagerCallback-128-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1055387 INFO  (zkConnectionManagerCallback-136-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1055643 INFO  (zkConnectionManagerCallback-132-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1055643 INFO  (zkConnectionManagerCallback-138-thread-1-processing-n:127.0.0.1:34933_solr) [n:127.0.0.1:34933_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1055983 INFO  (zkConnectionManagerCallback-140-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1056017 INFO  (zkConnectionManagerCallback-142-thread-1-processing-n:127.0.0.1:44922_solr) [n:127.0.0.1:44922_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1056018 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1056026 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:35284_solr
   [junit4]   2> 1056217 INFO  (jetty-launcher-115-thread-2) [n:127.0.0.1:44922_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1056226 INFO  (jetty-launcher-115-thread-2) [n:127.0.0.1:44922_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:44922_solr
   [junit4]   2> 1056610 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer Overseer (id=99209760458932232-127.0.0.1:35284_solr-n_0000000000) starting
   [junit4]   2> 1056707 INFO  (zkCallback-141-thread-1-processing-n:127.0.0.1:44922_solr) [n:127.0.0.1:44922_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 1056707 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer Starting to work on the main queue
   [junit4]   2> 1056727 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:35284_solr
   [junit4]   2> 1056750 INFO  (zkCallback-141-thread-1-processing-n:127.0.0.1:44922_solr) [n:127.0.0.1:44922_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 1056851 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 1058199 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 1
   [junit4]   2> 1058199 INFO  (zkCallback-139-thread-2-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1058200 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: [127.0.0.1:44922_solr, 127.0.0.1:35284_solr]
   [junit4]   2> 1058200 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion -1
   [junit4]   2> 1058200 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 1
   [junit4]   2> 1058262 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 1058262 DEBUG (OverseerAutoScalingTriggerThread-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion 1
   [junit4]   2> 1058496 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "operation":"downnode",
   [junit4]   2>   "node_name":"127.0.0.1:35284_solr"} current state version: 0
   [junit4]   2> 1058496 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.NodeMutator DownNode state invoked for node: 127.0.0.1:35284_solr
   [junit4]   2> 1058568 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1058570 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1058587 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer processMessage: queueSize: 2, message = {
   [junit4]   2>   "operation":"downnode",
   [junit4]   2>   "node_name":"127.0.0.1:34933_solr"} current state version: 0
   [junit4]   2> 1058587 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.NodeMutator DownNode state invoked for node: 127.0.0.1:34933_solr
   [junit4]   2> 1058588 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:34933_solr
   [junit4]   2> 1058593 INFO  (zkCallback-141-thread-1-processing-n:127.0.0.1:44922_solr) [n:127.0.0.1:44922_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1058594 INFO  (zkCallback-139-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1058689 DEBUG (ScheduledTrigger-391-thread-1) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:44922_solr, 127.0.0.1:35284_solr, 127.0.0.1:34933_solr]
   [junit4]   2> 1059030 INFO  (zkCallback-137-thread-1-processing-n:127.0.0.1:34933_solr) [n:127.0.0.1:34933_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1059717 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35284.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1059873 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35284.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1059874 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35284.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1059963 INFO  (jetty-launcher-115-thread-3) [n:127.0.0.1:35284_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_40E90D4E7F19AC74-001/tempDir-001/node3/.
   [junit4]   2> 1059963 DEBUG (ScheduledTrigger-391-thread-1) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:44922_solr, 127.0.0.1:35284_solr, 127.0.0.1:34933_solr]
   [junit4]   2> 1060396 INFO  (jetty-launcher-115-thread-2) [n:127.0.0.1:44922_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_44922.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1060879 INFO  (jetty-launcher-115-thread-2) [n:127.0.0.1:44922_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_44922.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1060879 INFO  (jetty-launcher-115-thread-2) [n:127.0.0.1:44922_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_44922.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1060880 INFO  (jetty-launcher-115-thread-2) [n:127.0.0.1:44922_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_40E90D4E7F19AC74-001/tempDir-001/node2/.
   [junit4]   2> 1061245 DEBUG (ScheduledTrigger-391-thread-2) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:44922_solr, 127.0.0.1:35284_solr, 127.0.0.1:34933_solr]
   [junit4]   2> 1061610 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34933.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1061670 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34933.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1061723 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34933.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@28d47133
   [junit4]   2> 1061770 INFO  (jetty-launcher-115-thread-1) [n:127.0.0.1:34933_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_40E90D4E7F19AC74-001/tempDir-001/node1/.
   [junit4]   2> 1062222 INFO  (zkConnectionManagerCallback-148-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1062294 INFO  (zkConnectionManagerCallback-152-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1062295 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 1062298 DEBUG (ScheduledTrigger-391-thread-1) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:44922_solr, 127.0.0.1:35284_solr, 127.0.0.1:34933_solr]
   [junit4]   2> 1062395 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[40E90D4E7F19AC74]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:51987/solr ready
   [junit4]   2> 1062476 INFO  (qtp1645299830-823) [n:127.0.0.1:34933_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=3&name=AutoscalingHistoryHandlerTest_collection&nrtReplicas=3&action=CREATE&numShards=1&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 1062498 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.CreateCollectionCmd Create collection AutoscalingHistoryHandlerTest_collection
   [junit4]   2> 1062499 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.CreateCollectionCmd Only _default config set found, using it.
   [junit4]   2> 1062499 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/managed-schema to /configs/AutoscalingHistoryHandlerTest_collection/managed-schema
   [junit4]   2> 1062520 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/protwords.txt to /configs/AutoscalingHistoryHandlerTest_collection/protwords.txt
   [junit4]   2> 1062521 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/solrconfig.xml to /configs/AutoscalingHistoryHandlerTest_collection/solrconfig.xml
   [junit4]   2> 1062522 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/synonyms.txt to /configs/AutoscalingHistoryHandlerTest_collection/synonyms.txt
   [junit4]   2> 1062524 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/stopwords.txt to /configs/AutoscalingHistoryHandlerTest_collection/stopwords.txt
   [junit4]   2> 1062525 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_it.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_it.txt
   [junit4]   2> 1062539 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_ca.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_ca.txt
   [junit4]   2> 1062540 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stemdict_nl.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stemdict_nl.txt
   [junit4]   2> 1062542 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_no.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_no.txt
   [junit4]   2> 1062543 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_hy.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_hy.txt
   [junit4]   2> 1062544 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_id.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_id.txt
   [junit4]   2> 1062563 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_hi.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_hi.txt
   [junit4]   2> 1062564 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ga.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ga.txt
   [junit4]   2> 1062565 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_da.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_da.txt
   [junit4]   2> 1062567 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ja.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ja.txt
   [junit4]   2> 1062568 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_pt.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_pt.txt
   [junit4]   2> 1062569 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_hu.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_hu.txt
   [junit4]   2> 1062591 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_el.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_el.txt
   [junit4]   2> 1062592 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ru.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ru.txt
   [junit4]   2> 1062598 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_tr.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_tr.txt
   [junit4]   2> 1062599 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ar.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ar.txt
   [junit4]   2> 1062614 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/userdict_ja.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/userdict_ja.txt
   [junit4]   2> 1062615 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_eu.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_eu.txt
   [junit4]   2> 1062616 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_it.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_it.txt
   [junit4]   2> 1062617 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_cz.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_cz.txt
   [junit4]   2> 1062619 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stoptags_ja.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stoptags_ja.txt
   [junit4]   2> 1062620 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_fr.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_fr.txt
   [junit4]   2> 1062621 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_de.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_de.txt
   [junit4]   2> 1062655 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_fa.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_fa.txt
   [junit4]   2> 1062656 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_ga.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_ga.txt
   [junit4]   2> 1062676 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ca.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ca.txt
   [junit4]   2> 1062677 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_nl.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_nl.txt
   [junit4]   2> 1062678 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_bg.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_bg.txt
   [junit4]   2> 1062700 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_en.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_en.txt
   [junit4]   2> 1062795 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_es.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_es.txt
   [junit4]   2> 1062799 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_lv.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_lv.txt
   [junit4]   2> 1062815 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ro.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ro.txt
   [junit4]   2> 1062816 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_th.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_th.txt
   [junit4]   2> 1062817 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_fr.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_fr.txt
   [junit4]   2> 1062818 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_sv.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_sv.txt
   [junit4]   2> 1062829 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_fi.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_fi.txt
   [junit4]   2> 1062840 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/hyphenations_ga.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/hyphenations_ga.txt
   [junit4]   2> 1062858 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_gl.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_gl.txt
   [junit4]   2> 1062859 INFO  (OverseerThreadFactory-393-thread-1-processing-n:127.0.0.1:35284_solr) [n:127.0.0.1:35284_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/params.json to /configs/AutoscalingHistoryHandlerTest_collection/params.json
   [junit4]   2> 1062863 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "name":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "fromApi":"true",
   [junit4]   2>   "replicationFactor":"3",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "nrtReplicas":"3",
   [junit4]   2>   "stateFormat":"2",
   [junit4]   2>   "operation":"create"} current state version: 0
   [junit4]   2> 1062864 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.ClusterStateMutator building a new cName: AutoscalingHistoryHandlerTest_collection
   [junit4]   2> 1062864 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.ZkStateWriter going to create_collection /collections/AutoscalingHistoryHandlerTest_collection/state.json
   [junit4]   2> 1063139 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:44922/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} current state version: 0
   [junit4]   2> 1063139 INFO  (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:44922/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 1063140 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.SliceMutator Old Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{}}
   [junit4]   2> 1063140 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.SliceMutator New Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{"core_node2":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:44922/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 1063247 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.ZkStateWriter going to update_collection /collections/AutoscalingHistoryHandlerTest_collection/state.json version: 0
   [junit4]   2> 1063306 DEBUG (ScheduledTrigger-391-thread-1) [n:127.0.0.1:35284_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:44922_solr, 127.0.0.1:35284_solr, 127.0.0.1:34933_solr]
   [junit4]   2> 1063336 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n3",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:35284/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} current state version: 0
   [junit4]   2> 1063336 INFO  (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n3",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:35284/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 1063379 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.SliceMutator Old Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{"core_node2":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:44922/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 1063379 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.o.SliceMutator New Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{
   [junit4]   2>     "core_node2":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:44922/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"},
   [junit4]   2>     "core_node5":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n3",
   [junit4]   2>       "base_url":"http://127.0.0.1:35284/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 1063411 DEBUG (OverseerStateUpdate-99209760458932232-127.0.0.1:35284_solr-n_0000000000) [n:127.0.0.1:35284_solr    ] o.a.s.c.Overseer processMessage: queueSize: 2, message = {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"sh

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

eporters were configured - adding default JMX reporter.
   [junit4]   2> 173937 T60 oasmr.SolrJmxReporter.doInit JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@6d3771e8
   [junit4]   2> 174045 T60 oasmr.SolrJmxReporter.doInit JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@6d3771e8
   [junit4]   2> 174046 T60 oasmr.SolrJmxReporter.doInit JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@6d3771e8
   [junit4]   2> 174107 T60 oasc.CorePropertiesLocator.discover Found 1 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/contrib/solr-dataimporthandler/test/J1/temp/solr.handler.dataimport.TestContentStreamDataSource_C84001AC4330ACF5-001/inst-002
   [junit4]   2> 174107 T60 oasc.CorePropertiesLocator.discover Cores are: [collection1]
   [junit4]   2> 174172 T93 oasc.TransientSolrCoreCacheDefault.doInit Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 174359 T93 x:x:collection1 oasc.SolrConfig.<init> Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 174540 T93 x:x:collection1 oass.IndexSchema.readSchema [collection1] Schema name=dih_test
   [junit4]   2> 174640 T93 x:x:collection1 oass.IndexSchema.readSchema Loaded schema dih_test/4.0 with uniqueid field id
   [junit4]   2> 174640 T93 x:x:collection1 oasc.CoreContainer.createFromDescriptor Creating SolrCore 'collection1' using configuration from instancedir /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/contrib/solr-dataimporthandler/test/J1/temp/solr.handler.dataimport.TestContentStreamDataSource_C84001AC4330ACF5-001/inst-002/collection1, trusted=true
   [junit4]   2> 174650 T93 x:x:collection1 oasmr.SolrJmxReporter.doInit JMX monitoring for 'solr.core.collection1' (registry 'solr.core.collection1') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@6d3771e8
   [junit4]   2> 174651 T93 x:x:collection1 oasc.SolrCore.initRecoveryStrategyBuilder solr.RecoveryStrategy.Builder
   [junit4]   2> 174651 T93 x:x:collection1 oasc.SolrCore.<init> [[collection1] ] Opening new SolrCore at [/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/contrib/solr-dataimporthandler/test/J1/temp/solr.handler.dataimport.TestContentStreamDataSource_C84001AC4330ACF5-001/inst-002/collection1], dataDir=[/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/contrib/solr-dataimporthandler/test/J1/temp/solr.handler.dataimport.TestContentStreamDataSource_C84001AC4330ACF5-001/inst-002/collection1/data/]
   [junit4]   2> 175891 T93 x:x:collection1 oasu.CommitTracker.<init> Hard AutoCommit: disabled
   [junit4]   2> 175891 T93 x:x:collection1 oasu.CommitTracker.<init> Soft AutoCommit: disabled
   [junit4]   2> 175893 T93 x:x:collection1 oass.SolrIndexSearcher.<init> Opening [Searcher@46253128[collection1] main]
   [junit4]   2> 175893 T93 x:x:collection1 oasr.ManagedResourceStorage$FileStorageIO.configure File-based storage initialized to use dir: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/contrib/solr-dataimporthandler/test/J1/temp/solr.handler.dataimport.TestContentStreamDataSource_C84001AC4330ACF5-001/inst-002/collection1/conf
   [junit4]   2> 175938 T93 x:x:collection1 oash.ReplicationHandler.inform Commits will be reserved for 10000ms.
   [junit4]   2> 175947 T97 x:x:collection1 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@46253128[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> ASYNC  NEW_CORE C7 name=collection1 org.apache.solr.core.SolrCore@5476653b
   [junit4]   2> 176649 T85 x:x:collection1 C7 oashd.DataImporter.maybeReloadConfiguration Loading DIH Configuration: data-config.xml
   [junit4]   2> 176683 T85 x:x:collection1 C7 oashd.DataImporter.loadDataConfig Data Configuration loaded successfully
   [junit4]   2> 176683 T85 x:x:collection1 C7 oashd.DataImporter.doFullImport Starting Full Import
   [junit4]   2> 176684 T85 x:x:collection1 C7 oashd.SimplePropertiesWriter.readIndexerProperties WARN Unable to read: dataimport.properties
   [junit4]   2> 177935 T85 x:x:collection1 C7 oashd.DocBuilder.finish Import completed successfully
   [junit4]   2> 177935 T85 x:x:collection1 C7 oashd.SimplePropertiesWriter.readIndexerProperties WARN Unable to read: dataimport.properties
   [junit4]   2> 177935 T85 x:x:collection1 C7 oashd.SimplePropertiesWriter.persist Wrote last indexed time to dataimport.properties
   [junit4]   2> 177935 T85 x:x:collection1 C7 oashd.DocBuilder.execute Time taken = 0:0:1.251
   [junit4]   2> 177935 T85 x:x:collection1 C7 oasup.LogUpdateProcessorFactory$LogUpdateProcessor.finish [collection1]  webapp=/solr path=/dataimport params={commitWithin=1000&commit=false&clean=false&wt=javabin&version=2&command=full-import}{add=[1, 2]} 0 1288
   [junit4]   2> 177967 T100 x:x:collection1 oasu.DirectUpdateHandler2.commit start commit{,optimize=false,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=true,prepareCommit=false}
   [junit4]   2> 178022 T100 x:x:collection1 oass.SolrIndexSearcher.<init> Opening [Searcher@78b373f0[collection1] main]
   [junit4]   2> 178026 T97 x:x:collection1 oasc.SolrCore.registerSearcher [collection1] Registered new searcher Searcher@78b373f0[collection1] main{ExitableDirectoryReader(UninvertingDirectoryReader(Uninverting(_0(7.2.0):c2)))}
   [junit4]   2> 178046 T100 x:x:collection1 oasu.DirectUpdateHandler2.commit end_commit_flush
   [junit4]   2> 178120 T86 x:x:collection1 C7 oasc.SolrCore.execute [collection1]  webapp=/solr path=/select params={q=*&df=desc&wt=javabin&version=2} hits=2 status=0 QTime=0
   [junit4]   2> 178198 T60 oejs.AbstractConnector.doStop Stopped ServerConnector@5f4715b6{SSL,[ssl, http/1.1]}{127.0.0.1:0}
   [junit4]   2> 178198 T60 oasc.CoreContainer.shutdown Shutting down CoreContainer instance=733468200
   [junit4]   2> 178294 T60 oasm.SolrMetricManager.closeReporters Closing metric reporters for registry=solr.node, tag=null
   [junit4]   2> 178295 T60 oasmr.SolrJmxReporter.close Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@2b26687a: rootName = null, domain = solr.node, service url = null, agent id = null] for registry solr.node / com.codahale.metrics.MetricRegistry@40a9b1c0
   [junit4]   2> 178309 T60 oasm.SolrMetricManager.closeReporters Closing metric reporters for registry=solr.jvm, tag=null
   [junit4]   2> 178309 T60 oasmr.SolrJmxReporter.close Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@186dc455: rootName = null, domain = solr.jvm, service url = null, agent id = null] for registry solr.jvm / com.codahale.metrics.MetricRegistry@4902260e
   [junit4]   2> 178334 T60 oasm.SolrMetricManager.closeReporters Closing metric reporters for registry=solr.jetty, tag=null
   [junit4]   2> 178334 T60 oasmr.SolrJmxReporter.close Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@433a5d3b: rootName = null, domain = solr.jetty, service url = null, agent id = null] for registry solr.jetty / com.codahale.metrics.MetricRegistry@338dcc04
   [junit4]   2> 178427 T102 x:x:collection1 oasc.SolrCore.close [collection1]  CLOSING SolrCore org.apache.solr.core.SolrCore@5476653b
   [junit4]   2> 178427 T102 x:x:collection1 oasm.SolrMetricManager.closeReporters Closing metric reporters for registry=solr.core.collection1, tag=1417045307
   [junit4]   2> 178427 T102 x:x:collection1 oasmr.SolrJmxReporter.close Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@5b897581: rootName = null, domain = solr.core.collection1, service url = null, agent id = null] for registry solr.core.collection1 / com.codahale.metrics.MetricRegistry@5b84583a
   [junit4]   2> 178631 T60 oejsh.ContextHandler.doStop Stopped o.e.j.s.ServletContextHandler@133d9f2d{/solr,null,UNAVAILABLE}
   [junit4]   2> 178638 T60 oas.SolrTestCaseJ4.tearDown ###Ending testCommitWithin
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestContentStreamDataSource -Dtests.method=testCommitWithin -Dtests.seed=C84001AC4330ACF5 -Dtests.multiplier=2 -Dtests.slow=true -Dtests.locale=it-IT -Dtests.timezone=Europe/Nicosia -Dtests.asserts=true -Dtests.file.encoding=UTF-8
   [junit4] FAILURE 5.73s J1 | TestContentStreamDataSource.testCommitWithin <<<
   [junit4]    > Throwable #1: java.lang.AssertionError: expected:<0> but was:<2>
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([C84001AC4330ACF5:72926ED4C01E42E0]:0)
   [junit4]    > 	at org.apache.solr.handler.dataimport.TestContentStreamDataSource.testCommitWithin(TestContentStreamDataSource.java:98)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> NOTE: leaving temporary files on disk at: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/contrib/solr-dataimporthandler/test/J1/temp/solr.handler.dataimport.TestContentStreamDataSource_C84001AC4330ACF5-001
   [junit4]   2> NOTE: test params are: codec=DummyCompressingStoredFields(storedFieldsFormat=CompressingStoredFieldsFormat(compressionMode=DUMMY, chunkSize=7, maxDocsPerChunk=1003, blockSize=599), termVectorsFormat=CompressingTermVectorsFormat(compressionMode=DUMMY, chunkSize=7, blockSize=599)), sim=RandomSimilarity(queryNorm=true): {}, locale=it-IT, timezone=Europe/Nicosia
   [junit4]   2> NOTE: Linux 3.13.0-88-generic amd64/Oracle Corporation 1.8.0_144 (64-bit)/cpus=4,threads=1,free=309185160,total=358612992
   [junit4]   2> NOTE: All tests run in this JVM: [TestEntityProcessorBase, TestScriptTransformer, TestFileListWithLineEntityProcessor, TestNestedChildren, TestTemplateTransformer, TestJdbcDataSourceConvertType, TestFileListEntityProcessor, TestXPathRecordReader, TestSqlEntityProcessorDelta, TestContentStreamDataSource]
   [junit4] Completed [24/38 (1!)] on J1 in 28.17s, 2 tests, 1 failure <<< FAILURES!

[...truncated 41842 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 17 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/17/

2 tests failed.
FAILED:  org.apache.solr.cloud.TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateSearchDelete

Error Message:
Error from server at https://127.0.0.1:37405/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html> <head> <meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/> <title>Error 404 </title> </head> <body> <h2>HTTP ERROR: 404</h2> <p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason: <pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p> <hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/> </body> </html> 

Stack Trace:
org.apache.solr.client.solrj.impl.CloudSolrClient$RouteException: Error from server at https://127.0.0.1:37405/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason:
<pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at __randomizedtesting.SeedInfo.seed([BE120274C2DB52EB:1DE8ACD14533B84E]:0)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.directUpdate(CloudSolrClient.java:549)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1012)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.request.UpdateRequest.commit(UpdateRequest.java:233)
	at org.apache.solr.cloud.TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateSearchDelete(TestCollectionsAPIViaSolrCloudCluster.java:167)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at https://127.0.0.1:37405/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason:
<pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:607)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.lambda$directUpdate$0(CloudSolrClient.java:526)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	... 1 more


FAILED:  org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest.testHistory

Error Message:
expected:<8> but was:<10>

Stack Trace:
java.lang.AssertionError: expected:<8> but was:<10>
	at __randomizedtesting.SeedInfo.seed([BE120274C2DB52EB:D3EEA6897893ADEC]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest.testHistory(AutoscalingHistoryHandlerTest.java:259)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 12294 lines...]
   [junit4] Suite: org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/init-core-data-001
   [junit4]   2> 2473976 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 2473977 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (false) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 2473977 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 2473978 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 3 servers in /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001
   [junit4]   2> 2473978 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 2474011 INFO  (Thread-815) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 2474011 INFO  (Thread-815) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 2474068 ERROR (Thread-815) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 2474121 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:36036
   [junit4]   2> 2474202 INFO  (zkConnectionManagerCallback-927-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474231 INFO  (jetty-launcher-924-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2474276 INFO  (jetty-launcher-924-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2474296 INFO  (jetty-launcher-924-thread-3) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2474332 INFO  (jetty-launcher-924-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@4ad46057{/solr,null,AVAILABLE}
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@5e21ccfb{HTTP/1.1,[http/1.1]}{127.0.0.1:35741}
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.e.j.s.Server Started @2490842ms
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=35741}
   [junit4]   2> 2474334 ERROR (jetty-launcher-924-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2474334 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-20T15:55:13.871Z
   [junit4]   2> 2474451 INFO  (jetty-launcher-924-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@498bf54d{/solr,null,AVAILABLE}
   [junit4]   2> 2474451 INFO  (jetty-launcher-924-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@3924af1f{HTTP/1.1,[http/1.1]}{127.0.0.1:39834}
   [junit4]   2> 2474451 INFO  (jetty-launcher-924-thread-1) [    ] o.e.j.s.Server Started @2490960ms
   [junit4]   2> 2474451 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=39834}
   [junit4]   2> 2474451 ERROR (jetty-launcher-924-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2474452 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 2474452 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2474452 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2474452 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-20T15:55:13.989Z
   [junit4]   2> 2474472 INFO  (zkConnectionManagerCallback-931-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474597 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2474624 INFO  (zkConnectionManagerCallback-929-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474625 INFO  (jetty-launcher-924-thread-3) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@54211782{/solr,null,AVAILABLE}
   [junit4]   2> 2474625 INFO  (jetty-launcher-924-thread-3) [    ] o.e.j.s.AbstractConnector Started ServerConnector@6629fc4{HTTP/1.1,[http/1.1]}{127.0.0.1:44645}
   [junit4]   2> 2474625 INFO  (jetty-launcher-924-thread-3) [    ] o.e.j.s.Server Started @2491134ms
   [junit4]   2> 2474625 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=44645}
   [junit4]   2> 2474625 ERROR (jetty-launcher-924-thread-3) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2474626 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 2474626 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2474626 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2474626 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-20T15:55:14.163Z
   [junit4]   2> 2474649 INFO  (zkConnectionManagerCallback-933-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474744 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2474750 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2474796 INFO  (jetty-launcher-924-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:36036/solr
   [junit4]   2> 2474820 INFO  (jetty-launcher-924-thread-3) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:36036/solr
   [junit4]   2> 2474880 INFO  (zkConnectionManagerCallback-941-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474940 INFO  (zkConnectionManagerCallback-943-thread-1-processing-n:127.0.0.1:44645_solr) [n:127.0.0.1:44645_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474948 INFO  (zkConnectionManagerCallback-937-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2474957 INFO  (jetty-launcher-924-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:36036/solr
   [junit4]   2> 2474990 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16074a2c9210004, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2475055 INFO  (zkConnectionManagerCallback-947-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2475127 INFO  (zkConnectionManagerCallback-949-thread-1-processing-n:127.0.0.1:39834_solr) [n:127.0.0.1:39834_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2475131 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16074a2c9210007, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2475164 INFO  (zkConnectionManagerCallback-951-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2475626 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2475627 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:35741_solr
   [junit4]   2> 2475661 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer Overseer (id=99207434310057993-127.0.0.1:35741_solr-n_0000000000) starting
   [junit4]   2> 2475754 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer Starting to work on the main queue
   [junit4]   2> 2475770 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:35741_solr
   [junit4]   2> 2475803 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 2475803 INFO  (zkCallback-950-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2475839 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 1
   [junit4]   2> 2475859 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: [127.0.0.1:35741_solr]
   [junit4]   2> 2475860 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion -1
   [junit4]   2> 2475860 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 1
   [junit4]   2> 2475989 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 2476050 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35741.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2476065 DEBUG (OverseerAutoScalingTriggerThread-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion 1
   [junit4]   2> 2476100 DEBUG (ScheduledTrigger-2167-thread-1) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35741_solr]
   [junit4]   2> 2476175 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35741.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2476175 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35741.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2476176 INFO  (jetty-launcher-924-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/.
   [junit4]   2> 2477180 DEBUG (ScheduledTrigger-2167-thread-1) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35741_solr]
   [junit4]   2> 2477890 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2477892 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2477910 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:44645_solr
   [junit4]   2> 2478023 INFO  (zkCallback-950-thread-2-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 2478043 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "operation":"downnode",
   [junit4]   2>   "node_name":"127.0.0.1:44645_solr"} current state version: 0
   [junit4]   2> 2478043 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.NodeMutator DownNode state invoked for node: 127.0.0.1:44645_solr
   [junit4]   2> 2478043 INFO  (zkCallback-942-thread-1-processing-n:127.0.0.1:44645_solr) [n:127.0.0.1:44645_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 2478190 DEBUG (ScheduledTrigger-2167-thread-2) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35741_solr, 127.0.0.1:44645_solr]
   [junit4]   2> 2478209 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_44645.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2478246 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_44645.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2478246 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_44645.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2478263 INFO  (jetty-launcher-924-thread-3) [n:127.0.0.1:44645_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/.
   [junit4]   2> 2478703 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 2478705 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2478719 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:39834_solr
   [junit4]   2> 2478767 INFO  (zkCallback-942-thread-1-processing-n:127.0.0.1:44645_solr) [n:127.0.0.1:44645_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 2478779 INFO  (zkCallback-950-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 2478873 INFO  (zkCallback-948-thread-1-processing-n:127.0.0.1:39834_solr) [n:127.0.0.1:39834_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 2478898 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "operation":"downnode",
   [junit4]   2>   "node_name":"127.0.0.1:39834_solr"} current state version: 0
   [junit4]   2> 2478898 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.NodeMutator DownNode state invoked for node: 127.0.0.1:39834_solr
   [junit4]   2> 2479070 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39834.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2479106 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39834.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2479106 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39834.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@71883934
   [junit4]   2> 2479107 INFO  (jetty-launcher-924-thread-1) [n:127.0.0.1:39834_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/.
   [junit4]   2> 2479256 DEBUG (ScheduledTrigger-2167-thread-1) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35741_solr, 127.0.0.1:39834_solr, 127.0.0.1:44645_solr]
   [junit4]   2> 2479341 INFO  (zkConnectionManagerCallback-957-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2479366 INFO  (zkConnectionManagerCallback-961-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2479368 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 2479368 INFO  (SUITE-AutoscalingHistoryHandlerTest-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:36036/solr ready
   [junit4]   2> 2479420 INFO  (qtp582188004-4354) [n:127.0.0.1:35741_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=3&name=AutoscalingHistoryHandlerTest_collection&nrtReplicas=3&action=CREATE&numShards=1&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 2479422 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.CreateCollectionCmd Create collection AutoscalingHistoryHandlerTest_collection
   [junit4]   2> 2479422 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.CreateCollectionCmd Only _default config set found, using it.
   [junit4]   2> 2479439 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/protwords.txt to /configs/AutoscalingHistoryHandlerTest_collection/protwords.txt
   [junit4]   2> 2479441 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/managed-schema to /configs/AutoscalingHistoryHandlerTest_collection/managed-schema
   [junit4]   2> 2479455 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/solrconfig.xml to /configs/AutoscalingHistoryHandlerTest_collection/solrconfig.xml
   [junit4]   2> 2479457 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/synonyms.txt to /configs/AutoscalingHistoryHandlerTest_collection/synonyms.txt
   [junit4]   2> 2479458 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/stopwords.txt to /configs/AutoscalingHistoryHandlerTest_collection/stopwords.txt
   [junit4]   2> 2479476 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/params.json to /configs/AutoscalingHistoryHandlerTest_collection/params.json
   [junit4]   2> 2479477 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_it.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_it.txt
   [junit4]   2> 2479478 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_no.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_no.txt
   [junit4]   2> 2479493 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_hy.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_hy.txt
   [junit4]   2> 2479494 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stemdict_nl.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stemdict_nl.txt
   [junit4]   2> 2479495 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_ca.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_ca.txt
   [junit4]   2> 2479509 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_id.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_id.txt
   [junit4]   2> 2479510 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ga.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ga.txt
   [junit4]   2> 2479511 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_da.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_da.txt
   [junit4]   2> 2479531 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_hi.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_hi.txt
   [junit4]   2> 2479532 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ja.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ja.txt
   [junit4]   2> 2479549 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_pt.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_pt.txt
   [junit4]   2> 2479551 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_hu.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_hu.txt
   [junit4]   2> 2479552 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_el.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_el.txt
   [junit4]   2> 2479565 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ru.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ru.txt
   [junit4]   2> 2479566 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_tr.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_tr.txt
   [junit4]   2> 2479567 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ar.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ar.txt
   [junit4]   2> 2479568 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/userdict_ja.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/userdict_ja.txt
   [junit4]   2> 2479582 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_it.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_it.txt
   [junit4]   2> 2479583 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_eu.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_eu.txt
   [junit4]   2> 2479584 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_cz.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_cz.txt
   [junit4]   2> 2479602 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stoptags_ja.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stoptags_ja.txt
   [junit4]   2> 2479603 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_fr.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_fr.txt
   [junit4]   2> 2479604 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_fa.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_fa.txt
   [junit4]   2> 2479605 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_de.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_de.txt
   [junit4]   2> 2479618 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/contractions_ga.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/contractions_ga.txt
   [junit4]   2> 2479619 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ca.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ca.txt
   [junit4]   2> 2479620 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_nl.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_nl.txt
   [junit4]   2> 2479621 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_bg.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_bg.txt
   [junit4]   2> 2479638 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_es.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_es.txt
   [junit4]   2> 2479640 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_en.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_en.txt
   [junit4]   2> 2479641 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_lv.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_lv.txt
   [junit4]   2> 2479642 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_th.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_th.txt
   [junit4]   2> 2479660 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_ro.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_ro.txt
   [junit4]   2> 2479661 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_fr.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_fr.txt
   [junit4]   2> 2479675 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_sv.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_sv.txt
   [junit4]   2> 2479676 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_fi.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_fi.txt
   [junit4]   2> 2479677 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/hyphenations_ga.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/hyphenations_ga.txt
   [junit4]   2> 2479695 INFO  (OverseerThreadFactory-2169-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkConfigManager Copying zk node /configs/_default/lang/stopwords_gl.txt to /configs/AutoscalingHistoryHandlerTest_collection/lang/stopwords_gl.txt
   [junit4]   2> 2479699 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "name":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "fromApi":"true",
   [junit4]   2>   "replicationFactor":"3",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "nrtReplicas":"3",
   [junit4]   2>   "stateFormat":"2",
   [junit4]   2>   "operation":"create"} current state version: 0
   [junit4]   2> 2479731 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ClusterStateMutator building a new cName: AutoscalingHistoryHandlerTest_collection
   [junit4]   2> 2479735 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ZkStateWriter going to create_collection /collections/AutoscalingHistoryHandlerTest_collection/state.json
   [junit4]   2> 2479807 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} current state version: 0
   [junit4]   2> 2479807 INFO  (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2479858 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator Old Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{}}
   [junit4]   2> 2479858 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator New Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{"core_node3":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 2479859 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 2, message = {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} current state version: 0
   [junit4]   2> 2479859 INFO  (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2479860 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator Old Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{"core_node3":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 2479860 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator New Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{
   [junit4]   2>     "core_node3":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"},
   [junit4]   2>     "core_node5":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>       "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 2479861 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 3, message = {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} current state version: 0
   [junit4]   2> 2479892 INFO  (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2479963 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator Old Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{
   [junit4]   2>     "core_node3":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"},
   [junit4]   2>     "core_node5":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>       "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 2479963 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.SliceMutator New Slice: shard1:{
   [junit4]   2>   "range":"80000000-7fffffff",
   [junit4]   2>   "state":"active",
   [junit4]   2>   "replicas":{
   [junit4]   2>     "core_node3":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>       "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"},
   [junit4]   2>     "core_node5":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>       "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"},
   [junit4]   2>     "core_node6":{
   [junit4]   2>       "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>       "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>       "state":"down",
   [junit4]   2>       "node_name":null,
   [junit4]   2>       "type":"NRT"}}}
   [junit4]   2> 2480109 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ZkStateWriter going to update_collection /collections/AutoscalingHistoryHandlerTest_collection/state.json version: 0
   [junit4]   2> 2480252 INFO  (qtp582188004-4352) [n:127.0.0.1:35741_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node3&collection.configName=AutoscalingHistoryHandlerTest_collection&newCollection=true&name=AutoscalingHistoryHandlerTest_collection_shard1_replica_n1&action=CREATE&numShards=1&collection=AutoscalingHistoryHandlerTest_collection&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2480253 INFO  (qtp582188004-4352) [n:127.0.0.1:35741_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2480253 INFO  (qtp571993283-4362) [n:127.0.0.1:39834_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node6&collection.configName=AutoscalingHistoryHandlerTest_collection&newCollection=true&name=AutoscalingHistoryHandlerTest_collection_shard1_replica_n4&action=CREATE&numShards=1&collection=AutoscalingHistoryHandlerTest_collection&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2480254 INFO  (qtp571993283-4362) [n:127.0.0.1:39834_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2480289 INFO  (qtp298377182-4374) [n:127.0.0.1:44645_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node5&collection.configName=AutoscalingHistoryHandlerTest_collection&newCollection=true&name=AutoscalingHistoryHandlerTest_collection_shard1_replica_n2&action=CREATE&numShards=1&collection=AutoscalingHistoryHandlerTest_collection&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2480289 INFO  (qtp298377182-4374) [n:127.0.0.1:44645_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2480356 DEBUG (ScheduledTrigger-2167-thread-1) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35741_solr, 127.0.0.1:39834_solr, 127.0.0.1:44645_solr]
   [junit4]   2> 2480427 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 1, message = {
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>   "core_node_name":"core_node5",
   [junit4]   2>   "roles":null,
   [junit4]   2>   "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>   "node_name":"127.0.0.1:44645_solr",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "operation":"state"} current state version: 0
   [junit4]   2> 2480427 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Update state numShards=1 message={
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>   "core_node_name":"core_node5",
   [junit4]   2>   "roles":null,
   [junit4]   2>   "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>   "node_name":"127.0.0.1:44645_solr",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "operation":"state"}
   [junit4]   2> 2480427 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Will update state for replica: core_node5:{"core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2","base_url":"http://127.0.0.1:44645/solr","node_name":"127.0.0.1:44645_solr","state":"down","type":"NRT"}
   [junit4]   2> 2480427 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Collection is now: DocCollection(AutoscalingHistoryHandlerTest_collection//collections/AutoscalingHistoryHandlerTest_collection/state.json/1)={
   [junit4]   2>   "pullReplicas":"0",
   [junit4]   2>   "replicationFactor":"3",
   [junit4]   2>   "router":{"name":"compositeId"},
   [junit4]   2>   "maxShardsPerNode":"1",
   [junit4]   2>   "autoAddReplicas":"false",
   [junit4]   2>   "nrtReplicas":"3",
   [junit4]   2>   "tlogReplicas":"0",
   [junit4]   2>   "shards":{"shard1":{
   [junit4]   2>       "range":"80000000-7fffffff",
   [junit4]   2>       "state":"active",
   [junit4]   2>       "replicas":{
   [junit4]   2>         "core_node3":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>           "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "node_name":null,
   [junit4]   2>           "type":"NRT"},
   [junit4]   2>         "core_node5":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>           "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>           "node_name":"127.0.0.1:44645_solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "type":"NRT"},
   [junit4]   2>         "core_node6":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>           "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "node_name":null,
   [junit4]   2>           "type":"NRT"}}}}}
   [junit4]   2> 2480480 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 2, message = {
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>   "core_node_name":"core_node3",
   [junit4]   2>   "roles":null,
   [junit4]   2>   "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>   "node_name":"127.0.0.1:35741_solr",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "operation":"state"} current state version: 0
   [junit4]   2> 2480480 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Update state numShards=1 message={
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>   "core_node_name":"core_node3",
   [junit4]   2>   "roles":null,
   [junit4]   2>   "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>   "node_name":"127.0.0.1:35741_solr",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "operation":"state"}
   [junit4]   2> 2480480 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Will update state for replica: core_node3:{"core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1","base_url":"http://127.0.0.1:35741/solr","node_name":"127.0.0.1:35741_solr","state":"down","type":"NRT"}
   [junit4]   2> 2480480 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Collection is now: DocCollection(AutoscalingHistoryHandlerTest_collection//collections/AutoscalingHistoryHandlerTest_collection/state.json/1)={
   [junit4]   2>   "pullReplicas":"0",
   [junit4]   2>   "replicationFactor":"3",
   [junit4]   2>   "router":{"name":"compositeId"},
   [junit4]   2>   "maxShardsPerNode":"1",
   [junit4]   2>   "autoAddReplicas":"false",
   [junit4]   2>   "nrtReplicas":"3",
   [junit4]   2>   "tlogReplicas":"0",
   [junit4]   2>   "shards":{"shard1":{
   [junit4]   2>       "range":"80000000-7fffffff",
   [junit4]   2>       "state":"active",
   [junit4]   2>       "replicas":{
   [junit4]   2>         "core_node3":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>           "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>           "node_name":"127.0.0.1:35741_solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "type":"NRT"},
   [junit4]   2>         "core_node5":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>           "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>           "node_name":"127.0.0.1:44645_solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "type":"NRT"},
   [junit4]   2>         "core_node6":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>           "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "node_name":null,
   [junit4]   2>           "type":"NRT"}}}}}
   [junit4]   2> 2480516 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.Overseer processMessage: queueSize: 3, message = {
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>   "core_node_name":"core_node6",
   [junit4]   2>   "roles":null,
   [junit4]   2>   "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>   "node_name":"127.0.0.1:39834_solr",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "operation":"state"} current state version: 0
   [junit4]   2> 2480516 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Update state numShards=1 message={
   [junit4]   2>   "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>   "core_node_name":"core_node6",
   [junit4]   2>   "roles":null,
   [junit4]   2>   "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>   "node_name":"127.0.0.1:39834_solr",
   [junit4]   2>   "numShards":"1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "collection":"AutoscalingHistoryHandlerTest_collection",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "operation":"state"}
   [junit4]   2> 2480516 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Will update state for replica: core_node6:{"core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4","base_url":"http://127.0.0.1:39834/solr","node_name":"127.0.0.1:39834_solr","state":"down","type":"NRT"}
   [junit4]   2> 2480516 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ReplicaMutator Collection is now: DocCollection(AutoscalingHistoryHandlerTest_collection//collections/AutoscalingHistoryHandlerTest_collection/state.json/1)={
   [junit4]   2>   "pullReplicas":"0",
   [junit4]   2>   "replicationFactor":"3",
   [junit4]   2>   "router":{"name":"compositeId"},
   [junit4]   2>   "maxShardsPerNode":"1",
   [junit4]   2>   "autoAddReplicas":"false",
   [junit4]   2>   "nrtReplicas":"3",
   [junit4]   2>   "tlogReplicas":"0",
   [junit4]   2>   "shards":{"shard1":{
   [junit4]   2>       "range":"80000000-7fffffff",
   [junit4]   2>       "state":"active",
   [junit4]   2>       "replicas":{
   [junit4]   2>         "core_node3":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n1",
   [junit4]   2>           "base_url":"http://127.0.0.1:35741/solr",
   [junit4]   2>           "node_name":"127.0.0.1:35741_solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "type":"NRT"},
   [junit4]   2>         "core_node5":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n2",
   [junit4]   2>           "base_url":"http://127.0.0.1:44645/solr",
   [junit4]   2>           "node_name":"127.0.0.1:44645_solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "type":"NRT"},
   [junit4]   2>         "core_node6":{
   [junit4]   2>           "core":"AutoscalingHistoryHandlerTest_collection_shard1_replica_n4",
   [junit4]   2>           "base_url":"http://127.0.0.1:39834/solr",
   [junit4]   2>           "node_name":"127.0.0.1:39834_solr",
   [junit4]   2>           "state":"down",
   [junit4]   2>           "type":"NRT"}}}}}
   [junit4]   2> 2480647 DEBUG (OverseerStateUpdate-99207434310057993-127.0.0.1:35741_solr-n_0000000000) [n:127.0.0.1:35741_solr    ] o.a.s.c.o.ZkStateWriter going to update_collection /collections/AutoscalingHistoryHandlerTest_collection/state.json version: 1
   [junit4]   2> 2480679 INFO  (zkCallback-948-thread-1-processing-n:127.0.0.1:39834_solr) [n:127.0.0.1:39834_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/AutoscalingHistoryHandlerTest_collection/state.json] for collection [AutoscalingHistoryHandlerTest_collection] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2480679 INFO  (zkCallback-942-thread-1-processing-n:127.0.0.1:44645_solr) [n:127.0.0.1:44645_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/AutoscalingHistoryHandlerTest_collection/state.json] for collection [AutoscalingHistoryHandlerTest_collection] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2480680 INFO  (zkCallback-950-thread-1-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/AutoscalingHistoryHandlerTest_collection/state.json] for collection [AutoscalingHistoryHandlerTest_collection] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2480680 INFO  (zkCallback-950-thread-2-processing-n:127.0.0.1:35741_solr) [n:127.0.0.1:35741_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/AutoscalingHistoryHandlerTest_collection/state.json] for collection [AutoscalingHistoryHandlerTest_collection] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2480695 INFO  (zkCallback-948-thread-2-processing-n:127.0.0.1:39834_solr) [n:127.0.0.1:39834_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/AutoscalingHistoryHandlerTest_collection/state.json] for collection [AutoscalingHistoryHandlerTest_collection] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2480708 INFO  (zkCallback-942-thread-2-processing-n:127.0.0.1:44645_solr) [n:127.0.0.1:44645_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/AutoscalingHistoryHandlerTest_collection/state.json] for collection [AutoscalingHistoryHandlerTest_collection] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2481370 DEBUG (ScheduledTrigger-2167-thread-1) [n:127.0.0.1:35741_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35741_solr, 127.0.0.1:39834_solr, 127.0.0.1:44645_solr]
   [junit4]   2> 2481448 INFO  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.RequestParams conf resource params.json loaded . version : 0 
   [junit4]   2> 2481486 INFO  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.RequestParams request params refreshed to version 0
   [junit4]   2> 2481487 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/extraction/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/extraction/lib
   [junit4]   2> 2481522 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist filtered by solr-cell-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist
   [junit4]   2> 2481523 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/clustering/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/clustering/lib
   [junit4]   2> 2481523 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist filtered by solr-clustering-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist
   [junit4]   2> 2481523 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/langid/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/langid/lib
   [junit4]   2> 2481523 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist filtered by solr-langid-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist
   [junit4]   2> 2481523 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/velocity/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../contrib/velocity/lib
   [junit4]   2> 2481524 WARN  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist filtered by solr-velocity-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node3/AutoscalingHistoryHandlerTest_collection_shard1_replica_n2/../../../../dist
   [junit4]   2> 2481559 INFO  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 2481760 INFO  (qtp298377182-4374) [n:127.0.0.1:44645_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node5 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] o.a.s.s.IndexSchema [AutoscalingHistoryHandlerTest_collection_shard1_replica_n2] Schema name=default-config
   [junit4]   2> 2481778 INFO  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.RequestParams conf resource params.json loaded . version : 0 
   [junit4]   2> 2481830 INFO  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.RequestParams request params refreshed to version 0
   [junit4]   2> 2481831 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/extraction/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/extraction/lib
   [junit4]   2> 2481831 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist filtered by solr-cell-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist
   [junit4]   2> 2481831 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/clustering/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/clustering/lib
   [junit4]   2> 2481832 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist filtered by solr-clustering-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist
   [junit4]   2> 2481832 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/langid/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/langid/lib
   [junit4]   2> 2481832 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist filtered by solr-langid-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist
   [junit4]   2> 2481832 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/velocity/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../contrib/velocity/lib
   [junit4]   2> 2481832 WARN  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist filtered by solr-velocity-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node2/AutoscalingHistoryHandlerTest_collection_shard1_replica_n1/../../../../dist
   [junit4]   2> 2481904 INFO  (qtp582188004-4352) [n:127.0.0.1:35741_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node3 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n1] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 2481936 INFO  (qtp571993283-4362) [n:127.0.0.1:39834_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node6 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n4] o.a.s.c.RequestParams conf resource params.json loaded . version : 0 
   [junit4]   2> 2481936 INFO  (qtp571993283-4362) [n:127.0.0.1:39834_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node6 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n4] o.a.s.c.RequestParams request params refreshed to version 0
   [junit4]   2> 2481937 WARN  (qtp571993283-4362) [n:127.0.0.1:39834_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node6 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n4] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../contrib/extraction/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../contrib/extraction/lib
   [junit4]   2> 2481937 WARN  (qtp571993283-4362) [n:127.0.0.1:39834_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node6 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n4] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../dist filtered by solr-cell-\d.*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../dist
   [junit4]   2> 2481937 WARN  (qtp571993283-4362) [n:127.0.0.1:39834_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node6 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n4] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../contrib/clustering/lib filtered by .*\.jar to classpath: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../contrib/clustering/lib
   [junit4]   2> 2481937 WARN  (qtp571993283-4362) [n:127.0.0.1:39834_solr c:AutoscalingHistoryHandlerTest_collection s:shard1 r:core_node6 x:AutoscalingHistoryHandlerTest_collection_shard1_replica_n4] o.a.s.c.SolrConfig Couldn't add files from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.handler.admin.AutoscalingHistoryHandlerTest_BE120274C2DB52EB-001/tempDir-001/node1/AutoscalingHistoryHandlerTest_collection_shard1_replica_n4/../../../../dist filtered by solr-clustering-\d.*\.jar to

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

58_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (0)
   [junit4]   2> 3618553 INFO  (zkCallback-4768-thread-1-processing-n:127.0.0.1:45885_solr) [n:127.0.0.1:45885_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (0)
   [junit4]   2> 3618662 INFO  (zkCallback-4749-thread-1-processing-n:127.0.0.1:41903_solr) [n:127.0.0.1:41903_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (0)
   [junit4]   2> 3618663 INFO  (zkCallback-4740-thread-1-processing-n:127.0.0.1:42837_solr) [n:127.0.0.1:42837_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (0)
   [junit4]   2> 3618777 INFO  (jetty-closer-4676-thread-5) [    ] o.a.s.c.Overseer Overseer (id=99207506787631112-127.0.0.1:40196_solr-n_0000000004) closing
   [junit4]   2> 3618779 INFO  (coreCloseExecutor-4348-thread-1) [n:127.0.0.1:42837_solr c:testStopAllStartAllCollection s:shard1 r:core_node5 x:testStopAllStartAllCollection_shard1_replica_n2] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testStopAllStartAllCollection.shard1.leader, tag=267106482
   [junit4]   2> 3618789 WARN  (OverseerAutoScalingTriggerThread-99207506787631112-127.0.0.1:40196_solr-n_0000000004) [n:127.0.0.1:40196_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 3618998 INFO  (coreCloseExecutor-4349-thread-1) [n:127.0.0.1:45885_solr c:testStopAllStartAllCollection s:shard2 r:core_node8 x:testStopAllStartAllCollection_shard2_replica_n6] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testStopAllStartAllCollection.shard2.leader, tag=917326857
   [junit4]   2> 3618976 INFO  (OverseerStateUpdate-99207506787631112-127.0.0.1:40196_solr-n_0000000004) [n:127.0.0.1:40196_solr    ] o.a.s.c.Overseer Overseer Loop exiting : 127.0.0.1:40196_solr
   [junit4]   2> 3619254 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16074b3a9210017, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 3619493 INFO  (jetty-closer-4676-thread-3) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@34f18e25{/solr,null,UNAVAILABLE}
   [junit4]   2> 3619546 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16074b3a921001a, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 3619551 INFO  (jetty-closer-4676-thread-5) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@4b144a81{/solr,null,UNAVAILABLE}
   [junit4]   2> 3619752 INFO  (zkCallback-4768-thread-2-processing-n:127.0.0.1:45885_solr) [n:127.0.0.1:45885_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:45885_solr
   [junit4]   2> 3620803 INFO  (jetty-closer-4676-thread-1) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@ea7543e{/solr,null,UNAVAILABLE}
   [junit4]   2> 3621176 INFO  (jetty-closer-4676-thread-2) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@441411a3{/solr,null,UNAVAILABLE}
   [junit4]   2> 3621262 INFO  (jetty-closer-4676-thread-4) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@d761cf7{/solr,null,UNAVAILABLE}
   [junit4]   2> 3621264 ERROR (TEST-TestCollectionsAPIViaSolrCloudCluster.testStopAllStartAll-seed#[BE120274C2DB52EB]) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 3621264 INFO  (TEST-TestCollectionsAPIViaSolrCloudCluster.testStopAllStartAll-seed#[BE120274C2DB52EB]) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:44712 44712
   [junit4]   2> 3621505 INFO  (Thread-6299) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:44712 44712
   [junit4]   2> 3621506 WARN  (Thread-6299) [    ] o.a.s.c.ZkTestServer Watch limit violations: 
   [junit4]   2> Maximum concurrent create/delete watches above limit:
   [junit4]   2> 
   [junit4]   2> 	10	/solr/aliases.json
   [junit4]   2> 	9	/solr/security.json
   [junit4]   2> 	8	/solr/configs/solrCloudCollectionConfig
   [junit4]   2> 
   [junit4]   2> Maximum concurrent data watches above limit:
   [junit4]   2> 
   [junit4]   2> 	107	/solr/collections/testStopAllStartAllCollection/state.json
   [junit4]   2> 	10	/solr/clusterprops.json
   [junit4]   2> 	10	/solr/clusterstate.json
   [junit4]   2> 	3	/solr/overseer_elect/election/99207506787631119-127.0.0.1:46189_solr-n_0000000001
   [junit4]   2> 	3	/solr/autoscaling.json
   [junit4]   2> 	2	/solr/overseer_elect/election/99207506787631112-127.0.0.1:40196_solr-n_0000000004
   [junit4]   2> 
   [junit4]   2> Maximum concurrent children watches above limit:
   [junit4]   2> 
   [junit4]   2> 	10	/solr/live_nodes
   [junit4]   2> 	10	/solr/collections
   [junit4]   2> 	3	/solr/autoscaling/events/.auto_add_replicas
   [junit4]   2> 	3	/solr/overseer/collection-queue-work
   [junit4]   2> 	3	/solr/overseer/queue-work
   [junit4]   2> 	2	/solr/overseer/queue
   [junit4]   2> 
   [junit4]   2> 3621506 INFO  (TEST-TestCollectionsAPIViaSolrCloudCluster.testStopAllStartAll-seed#[BE120274C2DB52EB]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testStopAllStartAll
   [junit4]   2> 3621507 INFO  (SUITE-TestCollectionsAPIViaSolrCloudCluster-seed#[BE120274C2DB52EB]-worker) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:44712 44712
   [junit4]   2> NOTE: leaving temporary files on disk at: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.TestCollectionsAPIViaSolrCloudCluster_BE120274C2DB52EB-001
   [junit4]   2> Dec 20, 2017 4:14:17 PM com.carrotsearch.randomizedtesting.ThreadLeakControl checkThreadLeaks
   [junit4]   2> WARNING: Will linger awaiting termination of 1 leaked thread(s).
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70): {_version_=PostingsFormat(name=LuceneVarGapDocFreqInterval), id=PostingsFormat(name=LuceneVarGapFixedInterval)}, docValues:{_version_=DocValuesFormat(name=Memory)}, maxPointsInLeafNode=1757, maxMBSortInHeap=5.984636811161495, sim=RandomSimilarity(queryNorm=true): {}, locale=fr-FR, timezone=Africa/Malabo
   [junit4]   2> NOTE: Linux 4.4.0-83-generic amd64/Oracle Corporation 1.8.0_152 (64-bit)/cpus=4,threads=1,free=283004856,total=521666560
   [junit4]   2> NOTE: All tests run in this JVM: [TestRawTransformer, TestPullReplica, RequestLoggingTest, HdfsThreadLeakTest, TestMiniSolrCloudClusterSSL, SortByFunctionTest, PluginInfoTest, SearchRateTriggerTest, DefaultValueUpdateProcessorTest, TestSolrCoreProperties, CdcrRequestHandlerTest, AddBlockUpdateTest, TestExtendedDismaxParser, AsyncCallRequestStatusResponseTest, ZkNodePropsTest, DistributedDebugComponentTest, BigEndianAscendingWordDeserializerTest, TestSchemaNameResource, HdfsCollectionsAPIDistributedZkTest, RecoveryZkTest, HdfsRecoveryZkTest, TestDistributedStatsComponentCardinality, TestNumericTerms32, EchoParamsTest, TestFunctionQuery, WordBreakSolrSpellCheckerTest, TestDFISimilarityFactory, MoveReplicaHDFSTest, TestExportWriter, TestSolrXml, AutoAddReplicasIntegrationTest, AlternateDirectoryTest, AliasIntegrationTest, SuggesterWFSTTest, TestReplicationHandlerBackup, HdfsWriteToMultipleCollectionsTest, TestSolrConfigHandlerConcurrent, CopyFieldTest, DisMaxRequestHandlerTest, TestPayloadScoreQParserPlugin, TestSmileRequest, TestSolrCloudWithHadoopAuthPlugin, TestConfigOverlay, SolrJmxReporterTest, TestMaxScoreQueryParser, HdfsDirectoryFactoryTest, DistributedQueryComponentOptimizationTest, TestJavabinTupleStreamParser, ScriptEngineTest, FullSolrCloudDistribCmdsTest, TestSearchPerf, RequiredFieldsTest, SystemInfoHandlerTest, TestTestInjection, TestQueryTypes, TestSolrDeletionPolicy2, TestPivotHelperCode, ExplicitHLLTest, TestLeaderInitiatedRecoveryThread, SuggesterTest, IndexBasedSpellCheckerTest, TestChildDocTransformer, LargeFieldTest, TestSQLHandler, AnalyticsMergeStrategyTest, TestLegacyTerms, TestSubQueryTransformerDistrib, TestTolerantUpdateProcessorRandomCloud, CdcrBootstrapTest, HighlighterMaxOffsetTest, IgnoreCommitOptimizeUpdateProcessorFactoryTest, TestTolerantSearch, CurrencyFieldTypeTest, LeaderElectionTest, AtomicUpdatesTest, TestRestManager, TriggerIntegrationTest, TestPartialUpdateDeduplication, TestScoreJoinQPNoScore, TestTrieFacet, DocValuesNotIndexedTest, TestConfigReload, TestReloadDeadlock, HdfsBasicDistributedZkTest, DistanceUnitsTest, TestCloudSearcherWarming, TestManagedStopFilterFactory, SpatialHeatmapFacetsTest, TestHashPartitioner, TestIndexSearcher, ZkStateReaderTest, SpellPossibilityIteratorTest, TestHashQParserPlugin, TestAuthorizationFramework, TestInitParams, TestCSVResponseWriter, TestFieldCacheReopen, TestFiltering, FieldMutatingUpdateProcessorTest, ReplicationFactorTest, TestComplexPhraseLeadingWildcard, FileBasedSpellCheckerTest, TestCharFilters, TestShardHandlerFactory, DirectSolrConnectionTest, SolrGangliaReporterTest, TestHdfsCloudBackupRestore, ResponseHeaderTest, ComputePlanActionTest, TestSystemIdResolver, LeaderElectionContextKeyTest, IndexSchemaTest, TestCollectionsAPIViaSolrCloudCluster]
   [junit4] Completed [350/751 (2!)] on J2 in 76.22s, 3 tests, 1 error <<< FAILURES!

[...truncated 48663 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 16 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/16/

6 tests failed.
FAILED:  org.apache.solr.client.solrj.io.stream.StreamExpressionTest.testExecutorStream

Error Message:


Stack Trace:
java.lang.AssertionError
	at __randomizedtesting.SeedInfo.seed([66FE22CE21FF6F26:443EA33502954536]:0)
	at org.junit.Assert.fail(Assert.java:92)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.junit.Assert.assertTrue(Assert.java:54)
	at org.apache.solr.client.solrj.io.stream.StreamExpressionTest.testExecutorStream(StreamExpressionTest.java:8443)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  junit.framework.TestSuite.org.apache.solr.client.solrj.io.stream.StreamExpressionTest

Error Message:
11 threads leaked from SUITE scope at org.apache.solr.client.solrj.io.stream.StreamExpressionTest:     1) Thread[id=292, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    2) Thread[id=298, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    3) Thread[id=299, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    4) Thread[id=3091, name=zkConnectionManagerCallback-65-thread-1-EventThread, state=WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)    5) Thread[id=3090, name=zkConnectionManagerCallback-65-thread-1-SendThread(127.0.0.1:41014), state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1051)    6) Thread[id=295, name=zkConnectionManagerCallback-65-thread-1, state=WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    7) Thread[id=309, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    8) Thread[id=3089, name=zkCallback-64-thread-8, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    9) Thread[id=310, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)   10) Thread[id=4056, name=zkCallback-64-thread-9, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)   11) Thread[id=4057, name=zkCallback-64-thread-10, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: 11 threads leaked from SUITE scope at org.apache.solr.client.solrj.io.stream.StreamExpressionTest: 
   1) Thread[id=292, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   2) Thread[id=298, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   3) Thread[id=299, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   4) Thread[id=3091, name=zkConnectionManagerCallback-65-thread-1-EventThread, state=WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)
   5) Thread[id=3090, name=zkConnectionManagerCallback-65-thread-1-SendThread(127.0.0.1:41014), state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1051)
   6) Thread[id=295, name=zkConnectionManagerCallback-65-thread-1, state=WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   7) Thread[id=309, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   8) Thread[id=3089, name=zkCallback-64-thread-8, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   9) Thread[id=310, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
  10) Thread[id=4056, name=zkCallback-64-thread-9, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
  11) Thread[id=4057, name=zkCallback-64-thread-10, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([66FE22CE21FF6F26]:0)


FAILED:  junit.framework.TestSuite.org.apache.solr.client.solrj.io.stream.StreamExpressionTest

Error Message:
There are still zombie threads that couldn't be terminated:    1) Thread[id=3090, name=zkConnectionManagerCallback-65-thread-1-SendThread(127.0.0.1:41014), state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1051)    2) Thread[id=295, name=zkConnectionManagerCallback-65-thread-1, state=WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    3) Thread[id=3089, name=zkCallback-64-thread-8, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    4) Thread[id=4056, name=zkCallback-64-thread-9, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    5) Thread[id=4057, name=zkCallback-64-thread-10, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: There are still zombie threads that couldn't be terminated:
   1) Thread[id=3090, name=zkConnectionManagerCallback-65-thread-1-SendThread(127.0.0.1:41014), state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1051)
   2) Thread[id=295, name=zkConnectionManagerCallback-65-thread-1, state=WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   3) Thread[id=3089, name=zkCallback-64-thread-8, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   4) Thread[id=4056, name=zkCallback-64-thread-9, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   5) Thread[id=4057, name=zkCallback-64-thread-10, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([66FE22CE21FF6F26]:0)


FAILED:  org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testNodeMarkersRegistration

Error Message:
Path /autoscaling/nodeAdded/127.0.0.1:46816_solr wasn't created

Stack Trace:
java.lang.AssertionError: Path /autoscaling/nodeAdded/127.0.0.1:46816_solr wasn't created
	at __randomizedtesting.SeedInfo.seed([96A7310850DC1CAB:8E1DB9045EE9D144]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testNodeMarkersRegistration(TriggerIntegrationTest.java:931)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest.testHistory

Error Message:
Timed out wait for collection be active null Live Nodes: [127.0.0.1:33748_solr, 127.0.0.1:39940_solr, 127.0.0.1:45972_solr] Last available state: null

Stack Trace:
java.lang.AssertionError: Timed out wait for collection be active
null
Live Nodes: [127.0.0.1:33748_solr, 127.0.0.1:39940_solr, 127.0.0.1:45972_solr]
Last available state: null
	at __randomizedtesting.SeedInfo.seed([96A7310850DC1CAB:FB5B95F5EA94E3AC]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.SolrCloudTestCase.waitForState(SolrCloudTestCase.java:269)
	at org.apache.solr.handler.admin.AutoscalingHistoryHandlerTest.testHistory(AutoscalingHistoryHandlerTest.java:178)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.LeaderFailoverAfterPartitionTest.test

Error Message:
Expected 2 of 3 replicas to be active but only found 1; [core_node5:{"core":"c8n_1x3_lf_shard1_replica_n2","base_url":"http://127.0.0.1:41542/_/le","node_name":"127.0.0.1:41542__%2Fle","state":"active","type":"NRT","leader":"true"}]; clusterState: DocCollection(c8n_1x3_lf//collections/c8n_1x3_lf/state.json/17)={   "pullReplicas":"0",   "replicationFactor":"1",   "shards":{"shard1":{       "range":"80000000-7fffffff",       "state":"active",       "replicas":{         "core_node4":{           "core":"c8n_1x3_lf_shard1_replica_n1",           "base_url":"http://127.0.0.1:40178/_/le",           "node_name":"127.0.0.1:40178__%2Fle",           "state":"down",           "type":"NRT"},         "core_node5":{           "core":"c8n_1x3_lf_shard1_replica_n2",           "base_url":"http://127.0.0.1:41542/_/le",           "node_name":"127.0.0.1:41542__%2Fle",           "state":"active",           "type":"NRT",           "leader":"true"},         "core_node6":{           "state":"down",           "base_url":"http://127.0.0.1:33071/_/le",           "core":"c8n_1x3_lf_shard1_replica_n3",           "node_name":"127.0.0.1:33071__%2Fle",           "type":"NRT"}}}},   "router":{"name":"compositeId"},   "maxShardsPerNode":"1",   "autoAddReplicas":"false",   "nrtReplicas":"3",   "tlogReplicas":"0"}

Stack Trace:
java.lang.AssertionError: Expected 2 of 3 replicas to be active but only found 1; [core_node5:{"core":"c8n_1x3_lf_shard1_replica_n2","base_url":"http://127.0.0.1:41542/_/le","node_name":"127.0.0.1:41542__%2Fle","state":"active","type":"NRT","leader":"true"}]; clusterState: DocCollection(c8n_1x3_lf//collections/c8n_1x3_lf/state.json/17)={
  "pullReplicas":"0",
  "replicationFactor":"1",
  "shards":{"shard1":{
      "range":"80000000-7fffffff",
      "state":"active",
      "replicas":{
        "core_node4":{
          "core":"c8n_1x3_lf_shard1_replica_n1",
          "base_url":"http://127.0.0.1:40178/_/le",
          "node_name":"127.0.0.1:40178__%2Fle",
          "state":"down",
          "type":"NRT"},
        "core_node5":{
          "core":"c8n_1x3_lf_shard1_replica_n2",
          "base_url":"http://127.0.0.1:41542/_/le",
          "node_name":"127.0.0.1:41542__%2Fle",
          "state":"active",
          "type":"NRT",
          "leader":"true"},
        "core_node6":{
          "state":"down",
          "base_url":"http://127.0.0.1:33071/_/le",
          "core":"c8n_1x3_lf_shard1_replica_n3",
          "node_name":"127.0.0.1:33071__%2Fle",
          "type":"NRT"}}}},
  "router":{"name":"compositeId"},
  "maxShardsPerNode":"1",
  "autoAddReplicas":"false",
  "nrtReplicas":"3",
  "tlogReplicas":"0"}
	at __randomizedtesting.SeedInfo.seed([96A7310850DC1CAB:1EF30ED2FE207153]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.LeaderFailoverAfterPartitionTest.testRf3WithLeaderFailover(LeaderFailoverAfterPartitionTest.java:169)
	at org.apache.solr.cloud.LeaderFailoverAfterPartitionTest.test(LeaderFailoverAfterPartitionTest.java:56)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 12307 lines...]
   [junit4] Suite: org.apache.solr.cloud.autoscaling.TriggerIntegrationTest
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_96A7310850DC1CAB-001/init-core-data-001
   [junit4]   2> 1956161 WARN  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=50 numCloses=50
   [junit4]   2> 1956161 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=true
   [junit4]   2> 1956162 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (true) and clientAuth (true) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 1956196 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 1956196 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 2 servers in /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_96A7310850DC1CAB-001/tempDir-001
   [junit4]   2> 1956197 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 1956216 INFO  (Thread-2164) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 1956216 INFO  (Thread-2164) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 1956252 ERROR (Thread-2164) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 1956325 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:45466
   [junit4]   2> 1956379 INFO  (zkConnectionManagerCallback-4333-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1956767 INFO  (jetty-launcher-4330-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1956787 INFO  (jetty-launcher-4330-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1956895 INFO  (jetty-launcher-4330-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@3a4af250{/solr,null,AVAILABLE}
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@156a81ed{SSL,[ssl, http/1.1]}{127.0.0.1:35712}
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.e.j.s.Server Started @1972155ms
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=35712}
   [junit4]   2> 1956932 ERROR (jetty-launcher-4330-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1956932 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-19T18:27:43.159Z
   [junit4]   2> 1956940 INFO  (jetty-launcher-4330-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@3f335824{/solr,null,AVAILABLE}
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@4cb158a1{SSL,[ssl, http/1.1]}{127.0.0.1:34804}
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.e.j.s.Server Started @1972164ms
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=34804}
   [junit4]   2> 1956941 ERROR (jetty-launcher-4330-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1956941 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-19T18:27:43.168Z
   [junit4]   2> 1957005 INFO  (zkConnectionManagerCallback-4337-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1957013 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1957037 INFO  (zkConnectionManagerCallback-4335-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1957038 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1957074 INFO  (jetty-launcher-4330-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:45466/solr
   [junit4]   2> 1957204 INFO  (zkConnectionManagerCallback-4341-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1957397 INFO  (jetty-launcher-4330-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:45466/solr
   [junit4]   2> 1957432 INFO  (zkConnectionManagerCallback-4343-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1957453 INFO  (zkConnectionManagerCallback-4347-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1957578 INFO  (zkConnectionManagerCallback-4349-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1957659 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1957659 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:35712_solr
   [junit4]   2> 1957672 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.Overseer Overseer (id=99202371581575174-127.0.0.1:35712_solr-n_0000000000) starting
   [junit4]   2> 1957810 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:35712_solr
   [junit4]   2> 1957811 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 1957841 INFO  (jetty-launcher-4330-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1957851 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 1
   [junit4]   2> 1957860 INFO  (jetty-launcher-4330-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:34804_solr
   [junit4]   2> 1957982 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: []
   [junit4]   2> 1957982 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion -1
   [junit4]   2> 1957982 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 1
   [junit4]   2> 1957982 INFO  (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1958107 INFO  (zkCallback-4342-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1958148 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 1958168 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion 1
   [junit4]   2> 1958184 DEBUG (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr]
   [junit4]   2> 1958928 INFO  (jetty-launcher-4330-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34804.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1959058 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35712.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1959073 INFO  (jetty-launcher-4330-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34804.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1959074 INFO  (jetty-launcher-4330-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_34804.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1959075 INFO  (jetty-launcher-4330-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_96A7310850DC1CAB-001/tempDir-001/node2/.
   [junit4]   2> 1959111 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35712.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1959111 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_35712.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1959129 INFO  (jetty-launcher-4330-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_96A7310850DC1CAB-001/tempDir-001/node1/.
   [junit4]   2> 1959424 DEBUG (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr]
   [junit4]   2> 1959515 INFO  (zkConnectionManagerCallback-4354-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1959518 INFO  (zkConnectionManagerCallback-4358-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1959519 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1959520 INFO  (SUITE-TriggerIntegrationTest-seed#[96A7310850DC1CAB]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:45466/solr ready
   [junit4]   2> 1959754 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testNodeAddedTriggerRestoreState
   [junit4]   2> 1959755 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.a.TriggerIntegrationTest /autoscaling.json reset, new znode version 2
   [junit4]   2> 1959755 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 2
   [junit4]   2> 1959755 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 2
   [junit4]   2> 1959828 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 1959829 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 1959829 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 2, lastZnodeVersion 2
   [junit4]   2> 1960101 INFO  (zkConnectionManagerCallback-4362-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1960101 INFO  (qtp110930798-12617) [n:127.0.0.1:35712_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1960102 INFO  (qtp110930798-12617) [n:127.0.0.1:35712_solr    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:45466/solr ready
   [junit4]   2> 1960131 INFO  (qtp110930798-12618) [n:127.0.0.1:35712_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1960279 INFO  (qtp482292044-12626) [n:127.0.0.1:34804_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1960279 DEBUG (qtp110930798-12617) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 1960320 INFO  (qtp110930798-12617) [n:127.0.0.1:35712_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/autoscaling params={wt=javabin&version=2} status=0 QTime=255
   [junit4]   2> 1960322 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 3
   [junit4]   2> 1960336 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1960349 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr]
   [junit4]   2> 1960349 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_restore_trigger instantiated with properties: {event=nodeAdded, waitFor=5, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestTriggerAction}], enabled=true}
   [junit4]   2> 1960357 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 3
   [junit4]   2> 1960414 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@11c22f6c{/solr,null,AVAILABLE}
   [junit4]   2> 1960414 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@b5b3fd8{SSL,[ssl, http/1.1]}{127.0.0.1:36527}
   [junit4]   2> 1960415 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.Server Started @1975638ms
   [junit4]   2> 1960415 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=36527}
   [junit4]   2> 1960415 ERROR (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1960415 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1960415 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 1960415 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 1960415 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-19T18:27:46.642Z
   [junit4]   2> 1960461 INFO  (zkConnectionManagerCallback-4364-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1960359 INFO  (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 1960467 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 1960487 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 1960597 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160700806ff000a, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 1960598 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 3, lastZnodeVersion 3
   [junit4]   2> 1960607 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:45466/solr
   [junit4]   2> 1960635 INFO  (zkConnectionManagerCallback-4368-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1960625 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_restore_trigger
   [junit4]   2> 1960735 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr]
   [junit4]   2> 1960760 INFO  (zkConnectionManagerCallback-4370-thread-1-processing-n:127.0.0.1:36527_solr) [n:127.0.0.1:36527_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1960797 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 1960799 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 1960849 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:36527_solr
   [junit4]   2> 1960891 INFO  (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1961012 INFO  (zkCallback-4342-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1961020 INFO  (zkCallback-4357-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1961093 INFO  (zkCallback-4369-thread-1-processing-n:127.0.0.1:36527_solr) [n:127.0.0.1:36527_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 1961560 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_36527.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1961612 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_36527.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1961613 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_36527.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@70ac3e88
   [junit4]   2> 1961630 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [n:127.0.0.1:36527_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_96A7310850DC1CAB-001/tempDir-001/node3/.
   [junit4]   2> 1961777 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_restore_trigger
   [junit4]   2> 1961777 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1961777 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Tracking new node: 127.0.0.1:36527_solr at time 1513708068004000000
   [junit4]   2> 1962790 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_restore_trigger
   [junit4]   2> 1962790 DEBUG (ScheduledTrigger-2827-thread-3) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1963485 INFO  (zkConnectionManagerCallback-4375-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1963486 INFO  (qtp482292044-12620) [n:127.0.0.1:34804_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 1963487 INFO  (qtp482292044-12620) [n:127.0.0.1:34804_solr    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:45466/solr ready
   [junit4]   2> 1963507 INFO  (qtp110930798-12611) [n:127.0.0.1:35712_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1963528 INFO  (qtp482292044-12623) [n:127.0.0.1:34804_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1963670 INFO  (qtp1662652313-12685) [n:127.0.0.1:36527_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1963671 DEBUG (qtp482292044-12620) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 1963734 INFO  (qtp482292044-12620) [n:127.0.0.1:34804_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/autoscaling params={wt=javabin&version=2} status=0 QTime=284
   [junit4]   2> 1963734 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 4
   [junit4]   2> 1963734 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1963735 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_restore_trigger instantiated with properties: {event=nodeAdded, waitFor=0, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestTriggerAction}], enabled=true}
   [junit4]   2> 1963735 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 4
   [junit4]   2> 1963736 INFO  (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 1963736 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Adding node from marker path: 127.0.0.1:36527_solr
   [junit4]   2> 1963736 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 1963737 DEBUG (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_restore_trigger
   [junit4]   2> 1963737 DEBUG (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1963737 DEBUG (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_restore_trigger firing registered processor for nodes: [127.0.0.1:36527_solr] added at times [1513708069963000000], now=1513708069964000000
   [junit4]   2> 1963737 DEBUG (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.ScheduledTriggers ++++++++ Cooldown inactive - processing event: {
   [junit4]   2>   "id":"1501c5783bc968c0Tdaym06ynvvtva5l676p37ip88",
   [junit4]   2>   "source":"node_added_restore_trigger",
   [junit4]   2>   "eventTime":1513708069963000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513708069963000000],
   [junit4]   2>     "nodeNames":["127.0.0.1:36527_solr"]}}
   [junit4]   2> 1963750 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 4, lastZnodeVersion 4
   [junit4]   2> 1963751 INFO  (ScheduledTrigger-2827-thread-1) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.SystemLogListener Collection .system does not exist, disabling logging.
   [junit4]   2> 1963752 DEBUG (AutoscalingActionExecutor-2828-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"1501c5783bc968c0Tdaym06ynvvtva5l676p37ip88",
   [junit4]   2>   "source":"node_added_restore_trigger",
   [junit4]   2>   "eventTime":1513708069963000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513708069963000000],
   [junit4]   2>     "_enqueue_time_":1513708069964000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:36527_solr"]}}
   [junit4]   2> 1963753 INFO  (TEST-TriggerIntegrationTest.testNodeAddedTriggerRestoreState-seed#[96A7310850DC1CAB]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testNodeAddedTriggerRestoreState
   [junit4]   2> 1963934 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testContinueTriggersOnOverseerRestart
   [junit4]   2> 1963950 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 5
   [junit4]   2> 1963950 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 5
   [junit4]   2> 1963953 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.a.TriggerIntegrationTest /autoscaling.json reset, new znode version 5
   [junit4]   2> 1963967 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 1963967 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 1963967 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 5, lastZnodeVersion 5
   [junit4]   2> 1964049 INFO  (qtp482292044-12623) [n:127.0.0.1:34804_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :overseerstatus with params action=OVERSEERSTATUS&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 1964345 INFO  (qtp482292044-12623) [n:127.0.0.1:34804_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={action=OVERSEERSTATUS&wt=javabin&version=2} status=0 QTime=295
   [junit4]   2> 1964413 INFO  (zkConnectionManagerCallback-4379-thread-1-processing-n:127.0.0.1:36527_solr) [n:127.0.0.1:36527_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 1964414 INFO  (qtp1662652313-12681) [n:127.0.0.1:36527_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 1964415 INFO  (qtp1662652313-12681) [n:127.0.0.1:36527_solr    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:45466/solr ready
   [junit4]   2> 1964451 INFO  (qtp110930798-12611) [n:127.0.0.1:35712_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1964471 INFO  (qtp482292044-12626) [n:127.0.0.1:34804_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 1964486 INFO  (qtp1662652313-12682) [n:127.0.0.1:36527_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=12
   [junit4]   2> 1964486 DEBUG (qtp1662652313-12681) [n:127.0.0.1:36527_solr    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 1964489 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 6
   [junit4]   2> 1964489 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1964489 DEBUG (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger instantiated with properties: {event=nodeAdded, waitFor=2, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestTriggerAction}], enabled=true}
   [junit4]   2> 1964489 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 6
   [junit4]   2> 1964503 INFO  (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 1964503 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 1964503 DEBUG (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 6, lastZnodeVersion 6
   [junit4]   2> 1964503 INFO  (qtp1662652313-12681) [n:127.0.0.1:36527_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/cluster/autoscaling params={wt=javabin&version=2} status=0 QTime=125
   [junit4]   2> 1964504 DEBUG (ScheduledTrigger-2827-thread-4) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1964504 DEBUG (ScheduledTrigger-2827-thread-4) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:35712_solr, 127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1964526 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.AbstractConnector Stopped ServerConnector@156a81ed{SSL,[ssl, http/1.1]}{127.0.0.1:0}
   [junit4]   2> 1964545 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.CoreContainer Shutting down CoreContainer instance=1704405995
   [junit4]   2> 1964576 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.node, tag=null
   [junit4]   2> 1964576 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@1050c021: rootName = solr_35712, domain = solr.node, service url = null, agent id = null] for registry solr.node / com.codahale.metrics.MetricRegistry@447048ca
   [junit4]   2> 1964635 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jvm, tag=null
   [junit4]   2> 1964635 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@43798293: rootName = solr_35712, domain = solr.jvm, service url = null, agent id = null] for registry solr.jvm / com.codahale.metrics.MetricRegistry@5804227a
   [junit4]   2> 1964757 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jetty, tag=null
   [junit4]   2> 1964757 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@77769929: rootName = solr_35712, domain = solr.jetty, service url = null, agent id = null] for registry solr.jetty / com.codahale.metrics.MetricRegistry@1d467509
   [junit4]   2> 1964775 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.ZkController Remove node as live in ZooKeeper:/live_nodes/127.0.0.1:35712_solr
   [junit4]   2> 1964792 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.cluster, tag=null
   [junit4]   2> 1964792 INFO  (zkCallback-4348-thread-1-processing-n:127.0.0.1:35712_solr) [n:127.0.0.1:35712_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 1964811 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 1964812 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.Overseer Overseer (id=99202371581575174-127.0.0.1:35712_solr-n_0000000000) closing
   [junit4]   2> 1964813 INFO  (OverseerStateUpdate-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.Overseer Overseer Loop exiting : 127.0.0.1:35712_solr
   [junit4]   2> 1964813 INFO  (zkCallback-4342-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 1964820 INFO  (zkCallback-4369-thread-1-processing-n:127.0.0.1:36527_solr) [n:127.0.0.1:36527_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 1964820 INFO  (zkCallback-4357-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 1964832 WARN  (OverseerAutoScalingTriggerThread-99202371581575174-127.0.0.1:35712_solr-n_0000000000) [n:127.0.0.1:35712_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 1964865 DEBUG (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread has been closed explicitly
   [junit4]   2> 1964901 INFO  (zkCallback-4342-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:34804_solr
   [junit4]   2> 1964902 INFO  (zkCallback-4342-thread-1-processing-n:127.0.0.1:34804_solr) [n:127.0.0.1:34804_solr    ] o.a.s.c.Overseer Overseer (id=99202371581575172-127.0.0.1:34804_solr-n_0000000001) starting
   [junit4]   2> 1964913 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@3a4af250{/solr,null,UNAVAILABLE}
   [junit4]   2> 1965048 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 1965048 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 7
   [junit4]   2> 1965049 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1965049 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger instantiated with properties: {event=nodeAdded, waitFor=2, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestTriggerAction}], enabled=true}
   [junit4]   2> 1965049 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1965049 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 7, lastZnodeVersion -1
   [junit4]   2> 1965049 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 7
   [junit4]   2> 1965084 INFO  (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 1965085 DEBUG (ScheduledTrigger-2842-thread-1) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1965101 DEBUG (OverseerAutoScalingTriggerThread-99202371581575172-127.0.0.1:34804_solr-n_0000000001) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 7, lastZnodeVersion 7
   [junit4]   2> 1965194 DEBUG (ScheduledTrigger-2842-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1965194 DEBUG (ScheduledTrigger-2842-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1966085 DEBUG (ScheduledTrigger-2842-thread-1) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1966196 DEBUG (ScheduledTrigger-2842-thread-1) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1966196 DEBUG (ScheduledTrigger-2842-thread-1) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1967115 DEBUG (ScheduledTrigger-2842-thread-2) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1967203 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1967203 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1968122 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1968219 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1968219 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1969131 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1969222 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1969222 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1970136 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1970229 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1970229 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1971148 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1971242 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1971242 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1972157 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1972251 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1972251 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1973162 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1973255 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1973255 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1974169 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1974259 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 1974259 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1975135 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 1975184 DEBUG (ScheduledTrigger-2842-thread-4) [n:127.0.0.1:34804_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:34804_solr, 127.0.0.1:36527_solr]
   [junit4]   2> 1975201 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@166f6964{/solr,null,AVAILABLE}
   [junit4]   2> 1975202 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@1d8362d6{SSL,[ssl, http/1.1]}{127.0.0.1:37341}
   [junit4]   2> 1975202 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.e.j.s.Server Started @1990425ms
   [junit4]   2> 1975202 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=37341}
   [junit4]   2> 1975202 ERROR (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 1975217 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 1975217 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[96A7310850DC1CAB]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   St

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

.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
   [junit4]    >         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
   [junit4]    >         at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)
   [junit4]    >    5) Thread[id=3090, name=zkConnectionManagerCallback-65-thread-1-SendThread(127.0.0.1:41014), state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at java.lang.Thread.sleep(Native Method)
   [junit4]    >         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1051)
   [junit4]    >    6) Thread[id=295, name=zkConnectionManagerCallback-65-thread-1, state=WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
   [junit4]    >         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
   [junit4]    >         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    7) Thread[id=309, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at java.lang.Thread.sleep(Native Method)
   [junit4]    >         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    8) Thread[id=3089, name=zkCallback-64-thread-8, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    9) Thread[id=310, name=Connection evictor, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at java.lang.Thread.sleep(Native Method)
   [junit4]    >         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >   10) Thread[id=4056, name=zkCallback-64-thread-9, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >   11) Thread[id=4057, name=zkCallback-64-thread-10, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([66FE22CE21FF6F26]:0)Throwable #2: com.carrotsearch.randomizedtesting.ThreadLeakError: There are still zombie threads that couldn't be terminated:
   [junit4]    >    1) Thread[id=3090, name=zkConnectionManagerCallback-65-thread-1-SendThread(127.0.0.1:41014), state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at java.lang.Thread.sleep(Native Method)
   [junit4]    >         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1051)
   [junit4]    >    2) Thread[id=295, name=zkConnectionManagerCallback-65-thread-1, state=WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
   [junit4]    >         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
   [junit4]    >         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    3) Thread[id=3089, name=zkCallback-64-thread-8, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    4) Thread[id=4056, name=zkCallback-64-thread-9, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    5) Thread[id=4057, name=zkCallback-64-thread-10, state=TIMED_WAITING, group=TGRP-StreamExpressionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([66FE22CE21FF6F26]:0)
   [junit4] Completed [130/146 (1!)] on J0 in 549.79s, 139 tests, 1 failure, 2 errors <<< FAILURES!

[...truncated 46466 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 15 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/15/

8 tests failed.
FAILED:  org.apache.solr.cloud.TestDownShardTolerantSearch.searchingShouldFailWithoutTolerantSearchSetToTrue

Error Message:
Could not load collection from ZK: tolerant

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: tolerant
	at __randomizedtesting.SeedInfo.seed([78D073778BE2C605:4A00D27C8E40A764]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.getDocCollection(CloudSolrClient.java:1205)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:892)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrClient.query(SolrClient.java:942)
	at org.apache.solr.cloud.TestDownShardTolerantSearch.searchingShouldFailWithoutTolerantSearchSetToTrue(TestDownShardTolerantSearch.java:68)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/tolerant/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 46 more


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.TestLeaderElectionZkExpiry

Error Message:
ObjectTracker found 1 object(s) that were not released!!! [Overseer] org.apache.solr.common.util.ObjectReleaseTracker$ObjectTrackerException: org.apache.solr.cloud.Overseer  at org.apache.solr.common.util.ObjectReleaseTracker.track(ObjectReleaseTracker.java:42)  at org.apache.solr.cloud.Overseer.start(Overseer.java:536)  at org.apache.solr.cloud.OverseerElectionContext.runLeaderProcess(ElectionContext.java:799)  at org.apache.solr.cloud.LeaderElector.runIamLeaderProcess(LeaderElector.java:170)  at org.apache.solr.cloud.LeaderElector.checkIfIamLeader(LeaderElector.java:135)  at org.apache.solr.cloud.LeaderElector.joinElection(LeaderElector.java:307)  at org.apache.solr.cloud.LeaderElector.joinElection(LeaderElector.java:216)  at org.apache.solr.cloud.ZkController$1.command(ZkController.java:353)  at org.apache.solr.common.cloud.ConnectionManager$1.update(ConnectionManager.java:167)  at org.apache.solr.common.cloud.DefaultConnectionStrategy.reconnect(DefaultConnectionStrategy.java:57)  at org.apache.solr.common.cloud.ConnectionManager.process(ConnectionManager.java:141)  at org.apache.zookeeper.ClientCnxn$EventThread.processEvent(ClientCnxn.java:530)  at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:505)  

Stack Trace:
java.lang.AssertionError: ObjectTracker found 1 object(s) that were not released!!! [Overseer]
org.apache.solr.common.util.ObjectReleaseTracker$ObjectTrackerException: org.apache.solr.cloud.Overseer
	at org.apache.solr.common.util.ObjectReleaseTracker.track(ObjectReleaseTracker.java:42)
	at org.apache.solr.cloud.Overseer.start(Overseer.java:536)
	at org.apache.solr.cloud.OverseerElectionContext.runLeaderProcess(ElectionContext.java:799)
	at org.apache.solr.cloud.LeaderElector.runIamLeaderProcess(LeaderElector.java:170)
	at org.apache.solr.cloud.LeaderElector.checkIfIamLeader(LeaderElector.java:135)
	at org.apache.solr.cloud.LeaderElector.joinElection(LeaderElector.java:307)
	at org.apache.solr.cloud.LeaderElector.joinElection(LeaderElector.java:216)
	at org.apache.solr.cloud.ZkController$1.command(ZkController.java:353)
	at org.apache.solr.common.cloud.ConnectionManager$1.update(ConnectionManager.java:167)
	at org.apache.solr.common.cloud.DefaultConnectionStrategy.reconnect(DefaultConnectionStrategy.java:57)
	at org.apache.solr.common.cloud.ConnectionManager.process(ConnectionManager.java:141)
	at org.apache.zookeeper.ClientCnxn$EventThread.processEvent(ClientCnxn.java:530)
	at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:505)


	at __randomizedtesting.SeedInfo.seed([78D073778BE2C605]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.junit.Assert.assertNull(Assert.java:551)
	at org.apache.solr.SolrTestCaseJ4.teardownTestCases(SolrTestCaseJ4.java:298)
	at sun.reflect.GeneratedMethodAccessor53.invoke(Unknown Source)
	at sun.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.lang.reflect.Method.invoke(Method.java:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:897)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.TestLeaderElectionZkExpiry

Error Message:
1 thread leaked from SUITE scope at org.apache.solr.cloud.TestLeaderElectionZkExpiry:     1) Thread[id=15382, name=OverseerAutoScalingTriggerThread-99193856354222089-dummy.host.com:8984_solr-n_0000000003, state=RUNNABLE, group=Overseer autoscaling triggers]         at org.apache.lucene.util.TestRuleLimitSysouts$DelegateStream.write(TestRuleLimitSysouts.java:128)         at java.io.PrintStream.write(PrintStream.java:480)         at sun.nio.cs.StreamEncoder.writeBytes(StreamEncoder.java:221)         at sun.nio.cs.StreamEncoder.implFlushBuffer(StreamEncoder.java:291)         at sun.nio.cs.StreamEncoder.implFlush(StreamEncoder.java:295)         at sun.nio.cs.StreamEncoder.flush(StreamEncoder.java:141)         at java.io.OutputStreamWriter.flush(OutputStreamWriter.java:229)         at org.apache.log4j.helpers.QuietWriter.flush(QuietWriter.java:59)         at org.apache.log4j.WriterAppender.subAppend(WriterAppender.java:324)         at org.apache.log4j.WriterAppender.append(WriterAppender.java:162)         at org.apache.log4j.AppenderSkeleton.doAppend(AppenderSkeleton.java:251)         at org.apache.log4j.helpers.AppenderAttachableImpl.appendLoopOnAppenders(AppenderAttachableImpl.java:66)         at org.apache.log4j.Category.callAppenders(Category.java:206)         at org.apache.log4j.Category.forcedLog(Category.java:391)         at org.apache.log4j.Category.log(Category.java:856)         at org.slf4j.impl.Log4jLoggerAdapter.error(Log4jLoggerAdapter.java:575)         at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:131)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: 1 thread leaked from SUITE scope at org.apache.solr.cloud.TestLeaderElectionZkExpiry: 
   1) Thread[id=15382, name=OverseerAutoScalingTriggerThread-99193856354222089-dummy.host.com:8984_solr-n_0000000003, state=RUNNABLE, group=Overseer autoscaling triggers]
        at org.apache.lucene.util.TestRuleLimitSysouts$DelegateStream.write(TestRuleLimitSysouts.java:128)
        at java.io.PrintStream.write(PrintStream.java:480)
        at sun.nio.cs.StreamEncoder.writeBytes(StreamEncoder.java:221)
        at sun.nio.cs.StreamEncoder.implFlushBuffer(StreamEncoder.java:291)
        at sun.nio.cs.StreamEncoder.implFlush(StreamEncoder.java:295)
        at sun.nio.cs.StreamEncoder.flush(StreamEncoder.java:141)
        at java.io.OutputStreamWriter.flush(OutputStreamWriter.java:229)
        at org.apache.log4j.helpers.QuietWriter.flush(QuietWriter.java:59)
        at org.apache.log4j.WriterAppender.subAppend(WriterAppender.java:324)
        at org.apache.log4j.WriterAppender.append(WriterAppender.java:162)
        at org.apache.log4j.AppenderSkeleton.doAppend(AppenderSkeleton.java:251)
        at org.apache.log4j.helpers.AppenderAttachableImpl.appendLoopOnAppenders(AppenderAttachableImpl.java:66)
        at org.apache.log4j.Category.callAppenders(Category.java:206)
        at org.apache.log4j.Category.forcedLog(Category.java:391)
        at org.apache.log4j.Category.log(Category.java:856)
        at org.slf4j.impl.Log4jLoggerAdapter.error(Log4jLoggerAdapter.java:575)
        at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:131)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([78D073778BE2C605]:0)


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.TestLeaderElectionZkExpiry

Error Message:
There are still zombie threads that couldn't be terminated:    1) Thread[id=15382, name=OverseerAutoScalingTriggerThread-99193856354222089-dummy.host.com:8984_solr-n_0000000003, state=RUNNABLE, group=Overseer autoscaling triggers]         at org.apache.lucene.util.TestRuleLimitSysouts$DelegateStream.write(TestRuleLimitSysouts.java:128)         at java.io.PrintStream.write(PrintStream.java:480)         at sun.nio.cs.StreamEncoder.writeBytes(StreamEncoder.java:221)         at sun.nio.cs.StreamEncoder.implFlushBuffer(StreamEncoder.java:291)         at sun.nio.cs.StreamEncoder.implFlush(StreamEncoder.java:295)         at sun.nio.cs.StreamEncoder.flush(StreamEncoder.java:141)         at java.io.OutputStreamWriter.flush(OutputStreamWriter.java:229)         at org.apache.log4j.helpers.QuietWriter.flush(QuietWriter.java:59)         at org.apache.log4j.WriterAppender.subAppend(WriterAppender.java:324)         at org.apache.log4j.WriterAppender.append(WriterAppender.java:162)         at org.apache.log4j.AppenderSkeleton.doAppend(AppenderSkeleton.java:251)         at org.apache.log4j.helpers.AppenderAttachableImpl.appendLoopOnAppenders(AppenderAttachableImpl.java:66)         at org.apache.log4j.Category.callAppenders(Category.java:206)         at org.apache.log4j.Category.forcedLog(Category.java:391)         at org.apache.log4j.Category.log(Category.java:856)         at org.slf4j.impl.Log4jLoggerAdapter.error(Log4jLoggerAdapter.java:575)         at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:131)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: There are still zombie threads that couldn't be terminated:
   1) Thread[id=15382, name=OverseerAutoScalingTriggerThread-99193856354222089-dummy.host.com:8984_solr-n_0000000003, state=RUNNABLE, group=Overseer autoscaling triggers]
        at org.apache.lucene.util.TestRuleLimitSysouts$DelegateStream.write(TestRuleLimitSysouts.java:128)
        at java.io.PrintStream.write(PrintStream.java:480)
        at sun.nio.cs.StreamEncoder.writeBytes(StreamEncoder.java:221)
        at sun.nio.cs.StreamEncoder.implFlushBuffer(StreamEncoder.java:291)
        at sun.nio.cs.StreamEncoder.implFlush(StreamEncoder.java:295)
        at sun.nio.cs.StreamEncoder.flush(StreamEncoder.java:141)
        at java.io.OutputStreamWriter.flush(OutputStreamWriter.java:229)
        at org.apache.log4j.helpers.QuietWriter.flush(QuietWriter.java:59)
        at org.apache.log4j.WriterAppender.subAppend(WriterAppender.java:324)
        at org.apache.log4j.WriterAppender.append(WriterAppender.java:162)
        at org.apache.log4j.AppenderSkeleton.doAppend(AppenderSkeleton.java:251)
        at org.apache.log4j.helpers.AppenderAttachableImpl.appendLoopOnAppenders(AppenderAttachableImpl.java:66)
        at org.apache.log4j.Category.callAppenders(Category.java:206)
        at org.apache.log4j.Category.forcedLog(Category.java:391)
        at org.apache.log4j.Category.log(Category.java:856)
        at org.slf4j.impl.Log4jLoggerAdapter.error(Log4jLoggerAdapter.java:575)
        at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:131)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([78D073778BE2C605]:0)


FAILED:  org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testNodeMarkersRegistration

Error Message:
Path /autoscaling/nodeAdded/127.0.0.1:44678_solr wasn't created

Stack Trace:
java.lang.AssertionError: Path /autoscaling/nodeAdded/127.0.0.1:44678_solr wasn't created
	at __randomizedtesting.SeedInfo.seed([78D073778BE2C605:606AFB7B85D70BEA]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testNodeMarkersRegistration(TriggerIntegrationTest.java:931)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.search.stats.TestDistribIDF.testSimpleQuery

Error Message:
Could not load collection from ZK: onecollection_local

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: onecollection_local
	at __randomizedtesting.SeedInfo.seed([78D073778BE2C605:DDDB36B9BF800D0]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.common.cloud.ClusterState.getCollectionOrNull(ClusterState.java:130)
	at org.apache.solr.cloud.AbstractDistribZkTestBase.waitForRecoveriesToFinish(AbstractDistribZkTestBase.java:154)
	at org.apache.solr.search.stats.TestDistribIDF.createCollection(TestDistribIDF.java:212)
	at org.apache.solr.search.stats.TestDistribIDF.testSimpleQuery(TestDistribIDF.java:78)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/onecollection_local/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 44 more


FAILED:  org.apache.solr.client.solrj.impl.CloudSolrClientTest.testRetryUpdatesWhenClusterStateIsStale

Error Message:
Could not load collection from ZK: stale_state_test_col

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: stale_state_test_col
	at __randomizedtesting.SeedInfo.seed([A6AEA9AA8465DB93:129F3142678CADBF]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.common.cloud.ClusterState.getCollectionOrNull(ClusterState.java:130)
	at org.apache.solr.cloud.AbstractDistribZkTestBase.waitForRecoveriesToFinish(AbstractDistribZkTestBase.java:154)
	at org.apache.solr.client.solrj.impl.CloudSolrClientTest.testRetryUpdatesWhenClusterStateIsStale(CloudSolrClientTest.java:805)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.junit.rules.ExpectedException$ExpectedExceptionStatement.evaluate(ExpectedException.java:110)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/stale_state_test_col/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 44 more


FAILED:  org.apache.solr.client.solrj.impl.CloudSolrClientTest.checkCollectionParameters

Error Message:
Could not load collection from ZK: collection1

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: collection1
	at __randomizedtesting.SeedInfo.seed([A6AEA9AA8465DB93:5DB93A1ADD320C24]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.getDocCollection(CloudSolrClient.java:1205)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:848)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.request.UpdateRequest.commit(UpdateRequest.java:233)
	at org.apache.solr.client.solrj.impl.CloudSolrClientTest.cleanIndex(CloudSolrClientTest.java:127)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:968)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.junit.rules.ExpectedException$ExpectedExceptionStatement.evaluate(ExpectedException.java:110)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/collection1/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 46 more




Build Log:
[...truncated 12583 lines...]
   [junit4] Suite: org.apache.solr.cloud.autoscaling.TriggerIntegrationTest
   [junit4]   2> 3372962 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> Creating dataDir: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_78D073778BE2C605-001/init-core-data-001
   [junit4]   2> 3372963 WARN  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=9 numCloses=9
   [junit4]   2> 3372963 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 3372964 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (true) and clientAuth (false) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 3372965 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 2 servers in /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_78D073778BE2C605-001/tempDir-001
   [junit4]   2> 3372965 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 3372982 INFO  (Thread-1278) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 3372982 INFO  (Thread-1278) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 3373014 ERROR (Thread-1278) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 3373086 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:54879
   [junit4]   2> 3373091 INFO  (zkConnectionManagerCallback-4118-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373202 INFO  (jetty-launcher-4115-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 3373204 INFO  (jetty-launcher-4115-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 3373375 INFO  (jetty-launcher-4115-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@68b1e206{/solr,null,AVAILABLE}
   [junit4]   2> 3373375 INFO  (jetty-launcher-4115-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@2e84611e{SSL,[ssl, http/1.1]}{127.0.0.1:59946}
   [junit4]   2> 3373376 INFO  (jetty-launcher-4115-thread-2) [    ] o.e.j.s.Server Started @3393613ms
   [junit4]   2> 3373376 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=59946}
   [junit4]   2> 3373376 ERROR (jetty-launcher-4115-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 3373376 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 3373376 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 3373376 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 3373376 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-18T05:57:34.446Z
   [junit4]   2> 3373377 INFO  (jetty-launcher-4115-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@c217c32{/solr,null,AVAILABLE}
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@30ebfff4{SSL,[ssl, http/1.1]}{127.0.0.1:41143}
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.e.j.s.Server Started @3393615ms
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=41143}
   [junit4]   2> 3373378 ERROR (jetty-launcher-4115-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 3373378 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-18T05:57:34.448Z
   [junit4]   2> 3373427 INFO  (zkConnectionManagerCallback-4120-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373427 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 3373446 INFO  (zkConnectionManagerCallback-4122-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373454 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 3373454 INFO  (jetty-launcher-4115-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:54879/solr
   [junit4]   2> 3373455 INFO  (zkConnectionManagerCallback-4126-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373509 INFO  (zkConnectionManagerCallback-4128-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373614 INFO  (jetty-launcher-4115-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:54879/solr
   [junit4]   2> 3373695 INFO  (zkConnectionManagerCallback-4133-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373724 INFO  (zkConnectionManagerCallback-4135-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3373743 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 3373744 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:41143_solr
   [junit4]   2> 3373744 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.Overseer Overseer (id=99193759600214022-127.0.0.1:41143_solr-n_0000000000) starting
   [junit4]   2> 3373782 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:41143_solr
   [junit4]   2> 3373783 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 3373796 INFO  (OverseerStateUpdate-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 3373846 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 1
   [junit4]   2> 3373882 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: [127.0.0.1:41143_solr]
   [junit4]   2> 3373882 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion -1
   [junit4]   2> 3373882 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 1
   [junit4]   2> 3374082 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 3374084 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 3374094 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:59946_solr
   [junit4]   2> 3374122 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 3374122 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion 1
   [junit4]   2> 3374123 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:41143_solr]
   [junit4]   2> 3374226 INFO  (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 3374344 INFO  (zkCallback-4134-thread-2-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 3374351 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_41143.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3374394 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_41143.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3374395 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_41143.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3374396 INFO  (jetty-launcher-4115-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_78D073778BE2C605-001/tempDir-001/node1/.
   [junit4]   2> 3375017 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_59946.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3375126 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:59946_solr, 127.0.0.1:41143_solr]
   [junit4]   2> 3375129 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_59946.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3375129 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_59946.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3375130 INFO  (jetty-launcher-4115-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_78D073778BE2C605-001/tempDir-001/node2/.
   [junit4]   2> 3375245 INFO  (zkConnectionManagerCallback-4139-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3375270 INFO  (zkConnectionManagerCallback-4143-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3375271 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 3375271 INFO  (SUITE-TriggerIntegrationTest-seed#[78D073778BE2C605]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:54879/solr ready
   [junit4]   2> 3375420 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testEventQueue
   [junit4]   2> 3375421 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.a.TriggerIntegrationTest /autoscaling.json reset, new znode version 2
   [junit4]   2> 3375421 DEBUG (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 2
   [junit4]   2> 3375421 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 2
   [junit4]   2> 3375422 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 3375422 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 3375422 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 2, lastZnodeVersion 2
   [junit4]   2> 3375566 INFO  (qtp655669960-11194) [n:127.0.0.1:41143_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :overseerstatus with params action=OVERSEERSTATUS&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 3375730 INFO  (OverseerCollectionConfigSetProcessor-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000000 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 3375731 INFO  (qtp655669960-11194) [n:127.0.0.1:41143_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={action=OVERSEERSTATUS&wt=javabin&version=2} status=0 QTime=165
   [junit4]   2> 3375914 INFO  (zkConnectionManagerCallback-4147-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3375915 INFO  (qtp655669960-11194) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 3375934 INFO  (qtp655669960-11194) [n:127.0.0.1:41143_solr    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:54879/solr ready
   [junit4]   2> 3375983 INFO  (qtp655669960-11191) [n:127.0.0.1:41143_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 3376274 INFO  (qtp282096827-11204) [n:127.0.0.1:59946_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 3376275 DEBUG (qtp655669960-11194) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 3376327 DEBUG (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 3
   [junit4]   2> 3376328 INFO  (qtp655669960-11194) [n:127.0.0.1:41143_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/autoscaling params={wt=javabin&version=2} status=0 QTime=595
   [junit4]   2> 3376337 INFO  (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.TriggerIntegrationTest TestEventQueueAction instantiated
   [junit4]   2> 3376337 DEBUG (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:59946_solr, 127.0.0.1:41143_solr]
   [junit4]   2> 3376338 DEBUG (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger1 instantiated with properties: {event=nodeAdded, waitFor=1, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestEventQueueAction}], enabled=true}
   [junit4]   2> 3376338 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 3
   [junit4]   2> 3376345 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 3376347 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 3376366 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3376366 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:41143_solr]
   [junit4]   2> 3376394 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 3376494 DEBUG (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 3, lastZnodeVersion 3
   [junit4]   2> 3376562 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@1db28880{/solr,null,AVAILABLE}
   [junit4]   2> 3376563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@e16965{SSL,[ssl, http/1.1]}{127.0.0.1:46892}
   [junit4]   2> 3376563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.e.j.s.Server Started @3396800ms
   [junit4]   2> 3376563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=46892}
   [junit4]   2> 3376563 ERROR (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 3376563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 3376563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 3376563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 3376564 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-18T05:57:37.634Z
   [junit4]   2> 3376662 INFO  (zkConnectionManagerCallback-4149-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3376663 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 3376745 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:54879/solr
   [junit4]   2> 3376834 INFO  (zkConnectionManagerCallback-4153-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3376951 INFO  (zkConnectionManagerCallback-4155-thread-1-processing-n:127.0.0.1:46892_solr) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3376954 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 3376955 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 3376956 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:46892_solr
   [junit4]   2> 3376957 INFO  (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 3376957 INFO  (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 3377035 INFO  (zkCallback-4142-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 3377035 INFO  (zkCallback-4154-thread-1-processing-n:127.0.0.1:46892_solr) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 3377367 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3377367 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr, 127.0.0.1:41143_solr]
   [junit4]   2> 3377367 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Tracking new node: 127.0.0.1:46892_solr at time 1513576658437000000
   [junit4]   2> 3377464 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_46892.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3377533 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_46892.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3377533 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_46892.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@1aec236d
   [junit4]   2> 3377563 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [n:127.0.0.1:46892_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J2/temp/solr.cloud.autoscaling.TriggerIntegrationTest_78D073778BE2C605-001/tempDir-001/node3/.
   [junit4]   2> 3378370 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3378370 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr, 127.0.0.1:41143_solr]
   [junit4]   2> 3378370 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger1 firing registered processor for nodes: [127.0.0.1:46892_solr] added at times [1513576658437000000], now=1513576659440000000
   [junit4]   2> 3378370 DEBUG (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.ScheduledTriggers ++++++++ Cooldown inactive - processing event: {
   [junit4]   2>   "id":"15014df39a75cb40T24dss1d10wnnazymysmyr7n57",
   [junit4]   2>   "source":"node_added_trigger1",
   [junit4]   2>   "eventTime":1513576658437000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513576658437000000],
   [junit4]   2>     "nodeNames":["127.0.0.1:46892_solr"]}}
   [junit4]   2> 3378371 INFO  (ScheduledTrigger-2754-thread-1) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.SystemLogListener Collection .system does not exist, disabling logging.
   [junit4]   2> 3378372 DEBUG (AutoscalingActionExecutor-2755-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"15014df39a75cb40T24dss1d10wnnazymysmyr7n57",
   [junit4]   2>   "source":"node_added_trigger1",
   [junit4]   2>   "eventTime":1513576658437000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513576658437000000],
   [junit4]   2>     "_enqueue_time_":1513576659440000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:46892_solr"]}}
   [junit4]   2> 3378372 INFO  (AutoscalingActionExecutor-2755-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.TriggerIntegrationTest -- event: {
   [junit4]   2>   "id":"15014df39a75cb40T24dss1d10wnnazymysmyr7n57",
   [junit4]   2>   "source":"node_added_trigger1",
   [junit4]   2>   "eventTime":1513576658437000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513576658437000000],
   [junit4]   2>     "_enqueue_time_":1513576659440000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:46892_solr"]}}
   [junit4]   2> 3378494 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.e.j.s.AbstractConnector Stopped ServerConnector@30ebfff4{SSL,[ssl, http/1.1]}{127.0.0.1:0}
   [junit4]   2> 3378497 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.CoreContainer Shutting down CoreContainer instance=21053059
   [junit4]   2> 3378498 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.node, tag=null
   [junit4]   2> 3378498 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@40ef9eb1: rootName = solr_41143, domain = solr.node, service url = null, agent id = null] for registry solr.node / com.codahale.metrics.MetricRegistry@3537299b
   [junit4]   2> 3378536 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jvm, tag=null
   [junit4]   2> 3378536 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@4b4de004: rootName = solr_41143, domain = solr.jvm, service url = null, agent id = null] for registry solr.jvm / com.codahale.metrics.MetricRegistry@63da6a3c
   [junit4]   2> 3378577 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jetty, tag=null
   [junit4]   2> 3378577 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@524e5f52: rootName = solr_41143, domain = solr.jetty, service url = null, agent id = null] for registry solr.jetty / com.codahale.metrics.MetricRegistry@78db110e
   [junit4]   2> 3378579 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.ZkController Remove node as live in ZooKeeper:/live_nodes/127.0.0.1:41143_solr
   [junit4]   2> 3378580 INFO  (zkCallback-4154-thread-1-processing-n:127.0.0.1:46892_solr) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 3378580 INFO  (zkCallback-4142-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 3378580 INFO  (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 3378581 INFO  (zkCallback-4134-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (2)
   [junit4]   2> 3378594 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.cluster, tag=null
   [junit4]   2> 3378794 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 3378794 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.Overseer Overseer (id=99193759600214022-127.0.0.1:41143_solr-n_0000000000) closing
   [junit4]   2> 3378795 WARN  (OverseerAutoScalingTriggerThread-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 3378795 INFO  (OverseerStateUpdate-99193759600214022-127.0.0.1:41143_solr-n_0000000000) [n:127.0.0.1:41143_solr    ] o.a.s.c.Overseer Overseer Loop exiting : 127.0.0.1:41143_solr
   [junit4]   2> 3378807 DEBUG (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread has been closed explicitly
   [junit4]   2> 3378807 WARN  (AutoscalingActionExecutor-2755-thread-1-processing-n:127.0.0.1:41143_solr) [n:127.0.0.1:41143_solr    ] o.a.s.c.a.ScheduledTriggers Exception executing actions
   [junit4]   2> org.apache.lucene.store.AlreadyClosedException: ScheduledTrigger node_added_trigger1 has been closed.
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers$ScheduledTrigger.dequeue(ScheduledTriggers.java:504)
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:320)
   [junit4]   2> 	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
   [junit4]   2> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 3378836 INFO  (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:59946_solr
   [junit4]   2> 3378837 INFO  (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.Overseer Overseer (id=99193759600214020-127.0.0.1:59946_solr-n_0000000001) starting
   [junit4]   2> 3378862 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@c217c32{/solr,null,UNAVAILABLE}
   [junit4]   2> 3378863 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 3378863 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 4
   [junit4]   2> 3378863 INFO  (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.TriggerIntegrationTest TestEventQueueAction instantiated
   [junit4]   2> 3378863 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3378863 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger1 instantiated with properties: {event=nodeAdded, waitFor=1, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestEventQueueAction}], enabled=true}
   [junit4]   2> 3378864 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3378864 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 4, lastZnodeVersion -1
   [junit4]   2> 3378864 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 4
   [junit4]   2> 3378874 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 3378875 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 4, lastZnodeVersion 4
   [junit4]   2> 3378875 DEBUG (ScheduledTrigger-2769-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3378876 DEBUG (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.ScheduledTriggers ++++++++ Cooldown inactive - processing event: {
   [junit4]   2>   "id":"15014df39a75cb40T24dss1d10wnnazymysmyr7n57",
   [junit4]   2>   "source":"node_added_trigger1",
   [junit4]   2>   "eventTime":1513576658437000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513576658437000000],
   [junit4]   2>     "_dequeue_time_":1513576659946000000,
   [junit4]   2>     "_enqueue_time_":1513576659440000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:46892_solr"],
   [junit4]   2>     "replaying":true}}
   [junit4]   2> 3378880 INFO  (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.SystemLogListener Collection .system does not exist, disabling logging.
   [junit4]   2> 3378890 DEBUG (AutoscalingActionExecutor-2770-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"15014df39a75cb40T24dss1d10wnnazymysmyr7n57",
   [junit4]   2>   "source":"node_added_trigger1",
   [junit4]   2>   "eventTime":1513576658437000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513576658437000000],
   [junit4]   2>     "_dequeue_time_":1513576659946000000,
   [junit4]   2>     "_enqueue_time_":1513576659440000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:46892_solr"],
   [junit4]   2>     "replaying":true}}
   [junit4]   2> 3378890 INFO  (AutoscalingActionExecutor-2770-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.TriggerIntegrationTest -- event: {
   [junit4]   2>   "id":"15014df39a75cb40T24dss1d10wnnazymysmyr7n57",
   [junit4]   2>   "source":"node_added_trigger1",
   [junit4]   2>   "eventTime":1513576658437000000,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[1513576658437000000],
   [junit4]   2>     "_dequeue_time_":1513576659946000000,
   [junit4]   2>     "_enqueue_time_":1513576659440000000,
   [junit4]   2>     "nodeNames":["127.0.0.1:46892_solr"],
   [junit4]   2>     "replaying":true}}
   [junit4]   2> 3378891 DEBUG (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3378891 DEBUG (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3379886 DEBUG (ScheduledTrigger-2769-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3379894 DEBUG (ScheduledTrigger-2769-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3379894 DEBUG (ScheduledTrigger-2769-thread-2) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3380894 DEBUG (ScheduledTrigger-2769-thread-4) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3380895 DEBUG (ScheduledTrigger-2769-thread-4) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3381275 DEBUG (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3381895 DEBUG (ScheduledTrigger-2769-thread-4) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3381895 DEBUG (ScheduledTrigger-2769-thread-4) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3382275 DEBUG (ScheduledTrigger-2769-thread-4) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3382895 DEBUG (ScheduledTrigger-2769-thread-3) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3382895 DEBUG (ScheduledTrigger-2769-thread-3) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3383275 DEBUG (ScheduledTrigger-2769-thread-3) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3383881 INFO  (TEST-TriggerIntegrationTest.testEventQueue-seed#[78D073778BE2C605]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testEventQueue
   [junit4]   2> 3383902 DEBUG (ScheduledTrigger-2769-thread-3) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger1
   [junit4]   2> 3383902 DEBUG (ScheduledTrigger-2769-thread-3) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3383902 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testContinueTriggersOnOverseerRestart
   [junit4]   2> 3383903 DEBUG (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 5
   [junit4]   2> 3383903 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 5
   [junit4]   2> 3383904 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 3383905 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 3383905 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 5, lastZnodeVersion 5
   [junit4]   2> 3383905 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.c.a.TriggerIntegrationTest /autoscaling.json reset, new znode version 5
   [junit4]   2> 3384047 INFO  (qtp425908279-11262) [n:127.0.0.1:46892_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :overseerstatus with params action=OVERSEERSTATUS&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 3384079 INFO  (OverseerCollectionConfigSetProcessor-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000002 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 3384080 INFO  (qtp425908279-11262) [n:127.0.0.1:46892_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={action=OVERSEERSTATUS&wt=javabin&version=2} status=0 QTime=32
   [junit4]   2> 3384151 INFO  (zkConnectionManagerCallback-4161-thread-1-processing-n:127.0.0.1:46892_solr) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 3384151 INFO  (qtp425908279-11263) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 3384152 INFO  (qtp425908279-11263) [n:127.0.0.1:46892_solr    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:54879/solr ready
   [junit4]   2> 3384185 INFO  (qtp425908279-11265) [n:127.0.0.1:46892_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 3384211 INFO  (qtp282096827-11202) [n:127.0.0.1:59946_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/metrics params={prefix=CORE.coreName&wt=javabin&version=2&group=solr.core} status=0 QTime=0
   [junit4]   2> 3384212 DEBUG (qtp425908279-11263) [n:127.0.0.1:46892_solr    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 3384235 DEBUG (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 6
   [junit4]   2> 3384235 INFO  (qtp425908279-11263) [n:127.0.0.1:46892_solr    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/cluster/autoscaling params={wt=javabin&version=2} status=0 QTime=141
   [junit4]   2> 3384278 DEBUG (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Initial livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3384278 DEBUG (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger instantiated with properties: {event=nodeAdded, waitFor=3, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.TriggerIntegrationTest$TestTriggerAction}], enabled=true}
   [junit4]   2> 3384278 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 6
   [junit4]   2> 3384290 INFO  (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.TriggerIntegrationTest TestTriggerAction init
   [junit4]   2> 3384290 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 3384290 DEBUG (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 6, lastZnodeVersion 6
   [junit4]   2> 3384294 DEBUG (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 3384294 DEBUG (ScheduledTrigger-2769-thread-1) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: [127.0.0.1:59946_solr, 127.0.0.1:46892_solr]
   [junit4]   2> 3384295 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.e.j.s.AbstractConnector Stopped ServerConnector@2e84611e{SSL,[ssl, http/1.1]}{127.0.0.1:0}
   [junit4]   2> 3384547 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.c.CoreContainer Shutting down CoreContainer instance=1343764145
   [junit4]   2> 3384547 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.node, tag=null
   [junit4]   2> 3384551 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@115382fe: rootName = solr_59946, domain = solr.node, service url = null, agent id = null] for registry solr.node / com.codahale.metrics.MetricRegistry@5d6569c1
   [junit4]   2> 3384556 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jvm, tag=null
   [junit4]   2> 3384557 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@37cd10f3: rootName = solr_59946, domain = solr.jvm, service url = null, agent id = null] for registry solr.jvm / com.codahale.metrics.MetricRegistry@63da6a3c
   [junit4]   2> 3384561 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jetty, tag=null
   [junit4]   2> 3384561 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@3af938cb: rootName = solr_59946, domain = solr.jetty, service url = null, agent id = null] for registry solr.jetty / com.codahale.metrics.MetricRegistry@78db110e
   [junit4]   2> 3384603 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.c.ZkController Remove node as live in ZooKeeper:/live_nodes/127.0.0.1:59946_solr
   [junit4]   2> 3384603 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.cluster, tag=null
   [junit4]   2> 3384603 INFO  (zkCallback-4142-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (1)
   [junit4]   2> 3384603 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 3384603 INFO  (zkCallback-4154-thread-1-processing-n:127.0.0.1:46892_solr) [n:127.0.0.1:46892_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (1)
   [junit4]   2> 3384604 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.c.Overseer Overseer (id=99193759600214020-127.0.0.1:59946_solr-n_0000000001) closing
   [junit4]   2> 3384604 INFO  (OverseerStateUpdate-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.Overseer Overseer Loop exiting : 127.0.0.1:59946_solr
   [junit4]   2> 3384604 INFO  (zkCallback-4127-thread-1-processing-n:127.0.0.1:59946_solr) [n:127.0.0.1:59946_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (1)
   [junit4]   2> 3384645 DEBUG (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread has been closed explicitly
   [junit4]   2> 3384666 WARN  (OverseerAutoScalingTriggerThread-99193759600214020-127.0.0.1:59946_solr-n_0000000001) [n:127.0.0.1:59946_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 3384667 INFO  (zkCallback-4154-thread-1-processing-n:127.0.0.1:46892_solr) [n:127.0.0.1:46892_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:46892_solr
   [junit4]   2> 3384668 INFO  (TEST-TriggerIntegrationTest.testContinueTriggersOnOverseerRestart-seed#[78D073778BE2C605]) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@68b1e206{/solr,null,UNAVAILABLE}
   [junit4]   2> 3384668 INFO  (zkCallba

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

.reporters.SolrJmxReporter@1cc56f13: rootName = solr_48072, domain = solr.core.localShardsTestColl.shard1.replica_n4, service url = null, agent id = null] for registry solr.core.localShardsTestColl.shard1.replica_n4 / com.codahale.metrics.MetricRegistry@7231c3ce
   [junit4]   2> 736200 INFO  (coreCloseExecutor-782-thread-4) [n:127.0.0.1:49822_solr c:localShardsTestColl s:shard2 r:core_node9 x:localShardsTestColl_shard2_replica_n6] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard2.leader, tag=208875406
   [junit4]   2> 736230 INFO  (coreCloseExecutor-782-thread-1) [n:127.0.0.1:49822_solr c:foo s:shard1 r:core_node6 x:foo_shard1_replica_n4] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.foo.shard1.leader, tag=1261798205
   [junit4]   2> 736230 INFO  (coreCloseExecutor-782-thread-5) [n:127.0.0.1:49822_solr c:localShardsTestColl s:shard3 r:core_node15 x:localShardsTestColl_shard3_replica_n12] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard3.leader, tag=1548526523
   [junit4]   2> 736279 INFO  (coreCloseExecutor-783-thread-7) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard1 r:core_node5 x:localShardsTestColl_shard1_replica_n2] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.localShardsTestColl.shard1.replica_n2, tag=1040897483
   [junit4]   2> 736280 INFO  (coreCloseExecutor-783-thread-7) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard1 r:core_node5 x:localShardsTestColl_shard1_replica_n2] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@1f8cc0f4: rootName = solr_53345, domain = solr.core.localShardsTestColl.shard1.replica_n2, service url = null, agent id = null] for registry solr.core.localShardsTestColl.shard1.replica_n2 / com.codahale.metrics.MetricRegistry@4ff008d1
   [junit4]   2> 736386 INFO  (coreCloseExecutor-783-thread-8) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard2 r:core_node11 x:localShardsTestColl_shard2_replica_n8] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.localShardsTestColl.shard2.replica_n8, tag=333522217
   [junit4]   2> 736386 INFO  (coreCloseExecutor-783-thread-8) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard2 r:core_node11 x:localShardsTestColl_shard2_replica_n8] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@2f480927: rootName = solr_53345, domain = solr.core.localShardsTestColl.shard2.replica_n8, service url = null, agent id = null] for registry solr.core.localShardsTestColl.shard2.replica_n8 / com.codahale.metrics.MetricRegistry@62bdae0d
   [junit4]   2> 736408 INFO  (coreCloseExecutor-783-thread-8) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard2 r:core_node11 x:localShardsTestColl_shard2_replica_n8] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard2.leader, tag=333522217
   [junit4]   2> 736415 INFO  (coreCloseExecutor-783-thread-4) [n:127.0.0.1:53345_solr c:2nd_collection s:shard2 r:core_node4 x:2nd_collection_shard2_replica_n3] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.2nd_collection.shard2.leader, tag=1980797789
   [junit4]   2> 736416 INFO  (coreCloseExecutor-783-thread-7) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard1 r:core_node5 x:localShardsTestColl_shard1_replica_n2] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard1.leader, tag=1040897483
   [junit4]   2> 736426 INFO  (coreCloseExecutor-784-thread-5) [n:127.0.0.1:48072_solr c:localShardsTestColl s:shard1 r:core_node7 x:localShardsTestColl_shard1_replica_n4] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard1.leader, tag=1125629629
   [junit4]   2> 736427 INFO  (coreCloseExecutor-783-thread-6) [n:127.0.0.1:53345_solr c:localShardsTestColl s:shard3 r:core_node17 x:localShardsTestColl_shard3_replica_n14] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard3.leader, tag=847046484
   [junit4]   2> 736454 INFO  (coreCloseExecutor-784-thread-1) [n:127.0.0.1:48072_solr c:collection1 s:shard1 r:core_node2 x:collection1_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.collection1.shard1.leader, tag=1665412270
   [junit4]   2> 736454 INFO  (coreCloseExecutor-784-thread-3) [n:127.0.0.1:48072_solr c:localShardsTestColl s:shard3 r:core_node18 x:localShardsTestColl_shard3_replica_n16] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard3.leader, tag=56980734
   [junit4]   2> 736455 INFO  (coreCloseExecutor-784-thread-4) [n:127.0.0.1:48072_solr c:localShardsTestColl s:shard2 r:core_node13 x:localShardsTestColl_shard2_replica_n10] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.localShardsTestColl.shard2.leader, tag=1904157904
   [junit4]   2> 736456 INFO  (coreCloseExecutor-784-thread-2) [n:127.0.0.1:48072_solr c:foo s:shard1 r:core_node3 x:foo_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.foo.shard1.leader, tag=2000090940
   [junit4]   2> 737260 INFO  (jetty-closer-230-thread-2) [    ] o.a.s.c.Overseer Overseer (id=99194007766433799-127.0.0.1:48072_solr-n_0000000000) closing
   [junit4]   2> 737260 INFO  (OverseerStateUpdate-99194007766433799-127.0.0.1:48072_solr-n_0000000000) [n:127.0.0.1:48072_solr    ] o.a.s.c.Overseer Overseer Loop exiting : 127.0.0.1:48072_solr
   [junit4]   2> 737263 INFO  (jetty-closer-230-thread-3) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@7cdc7510{/solr,null,UNAVAILABLE}
   [junit4]   2> 737263 WARN  (OverseerAutoScalingTriggerThread-99194007766433799-127.0.0.1:48072_solr-n_0000000000) [n:127.0.0.1:48072_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 737350 INFO  (jetty-closer-230-thread-1) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@48194514{/solr,null,UNAVAILABLE}
   [junit4]   2> 737366 INFO  (jetty-closer-230-thread-2) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@5eec7d30{/solr,null,UNAVAILABLE}
   [junit4]   2> 737415 ERROR (SUITE-CloudSolrClientTest-seed#[A6AEA9AA8465DB93]-worker) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 737415 INFO  (SUITE-CloudSolrClientTest-seed#[A6AEA9AA8465DB93]-worker) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:41727 41727
   [junit4]   2> 737541 INFO  (Thread-275) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:41727 41727
   [junit4]   2> 737558 WARN  (Thread-275) [    ] o.a.s.c.ZkTestServer Watch limit violations: 
   [junit4]   2> Maximum concurrent create/delete watches above limit:
   [junit4]   2> 
   [junit4]   2> 	7	/solr/clusterprops.json
   [junit4]   2> 	7	/solr/aliases.json
   [junit4]   2> 	3	/solr/security.json
   [junit4]   2> 	3	/solr/configs/conf
   [junit4]   2> 
   [junit4]   2> Maximum concurrent data watches above limit:
   [junit4]   2> 
   [junit4]   2> 	37	/solr/collections/localShardsTestColl/state.json
   [junit4]   2> 	29	/solr/collections/foo/state.json
   [junit4]   2> 	18	/solr/collections/2nd_collection/state.json
   [junit4]   2> 	14	/solr/collections/collection1/state.json
   [junit4]   2> 	14	/solr/collections/nemesis/state.json
   [junit4]   2> 	7	/solr/clusterstate.json
   [junit4]   2> 	6	/solr/collections/stale_state_test_col/state.json
   [junit4]   2> 	6	/solr/collections/overwrite/state.json
   [junit4]   2> 	2	/solr/collections/localShardsTestColl/leader_elect/shard2/election/99194007766433800-core_node11-n_0000000000
   [junit4]   2> 	2	/solr/collections/localShardsTestColl/leader_elect/shard3/election/99194007766433800-core_node17-n_0000000000
   [junit4]   2> 
   [junit4]   2> Maximum concurrent children watches above limit:
   [junit4]   2> 
   [junit4]   2> 	7	/solr/live_nodes
   [junit4]   2> 	7	/solr/collections
   [junit4]   2> 
   [junit4]   2> NOTE: leaving temporary files on disk at: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-solrj/test/J2/temp/solr.client.solrj.impl.CloudSolrClientTest_A6AEA9AA8465DB93-001
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70), sim=RandomSimilarity(queryNorm=false): {}, locale=en-ZA, timezone=Asia/Tehran
   [junit4]   2> NOTE: Linux 3.13.0-88-generic amd64/Oracle Corporation 1.8.0_144 (64-bit)/cpus=4,threads=1,free=235929744,total=418906112
   [junit4]   2> NOTE: All tests run in this JVM: [LessThanEqualToEvaluatorTest, CommonParamsTest, TestCoreAdmin, SolrExampleBinaryTest, CloudSolrClientBuilderTest, RegressionEvaluatorTest, CoalesceEvaluatorTest, OperationsTest, TestCollectionStateWatchers, SineEvaluatorTest, GreaterThanEqualToEvaluatorTest, DivideEvaluatorTest, StreamExpressionToExplanationTest, TestJavaBinCodec, SolrExampleJettyTest, JdbcDriverTest, ArrayEvaluatorTest, PowerEvaluatorTest, HttpSolrClientBuilderTest, JettyWebappTest, HyperbolicSineEvaluatorTest, TangentEvaluatorTest, TestCloudSolrClientConnections, ExclusiveOrEvaluatorTest, TestSpellCheckResponse, SolrParamTest, QueryResponseTest, TestNamedListCodec, SolrQueryTest, TestHash, ModifiableSolrParamsTest, TestFastInputStream, TestXMLEscaping, DocumentAnalysisResponseTest, SolrDocumentTest, SolrExceptionTest, TestUpdateRequestCodec, FieldAnalysisResponseTest, NamedListTest, AnlysisResponseBaseTest, FacetFieldTest, UsingSolrJRefGuideExamplesTest, TestLBHttpSolrClient, TestPolicy, BasicHttpSolrClientTest, CloudSolrClientTest]
   [junit4] Completed [82/146 (1!)] on J2 in 127.10s, 16 tests, 2 errors <<< FAILURES!

[...truncated 46637 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 14 - Still unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/14/

3 tests failed.
FAILED:  org.apache.solr.cloud.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests

Error Message:
No live SolrServers available to handle this request:[http://127.0.0.1:39573/solr/myalias, http://127.0.0.1:38788/solr/myalias]

Stack Trace:
org.apache.solr.client.solrj.SolrServerException: No live SolrServers available to handle this request:[http://127.0.0.1:39573/solr/myalias, http://127.0.0.1:38788/solr/myalias]
	at __randomizedtesting.SeedInfo.seed([F2C338891A09F7F0:1687043EBCA1B92F]:0)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:462)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1103)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrClient.query(SolrClient.java:942)
	at org.apache.solr.cloud.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests(CollectionsAPIAsyncDistributedZkTest.java:150)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at http://127.0.0.1:39573/solr/myalias: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/myalias/select. Reason:
<pre>    Can not find: /solr/myalias/select</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:607)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	... 45 more


FAILED:  org.apache.solr.cloud.LeaderFailoverAfterPartitionTest.test

Error Message:
Expected 2 of 3 replicas to be active but only found 1; [core_node5:{"core":"c8n_1x3_lf_shard1_replica_t3","base_url":"http://127.0.0.1:42010","node_name":"127.0.0.1:42010_","state":"active","type":"TLOG","leader":"true"}]; clusterState: DocCollection(c8n_1x3_lf//clusterstate.json/29)={   "pullReplicas":"0",   "replicationFactor":"1",   "shards":{"shard1":{       "range":"80000000-7fffffff",       "state":"active",       "replicas":{         "core_node2":{           "core":"c8n_1x3_lf_shard1_replica_t1",           "base_url":"http://127.0.0.1:39934",           "node_name":"127.0.0.1:39934_",           "state":"down",           "type":"TLOG"},         "core_node5":{           "core":"c8n_1x3_lf_shard1_replica_t3",           "base_url":"http://127.0.0.1:42010",           "node_name":"127.0.0.1:42010_",           "state":"active",           "type":"TLOG",           "leader":"true"},         "core_node6":{           "state":"down",           "base_url":"http://127.0.0.1:41787",           "core":"c8n_1x3_lf_shard1_replica_t4",           "node_name":"127.0.0.1:41787_",           "type":"TLOG"}}}},   "router":{"name":"compositeId"},   "maxShardsPerNode":"1",   "autoAddReplicas":"false",   "nrtReplicas":"0",   "tlogReplicas":"3"}

Stack Trace:
java.lang.AssertionError: Expected 2 of 3 replicas to be active but only found 1; [core_node5:{"core":"c8n_1x3_lf_shard1_replica_t3","base_url":"http://127.0.0.1:42010","node_name":"127.0.0.1:42010_","state":"active","type":"TLOG","leader":"true"}]; clusterState: DocCollection(c8n_1x3_lf//clusterstate.json/29)={
  "pullReplicas":"0",
  "replicationFactor":"1",
  "shards":{"shard1":{
      "range":"80000000-7fffffff",
      "state":"active",
      "replicas":{
        "core_node2":{
          "core":"c8n_1x3_lf_shard1_replica_t1",
          "base_url":"http://127.0.0.1:39934",
          "node_name":"127.0.0.1:39934_",
          "state":"down",
          "type":"TLOG"},
        "core_node5":{
          "core":"c8n_1x3_lf_shard1_replica_t3",
          "base_url":"http://127.0.0.1:42010",
          "node_name":"127.0.0.1:42010_",
          "state":"active",
          "type":"TLOG",
          "leader":"true"},
        "core_node6":{
          "state":"down",
          "base_url":"http://127.0.0.1:41787",
          "core":"c8n_1x3_lf_shard1_replica_t4",
          "node_name":"127.0.0.1:41787_",
          "type":"TLOG"}}}},
  "router":{"name":"compositeId"},
  "maxShardsPerNode":"1",
  "autoAddReplicas":"false",
  "nrtReplicas":"0",
  "tlogReplicas":"3"}
	at __randomizedtesting.SeedInfo.seed([F2C338891A09F7F0:7A970753B4F59A08]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.LeaderFailoverAfterPartitionTest.testRf3WithLeaderFailover(LeaderFailoverAfterPartitionTest.java:169)
	at org.apache.solr.cloud.LeaderFailoverAfterPartitionTest.test(LeaderFailoverAfterPartitionTest.java:56)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.PeerSyncReplicationTest.test

Error Message:
expected:<0> but was:<1>

Stack Trace:
java.lang.AssertionError: expected:<0> but was:<1>
	at __randomizedtesting.SeedInfo.seed([F2C338891A09F7F0:7A970753B4F59A08]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.cloud.PeerSyncReplicationTest.test(PeerSyncReplicationTest.java:202)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 11860 lines...]
   [junit4] Suite: org.apache.solr.cloud.PeerSyncReplicationTest
   [junit4]   2> 864922 INFO  (SUITE-PeerSyncReplicationTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/init-core-data-001
   [junit4]   2> 864923 WARN  (SUITE-PeerSyncReplicationTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=2 numCloses=2
   [junit4]   2> 864923 INFO  (SUITE-PeerSyncReplicationTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 864924 INFO  (SUITE-PeerSyncReplicationTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (true) via: @org.apache.solr.util.RandomizeSSL(reason=, ssl=NaN, value=NaN, clientAuth=NaN)
   [junit4]   2> 864924 INFO  (SUITE-PeerSyncReplicationTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.s.BaseDistributedSearchTestCase Setting hostContext system property: /
   [junit4]   2> 864981 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 865023 INFO  (Thread-271) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 865023 INFO  (Thread-271) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 865089 ERROR (Thread-271) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 865124 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ZkTestServer start zk server on port:46294
   [junit4]   2> 865223 INFO  (zkConnectionManagerCallback-373-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 865349 INFO  (zkConnectionManagerCallback-375-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 865365 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/solrconfig-tlog.xml to /configs/conf1/solrconfig.xml
   [junit4]   2> 865366 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/schema.xml to /configs/conf1/schema.xml
   [junit4]   2> 865368 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/solrconfig.snippet.randomindexconfig.xml to /configs/conf1/solrconfig.snippet.randomindexconfig.xml
   [junit4]   2> 865368 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/stopwords.txt to /configs/conf1/stopwords.txt
   [junit4]   2> 865386 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/protwords.txt to /configs/conf1/protwords.txt
   [junit4]   2> 865387 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/currency.xml to /configs/conf1/currency.xml
   [junit4]   2> 865388 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/enumsConfig.xml to /configs/conf1/enumsConfig.xml
   [junit4]   2> 865402 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/open-exchange-rates.json to /configs/conf1/open-exchange-rates.json
   [junit4]   2> 865402 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/mapping-ISOLatin1Accent.txt to /configs/conf1/mapping-ISOLatin1Accent.txt
   [junit4]   2> 865403 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/old_synonyms.txt to /configs/conf1/old_synonyms.txt
   [junit4]   2> 865404 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractZkTestCase put /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/core/src/test-files/solr/collection1/conf/synonyms.txt to /configs/conf1/synonyms.txt
   [junit4]   2> 865405 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractFullDistribZkTestBase Will use NRT replicas unless explicitly asked otherwise
   [junit4]   2> 866709 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 866834 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@411ffa19{/,null,AVAILABLE}
   [junit4]   2> 866853 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@2fd30db7{HTTP/1.1,[http/1.1]}{127.0.0.1:34042}
   [junit4]   2> 866853 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server Started @879290ms
   [junit4]   2> 866854 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {solr.data.dir=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/tempDir-001/control/data, hostContext=/, hostPort=34042, coreRootDirectory=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/../../../../../../../../../../home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/control-001/cores}
   [junit4]   2> 866854 ERROR (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 866854 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 866854 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 866907 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 866907 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-16T22:29:10.948Z
   [junit4]   2> 866997 INFO  (zkConnectionManagerCallback-377-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 867035 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter Loading solr.xml from SolrHome (not found in ZooKeeper)
   [junit4]   2> 867035 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Loading container configuration from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/control-001/solr.xml
   [junit4]   2> 867107 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverWorkLoopDelay is ignored
   [junit4]   2> 867107 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverBadNodeExpiration is ignored
   [junit4]   2> 867108 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig MBean server found: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747, but no JMX reporters were configured - adding default JMX reporter.
   [junit4]   2> 867145 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:46294/solr
   [junit4]   2> 867383 INFO  (zkConnectionManagerCallback-381-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 867489 INFO  (zkConnectionManagerCallback-383-thread-1-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 868095 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 868095 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:34042_
   [junit4]   2> 868129 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.c.Overseer Overseer (id=99186334046683140-127.0.0.1:34042_-n_0000000000) starting
   [junit4]   2> 868296 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:34042_
   [junit4]   2> 868314 INFO  (OverseerStateUpdate-99186334046683140-127.0.0.1:34042_-n_0000000000) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 869269 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 869432 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 869433 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 869467 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:34042_    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/../../../../../../../../../../home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/control-001/cores
   [junit4]   2> 869646 INFO  (zkConnectionManagerCallback-389-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 869668 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 869668 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:46294/solr ready
   [junit4]   2> 869724 INFO  (qtp1432858148-1627) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=1&collection.configName=conf1&name=control_collection&nrtReplicas=1&action=CREATE&numShards=1&createNodeSet=127.0.0.1:34042_&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 869845 INFO  (OverseerThreadFactory-681-thread-1-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.CreateCollectionCmd Create collection control_collection
   [junit4]   2> 870023 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&newCollection=true&name=control_collection_shard1_replica_n1&action=CREATE&numShards=1&collection=control_collection&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 870023 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 4 transient cores
   [junit4]   2> 870163 INFO  (zkCallback-382-thread-1-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/control_collection/state.json] for collection [control_collection] has occurred - updating... (live nodes size: [1])
   [junit4]   2> 871284 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 871502 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.s.IndexSchema [control_collection_shard1_replica_n1] Schema name=test
   [junit4]   2> 872178 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.s.IndexSchema Loaded schema test/1.0 with uniqueid field id
   [junit4]   2> 872343 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.CoreContainer Creating SolrCore 'control_collection_shard1_replica_n1' using configuration from collection control_collection, trusted=true
   [junit4]   2> 872344 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.core.control_collection.shard1.replica_n1' (registry 'solr.core.control_collection.shard1.replica_n1') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 872344 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 872344 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SolrCore [[control_collection_shard1_replica_n1] ] Opening new SolrCore at [/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/control-001/cores/control_collection_shard1_replica_n1], dataDir=[/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/../../../../../../../../../../home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/control-001/cores/control_collection_shard1_replica_n1/data/]
   [junit4]   2> 872360 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.LogDocMergePolicy: [LogDocMergePolicy: minMergeSize=1000, mergeFactor=36, maxMergeSize=9223372036854775807, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=true, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.8807027107780294]
   [junit4]   2> 872411 WARN  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.RequestHandlers INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,attributes = {initParams=a, name=/dump, class=DumpRequestHandler},args = {defaults={a=A,b=B}}}
   [junit4]   2> 872628 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.UpdateHandler Using UpdateLog implementation: org.apache.solr.update.UpdateLog
   [junit4]   2> 872628 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.UpdateLog Initializing UpdateLog: dataDir= defaultSyncLevel=FLUSH numRecordsToKeep=1000 maxNumLogsToKeep=10 numVersionBuckets=65536
   [junit4]   2> 872629 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.CommitTracker Hard AutoCommit: disabled
   [junit4]   2> 872629 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.CommitTracker Soft AutoCommit: disabled
   [junit4]   2> 872631 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=42, maxMergeAtOnceExplicit=38, maxMergedSegmentMB=66.494140625, floorSegmentMB=1.2265625, forceMergeDeletesPctAllowed=11.20150847438964, segmentsPerTier=20.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.5160383347538873
   [junit4]   2> 872632 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.s.SolrIndexSearcher Opening [Searcher@50b6b253[control_collection_shard1_replica_n1] main]
   [junit4]   2> 872651 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.r.ManagedResourceStorage Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 872651 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.r.ManagedResourceStorage Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 872652 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.h.ReplicationHandler Commits will be reserved for 10000ms.
   [junit4]   2> 872674 INFO  (searcherExecutor-684-thread-1-processing-n:127.0.0.1:34042_ x:control_collection_shard1_replica_n1 s:shard1 c:control_collection) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SolrCore [control_collection_shard1_replica_n1] Registered new searcher Searcher@50b6b253[control_collection_shard1_replica_n1] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 872685 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.u.UpdateLog Could not find max version in index or recent updates, using new clock 1586981352742322176
   [junit4]   2> 872710 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.ShardLeaderElectionContext Enough replicas found to continue.
   [junit4]   2> 872711 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.ShardLeaderElectionContext I may be the new leader - try and sync
   [junit4]   2> 872711 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SyncStrategy Sync replicas to http://127.0.0.1:34042/control_collection_shard1_replica_n1/
   [junit4]   2> 872711 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SyncStrategy Sync Success - now sync replicas to me
   [junit4]   2> 872711 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.SyncStrategy http://127.0.0.1:34042/control_collection_shard1_replica_n1/ has no replicas
   [junit4]   2> 872711 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.ShardLeaderElectionContext Found all replicas participating in election, clear LIR
   [junit4]   2> 872713 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.ShardLeaderElectionContext I am the new leader: http://127.0.0.1:34042/control_collection_shard1_replica_n1/ shard1
   [junit4]   2> 872796 INFO  (zkCallback-382-thread-2-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/control_collection/state.json] for collection [control_collection] has occurred - updating... (live nodes size: [1])
   [junit4]   2> 872906 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.c.ZkController I am the leader, no recovery necessary
   [junit4]   2> 872908 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_ c:control_collection s:shard1  x:control_collection_shard1_replica_n1] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/cores params={qt=/admin/cores&collection.configName=conf1&newCollection=true&name=control_collection_shard1_replica_n1&action=CREATE&numShards=1&collection=control_collection&shard=shard1&wt=javabin&version=2&replicaType=NRT} status=0 QTime=2885
   [junit4]   2> 873016 INFO  (qtp1432858148-1627) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Wait for new collection to be active for at most 30 seconds. Check all shard replicas
   [junit4]   2> 873018 INFO  (OverseerCollectionConfigSetProcessor-99186334046683140-127.0.0.1:34042_-n_0000000000) [n:127.0.0.1:34042_    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000000 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 873124 INFO  (zkCallback-382-thread-2-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/control_collection/state.json] for collection [control_collection] has occurred - updating... (live nodes size: [1])
   [junit4]   2> 874019 INFO  (qtp1432858148-1627) [n:127.0.0.1:34042_    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={replicationFactor=1&collection.configName=conf1&name=control_collection&nrtReplicas=1&action=CREATE&numShards=1&createNodeSet=127.0.0.1:34042_&wt=javabin&version=2} status=0 QTime=4295
   [junit4]   2> 874076 INFO  (zkConnectionManagerCallback-393-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 874077 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 874078 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:46294/solr ready
   [junit4]   2> 874078 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ChaosMonkey monkey: init - expire sessions:false cause connection loss:false
   [junit4]   2> 874079 INFO  (qtp1432858148-1630) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=1&collection.configName=conf1&name=collection1&nrtReplicas=1&action=CREATE&numShards=1&createNodeSet=&stateFormat=1&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 874134 INFO  (OverseerThreadFactory-681-thread-2-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.CreateCollectionCmd Create collection collection1
   [junit4]   2> 874135 WARN  (OverseerThreadFactory-681-thread-2-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.CreateCollectionCmd It is unusual to create a collection (collection1) without cores.
   [junit4]   2> 874386 INFO  (qtp1432858148-1630) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Wait for new collection to be active for at most 30 seconds. Check all shard replicas
   [junit4]   2> 874386 INFO  (qtp1432858148-1630) [n:127.0.0.1:34042_    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={replicationFactor=1&collection.configName=conf1&name=collection1&nrtReplicas=1&action=CREATE&numShards=1&createNodeSet=&stateFormat=1&wt=javabin&version=2} status=0 QTime=306
   [junit4]   2> 875381 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractFullDistribZkTestBase create jetty 1 in directory /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-1-001 of type NRT
   [junit4]   2> 875382 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 875526 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@51f0cf20{/,null,AVAILABLE}
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@23380481{HTTP/1.1,[http/1.1]}{127.0.0.1:35310}
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server Started @887963ms
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {solr.data.dir=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/tempDir-001/jetty1, replicaType=NRT, solrconfig=solrconfig.xml, hostContext=/, hostPort=35310, coreRootDirectory=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-1-001/cores}
   [junit4]   2> 875527 ERROR (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 875527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-16T22:29:19.568Z
   [junit4]   2> 875575 INFO  (zkConnectionManagerCallback-395-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 875595 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter Loading solr.xml from SolrHome (not found in ZooKeeper)
   [junit4]   2> 875595 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Loading container configuration from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-1-001/solr.xml
   [junit4]   2> 875599 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverWorkLoopDelay is ignored
   [junit4]   2> 875599 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverBadNodeExpiration is ignored
   [junit4]   2> 875649 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig MBean server found: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747, but no JMX reporters were configured - adding default JMX reporter.
   [junit4]   2> 875706 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:46294/solr
   [junit4]   2> 875831 INFO  (zkConnectionManagerCallback-399-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 875974 INFO  (zkConnectionManagerCallback-401-thread-1-processing-n:127.0.0.1:35310_) [n:127.0.0.1:35310_    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 876035 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 876037 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 876051 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:35310_
   [junit4]   2> 876088 INFO  (zkCallback-392-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 876088 INFO  (zkCallback-382-thread-2-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 876162 INFO  (OverseerCollectionConfigSetProcessor-99186334046683140-127.0.0.1:34042_-n_0000000000) [n:127.0.0.1:34042_    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000002 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 876185 INFO  (zkCallback-400-thread-1-processing-n:127.0.0.1:35310_) [n:127.0.0.1:35310_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 876470 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 876545 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 876545 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 876565 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:35310_    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-1-001/cores
   [junit4]   2> 876786 INFO  (qtp1432858148-1624) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :addreplica with params node=127.0.0.1:35310_&action=ADDREPLICA&collection=collection1&shard=shard1&type=NRT&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 876840 INFO  (OverseerThreadFactory-681-thread-3-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.AddReplicaCmd Node Identified 127.0.0.1:35310_ for creating new replica
   [junit4]   2> 876873 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&name=collection1_shard1_replica_n21&action=CREATE&collection=collection1&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 876874 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 4 transient cores
   [junit4]   2> 878063 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 878136 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.s.IndexSchema [collection1_shard1_replica_n21] Schema name=test
   [junit4]   2> 878921 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.s.IndexSchema Loaded schema test/1.0 with uniqueid field id
   [junit4]   2> 879037 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.CoreContainer Creating SolrCore 'collection1_shard1_replica_n21' using configuration from collection collection1, trusted=true
   [junit4]   2> 879038 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.core.collection1.shard1.replica_n21' (registry 'solr.core.collection1.shard1.replica_n21') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 879038 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 879038 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SolrCore [[collection1_shard1_replica_n21] ] Opening new SolrCore at [/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-1-001/cores/collection1_shard1_replica_n21], dataDir=[/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-1-001/cores/collection1_shard1_replica_n21/data/]
   [junit4]   2> 879074 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.LogDocMergePolicy: [LogDocMergePolicy: minMergeSize=1000, mergeFactor=36, maxMergeSize=9223372036854775807, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=true, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.8807027107780294]
   [junit4]   2> 879110 WARN  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.RequestHandlers INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,attributes = {initParams=a, name=/dump, class=DumpRequestHandler},args = {defaults={a=A,b=B}}}
   [junit4]   2> 879304 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.UpdateHandler Using UpdateLog implementation: org.apache.solr.update.UpdateLog
   [junit4]   2> 879304 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.UpdateLog Initializing UpdateLog: dataDir= defaultSyncLevel=FLUSH numRecordsToKeep=1000 maxNumLogsToKeep=10 numVersionBuckets=65536
   [junit4]   2> 879305 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.CommitTracker Hard AutoCommit: disabled
   [junit4]   2> 879305 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.CommitTracker Soft AutoCommit: disabled
   [junit4]   2> 879306 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=42, maxMergeAtOnceExplicit=38, maxMergedSegmentMB=66.494140625, floorSegmentMB=1.2265625, forceMergeDeletesPctAllowed=11.20150847438964, segmentsPerTier=20.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.5160383347538873
   [junit4]   2> 879307 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.s.SolrIndexSearcher Opening [Searcher@74e28072[collection1_shard1_replica_n21] main]
   [junit4]   2> 879321 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.r.ManagedResourceStorage Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 879321 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.r.ManagedResourceStorage Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 879322 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.h.ReplicationHandler Commits will be reserved for 10000ms.
   [junit4]   2> 879322 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.u.UpdateLog Could not find max version in index or recent updates, using new clock 1586981359701721088
   [junit4]   2> 879343 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.ShardLeaderElectionContext Enough replicas found to continue.
   [junit4]   2> 879343 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.ShardLeaderElectionContext I may be the new leader - try and sync
   [junit4]   2> 879343 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SyncStrategy Sync replicas to http://127.0.0.1:35310/collection1_shard1_replica_n21/
   [junit4]   2> 879343 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SyncStrategy Sync Success - now sync replicas to me
   [junit4]   2> 879343 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SyncStrategy http://127.0.0.1:35310/collection1_shard1_replica_n21/ has no replicas
   [junit4]   2> 879343 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.ShardLeaderElectionContext Found all replicas participating in election, clear LIR
   [junit4]   2> 879357 INFO  (searcherExecutor-695-thread-1-processing-n:127.0.0.1:35310_ x:collection1_shard1_replica_n21 s:shard1 c:collection1) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.SolrCore [collection1_shard1_replica_n21] Registered new searcher Searcher@74e28072[collection1_shard1_replica_n21] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 879377 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.ShardLeaderElectionContext I am the new leader: http://127.0.0.1:35310/collection1_shard1_replica_n21/ shard1
   [junit4]   2> 879438 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.c.ZkController I am the leader, no recovery necessary
   [junit4]   2> 879440 INFO  (qtp420806349-1676) [n:127.0.0.1:35310_ c:collection1 s:shard1  x:collection1_shard1_replica_n21] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/cores params={qt=/admin/cores&collection.configName=conf1&name=collection1_shard1_replica_n21&action=CREATE&collection=collection1&shard=shard1&wt=javabin&version=2&replicaType=NRT} status=0 QTime=2567
   [junit4]   2> 879455 INFO  (qtp1432858148-1624) [n:127.0.0.1:34042_    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={node=127.0.0.1:35310_&action=ADDREPLICA&collection=collection1&shard=shard1&type=NRT&wt=javabin&version=2} status=0 QTime=2669
   [junit4]   2> 880330 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractFullDistribZkTestBase create jetty 2 in directory /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-2-001 of type NRT
   [junit4]   2> 880331 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 880332 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@61f3194d{/,null,AVAILABLE}
   [junit4]   2> 880365 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@30d8ac73{HTTP/1.1,[http/1.1]}{127.0.0.1:43059}
   [junit4]   2> 880365 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server Started @892802ms
   [junit4]   2> 880365 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {solr.data.dir=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/tempDir-001/jetty2, solrconfig=solrconfig.xml, hostContext=/, hostPort=43059, coreRootDirectory=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-2-001/cores}
   [junit4]   2> 880366 ERROR (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 880382 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 880382 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 880382 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 880382 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-16T22:29:24.423Z
   [junit4]   2> 880487 INFO  (zkConnectionManagerCallback-404-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 880527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter Loading solr.xml from SolrHome (not found in ZooKeeper)
   [junit4]   2> 880527 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Loading container configuration from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-2-001/solr.xml
   [junit4]   2> 880531 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverWorkLoopDelay is ignored
   [junit4]   2> 880531 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverBadNodeExpiration is ignored
   [junit4]   2> 880674 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig MBean server found: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747, but no JMX reporters were configured - adding default JMX reporter.
   [junit4]   2> 880686 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:46294/solr
   [junit4]   2> 880714 INFO  (zkConnectionManagerCallback-408-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 880881 INFO  (OverseerCollectionConfigSetProcessor-99186334046683140-127.0.0.1:34042_-n_0000000000) [n:127.0.0.1:34042_    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000004 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 880881 INFO  (zkConnectionManagerCallback-410-thread-1-processing-n:127.0.0.1:43059_) [n:127.0.0.1:43059_    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 880933 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (2)
   [junit4]   2> 880935 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 880936 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:43059_
   [junit4]   2> 881014 INFO  (zkCallback-400-thread-1-processing-n:127.0.0.1:35310_) [n:127.0.0.1:35310_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 881026 INFO  (zkCallback-392-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 881026 INFO  (zkCallback-382-thread-2-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 881026 INFO  (zkCallback-409-thread-1-processing-n:127.0.0.1:43059_) [n:127.0.0.1:43059_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 881357 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 881448 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 881448 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 881482 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:43059_    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-2-001/cores
   [junit4]   2> 881730 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :addreplica with params node=127.0.0.1:43059_&action=ADDREPLICA&collection=collection1&shard=shard1&type=NRT&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 881733 INFO  (OverseerThreadFactory-681-thread-4-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.AddReplicaCmd Node Identified 127.0.0.1:43059_ for creating new replica
   [junit4]   2> 881799 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&name=collection1_shard1_replica_n23&action=CREATE&collection=collection1&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 881799 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 4 transient cores
   [junit4]   2> 882924 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 882983 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.s.IndexSchema [collection1_shard1_replica_n23] Schema name=test
   [junit4]   2> 883801 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.s.IndexSchema Loaded schema test/1.0 with uniqueid field id
   [junit4]   2> 883913 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.CoreContainer Creating SolrCore 'collection1_shard1_replica_n23' using configuration from collection collection1, trusted=true
   [junit4]   2> 883914 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.core.collection1.shard1.replica_n23' (registry 'solr.core.collection1.shard1.replica_n23') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 883914 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 883914 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.SolrCore [[collection1_shard1_replica_n23] ] Opening new SolrCore at [/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-2-001/cores/collection1_shard1_replica_n23], dataDir=[/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-2-001/cores/collection1_shard1_replica_n23/data/]
   [junit4]   2> 883949 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.LogDocMergePolicy: [LogDocMergePolicy: minMergeSize=1000, mergeFactor=36, maxMergeSize=9223372036854775807, maxMergeSizeForForcedMerge=9223372036854775807, calibrateSizeByDeletes=true, maxMergeDocs=2147483647, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.8807027107780294]
   [junit4]   2> 883998 WARN  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.RequestHandlers INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,attributes = {initParams=a, name=/dump, class=DumpRequestHandler},args = {defaults={a=A,b=B}}}
   [junit4]   2> 884287 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.UpdateHandler Using UpdateLog implementation: org.apache.solr.update.UpdateLog
   [junit4]   2> 884287 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.UpdateLog Initializing UpdateLog: dataDir= defaultSyncLevel=FLUSH numRecordsToKeep=1000 maxNumLogsToKeep=10 numVersionBuckets=65536
   [junit4]   2> 884305 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.CommitTracker Hard AutoCommit: disabled
   [junit4]   2> 884305 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.CommitTracker Soft AutoCommit: disabled
   [junit4]   2> 884306 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=42, maxMergeAtOnceExplicit=38, maxMergedSegmentMB=66.494140625, floorSegmentMB=1.2265625, forceMergeDeletesPctAllowed=11.20150847438964, segmentsPerTier=20.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.5160383347538873
   [junit4]   2> 884431 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.s.SolrIndexSearcher Opening [Searcher@15ec756f[collection1_shard1_replica_n23] main]
   [junit4]   2> 884439 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.r.ManagedResourceStorage Configured ZooKeeperStorageIO with znodeBase: /configs/conf1
   [junit4]   2> 884439 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.r.ManagedResourceStorage Loaded null at path _rest_managed.json using ZooKeeperStorageIO:path=/configs/conf1
   [junit4]   2> 884440 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.h.ReplicationHandler Commits will be reserved for 10000ms.
   [junit4]   2> 884440 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.u.UpdateLog Could not find max version in index or recent updates, using new clock 1586981365068333056
   [junit4]   2> 884508 INFO  (searcherExecutor-706-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.SolrCore [collection1_shard1_replica_n23] Registered new searcher Searcher@15ec756f[collection1_shard1_replica_n23] main{ExitableDirectoryReader(UninvertingDirectoryReader())}
   [junit4]   2> 884513 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.c.ZkController Core needs to recover:collection1_shard1_replica_n23
   [junit4]   2> 884521 INFO  (qtp1104716331-1707) [n:127.0.0.1:43059_ c:collection1 s:shard1  x:collection1_shard1_replica_n23] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/cores params={qt=/admin/cores&collection.configName=conf1&name=collection1_shard1_replica_n23&action=CREATE&collection=collection1&shard=shard1&wt=javabin&version=2&replicaType=NRT} status=0 QTime=2734
   [junit4]   2> 884540 INFO  (updateExecutor-405-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.DefaultSolrCoreState Running recovery
   [junit4]   2> 884540 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Starting recovery process. recoveringAfterStartup=true
   [junit4]   2> 884554 INFO  (qtp1432858148-1625) [n:127.0.0.1:34042_    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/collections params={node=127.0.0.1:43059_&action=ADDREPLICA&collection=collection1&shard=shard1&type=NRT&wt=javabin&version=2} status=0 QTime=2823
   [junit4]   2> 884556 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy ###### startupVersions=[[]]
   [junit4]   2> 884556 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Begin buffering updates. core=[collection1_shard1_replica_n23]
   [junit4]   2> 884556 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.UpdateLog Starting to buffer updates. FSUpdateLog{state=ACTIVE, tlog=null}
   [junit4]   2> 884556 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Publishing state of core [collection1_shard1_replica_n23] as recovering, leader is [http://127.0.0.1:35310/collection1_shard1_replica_n21/] and I am [http://127.0.0.1:43059/collection1_shard1_replica_n23/]
   [junit4]   2> 884724 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Sending prep recovery command to [http://127.0.0.1:35310]; [WaitForState: action=PREPRECOVERY&core=collection1_shard1_replica_n21&nodeName=127.0.0.1:43059_&coreNodeName=core_node24&state=recovering&checkLive=true&onlyIfLeader=true&onlyIfLeaderActive=true]
   [junit4]   2> 884788 INFO  (qtp420806349-1674) [n:127.0.0.1:35310_    ] o.a.s.h.a.PrepRecoveryOp Going to wait for coreNodeName: core_node24, state: recovering, checkLive: true, onlyIfLeader: true, onlyIfLeaderActive: true, maxTime: 183 s
   [junit4]   2> 884902 INFO  (qtp420806349-1674) [n:127.0.0.1:35310_    ] o.a.s.h.a.PrepRecoveryOp In WaitForState(recovering): collection=collection1, shard=shard1, thisCore=collection1_shard1_replica_n21, leaderDoesNotNeedRecovery=false, isLeader? true, live=true, checkLive=true, currentState=recovering, localState=active, nodeName=127.0.0.1:43059_, coreNodeName=core_node24, onlyIfActiveCheckResult=false, nodeProps: core_node24:{"core":"collection1_shard1_replica_n23","base_url":"http://127.0.0.1:43059","node_name":"127.0.0.1:43059_","state":"recovering","type":"NRT"}
   [junit4]   2> 884902 INFO  (qtp420806349-1674) [n:127.0.0.1:35310_    ] o.a.s.h.a.PrepRecoveryOp Waited coreNodeName: core_node24, state: recovering, checkLive: true, onlyIfLeader: true for: 0 seconds.
   [junit4]   2> 884902 INFO  (qtp420806349-1674) [n:127.0.0.1:35310_    ] o.a.s.s.HttpSolrCall [admin] webapp=null path=/admin/cores params={nodeName=127.0.0.1:43059_&onlyIfLeaderActive=true&core=collection1_shard1_replica_n21&coreNodeName=core_node24&action=PREPRECOVERY&checkLive=true&state=recovering&onlyIfLeader=true&wt=javabin&version=2} status=0 QTime=114
   [junit4]   2> 885413 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Attempting to PeerSync from [http://127.0.0.1:35310/collection1_shard1_replica_n21/] - recoveringAfterStartup=[true]
   [junit4]   2> 885414 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.PeerSync PeerSync: core=collection1_shard1_replica_n23 url=http://127.0.0.1:43059 START replicas=[http://127.0.0.1:35310/collection1_shard1_replica_n21/] nUpdates=1000
   [junit4]   2> 885741 INFO  (OverseerCollectionConfigSetProcessor-99186334046683140-127.0.0.1:34042_-n_0000000000) [n:127.0.0.1:34042_    ] o.a.s.c.OverseerTaskQueue Response ZK path: /overseer/collection-queue-work/qnr-0000000006 doesn't exist.  Requestor may have disconnected from ZooKeeper
   [junit4]   2> 885775 INFO  (qtp420806349-1678) [n:127.0.0.1:35310_ c:collection1 s:shard1 r:core_node22 x:collection1_shard1_replica_n21] o.a.s.u.IndexFingerprint IndexFingerprint millis:185.0 result:{maxVersionSpecified=9223372036854775807, maxVersionEncountered=0, maxInHash=0, versionsHash=0, numVersions=0, numDocs=0, maxDoc=0}
   [junit4]   2> 885775 INFO  (qtp420806349-1678) [n:127.0.0.1:35310_ c:collection1 s:shard1 r:core_node22 x:collection1_shard1_replica_n21] o.a.s.c.S.Request [collection1_shard1_replica_n21]  webapp= path=/get params={distrib=false&qt=/get&getFingerprint=9223372036854775807&wt=javabin&version=2} status=0 QTime=329
   [junit4]   2> 885868 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.IndexFingerprint IndexFingerprint millis:87.0 result:{maxVersionSpecified=9223372036854775807, maxVersionEncountered=0, maxInHash=0, versionsHash=0, numVersions=0, numDocs=0, maxDoc=0}
   [junit4]   2> 885868 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.PeerSync We are already in sync. No need to do a PeerSync 
   [junit4]   2> 885868 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.DirectUpdateHandler2 start commit{,optimize=false,openSearcher=true,waitSearcher=true,expungeDeletes=false,softCommit=false,prepareCommit=false}
   [junit4]   2> 885885 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.DirectUpdateHandler2 No uncommitted changes. Skipping IW.commit.
   [junit4]   2> 885921 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.u.DirectUpdateHandler2 end_commit_flush
   [junit4]   2> 885933 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy PeerSync stage of recovery was successful.
   [junit4]   2> 885933 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Replaying updates buffered during PeerSync.
   [junit4]   2> 885933 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy No replay needed.
   [junit4]   2> 885933 INFO  (recoveryExecutor-406-thread-1-processing-n:127.0.0.1:43059_ x:collection1_shard1_replica_n23 s:shard1 c:collection1 r:core_node24) [n:127.0.0.1:43059_ c:collection1 s:shard1 r:core_node24 x:collection1_shard1_replica_n23] o.a.s.c.RecoveryStrategy Registering as Active after recovery.
   [junit4]   2> 886270 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.AbstractFullDistribZkTestBase create jetty 3 in directory /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-3-001 of type NRT
   [junit4]   2> 886289 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 886290 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@69a10862{/,null,AVAILABLE}
   [junit4]   2> 886324 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.AbstractConnector Started ServerConnector@432d2b39{HTTP/1.1,[http/1.1]}{127.0.0.1:39868}
   [junit4]   2> 886324 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.e.j.s.Server Started @898760ms
   [junit4]   2> 886324 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {solr.data.dir=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/tempDir-001/jetty3, replicaType=NRT, solrconfig=solrconfig.xml, hostContext=/, hostPort=39868, coreRootDirectory=/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-3-001/cores}
   [junit4]   2> 886324 ERROR (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 886325 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 886325 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 886325 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 886325 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-16T22:29:30.366Z
   [junit4]   2> 886453 INFO  (zkConnectionManagerCallback-414-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 886466 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.s.SolrDispatchFilter Loading solr.xml from SolrHome (not found in ZooKeeper)
   [junit4]   2> 886466 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Loading container configuration from /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-3-001/solr.xml
   [junit4]   2> 886556 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverWorkLoopDelay is ignored
   [junit4]   2> 886556 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig Configuration parameter autoReplicaFailoverBadNodeExpiration is ignored
   [junit4]   2> 886557 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.SolrXmlConfig MBean server found: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747, but no JMX reporters were configured - adding default JMX reporter.
   [junit4]   2> 886612 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:46294/solr
   [junit4]   2> 886656 INFO  (zkConnectionManagerCallback-418-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 886847 INFO  (zkConnectionManagerCallback-420-thread-1-processing-n:127.0.0.1:39868_) [n:127.0.0.1:39868_    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 886909 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 886911 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 886929 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:39868_
   [junit4]   2> 886948 INFO  (zkCallback-400-thread-1-processing-n:127.0.0.1:35310_) [n:127.0.0.1:35310_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 887010 INFO  (zkCallback-409-thread-1-processing-n:127.0.0.1:43059_) [n:127.0.0.1:43059_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 887010 INFO  (zkCallback-382-thread-1-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 887010 INFO  (zkCallback-392-thread-1) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 887124 INFO  (zkCallback-419-thread-1-processing-n:127.0.0.1:39868_) [n:127.0.0.1:39868_    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 887602 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 887712 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 887725 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2459e747
   [junit4]   2> 887745 INFO  (TEST-PeerSyncReplicationTest.test-seed#[F2C338891A09F7F0]) [n:127.0.0.1:39868_    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.PeerSyncReplicationTest_F2C338891A09F7F0-001/shard-3-001/cores
   [junit4]   2> 888005 INFO  (qtp1432858148-1627) [n:127.0.0.1:34042_    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :addreplica with params node=127.0.0.1:39868_&action=ADDREPLICA&collection=collection1&shard=shard1&type=NRT&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 888022 INFO  (OverseerThreadFactory-681-thread-5-processing-n:127.0.0.1:34042_) [n:127.0.0.1:34042_    ] o.a.s.c.AddReplicaCmd Node Identified 127.0.0.1:39868_ for creating new replica
   [junit4]   2> 888118 INFO  (qtp1249706770-1742) [n:127.0.0.1:39868_    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=conf1&name=collection1_shard1_replica_n25&action=CREATE&collection=collection1&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 888118 INFO  (qtp1249706770-1742) [n:127.0.0.1:39868_    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 4 transient cores
   [junit4]   2> 889315 INFO  (qtp1249706770-1742) [n:127.0.0.1:39868_ c:collection1 s:shard1  x:collection1_shard1_replica_n25] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 889409 INFO  (qtp1249706770-1742) [n:127.0.0.1:39868_ c:collection1 s:shard1  x:collection1_shard1_replica_n25] o.a.s.s.IndexSchema [collection1_s

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

y=solr.core.testasynccollectioncreation.shard1_1.replica0, tag=2123689561
   [junit4]   2> 5054188 INFO  (coreCloseExecutor-5599-thread-4) [n:127.0.0.1:38788_solr c:testasynccollectioncreation s:shard1_1 r:core_node10 x:testasynccollectioncreation_shard1_1_replica0] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@ceb0163: rootName = solr_38788, domain = solr.core.testasynccollectioncreation.shard1_1.replica0, service url = null, agent id = null] for registry solr.core.testasynccollectioncreation.shard1_1.replica0 / com.codahale.metrics.MetricRegistry@3a7cde3b
   [junit4]   2> 5054190 WARN  (OverseerAutoScalingTriggerThread-99186606297579525-127.0.0.1:39573_solr-n_0000000000) [n:127.0.0.1:39573_solr    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 5054316 INFO  (coreCloseExecutor-5599-thread-4) [n:127.0.0.1:38788_solr c:testasynccollectioncreation s:shard1_1 r:core_node10 x:testasynccollectioncreation_shard1_1_replica0] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testasynccollectioncreation.shard1_1.leader, tag=2123689561
   [junit4]   2> 5054318 INFO  (coreCloseExecutor-5599-thread-5) [n:127.0.0.1:38788_solr c:testAsyncOperations s:shard1 r:core_node2 x:testAsyncOperations_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.testAsyncOperations.shard1.replica_n1, tag=993133878
   [junit4]   2> 5054318 INFO  (coreCloseExecutor-5599-thread-5) [n:127.0.0.1:38788_solr c:testAsyncOperations s:shard1 r:core_node2 x:testAsyncOperations_shard1_replica_n1] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@8367a7b: rootName = solr_38788, domain = solr.core.testAsyncOperations.shard1.replica_n1, service url = null, agent id = null] for registry solr.core.testAsyncOperations.shard1.replica_n1 / com.codahale.metrics.MetricRegistry@437a69d4
   [junit4]   2> 5054327 INFO  (jetty-closer-2754-thread-2) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@3e46ca4e{/solr,null,UNAVAILABLE}
   [junit4]   2> 5054327 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16061b162d80005, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 5054328 INFO  (zkCallback-2769-thread-2-processing-n:127.0.0.1:38788_solr) [n:127.0.0.1:38788_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:38788_solr
   [junit4]   2> 5054337 INFO  (coreCloseExecutor-5599-thread-3) [n:127.0.0.1:38788_solr c:testasynccollectioncreation s:shard1_1 r:core_node8 x:testasynccollectioncreation_shard1_1_replica_n6] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testasynccollectioncreation.shard1_1.leader, tag=340817135
   [junit4]   2> 5054337 INFO  (coreCloseExecutor-5599-thread-5) [n:127.0.0.1:38788_solr c:testAsyncOperations s:shard1 r:core_node2 x:testAsyncOperations_shard1_replica_n1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.testAsyncOperations.shard1.leader, tag=993133878
   [junit4]   2> 5054387 INFO  (jetty-closer-2754-thread-1) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@5e2e3027{/solr,null,UNAVAILABLE}
   [junit4]   2> 5054388 ERROR (SUITE-CollectionsAPIAsyncDistributedZkTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 5054388 INFO  (SUITE-CollectionsAPIAsyncDistributedZkTest-seed#[F2C338891A09F7F0]-worker) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:40574 40574
   [junit4]   2> 5054774 INFO  (Thread-4762) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:40574 40574
   [junit4]   2> 5054775 WARN  (Thread-4762) [    ] o.a.s.c.ZkTestServer Watch limit violations: 
   [junit4]   2> Maximum concurrent create/delete watches above limit:
   [junit4]   2> 
   [junit4]   2> 	3	/solr/aliases.json
   [junit4]   2> 	3	/solr/clusterprops.json
   [junit4]   2> 	2	/solr/security.json
   [junit4]   2> 	2	/solr/configs/conf1
   [junit4]   2> 
   [junit4]   2> Maximum concurrent data watches above limit:
   [junit4]   2> 
   [junit4]   2> 	50	/solr/collections/testasynccollectioncreation/state.json
   [junit4]   2> 	27	/solr/collections/testAsyncOperations/state.json
   [junit4]   2> 	3	/solr/clusterstate.json
   [junit4]   2> 
   [junit4]   2> Maximum concurrent children watches above limit:
   [junit4]   2> 
   [junit4]   2> 	3	/solr/live_nodes
   [junit4]   2> 	3	/solr/collections
   [junit4]   2> 
   [junit4]   2> NOTE: leaving temporary files on disk at: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.CollectionsAPIAsyncDistributedZkTest_F2C338891A09F7F0-001
   [junit4]   2> Dec 16, 2017 11:38:58 PM com.carrotsearch.randomizedtesting.ThreadLeakControl checkThreadLeaks
   [junit4]   2> WARNING: Will linger awaiting termination of 1 leaked thread(s).
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70): {id=PostingsFormat(name=LuceneFixedGap), _route_=PostingsFormat(name=Memory)}, docValues:{}, maxPointsInLeafNode=1904, maxMBSortInHeap=7.590347205812323, sim=RandomSimilarity(queryNorm=false): {}, locale=ar-OM, timezone=Asia/Ashgabat
   [junit4]   2> NOTE: Linux 4.4.0-83-generic amd64/Oracle Corporation 1.8.0_152 (64-bit)/cpus=4,threads=1,free=239572120,total=524812288
   [junit4]   2> NOTE: All tests run in this JVM: [TestApiFramework, TestMinMaxOnMultiValuedField, TestPseudoReturnFields, DocExpirationUpdateProcessorFactoryTest, TestLeaderElectionZkExpiry, ConfigureRecoveryStrategyTest, TestRandomCollapseQParserPlugin, TestLegacyNumericRangeQueryBuilder, DeleteLastCustomShardedReplicaTest, ExitableDirectoryReaderTest, TestGraphMLResponseWriter, MoreLikeThisHandlerTest, TestSlowCompositeReaderWrapper, CircularListTest, SynonymTokenizerTest, TestHttpShardHandlerFactory, BinaryUpdateRequestHandlerTest, LukeRequestHandlerTest, TestTolerantUpdateProcessorCloud, TestConfigSetsAPIExclusivity, NumericFieldsTest, CoreAdminCreateDiscoverTest, TestCollationField, ChaosMonkeySafeLeaderWithPullReplicasTest, HdfsChaosMonkeySafeLeaderTest, FacetPivotSmallTest, TestDocSet, SolrCloudReportersTest, V2ApiIntegrationTest, TestStressReorder, TestWriterPerf, PeerSyncReplicationTest, TestSolrCLIRunExample, DistributedVersionInfoTest, ClusterStateUpdateTest, TestCloudJSONFacetJoinDomain, TestSolrCloudWithKerberosAlt, PreAnalyzedUpdateProcessorTest, TestFastWriter, TestSimpleTrackingShardHandler, SOLR749Test, TestNumericRangeQuery32, TestSimpleQParserPlugin, TestManagedSchemaAPI, TestMaxTokenLenTokenizer, ShardRoutingCustomTest, TestStressRecovery, CdcrUpdateLogTest, NotRequiredUniqueKeyTest, TestPerFieldSimilarity, LeaderFailureAfterFreshStartTest, AddReplicaTest, SolrRequestParserTest, TestCollapseQParserPlugin, SubstringBytesRefFilterTest, TestJmxIntegration, SolrCoreMetricManagerTest, TestLegacyFieldCache, TestSolrConfigHandler, TestCustomSort, TestAtomicUpdateErrorCases, ZkSolrClientTest, NodeLostTriggerTest, QueryEqualityTest, TestLRUStatsCache, TestUseDocValuesAsStored2, RollingRestartTest, TlogReplayBufferedWhileIndexingTest, HLLSerializationTest, HdfsRecoverLeaseTest, TestSchemaSimilarityResource, OverriddenZkACLAndCredentialsProvidersTest, SolrCmdDistributorTest, TestSolr4Spatial, TestXmlQParserPlugin, TestBM25SimilarityFactory, OpenCloseCoreStressTest, UpdateLogTest, HdfsSyncSliceTest, TestCoreAdminApis, OpenExchangeRatesOrgProviderTest, ConcurrentDeleteAndCreateCollectionTest, TestPayloadCheckQParserPlugin, TestEmbeddedSolrServerAdminHandler, TestSolrCoreParser, SpellingQueryConverterTest, TestSolrCoreSnapshots, ReplaceNodeTest, MBeansHandlerTest, SampleTest, TestRecoveryHdfs, TestStressUserVersions, TestConfigSetProperties, TestFaceting, DocumentAnalysisRequestHandlerTest, TestClassicSimilarityFactory, PolyFieldTest, TestFieldCache, TestCollectionAPI, ShufflingReplicaListTransformerTest, ShardRoutingTest, SuggesterFSTTest, HdfsBasicDistributedZk2Test, TestCustomDocTransformer, ShowFileRequestHandlerTest, PreAnalyzedFieldManagedSchemaCloudTest, PathHierarchyTokenizerFactoryTest, TestExclusionRuleCollectionAccess, TestFieldCacheSortRandom, HighlighterConfigTest, TestManagedSynonymGraphFilterFactory, TestCustomStream, TestDeleteCollectionOnDownNodes, TestReplicaProperties, TestMultiWordSynonyms, HttpPartitionTest, TermVectorComponentDistributedTest, SolrCLIZkUtilsTest, UUIDUpdateProcessorFallbackTest, TestLegacyNumericUtils, TestStressInPlaceUpdates, BasicDistributedZkTest, AnalysisAfterCoreReloadTest, TestExtendedDismaxParser, SuggesterTSTTest, TestStressLucene, TestTrie, NoCacheHeaderTest, SchemaVersionSpecificBehaviorTest, TestUpdate, DefaultValueUpdateProcessorTest, DocValuesMultiTest, XsltUpdateRequestHandlerTest, CacheHeaderTest, PrimitiveFieldTypeTest, TermsComponentTest, RegexBoostProcessorTest, ReturnFieldsTest, TestCSVResponseWriter, UniqFieldsUpdateProcessorFactoryTest, PingRequestHandlerTest, TestConfig, TestFuzzyAnalyzedSuggestions, TestLuceneMatchVersion, TestCharFilters, TestXIncludeConfig, EchoParamsTest, TestSweetSpotSimilarityFactory, TestDFRSimilarityFactory, TestIBSimilarityFactory, ChaosMonkeyNothingIsSafeTest, TestCrossCoreJoin, TestCursorMarkWithoutUniqueKey, TestLuceneIndexBackCompat, CloudExitableDirectoryReaderTest, CollectionsAPIAsyncDistributedZkTest]
   [junit4] Completed [507/751 (3!)] on J1 in 35.93s, 2 tests, 1 error <<< FAILURES!

[...truncated 48140 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 13 - Failure

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/13/

9 tests failed.
FAILED:  org.apache.solr.cloud.DistribCursorPagingTest.test

Error Message:
Could not load collection from ZK: collection1

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: collection1
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:A9FB1037DA644DE8]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.getDocCollection(CloudSolrClient.java:1205)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:848)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrClient.query(SolrClient.java:942)
	at org.apache.solr.client.solrj.SolrClient.query(SolrClient.java:957)
	at org.apache.solr.cloud.DistribCursorPagingTest.assertFullWalkNoDups(DistribCursorPagingTest.java:718)
	at org.apache.solr.cloud.DistribCursorPagingTest.doRandomSortsOnLargeIndex(DistribCursorPagingTest.java:545)
	at org.apache.solr.cloud.DistribCursorPagingTest.test(DistribCursorPagingTest.java:93)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/collection1/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 51 more


FAILED:  org.apache.solr.cloud.RecoveryZkTest.test

Error Message:


Stack Trace:
java.util.concurrent.TimeoutException
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:A9FB1037DA644DE8]:0)
	at org.apache.solr.common.cloud.ZkStateReader.waitForState(ZkStateReader.java:1276)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.waitForState(CloudSolrClient.java:448)
	at org.apache.solr.cloud.RecoveryZkTest.test(RecoveryZkTest.java:122)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestAuthenticationFramework.testBasics

Error Message:
Error from server at http://127.0.0.1:58293/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html> <head> <meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/> <title>Error 404 </title> </head> <body> <h2>HTTP ERROR: 404</h2> <p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason: <pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p> <hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/> </body> </html> 

Stack Trace:
org.apache.solr.client.solrj.impl.CloudSolrClient$RouteException: Error from server at http://127.0.0.1:58293/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason:
<pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:1C7781C14C767E60]:0)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.directUpdate(CloudSolrClient.java:549)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1012)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.request.UpdateRequest.commit(UpdateRequest.java:233)
	at org.apache.solr.cloud.TestAuthenticationFramework.collectionCreateSearchDeleteTwice(TestAuthenticationFramework.java:126)
	at org.apache.solr.cloud.TestAuthenticationFramework.testBasics(TestAuthenticationFramework.java:74)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at http://127.0.0.1:58293/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason:
<pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:607)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.lambda$directUpdate$0(CloudSolrClient.java:526)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	... 1 more


FAILED:  org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates.test_dv

Error Message:
java.lang.RuntimeException: Error from server at http://127.0.0.1:50162/solr/test_col: Async exception during distributed update: Error from server at http://127.0.0.1:38869/solr/test_col_shard1_replica_n1: Server Error    request: http://127.0.0.1:38869/solr/test_col_shard1_replica_n1/update?update.distrib=TOLEADER&distrib.from=http%3A%2F%2F127.0.0.1%3A50162%2Fsolr%2Ftest_col_shard2_replica_n7%2F&wt=javabin&version=2 Remote error message: Failed synchronous update on shard StdNode: http://127.0.0.1:50357/solr/test_col_shard1_replica_n3/ update: org.apache.solr.client.solrj.request.UpdateRequest@30a3d854

Stack Trace:
java.util.concurrent.ExecutionException: java.lang.RuntimeException: Error from server at http://127.0.0.1:50162/solr/test_col: Async exception during distributed update: Error from server at http://127.0.0.1:38869/solr/test_col_shard1_replica_n1: Server Error



request: http://127.0.0.1:38869/solr/test_col_shard1_replica_n1/update?update.distrib=TOLEADER&distrib.from=http%3A%2F%2F127.0.0.1%3A50162%2Fsolr%2Ftest_col_shard2_replica_n7%2F&wt=javabin&version=2
Remote error message: Failed synchronous update on shard StdNode: http://127.0.0.1:50357/solr/test_col_shard1_replica_n3/ update: org.apache.solr.client.solrj.request.UpdateRequest@30a3d854
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:17BB4DABFEC51A01]:0)
	at java.util.concurrent.FutureTask.report(FutureTask.java:122)
	at java.util.concurrent.FutureTask.get(FutureTask.java:192)
	at org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates.checkField(TestStressCloudBlindAtomicUpdates.java:283)
	at org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates.test_dv(TestStressCloudBlindAtomicUpdates.java:195)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: java.lang.RuntimeException: Error from server at http://127.0.0.1:50162/solr/test_col: Async exception during distributed update: Error from server at http://127.0.0.1:38869/solr/test_col_shard1_replica_n1: Server Error



request: http://127.0.0.1:38869/solr/test_col_shard1_replica_n1/update?update.distrib=TOLEADER&distrib.from=http%3A%2F%2F127.0.0.1%3A50162%2Fsolr%2Ftest_col_shard2_replica_n7%2F&wt=javabin&version=2
Remote error message: Failed synchronous update on shard StdNode: http://127.0.0.1:50357/solr/test_col_shard1_replica_n3/ update: org.apache.solr.client.solrj.request.UpdateRequest@30a3d854
	at org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates$Worker.run(TestStressCloudBlindAtomicUpdates.java:411)
	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	... 1 more
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at http://127.0.0.1:50162/solr/test_col: Async exception during distributed update: Error from server at http://127.0.0.1:38869/solr/test_col_shard1_replica_n1: Server Error



request: http://127.0.0.1:38869/solr/test_col_shard1_replica_n1/update?update.distrib=TOLEADER&distrib.from=http%3A%2F%2F127.0.0.1%3A50162%2Fsolr%2Ftest_col_shard2_replica_n7%2F&wt=javabin&version=2
Remote error message: Failed synchronous update on shard StdNode: http://127.0.0.1:50357/solr/test_col_shard1_replica_n3/ update: org.apache.solr.client.solrj.request.UpdateRequest@30a3d854
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
	at org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates$Worker.doRandomAtomicUpdate(TestStressCloudBlindAtomicUpdates.java:370)
	at org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates$Worker.run(TestStressCloudBlindAtomicUpdates.java:399)
	... 6 more


FAILED:  org.apache.solr.cloud.ZkSolrClientTest.testMultipleWatchesAsync

Error Message:


Stack Trace:
java.lang.AssertionError
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:4919FC4FE17C218E]:0)
	at org.junit.Assert.fail(Assert.java:92)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.junit.Assert.assertTrue(Assert.java:54)
	at org.apache.solr.cloud.ZkSolrClientTest.testMultipleWatchesAsync(ZkSolrClientTest.java:252)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.LeaderElectionIntegrationTest.testSimpleSliceLeaderElection

Error Message:
Could not load collection from ZK: collection1

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: collection1
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:7F9BE2A337E7BCF7]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.common.cloud.ClusterState.getCollectionOrNull(ClusterState.java:130)
	at org.apache.solr.common.cloud.ZkStateReader.getLeader(ZkStateReader.java:743)
	at org.apache.solr.common.cloud.ZkStateReader.getLeaderRetry(ZkStateReader.java:765)
	at org.apache.solr.cloud.LeaderElectionIntegrationTest.getLeader(LeaderElectionIntegrationTest.java:168)
	at org.apache.solr.cloud.LeaderElectionIntegrationTest.testSimpleSliceLeaderElection(LeaderElectionIntegrationTest.java:70)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/collection1/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 45 more


FAILED:  org.apache.solr.cloud.TestSkipOverseerOperations.testSkipDownOperations

Error Message:
Expected 2x2 for collection: collection2 null Live Nodes: [127.0.0.1:35116_solr, 127.0.0.1:40354_solr, 127.0.0.1:43623_solr] Last available state: DocCollection(collection2//collections/collection2/state.json/25)={   "pullReplicas":"0",   "replicationFactor":"2",   "shards":{     "shard1":{       "range":"80000000-ffffffff",       "state":"active",       "replicas":{         "core_node3":{           "core":"collection2_shard1_replica_n1",           "base_url":"https://127.0.0.1:35116/solr",           "node_name":"127.0.0.1:35116_solr",           "state":"active",           "type":"NRT"},         "core_node5":{           "core":"collection2_shard1_replica_n2",           "base_url":"https://127.0.0.1:40354/solr",           "node_name":"127.0.0.1:40354_solr",           "state":"active",           "type":"NRT",           "leader":"true"}}},     "shard2":{       "range":"0-7fffffff",       "state":"active",       "replicas":{         "core_node7":{           "core":"collection2_shard2_replica_n4",           "base_url":"https://127.0.0.1:35116/solr",           "node_name":"127.0.0.1:35116_solr",           "state":"active",           "type":"NRT",           "leader":"true"},         "core_node8":{           "core":"collection2_shard2_replica_n6",           "base_url":"https://127.0.0.1:40354/solr",           "node_name":"127.0.0.1:40354_solr",           "state":"down",           "type":"NRT"}}}},   "router":{"name":"compositeId"},   "maxShardsPerNode":"2",   "autoAddReplicas":"false",   "nrtReplicas":"2",   "tlogReplicas":"0"}

Stack Trace:
java.lang.AssertionError: Expected 2x2 for collection: collection2
null
Live Nodes: [127.0.0.1:35116_solr, 127.0.0.1:40354_solr, 127.0.0.1:43623_solr]
Last available state: DocCollection(collection2//collections/collection2/state.json/25)={
  "pullReplicas":"0",
  "replicationFactor":"2",
  "shards":{
    "shard1":{
      "range":"80000000-ffffffff",
      "state":"active",
      "replicas":{
        "core_node3":{
          "core":"collection2_shard1_replica_n1",
          "base_url":"https://127.0.0.1:35116/solr",
          "node_name":"127.0.0.1:35116_solr",
          "state":"active",
          "type":"NRT"},
        "core_node5":{
          "core":"collection2_shard1_replica_n2",
          "base_url":"https://127.0.0.1:40354/solr",
          "node_name":"127.0.0.1:40354_solr",
          "state":"active",
          "type":"NRT",
          "leader":"true"}}},
    "shard2":{
      "range":"0-7fffffff",
      "state":"active",
      "replicas":{
        "core_node7":{
          "core":"collection2_shard2_replica_n4",
          "base_url":"https://127.0.0.1:35116/solr",
          "node_name":"127.0.0.1:35116_solr",
          "state":"active",
          "type":"NRT",
          "leader":"true"},
        "core_node8":{
          "core":"collection2_shard2_replica_n6",
          "base_url":"https://127.0.0.1:40354/solr",
          "node_name":"127.0.0.1:40354_solr",
          "state":"down",
          "type":"NRT"}}}},
  "router":{"name":"compositeId"},
  "maxShardsPerNode":"2",
  "autoAddReplicas":"false",
  "nrtReplicas":"2",
  "tlogReplicas":"0"}
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:E63D5DAB89D49BC6]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.SolrCloudTestCase.waitForState(SolrCloudTestCase.java:269)
	at org.apache.solr.cloud.TestSkipOverseerOperations.testSkipDownOperations(TestSkipOverseerOperations.java:104)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestSkipOverseerOperations.testSkipLeaderOperations

Error Message:
expected:<7> but was:<9>

Stack Trace:
java.lang.AssertionError: expected:<7> but was:<9>
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:D145FC11ABBB507A]: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.junit.Assert.assertEquals(Assert.java:456)
	at org.apache.solr.cloud.TestSkipOverseerOperations.testSkipLeaderOperations(TestSkipOverseerOperations.java:72)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestStressInPlaceUpdates.stressTest

Error Message:
Captured an uncaught exception in thread: Thread[id=31766, name=WRITER11, state=RUNNABLE, group=TGRP-TestStressInPlaceUpdates]

Stack Trace:
com.carrotsearch.randomizedtesting.UncaughtExceptionError: Captured an uncaught exception in thread: Thread[id=31766, name=WRITER11, state=RUNNABLE, group=TGRP-TestStressInPlaceUpdates]
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010:4AC9F0404A4DF4EA]:0)
Caused by: java.lang.RuntimeException: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at https://127.0.0.1:38826/qhks/ep/collection1: Cannot talk to ZooKeeper - Updates are disabled.
	at __randomizedtesting.SeedInfo.seed([21AF2FED74982010]:0)
	at org.apache.solr.cloud.TestStressInPlaceUpdates$1.run(TestStressInPlaceUpdates.java:306)
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at https://127.0.0.1:38826/qhks/ep/collection1: Cannot talk to ZooKeeper - Updates are disabled.
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
	at org.apache.solr.cloud.TestStressInPlaceUpdates.addDocAndGetVersion(TestStressInPlaceUpdates.java:549)
	at org.apache.solr.cloud.TestStressInPlaceUpdates$1.run(TestStressInPlaceUpdates.java:254)




Build Log:
[...truncated 11671 lines...]
   [junit4] Suite: org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates
   [junit4]   2> Creating dataDir: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/init-core-data-001
   [junit4]   2> 124144 WARN  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=5 numCloses=5
   [junit4]   2> 124145 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=true
   [junit4]   2> 124342 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (false) via: @org.apache.solr.SolrTestCaseJ4$SuppressSSL(bugUrl=SSL overhead seems to cause OutOfMemory when stress testing)
   [junit4]   2> 124342 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 124352 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 4 servers in /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001
   [junit4]   2> 124363 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 124412 INFO  (Thread-3) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 124412 INFO  (Thread-3) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 125643 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:42174
   [junit4]   2> 127197 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn Exception causing close of session 0x0 due to java.io.IOException: ZooKeeperServer not running
   [junit4]   2> 127854 ERROR (Thread-3) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 129079 INFO  (zkConnectionManagerCallback-8-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 133132 INFO  (jetty-launcher-5-thread-4) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 133152 INFO  (jetty-launcher-5-thread-3) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 133171 INFO  (jetty-launcher-5-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 133194 INFO  (jetty-launcher-5-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 133580 INFO  (jetty-launcher-5-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@35addbc6{/solr,null,AVAILABLE}
   [junit4]   2> 133580 INFO  (jetty-launcher-5-thread-3) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@7c7d6da8{/solr,null,AVAILABLE}
   [junit4]   2> 133580 INFO  (jetty-launcher-5-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@50a1bdbe{/solr,null,AVAILABLE}
   [junit4]   2> 133580 INFO  (jetty-launcher-5-thread-4) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@6f68354e{/solr,null,AVAILABLE}
   [junit4]   2> 133654 INFO  (jetty-launcher-5-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@789d19bb{HTTP/1.1,[http/1.1]}{127.0.0.1:50357}
   [junit4]   2> 133654 INFO  (jetty-launcher-5-thread-2) [    ] o.e.j.s.Server Started @151240ms
   [junit4]   2> 133654 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=50357}
   [junit4]   2> 133695 INFO  (jetty-launcher-5-thread-4) [    ] o.e.j.s.AbstractConnector Started ServerConnector@3f51c71e{HTTP/1.1,[http/1.1]}{127.0.0.1:42127}
   [junit4]   2> 133695 INFO  (jetty-launcher-5-thread-4) [    ] o.e.j.s.Server Started @151281ms
   [junit4]   2> 133679 INFO  (jetty-launcher-5-thread-3) [    ] o.e.j.s.AbstractConnector Started ServerConnector@4fdedabe{HTTP/1.1,[http/1.1]}{127.0.0.1:38869}
   [junit4]   2> 133792 INFO  (jetty-launcher-5-thread-3) [    ] o.e.j.s.Server Started @151378ms
   [junit4]   2> 133792 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=38869}
   [junit4]   2> 133683 INFO  (jetty-launcher-5-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@3e2d7044{HTTP/1.1,[http/1.1]}{127.0.0.1:50162}
   [junit4]   2> 133793 INFO  (jetty-launcher-5-thread-1) [    ] o.e.j.s.Server Started @151379ms
   [junit4]   2> 133793 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=50162}
   [junit4]   2> 133695 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=42127}
   [junit4]   2> 133823 ERROR (jetty-launcher-5-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 133823 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 133824 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 133824 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 133824 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-15T11:01:24.889Z
   [junit4]   2> 133825 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.c.SolrResourceLoader solr home defaulted to 'solr/' (could not find system property or JNDI)
   [junit4]   2> 133832 ERROR (jetty-launcher-5-thread-4) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 133832 ERROR (jetty-launcher-5-thread-3) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 133835 ERROR (jetty-launcher-5-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 133887 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 133883 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 133883 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr? version 7.2.0
   [junit4]   2> 133888 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 133888 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 133888 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-15T11:01:24.953Z
   [junit4]   2> 133888 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 133888 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 133888 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-15T11:01:24.953Z
   [junit4]   2> 133908 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 133908 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 133971 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-15T11:01:25.036Z
   [junit4]   2> 134404 INFO  (zkConnectionManagerCallback-14-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 134463 INFO  (zkConnectionManagerCallback-16-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 134565 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 134483 INFO  (zkConnectionManagerCallback-10-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 134607 INFO  (zkConnectionManagerCallback-12-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 134609 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 134651 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 134651 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 135533 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16059d5e2c20003, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 135573 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16059d5e2c20002, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 135689 INFO  (jetty-launcher-5-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:42174/solr
   [junit4]   2> 135997 INFO  (jetty-launcher-5-thread-3) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:42174/solr
   [junit4]   2> 136363 INFO  (jetty-launcher-5-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:42174/solr
   [junit4]   2> 136342 INFO  (jetty-launcher-5-thread-4) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:42174/solr
   [junit4]   2> 137103 INFO  (zkConnectionManagerCallback-24-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 137147 INFO  (zkConnectionManagerCallback-28-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 137176 INFO  (zkConnectionManagerCallback-30-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 137342 INFO  (zkConnectionManagerCallback-32-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 137429 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x16059d5e2c20006, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 137711 INFO  (zkConnectionManagerCallback-34-thread-1-processing-n:127.0.0.1:38869_solr) [n:127.0.0.1:38869_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 138631 INFO  (zkConnectionManagerCallback-36-thread-1-processing-n:127.0.0.1:50357_solr) [n:127.0.0.1:50357_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 138635 INFO  (zkConnectionManagerCallback-38-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 140127 INFO  (zkConnectionManagerCallback-40-thread-1-processing-n:127.0.0.1:42127_solr) [n:127.0.0.1:42127_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 141971 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 142008 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:50162_solr
   [junit4]   2> 142061 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.c.Overseer Overseer (id=99177966969421835-127.0.0.1:50162_solr-n_0000000000) starting
   [junit4]   2> 145930 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:50162_solr
   [junit4]   2> 146183 INFO  (zkCallback-37-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 146495 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 146497 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 146587 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 146588 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 146644 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:38869_solr
   [junit4]   2> 146644 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:50357_solr
   [junit4]   2> 146955 INFO  (zkCallback-37-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (3)
   [junit4]   2> 146960 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 146963 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 146967 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:42127_solr
   [junit4]   2> 146968 INFO  (zkCallback-37-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 147078 INFO  (zkCallback-35-thread-1-processing-n:127.0.0.1:50357_solr) [n:127.0.0.1:50357_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (4)
   [junit4]   2> 147468 INFO  (zkCallback-39-thread-1-processing-n:127.0.0.1:42127_solr) [n:127.0.0.1:42127_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (3) -> (4)
   [junit4]   2> 147468 INFO  (zkCallback-33-thread-1-processing-n:127.0.0.1:38869_solr) [n:127.0.0.1:38869_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (4)
   [junit4]   2> 154410 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50162.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 154460 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50162.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 154460 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50162.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 154751 INFO  (jetty-launcher-5-thread-1) [n:127.0.0.1:50162_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node1/.
   [junit4]   2> 155340 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_42127.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155341 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_42127.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155341 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_42127.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155538 INFO  (jetty-launcher-5-thread-4) [n:127.0.0.1:42127_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node4/.
   [junit4]   2> 155931 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50357.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155933 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50357.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155933 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50357.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155942 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38869.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 155989 INFO  (jetty-launcher-5-thread-2) [n:127.0.0.1:50357_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node2/.
   [junit4]   2> 156201 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38869.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 156202 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38869.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 156220 INFO  (jetty-launcher-5-thread-3) [n:127.0.0.1:38869_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node3/.
   [junit4]   2> 161991 INFO  (zkConnectionManagerCallback-47-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 162147 INFO  (zkConnectionManagerCallback-51-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 162192 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (4)
   [junit4]   2> 162194 INFO  (SUITE-TestStressCloudBlindAtomicUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:42174/solr ready
   [junit4]   2> 171888 INFO  (qtp1896688340-78) [n:127.0.0.1:38869_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=2&property.config=solrconfig-tlog.xml&property.schema=schema-minimal-atomic-stress.xml&collection.configName=org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates_config-set&name=test_col&nrtReplicas=2&action=CREATE&numShards=2&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 172222 INFO  (OverseerThreadFactory-50-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.CreateCollectionCmd Create collection test_col
   [junit4]   2> 172684 INFO  (OverseerStateUpdate-99177966969421835-127.0.0.1:50162_solr-n_0000000000) [n:127.0.0.1:50162_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"test_col",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"test_col_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:38869/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 172735 INFO  (OverseerStateUpdate-99177966969421835-127.0.0.1:50162_solr-n_0000000000) [n:127.0.0.1:50162_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"test_col",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"test_col_shard1_replica_n3",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:50357/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 172756 INFO  (OverseerStateUpdate-99177966969421835-127.0.0.1:50162_solr-n_0000000000) [n:127.0.0.1:50162_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"test_col",
   [junit4]   2>   "shard":"shard2",
   [junit4]   2>   "core":"test_col_shard2_replica_n5",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:42127/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 172777 INFO  (OverseerStateUpdate-99177966969421835-127.0.0.1:50162_solr-n_0000000000) [n:127.0.0.1:50162_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"test_col",
   [junit4]   2>   "shard":"shard2",
   [junit4]   2>   "core":"test_col_shard2_replica_n7",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:50162/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 176497 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates_config-set&newCollection=true&collection=test_col&version=2&replicaType=NRT&property.config=solrconfig-tlog.xml&property.schema=schema-minimal-atomic-stress.xml&coreNodeName=core_node2&name=test_col_shard1_replica_n1&action=CREATE&numShards=2&shard=shard1&wt=javabin
   [junit4]   2> 176499 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 176508 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates_config-set&newCollection=true&collection=test_col&version=2&replicaType=NRT&property.config=solrconfig-tlog.xml&property.schema=schema-minimal-atomic-stress.xml&coreNodeName=core_node4&name=test_col_shard1_replica_n3&action=CREATE&numShards=2&shard=shard1&wt=javabin
   [junit4]   2> 176508 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 176509 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates_config-set&newCollection=true&collection=test_col&version=2&replicaType=NRT&property.config=solrconfig-tlog.xml&property.schema=schema-minimal-atomic-stress.xml&coreNodeName=core_node6&name=test_col_shard2_replica_n5&action=CREATE&numShards=2&shard=shard2&wt=javabin
   [junit4]   2> 176509 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 176584 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&collection.configName=org.apache.solr.cloud.TestStressCloudBlindAtomicUpdates_config-set&newCollection=true&collection=test_col&version=2&replicaType=NRT&property.config=solrconfig-tlog.xml&property.schema=schema-minimal-atomic-stress.xml&coreNodeName=core_node8&name=test_col_shard2_replica_n7&action=CREATE&numShards=2&shard=shard2&wt=javabin
   [junit4]   2> 176591 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 176715 INFO  (zkCallback-33-thread-1-processing-n:127.0.0.1:38869_solr) [n:127.0.0.1:38869_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 176716 INFO  (zkCallback-35-thread-1-processing-n:127.0.0.1:50357_solr) [n:127.0.0.1:50357_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 176727 INFO  (zkCallback-37-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177246 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 177396 INFO  (zkCallback-39-thread-1-processing-n:127.0.0.1:42127_solr) [n:127.0.0.1:42127_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177396 INFO  (zkCallback-37-thread-1-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177397 INFO  (zkCallback-33-thread-1-processing-n:127.0.0.1:38869_solr) [n:127.0.0.1:38869_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177397 INFO  (zkCallback-35-thread-1-processing-n:127.0.0.1:50357_solr) [n:127.0.0.1:50357_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177403 INFO  (zkCallback-33-thread-2-processing-n:127.0.0.1:38869_solr) [n:127.0.0.1:38869_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177439 INFO  (zkCallback-37-thread-2-processing-n:127.0.0.1:50162_solr) [n:127.0.0.1:50162_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177455 INFO  (zkCallback-35-thread-2-processing-n:127.0.0.1:50357_solr) [n:127.0.0.1:50357_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/test_col/state.json] for collection [test_col] has occurred - updating... (live nodes size: [4])
   [junit4]   2> 177583 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.s.IndexSchema [test_col_shard2_replica_n5] Schema name=minimal-atomic-stress
   [junit4]   2> 177686 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.s.IndexSchema Loaded schema minimal-atomic-stress/1.6 with uniqueid field id
   [junit4]   2> 177699 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.CoreContainer Creating SolrCore 'test_col_shard2_replica_n5' using configuration from collection test_col, trusted=true
   [junit4]   2> 177736 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_42127.solr.core.test_col.shard2.replica_n5' (registry 'solr.core.test_col.shard2.replica_n5') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 177736 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 177736 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.SolrCore [[test_col_shard2_replica_n5] ] Opening new SolrCore at [/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node4/test_col_shard2_replica_n5], dataDir=[/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node4/./test_col_shard2_replica_n5/data/]
   [junit4]   2> 177781 INFO  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=27, maxMergeAtOnceExplicit=15, maxMergedSegmentMB=54.310546875, floorSegmentMB=1.0595703125, forceMergeDeletesPctAllowed=29.051325993209687, segmentsPerTier=28.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.7820420705856912
   [junit4]   2> 178114 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 178195 WARN  (qtp1823018443-54) [n:127.0.0.1:42127_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.RequestHandlers INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,attributes = {initParams=a, name=/dump, class=DumpRequestHandler},args = {defaults={a=A,b=B}}}
   [junit4]   2> 178334 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.s.IndexSchema [test_col_shard1_replica_n1] Schema name=minimal-atomic-stress
   [junit4]   2> 178368 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.s.IndexSchema Loaded schema minimal-atomic-stress/1.6 with uniqueid field id
   [junit4]   2> 178368 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.c.CoreContainer Creating SolrCore 'test_col_shard1_replica_n1' using configuration from collection test_col, trusted=true
   [junit4]   2> 178369 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38869.solr.core.test_col.shard1.replica_n1' (registry 'solr.core.test_col.shard1.replica_n1') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 178369 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 178369 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.c.SolrCore [[test_col_shard1_replica_n1] ] Opening new SolrCore at [/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node3/test_col_shard1_replica_n1], dataDir=[/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node3/./test_col_shard1_replica_n1/data/]
   [junit4]   2> 178406 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 178425 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 178441 INFO  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=27, maxMergeAtOnceExplicit=15, maxMergedSegmentMB=54.310546875, floorSegmentMB=1.0595703125, forceMergeDeletesPctAllowed=29.051325993209687, segmentsPerTier=28.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.7820420705856912
   [junit4]   2> 178570 WARN  (qtp1896688340-68) [n:127.0.0.1:38869_solr c:test_col s:shard1 r:core_node2 x:test_col_shard1_replica_n1] o.a.s.c.RequestHandlers INVALID paramSet a in requestHandler {type = requestHandler,name = /dump,class = DumpRequestHandler,attributes = {initParams=a, name=/dump, class=DumpRequestHandler},args = {defaults={a=A,b=B}}}
   [junit4]   2> 179060 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.s.IndexSchema [test_col_shard1_replica_n3] Schema name=minimal-atomic-stress
   [junit4]   2> 179062 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.s.IndexSchema Loaded schema minimal-atomic-stress/1.6 with uniqueid field id
   [junit4]   2> 179062 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.c.CoreContainer Creating SolrCore 'test_col_shard1_replica_n3' using configuration from collection test_col, trusted=true
   [junit4]   2> 179063 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50357.solr.core.test_col.shard1.replica_n3' (registry 'solr.core.test_col.shard1.replica_n3') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 179066 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.s.IndexSchema [test_col_shard2_replica_n7] Schema name=minimal-atomic-stress
   [junit4]   2> 179094 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.s.IndexSchema Loaded schema minimal-atomic-stress/1.6 with uniqueid field id
   [junit4]   2> 179094 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.c.CoreContainer Creating SolrCore 'test_col_shard2_replica_n7' using configuration from collection test_col, trusted=true
   [junit4]   2> 179095 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_50162.solr.core.test_col.shard2.replica_n7' (registry 'solr.core.test_col.shard2.replica_n7') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@5f237b76
   [junit4]   2> 179095 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 179095 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.c.SolrCore [[test_col_shard2_replica_n7] ] Opening new SolrCore at [/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node1/test_col_shard2_replica_n7], dataDir=[/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node1/./test_col_shard2_replica_n7/data/]
   [junit4]   2> 179095 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 179103 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.c.SolrCore [[test_col_shard1_replica_n3] ] Opening new SolrCore at [/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node2/test_col_shard1_replica_n3], dataDir=[/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.TestStressCloudBlindAtomicUpdates_21AF2FED74982010-001/tempDir-001/node2/./test_col_shard1_replica_n3/data/]
   [junit4]   2> 179133 INFO  (qtp1689528207-62) [n:127.0.0.1:50357_solr c:test_col s:shard1 r:core_node4 x:test_col_shard1_replica_n3] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergePolicy: maxMergeAtOnce=27, maxMergeAtOnceExplicit=15, maxMergedSegmentMB=54.310546875, floorSegmentMB=1.0595703125, forceMergeDeletesPctAllowed=29.051325993209687, segmentsPerTier=28.0, maxCFSSegmentSizeMB=8.796093022207999E12, noCFSRatio=0.7820420705856912
   [junit4]   2> 179147 INFO  (qtp1879178943-73) [n:127.0.0.1:50162_solr c:test_col s:shard2 r:core_node8 x:test_col_shard2_replica_n7] o.a.s.u.RandomMergePolicy RandomMergePolicy wrapping class org.apache.lucene.index.TieredMergePolicy: [TieredMergeP

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

org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
   [junit4]    > 	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
   [junit4]    > 	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
   [junit4]    > 	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
   [junit4]    > 	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
   [junit4]    > 	at org.apache.solr.cloud.TestStressInPlaceUpdates.addDocAndGetVersion(TestStressInPlaceUpdates.java:549)
   [junit4]    > 	at org.apache.solr.cloud.TestStressInPlaceUpdates$1.run(TestStressInPlaceUpdates.java:254)
   [junit4]   2> 10109305 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.SolrTestCaseJ4 ###deleteCore
   [junit4]   2> 10109305 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.c.CoreContainer Shutting down CoreContainer instance=686671300
   [junit4]   2> 10109305 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.node, tag=null
   [junit4]   2> 10109305 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@194ff8e0: rootName = null, domain = solr.node, service url = null, agent id = null] for registry solr.node / com.codahale.metrics.MetricRegistry@491c59a5
   [junit4]   2> 10109306 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jvm, tag=null
   [junit4]   2> 10109306 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@652778aa: rootName = null, domain = solr.jvm, service url = null, agent id = null] for registry solr.jvm / com.codahale.metrics.MetricRegistry@d5401de
   [junit4]   2> 10109307 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.jetty, tag=null
   [junit4]   2> 10109307 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@12fbcb9f: rootName = null, domain = solr.jetty, service url = null, agent id = null] for registry solr.jetty / com.codahale.metrics.MetricRegistry@511eb8c9
   [junit4]   2> 10109320 INFO  (coreCloseExecutor-7846-thread-1) [    x:collection1] o.a.s.c.SolrCore [collection1]  CLOSING SolrCore org.apache.solr.core.SolrCore@355c48ce
   [junit4]   2> 10109320 INFO  (coreCloseExecutor-7846-thread-1) [    x:collection1] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.collection1, tag=895240398
   [junit4]   2> 10109320 INFO  (coreCloseExecutor-7846-thread-1) [    x:collection1] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@258c5baa: rootName = null, domain = solr.core.collection1, service url = null, agent id = null] for registry solr.core.collection1 / com.codahale.metrics.MetricRegistry@428127ae
   [junit4]   2> 10109359 INFO  (SUITE-TestStressInPlaceUpdates-seed#[21AF2FED74982010]-worker) [    ] o.a.s.SolrTestCaseJ4 ------------------------------------------------------- Done waiting for tracked resources to be released
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70): {title_s=PostingsFormat(name=Memory), id=PostingsFormat(name=LuceneFixedGap), id_field_copy_that_does_not_support_in_place_update_s=PostingsFormat(name=Memory)}, docValues:{val1_i_dvo=DocValuesFormat(name=Asserting), _version_=DocValuesFormat(name=Direct), val2_l_dvo=DocValuesFormat(name=Asserting), id=DocValuesFormat(name=Lucene70), inplace_updatable_int_with_default=DocValuesFormat(name=Direct), inplace_updatable_float_with_default=DocValuesFormat(name=Memory)}, maxPointsInLeafNode=1107, maxMBSortInHeap=6.729711659061098, sim=RandomSimilarity(queryNorm=true): {}, locale=ko, timezone=America/Argentina/Jujuy
   [junit4]   2> NOTE: Linux 3.13.0-88-generic amd64/Oracle Corporation 1.8.0_144 (64-bit)/cpus=4,threads=1,free=370844568,total=492306432
   [junit4]   2> NOTE: All tests run in this JVM: [CustomCollectionTest, TestAuthorizationFramework, BasicDistributedZk2Test, TestGroupingSearch, TestShardHandlerFactory, ClassificationUpdateProcessorTest, AnalyticsMergeStrategyTest, TestFieldResource, TestCoreContainer, TestSolrConfigHandlerConcurrent, HdfsBasicDistributedZkTest, MetricsHandlerTest, HighlighterTest, TestReload, TestRealTimeGet, SpellPossibilityIteratorTest, TestNoOpRegenerator, NodeMutatorTest, TestDistributedStatsComponentCardinality, DistribJoinFromCollectionTest, BigEndianAscendingWordDeserializerTest, ReturnFieldsTest, DistributedFacetPivotLargeTest, TestMacroExpander, TestDistributedGrouping, TestReloadDeadlock, SuggesterWFSTTest, FieldMutatingUpdateProcessorTest, UnloadDistributedZkTest, SpatialHeatmapFacetsTest, DirectSolrConnectionTest, FieldAnalysisRequestHandlerTest, HdfsThreadLeakTest, RecoveryZkTest, DistributedQueryComponentOptimizationTest, CSVRequestHandlerTest, SolrMetricManagerTest, TestHashPartitioner, TestEmbeddedSolrServerConstructors, TestMiniSolrCloudClusterSSL, TestZkChroot, TestTolerantSearch, DistanceUnitsTest, HdfsWriteToMultipleCollectionsTest, TestElisionMultitermQuery, ZkNodePropsTest, TestHashQParserPlugin, DistributedSpellCheckComponentTest, GraphQueryTest, LoggingHandlerTest, TestStressLiveNodes, CoreSorterTest, TimeZoneUtilsTest, ZkStateReaderTest, SolrTestCaseJ4Test, ResponseHeaderTest, TestConfigOverlay, OverseerStatusTest, EchoParamsTest, AliasIntegrationTest, IgnoreCommitOptimizeUpdateProcessorFactoryTest, ClusterStateTest, ConnectionReuseTest, TimeRoutedAliasUpdateProcessorTest, SolrJmxReporterTest, TestConfigSets, WordBreakSolrSpellCheckerTest, TestSolrCloudWithHadoopAuthPlugin, TestHalfAndHalfDocValues, HdfsRecoveryZkTest, TestSchemaVersionResource, TestSolrCoreProperties, TestConfigReload, TestSystemIdResolver, TestFieldSortValues, VersionInfoTest, DataDrivenBlockJoinTest, CollectionReloadTest, PluginInfoTest, TestSubQueryTransformerDistrib, TestLMDirichletSimilarityFactory, TestSchemaNameResource, UninvertDocValuesMergePolicyTest, HdfsLockFactoryTest, TestRequestForwarding, LargeFieldTest, TestInitParams, TestSchemalessBufferedUpdates, SortSpecParsingTest, TestDynamicFieldCollectionResource, TestFieldCacheVsDocValues, TestSQLHandler, LeaderInitiatedRecoveryOnCommitTest, TestLeaderInitiatedRecoveryThread, TestDistributedMissingSort, FileBasedSpellCheckerTest, TestComplexPhraseLeadingWildcard, BlockJoinFacetDistribTest, ConfigSetsAPITest, BadCopyFieldTest, DeleteStatusTest, TestJsonFacetRefinement, TestManagedSchemaThreadSafety, TestTestInjection, RequestLoggingTest, CoreAdminHandlerTest, TestSearchPerf, TestCollectionsAPIViaSolrCloudCluster, TestLegacyField, TestSmileRequest, HdfsDirectoryFactoryTest, AddBlockUpdateTest, QueryElevationComponentTest, TestSolrXml, DocValuesNotIndexedTest, BlockDirectoryTest, TestQueryTypes, DistributedFacetPivotSmallTest, HLLUtilTest, TestRestManager, BasicDistributedZkTest, CollectionsAPIDistributedZkTest, OpenCloseCoreStressTest, OverseerTest, ShardRoutingTest, BasicZkTest, FullSolrCloudDistribCmdsTest, SolrCoreTest, SpellCheckComponentTest, PeerSyncTest, TestFiltering, TestIndexSearcher, ShowFileRequestHandlerTest, DistributedQueryElevationComponentTest, SignatureUpdateProcessorFactoryTest, TestExtendedDismaxParser, SuggesterFSTTest, TestFoldingMultitermQuery, PolyFieldTest, SolrCoreCheckLockOnStartupTest, DefaultValueUpdateProcessorTest, DistanceFunctionTest, IndexBasedSpellCheckerTest, TestQueryUtils, PrimitiveFieldTypeTest, DocumentBuilderTest, TermVectorComponentTest, RequiredFieldsTest, SolrPluginUtilsTest, TestCSVResponseWriter, UniqFieldsUpdateProcessorFactoryTest, JsonLoaderTest, TestPHPSerializedResponseWriter, TestComponentsName, TestLFUCache, ForceLeaderTest, OverseerCollectionConfigSetProcessorTest, OverseerTaskQueueTest, PeerSyncReplicationTest, ReplicationFactorTest, RestartWhileUpdatingTest, SSLMigrationTest, SaslZkACLProviderTest, SolrCloudExampleTest, TestClusterProperties, TestCollectionAPI, TestDownShardTolerantSearch, TestHdfsCloudBackupRestore, TestPullReplicaErrorHandling, TestRandomRequestDistribution, TestSegmentSorting, TestSolrCloudWithKerberosAlt, TestSolrCloudWithSecureImpersonation, TestStressInPlaceUpdates]
   [junit4] Completed [565/751 (8!)] on J2 in 318.44s, 1 test, 1 error <<< FAILURES!

[...truncated 711 lines...]
   [junit4] JVM J2: stdout was not empty, see: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/temp/junit4-J2-20171215_105853_4043118612524573141631.sysout
   [junit4] >>> JVM J2 emitted unexpected output (verbatim) ----
   [junit4] java.lang.OutOfMemoryError: Java heap space
   [junit4] Dumping heap to /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/heapdumps/java_pid2311.hprof ...
   [junit4] Heap dump file created [543411015 bytes in 26.019 secs]
   [junit4] <<< JVM J2: EOF ----

[...truncated 8485 lines...]
BUILD FAILED
/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/build.xml:835: The following error occurred while executing this line:
/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/build.xml:787: Some of the tests produced a heap dump, but did not fail. Maybe a suppressed OutOfMemoryError? Dumps created:
* java_pid2311.hprof

Total time: 391 minutes 31 seconds
Build step 'Invoke Ant' marked build as failure
Archiving artifacts
[Fast Archiver] No artifacts from Lucene-Solr-Tests-7.2 #12 to compare, so performing full copy of artifacts
Recording test results
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 12 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/12/

5 tests failed.
FAILED:  org.apache.solr.cloud.HttpPartitionTest.test

Error Message:


Stack Trace:
java.lang.NullPointerException
	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA:3A75A033D168E812]:0)
	at org.apache.solr.client.solrj.embedded.JettySolrRunner.getNodeName(JettySolrRunner.java:345)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.createServers(AbstractFullDistribZkTestBase.java:313)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:991)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.HttpPartitionTest

Error Message:
16 threads leaked from SUITE scope at org.apache.solr.cloud.HttpPartitionTest:     1) Thread[id=18473, name=zkCallback-4005-thread-4, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    2) Thread[id=18479, name=zkCallback-4005-thread-6, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    3) Thread[id=18464, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-EventThread, state=WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)    4) Thread[id=18459, name=Connection evictor, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    5) Thread[id=18463, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-SendThread(127.0.0.1:35630), state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)         at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)    6) Thread[id=18472, name=zkCallback-4005-thread-3, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    7) Thread[id=18458, name=Connection evictor, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)    8) Thread[id=18465, name=zkConnectionManagerCallback-4006-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    9) Thread[id=18469, name=OverseerAutoScalingTriggerThread-99169666974613508-127.0.0.1:34329_-n_0000000000, state=TIMED_WAITING, group=Overseer autoscaling triggers]         at java.lang.Thread.sleep(Native Method)         at org.apache.solr.common.cloud.ZkCmdExecutor.retryDelay(ZkCmdExecutor.java:111)         at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:70)         at org.apache.solr.common.cloud.SolrZkClient.getChildren(SolrZkClient.java:327)         at org.apache.solr.client.solrj.impl.ZkDistribStateManager.listData(ZkDistribStateManager.java:66)         at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:245)         at java.lang.Thread.run(Thread.java:748)   10) Thread[id=18470, name=zkCallback-4005-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)   11) Thread[id=18466, name=OverseerStateUpdate-99169666974613508-127.0.0.1:34329_-n_0000000000, state=TIMED_WAITING, group=Overseer state updater.]         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.solr.cloud.ZkDistributedQueue.peekElements(ZkDistributedQueue.java:463)         at org.apache.solr.cloud.Overseer$ClusterStateUpdater.run(Overseer.java:203)         at java.lang.Thread.run(Thread.java:748)   12) Thread[id=18468, name=Connection evictor, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)         at java.lang.Thread.run(Thread.java:748)   13) Thread[id=18471, name=zkCallback-4005-thread-2, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)   14) Thread[id=18478, name=zkCallback-4005-thread-5, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)   15) Thread[id=18467, name=OverseerCollectionConfigSetProcessor-99169666974613508-127.0.0.1:34329_-n_0000000000, state=WAITING, group=Overseer collection creation process.]         at java.lang.Object.wait(Native Method)         at java.lang.Object.wait(Object.java:502)         at org.apache.zookeeper.ClientCnxn.submitRequest(ClientCnxn.java:1406)         at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1210)         at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)         at org.apache.solr.common.cloud.SolrZkClient$$Lambda$288/1110314523.execute(Unknown Source)         at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)         at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)         at org.apache.solr.cloud.OverseerTaskProcessor.amILeader(OverseerTaskProcessor.java:387)         at org.apache.solr.cloud.OverseerTaskProcessor.run(OverseerTaskProcessor.java:193)         at java.lang.Thread.run(Thread.java:748)   16) Thread[id=18476, name=ScheduledTrigger-7111-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.solr.common.cloud.ZkCmdExecutor.retryDelay(ZkCmdExecutor.java:111)         at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:70)         at org.apache.solr.common.cloud.SolrZkClient.getChildren(SolrZkClient.java:327)         at org.apache.solr.cloud.ZkDistributedQueue.fetchZkChildren(ZkDistributedQueue.java:410)         at org.apache.solr.cloud.ZkDistributedQueue.firstChild(ZkDistributedQueue.java:387)         at org.apache.solr.cloud.ZkDistributedQueue.firstElement(ZkDistributedQueue.java:504)         at org.apache.solr.cloud.ZkDistributedQueue.peek(ZkDistributedQueue.java:145)         at org.apache.solr.cloud.autoscaling.TriggerEventQueue.peekEvent(TriggerEventQueue.java:69)         at org.apache.solr.cloud.autoscaling.ScheduledTriggers$ScheduledTrigger.run(ScheduledTriggers.java:529)         at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)         at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:308)         at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$301(ScheduledThreadPoolExecutor.java:180)         at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:294)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: 16 threads leaked from SUITE scope at org.apache.solr.cloud.HttpPartitionTest: 
   1) Thread[id=18473, name=zkCallback-4005-thread-4, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   2) Thread[id=18479, name=zkCallback-4005-thread-6, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   3) Thread[id=18464, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-EventThread, state=WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at org.apache.zookeeper.ClientCnxn$EventThread.run(ClientCnxn.java:501)
   4) Thread[id=18459, name=Connection evictor, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   5) Thread[id=18463, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-SendThread(127.0.0.1:35630), state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)
        at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)
        at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)
   6) Thread[id=18472, name=zkCallback-4005-thread-3, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   7) Thread[id=18458, name=Connection evictor, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
   8) Thread[id=18465, name=zkConnectionManagerCallback-4006-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   9) Thread[id=18469, name=OverseerAutoScalingTriggerThread-99169666974613508-127.0.0.1:34329_-n_0000000000, state=TIMED_WAITING, group=Overseer autoscaling triggers]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.solr.common.cloud.ZkCmdExecutor.retryDelay(ZkCmdExecutor.java:111)
        at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:70)
        at org.apache.solr.common.cloud.SolrZkClient.getChildren(SolrZkClient.java:327)
        at org.apache.solr.client.solrj.impl.ZkDistribStateManager.listData(ZkDistribStateManager.java:66)
        at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:245)
        at java.lang.Thread.run(Thread.java:748)
  10) Thread[id=18470, name=zkCallback-4005-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
  11) Thread[id=18466, name=OverseerStateUpdate-99169666974613508-127.0.0.1:34329_-n_0000000000, state=TIMED_WAITING, group=Overseer state updater.]
        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.solr.cloud.ZkDistributedQueue.peekElements(ZkDistributedQueue.java:463)
        at org.apache.solr.cloud.Overseer$ClusterStateUpdater.run(Overseer.java:203)
        at java.lang.Thread.run(Thread.java:748)
  12) Thread[id=18468, name=Connection evictor, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.http.impl.client.IdleConnectionEvictor$1.run(IdleConnectionEvictor.java:66)
        at java.lang.Thread.run(Thread.java:748)
  13) Thread[id=18471, name=zkCallback-4005-thread-2, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
  14) Thread[id=18478, name=zkCallback-4005-thread-5, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
  15) Thread[id=18467, name=OverseerCollectionConfigSetProcessor-99169666974613508-127.0.0.1:34329_-n_0000000000, state=WAITING, group=Overseer collection creation process.]
        at java.lang.Object.wait(Native Method)
        at java.lang.Object.wait(Object.java:502)
        at org.apache.zookeeper.ClientCnxn.submitRequest(ClientCnxn.java:1406)
        at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1210)
        at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
        at org.apache.solr.common.cloud.SolrZkClient$$Lambda$288/1110314523.execute(Unknown Source)
        at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
        at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
        at org.apache.solr.cloud.OverseerTaskProcessor.amILeader(OverseerTaskProcessor.java:387)
        at org.apache.solr.cloud.OverseerTaskProcessor.run(OverseerTaskProcessor.java:193)
        at java.lang.Thread.run(Thread.java:748)
  16) Thread[id=18476, name=ScheduledTrigger-7111-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.solr.common.cloud.ZkCmdExecutor.retryDelay(ZkCmdExecutor.java:111)
        at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:70)
        at org.apache.solr.common.cloud.SolrZkClient.getChildren(SolrZkClient.java:327)
        at org.apache.solr.cloud.ZkDistributedQueue.fetchZkChildren(ZkDistributedQueue.java:410)
        at org.apache.solr.cloud.ZkDistributedQueue.firstChild(ZkDistributedQueue.java:387)
        at org.apache.solr.cloud.ZkDistributedQueue.firstElement(ZkDistributedQueue.java:504)
        at org.apache.solr.cloud.ZkDistributedQueue.peek(ZkDistributedQueue.java:145)
        at org.apache.solr.cloud.autoscaling.TriggerEventQueue.peekEvent(TriggerEventQueue.java:69)
        at org.apache.solr.cloud.autoscaling.ScheduledTriggers$ScheduledTrigger.run(ScheduledTriggers.java:529)
        at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
        at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:308)
        at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$301(ScheduledThreadPoolExecutor.java:180)
        at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:294)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA]:0)


FAILED:  junit.framework.TestSuite.org.apache.solr.cloud.HttpPartitionTest

Error Message:
There are still zombie threads that couldn't be terminated:    1) Thread[id=18473, name=zkCallback-4005-thread-4, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    2) Thread[id=18470, name=zkCallback-4005-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    3) Thread[id=18479, name=zkCallback-4005-thread-6, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    4) Thread[id=18463, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-SendThread(127.0.0.1:35630), state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at java.lang.Thread.sleep(Native Method)         at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)         at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)    5) Thread[id=18472, name=zkCallback-4005-thread-3, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    6) Thread[id=18471, name=zkCallback-4005-thread-2, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    7) Thread[id=18478, name=zkCallback-4005-thread-5, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    8) Thread[id=18465, name=zkConnectionManagerCallback-4006-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)    9) Thread[id=18476, name=ScheduledTrigger-7111-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]         at sun.misc.Unsafe.park(Native Method)         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)         at java.util.concurrent.ScheduledThreadPoolExecutor$DelayedWorkQueue.take(ScheduledThreadPoolExecutor.java:1088)         at java.util.concurrent.ScheduledThreadPoolExecutor$DelayedWorkQueue.take(ScheduledThreadPoolExecutor.java:809)         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)         at java.lang.Thread.run(Thread.java:748)

Stack Trace:
com.carrotsearch.randomizedtesting.ThreadLeakError: There are still zombie threads that couldn't be terminated:
   1) Thread[id=18473, name=zkCallback-4005-thread-4, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   2) Thread[id=18470, name=zkCallback-4005-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   3) Thread[id=18479, name=zkCallback-4005-thread-6, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   4) Thread[id=18463, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-SendThread(127.0.0.1:35630), state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at java.lang.Thread.sleep(Native Method)
        at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)
        at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)
        at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)
   5) Thread[id=18472, name=zkCallback-4005-thread-3, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   6) Thread[id=18471, name=zkCallback-4005-thread-2, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   7) Thread[id=18478, name=zkCallback-4005-thread-5, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
        at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
        at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
        at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   8) Thread[id=18465, name=zkConnectionManagerCallback-4006-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
   9) Thread[id=18476, name=ScheduledTrigger-7111-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]
        at sun.misc.Unsafe.park(Native Method)
        at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
        at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
        at java.util.concurrent.ScheduledThreadPoolExecutor$DelayedWorkQueue.take(ScheduledThreadPoolExecutor.java:1088)
        at java.util.concurrent.ScheduledThreadPoolExecutor$DelayedWorkQueue.take(ScheduledThreadPoolExecutor.java:809)
        at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
        at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
        at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
        at java.lang.Thread.run(Thread.java:748)
	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA]:0)


FAILED:  org.apache.solr.cloud.LeaderElectionIntegrationTest.testSimpleSliceLeaderElection

Error Message:
Could not load collection from ZK: collection2

Stack Trace:
org.apache.solr.common.SolrException: Could not load collection from ZK: collection2
	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA:EC1552A73CEB190D]:0)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1123)
	at org.apache.solr.common.cloud.ZkStateReader$LazyCollectionRef.get(ZkStateReader.java:648)
	at org.apache.solr.common.cloud.ClusterState.getCollectionOrNull(ClusterState.java:130)
	at org.apache.solr.common.cloud.ZkStateReader.getLeader(ZkStateReader.java:743)
	at org.apache.solr.common.cloud.ZkStateReader.getLeaderRetry(ZkStateReader.java:765)
	at org.apache.solr.cloud.LeaderElectionIntegrationTest.getLeader(LeaderElectionIntegrationTest.java:168)
	at org.apache.solr.cloud.LeaderElectionIntegrationTest.testSimpleSliceLeaderElection(LeaderElectionIntegrationTest.java:121)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.zookeeper.KeeperException$SessionExpiredException: KeeperErrorCode = Session expired for /collections/collection2/state.json
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:127)
	at org.apache.zookeeper.KeeperException.create(KeeperException.java:51)
	at org.apache.zookeeper.ZooKeeper.getData(ZooKeeper.java:1212)
	at org.apache.solr.common.cloud.SolrZkClient.lambda$getData$5(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkCmdExecutor.retryOperation(ZkCmdExecutor.java:60)
	at org.apache.solr.common.cloud.SolrZkClient.getData(SolrZkClient.java:339)
	at org.apache.solr.common.cloud.ZkStateReader.fetchCollectionState(ZkStateReader.java:1135)
	at org.apache.solr.common.cloud.ZkStateReader.getCollectionLive(ZkStateReader.java:1121)
	... 45 more


FAILED:  org.apache.solr.update.SoftAutoCommitTest.testHardCommitWithinAndSoftCommitMaxTimeRapidAdds

Error Message:
softCommit: did not find a single commit

Stack Trace:
java.lang.AssertionError: softCommit: did not find a single commit
	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA:278F39BE9D86F797]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.junit.Assert.assertNotNull(Assert.java:526)
	at org.apache.solr.update.SoftAutoCommitTest.assertRapidMultiCommitQueues(SoftAutoCommitTest.java:494)
	at org.apache.solr.update.SoftAutoCommitTest.doTestSoftAndHardCommitMaxTimeRapidAdds(SoftAutoCommitTest.java:459)
	at org.apache.solr.update.SoftAutoCommitTest.testHardCommitWithinAndSoftCommitMaxTimeRapidAdds(SoftAutoCommitTest.java:411)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 12296 lines...]
   [junit4] Suite: org.apache.solr.cloud.LeaderElectionIntegrationTest
   [junit4]   2> Creating dataDir: /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/init-core-data-001
   [junit4]   2> 2107877 WARN  (SUITE-LeaderElectionIntegrationTest-seed#[B2219FE97F9485EA]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=6 numCloses=6
   [junit4]   2> 2107877 INFO  (SUITE-LeaderElectionIntegrationTest-seed#[B2219FE97F9485EA]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=true
   [junit4]   2> 2107878 INFO  (SUITE-LeaderElectionIntegrationTest-seed#[B2219FE97F9485EA]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (false) and clientAuth (true) via: @org.apache.solr.util.RandomizeSSL(reason=, value=NaN, ssl=NaN, clientAuth=NaN)
   [junit4]   2> 2107878 INFO  (SUITE-LeaderElectionIntegrationTest-seed#[B2219FE97F9485EA]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 2107892 INFO  (TEST-LeaderElectionIntegrationTest.testSimpleSliceLeaderElection-seed#[B2219FE97F9485EA]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testSimpleSliceLeaderElection
   [junit4]   2> 2107892 INFO  (TEST-LeaderElectionIntegrationTest.testSimpleSliceLeaderElection-seed#[B2219FE97F9485EA]) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 6 servers in /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001
   [junit4]   2> 2107892 INFO  (TEST-LeaderElectionIntegrationTest.testSimpleSliceLeaderElection-seed#[B2219FE97F9485EA]) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 2107916 INFO  (Thread-1465) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 2107916 INFO  (Thread-1465) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 2107932 ERROR (Thread-1465) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 2108026 INFO  (TEST-LeaderElectionIntegrationTest.testSimpleSliceLeaderElection-seed#[B2219FE97F9485EA]) [    ] o.a.s.c.ZkTestServer start zk server on port:38399
   [junit4]   2> 2108148 INFO  (zkConnectionManagerCallback-1121-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108165 INFO  (jetty-launcher-1118-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2108185 INFO  (jetty-launcher-1118-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2108243 INFO  (jetty-launcher-1118-thread-3) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2108244 INFO  (jetty-launcher-1118-thread-4) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2108244 INFO  (jetty-launcher-1118-thread-5) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2108258 INFO  (jetty-launcher-1118-thread-6) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2108400 INFO  (jetty-launcher-1118-thread-3) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@785af814{/solr,null,AVAILABLE}
   [junit4]   2> 2108400 INFO  (jetty-launcher-1118-thread-3) [    ] o.e.j.s.AbstractConnector Started ServerConnector@29c71281{HTTP/1.1,[http/1.1]}{127.0.0.1:32808}
   [junit4]   2> 2108400 INFO  (jetty-launcher-1118-thread-3) [    ] o.e.j.s.Server Started @2124131ms
   [junit4]   2> 2108400 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=32808}
   [junit4]   2> 2108401 ERROR (jetty-launcher-1118-thread-3) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2108401 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2108401 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2108401 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2108401 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-13T22:58:48.953Z
   [junit4]   2> 2108420 INFO  (jetty-launcher-1118-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@100a3d71{/solr,null,AVAILABLE}
   [junit4]   2> 2108420 INFO  (jetty-launcher-1118-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@4c72d72d{HTTP/1.1,[http/1.1]}{127.0.0.1:38306}
   [junit4]   2> 2108420 INFO  (jetty-launcher-1118-thread-1) [    ] o.e.j.s.Server Started @2124151ms
   [junit4]   2> 2108420 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=38306}
   [junit4]   2> 2108421 ERROR (jetty-launcher-1118-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2108421 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2108421 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2108421 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2108421 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-13T22:58:48.973Z
   [junit4]   2> 2108473 INFO  (jetty-launcher-1118-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@50b5db46{/solr,null,AVAILABLE}
   [junit4]   2> 2108473 INFO  (jetty-launcher-1118-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@53ab1966{HTTP/1.1,[http/1.1]}{127.0.0.1:39213}
   [junit4]   2> 2108473 INFO  (jetty-launcher-1118-thread-2) [    ] o.e.j.s.Server Started @2124204ms
   [junit4]   2> 2108473 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=39213}
   [junit4]   2> 2108473 ERROR (jetty-launcher-1118-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2108474 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2108474 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2108474 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2108474 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-13T22:58:49.026Z
   [junit4]   2> 2108532 INFO  (jetty-launcher-1118-thread-6) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@3889d2c4{/solr,null,AVAILABLE}
   [junit4]   2> 2108532 INFO  (jetty-launcher-1118-thread-6) [    ] o.e.j.s.AbstractConnector Started ServerConnector@ffd8ed5{HTTP/1.1,[http/1.1]}{127.0.0.1:43476}
   [junit4]   2> 2108532 INFO  (jetty-launcher-1118-thread-6) [    ] o.e.j.s.Server Started @2124263ms
   [junit4]   2> 2108532 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=43476}
   [junit4]   2> 2108532 ERROR (jetty-launcher-1118-thread-6) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2108532 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2108533 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2108533 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2108533 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-13T22:58:49.085Z
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@708166aa{/solr,null,AVAILABLE}
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.e.j.s.AbstractConnector Started ServerConnector@66058a72{HTTP/1.1,[http/1.1]}{127.0.0.1:39667}
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.e.j.s.Server Started @2124427ms
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=39667}
   [junit4]   2> 2108696 ERROR (jetty-launcher-1118-thread-5) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2108696 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-13T22:58:49.248Z
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@7ceb2db2{/solr,null,AVAILABLE}
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.e.j.s.AbstractConnector Started ServerConnector@77ff1819{HTTP/1.1,[http/1.1]}{127.0.0.1:33422}
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.e.j.s.Server Started @2124448ms
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=33422}
   [junit4]   2> 2108717 ERROR (jetty-launcher-1118-thread-4) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2108717 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-13T22:58:49.269Z
   [junit4]   2> 2108745 INFO  (zkConnectionManagerCallback-1129-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108745 INFO  (zkConnectionManagerCallback-1127-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108773 INFO  (zkConnectionManagerCallback-1123-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108773 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2108801 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2108801 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2108854 INFO  (zkConnectionManagerCallback-1131-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108870 INFO  (zkConnectionManagerCallback-1125-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108887 INFO  (jetty-launcher-1118-thread-6) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:38399/solr
   [junit4]   2> 2108888 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160521a12150004, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2108913 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2108890 INFO  (zkConnectionManagerCallback-1133-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2108943 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2109021 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2109037 INFO  (zkConnectionManagerCallback-1137-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109057 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160521a12150005, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2109132 INFO  (jetty-launcher-1118-thread-5) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:38399/solr
   [junit4]   2> 2109148 INFO  (zkConnectionManagerCallback-1141-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109168 INFO  (zkConnectionManagerCallback-1143-thread-1-processing-n:127.0.0.1:39667_solr) [n:127.0.0.1:39667_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109254 INFO  (jetty-launcher-1118-thread-3) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:38399/solr
   [junit4]   2> 2109345 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160521a12150002, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2109455 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160521a12150006, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2109455 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160521a12150007, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2109455 INFO  (jetty-launcher-1118-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:38399/solr
   [junit4]   2> 2109374 INFO  (zkConnectionManagerCallback-1148-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109557 INFO  (jetty-launcher-1118-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:38399/solr
   [junit4]   2> 2109587 INFO  (jetty-launcher-1118-thread-4) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:38399/solr
   [junit4]   2> 2109610 INFO  (zkConnectionManagerCallback-1156-thread-1-processing-n:127.0.0.1:43476_solr) [n:127.0.0.1:43476_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109650 INFO  (zkConnectionManagerCallback-1152-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109658 INFO  (zkConnectionManagerCallback-1162-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109661 INFO  (zkConnectionManagerCallback-1166-thread-1-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109687 INFO  (zkConnectionManagerCallback-1158-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109714 INFO  (zkConnectionManagerCallback-1164-thread-1-processing-n:127.0.0.1:32808_solr) [n:127.0.0.1:32808_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109715 INFO  (zkConnectionManagerCallback-1168-thread-1-processing-n:127.0.0.1:39213_solr) [n:127.0.0.1:39213_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109731 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x160521a1215000c, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2109878 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2109913 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:33422_solr
   [junit4]   2> 2109922 INFO  (zkConnectionManagerCallback-1171-thread-1-processing-n:127.0.0.1:38306_solr) [n:127.0.0.1:38306_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2109934 INFO  (jetty-launcher-1118-thread-3) [n:127.0.0.1:32808_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2109971 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.c.Overseer Overseer (id=99169463728144399-127.0.0.1:33422_solr-n_0000000000) starting
   [junit4]   2> 2109971 INFO  (jetty-launcher-1118-thread-6) [n:127.0.0.1:43476_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2109972 INFO  (jetty-launcher-1118-thread-3) [n:127.0.0.1:32808_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:32808_solr
   [junit4]   2> 2109998 INFO  (jetty-launcher-1118-thread-2) [n:127.0.0.1:39213_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2110025 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2110173 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2110174 INFO  (jetty-launcher-1118-thread-6) [n:127.0.0.1:43476_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:43476_solr
   [junit4]   2> 2110230 INFO  (zkCallback-1167-thread-1-processing-n:127.0.0.1:39213_solr) [n:127.0.0.1:39213_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2110242 INFO  (zkCallback-1163-thread-1-processing-n:127.0.0.1:32808_solr) [n:127.0.0.1:32808_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2110242 INFO  (zkCallback-1165-thread-1-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2110243 INFO  (zkCallback-1155-thread-1-processing-n:127.0.0.1:43476_solr) [n:127.0.0.1:43476_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2110247 INFO  (jetty-launcher-1118-thread-2) [n:127.0.0.1:39213_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:39213_solr
   [junit4]   2> 2110249 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:38306_solr
   [junit4]   2> 2110284 INFO  (OverseerStateUpdate-99169463728144399-127.0.0.1:33422_solr-n_0000000000) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (4)
   [junit4]   2> 2110305 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:33422_solr
   [junit4]   2> 2110335 INFO  (zkCallback-1163-thread-1-processing-n:127.0.0.1:32808_solr) [n:127.0.0.1:32808_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (5)
   [junit4]   2> 2110357 INFO  (zkCallback-1167-thread-1-processing-n:127.0.0.1:39213_solr) [n:127.0.0.1:39213_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (5)
   [junit4]   2> 2110372 INFO  (zkCallback-1165-thread-1-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (4) -> (5)
   [junit4]   2> 2110372 INFO  (zkCallback-1155-thread-1-processing-n:127.0.0.1:43476_solr) [n:127.0.0.1:43476_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (5)
   [junit4]   2> 2110498 INFO  (zkCallback-1170-thread-1-processing-n:127.0.0.1:38306_solr) [n:127.0.0.1:38306_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (5)
   [junit4]   2> 2111086 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38306.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111102 INFO  (jetty-launcher-1118-thread-3) [n:127.0.0.1:32808_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_32808.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111193 INFO  (jetty-launcher-1118-thread-3) [n:127.0.0.1:32808_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_32808.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111193 INFO  (jetty-launcher-1118-thread-3) [n:127.0.0.1:32808_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_32808.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111209 INFO  (jetty-launcher-1118-thread-3) [n:127.0.0.1:32808_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001/node3/.
   [junit4]   2> 2111230 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_33422.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111524 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_33422.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111524 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_33422.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111526 INFO  (jetty-launcher-1118-thread-4) [n:127.0.0.1:33422_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001/node4/.
   [junit4]   2> 2111566 INFO  (jetty-launcher-1118-thread-6) [n:127.0.0.1:43476_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_43476.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111594 INFO  (jetty-launcher-1118-thread-6) [n:127.0.0.1:43476_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_43476.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111594 INFO  (jetty-launcher-1118-thread-6) [n:127.0.0.1:43476_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_43476.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111612 INFO  (jetty-launcher-1118-thread-6) [n:127.0.0.1:43476_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001/node6/.
   [junit4]   2> 2111623 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38306.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111623 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_38306.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111650 INFO  (jetty-launcher-1118-thread-2) [n:127.0.0.1:39213_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39213.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111657 INFO  (jetty-launcher-1118-thread-1) [n:127.0.0.1:38306_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001/node1/.
   [junit4]   2> 2111704 INFO  (jetty-launcher-1118-thread-2) [n:127.0.0.1:39213_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39213.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111704 INFO  (jetty-launcher-1118-thread-2) [n:127.0.0.1:39213_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39213.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2111722 INFO  (jetty-launcher-1118-thread-2) [n:127.0.0.1:39213_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001/node2/.
   [junit4]   2> 2113022 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (5)
   [junit4]   2> 2113024 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2113026 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:39667_solr
   [junit4]   2> 2113044 INFO  (zkCallback-1155-thread-1-processing-n:127.0.0.1:43476_solr) [n:127.0.0.1:43476_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (5) -> (6)
   [junit4]   2> 2113059 INFO  (zkCallback-1170-thread-1-processing-n:127.0.0.1:38306_solr) [n:127.0.0.1:38306_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (5) -> (6)
   [junit4]   2> 2113071 INFO  (zkCallback-1163-thread-1-processing-n:127.0.0.1:32808_solr) [n:127.0.0.1:32808_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (5) -> (6)
   [junit4]   2> 2113096 INFO  (zkCallback-1165-thread-1-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (5) -> (6)
   [junit4]   2> 2113096 INFO  (zkCallback-1167-thread-1-processing-n:127.0.0.1:39213_solr) [n:127.0.0.1:39213_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (5) -> (6)
   [junit4]   2> 2113097 INFO  (zkCallback-1142-thread-1-processing-n:127.0.0.1:39667_solr) [n:127.0.0.1:39667_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (5) -> (6)
   [junit4]   2> 2113368 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39667.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2113403 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39667.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2113403 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_39667.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2113417 INFO  (jetty-launcher-1118-thread-5) [n:127.0.0.1:39667_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.LeaderElectionIntegrationTest_B2219FE97F9485EA-001/tempDir-001/node5/.
   [junit4]   2> 2113673 INFO  (zkConnectionManagerCallback-1178-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2113677 INFO  (zkConnectionManagerCallback-1182-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2113678 INFO  (TEST-LeaderElectionIntegrationTest.testSimpleSliceLeaderElection-seed#[B2219FE97F9485EA]) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (6)
   [junit4]   2> 2113678 INFO  (TEST-LeaderElectionIntegrationTest.testSimpleSliceLeaderElection-seed#[B2219FE97F9485EA]) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:38399/solr ready
   [junit4]   2> 2113740 INFO  (qtp862298713-5951) [n:127.0.0.1:33422_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=1&collection.configName=conf&maxShardsPerNode=1&name=collection1&nrtReplicas=1&action=CREATE&numShards=2&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 2113775 INFO  (OverseerThreadFactory-2554-thread-1-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.CreateCollectionCmd Create collection collection1
   [junit4]   2> 2113999 INFO  (OverseerStateUpdate-99169463728144399-127.0.0.1:33422_solr-n_0000000000) [n:127.0.0.1:33422_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"collection1",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":"collection1_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:39667/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2114072 INFO  (OverseerStateUpdate-99169463728144399-127.0.0.1:33422_solr-n_0000000000) [n:127.0.0.1:33422_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":"collection1",
   [junit4]   2>   "shard":"shard2",
   [junit4]   2>   "core":"collection1_shard2_replica_n2",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"http://127.0.0.1:33422/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2114336 INFO  (qtp1829513351-5937) [n:127.0.0.1:39667_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node3&collection.configName=conf&newCollection=true&name=collection1_shard1_replica_n1&action=CREATE&numShards=2&collection=collection1&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2114336 INFO  (qtp1829513351-5937) [n:127.0.0.1:39667_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2114594 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node4&collection.configName=conf&newCollection=true&name=collection1_shard2_replica_n2&action=CREATE&numShards=2&collection=collection1&shard=shard2&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2114594 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2114850 INFO  (zkCallback-1142-thread-1-processing-n:127.0.0.1:39667_solr) [n:127.0.0.1:39667_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/collection1/state.json] for collection [collection1] has occurred - updating... (live nodes size: [6])
   [junit4]   2> 2114865 INFO  (zkCallback-1165-thread-1-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/collection1/state.json] for collection [collection1] has occurred - updating... (live nodes size: [6])
   [junit4]   2> 2114882 INFO  (zkCallback-1142-thread-2-processing-n:127.0.0.1:39667_solr) [n:127.0.0.1:39667_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/collection1/state.json] for collection [collection1] has occurred - updating... (live nodes size: [6])
   [junit4]   2> 2114882 INFO  (zkCallback-1165-thread-2-processing-n:127.0.0.1:33422_solr) [n:127.0.0.1:33422_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/collection1/state.json] for collection [collection1] has occurred - updating... (live nodes size: [6])
   [junit4]   2> 2115690 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 2115741 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.s.IndexSchema [collection1_shard2_replica_n2] Schema name=minimal
   [junit4]   2> 2115743 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.s.IndexSchema Loaded schema minimal/1.1 with uniqueid field id
   [junit4]   2> 2115743 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.c.CoreContainer Creating SolrCore 'collection1_shard2_replica_n2' using configuration from collection collection1, trusted=true
   [junit4]   2> 2115757 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_33422.solr.core.collection1.shard2.replica_n2' (registry 'solr.core.collection1.shard2.replica_n2') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@2b5285e0
   [junit4]   2> 2115757 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 2115757 INFO  (qtp862298713-5953) [n:127.0.0.1:33422_solr c:collection1 s:shard2 r:core_node4 x:collection1_shard2_replica_n2] o.a.s.c.SolrCore [[collection1_shard2_replica_n2] ] Opening new SolrCore at [/home/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/t

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

nit4]    >         at org.apache.solr.cloud.autoscaling.TriggerEventQueue.peekEvent(TriggerEventQueue.java:69)
   [junit4]    >         at org.apache.solr.cloud.autoscaling.ScheduledTriggers$ScheduledTrigger.run(ScheduledTriggers.java:529)
   [junit4]    >         at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511)
   [junit4]    >         at java.util.concurrent.FutureTask.runAndReset(FutureTask.java:308)
   [junit4]    >         at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.access$301(ScheduledThreadPoolExecutor.java:180)
   [junit4]    >         at java.util.concurrent.ScheduledThreadPoolExecutor$ScheduledFutureTask.run(ScheduledThreadPoolExecutor.java:294)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA]:0)Throwable #2: com.carrotsearch.randomizedtesting.ThreadLeakError: There are still zombie threads that couldn't be terminated:
   [junit4]    >    1) Thread[id=18473, name=zkCallback-4005-thread-4, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    2) Thread[id=18470, name=zkCallback-4005-thread-1, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    3) Thread[id=18479, name=zkCallback-4005-thread-6, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    4) Thread[id=18463, name=TEST-HttpPartitionTest.test-seed#[B2219FE97F9485EA]-SendThread(127.0.0.1:35630), state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at java.lang.Thread.sleep(Native Method)
   [junit4]    >         at org.apache.zookeeper.client.StaticHostProvider.next(StaticHostProvider.java:101)
   [junit4]    >         at org.apache.zookeeper.ClientCnxn$SendThread.startConnect(ClientCnxn.java:997)
   [junit4]    >         at org.apache.zookeeper.ClientCnxn$SendThread.run(ClientCnxn.java:1060)
   [junit4]    >    5) Thread[id=18472, name=zkCallback-4005-thread-3, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    6) Thread[id=18471, name=zkCallback-4005-thread-2, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    7) Thread[id=18478, name=zkCallback-4005-thread-5, state=TIMED_WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.awaitFulfill(SynchronousQueue.java:460)
   [junit4]    >         at java.util.concurrent.SynchronousQueue$TransferStack.transfer(SynchronousQueue.java:362)
   [junit4]    >         at java.util.concurrent.SynchronousQueue.poll(SynchronousQueue.java:941)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1073)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    8) Thread[id=18465, name=zkConnectionManagerCallback-4006-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
   [junit4]    >         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
   [junit4]    >         at java.util.concurrent.LinkedBlockingQueue.take(LinkedBlockingQueue.java:442)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    >    9) Thread[id=18476, name=ScheduledTrigger-7111-thread-1, state=WAITING, group=TGRP-HttpPartitionTest]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.park(LockSupport.java:175)
   [junit4]    >         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2039)
   [junit4]    >         at java.util.concurrent.ScheduledThreadPoolExecutor$DelayedWorkQueue.take(ScheduledThreadPoolExecutor.java:1088)
   [junit4]    >         at java.util.concurrent.ScheduledThreadPoolExecutor$DelayedWorkQueue.take(ScheduledThreadPoolExecutor.java:809)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.getTask(ThreadPoolExecutor.java:1074)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1134)
   [junit4]    >         at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
   [junit4]    >         at java.lang.Thread.run(Thread.java:748)
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([B2219FE97F9485EA]:0)
   [junit4] Completed [526/751 (3!)] on J2 in 46.23s, 1 test, 3 errors <<< FAILURES!

[...truncated 48023 lines...]

[JENKINS] Lucene-Solr-Tests-7.2 - Build # 11 - Still Unstable

Posted by Apache Jenkins Server <je...@builds.apache.org>.
Build: https://builds.apache.org/job/Lucene-Solr-Tests-7.2/11/

11 tests failed.
FAILED:  org.apache.solr.cloud.BasicDistributedZkTest.test

Error Message:
Error from server at http://127.0.0.1:44046/collection1: Cannot talk to ZooKeeper - Updates are disabled.

Stack Trace:
org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at http://127.0.0.1:44046/collection1: Cannot talk to ZooKeeper - Updates are disabled.
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:78C2D323C667ED7B]:0)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
	at org.apache.solr.BaseDistributedSearchTestCase.add(BaseDistributedSearchTestCase.java:507)
	at org.apache.solr.cloud.BasicDistributedZkTest.testUpdateProcessorsRunOnlyOnce(BasicDistributedZkTest.java:683)
	at org.apache.solr.cloud.BasicDistributedZkTest.test(BasicDistributedZkTest.java:377)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.CustomCollectionTest.testRouteFieldForImplicitRouter

Error Message:
Error from server at https://127.0.0.1:44680/solr: KeeperErrorCode = NoNode for /overseer/collection-queue-work/qnr-0000000006

Stack Trace:
org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at https://127.0.0.1:44680/solr: KeeperErrorCode = NoNode for /overseer/collection-queue-work/qnr-0000000006
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:A5C6046BC4624F73]:0)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:643)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1103)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:211)
	at org.apache.solr.cloud.CustomCollectionTest.testRouteFieldForImplicitRouter(CustomCollectionTest.java:135)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.FullSolrCloudDistribCmdsTest.test

Error Message:
Timeout occured while waiting response from server at: http://127.0.0.1:44570

Stack Trace:
org.apache.solr.client.solrj.SolrServerException: Timeout occured while waiting response from server at: http://127.0.0.1:44570
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:78C2D323C667ED7B]:0)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:654)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1103)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrClient.request(SolrClient.java:1219)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.createCollection(AbstractFullDistribZkTestBase.java:1668)
	at org.apache.solr.cloud.AbstractFullDistribZkTestBase.createCollection(AbstractFullDistribZkTestBase.java:1695)
	at org.apache.solr.cloud.FullSolrCloudDistribCmdsTest.testIndexingBatchPerRequestWithHttpSolrClient(FullSolrCloudDistribCmdsTest.java:610)
	at org.apache.solr.cloud.FullSolrCloudDistribCmdsTest.test(FullSolrCloudDistribCmdsTest.java:152)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: java.net.SocketTimeoutException: Read timed out
	at java.net.SocketInputStream.socketRead0(Native Method)
	at java.net.SocketInputStream.socketRead(SocketInputStream.java:116)
	at java.net.SocketInputStream.read(SocketInputStream.java:171)
	at java.net.SocketInputStream.read(SocketInputStream.java:141)
	at org.apache.http.impl.io.SessionInputBufferImpl.streamRead(SessionInputBufferImpl.java:137)
	at org.apache.http.impl.io.SessionInputBufferImpl.fillBuffer(SessionInputBufferImpl.java:153)
	at org.apache.http.impl.io.SessionInputBufferImpl.readLine(SessionInputBufferImpl.java:282)
	at org.apache.http.impl.conn.DefaultHttpResponseParser.parseHead(DefaultHttpResponseParser.java:138)
	at org.apache.http.impl.conn.DefaultHttpResponseParser.parseHead(DefaultHttpResponseParser.java:56)
	at org.apache.http.impl.io.AbstractMessageParser.parse(AbstractMessageParser.java:259)
	at org.apache.http.impl.DefaultBHttpClientConnection.receiveResponseHeader(DefaultBHttpClientConnection.java:163)
	at org.apache.http.impl.conn.CPoolProxy.receiveResponseHeader(CPoolProxy.java:165)
	at org.apache.http.protocol.HttpRequestExecutor.doReceiveResponse(HttpRequestExecutor.java:273)
	at org.apache.http.protocol.HttpRequestExecutor.execute(HttpRequestExecutor.java:125)
	at org.apache.http.impl.execchain.MainClientExec.execute(MainClientExec.java:272)
	at org.apache.http.impl.execchain.ProtocolExec.execute(ProtocolExec.java:185)
	at org.apache.http.impl.execchain.RetryExec.execute(RetryExec.java:89)
	at org.apache.http.impl.execchain.RedirectExec.execute(RedirectExec.java:111)
	at org.apache.http.impl.client.InternalHttpClient.doExecute(InternalHttpClient.java:185)
	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:83)
	at org.apache.http.impl.client.CloseableHttpClient.execute(CloseableHttpClient.java:56)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:542)
	... 53 more


FAILED:  org.apache.solr.cloud.OverseerTaskQueueTest.testPeekElements

Error Message:


Stack Trace:
java.lang.AssertionError
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:DB856D8B8A2D49E]:0)
	at org.junit.Assert.fail(Assert.java:92)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.junit.Assert.assertTrue(Assert.java:54)
	at org.apache.solr.cloud.DistributedQueueTest.testPeekElements(DistributedQueueTest.java:265)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.ShardSplitTest.testSplitAfterFailedSplit

Error Message:
Shard split did not succeed after a previous failed split attempt left sub-shards in construction state

Stack Trace:
java.lang.AssertionError: Shard split did not succeed after a previous failed split attempt left sub-shards in construction state
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:9DB7F5654EECD09]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.ShardSplitTest.testSplitAfterFailedSplit(ShardSplitTest.java:294)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsFixedStatement.callStatement(BaseDistributedSearchTestCase.java:993)
	at org.apache.solr.BaseDistributedSearchTestCase$ShardsRepeatRule$ShardsStatement.evaluate(BaseDistributedSearchTestCase.java:968)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateSearchDelete

Error Message:
Error from server at https://127.0.0.1:49810/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html> <head> <meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/> <title>Error 404 </title> </head> <body> <h2>HTTP ERROR: 404</h2> <p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason: <pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p> <hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/> </body> </html> 

Stack Trace:
org.apache.solr.client.solrj.impl.CloudSolrClient$RouteException: Error from server at https://127.0.0.1:49810/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason:
<pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:536C425CEF736A26]:0)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.directUpdate(CloudSolrClient.java:549)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.sendRequest(CloudSolrClient.java:1012)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:883)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.requestWithRetryOnStaleState(CloudSolrClient.java:945)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.request(CloudSolrClient.java:816)
	at org.apache.solr.client.solrj.SolrRequest.process(SolrRequest.java:194)
	at org.apache.solr.client.solrj.request.UpdateRequest.commit(UpdateRequest.java:233)
	at org.apache.solr.cloud.TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateSearchDelete(TestCollectionsAPIViaSolrCloudCluster.java:167)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)
Caused by: org.apache.solr.client.solrj.impl.HttpSolrClient$RemoteSolrException: Error from server at https://127.0.0.1:49810/solr/testcollection_shard1_replica_n2: Expected mime type application/octet-stream but got text/html. <html>
<head>
<meta http-equiv="Content-Type" content="text/html;charset=ISO-8859-1"/>
<title>Error 404 </title>
</head>
<body>
<h2>HTTP ERROR: 404</h2>
<p>Problem accessing /solr/testcollection_shard1_replica_n2/update. Reason:
<pre>    Can not find: /solr/testcollection_shard1_replica_n2/update</pre></p>
<hr /><a href="http://eclipse.org/jetty">Powered by Jetty:// 9.3.20.v20170531</a><hr/>
</body>
</html>

	at org.apache.solr.client.solrj.impl.HttpSolrClient.executeMethod(HttpSolrClient.java:607)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:255)
	at org.apache.solr.client.solrj.impl.HttpSolrClient.request(HttpSolrClient.java:244)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.doRequest(LBHttpSolrClient.java:483)
	at org.apache.solr.client.solrj.impl.LBHttpSolrClient.request(LBHttpSolrClient.java:413)
	at org.apache.solr.client.solrj.impl.CloudSolrClient.lambda$directUpdate$0(CloudSolrClient.java:526)
	at java.util.concurrent.FutureTask.run(FutureTask.java:266)
	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:188)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624)
	... 1 more


FAILED:  org.apache.solr.cloud.TestLocalFSCloudBackupRestore.test

Error Message:
expected:<COMPLETED> but was:<RUNNING>

Stack Trace:
java.lang.AssertionError: expected:<COMPLETED> but was:<RUNNING>
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:78C2D323C667ED7B]: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:147)
	at org.apache.solr.cloud.AbstractCloudBackupRestoreTestCase.testBackupAndRestore(AbstractCloudBackupRestoreTestCase.java:287)
	at org.apache.solr.cloud.AbstractCloudBackupRestoreTestCase.test(AbstractCloudBackupRestoreTestCase.java:140)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestPullReplica.testKillPullReplica

Error Message:
Didn't update state null Live Nodes: [127.0.0.1:43697_solr, 127.0.0.1:57766_solr] Last available state: DocCollection(pull_replica_test_kill_pull_replica//collections/pull_replica_test_kill_pull_replica/state.json/8)={   "pullReplicas":"1",   "replicationFactor":"1",   "shards":{"shard1":{       "range":"80000000-7fffffff",       "state":"active",       "replicas":{         "core_node3":{           "core":"pull_replica_test_kill_pull_replica_shard1_replica_n1",           "base_url":"https://127.0.0.1:57766/solr",           "node_name":"127.0.0.1:57766_solr",           "state":"active",           "type":"NRT",           "leader":"true"},         "core_node4":{           "core":"pull_replica_test_kill_pull_replica_shard1_replica_p2",           "base_url":"https://127.0.0.1:43697/solr",           "node_name":"127.0.0.1:43697_solr",           "state":"down",           "type":"PULL"}}}},   "router":{"name":"compositeId"},   "maxShardsPerNode":"100",   "autoAddReplicas":"false",   "nrtReplicas":"1",   "tlogReplicas":"0"}

Stack Trace:
java.lang.AssertionError: Didn't update state
null
Live Nodes: [127.0.0.1:43697_solr, 127.0.0.1:57766_solr]
Last available state: DocCollection(pull_replica_test_kill_pull_replica//collections/pull_replica_test_kill_pull_replica/state.json/8)={
  "pullReplicas":"1",
  "replicationFactor":"1",
  "shards":{"shard1":{
      "range":"80000000-7fffffff",
      "state":"active",
      "replicas":{
        "core_node3":{
          "core":"pull_replica_test_kill_pull_replica_shard1_replica_n1",
          "base_url":"https://127.0.0.1:57766/solr",
          "node_name":"127.0.0.1:57766_solr",
          "state":"active",
          "type":"NRT",
          "leader":"true"},
        "core_node4":{
          "core":"pull_replica_test_kill_pull_replica_shard1_replica_p2",
          "base_url":"https://127.0.0.1:43697/solr",
          "node_name":"127.0.0.1:43697_solr",
          "state":"down",
          "type":"PULL"}}}},
  "router":{"name":"compositeId"},
  "maxShardsPerNode":"100",
  "autoAddReplicas":"false",
  "nrtReplicas":"1",
  "tlogReplicas":"0"}
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:7C67F06CC82A61BB]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.apache.solr.cloud.SolrCloudTestCase.waitForState(SolrCloudTestCase.java:269)
	at org.apache.solr.cloud.TestPullReplica.testKillPullReplica(TestPullReplica.java:478)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.TestTolerantUpdateProcessorRandomCloud.testRandomUpdates

Error Message:
org.apache.solr.client.solrj.impl.CloudSolrClient@3b1ad338 => [type=<ADD>,id=<id_22464>,msgSubStr=<null>, type=<ADD>,id=<(unknown)>,msgSubStr=<null>, type=<DELID>,id=<id_17074>,msgSubStr=<null>, type=<ADD>,id=<id_9173>,msgSubStr=<null>, type=<DELQ>,id=<foo_i:[11199 TO ....giberish>,msgSubStr=<null>]: Num error ids: [{type=ADD,id=id_22464,message=ClusterState says we are the leader (http://127.0.0.1:51152/solr/test_col_shard3_replica_n11), but locally we don't think so. Request came from null}, {type=ADD,id=id_9918,message=ClusterState says we are the leader (http://127.0.0.1:51152/solr/test_col_shard3_replica_n11), but locally we don't think so. Request came from null}, {type=ADD,id=(unknown),message=Document is missing mandatory uniqueKey field: id}, {type=DELID,id=id_17074,message=ClusterState says we are the leader (http://127.0.0.1:51152/solr/test_col_shard3_replica_n11), but locally we don't think so. Request came from null}, {type=DELQ,id=foo_i:[11199 TO ....giberish,message=org.apache.solr.search.SyntaxError: Cannot parse 'foo_i:[11199 TO ....giberish': Encountered "<EOF>" at line 1, column 28. Was expecting one of:     "]" ...     "}" ...     }, {type=ADD,id=id_9173,message=ERROR: [doc=id_9173] Error adding field 'foo_i'='[bogus_val]' msg=For input string: "bogus_val"}] expected:<5> but was:<6>

Stack Trace:
java.lang.AssertionError: org.apache.solr.client.solrj.impl.CloudSolrClient@3b1ad338 => [type=<ADD>,id=<id_22464>,msgSubStr=<null>, type=<ADD>,id=<(unknown)>,msgSubStr=<null>, type=<DELID>,id=<id_17074>,msgSubStr=<null>, type=<ADD>,id=<id_9173>,msgSubStr=<null>, type=<DELQ>,id=<foo_i:[11199 TO ....giberish>,msgSubStr=<null>]: Num error ids: [{type=ADD,id=id_22464,message=ClusterState says we are the leader (http://127.0.0.1:51152/solr/test_col_shard3_replica_n11), but locally we don't think so. Request came from null}, {type=ADD,id=id_9918,message=ClusterState says we are the leader (http://127.0.0.1:51152/solr/test_col_shard3_replica_n11), but locally we don't think so. Request came from null}, {type=ADD,id=(unknown),message=Document is missing mandatory uniqueKey field: id}, {type=DELID,id=id_17074,message=ClusterState says we are the leader (http://127.0.0.1:51152/solr/test_col_shard3_replica_n11), but locally we don't think so. Request came from null}, {type=DELQ,id=foo_i:[11199 TO ....giberish,message=org.apache.solr.search.SyntaxError: Cannot parse 'foo_i:[11199 TO ....giberish': Encountered "<EOF>" at line 1, column 28.
Was expecting one of:
    "]" ...
    "}" ...
    }, {type=ADD,id=id_9173,message=ERROR: [doc=id_9173] Error adding field 'foo_i'='[bogus_val]' msg=For input string: "bogus_val"}] expected:<5> but was:<6>
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:CC5739491FE67E91]: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.TestTolerantUpdateProcessorCloud.assertUpdateTolerantErrors(TestTolerantUpdateProcessorCloud.java:969)
	at org.apache.solr.cloud.TestTolerantUpdateProcessorRandomCloud.testRandomUpdates(TestTolerantUpdateProcessorRandomCloud.java:269)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.autoscaling.SystemLogListenerTest.test

Error Message:
Trigger was not fired 

Stack Trace:
java.lang.AssertionError: Trigger was not fired 
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:78C2D323C667ED7B]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.SystemLogListenerTest.test(SystemLogListenerTest.java:151)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)


FAILED:  org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testEventQueue

Error Message:
action wasn't interrupted

Stack Trace:
java.lang.AssertionError: action wasn't interrupted
	at __randomizedtesting.SeedInfo.seed([F096ECF9689B8083:3923AE5761FC4676]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.TriggerIntegrationTest.testEventQueue(TriggerIntegrationTest.java:706)
	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:498)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1737)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:934)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:970)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:984)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.TestRuleSetupTeardownChained$1.evaluate(TestRuleSetupTeardownChained.java:49)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at org.apache.lucene.util.TestRuleThreadAndTestName$1.evaluate(TestRuleThreadAndTestName.java:48)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl.forkTimeoutingTask(ThreadLeakControl.java:817)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$3.evaluate(ThreadLeakControl.java:468)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.runSingleTest(RandomizedRunner.java:943)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:829)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:879)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:890)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.SystemPropertiesRestoreRule$1.evaluate(SystemPropertiesRestoreRule.java:57)
	at org.apache.lucene.util.AbstractBeforeAfterRule$1.evaluate(AbstractBeforeAfterRule.java:45)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleStoreClassName$1.evaluate(TestRuleStoreClassName.java:41)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.NoShadowingOrOverridesOnMethodsRule$1.evaluate(NoShadowingOrOverridesOnMethodsRule.java:40)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at org.apache.lucene.util.TestRuleAssertionsRequired$1.evaluate(TestRuleAssertionsRequired.java:53)
	at org.apache.lucene.util.TestRuleMarkFailure$1.evaluate(TestRuleMarkFailure.java:47)
	at org.apache.lucene.util.TestRuleIgnoreAfterMaxFailures$1.evaluate(TestRuleIgnoreAfterMaxFailures.java:64)
	at org.apache.lucene.util.TestRuleIgnoreTestSuites$1.evaluate(TestRuleIgnoreTestSuites.java:54)
	at com.carrotsearch.randomizedtesting.rules.StatementAdapter.evaluate(StatementAdapter.java:36)
	at com.carrotsearch.randomizedtesting.ThreadLeakControl$StatementRunner.run(ThreadLeakControl.java:368)
	at java.lang.Thread.run(Thread.java:748)




Build Log:
[...truncated 12215 lines...]
   [junit4] Suite: org.apache.solr.cloud.autoscaling.SystemLogListenerTest
   [junit4]   2> Creating dataDir: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.autoscaling.SystemLogListenerTest_F096ECF9689B8083-001/init-core-data-001
   [junit4]   2> 2781111 WARN  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.SolrTestCaseJ4 startTrackingSearchers: numOpens=13 numCloses=13
   [junit4]   2> 2781111 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 2781112 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.SolrTestCaseJ4 Randomized ssl (true) and clientAuth (false) via: @org.apache.solr.util.RandomizeSSL(reason=, value=NaN, ssl=NaN, clientAuth=NaN)
   [junit4]   2> 2781112 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> 2781113 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.c.MiniSolrCloudCluster Starting cluster of 3 servers in /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.autoscaling.SystemLogListenerTest_F096ECF9689B8083-001/tempDir-001
   [junit4]   2> 2781113 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.c.ZkTestServer STARTING ZK TEST SERVER
   [junit4]   2> 2781138 INFO  (Thread-1348) [    ] o.a.s.c.ZkTestServer client port:0.0.0.0/0.0.0.0:0
   [junit4]   2> 2781138 INFO  (Thread-1348) [    ] o.a.s.c.ZkTestServer Starting server
   [junit4]   2> 2781150 ERROR (Thread-1348) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 2781242 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.c.ZkTestServer start zk server on port:40375
   [junit4]   2> 2781278 INFO  (zkConnectionManagerCallback-1415-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781323 WARN  (NIOServerCxn.Factory:0.0.0.0/0.0.0.0:0) [    ] o.a.z.s.NIOServerCnxn caught end of stream exception
   [junit4]   2> EndOfStreamException: Unable to read additional data from client sessionid 0x1604c4fd1d00000, likely client has closed socket
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxn.doIO(NIOServerCnxn.java:239)
   [junit4]   2> 	at org.apache.zookeeper.server.NIOServerCnxnFactory.run(NIOServerCnxnFactory.java:203)
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> 2781336 INFO  (jetty-launcher-1412-thread-1) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2781388 INFO  (jetty-launcher-1412-thread-3) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2781395 INFO  (jetty-launcher-1412-thread-2) [    ] o.e.j.s.Server jetty-9.3.20.v20170531
   [junit4]   2> 2781431 INFO  (jetty-launcher-1412-thread-1) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@4fc619ba{/solr,null,AVAILABLE}
   [junit4]   2> 2781431 INFO  (jetty-launcher-1412-thread-2) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@62dbec99{/solr,null,AVAILABLE}
   [junit4]   2> 2781432 INFO  (jetty-launcher-1412-thread-3) [    ] o.e.j.s.h.ContextHandler Started o.e.j.s.ServletContextHandler@4b20d5ff{/solr,null,AVAILABLE}
   [junit4]   2> 2781446 INFO  (jetty-launcher-1412-thread-3) [    ] o.e.j.s.AbstractConnector Started ServerConnector@1c2e1812{SSL,[ssl, http/1.1]}{127.0.0.1:46267}
   [junit4]   2> 2781447 INFO  (jetty-launcher-1412-thread-3) [    ] o.e.j.s.Server Started @2803136ms
   [junit4]   2> 2781478 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=46267}
   [junit4]   2> 2781478 ERROR (jetty-launcher-1412-thread-3) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-12T19:59:47.993Z
   [junit4]   2> 2781453 INFO  (jetty-launcher-1412-thread-1) [    ] o.e.j.s.AbstractConnector Started ServerConnector@3c0ef475{SSL,[ssl, http/1.1]}{127.0.0.1:53504}
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-1) [    ] o.e.j.s.Server Started @2803168ms
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=53504}
   [junit4]   2> 2781479 ERROR (jetty-launcher-1412-thread-1) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2781479 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-12T19:59:47.993Z
   [junit4]   2> 2781453 INFO  (jetty-launcher-1412-thread-2) [    ] o.e.j.s.AbstractConnector Started ServerConnector@5c2d03b1{SSL,[ssl, http/1.1]}{127.0.0.1:54300}
   [junit4]   2> 2781480 INFO  (jetty-launcher-1412-thread-2) [    ] o.e.j.s.Server Started @2803169ms
   [junit4]   2> 2781480 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.c.s.e.JettySolrRunner Jetty properties: {hostContext=/solr, hostPort=54300}
   [junit4]   2> 2781480 ERROR (jetty-launcher-1412-thread-2) [    ] o.a.s.u.StartupLoggingUtils Missing Java Option solr.log.dir. Logging may be missing or incomplete.
   [junit4]   2> 2781480 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.s.SolrDispatchFilter  ___      _       Welcome to Apache Solr™ version 7.2.0
   [junit4]   2> 2781480 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.s.SolrDispatchFilter / __| ___| |_ _   Starting in cloud mode on port null
   [junit4]   2> 2781480 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.s.SolrDispatchFilter \__ \/ _ \ | '_|  Install dir: null
   [junit4]   2> 2781480 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.s.SolrDispatchFilter |___/\___/_|_|    Start time: 2017-12-12T19:59:47.994Z
   [junit4]   2> 2781726 INFO  (zkConnectionManagerCallback-1417-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781735 INFO  (zkConnectionManagerCallback-1419-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781766 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2781795 INFO  (jetty-launcher-1412-thread-1) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:40375/solr
   [junit4]   2> 2781796 INFO  (zkConnectionManagerCallback-1421-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781799 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2781830 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.s.SolrDispatchFilter solr.xml found in ZooKeeper. Loading...
   [junit4]   2> 2781835 INFO  (jetty-launcher-1412-thread-2) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:40375/solr
   [junit4]   2> 2781850 INFO  (zkConnectionManagerCallback-1425-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781943 INFO  (jetty-launcher-1412-thread-3) [    ] o.a.s.c.ZkContainer Zookeeper client=127.0.0.1:40375/solr
   [junit4]   2> 2781943 INFO  (zkConnectionManagerCallback-1429-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781947 INFO  (zkConnectionManagerCallback-1433-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781974 INFO  (zkConnectionManagerCallback-1435-thread-1-processing-n:127.0.0.1:53504_solr) [n:127.0.0.1:53504_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781978 INFO  (zkConnectionManagerCallback-1439-thread-1-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2781978 INFO  (zkConnectionManagerCallback-1437-thread-1-processing-n:127.0.0.1:46267_solr) [n:127.0.0.1:46267_solr    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2782230 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2782247 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:54300_solr
   [junit4]   2> 2782248 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.c.Overseer Overseer (id=99163097508347913-127.0.0.1:54300_solr-n_0000000000) starting
   [junit4]   2> 2782306 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:54300_solr
   [junit4]   2> 2782418 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.OverseerTriggerThread Adding .autoAddReplicas trigger
   [junit4]   2> 2782422 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 1
   [junit4]   2> 2782426 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Initial livenodes: []
   [junit4]   2> 2782430 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion -1
   [junit4]   2> 2782430 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 1
   [junit4]   2> 2782448 INFO  (OverseerStateUpdate-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2782542 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 2782542 DEBUG (OverseerAutoScalingTriggerThread-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 1, lastZnodeVersion 1
   [junit4]   2> 2782543 DEBUG (ScheduledTrigger-3051-thread-1) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:54300_solr]
   [junit4]   2> 2783027 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2783027 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (1)
   [junit4]   2> 2783225 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2783226 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.c.Overseer Overseer (id=null) closing
   [junit4]   2> 2783228 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:53504_solr
   [junit4]   2> 2783234 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.c.ZkController Register node as live in ZooKeeper:/live_nodes/127.0.0.1:46267_solr
   [junit4]   2> 2783258 INFO  (zkCallback-1438-thread-1-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (2)
   [junit4]   2> 2783259 INFO  (zkCallback-1438-thread-1-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (2) -> (3)
   [junit4]   2> 2783339 INFO  (zkCallback-1436-thread-1-processing-n:127.0.0.1:46267_solr) [n:127.0.0.1:46267_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (3)
   [junit4]   2> 2783426 INFO  (zkCallback-1434-thread-1-processing-n:127.0.0.1:53504_solr) [n:127.0.0.1:53504_solr    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (1) -> (3)
   [junit4]   2> 2783702 DEBUG (ScheduledTrigger-3051-thread-1) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:46267_solr, 127.0.0.1:53504_solr, 127.0.0.1:54300_solr]
   [junit4]   2> 2784230 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_54300.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784254 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_54300.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784254 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_54300.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784275 INFO  (jetty-launcher-1412-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.autoscaling.SystemLogListenerTest_F096ECF9689B8083-001/tempDir-001/node2/.
   [junit4]   2> 2784479 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_53504.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784495 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_46267.solr.node' (registry 'solr.node') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784803 DEBUG (ScheduledTrigger-3051-thread-2) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:46267_solr, 127.0.0.1:53504_solr, 127.0.0.1:54300_solr]
   [junit4]   2> 2784815 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_46267.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784816 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_46267.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784817 INFO  (jetty-launcher-1412-thread-3) [n:127.0.0.1:46267_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.autoscaling.SystemLogListenerTest_F096ECF9689B8083-001/tempDir-001/node3/.
   [junit4]   2> 2784826 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_53504.solr.jvm' (registry 'solr.jvm') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784827 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_53504.solr.jetty' (registry 'solr.jetty') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2784828 INFO  (jetty-launcher-1412-thread-1) [n:127.0.0.1:53504_solr    ] o.a.s.c.CorePropertiesLocator Found 0 core definitions underneath /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.autoscaling.SystemLogListenerTest_F096ECF9689B8083-001/tempDir-001/node1/.
   [junit4]   2> 2785639 INFO  (zkConnectionManagerCallback-1445-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2785691 INFO  (zkConnectionManagerCallback-1449-thread-1) [    ] o.a.s.c.c.ConnectionManager zkClient has connected
   [junit4]   2> 2785692 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.c.c.ZkStateReader Updated live nodes from ZooKeeper... (0) -> (3)
   [junit4]   2> 2785692 INFO  (SUITE-SystemLogListenerTest-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.c.s.i.ZkClientClusterStateProvider Cluster at 127.0.0.1:40375/solr ready
   [junit4]   2> 2785804 DEBUG (ScheduledTrigger-3051-thread-1) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:46267_solr, 127.0.0.1:53504_solr, 127.0.0.1:54300_solr]
   [junit4]   2> 2785936 INFO  (qtp379242919-6627) [n:127.0.0.1:54300_solr    ] o.a.s.h.a.CollectionsHandler Invoked Collection Action :create with params replicationFactor=3&name=.system&nrtReplicas=3&action=CREATE&numShards=1&wt=javabin&version=2 and sendToOCPQueue=true
   [junit4]   2> 2785966 INFO  (OverseerThreadFactory-3053-thread-1-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.CreateCollectionCmd Create collection .system
   [junit4]   2> 2786604 INFO  (OverseerStateUpdate-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":".system",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":".system_shard1_replica_n1",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"https://127.0.0.1:46267/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2786615 INFO  (OverseerStateUpdate-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":".system",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":".system_shard1_replica_n2",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"https://127.0.0.1:54300/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2786617 INFO  (OverseerStateUpdate-99163097508347913-127.0.0.1:54300_solr-n_0000000000) [n:127.0.0.1:54300_solr    ] o.a.s.c.o.SliceMutator createReplica() {
   [junit4]   2>   "operation":"ADDREPLICA",
   [junit4]   2>   "collection":".system",
   [junit4]   2>   "shard":"shard1",
   [junit4]   2>   "core":".system_shard1_replica_n4",
   [junit4]   2>   "state":"down",
   [junit4]   2>   "base_url":"https://127.0.0.1:53504/solr",
   [junit4]   2>   "type":"NRT",
   [junit4]   2>   "waitForFinalState":"false"} 
   [junit4]   2> 2786806 DEBUG (ScheduledTrigger-3051-thread-1) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:46267_solr, 127.0.0.1:53504_solr, 127.0.0.1:54300_solr]
   [junit4]   2> 2787252 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node5&collection.configName=.system&newCollection=true&name=.system_shard1_replica_n2&action=CREATE&numShards=1&collection=.system&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2787253 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2787402 INFO  (qtp858060463-6634) [n:127.0.0.1:46267_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node3&collection.configName=.system&newCollection=true&name=.system_shard1_replica_n1&action=CREATE&numShards=1&collection=.system&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2787418 INFO  (zkCallback-1438-thread-1-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787419 INFO  (qtp858060463-6634) [n:127.0.0.1:46267_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2787430 INFO  (zkCallback-1438-thread-2-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787494 INFO  (qtp1379252043-6618) [n:127.0.0.1:53504_solr    ] o.a.s.h.a.CoreAdminOperation core create command qt=/admin/cores&coreNodeName=core_node6&collection.configName=.system&newCollection=true&name=.system_shard1_replica_n4&action=CREATE&numShards=1&collection=.system&shard=shard1&wt=javabin&version=2&replicaType=NRT
   [junit4]   2> 2787495 INFO  (qtp1379252043-6618) [n:127.0.0.1:53504_solr    ] o.a.s.c.TransientSolrCoreCacheDefault Allocating transient cache for 2147483647 transient cores
   [junit4]   2> 2787754 INFO  (zkCallback-1436-thread-1-processing-n:127.0.0.1:46267_solr) [n:127.0.0.1:46267_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787754 INFO  (zkCallback-1434-thread-1-processing-n:127.0.0.1:53504_solr) [n:127.0.0.1:53504_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787770 INFO  (zkCallback-1438-thread-3-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787782 INFO  (zkCallback-1438-thread-2-processing-n:127.0.0.1:54300_solr) [n:127.0.0.1:54300_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787783 INFO  (zkCallback-1436-thread-2-processing-n:127.0.0.1:46267_solr) [n:127.0.0.1:46267_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2787806 DEBUG (ScheduledTrigger-3051-thread-1) [n:127.0.0.1:54300_solr    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: [127.0.0.1:46267_solr, 127.0.0.1:53504_solr, 127.0.0.1:54300_solr]
   [junit4]   2> 2787846 INFO  (zkCallback-1434-thread-2-processing-n:127.0.0.1:53504_solr) [n:127.0.0.1:53504_solr    ] o.a.s.c.c.ZkStateReader A cluster state change: [WatchedEvent state:SyncConnected type:NodeDataChanged path:/collections/.system/state.json] for collection [.system] has occurred - updating... (live nodes size: [3])
   [junit4]   2> 2788360 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 2788400 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.s.ManagedIndexSchemaFactory The schema is configured as managed, but managed schema resource managed-schema not found - loading non-managed schema schema.xml instead
   [junit4]   2> 2788423 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.s.IndexSchema [.system_shard1_replica_n2] Schema name=_system collection or core
   [junit4]   2> 2788476 INFO  (qtp858060463-6634) [n:127.0.0.1:46267_solr c:.system s:shard1 r:core_node3 x:.system_shard1_replica_n1] o.a.s.c.SolrConfig Using Lucene MatchVersion: 7.2.0
   [junit4]   2> 2788495 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.s.IndexSchema Loaded schema _system collection or core/1.1 with uniqueid field id
   [junit4]   2> 2788495 INFO  (qtp858060463-6634) [n:127.0.0.1:46267_solr c:.system s:shard1 r:core_node3 x:.system_shard1_replica_n1] o.a.s.s.ManagedIndexSchemaFactory The schema is configured as managed, but managed schema resource managed-schema not found - loading non-managed schema schema.xml instead
   [junit4]   2> 2788504 INFO  (qtp858060463-6634) [n:127.0.0.1:46267_solr c:.system s:shard1 r:core_node3 x:.system_shard1_replica_n1] o.a.s.s.IndexSchema [.system_shard1_replica_n1] Schema name=_system collection or core
   [junit4]   2> 2788575 INFO  (qtp858060463-6634) [n:127.0.0.1:46267_solr c:.system s:shard1 r:core_node3 x:.system_shard1_replica_n1] o.a.s.s.IndexSchema Loaded schema _system collection or core/1.1 with uniqueid field id
   [junit4]   2> 2788802 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.s.ManagedIndexSchema Created and persisted managed schema znode at /configs/.system/managed-schema
   [junit4]   2> 2788810 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.s.ManagedIndexSchemaFactory After upgrading to managed schema in ZooKeeper, renamed the non-managed schema /configs/.system/schema.xml to /configs/.system/schema.xml.bak
   [junit4]   2> 2788810 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.c.CoreContainer Creating SolrCore '.system_shard1_replica_n2' using configuration from collection .system, trusted=true
   [junit4]   2> 2788811 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.m.r.SolrJmxReporter JMX monitoring for 'solr_54300.solr.core..system.shard1.replica_n2' (registry 'solr.core..system.shard1.replica_n2') enabled at server: com.sun.jmx.mbeanserver.JmxMBeanServer@62cae7a0
   [junit4]   2> 2788811 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.c.SolrCore solr.RecoveryStrategy.Builder
   [junit4]   2> 2788811 INFO  (qtp379242919-6623) [n:127.0.0.1:54300_solr c:.system s:shard1 r:core_node5 x:.system_shard1_replica_n2] o.a.s.c.SolrCore [[.system_shard1_replica_n2] ] Opening new SolrCore at [/x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J0/temp/solr.cloud.autoscaling.SystemLogListenerTest_F096ECF9689B8083-001/tempDir-001/node2/.system_shard1_replica_n2], dataDir=[/x1/jenkins/jenk

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

yExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.RecoveryStrategy RecoveryStrategy has been closed
   [junit4]   2> 9879123 INFO  (recoveryExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.RecoveryStrategy Finished recovery process, successful=[false]
   [junit4]   2> 9879123 INFO  (recoveryExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.SolrCore [test_col_shard2_replica_n5]  CLOSING SolrCore org.apache.solr.core.SolrCore@1bb84c1a
   [junit4]   2> 9879123 INFO  (recoveryExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.core.test_col.shard2.replica_n5, tag=465062938
   [junit4]   2> 9879123 INFO  (recoveryExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.m.r.SolrJmxReporter Closing reporter [org.apache.solr.metrics.reporters.SolrJmxReporter@5b1085a4: rootName = solr_39841, domain = solr.core.test_col.shard2.replica_n5, service url = null, agent id = null] for registry solr.core.test_col.shard2.replica_n5 / com.codahale.metrics.MetricRegistry@50c10b5b
   [junit4]   2> 9879131 INFO  (zkCallback-3235-thread-8-processing-n:127.0.0.1:39841_solr) [n:127.0.0.1:39841_solr    ] o.a.s.c.OverseerElectionContext I am going to be the leader 127.0.0.1:39841_solr
   [junit4]   2> 9879134 INFO  (recoveryExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.m.SolrMetricManager Closing metric reporters for registry=solr.collection.test_col.shard2.leader, tag=465062938
   [junit4]   2> 9879134 WARN  (recoveryExecutor-3209-thread-1-processing-n:127.0.0.1:39841_solr x:test_col_shard2_replica_n5 s:shard2 c:test_col r:core_node6) [n:127.0.0.1:39841_solr c:test_col s:shard2 r:core_node6 x:test_col_shard2_replica_n5] o.a.s.c.RecoveryStrategy Stopping recovery for core=[test_col_shard2_replica_n5] coreNodeName=[core_node6]
   [junit4]   2> 9879137 INFO  (jetty-closer-3181-thread-2) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@5f1d05d0{/solr,null,UNAVAILABLE}
   [junit4]   2> 9879214 INFO  (jetty-closer-3181-thread-6) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@361f179f{/solr,null,UNAVAILABLE}
   [junit4]   2> 9879327 INFO  (jetty-closer-3181-thread-5) [    ] o.e.j.s.h.ContextHandler Stopped o.e.j.s.ServletContextHandler@501333ee{/solr,null,UNAVAILABLE}
   [junit4]   2> 9879350 ERROR (SUITE-TestTolerantUpdateProcessorRandomCloud-seed#[F096ECF9689B8083]-worker) [    ] o.a.z.s.ZooKeeperServer ZKShutdownHandler is not registered, so ZooKeeper server won't take any action on ERROR or SHUTDOWN server state changes
   [junit4]   2> 9879350 INFO  (SUITE-TestTolerantUpdateProcessorRandomCloud-seed#[F096ECF9689B8083]-worker) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:33868 33868
   [junit4]   2> 9879454 INFO  (Thread-3106) [    ] o.a.s.c.ZkTestServer connecting to 127.0.0.1:33868 33868
   [junit4]   2> 9879478 WARN  (Thread-3106) [    ] o.a.s.c.ZkTestServer Watch limit violations: 
   [junit4]   2> Maximum concurrent create/delete watches above limit:
   [junit4]   2> 
   [junit4]   2> 	15	/solr/aliases.json
   [junit4]   2> 	15	/solr/clusterprops.json
   [junit4]   2> 	13	/solr/security.json
   [junit4]   2> 	11	/solr/configs/solrCloudCollectionConfig/managed-schema
   [junit4]   2> 	11	/solr/configs/solrCloudCollectionConfig
   [junit4]   2> 
   [junit4]   2> Maximum concurrent data watches above limit:
   [junit4]   2> 
   [junit4]   2> 	81	/solr/collections/test_col/state.json
   [junit4]   2> 	15	/solr/clusterstate.json
   [junit4]   2> 	4	/solr/overseer_elect/election/99163552257998872-127.0.0.1:52341_solr-n_0000000007
   [junit4]   2> 	2	/solr/collections/test_col/leader_elect/shard1/election/99163552257998864-core_node2-n_0000000000
   [junit4]   2> 	2	/solr/overseer_elect/election/99163552257998875-127.0.0.1:51152_solr-n_0000000010
   [junit4]   2> 	2	/solr/overseer_elect/election/99163552257998864-127.0.0.1:60592_solr-n_0000000000
   [junit4]   2> 
   [junit4]   2> Maximum concurrent children watches above limit:
   [junit4]   2> 
   [junit4]   2> 	15	/solr/collections
   [junit4]   2> 	8	/solr/live_nodes
   [junit4]   2> 
   [junit4]   2> NOTE: leaving temporary files on disk at: /x1/jenkins/jenkins-slave/workspace/Lucene-Solr-Tests-7.2/solr/build/solr-core/test/J1/temp/solr.cloud.TestTolerantUpdateProcessorRandomCloud_F096ECF9689B8083-001
   [junit4]   2> Dec 12, 2017 9:58:16 PM com.carrotsearch.randomizedtesting.ThreadLeakControl checkThreadLeaks
   [junit4]   2> WARNING: Will linger awaiting termination of 1 leaked thread(s).
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene70): {foo_i=FST50, id_i=PostingsFormat(name=LuceneFixedGap), id=PostingsFormat(name=Asserting)}, docValues:{_version_=DocValuesFormat(name=Lucene70)}, maxPointsInLeafNode=948, maxMBSortInHeap=5.996089679828728, sim=RandomSimilarity(queryNorm=true): {}, locale=es-PE, timezone=Europe/Vatican
   [junit4]   2> NOTE: Linux 3.13.0-88-generic amd64/Oracle Corporation 1.8.0_144 (64-bit)/cpus=4,threads=1,free=221186480,total=523763712
   [junit4]   2> NOTE: All tests run in this JVM: [ImplicitSnitchTest, TestSchemaSimilarityResource, PathHierarchyTokenizerFactoryTest, SolrMetricsIntegrationTest, TestAtomicUpdateErrorCases, HdfsChaosMonkeySafeLeaderTest, TestBulkSchemaConcurrent, ExitableDirectoryReaderTest, TestCoreAdminApis, LegacyCloudClusterPropTest, ChangedSchemaMergeTest, ClassificationUpdateProcessorIntegrationTest, TestImpersonationWithHadoopAuth, SolrJmxReporterCloudTest, TestLegacyNumericUtils, SuggesterFSTTest, LeaderFailureAfterFreshStartTest, TestPayloadCheckQParserPlugin, PKIAuthenticationIntegrationTest, TestJsonRequest, OverriddenZkACLAndCredentialsProvidersTest, TestUninvertingReader, TestXIncludeConfig, TestUniqueKeyFieldResource, OpenCloseCoreStressTest, MultiThreadedOCPTest, AtomicUpdateProcessorFactoryTest, SolrCLIZkUtilsTest, PreAnalyzedUpdateProcessorTest, TestLockTree, DistributedQueryComponentCustomSortTest, TestLazyCores, TestTolerantUpdateProcessorCloud, HdfsDirectoryTest, TestConfigSetProperties, MBeansHandlerTest, CursorMarkTest, ZkSolrClientTest, TestRestoreCore, MetricUtilsTest, TestUseDocValuesAsStored2, TestHttpShardHandlerFactory, RankQueryTest, TestCloudJSONFacetJoinDomain, TestManagedResourceStorage, TestCustomStream, ShardSplitTest, TestLegacyFieldCache, TestNumericRangeQuery32, TestStreamBody, TestMultiWordSynonyms, FacetPivotSmallTest, TestSolrCloudWithKerberosAlt, TestStressUserVersions, TestRandomCollapseQParserPlugin, TestFieldTypeResource, PeerSyncReplicationTest, PrimUtilsTest, DeleteLastCustomShardedReplicaTest, PreAnalyzedFieldManagedSchemaCloudTest, DirectUpdateHandlerTest, HttpPartitionTest, HdfsBasicDistributedZk2Test, SecurityConfHandlerTest, TestAnalyzedSuggestions, HdfsUnloadDistributedZkTest, SpellCheckCollatorWithCollapseTest, TestSolrCoreSnapshots, AssignTest, SubstringBytesRefFilterTest, TestDocumentBuilder, DebugComponentTest, TestDocSet, TestSchemaManager, CreateCollectionCleanupTest, TestCollationFieldDocValues, TestWriterPerf, PingRequestHandlerTest, CdcrUpdateLogTest, TestSSLRandomization, ChaosMonkeySafeLeaderTest, TermVectorComponentDistributedTest, TestPerFieldSimilarity, TestLegacyNumericRangeQueryBuilder, TestCollationField, TestInfoStreamLogging, DOMUtilTest, TestSolrCLIRunExample, TestJmxIntegration, SolrCoreMetricManagerTest, TestNamedUpdateProcessors, TestManagedSynonymGraphFilterFactory, PolyFieldTest, TestSolrConfigHandler, CdcrReplicationHandlerTest, TestReloadAndDeleteDocs, TestBM25SimilarityFactory, HLLSerializationTest, BlobRepositoryCloudTest, SolrRequestParserTest, RegexBoostProcessorTest, SOLR749Test, V2ApiIntegrationTest, TestSimpleQParserPlugin, DistributedIntervalFacetingTest, OutputWriterTest, TestFieldCollectionResource, CloudExitableDirectoryReaderTest, TestXmlQParserPlugin, TestClassicSimilarityFactory, TestJettySolrRunner, SolrIndexMetricsTest, TestGraphMLResponseWriter, TestFieldCache, TestCloudRecovery, TestHdfsBackupRestoreCore, SolrCmdDistributorTest, ChaosMonkeySafeLeaderWithPullReplicasTest, TestSimpleTrackingShardHandler, TestLRUStatsCache, ZkFailoverTest, DistribDocExpirationUpdateProcessorTest, SolrIndexSplitterTest, SuggesterTSTTest, SuggesterTest, TestStressLucene, SpatialFilterTest, TestCSVLoader, NoCacheHeaderTest, WordBreakSolrSpellCheckerTest, SchemaVersionSpecificBehaviorTest, QueryEqualityTest, TestRemoteStreaming, DocValuesMultiTest, TestSolrDeletionPolicy1, TestSurroundQueryParser, TestReversedWildcardFilterFactory, PrimitiveFieldTypeTest, TestOmitPositions, TermsComponentTest, HighlighterConfigTest, AlternateDirectoryTest, CopyFieldTest, TestStressRecovery, TestCloudPivotFacet, TestConfigSetsAPIExclusivity, TestDeleteCollectionOnDownNodes, TestDistribDocBasedVersion, TestLeaderElectionWithEmptyReplica, TestOnReconnectListenerSupport, TestPullReplica, TestShortCircuitedRequests, TestSolrCloudWithDelegationTokens, TestTolerantUpdateProcessorRandomCloud]
   [junit4] Completed [569/751 (11!)] on J1 in 171.07s, 2 tests, 1 failure <<< FAILURES!

[...truncated 48004 lines...]