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 2019/05/16 18:43:52 UTC

[JENKINS] Lucene-Solr-master-Linux (64bit/jdk-11) - Build # 24091 - Still Failing!

Build: https://jenkins.thetaphi.de/job/Lucene-Solr-master-Linux/24091/
Java: 64bit/jdk-11 -XX:+UseCompressedOops -XX:+UseParallelGC

All tests passed

Build Log:
[...truncated 62079 lines...]
-ecj-javadoc-lint-src:
    [mkdir] Created dir: /tmp/ecj311801445
 [ecj-lint] Compiling 1273 source files to /tmp/ecj311801445
 [ecj-lint] Processing annotations
 [ecj-lint] Annotations processed
 [ecj-lint] Processing annotations
 [ecj-lint] No elements to process
 [ecj-lint] invalid Class-Path header in manifest of jar file: /home/jenkins/.ivy2/cache/org.restlet.jee/org.restlet/jars/org.restlet-2.3.0.jar
 [ecj-lint] invalid Class-Path header in manifest of jar file: /home/jenkins/.ivy2/cache/org.restlet.jee/org.restlet.ext.servlet/jars/org.restlet.ext.servlet-2.3.0.jar
 [ecj-lint] ----------
 [ecj-lint] 1. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/client/solrj/embedded/EmbeddedSolrServer.java (at line 219)
 [ecj-lint] 	return (NamedList<Object>) new JavaBinCodec(resolver).unmarshal(in);
 [ecj-lint] 	                           ^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: '<unassigned Closeable value>' is never closed
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 2. ERROR in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/cloud/autoscaling/AutoScalingHandler.java (at line 74)
 [ecj-lint] 	import static org.apache.solr.common.util.Utils.fromJSON;
 [ecj-lint] 	              ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] The import org.apache.solr.common.util.Utils.fromJSON is never used
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 3. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/cloud/autoscaling/sim/SimCloudManager.java (at line 788)
 [ecj-lint] 	throw new UnsupportedOperationException("must add at least 1 node first");
 [ecj-lint] 	^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: 'queryRequest' is not closed at this location
 [ecj-lint] ----------
 [ecj-lint] 4. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/cloud/autoscaling/sim/SimCloudManager.java (at line 794)
 [ecj-lint] 	throw new UnsupportedOperationException("must add at least 1 node first");
 [ecj-lint] 	^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: 'queryRequest' is not closed at this location
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 5. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/handler/admin/SegmentsInfoRequestHandler.java (at line 215)
 [ecj-lint] 	leafReader = ((FilterLeafReader)leafReader).getDelegate();
 [ecj-lint] 	^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: 'leafReader' is not closed at this location
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 6. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/handler/component/HttpShardHandler.java (at line 142)
 [ecj-lint] 	return new JavaBinCodec(null, stringCache).setReadStringAsCharSeq(true);
 [ecj-lint] 	       ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: '<unassigned Closeable value>' is never closed
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 7. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/handler/loader/JavabinLoader.java (at line 137)
 [ecj-lint] 	new JavaBinCodec() {
 [ecj-lint]       SolrParams params;
 [ecj-lint]       AddUpdateCommand addCmd = null;
 [ecj-lint] 
 [ecj-lint]       @Override
 [ecj-lint]       public List<Object> readIterator(DataInputInputStream fis) throws IOException {
 [ecj-lint]         while (true) {
 [ecj-lint]           Object o = readVal(fis);
 [ecj-lint]           if (o == END_OBJ) break;
 [ecj-lint]           if (o instanceof NamedList) {
 [ecj-lint]             params = ((NamedList) o).toSolrParams();
 [ecj-lint]           } else {
 [ecj-lint]             try {
 [ecj-lint]               if (o instanceof byte[]) {
 [ecj-lint]                 if (params != null) req.setParams(params);
 [ecj-lint]                 byte[] buf = (byte[]) o;
 [ecj-lint]                 contentStreamLoader.load(req, rsp, new ContentStreamBase.ByteArrayStream(buf, null), processor);
 [ecj-lint]               } else {
 [ecj-lint]                 throw new RuntimeException("unsupported type ");
 [ecj-lint]               }
 [ecj-lint]             } catch (Exception e) {
 [ecj-lint]               throw new RuntimeException(e);
 [ecj-lint]             } finally {
 [ecj-lint]               params = null;
 [ecj-lint]               req.setParams(old);
 [ecj-lint]             }
 [ecj-lint]           }
 [ecj-lint]         }
 [ecj-lint]         return Collections.emptyList();
 [ecj-lint]       }
 [ecj-lint] 
 [ecj-lint]     }.unmarshal(in);
 [ecj-lint] 	^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: '<unassigned Closeable value>' is never closed
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 8. INFO in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/logging/log4j2/Log4j2Watcher.java (at line 187)
 [ecj-lint] 	if (logger == root || root.equals(logger) || isRootLogger(name) || "".equals(name)) {
 [ecj-lint] 	                                  ^^^^^^
 [ecj-lint] Unlikely argument type for equals(): Map.Entry<String,LoggerConfig> seems to be unrelated to Logger
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 9. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/update/SolrIndexSplitter.java (at line 258)
 [ecj-lint] 	HardlinkCopyDirectoryWrapper hardLinkedDir = new HardlinkCopyDirectoryWrapper(splitDir);
 [ecj-lint] 	                             ^^^^^^^^^^^^^
 [ecj-lint] Resource leak: 'hardLinkedDir' is never closed
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 10. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/util/FileUtils.java (at line 50)
 [ecj-lint] 	in = new FileInputStream(src).getChannel();
 [ecj-lint] 	     ^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: '<unassigned Closeable value>' is never closed
 [ecj-lint] ----------
 [ecj-lint] 11. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/util/FileUtils.java (at line 51)
 [ecj-lint] 	out = new FileOutputStream(destination).getChannel();
 [ecj-lint] 	      ^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: '<unassigned Closeable value>' is never closed
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 12. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/util/SolrCLI.java (at line 1143)
 [ecj-lint] 	SnapshotCloudManager snapshotCloudManager = new SnapshotCloudManager(simCloudManager, config);
 [ecj-lint] 	                     ^^^^^^^^^^^^^^^^^^^^
 [ecj-lint] Resource leak: 'snapshotCloudManager' is never closed
 [ecj-lint] ----------
 [ecj-lint] ----------
 [ecj-lint] 13. WARNING in /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/core/src/java/org/apache/solr/util/TestInjection.java (at line 263)
 [ecj-lint] 	timers.remove(this);
 [ecj-lint] 	              ^^^^
 [ecj-lint] Unlikely argument type new TimerTask(){} for remove(Object) on a Collection<Timer>
 [ecj-lint] ----------
 [ecj-lint] 13 problems (1 error, 11 warnings, 1 info)

BUILD FAILED
/home/jenkins/workspace/Lucene-Solr-master-Linux/build.xml:634: The following error occurred while executing this line:
/home/jenkins/workspace/Lucene-Solr-master-Linux/build.xml:101: The following error occurred while executing this line:
/home/jenkins/workspace/Lucene-Solr-master-Linux/solr/build.xml:681: The following error occurred while executing this line:
/home/jenkins/workspace/Lucene-Solr-master-Linux/lucene/common-build.xml:2010: The following error occurred while executing this line:
/home/jenkins/workspace/Lucene-Solr-master-Linux/lucene/common-build.xml:2049: Compile failed; see the compiler error output for details.

Total time: 72 minutes 47 seconds
Build step 'Invoke Ant' marked build as failure
Archiving artifacts
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
[WARNINGS] Skipping publisher since build result is FAILURE
Recording test results
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
Email was triggered for: Failure - Any
Sending email for trigger: Failure - Any
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2
Setting ANT_1_8_2_HOME=/home/jenkins/tools/hudson.tasks.Ant_AntInstallation/ANT_1.8.2

[JENKINS-EA] Lucene-Solr-master-Linux (64bit/jdk-13-ea+shipilev-fastdebug) - Build # 24092 - Unstable!

Posted by Policeman Jenkins Server <je...@thetaphi.de>.
Build: https://jenkins.thetaphi.de/job/Lucene-Solr-master-Linux/24092/
Java: 64bit/jdk-13-ea+shipilev-fastdebug -XX:+UseCompressedOops -XX:+UseSerialGC

1 tests failed.
FAILED:  org.apache.solr.metrics.rrd.SolrRrdBackendFactoryTest.testBasic

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

Stack Trace:
java.lang.AssertionError: {} expected:<1> but was:<0>
	at __randomizedtesting.SeedInfo.seed([78D5F5126CA24AEA:D32FE807B37ECCC4]:0)
	at org.junit.Assert.fail(Assert.java:88)
	at org.junit.Assert.failNotEquals(Assert.java:834)
	at org.junit.Assert.assertEquals(Assert.java:645)
	at org.apache.solr.metrics.rrd.SolrRrdBackendFactoryTest.testBasic(SolrRrdBackendFactoryTest.java:94)
	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
	at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
	at java.base/java.lang.reflect.Method.invoke(Method.java:567)
	at com.carrotsearch.randomizedtesting.RandomizedRunner.invoke(RandomizedRunner.java:1750)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$8.evaluate(RandomizedRunner.java:938)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$9.evaluate(RandomizedRunner.java:974)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$10.evaluate(RandomizedRunner.java:988)
	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:947)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$5.evaluate(RandomizedRunner.java:832)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$6.evaluate(RandomizedRunner.java:883)
	at com.carrotsearch.randomizedtesting.RandomizedRunner$7.evaluate(RandomizedRunner.java:894)
	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 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.base/java.lang.Thread.run(Thread.java:830)




Build Log:
[...truncated 14747 lines...]
   [junit4] Suite: org.apache.solr.metrics.rrd.SolrRrdBackendFactoryTest
   [junit4]   2> Creating dataDir: /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/build/solr-core/test/J0/temp/solr.metrics.rrd.SolrRrdBackendFactoryTest_78D5F5126CA24AEA-001/init-core-data-001
   [junit4]   2> 2720770 DEBUG (TEST-SolrRrdBackendFactoryTest.testBasic-seed#[78D5F5126CA24AEA]) [    ] o.a.s.m.r.SolrRrdBackendFactory Created 1589553328
   [junit4]   2> 2720791 DEBUG (SolrRrdBackendFactory-12456-thread-1) [    ] o.a.s.m.r.SolrRrdBackendFactory -- maybe sync backends: [foo]
   [junit4]   2> 2720930 DEBUG (SolrRrdBackendFactory-12456-thread-1) [    ] o.a.s.m.r.SolrRrdBackendFactory -- syncing [foo]
   [junit4]   2> 2721058 DEBUG (TEST-SolrRrdBackendFactoryTest.testBasic-seed#[78D5F5126CA24AEA]) [    ] o.a.s.m.r.SolrRrdBackendFactory Closing 1589553328
   [junit4]   2> NOTE: reproduce with: ant test  -Dtestcase=SolrRrdBackendFactoryTest -Dtests.method=testBasic -Dtests.seed=78D5F5126CA24AEA -Dtests.multiplier=3 -Dtests.slow=true -Dtests.locale=os -Dtests.timezone=Atlantic/St_Helena -Dtests.asserts=true -Dtests.file.encoding=US-ASCII
   [junit4] FAILURE 0.35s J0 | SolrRrdBackendFactoryTest.testBasic <<<
   [junit4]    > Throwable #1: java.lang.AssertionError: {} expected:<1> but was:<0>
   [junit4]    > 	at __randomizedtesting.SeedInfo.seed([78D5F5126CA24AEA:D32FE807B37ECCC4]:0)
   [junit4]    > 	at org.apache.solr.metrics.rrd.SolrRrdBackendFactoryTest.testBasic(SolrRrdBackendFactoryTest.java:94)
   [junit4]    > 	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke0(Native Method)
   [junit4]    > 	at java.base/jdk.internal.reflect.NativeMethodAccessorImpl.invoke(NativeMethodAccessorImpl.java:62)
   [junit4]    > 	at java.base/jdk.internal.reflect.DelegatingMethodAccessorImpl.invoke(DelegatingMethodAccessorImpl.java:43)
   [junit4]    > 	at java.base/java.lang.reflect.Method.invoke(Method.java:567)
   [junit4]    > 	at java.base/java.lang.Thread.run(Thread.java:830)
   [junit4]   2> NOTE: leaving temporary files on disk at: /home/jenkins/workspace/Lucene-Solr-master-Linux/solr/build/solr-core/test/J0/temp/solr.metrics.rrd.SolrRrdBackendFactoryTest_78D5F5126CA24AEA-001
   [junit4]   2> NOTE: test params are: codec=Asserting(Lucene80): {}, docValues:{}, maxPointsInLeafNode=1751, maxMBSortInHeap=6.054774295008707, sim=Asserting(org.apache.lucene.search.similarities.AssertingSimilarity@47dd70f1), locale=os, timezone=Atlantic/St_Helena
   [junit4]   2> NOTE: Linux 4.18.0-17-generic amd64/Aleksey Shipilev 13-testing (64-bit)/cpus=8,threads=1,free=396434160,total=518979584
   [junit4]   2> NOTE: All tests run in this JVM: [RulesTest, HdfsAutoAddReplicasIntegrationTest, HdfsBasicDistributedZkTest, TestFuzzyAnalyzedSuggestions, StatelessScriptUpdateProcessorFactoryTest, TestLegacyFieldReuse, ManagedSchemaRoundRobinCloudTest, OverseerCollectionConfigSetProcessorTest, ResourceLoaderTest, TestHdfsCloudBackupRestore, SyncSliceTest, TestCollectionAPIs, TestRandomCollapseQParserPlugin, TestFieldResource, ClassificationUpdateProcessorFactoryTest, BlockCacheTest, TestStressLiveNodes, AtomicUpdateRemovalJavabinTest, TestSha256AuthenticationProvider, CursorPagingTest, TestFieldCacheWithThreads, HdfsTlogReplayBufferedWhileIndexingTest, SolrCloudExampleTest, MetricsHandlerTest, CdcrBidirectionalTest, TestCSVResponseWriter, TestLeaderElectionZkExpiry, HighlighterMaxOffsetTest, TestSchemalessBufferedUpdates, TestSolrCoreSnapshots, SpatialRPTFieldTypeTest, TestRestManager, TestDocSet, SolrCloudReportersTest, AdminHandlersProxyTest, TestSolrCloudWithSecureImpersonation, TestChildDocTransformerHierarchy, TestValueSourceCache, TestLFUCache, FullHLLTest, SecurityConfHandlerTest, TestNumericTerms64, TestSimExtremeIndexing, TestDistributedStatsComponentCardinality, SpellingQueryConverterTest, ResponseBuilderTest, LoggingHandlerTest, TestWriterPerf, DirectSolrSpellCheckerTest, DirectUpdateHandlerTest, ReindexCollectionTest, TestCollationField, TestXIncludeConfig, TestSolrDeletionPolicy2, TestWordDelimiterFilterFactory, LeaderElectionContextKeyTest, TestCloudConsistency, ConfigureRecoveryStrategyTest, ZkStateWriterTest, TestDynamicFieldCollectionResource, SolrCoreTest, TestInitParams, TestSolrFieldCacheBean, MultiSolrCloudTestCaseTest, BJQParserTest, TestRebalanceLeaders, DistanceUnitsTest, UnloadDistributedZkTest, CreateCollectionCleanupTest, TestRealTimeGet, DistributedExpandComponentTest, MetricTriggerIntegrationTest, TestPayloadCheckQParserPlugin, ScriptEngineTest, TestCodecSupport, TestSolr4Spatial, SchemaApiFailureTest, SuggesterWFSTTest, TestDistributedMissingSort, TestObjectReleaseTracker, ReplicaListTransformerTest, StressHdfsTest, TriggerSetPropertiesIntegrationTest, TestTolerantUpdateProcessorRandomCloud, AsyncCallRequestStatusResponseTest, TriggerCooldownIntegrationTest, TestHdfsBackupRestoreCore, TestInPlaceUpdatesDistrib, NodeMarkersRegistrationTest, LeaderVoteWaitTimeoutTest, JSONWriterTest, TestLMJelinekMercerSimilarityFactory, CustomTermsComponentTest, TestMultiWordSynonyms, PeerSyncWithLeaderAndIndexFingerprintCachingTest, TestConfigSetImmutable, SuggesterFSTTest, TestRequestStatusCollectionAPI, TestSubQueryTransformerDistrib, TestMaxScoreQueryParser, V2StandaloneTest, PathHierarchyTokenizerFactoryTest, UniqFieldsUpdateProcessorFactoryTest, AnalysisAfterCoreReloadTest, TestUnifiedSolrHighlighter, ForceLeaderWithTlogReplicasTest, TestExceedMaxTermLength, TestCloudJSONFacetJoinDomain, DistributedVersionInfoTest, AddReplicaTest, CollectionPropsTest, PreAnalyzedUpdateProcessorTest, Tagger2Test, TestManagedSchema, OverseerStatusTest, BadCopyFieldTest, TestBlendedInfixSuggestions, DeleteLastCustomShardedReplicaTest, TestSimpleTextCodec, ConcurrentCreateRoutedAliasTest, TestClusterProperties, QueryResultKeyTest, TestComplexPhraseQParserPlugin, DocExpirationUpdateProcessorFactoryTest, TestSchemaNameResource, TestDFRSimilarityFactory, TestPivotHelperCode, TestBulkSchemaConcurrent, TestManagedStopFilterFactory, TestUtils, VersionInfoTest, TestNestedDocsSort, IgnoreLargeDocumentProcessorFactoryTest, MultiDestinationAuditLoggerTest, MoveReplicaHDFSFailoverTest, WrapperMergePolicyFactoryTest, TestDeprecatedFilters, TestPerFieldSimilarity, BasicDistributedZk2Test, JavabinLoaderTest, SortByFunctionTest, MetricsHistoryWithAuthIntegrationTest, DistributedIntervalFacetingTest, TestGroupingSearch, TestRandomDVFaceting, TestSolrCoreProperties, TestTolerantSearch, TestTrie, TestLuceneIndexBackCompat, TestEmbeddedSolrServerAdminHandler, TestEmbeddedSolrServerConstructors, TestEmbeddedSolrServerSchemaAPI, TestJettySolrRunner, ConnectionReuseTest, ActionThrottleTest, ChaosMonkeyNothingIsSafeTest, ChaosMonkeySafeLeaderTest, ClusterStateTest, CollectionsAPISolrJTest, HttpPartitionWithTlogReplicasTest, NestedShardedAtomicUpdateTest, RecoveryZkTest, ReplaceNodeNoTargetTest, ReplaceNodeTest, RestartWhileUpdatingTest, RollingRestartTest, RoutingToNodesWithPropertiesTest, SharedFSAutoReplicaFailoverTest, SolrCLIZkUtilsTest, TestCloudInspectUtil, TestCloudPhrasesIdentificationComponent, TestCloudRecovery, TestCloudSearcherWarming, TestPrepRecovery, TestSSLRandomization, TestSegmentSorting, TestSolrCloudWithKerberosAlt, TestWithCollection, CustomCollectionTest, SimpleCollectionCreateDeleteTest, TestCollectionAPI, TestReplicaProperties, ComputePlanActionTest, ScheduledMaintenanceTriggerTest, SystemLogListenerTest, TestSnapshotCloudManager, CdcrWithNodesRestartsTest, HDFSCollectionsAPITest, HdfsRecoveryZkTest, HdfsRestartWhileUpdatingTest, HdfsSyncSliceTest, RuleEngineTest, CachingDirectoryFactoryTest, TestCoreDiscovery, TestDirectoryFactory, TestDynamicLoading, TestCSVLoader, TestConfigReload, TestReplicationHandlerDiskOverFlow, TestSQLHandlerNonCloud, TestSolrConfigHandlerConcurrent, TestSystemCollAutoCreate, CoreAdminHandlerTest, CoreAdminOperationTest, CoreMergeIndexesAdminHandlerTest, DaemonStreamApiTest, PropertiesRequestHandlerTest, ShowFileRequestHandlerTest, StatsReloadRaceTest, DistributedFacetPivotSmallAdvancedTest, DistributedFacetPivotWhiteBoxTest, DistributedQueryComponentOptimizationTest, DistributedSuggestComponentTest, PhrasesIdentificationComponentTest, SearchHandlerTest, SuggestComponentTest, TermVectorComponentTest, RandomizedTaggerTest, XmlInterpolationTest, FastVectorHighlighterTest, HighlighterConfigTest, TestLegacyField, TestNumericTokenStream, TestLogWatcher, SolrCoreMetricManagerTest, SolrRrdBackendFactoryTest]
   [junit4] Completed [661/857 (1!)] on J0 in 1.80s, 1 test, 1 failure <<< FAILURES!

[...truncated 43898 lines...]
[repro] Jenkins log URL: https://jenkins.thetaphi.de/job/Lucene-Solr-master-Linux/24092/consoleText

[repro] Revision: 9d7c1923e4b30dc1f04a56986628944c0a2b6a6e

[repro] Ant options: "-Dargs=-XX:+UseCompressedOops -XX:+UseSerialGC"
[repro] Repro line:  ant test  -Dtestcase=SolrRrdBackendFactoryTest -Dtests.method=testBasic -Dtests.seed=78D5F5126CA24AEA -Dtests.multiplier=3 -Dtests.slow=true -Dtests.locale=os -Dtests.timezone=Atlantic/St_Helena -Dtests.asserts=true -Dtests.file.encoding=US-ASCII

[repro] ant clean

[...truncated 6 lines...]
[repro] Test suites by module:
[repro]    solr/core
[repro]       SolrRrdBackendFactoryTest
[repro] ant compile-test

[...truncated 3309 lines...]
[repro] ant test-nocompile -Dtests.dups=5 -Dtests.maxfailures=5 -Dtests.class="*.SolrRrdBackendFactoryTest" -Dtests.showOutput=onerror "-Dargs=-XX:+UseCompressedOops -XX:+UseSerialGC" -Dtests.seed=78D5F5126CA24AEA -Dtests.multiplier=3 -Dtests.slow=true -Dtests.locale=os -Dtests.timezone=Atlantic/St_Helena -Dtests.asserts=true -Dtests.file.encoding=US-ASCII

[...truncated 75 lines...]
[repro] Failures:
[repro]   0/5 failed: org.apache.solr.metrics.rrd.SolrRrdBackendFactoryTest
[repro] Exiting with code 0

[...truncated 43 lines...]