You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@lucene.apache.org by Policeman Jenkins Server <je...@thetaphi.de> on 2018/09/23 08:19:39 UTC

[JENKINS] Lucene-Solr-master-Windows (64bit/jdk1.8.0_172) - Build # 7531 - Still Unstable!

Build: https://jenkins.thetaphi.de/job/Lucene-Solr-master-Windows/7531/
Java: 64bit/jdk1.8.0_172 -XX:+UseCompressedOops -XX:+UseSerialGC

2 tests failed.
FAILED:  org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue.testDistributedQueueBlocking

Error Message:


Stack Trace:
java.util.concurrent.TimeoutException
	at __randomizedtesting.SeedInfo.seed([F48230836902F6F5:B12842FA2D504A81]:0)
	at java.util.concurrent.FutureTask.get(FutureTask.java:205)
	at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue.testDistributedQueueBlocking(TestSimDistributedQueue.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:1742)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:935)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:971)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:985)
	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:944)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:830)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:880)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:891)
	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.autoscaling.sim.TestSimGenericDistributedQueue

Error Message:
1 thread leaked from SUITE scope at org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue:     1) Thread[id=40962, name=sdqtest--12649-thread-1, state=TIMED_WAITING, group=TGRP-TestSimGenericDistributedQueue]         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.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:194)         at org.apache.solr.cloud.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:167)         at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue.lambda$testDistributedQueueBlocking$0(TestSimDistributedQueue.java:93)         at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue$$Lambda$1467/1195269046.call(Unknown Source)         at java.util.concurrent.FutureTask.run(FutureTask.java:266)         at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:209)         at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor$$Lambda$132/609932897.run(Unknown Source)         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: 1 thread leaked from SUITE scope at org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue: 
   1) Thread[id=40962, name=sdqtest--12649-thread-1, state=TIMED_WAITING, group=TGRP-TestSimGenericDistributedQueue]
        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.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:194)
        at org.apache.solr.cloud.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:167)
        at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue.lambda$testDistributedQueueBlocking$0(TestSimDistributedQueue.java:93)
        at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue$$Lambda$1467/1195269046.call(Unknown Source)
        at java.util.concurrent.FutureTask.run(FutureTask.java:266)
        at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:209)
        at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor$$Lambda$132/609932897.run(Unknown Source)
        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([F48230836902F6F5]:0)




Build Log:
[...truncated 14430 lines...]
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
   [junit4]   2> 4070136 INFO  (SUITE-TestSimGenericDistributedQueue-seed#[F48230836902F6F5]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> Creating dataDir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J0\temp\solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue_F48230836902F6F5-001\init-core-data-001
   [junit4]   2> 4070139 INFO  (SUITE-TestSimGenericDistributedQueue-seed#[F48230836902F6F5]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=true
   [junit4]   2> 4070141 INFO  (SUITE-TestSimGenericDistributedQueue-seed#[F48230836902F6F5]-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> 4070142 INFO  (TEST-TestSimGenericDistributedQueue.testPeekElements-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testPeekElements
   [junit4]   2> 4071646 INFO  (TEST-TestSimGenericDistributedQueue.testPeekElements-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testPeekElements
   [junit4]   2> 4071648 INFO  (TEST-TestSimGenericDistributedQueue.testDistributedQueue-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testDistributedQueue
   [junit4]   2> 4073653 INFO  (TEST-TestSimGenericDistributedQueue.testDistributedQueue-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testDistributedQueue
   [junit4]   2> 4073655 INFO  (TEST-TestSimGenericDistributedQueue.testDistributedQueue-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testDistributedQueue {#2}
   [junit4]   2> 4075660 INFO  (TEST-TestSimGenericDistributedQueue.testDistributedQueue-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testDistributedQueue {#2}
   [junit4]   2> 4075665 INFO  (TEST-TestSimGenericDistributedQueue.testLocallyOffer-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testLocallyOffer
   [junit4]   2> 4075970 INFO  (TEST-TestSimGenericDistributedQueue.testLocallyOffer-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testLocallyOffer
   [junit4]   2> 4075978 INFO  (TEST-TestSimGenericDistributedQueue.testDistributedQueueBlocking-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testDistributedQueueBlocking
   [junit4]   2> 4077983 INFO  (TEST-TestSimGenericDistributedQueue.testDistributedQueueBlocking-seed#[F48230836902F6F5]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testDistributedQueueBlocking
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestSimGenericDistributedQueue -Dtests.method=testDistributedQueueBlocking -Dtests.seed=F48230836902F6F5 -Dtests.slow=true -Dtests.locale=de-LU -Dtests.timezone=Antarctica/DumontDUrville -Dtests.asserts=true -Dtests.file.encoding=US-ASCII
   [junit4] ERROR   2.02s J0 | TestSimGenericDistributedQueue.testDistributedQueueBlocking <<<
   [junit4]    > Throwable #1: java.util.concurrent.TimeoutException
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([F48230836902F6F5:B12842FA2D504A81]:0)
   [junit4]    > 	at java.util.concurrent.FutureTask.get(FutureTask.java:205)
   [junit4]    > 	at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue.testDistributedQueueBlocking(TestSimDistributedQueue.java:102)
   [junit4]    > 	at java.lang.Thread.run(Thread.java:748)
   [junit4]   2> NOTE: leaving temporary files on disk at: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J0\temp\solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue_F48230836902F6F5-001
   [junit4]   2> Sep 23, 2018 7:38:44 AM com.carrotsearch.randomizedtesting.ThreadLeakControl checkThreadLeaks
   [junit4]   2> WARNING: Will linger awaiting termination of 1 leaked thread(s).
   [junit4]   2> Sep 23, 2018 7:40:04 AM com.carrotsearch.randomizedtesting.ThreadLeakControl checkThreadLeaks
   [junit4]   2> SEVERE: 1 thread leaked from SUITE scope at org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue: 
   [junit4]   2>    1) Thread[id=40962, name=sdqtest--12649-thread-1, state=TIMED_WAITING, group=TGRP-TestSimGenericDistributedQueue]
   [junit4]   2>         at sun.misc.Unsafe.park(Native Method)
   [junit4]   2>         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]   2>         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.awaitNanos(AbstractQueuedSynchronizer.java:2078)
   [junit4]   2>         at org.apache.solr.cloud.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:194)
   [junit4]   2>         at org.apache.solr.cloud.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:167)
   [junit4]   2>         at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue.lambda$testDistributedQueueBlocking$0(TestSimDistributedQueue.java:93)
   [junit4]   2>         at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue$$Lambda$1467/1195269046.call(Unknown Source)
   [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:209)
   [junit4]   2>         at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor$$Lambda$132/609932897.run(Unknown Source)
   [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> Sep 23, 2018 7:40:04 AM com.carrotsearch.randomizedtesting.ThreadLeakControl tryToInterruptAll
   [junit4]   2> INFO: Starting to interrupt leaked threads:
   [junit4]   2>    1) Thread[id=40962, name=sdqtest--12649-thread-1, state=TIMED_WAITING, group=TGRP-TestSimGenericDistributedQueue]
   [junit4]   2> Sep 23, 2018 7:40:04 AM com.carrotsearch.randomizedtesting.ThreadLeakControl tryToInterruptAll
   [junit4]   2> INFO: All leaked threads terminated.
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene80): {}, docValues:{}, maxPointsInLeafNode=728, maxMBSortInHeap=6.249024416831334, sim=Asserting(org.apache.lucene.search.similarities.AssertingSimilarity@5de79756), locale=de-LU, timezone=Antarctica/DumontDUrville
   [junit4]   2> NOTE: Windows 10 10.0 amd64/Oracle Corporation 1.8.0_172 (64-bit)/cpus=3,threads=1,free=116685880,total=518979584
   [junit4]   2> NOTE: All tests run in this JVM: [BadComponentTest, TestAnalyzedSuggestions, HdfsBasicDistributedZkTest, DateFieldTest, TestPrepRecovery, SpatialHeatmapFacetsTest, BooleanFieldTest, OverseerStatusTest, TestChildDocTransformerHierarchy, SpellCheckCollatorWithCollapseTest, LeaderFailureAfterFreshStartTest, TestLuceneIndexBackCompat, BlockJoinFacetSimpleTest, PolyFieldTest, FacetPivotSmallTest, TestRecovery, FullSolrCloudDistribCmdsTest, TestPostingsSolrHighlighter, NodeAddedTriggerIntegrationTest, AtomicUpdatesTest, ClusterStateUpdateTest, TestRandomRequestDistribution, TriggerSetPropertiesIntegrationTest, TestWithCollection, TestBadConfig, TaggingAttributeTest, TestLegacyField, SharedFSAutoReplicaFailoverTest, TestSolrCloudSnapshots, RequiredFieldsTest, CollectionStateFormat2Test, HttpPartitionOnCommitTest, DOMUtilTest, TestUseDocValuesAsStored2, TestRangeQuery, DistributedFacetPivotWhiteBoxTest, TemplateUpdateProcessorTest, ImplicitSnitchTest, TestRequestForwarding, TestCopyFieldCollectionResource, CollectionsAPIDistributedZkTest, IgnoreLargeDocumentProcessorFactoryTest, TestWordDelimiterFilterFactory, DistributedExpandComponentTest, TestTolerantUpdateProcessorRandomCloud, TestMacros, DebugComponentTest, TestMiniSolrCloudClusterSSL, TestConfigSetsAPIZkFailure, TestNumericTerms64, SolrXmlInZkTest, SolrMetricsIntegrationTest, SpatialRPTFieldTypeTest, CollectionTooManyReplicasTest, NodeMarkersRegistrationTest, MetricsConfigTest, FastVectorHighlighterTest, TriggerEventQueueTest, TestImpersonationWithHadoopAuth, NodeLostTriggerIntegrationTest, ExitableDirectoryReaderTest, CoreSorterTest, SolrIndexSplitterTest, TestStressLucene, TestCollectionAPI, ConnectionManagerTest, TermsComponentTest, SolrCLIZkUtilsTest, TestEmbeddedSolrServerConstructors, TestHdfsCloudBackupRestore, TestInPlaceUpdatesStandalone, TermVectorComponentDistributedTest, TestDocTermOrds, CreateRoutedAliasTest, CdcrUpdateLogTest, SimpleFacetsTest, CachingDirectoryFactoryTest, TestQuerySenderNoQuery, TestMultiWordSynonyms, ZkShardTermsTest, TestRandomFaceting, TestHashQParserPlugin, DistributedQueryComponentCustomSortTest, TestSortableTextField, TestSolrCoreParser, AdminHandlersProxyTest, LeaderVoteWaitTimeoutTest, PeerSyncWithLeaderAndIndexFingerprintCachingTest, HLLSerializationTest, TestCollapseQParserPlugin, TestConfig, TimeZoneUtilsTest, TestLegacyFieldCache, TestNRTOpen, TestCustomSort, AnalyticsMergeStrategyTest, TestSolrJ, TestSort, TestWriterPerf, BadCopyFieldTest, TestExpandComponent, TestXmlQParser, TestJavabinTupleStreamParser, TestSolrCloudWithDelegationTokens, HdfsChaosMonkeySafeLeaderTest, PingRequestHandlerTest, SolrInfoBeanTest, TestLRUCache, TestStreamBody, TestCoreAdminApis, ConvertedLegacyTest, TestSimNodeAddedTrigger, DistributedUpdateProcessorTest, BasicDistributedZkTest, TestCloudJSONFacetJoinDomain, DocumentAnalysisRequestHandlerTest, TestJsonFacetsWithNestedObjects, TestShardHandlerFactory, Tagger2Test, DocValuesTest, TestSchemaResource, TestFastLRUCache, LargeFieldTest, SolrIndexConfigTest, OverriddenZkACLAndCredentialsProvidersTest, ResponseBuilderTest, DistanceFunctionTest, TestCustomStream, SpellingQueryConverterTest, QueryEqualityTest, ChaosMonkeyNothingIsSafeTest, TestFieldResource, TestStressReorder, TestLuceneMatchVersion, AliasIntegrationTest, LIROnShardRestartTest, CopyFieldTest, SearchHandlerTest, TestQueryTypes, DistributedFacetPivotLargeTest, MetricsHistoryIntegrationTest, ClassificationUpdateProcessorIntegrationTest, OverseerTest, TestFilteredDocIdSet, SolrJmxReporterTest, TestSimComputePlanAction, TolerantUpdateProcessorTest, UpdateRequestProcessorFactoryTest, TestGroupingSearch, SolrRrdBackendFactoryTest, TestReload, CdcrVersionReplicationTest, TestDocBasedVersionConstraints, CoreAdminCreateDiscoverTest, TestMaxScoreQueryParser, TestExportWriter, NumericFieldsTest, SignificantTermsQParserPluginTest, TestCloudDeleteByQuery, HdfsRestartWhileUpdatingTest, TestConfigSetsAPI, SuggesterTSTTest, TestSizeLimitedDistributedMap, TestDistributedSearch, TestClassicSimilarityFactory, CustomCollectionTest, TestPartialUpdateDeduplication, MBeansHandlerTest, DistribDocExpirationUpdateProcessorTest, SolrCoreTest, ZkCLITest, MaxSizeAutoCommitTest, TestDynamicFieldResource, DirectSolrConnectionTest, PrimUtilsTest, TestRawTransformer, TestCloudManagedSchema, TestJettySolrRunner, TestNestedUpdateProcessor, TestSolrDeletionPolicy2, TestExactStatsCache, ExplicitHLLTest, TestSubQueryTransformerCrossCore, TestFieldCacheSort, TestInitParams, TestJsonRequest, EchoParamsTest, TestNonDefinedSimilarityFactory, BlobRepositoryCloudTest, AutoAddReplicasIntegrationTest, MetricTriggerIntegrationTest, RecoveryAfterSoftCommitTest, CloneFieldUpdateProcessorFactoryTest, TestCrossCoreJoin, DistributedQueryElevationComponentTest, CdcrBootstrapTest, TestPushWriter, TestStressVersions, TestSolrCLIRunExample, TestPayloadScoreQParserPlugin, SparseHLLTest, TestScoreJoinQPNoScore, TestReRankQParserPlugin, AnalysisAfterCoreReloadTest, BasicFunctionalityTest, DisMaxRequestHandlerTest, DistributedIntervalFacetingTest, OutputWriterTest, SampleTest, TestDistributedGrouping, TestDistributedMissingSort, TestJoin, TestRandomDVFaceting, TestSolrCoreProperties, TestTolerantSearch, TestTrie, PathHierarchyTokenizerFactoryTest, ProtectedTermFilterFactoryTest, TestCharFilters, ActionThrottleTest, AddReplicaTest, AsyncCallRequestStatusResponseTest, BasicDistributedZk2Test, ChaosMonkeySafeLeaderTest, ChaosMonkeySafeLeaderWithPullReplicasTest, CleanupOldIndexTest, CloudExitableDirectoryReaderTest, ClusterStateTest, ConcurrentCreateRoutedAliasTest, ConfigSetsAPITest, DeleteLastCustomShardedReplicaTest, DeleteNodeTest, DeleteReplicaTest, DeleteShardTest, DeleteStatusTest, DistribCursorPagingTest, DistributedQueueTest, DistributedVersionInfoTest, DocValuesNotIndexedTest, ForceLeaderTest, LeaderElectionContextKeyTest, LeaderElectionIntegrationTest, LeaderElectionTest, LeaderFailoverAfterPartitionTest, MissingSegmentRecoveryTest, MoveReplicaHDFSFailoverTest, MoveReplicaHDFSTest, MoveReplicaTest, MultiSolrCloudTestCaseTest, MultiThreadedOCPTest, NodeMutatorTest, OutOfBoxZkACLAndCredentialsProvidersTest, OverseerModifyCollectionTest, OverseerRolesTest, RemoteQueryErrorTest, ReplaceNodeNoTargetTest, ReplaceNodeTest, ReplicationFactorTest, RestartWhileUpdatingTest, RollingRestartTest, SSLMigrationTest, SaslZkACLProviderTest, ShardRoutingCustomTest, ShardRoutingTest, TestAuthenticationFramework, TestCloudConsistency, TestCloudPhrasesIdentificationComponent, TestCloudPivotFacet, TestCloudPseudoReturnFields, TestCloudRecovery, TestCloudSearcherWarming, TestClusterProperties, TestDeleteCollectionOnDownNodes, TestDistribDocBasedVersion, TestDistributedMap, TestDownShardTolerantSearch, TestExclusionRuleCollectionAccess, TestHashPartitioner, TestLeaderElectionWithEmptyReplica, TestLeaderElectionZkExpiry, TestLeaderInitiatedRecoveryThread, TestLockTree, TestPullReplicaErrorHandling, TestRandomFlRTGCloud, TestSegmentSorting, TestShortCircuitedRequests, TestSolrCloudWithSecureImpersonation, TestStressCloudBlindAtomicUpdates, TestStressInPlaceUpdates, TestStressLiveNodes, TestTlogReplica, TestTolerantUpdateProcessorCloud, TlogReplayBufferedWhileIndexingTest, TriLevelCompositeIdRoutingTest, UnloadDistributedZkTest, VMParamsZkACLAndCredentialsProvidersTest, ZkFailoverTest, SimpleCollectionCreateDeleteTest, TestReplicaProperties, TestRequestStatusCollectionAPI, AutoScalingHandlerTest, ComputePlanActionTest, ExecutePlanActionTest, HdfsAutoAddReplicasIntegrationTest, HttpTriggerListenerTest, IndexSizeTriggerTest, ScheduledMaintenanceTriggerTest, ScheduledTriggerIntegrationTest, SearchRateTriggerTest, TriggerCooldownIntegrationTest, TestSimDistributedQueue, TestSimGenericDistributedQueue]
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=TestSimGenericDistributedQueue -Dtests.seed=F48230836902F6F5 -Dtests.slow=true -Dtests.locale=de-LU -Dtests.timezone=Antarctica/DumontDUrville -Dtests.asserts=true -Dtests.file.encoding=US-ASCII
   [junit4] ERROR   0.00s J0 | TestSimGenericDistributedQueue (suite) <<<
   [junit4]    > Throwable #1: com.carrotsearch.randomizedtesting.ThreadLeakError: 1 thread leaked from SUITE scope at org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue: 
   [junit4]    >    1) Thread[id=40962, name=sdqtest--12649-thread-1, state=TIMED_WAITING, group=TGRP-TestSimGenericDistributedQueue]
   [junit4]    >         at sun.misc.Unsafe.park(Native Method)
   [junit4]    >         at java.util.concurrent.locks.LockSupport.parkNanos(LockSupport.java:215)
   [junit4]    >         at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.awaitNanos(AbstractQueuedSynchronizer.java:2078)
   [junit4]    >         at org.apache.solr.cloud.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:194)
   [junit4]    >         at org.apache.solr.cloud.autoscaling.sim.GenericDistributedQueue.peek(GenericDistributedQueue.java:167)
   [junit4]    >         at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue.lambda$testDistributedQueueBlocking$0(TestSimDistributedQueue.java:93)
   [junit4]    >         at org.apache.solr.cloud.autoscaling.sim.TestSimDistributedQueue$$Lambda$1467/1195269046.call(Unknown Source)
   [junit4]    >         at java.util.concurrent.FutureTask.run(FutureTask.java:266)
   [junit4]    >         at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:209)
   [junit4]    >         at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor$$Lambda$132/609932897.run(Unknown Source)
   [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([F48230836902F6F5]:0)
   [junit4] Completed [556/834 (1!)] on J0 in 88.01s, 5 tests, 2 errors <<< FAILURES!

[...truncated 49650 lines...]
[asciidoctor:convert] asciidoctor: ERROR: about-this-guide.adoc: line 1: invalid part, must have at least one section (e.g., chapter, appendix, etc.)
[asciidoctor:convert] asciidoctor: ERROR: solr-glossary.adoc: line 1: invalid part, must have at least one section (e.g., chapter, appendix, etc.)
     [java] Processed 2430 links (1982 relative) to 3172 anchors in 246 files
     [echo] Validated Links & Anchors via: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-ref-guide/bare-bones-html/

-documentation-lint:
    [jtidy] Checking for broken html (such as invalid tags)...
   [delete] Deleting directory C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\jtidy_tmp
     [echo] Checking for broken links...
     [exec] 
     [exec] Crawl/parse...
     [exec] 
     [exec] Verify...
     [echo] Checking for malformed docs...

jar-checksums:

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

common.resolve:

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

jar-checksums:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\null339410978
     [copy] Copying 35 files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\null339410978
   [delete] Deleting directory C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\null339410978

resolve-example:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

resolve-server:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

jar-checksums:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\null1837226450
     [copy] Copying 238 files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\null1837226450
   [delete] Deleting directory C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\null1837226450

check-working-copy:
[ivy:cachepath] :: resolving dependencies :: org.eclipse.jgit#org.eclipse.jgit-caller;working
[ivy:cachepath] 	confs: [default]
[ivy:cachepath] 	found org.eclipse.jgit#org.eclipse.jgit;4.6.0.201612231935-r in public
[ivy:cachepath] 	found com.jcraft#jsch;0.1.53 in public
[ivy:cachepath] 	found com.googlecode.javaewah#JavaEWAH;1.1.6 in public
[ivy:cachepath] 	found org.apache.httpcomponents#httpclient;4.3.6 in public
[ivy:cachepath] 	found org.apache.httpcomponents#httpcore;4.3.3 in public
[ivy:cachepath] 	found commons-logging#commons-logging;1.1.3 in public
[ivy:cachepath] 	found commons-codec#commons-codec;1.6 in public
[ivy:cachepath] 	found org.slf4j#slf4j-api;1.7.2 in public
[ivy:cachepath] :: resolution report :: resolve 40ms :: artifacts dl 3ms
	---------------------------------------------------------------------
	|                  |            modules            ||   artifacts   |
	|       conf       | number| search|dwnlded|evicted|| number|dwnlded|
	---------------------------------------------------------------------
	|      default     |   8   |   0   |   0   |   0   ||   8   |   0   |
	---------------------------------------------------------------------
[wc-checker] Initializing working copy...
[wc-checker] SLF4J: Failed to load class "org.slf4j.impl.StaticLoggerBinder".
[wc-checker] SLF4J: Defaulting to no-operation (NOP) logger implementation
[wc-checker] SLF4J: See http://www.slf4j.org/codes.html#StaticLoggerBinder for further details.
[wc-checker] Checking working copy status...

-jenkins-base:

BUILD SUCCESSFUL
Total time: 124 minutes 8 seconds
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
[Lucene-Solr-master-Windows] $ cmd /c call C:\Users\jenkins\AppData\Local\Temp\jenkins7359425584256619386.bat

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST lucene\build move /y lucene\build lucene\build.orig 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST solr\build move /y solr\build solr\build.orig 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>set ANT_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2 

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>set PATH=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2\bin;C:\Users\jenkins\tools\java\64bit\jdk1.8.0_172\bin;C:\Program Files (x86)\Common Files\Oracle\Java\javapath;C:\ProgramData\Oracle\Java\javapath;C:\Python35\Scripts\;C:\Python35\;C:\Perl64\site\bin;C:\Perl64\bin;C:\WINDOWS\system32;C:\WINDOWS;C:\WINDOWS\System32\Wbem;C:\WINDOWS\System32\WindowsPowerShell\v1.0\;C:\WINDOWS\System32\OpenSSH\;C:\Users\jenkins\AppData\Local\Microsoft\WindowsApps 

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>C:\Python35\python.exe -u dev-tools\scripts\reproduceJenkinsFailures.py --no-git https://jenkins.thetaphi.de/job/Lucene-Solr-master-Windows/7531/consoleText 
[repro] Jenkins log URL: https://jenkins.thetaphi.de/job/Lucene-Solr-master-Windows/7531/consoleText

[repro] Revision: 4ccf0fb8f6ce269de8b4501fca201f5b4763cfe7

[repro] Ant options: "-Dargs=-XX:+UseCompressedOops -XX:+UseSerialGC"
[repro] Repro line:  ant test  -Dtestcase=TestSimGenericDistributedQueue -Dtests.method=testDistributedQueueBlocking -Dtests.seed=F48230836902F6F5 -Dtests.slow=true -Dtests.locale=de-LU -Dtests.timezone=Antarctica/DumontDUrville -Dtests.asserts=true -Dtests.file.encoding=US-ASCII


[repro] Repro line:  ant test  -Dtestcase=TestSimGenericDistributedQueue -Dtests.seed=F48230836902F6F5 -Dtests.slow=true -Dtests.locale=de-LU -Dtests.timezone=Antarctica/DumontDUrville -Dtests.asserts=true -Dtests.file.encoding=US-ASCII


[repro] ant clean
Buildfile: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\build.xml

clean:

clean:

clean:

BUILD SUCCESSFUL
Total time: 0 seconds
[repro] Test suites by module:
[repro]    solr\core
[repro]       TestSimGenericDistributedQueue
[repro] ant compile-test
Buildfile: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\core\build.xml

check-analyzers-icu-uptodate:

jar-analyzers-icu:

-mrjar-classes-uptodate:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: Apache Ivy 2.4.0 - 20141213170938 :: http://ant.apache.org/ivy/ ::
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve-groovy:
[ivy:cachepath] :: resolving dependencies :: org.codehaus.groovy#groovy-all-caller;working
[ivy:cachepath] 	confs: [default]
[ivy:cachepath] 	found org.codehaus.groovy#groovy-all;2.4.15 in public
[ivy:cachepath] :: resolution report :: resolve 113ms :: artifacts dl 2ms
	---------------------------------------------------------------------
	|                  |            modules            ||   artifacts   |
	|       conf       | number| search|dwnlded|evicted|| number|dwnlded|
	---------------------------------------------------------------------
	|      default     |   1   |   0   |   0   |   0   ||   1   |   0   |
	---------------------------------------------------------------------

check-analyzers-common-uptodate:

jar-analyzers-common:

-mrjar-classes-uptodate:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve-groovy:

-check-git-state:

-git-cleanroot:

-copy-git-state:
     [copy] Copying 1 file to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build

git-autoclean:

resolve:

common.init:

compile-lucene-core:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

compile-core:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java
    [javac] Compiling 868 source files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java
    [javac] Note: Some input files use or override a deprecated API.
    [javac] Note: Recompile with -Xlint:deprecation for details.
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\graph\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\document\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\bkd\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\compressing\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\lucene60\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\lucene80\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\index\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\fst\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\analysis\tokenattributes\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\search\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\packed\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\mutable\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\lucene70\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\perfield\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\analysis\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\analysis\standard\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\store\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\blocktree\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\search\spans\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\search\similarities\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\util\automaton\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\codecs\lucene50\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java\org\apache\lucene\geo\package-info.class
     [copy] Copying 3 files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\core\classes\java

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

compile-core:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java
    [javac] Compiling 472 source files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java
    [javac] Note: Some input files use or override a deprecated API.
    [javac] Note: Recompile with -Xlint:deprecation for details.
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\hunspell\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\minhash\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ga\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ca\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\custom\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\sr\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\collation\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\sv\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\bg\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\payloads\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ngram\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\core\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\bn\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\fr\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\tartarus\snowball\ext\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\br\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\miscellaneous\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\sinks\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\cjk\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\synonym\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\wikipedia\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\fa\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\reverse\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\nl\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ro\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\fi\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ru\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\no\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\el\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ckb\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\tartarus\snowball\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\in\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\util\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\it\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\snowball\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\en\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\es\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\shingle\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\eu\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\ar\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\query\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\id\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\compound\hyphenation\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\charfilter\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\pt\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\lv\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\lt\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\hu\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\hy\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\pattern\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\cz\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\th\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\path\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\tr\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\da\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\de\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\hi\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\collation\tokenattributes\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\gl\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\commongrams\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java\org\apache\lucene\analysis\compound\package-info.class
     [copy] Copying 40 files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java

patch-mrjar-classes:
[patch-cls] Remapped 0 class files for Java 9 to: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\classes\java9
    [touch] Creating C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\patch-mrjar.stamp

-mrjar-check:

-mrjar-core:

-jar-core:
     [exec] Execute failed: java.io.IOException: Cannot run program "git" (in directory "C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\analysis\common"): CreateProcess error=2, The system cannot find the file specified
      [jar] Building jar: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\common\lucene-analyzers-common-8.0.0-SNAPSHOT.jar

jar-core:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

resolve:

common.init:

compile-lucene-core:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

compile-core:

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

common.compile-core:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java
    [javac] Compiling 25 source files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java
    [javac] Note: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\analysis\icu\src\java\org\apache\lucene\analysis\icu\ICUTransformFilter.java uses or overrides a deprecated API.
    [javac] Note: Recompile with -Xlint:deprecation for details.
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java\org\apache\lucene\analysis\icu\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java\org\apache\lucene\analysis\icu\tokenattributes\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java\org\apache\lucene\analysis\icu\segmentation\package-info.class
     [copy] Copying 6 files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java

compile-core:

patch-mrjar-classes:
[patch-cls] Remapped 0 class files for Java 9 to: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\classes\java9
    [touch] Creating C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\patch-mrjar.stamp

-mrjar-check:

-mrjar-core:

-jar-core:
     [exec] Execute failed: java.io.IOException: Cannot run program "git" (in directory "C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\analysis\icu"): CreateProcess error=2, The system cannot find the file specified
      [jar] Building jar: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\analysis\icu\lucene-analyzers-icu-8.0.0-SNAPSHOT.jar

jar-core:

-compile-test-lucene-queryparser:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

common.init:

compile-lucene-core:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve:

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

compile-core:

init:

compile-test:

check-queries-uptodate:

jar-queries:

-mrjar-classes-uptodate:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve-groovy:
[ivy:cachepath] :: resolving dependencies :: org.codehaus.groovy#groovy-all-caller;working
[ivy:cachepath] 	confs: [default]
[ivy:cachepath] 	found org.codehaus.groovy#groovy-all;2.4.15 in public
[ivy:cachepath] :: resolution report :: resolve 21ms :: artifacts dl 2ms
	---------------------------------------------------------------------
	|                  |            modules            ||   artifacts   |
	|       conf       | number| search|dwnlded|evicted|| number|dwnlded|
	---------------------------------------------------------------------
	|      default     |   1   |   0   |   0   |   0   ||   1   |   0   |
	---------------------------------------------------------------------

check-expressions-uptodate:

jar-expressions:

-mrjar-classes-uptodate:

ivy-availability-check:
[loadresource] Do not set property disallowed.ivy.jars.list as its length is 0.

-ivy-fail-disallowed-ivy-version:

ivy-fail:

ivy-configure:
[ivy:configure] :: loading settings :: file = C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\top-level-ivy-settings.xml

resolve-groovy:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

resolve:

common.init:

compile-lucene-core:

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

compile-core:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\classes\java
    [javac] Compiling 16 source files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\classes\java
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\classes\java\org\apache\lucene\expressions\js\package-info.class
    [javac] Creating empty C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\classes\java\org\apache\lucene\expressions\package-info.class
     [copy] Copying 1 file to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\classes\java

patch-mrjar-classes:
[patch-cls] Remapped 0 class files for Java 9 to: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\classes\java9
    [touch] Creating C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\patch-mrjar.stamp

-mrjar-check:

-mrjar-core:

-jar-core:
     [exec] Execute failed: java.io.IOException: Cannot run program "git" (in directory "C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\expressions"): CreateProcess error=2, The system cannot find the file specified
      [jar] Building jar: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\expressions\lucene-expressions-8.0.0-SNAPSHOT.jar

jar-core:

-check-git-state:

-git-cleanroot:

-copy-git-state:

git-autoclean:

resolve:

common.init:

compile-lucene-core:

init:

-clover.disable:

-clover.load:

-clover.classpath:

-clover.setup:

clover:

common.compile-core:
    [mkdir] Created dir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\queries\classes\java
    [javac] Compiling 82 source files to C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\build\queries\classes\java
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\FunctionQuery.java:60: warning: [rawtypes] found raw type: Map
    [javac]     protected final Map context;
    [javac]                     ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:54: warning: [rawtypes] found raw type: Map
    [javac]   public abstract FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException;
    [javac]                                            ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:78: warning: [rawtypes] found raw type: Map
    [javac]   public void createWeight(Map context, IndexSearcher searcher) throws IOException {
    [javac]                            ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:84: warning: [rawtypes] found raw type: Map
    [javac]   public static Map newContext(IndexSearcher searcher) {
    [javac]                 ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:85: warning: [rawtypes] found raw type: Map
    [javac]     Map context = new IdentityHashMap();
    [javac]     ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:85: warning: [rawtypes] found raw type: IdentityHashMap
    [javac]     Map context = new IdentityHashMap();
    [javac]                       ^
    [javac]   missing type arguments for generic class IdentityHashMap<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in class IdentityHashMap
    [javac]     V extends Object declared in class IdentityHashMap
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:86: warning: [unchecked] unchecked call to put(K,V) as a member of the raw type Map
    [javac]     context.put("searcher", searcher);
    [javac]                ^
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:123: warning: [rawtypes] found raw type: Map
    [javac]       Map context = new IdentityHashMap<>();
    [javac]       ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:125: warning: [unchecked] unchecked call to put(K,V) as a member of the raw type Map
    [javac]       context.put("scorer", scorer);
    [javac]                  ^
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:199: warning: [rawtypes] found raw type: Map
    [javac]       Map context = new HashMap<>();
    [javac]       ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:201: warning: [unchecked] unchecked call to put(K,V) as a member of the raw type Map
    [javac]       context.put("scorer", scorer);
    [javac]                  ^
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:202: warning: [unchecked] unchecked call to put(K,V) as a member of the raw type Map
    [javac]       context.put("searcher", searcher);
    [javac]                  ^
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:236: warning: [rawtypes] found raw type: Map
    [javac]       Map context = new HashMap<>();
    [javac]       ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:239: warning: [unchecked] unchecked call to put(K,V) as a member of the raw type Map
    [javac]       context.put("scorer", scorer);
    [javac]                  ^
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:240: warning: [unchecked] unchecked call to put(K,V) as a member of the raw type Map
    [javac]       context.put("searcher", searcher);
    [javac]                  ^
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:284: warning: [rawtypes] found raw type: Map
    [javac]     public FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException {
    [javac]                                     ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:366: warning: [rawtypes] found raw type: Map
    [javac]       Map context = newContext(searcher);
    [javac]       ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:373: warning: [rawtypes] found raw type: Map
    [javac]     private final Map context;
    [javac]                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:375: warning: [rawtypes] found raw type: Map
    [javac]     public ValueSourceComparatorSource(Map context) {
    [javac]                                        ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:395: warning: [rawtypes] found raw type: Map
    [javac]     private final Map fcontext;
    [javac]                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\ValueSource.java:398: warning: [rawtypes] found raw type: Map
    [javac]     ValueSourceComparator(Map fcontext, int numHits) {
    [javac]                           ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\BytesRefFieldSource.java:44: warning: [rawtypes] found raw type: Map
    [javac]   public FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException {
    [javac]                                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\ComparisonBoolFunction.java:53: warning: [rawtypes] found raw type: Map
    [javac]   public FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException {
    [javac]                                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\ComparisonBoolFunction.java:100: warning: [rawtypes] found raw type: Map
    [javac]   public void createWeight(Map context, IndexSearcher searcher) throws IOException {
    [javac]                            ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\ConstValueSource.java:44: warning: [rawtypes] found raw type: Map
    [javac]   public FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException {
    [javac]                                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\MultiFunction.java:115: warning: [rawtypes] found raw type: Map
    [javac]   public static FunctionValues[] valsArr(List<ValueSource> sources, Map fcontext, LeafReaderContext readerContext) throws IOException {
    [javac]                                                                     ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\MultiFunction.java:160: warning: [rawtypes] found raw type: Map
    [javac]   public void createWeight(Map context, IndexSearcher searcher) throws IOException {
    [javac]                            ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\DefFunction.java:45: warning: [rawtypes] found raw type: Map
    [javac]   public FunctionValues getValues(Map fcontext, LeafReaderContext readerContext) throws IOException {
    [javac]                                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\DualFloatFunction.java:54: warning: [rawtypes] found raw type: Map
    [javac]   public FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException {
    [javac]                                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\DualFloatFunction.java:78: warning: [rawtypes] found raw type: Map
    [javac]   public void createWeight(Map context, IndexSearcher searcher) throws IOException {
    [javac]                            ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\DocFreqValueSource.java:148: warning: [rawtypes] found raw type: Map
    [javac]   public FunctionValues getValues(Map context, LeafReaderContext readerContext) throws IOException {
    [javac]                                   ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java\org\apache\lucene\queries\function\valuesource\DocFreqValueSource.java:155: warning: [rawtypes] found raw type: Map
    [javac]   public void createWeight(Map context, IndexSearcher searcher) throws IOException {
    [javac]                            ^
    [javac]   missing type arguments for generic class Map<K,V>
    [javac]   where K,V are type-variables:
    [javac]     K extends Object declared in interface Map
    [javac]     V extends Object declared in interface Map
    [javac] C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\queries\src\java

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

certain unicode glyphs: windows-1252
   [junit4] Executing 5 suites with 2 JVMs.
   [junit4] 
   [junit4] Started J0 PID(10244@serv1-vm1).
   [junit4] Started J1 PID(11036@serv1-vm1).
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
   [junit4] OK      1.77s J0 | TestSimGenericDistributedQueue.testPeekElements
   [junit4] OK      2.02s J0 | TestSimGenericDistributedQueue.testDistributedQueue
   [junit4] OK      2.01s J0 | TestSimGenericDistributedQueue.testDistributedQueue {#2}
   [junit4] OK      0.22s J0 | TestSimGenericDistributedQueue.testLocallyOffer
   [junit4] OK      2.11s J0 | TestSimGenericDistributedQueue.testDistributedQueueBlocking
   [junit4] Completed [1/5] on J0 in 18.82s, 5 tests
   [junit4] 
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
   [junit4] OK      1.71s J1 | TestSimGenericDistributedQueue.testPeekElements
   [junit4] OK      2.01s J1 | TestSimGenericDistributedQueue.testDistributedQueue
   [junit4] OK      2.01s J1 | TestSimGenericDistributedQueue.testDistributedQueue {#2}
   [junit4] OK      0.23s J1 | TestSimGenericDistributedQueue.testLocallyOffer
   [junit4] OK      2.11s J1 | TestSimGenericDistributedQueue.testDistributedQueueBlocking
   [junit4] Completed [2/5] on J1 in 18.78s, 5 tests
   [junit4] 
   [junit4] Duplicate suite name used with XML reports: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue. This may confuse tools that process XML reports. Set 'ignoreDuplicateSuites' to true to skip this message.
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
   [junit4] OK      1.51s J0 | TestSimGenericDistributedQueue.testPeekElements
   [junit4] OK      2.01s J0 | TestSimGenericDistributedQueue.testDistributedQueue
   [junit4] OK      2.01s J0 | TestSimGenericDistributedQueue.testDistributedQueue {#2}
   [junit4] OK      0.22s J0 | TestSimGenericDistributedQueue.testLocallyOffer
   [junit4] OK      2.11s J0 | TestSimGenericDistributedQueue.testDistributedQueueBlocking
   [junit4] Completed [3/5] on J0 in 7.90s, 5 tests
   [junit4] 
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
   [junit4] OK      1.50s J1 | TestSimGenericDistributedQueue.testPeekElements
   [junit4] OK      2.01s J1 | TestSimGenericDistributedQueue.testDistributedQueue
   [junit4] OK      2.01s J1 | TestSimGenericDistributedQueue.testDistributedQueue {#2}
   [junit4] OK      0.23s J1 | TestSimGenericDistributedQueue.testLocallyOffer
   [junit4] OK      2.10s J1 | TestSimGenericDistributedQueue.testDistributedQueueBlocking
   [junit4] Completed [4/5] on J1 in 7.87s, 5 tests
   [junit4] 
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
   [junit4] OK      1.50s J0 | TestSimGenericDistributedQueue.testPeekElements
   [junit4] OK      2.01s J0 | TestSimGenericDistributedQueue.testDistributedQueue
   [junit4] OK      2.00s J0 | TestSimGenericDistributedQueue.testDistributedQueue {#2}
   [junit4] OK      0.18s J0 | TestSimGenericDistributedQueue.testLocallyOffer
   [junit4] OK      2.11s J0 | TestSimGenericDistributedQueue.testDistributedQueueBlocking
   [junit4] Completed [5/5] on J0 in 7.82s, 5 tests
   [junit4] 
   [junit4] JVM J0:     0.88 ..    37.29 =    36.41s
   [junit4] JVM J1:     0.88 ..    29.52 =    28.65s
   [junit4] Execution time total: 37 seconds
   [junit4] Tests summary: 5 suites, 25 tests
   [junit4] Could not remove temporary path: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J0 (java.nio.file.DirectoryNotEmptyException: Remaining files: [C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J0\temp])
   [junit4] Could not remove temporary path: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J1 (java.nio.file.DirectoryNotEmptyException: Remaining files: [C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J1\temp])
     [echo] 5 slowest tests:
[junit4:tophints] 962.12s | org.apache.solr.cloud.cdcr.CdcrWithNodesRestartsTest
[junit4:tophints] 686.08s | org.apache.solr.cloud.cdcr.CdcrOpsAndBoundariesTest
[junit4:tophints] 459.70s | org.apache.solr.cloud.api.collections.ShardSplitTest
[junit4:tophints] 130.87s | org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest
[junit4:tophints] 125.76s | org.apache.solr.cloud.ZkFailoverTest

-check-totals:

test-nocompile:

BUILD SUCCESSFUL
Total time: 39 seconds
[repro] Failures:
[repro]   0/5 failed: org.apache.solr.cloud.autoscaling.sim.TestSimGenericDistributedQueue
[repro] Exiting with code 0

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST lucene\build move /y lucene\build lucene\build.repro 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST solr\build move /y solr\build solr\build.repro 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST lucene\build.orig move /y lucene\build.orig lucene\build 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST solr\build.orig move /y solr\build.orig solr\build 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>exit 0 
Archiving artifacts
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
java.lang.InterruptedException: no matches found within 10000
	at hudson.FilePath$ValidateAntFileMask.hasMatch(FilePath.java:2845)
	at hudson.FilePath$ValidateAntFileMask.invoke(FilePath.java:2724)
	at hudson.FilePath$ValidateAntFileMask.invoke(FilePath.java:2705)
	at hudson.FilePath$FileCallableWrapper.call(FilePath.java:3084)
Also:   hudson.remoting.Channel$CallSiteStackTrace: Remote call to Windows VBOX
		at hudson.remoting.Channel.attachCallSiteStackTrace(Channel.java:1741)
		at hudson.remoting.UserRequest$ExceptionResponse.retrieve(UserRequest.java:357)
		at hudson.remoting.Channel.call(Channel.java:955)
		at hudson.FilePath.act(FilePath.java:1070)
		at hudson.FilePath.act(FilePath.java:1059)
		at hudson.FilePath.validateAntFileMask(FilePath.java:2703)
		at hudson.tasks.ArtifactArchiver.perform(ArtifactArchiver.java:243)
		at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
		at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
		at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
		at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
		at hudson.model.Build$BuildExecution.post2(Build.java:186)
		at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
		at hudson.model.Run.execute(Run.java:1840)
		at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
		at hudson.model.ResourceController.execute(ResourceController.java:97)
		at hudson.model.Executor.run(Executor.java:429)
Caused: hudson.FilePath$TunneledInterruptedException
	at hudson.FilePath$FileCallableWrapper.call(FilePath.java:3086)
	at hudson.remoting.UserRequest.perform(UserRequest.java:212)
	at hudson.remoting.UserRequest.perform(UserRequest.java:54)
	at hudson.remoting.Request$2.run(Request.java:369)
	at hudson.remoting.InterceptingExecutorService$1.call(InterceptingExecutorService.java:72)
	at java.util.concurrent.FutureTask.run(Unknown Source)
	at java.util.concurrent.ThreadPoolExecutor.runWorker(Unknown Source)
	at java.util.concurrent.ThreadPoolExecutor$Worker.run(Unknown Source)
	at java.lang.Thread.run(Unknown Source)
Caused: java.lang.InterruptedException: java.lang.InterruptedException: no matches found within 10000
	at hudson.FilePath.act(FilePath.java:1072)
	at hudson.FilePath.act(FilePath.java:1059)
	at hudson.FilePath.validateAntFileMask(FilePath.java:2703)
	at hudson.tasks.ArtifactArchiver.perform(ArtifactArchiver.java:243)
	at hudson.tasks.BuildStepCompatibilityLayer.perform(BuildStepCompatibilityLayer.java:81)
	at hudson.tasks.BuildStepMonitor$1.perform(BuildStepMonitor.java:20)
	at hudson.model.AbstractBuild$AbstractBuildExecution.perform(AbstractBuild.java:744)
	at hudson.model.AbstractBuild$AbstractBuildExecution.performAllBuildSteps(AbstractBuild.java:690)
	at hudson.model.Build$BuildExecution.post2(Build.java:186)
	at hudson.model.AbstractBuild$AbstractBuildExecution.post(AbstractBuild.java:635)
	at hudson.model.Run.execute(Run.java:1840)
	at hudson.model.FreeStyleBuild.run(FreeStyleBuild.java:43)
	at hudson.model.ResourceController.execute(ResourceController.java:97)
	at hudson.model.Executor.run(Executor.java:429)
No artifacts found that match the file pattern "**/*.events,heapdumps/**,**/*_pid*.log". Configuration error?
[WARNINGS] Parsing warnings in console log with parser Java Compiler (javac)
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=4ccf0fb8f6ce269de8b4501fca201f5b4763cfe7, workspace=C:\Users\jenkins\workspace\Lucene-Solr-master-Windows
[WARNINGS] Computing warning deltas based on reference build #7530
Recording test results
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Build step 'Publish JUnit test result report' changed build result to UNSTABLE
Email was triggered for: Unstable (Test Failures)
Sending email for trigger: Unstable (Test Failures)
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2

[JENKINS] Lucene-Solr-master-Windows (32bit/jdk1.8.0_172) - Build # 7532 - Still Unstable!

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

2 tests failed.
FAILED:  org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration.testEventQueue

Error Message:
action did not start

Stack Trace:
java.lang.AssertionError: action did not start
	at __randomizedtesting.SeedInfo.seed([7FA427DF5A59F17B:B6116571533E378E]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration.testEventQueue(TestSimTriggerIntegration.java:666)
	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:1742)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:935)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:971)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:985)
	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:944)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:830)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:880)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:891)
	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.sim.TestSimTriggerIntegration.testEventQueue

Error Message:
action did not start

Stack Trace:
java.lang.AssertionError: action did not start
	at __randomizedtesting.SeedInfo.seed([7FA427DF5A59F17B:B6116571533E378E]:0)
	at org.junit.Assert.fail(Assert.java:93)
	at org.junit.Assert.assertTrue(Assert.java:43)
	at org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration.testEventQueue(TestSimTriggerIntegration.java:666)
	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:1742)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:935)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:971)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:985)
	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:944)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:830)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:880)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:891)
	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 12467 lines...]
   [junit4] Suite: org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration
   [junit4]   2> 314619 INFO  (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.SolrTestCaseJ4 SecureRandom sanity checks: test.solr.allowed.securerandom=null & java.security.egd=file:/dev/./urandom
   [junit4]   2> Creating dataDir: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J1\temp\solr.cloud.autoscaling.sim.TestSimTriggerIntegration_7FA427DF5A59F17B-001\init-core-data-001
   [junit4]   2> 314622 INFO  (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.SolrTestCaseJ4 Using PointFields (NUMERIC_POINTS_SYSPROP=true) w/NUMERIC_DOCVALUES_SYSPROP=false
   [junit4]   2> 314624 INFO  (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-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> 314673 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.s.SimClusterStateProvider --- new Overseer leader: 127.0.0.1:10000_solr
   [junit4]   2> 314673 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Adding .auto_add_replicas and .scheduled_maintenance triggers
   [junit4]   2> 314673 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 0
   [junit4]   2> 314674 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 0, lastZnodeVersion -1
   [junit4]   2> 314674 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 0
   [junit4]   2> 314675 INFO  (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.h.a.MetricsHistoryHandler No .system collection, keeping metrics history in memory.
   [junit4]   2> 314681 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.NodeLostTrigger NodeLostTrigger .auto_add_replicas - Initial livenodes: [127.0.0.1:10001_solr, 127.0.0.1:10000_solr]
   [junit4]   2> 314682 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 314682 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 0, lastZnodeVersion 0
   [junit4]   2> 314683 INFO  (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testSearchRate
   [junit4]   2> 314683 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 1
   [junit4]   2> 314684 INFO  (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.s.SimCloudManager === Restarting OverseerTriggerThread and clearing object cache...
   [junit4]   2> 314685 WARN  (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 314686 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Shutting down scheduled thread pool executor now
   [junit4]   2> 314686 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Shutting down action executor now
   [junit4]   2> 314686 WARN  (ScheduledTrigger-764-thread-1) [    ] o.a.s.c.a.NodeLostTrigger NodeLostTrigger ran but was already closed
   [junit4]   2> 314686 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Awaiting termination for action executor
   [junit4]   2> 314686 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Awaiting termination for scheduled thread pool executor
   [junit4]   2> 314686 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers ScheduledTriggers closed completely
   [junit4]   2> 314687 DEBUG (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread has been closed explicitly
   [junit4]   2> 314687 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Adding .auto_add_replicas and .scheduled_maintenance triggers
   [junit4]   2> 314688 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 2
   [junit4]   2> 314688 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 2, lastZnodeVersion -1
   [junit4]   2> 314688 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 2
   [junit4]   2> 314688 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.NodeLostTrigger NodeLostTrigger .auto_add_replicas - Initial livenodes: [127.0.0.1:10001_solr, 127.0.0.1:10000_solr]
   [junit4]   2> 314688 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 314688 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 2, lastZnodeVersion 2
   [junit4]   2> 314689 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314711 DEBUG (ScheduledTrigger-769-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314732 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314753 DEBUG (ScheduledTrigger-769-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314775 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314795 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314806 DEBUG (simCloudManagerPool-768-thread-1) [    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 314807 DEBUG (simCloudManagerPool-768-thread-1) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 3
   [junit4]   2> 314807 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 3
   [junit4]   2> 314807 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 314807 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 3, lastZnodeVersion 3
   [junit4]   2> 314817 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314838 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314838 DEBUG (simCloudManagerPool-768-thread-2) [    ] o.a.s.c.a.s.SimClusterStateProvider -- submit leader election for .system / shard1
   [junit4]   2> 314839 DEBUG (simCloudManagerPool-768-thread-3) [    ] o.a.s.c.a.s.SimClusterStateProvider Running leader election for .system / shard1
   [junit4]   2> 314841 DEBUG (simCloudManagerPool-768-thread-3) [    ] o.a.s.c.a.s.SimClusterStateProvider -- elected new leader for .system / shard1: core_node1
   [junit4]   2> 314859 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314869 DEBUG (simCloudManagerPool-768-thread-6) [    ] o.a.s.c.a.s.SimClusterStateProvider -- submit leader election for collection1 / shard1
   [junit4]   2> 314870 DEBUG (simCloudManagerPool-768-thread-7) [    ] o.a.s.c.a.s.SimClusterStateProvider Running leader election for collection1 / shard1
   [junit4]   2> 314870 DEBUG (simCloudManagerPool-768-thread-7) [    ] o.a.s.c.a.s.SimClusterStateProvider -- elected new leader for collection1 / shard1: core_node2
   [junit4]   2> 314879 DEBUG (simCloudManagerPool-768-thread-5) [    ] o.a.s.c.a.s.SimClusterStateProvider -- already has leader collection1 / shard1
   [junit4]   2> 314881 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314897 DEBUG (simCloudManagerPool-768-thread-8) [    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 314898 DEBUG (simCloudManagerPool-768-thread-8) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 4
   [junit4]   2> 314898 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 4
   [junit4]   2> 314898 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 314899 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 4, lastZnodeVersion 4
   [junit4]   2> 314901 DEBUG (ScheduledTrigger-769-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314901 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10001_solr
   [junit4]   2> 314901 DEBUG (simCloudManagerPool-768-thread-9) [    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 314901 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10000_solr
   [junit4]   2> 314902 DEBUG (simCloudManagerPool-768-thread-9) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 5
   [junit4]   2> 314902 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 5
   [junit4]   2> 314902 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 314902 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 5, lastZnodeVersion 5
   [junit4]   2> 314922 DEBUG (ScheduledTrigger-769-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314928 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10001_solr
   [junit4]   2> 314928 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n1:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 314933 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10000_solr
   [junit4]   2> 314933 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n2:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 314933 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ## Collection: collection1
   [junit4]   2> 314933 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ##  - shard1
   [junit4]   2> 314933 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n1  250.0
   [junit4]   2> 314933 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n2  250.0
   [junit4]   2> 314942 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger -- collection1.shard1: totalShardRate=500.0, shardRate=250.0
   [junit4]   2> 314943 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10001_solr
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n1:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10000_solr
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n2:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ## Collection: collection1
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ##  - shard1
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n1  250.0
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n2  250.0
   [junit4]   2> 314963 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger -- collection1.shard1: totalShardRate=500.0, shardRate=250.0
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10001_solr
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n1:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10000_solr
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n2:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ## Collection: collection1
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ##  - shard1
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n1  250.0
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n2  250.0
   [junit4]   2> 314984 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.SearchRateTrigger -- collection1.shard1: totalShardRate=500.0, shardRate=250.0
   [junit4]   2> 315004 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10001_solr
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n1:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10000_solr
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n2:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ## Collection: collection1
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ##  - shard1
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n1  250.0
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n2  250.0
   [junit4]   2> 315005 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.SearchRateTrigger -- collection1.shard1: totalShardRate=500.0, shardRate=250.0
   [junit4]   2> 315016 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.ScheduledTriggers ++++++++ Cooldown inactive - processing event: {
   [junit4]   2>   "id":"27c1d33c61988Td055tdz7fniekgz6ts75eextv",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699414817937800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":250.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}}
   [junit4]   2> 315017 DEBUG (ScheduledTrigger-769-thread-4) [    ] o.a.s.c.a.ScheduledTriggers Pausing all triggers: [.auto_add_replicas, search_rate_trigger]
   [junit4]   2> 315029 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"27c1d33c61988Td055tdz7fniekgz6ts75eextv",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699414817937800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":250.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699419039922800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}}
   [junit4]   2> 315034 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction -- processing event: {
   [junit4]   2>   "id":"27c1d33c61988Td055tdz7fniekgz6ts75eextv",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699414817937800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":250.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699419039922800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}} with context properties: {AFTER_ACTION=[start], BEFORE_ACTION=[start, compute]}
   [junit4]   2> 315059 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction Computed Plan: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10001_solr&type=NRT
   [junit4]   2> 315061 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction Computed Plan: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10001_solr&type=NRT
   [junit4]   2> 315061 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction Computed Plan: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10000_solr&type=NRT
   [junit4]   2> 315061 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.s.c.a.PolicyHelper returnSession, curr-time 699421197 sessionWrapper.createTime 699420474107800, this.sessionWrapper.createTime 699420474107800 
   [junit4]   2> 315062 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction -- processing event: {
   [junit4]   2>   "id":"27c1d33c61988Td055tdz7fniekgz6ts75eextv",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699414817937800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "__start__":3,
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":250.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699419039922800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}} with context properties: {operations=[{
   [junit4]   2>   "class":"org.apache.solr.client.solrj.request.CollectionAdminRequest$AddReplica",
   [junit4]   2>   "method":"GET",
   [junit4]   2>   "params.action":"ADDREPLICA",
   [junit4]   2>   "params.collection":"collection1",
   [junit4]   2>   "params.shard":"shard1",
   [junit4]   2>   "params.node":"127.0.0.1:10001_solr",
   [junit4]   2>   "params.type":"NRT"}, {
   [junit4]   2>   "class":"org.apache.solr.client.solrj.request.CollectionAdminRequest$AddReplica",
   [junit4]   2>   "method":"GET",
   [junit4]   2>   "params.action":"ADDREPLICA",
   [junit4]   2>   "params.collection":"collection1",
   [junit4]   2>   "params.shard":"shard1",
   [junit4]   2>   "params.node":"127.0.0.1:10001_solr",
   [junit4]   2>   "params.type":"NRT"}, {
   [junit4]   2>   "class":"org.apache.solr.client.solrj.request.CollectionAdminRequest$AddReplica",
   [junit4]   2>   "method":"GET",
   [junit4]   2>   "params.action":"ADDREPLICA",
   [junit4]   2>   "params.collection":"collection1",
   [junit4]   2>   "params.shard":"shard1",
   [junit4]   2>   "params.node":"127.0.0.1:10000_solr",
   [junit4]   2>   "params.type":"NRT"}], AFTER_ACTION=[start, compute], BEFORE_ACTION=[start, compute, execute]}
   [junit4]   2> 315062 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction Executing operation: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10001_solr&type=NRT
   [junit4]   2> 315063 INFO  (simCloudManagerPool-768-thread-11) [    ] o.a.s.c.a.c.AddReplicaCmd Node Identified 127.0.0.1:10001_solr for creating new replica of shard shard1
   [junit4]   2> 315075 DEBUG (simCloudManagerPool-768-thread-11) [    ] o.a.s.c.a.s.SimClusterStateProvider -- already has leader collection1 / shard1
   [junit4]   2> 315081 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction Executing operation: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10001_solr&type=NRT
   [junit4]   2> 315082 INFO  (simCloudManagerPool-768-thread-14) [    ] o.a.s.c.a.c.AddReplicaCmd Node Identified 127.0.0.1:10001_solr for creating new replica of shard shard1
   [junit4]   2> 315094 DEBUG (simCloudManagerPool-768-thread-14) [    ] o.a.s.c.a.s.SimClusterStateProvider -- already has leader collection1 / shard1
   [junit4]   2> 315094 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction Executing operation: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10000_solr&type=NRT
   [junit4]   2> 315095 INFO  (simCloudManagerPool-768-thread-17) [    ] o.a.s.c.a.c.AddReplicaCmd Node Identified 127.0.0.1:10000_solr for creating new replica of shard shard1
   [junit4]   2> 315107 DEBUG (simCloudManagerPool-768-thread-17) [    ] o.a.s.c.a.s.SimClusterStateProvider -- already has leader collection1 / shard1
   [junit4]   2> 315113 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Resuming trigger: .auto_add_replicas after 100ms
   [junit4]   2> 315113 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Resuming trigger: search_rate_trigger after 100ms
   [junit4]   2> 315113 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing took 4411 ms for event id=27c1d33c61988Td055tdz7fniekgz6ts75eextv
   [junit4]   2> 315210 INFO  (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testSearchRate
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-1) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315214 INFO  (TEST-TestSimTriggerIntegration.testSearchRate-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.s.SimSolrCloudTestCase #######################################
   [junit4]   2> ############ CLUSTER STATE ############
   [junit4]   2> #######################################
   [junit4]   2> ## Live nodes:		2
   [junit4]   2> ## Empty nodes:	0
   [junit4]   2> ## Dead nodes:		0
   [junit4]   2> ## Collections:	[collection1, .system]
   [junit4]   2> ## Max replicas per node:	3
   [junit4]   2> ## Min replicas per node:	3
   [junit4]   2> ## Total replicas:		6
   [junit4]   2> ## * .system		1
   [junit4]   2> ##		- active           1
   [junit4]   2> ## * collection1		5
   [junit4]   2> ##		- active           5
   [junit4]   2> ######### Solr op counts ##########
   [junit4]   2> ##		- ADDREPLICA         3
   [junit4]   2> ##		- CREATE             1
   [junit4]   2> ##		- DELETESTATUS       3
   [junit4]   2> ##		- REQUESTSTATUS      3
   [junit4]   2> ##		- autoscaling        3
   [junit4]   2> ##		- update             2
   [junit4]   2> ######### Autoscaling event counts ###########
   [junit4]   2> ## * Trigger: search_rate_trigger
   [junit4]   2> ##		- STARTED         1
   [junit4]   2> ##		- SUCCEEDED       1
   [junit4]   2> 
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10001_solr
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n1:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ### rates for node 127.0.0.1:10000_solr
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ###  metrics:solr.core.collection1.shard1.replica_n2:QUERY./select.requestTimes:1minRate	250
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ## Collection: collection1
   [junit4]   2> 315214 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ##  - shard1
   [junit4]   2> 315215 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n1  250.0
   [junit4]   2> 315215 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger ##     collection1_shard1_replica_n2  250.0
   [junit4]   2> 315215 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.SearchRateTrigger -- collection1.shard1: totalShardRate=500.0, shardRate=100.0
   [junit4] IGNOR/A 0.00s J1 | TestSimTriggerIntegration.testNodeMarkersRegistration
   [junit4]    > Assumption #1: 'badapple' test group is disabled (@BadApple(bugUrl=https://issues.apache.org/jira/browse/SOLR-12028))
   [junit4]   2> 315217 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.ScheduledTriggers ++++++++ Cooldown inactive - processing event: {
   [junit4]   2>   "id":"27c1e0adb8430Td055tdz7fniekgz6ts75eexty",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699418426442800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":100.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}}
   [junit4]   2> 315217 DEBUG (ScheduledTrigger-769-thread-2) [    ] o.a.s.c.a.ScheduledTriggers Pausing all triggers: [.auto_add_replicas, search_rate_trigger]
   [junit4]   2> 315226 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"27c1e0adb8430Td055tdz7fniekgz6ts75eexty",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699418426442800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":100.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699429018647800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}}
   [junit4]   2> 315227 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction -- processing event: {
   [junit4]   2>   "id":"27c1e0adb8430Td055tdz7fniekgz6ts75eexty",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699418426442800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":100.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699429018647800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}} with context properties: {AFTER_ACTION=[start], BEFORE_ACTION=[start, compute]}
   [junit4]   2> 315229 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction Computed Plan: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10000_solr&type=NRT
   [junit4]   2> 315229 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction Computed Plan: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10001_solr&type=NRT
   [junit4]   2> 315229 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ComputePlanAction Computed Plan: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10001_solr&type=NRT
   [junit4]   2> 315229 INFO  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.s.c.a.PolicyHelper returnSession, curr-time 699429623 sessionWrapper.createTime 699429521937800, this.sessionWrapper.createTime 699429521937800 
   [junit4]   2> 315229 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction -- processing event: {
   [junit4]   2>   "id":"27c1e0adb8430Td055tdz7fniekgz6ts75eexty",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699418426442800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "__start__":3,
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":100.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699429018647800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}} with context properties: {operations=[{
   [junit4]   2>   "class":"org.apache.solr.client.solrj.request.CollectionAdminRequest$AddReplica",
   [junit4]   2>   "method":"GET",
   [junit4]   2>   "params.action":"ADDREPLICA",
   [junit4]   2>   "params.collection":"collection1",
   [junit4]   2>   "params.shard":"shard1",
   [junit4]   2>   "params.node":"127.0.0.1:10000_solr",
   [junit4]   2>   "params.type":"NRT"}, {
   [junit4]   2>   "class":"org.apache.solr.client.solrj.request.CollectionAdminRequest$AddReplica",
   [junit4]   2>   "method":"GET",
   [junit4]   2>   "params.action":"ADDREPLICA",
   [junit4]   2>   "params.collection":"collection1",
   [junit4]   2>   "params.shard":"shard1",
   [junit4]   2>   "params.node":"127.0.0.1:10001_solr",
   [junit4]   2>   "params.type":"NRT"}, {
   [junit4]   2>   "class":"org.apache.solr.client.solrj.request.CollectionAdminRequest$AddReplica",
   [junit4]   2>   "method":"GET",
   [junit4]   2>   "params.action":"ADDREPLICA",
   [junit4]   2>   "params.collection":"collection1",
   [junit4]   2>   "params.shard":"shard1",
   [junit4]   2>   "params.node":"127.0.0.1:10001_solr",
   [junit4]   2>   "params.type":"NRT"}], AFTER_ACTION=[start, compute], BEFORE_ACTION=[start, compute, execute]}
   [junit4]   2> 315230 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction Executing operation: action=ADDREPLICA&collection=collection1&shard=shard1&node=127.0.0.1:10000_solr&type=NRT
   [junit4]   2> 315233 INFO  (simCloudManagerPool-768-thread-22) [    ] o.a.s.c.a.c.AddReplicaCmd Node Identified 127.0.0.1:10000_solr for creating new replica of shard shard1
   [junit4]   2> 315236 INFO  (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.SolrTestCaseJ4 ###Starting testEventFromRestoredState
   [junit4]   2> 315236 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 6
   [junit4]   2> 315236 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 6
   [junit4]   2> 315237 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeLost markers
   [junit4]   2> 315237 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 315237 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 6, lastZnodeVersion 6
   [junit4]   2> 315245 DEBUG (simCloudManagerPool-768-thread-22) [    ] o.a.s.c.a.s.SimClusterStateProvider -- already has leader collection1 / shard1
   [junit4]   2> 315246 INFO  (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.s.SimCloudManager === Restarting OverseerTriggerThread and clearing object cache...
   [junit4]   2> 315246 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Shutting down scheduled thread pool executor now
   [junit4]   2> 315246 WARN  (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread woken up but we are closed, exiting.
   [junit4]   2> 315246 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Shutting down action executor now
   [junit4]   2> 315246 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Awaiting termination for action executor
   [junit4]   2> 315252 ERROR (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ExecutePlanAction Unexpected Exception while querying status of requestId=search_rate_trigger/27c1e0adb8430Td055tdz7fniekgz6ts75eexty/0
   [junit4]   2> java.io.IOException: java.lang.InterruptedException
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.sim.SimCloudManager.request(SimCloudManager.java:632) ~[test/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.waitForTaskToFinish(ExecutePlanAction.java:132) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.process(ExecutePlanAction.java:85) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:308) ~[java/:?]
   [junit4]   2> 	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) ~[?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266) ~[?:1.8.0_172]
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:209) ~[java/:?]
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) [?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) [?:1.8.0_172]
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748) [?:1.8.0_172]
   [junit4]   2> Caused by: java.lang.InterruptedException
   [junit4]   2> 	at java.util.concurrent.FutureTask.awaitDone(FutureTask.java:404) ~[?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.FutureTask.get(FutureTask.java:191) ~[?:1.8.0_172]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.sim.SimCloudManager.request(SimCloudManager.java:630) ~[test/:?]
   [junit4]   2> 	... 9 more
   [junit4]   2> 315277 DEBUG (simCloudManagerPool-768-thread-25) [    ] o.a.s.c.a.s.SimClusterStateProvider -- submit leader election for .system / shard1
   [junit4]   2> 315278 DEBUG (simCloudManagerPool-768-thread-26) [    ] o.a.s.c.a.s.SimClusterStateProvider Running leader election for .system / shard1
   [junit4]   2> 315279 DEBUG (simCloudManagerPool-768-thread-26) [    ] o.a.s.c.a.s.SimClusterStateProvider -- elected new leader for .system / shard1: core_node2
   [junit4]   2> 315280 WARN  (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Exception executing actions
   [junit4]   2> org.apache.solr.cloud.autoscaling.TriggerActionException: Error processing action for trigger event: {
   [junit4]   2>   "id":"27c1e0adb8430Td055tdz7fniekgz6ts75eexty",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699418426442800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "__start__":3,
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":100.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699429018647800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}}
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:311) ~[java/:?]
   [junit4]   2> 	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) ~[?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266) ~[?:1.8.0_172]
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:209) ~[java/:?]
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) [?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) [?:1.8.0_172]
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748) [?:1.8.0_172]
   [junit4]   2> Caused by: org.apache.solr.common.SolrException: Unexpected exception while processing event: {
   [junit4]   2>   "id":"27c1e0adb8430Td055tdz7fniekgz6ts75eexty",
   [junit4]   2>   "source":"search_rate_trigger",
   [junit4]   2>   "eventTime":699418426442800,
   [junit4]   2>   "eventType":"SEARCHRATE",
   [junit4]   2>   "properties":{
   [junit4]   2>     "hotReplicas":[
   [junit4]   2>       {"core_node1":{
   [junit4]   2>           "core":"collection1_shard1_replica_n1",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10001_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}},
   [junit4]   2>       {"core_node2":{
   [junit4]   2>           "core":"collection1_shard1_replica_n2",
   [junit4]   2>           "shard":"shard1",
   [junit4]   2>           "collection":"collection1",
   [junit4]   2>           "node_name":"127.0.0.1:10000_solr",
   [junit4]   2>           "type":"NRT",
   [junit4]   2>           "leader":"true",
   [junit4]   2>           "SEARCHER.searcher.maxDoc":0,
   [junit4]   2>           "SEARCHER.searcher.deletedDocs":0,
   [junit4]   2>           "INDEX.sizeInBytes":10240,
   [junit4]   2>           "rate":250.0,
   [junit4]   2>           "state":"active",
   [junit4]   2>           "QUERY./select.requestTimes:1minRate":250,
   [junit4]   2>           "INDEX.sizeInGB":9.5367431640625E-6,
   [junit4]   2>           "SEARCHER.searcher.numDocs":0}}],
   [junit4]   2>     "__start__":3,
   [junit4]   2>     "coldNodes":{},
   [junit4]   2>     "coldShards":{},
   [junit4]   2>     "coldReplicas":[],
   [junit4]   2>     "violationType":["hotShards"],
   [junit4]   2>     "coldCollections":{},
   [junit4]   2>     "hotShards":{"collection1":{"shard1":100.0}},
   [junit4]   2>     "hotCollections":{"collection1":500.0},
   [junit4]   2>     "hotNodes":{
   [junit4]   2>       "127.0.0.1:10001_solr":250.0,
   [junit4]   2>       "127.0.0.1:10000_solr":250.0},
   [junit4]   2>     "_enqueue_time_":699429018647800,
   [junit4]   2>     "requestedOps":[
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}},
   [junit4]   2>       {
   [junit4]   2>         "action":"ADDREPLICA",
   [junit4]   2>         "hints":{"COLL_SHARD":[{
   [junit4]   2>               "first":"collection1",
   [junit4]   2>               "second":"shard1"}]}}]}}
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.process(ExecutePlanAction.java:120) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:308) ~[java/:?]
   [junit4]   2> 	... 6 more
   [junit4]   2> Caused by: org.apache.solr.common.SolrException: Unexpected exception executing operation: action=ADDREPLICA&async=search_rate_trigger/27c1e0adb8430Td055tdz7fniekgz6ts75eexty/0&waitForFinalState=true&collection=collection1&shard=shard1&node=127.0.0.1:10000_solr&type=NRT
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.process(ExecutePlanAction.java:110) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:308) ~[java/:?]
   [junit4]   2> 	... 6 more
   [junit4]   2> Caused by: java.io.IOException: java.lang.InterruptedException
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.sim.SimCloudManager.request(SimCloudManager.java:632) ~[test/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.waitForTaskToFinish(ExecutePlanAction.java:132) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.process(ExecutePlanAction.java:85) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:308) ~[java/:?]
   [junit4]   2> 	... 6 more
   [junit4]   2> Caused by: java.lang.InterruptedException
   [junit4]   2> 	at java.util.concurrent.FutureTask.awaitDone(FutureTask.java:404) ~[?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.FutureTask.get(FutureTask.java:191) ~[?:1.8.0_172]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.sim.SimCloudManager.request(SimCloudManager.java:630) ~[test/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.waitForTaskToFinish(ExecutePlanAction.java:132) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ExecutePlanAction.process(ExecutePlanAction.java:85) ~[java/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:308) ~[java/:?]
   [junit4]   2> 	... 6 more
   [junit4]   2> 315281 DEBUG (AutoscalingActionExecutor-770-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing took 2855 ms for event id=27c1e0adb8430Td055tdz7fniekgz6ts75eexty
   [junit4]   2> 315282 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers Awaiting termination for scheduled thread pool executor
   [junit4]   2> 315282 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.ScheduledTriggers ScheduledTriggers closed completely
   [junit4]   2> 315282 DEBUG (TEST-TestSimTriggerIntegration.testEventFromRestoredState-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread has been closed explicitly
   [junit4]   2> 315285 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Adding .auto_add_replicas and .scheduled_maintenance triggers
   [junit4]   2> 315285 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 7
   [junit4]   2> 315286 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 7, lastZnodeVersion -1
   [junit4]   2> 315286 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 7
   [junit4]   2> 315286 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.NodeLostTrigger NodeLostTrigger .auto_add_replicas - Initial livenodes: [127.0.0.1:10001_solr, 127.0.0.1:10000_solr]
   [junit4]   2> 315287 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 315287 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 7, lastZnodeVersion 7
   [junit4]   2> 315287 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315308 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315330 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315351 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315372 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315383 DEBUG (simCloudManagerPool-771-thread-1) [    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 315383 DEBUG (simCloudManagerPool-771-thread-1) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 8
   [junit4]   2> 315384 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 8
   [junit4]   2> 315384 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread -- clean old nodeAdded markers
   [junit4]   2> 315384 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 8, lastZnodeVersion 8
   [junit4]   2> 315392 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 2
   [junit4]   2> 315401 DEBUG (simCloudManagerPool-771-thread-2) [    ] o.a.s.c.a.AutoScalingHandler Verified autoscaling configuration
   [junit4]   2> 315401 DEBUG (simCloudManagerPool-771-thread-2) [    ] o.a.s.c.a.OverseerTriggerThread Refreshing /autoscaling.json with znode version 9
   [junit4]   2> 315402 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Processed trigger updates upto znodeVersion 9
   [junit4]   2> 315402 INFO  (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.s.TestSimTriggerIntegration TestTriggerAction init
   [junit4]   2> 315402 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger - Initial livenodes: [127.0.0.1:10001_solr, 127.0.0.1:10000_solr]
   [junit4]   2> 315402 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger instantiated with properties: {event=nodeAdded, waitFor=10, actions=[{name=test, class=org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration$TestTriggerAction}], enabled=true}
   [junit4]   2> 315402 DEBUG (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Current znodeVersion 9, lastZnodeVersion 9
   [junit4]   2> 315403 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315403 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 2
   [junit4]   2> 315413 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315425 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315425 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315425 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Tracking new node: 127.0.0.1:10002_solr at time 699439409992800
   [junit4]   2> 315433 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315446 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315446 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315454 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315467 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315467 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315475 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315487 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315487 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315495 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315507 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315507 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315516 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315528 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315528 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315536 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315548 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315548 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315557 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315568 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315568 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315578 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315589 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315589 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315598 DEBUG (ScheduledTrigger-772-thread-3) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315610 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315610 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315618 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLostTrigger: .auto_add_replicas with currently live nodes: 3
   [junit4]   2> 315630 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315630 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger Found livenodes: 3
   [junit4]   2> 315630 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger firing registered processor for nodes: [127.0.0.1:10002_solr] added at times [699439409992800], now=699449660337800
   [junit4]   2> 315630 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.ScheduledTriggers ++++++++ Cooldown inactive - processing event: {
   [junit4]   2>   "id":"27c22ed931460Td055tdz7fniekgz6ts75eexu1",
   [junit4]   2>   "source":"node_added_trigger",
   [junit4]   2>   "eventTime":699439409992800,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[699439409992800],
   [junit4]   2>     "preferredOperation":"movereplica",
   [junit4]   2>     "nodeNames":["127.0.0.1:10002_solr"]}}
   [junit4]   2> 315632 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.ScheduledTriggers Pausing all triggers: [.auto_add_replicas, node_added_trigger]
   [junit4]   2> 315633 DEBUG (AutoscalingActionExecutor-773-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"27c22ed931460Td055tdz7fniekgz6ts75eexu1",
   [junit4]   2>   "source":"node_added_trigger",
   [junit4]   2>   "eventTime":699439409992800,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[699439409992800],
   [junit4]   2>     "preferredOperation":"movereplica",
   [junit4]   2>     "_enqueue_time_":699449713332800,
   [junit4]   2>     "nodeNames":["127.0.0.1:10002_solr"]}}
   [junit4]   2> 315633 DEBUG (ScheduledTrigger-772-thread-2) [    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger - removing marker path: /autoscaling/nodeAdded/127.0.0.1:10002_solr
   [junit4]   2> 315634 DEBUG (AutoscalingActionExecutor-773-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Resuming trigger: .auto_add_replicas after 100ms
   [junit4]   2> 315634 DEBUG (AutoscalingActionExecutor-773-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Resuming trigger: node_added_trigger after 100ms
   [junit4]   2> 315634 DEBUG (AutoscalingActionExecutor-773-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing took 71 ms for event id=27c22ed931460Td055tdz7fniekgz6ts75eexu1
   [junit4]   2> 315736 DEBUG (ScheduledTrigger-772-thread-4) [    ] o.a.s.c.a.NodeAddedTrigger Running NodeAddedTrigger node_added_trigger
   [junit4]   2> 315736 DEBUG (ScheduledTrigger-772-thread-1) [    ] o.a.s.c.a.NodeLostTrigger Running NodeLos

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

 [junit4]   2>   "source":"node_added_trigger",
   [junit4]   2>   "eventTime":706054421660300,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[706054421660300],
   [junit4]   2>     "preferredOperation":"movereplica",
   [junit4]   2>     "nodeNames":["127.0.0.1:10015_solr"]}}
   [junit4]   2> 16309 DEBUG (ScheduledTrigger-47-thread-4) [    ] o.a.s.c.a.ScheduledTriggers Pausing all triggers: [.auto_add_replicas, node_added_trigger]
   [junit4]   2> 16310 DEBUG (ScheduledTrigger-47-thread-4) [    ] o.a.s.c.a.NodeAddedTrigger NodeAddedTrigger node_added_trigger - removing marker path: /autoscaling/nodeAdded/127.0.0.1:10015_solr
   [junit4]   2> 16310 DEBUG (AutoscalingActionExecutor-48-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing actions for {
   [junit4]   2>   "id":"282271afec28cTd055tdz7fniekgz6ts75eexng",
   [junit4]   2>   "source":"node_added_trigger",
   [junit4]   2>   "eventTime":706054421660300,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[706054421660300],
   [junit4]   2>     "preferredOperation":"movereplica",
   [junit4]   2>     "_enqueue_time_":706055440780300,
   [junit4]   2>     "nodeNames":["127.0.0.1:10015_solr"]}}
   [junit4]   2> 16311 WARN  (AutoscalingActionExecutor-48-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Exception executing actions
   [junit4]   2> org.apache.solr.cloud.autoscaling.TriggerActionException: Error processing action for trigger event: {
   [junit4]   2>   "id":"282271afec28cTd055tdz7fniekgz6ts75eexng",
   [junit4]   2>   "source":"node_added_trigger",
   [junit4]   2>   "eventTime":706054421660300,
   [junit4]   2>   "eventType":"NODEADDED",
   [junit4]   2>   "properties":{
   [junit4]   2>     "eventTimes":[706054421660300],
   [junit4]   2>     "preferredOperation":"movereplica",
   [junit4]   2>     "_enqueue_time_":706055440780300,
   [junit4]   2>     "nodeNames":["127.0.0.1:10015_solr"]}}
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:311) ~[java/:?]
   [junit4]   2> 	at java.util.concurrent.Executors$RunnableAdapter.call(Executors.java:511) ~[?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.FutureTask.run(FutureTask.java:266) ~[?:1.8.0_172]
   [junit4]   2> 	at org.apache.solr.common.util.ExecutorUtil$MDCAwareThreadPoolExecutor.lambda$execute$0(ExecutorUtil.java:209) ~[java/:?]
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor.runWorker(ThreadPoolExecutor.java:1149) [?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.ThreadPoolExecutor$Worker.run(ThreadPoolExecutor.java:624) [?:1.8.0_172]
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748) [?:1.8.0_172]
   [junit4]   2> Caused by: java.lang.RuntimeException: failure
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration$TestDummyAction.process(TestSimTriggerIntegration.java:937) ~[test/:?]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.ScheduledTriggers.lambda$null$3(ScheduledTriggers.java:308) ~[java/:?]
   [junit4]   2> 	... 6 more
   [junit4]   2> 16311 DEBUG (AutoscalingActionExecutor-48-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Resuming trigger: .auto_add_replicas after 100ms
   [junit4]   2> 16311 DEBUG (AutoscalingActionExecutor-48-thread-1) [    ] o.a.s.c.a.ScheduledTriggers Resuming trigger: node_added_trigger after 100ms
   [junit4]   2> 16311 DEBUG (AutoscalingActionExecutor-48-thread-1) [    ] o.a.s.c.a.ScheduledTriggers -- processing took 66 ms for event id=282271afec28cTd055tdz7fniekgz6ts75eexng
   [junit4]   2> 16351 INFO  (TEST-TestSimTriggerIntegration.testListeners-seed#[7FA427DF5A59F17B]) [    ] o.a.s.SolrTestCaseJ4 ###Ending testListeners
   [junit4]   2> 16351 INFO  (TEST-TestSimTriggerIntegration.testListeners-seed#[7FA427DF5A59F17B]) [    ] o.a.s.c.a.s.SimSolrCloudTestCase #######################################
   [junit4]   2> ############ CLUSTER STATE ############
   [junit4]   2> #######################################
   [junit4]   2> ## Live nodes:		4
   [junit4]   2> ## Empty nodes:	3
   [junit4]   2> ## Dead nodes:		0
   [junit4]   2> ## Collections:	[.system]
   [junit4]   2> ## Max replicas per node:	1
   [junit4]   2> ## Min replicas per node:	0
   [junit4]   2> ## Total replicas:		1
   [junit4]   2> ## * .system		1
   [junit4]   2> ##		- active           1
   [junit4]   2> ######### Solr op counts ##########
   [junit4]   2> ##		- autoscaling        4
   [junit4]   2> ##		- update             4
   [junit4]   2> ######### Autoscaling event counts ###########
   [junit4]   2> ## * Trigger: node_added_trigger
   [junit4]   2> ##		- FAILED          1
   [junit4]   2> ##		- STARTED         2
   [junit4]   2> ##		- SUCCEEDED       1
   [junit4]   2> 
   [junit4] OK      0.34s J0 | TestSimTriggerIntegration.testListeners
   [junit4]   2> 16353 WARN  (Simulated OverseerAutoScalingTriggerThread) [    ] o.a.s.c.a.OverseerTriggerThread Interrupted
   [junit4]   2> java.lang.InterruptedException: null
   [junit4]   2> 	at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.reportInterruptAfterWait(AbstractQueuedSynchronizer.java:2014) ~[?:1.8.0_172]
   [junit4]   2> 	at java.util.concurrent.locks.AbstractQueuedSynchronizer$ConditionObject.await(AbstractQueuedSynchronizer.java:2048) ~[?:1.8.0_172]
   [junit4]   2> 	at org.apache.solr.cloud.autoscaling.OverseerTriggerThread.run(OverseerTriggerThread.java:189) [java/:?]
   [junit4]   2> 	at java.lang.Thread.run(Thread.java:748) [?:1.8.0_172]
   [junit4]   2> 16353 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.ScheduledTriggers Shutting down scheduled thread pool executor now
   [junit4]   2> 16353 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.ScheduledTriggers Shutting down action executor now
   [junit4]   2> 16353 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.ScheduledTriggers Awaiting termination for action executor
   [junit4]   2> 16353 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.ScheduledTriggers Awaiting termination for scheduled thread pool executor
   [junit4]   2> 16353 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.ScheduledTriggers ScheduledTriggers closed completely
   [junit4]   2> 16353 DEBUG (SUITE-TestSimTriggerIntegration-seed#[7FA427DF5A59F17B]-worker) [    ] o.a.s.c.a.OverseerTriggerThread OverseerTriggerThread has been closed explicitly
   [junit4]   2> NOTE: leaving temporary files on disk at: C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\solr\build\solr-core\test\J0\temp\solr.cloud.autoscaling.sim.TestSimTriggerIntegration_7FA427DF5A59F17B-001
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene80): {}, docValues:{}, maxPointsInLeafNode=444, maxMBSortInHeap=7.92025437522433, sim=Asserting(org.apache.lucene.search.similarities.AssertingSimilarity@37bc06), locale=de-LU, timezone=Asia/Hebron
   [junit4]   2> NOTE: Windows 10 10.0 x86/Oracle Corporation 1.8.0_172 (32-bit)/cpus=3,threads=1,free=47479896,total=65011712
   [junit4]   2> NOTE: All tests run in this JVM: [TestSimTriggerIntegration]
   [junit4] Completed [2/5 (1!)] on J0 in 15.07s, 11 tests, 1 failure <<< FAILURES!

[...truncated 53 lines...]
BUILD FAILED
C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\common-build.xml:1567: The following error occurred while executing this line:
C:\Users\jenkins\workspace\Lucene-Solr-master-Windows\lucene\common-build.xml:1092: There were test failures: 5 suites, 55 tests, 1 failure [seed: 7FA427DF5A59F17B]

Total time: 26 seconds

[repro] Setting last failure code to 1

[repro] Failures:
[repro]   1/5 failed: org.apache.solr.cloud.autoscaling.sim.TestSimTriggerIntegration
[repro] Exiting with code 1

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST lucene\build move /y lucene\build lucene\build.repro 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST solr\build move /y solr\build solr\build.repro 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST lucene\build.orig move /y lucene\build.orig lucene\build 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>IF EXIST solr\build.orig move /y solr\build.orig solr\build 
        1 dir(s) moved.

C:\Users\jenkins\workspace\Lucene-Solr-master-Windows>exit 0 
Archiving artifacts
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
[WARNINGS] Parsing warnings in console log with parser Java Compiler (javac)
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
<Git Blamer> Using GitBlamer to create author and commit information for all warnings.
<Git Blamer> GIT_COMMIT=e6e3dc7ea8c626f0f4a1173f899a9d7bb1af26d1, workspace=C:\Users\jenkins\workspace\Lucene-Solr-master-Windows
[WARNINGS] Computing warning deltas based on reference build #7531
Recording test results
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Build step 'Publish JUnit test result report' changed build result to UNSTABLE
Email was triggered for: Unstable (Test Failures)
Sending email for trigger: Unstable (Test Failures)
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2
Setting ANT_1_8_2_HOME=C:\Users\jenkins\tools\hudson.tasks.Ant_AntInstallation\ANT_1.8.2