You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@lucene.apache.org by Erick Erickson <er...@gmail.com> on 2018/06/05 16:18:30 UTC

Badapple report, rehabilitating annotated tests. Please read the intro and comment.

---------- First

One thing that's been vexing me is that the "noise reduction" is A
Good Thing, but how do we rehabilitate annotated tests?

Here's the result of my most recent changes to the reporter. The
change is that I have candidates to un-annotate.

Here's the theory:

> I roll up all of Hoss' reports so I have lists by week (roughly) of test methods and suites that failed.

> I have lists of all methods and suites that are annotated in the source code.

> If an annotated test or suite has NOT failed in the last 4 weeks, it's a candidate to un-annotate. I chose 4 weeks arbitrarily, it's simple to change to more or less.

Below is a new report. If people could take a quick look at the first
section, up to the line "********Failures in Hoss' reports" and sanity
check whether these tests seem reasonable to un-annotate I'd
appreciate it. Next time I BadApple stuff, I'll also un-badApple all
these unless there are objections.

Besides, seeing things come _off_ the annotations list is encouraging.

---------- Second

What do people think about the recency report? (the section that
starts with "********Failures in Hoss' reports"). Is it useful? Is the
order most useful?

----------Third

How big should the window be? Since there are 64 bits I could use in a
long, it's simple to keep this going for that long. Also a waste of
electrons and makes for massive e-mails.

I propose that the report confine itself to 4 weeks. I'll keep the
history in case anyone wants to do a longer analysis. I don't seen any
point in looking at tests that failed N weeks ago as a regular thing,
We all have committed code that breaks tests and fixed them, so
letting that kind of information  accumulate forever in  reports seems
pretty useless.

For instance, way at the end are a bunch of tests that  failed 9 weeks
ago and haven't failed since. I can't imagine that's useful
information to see every week.

----------Fourth

The report contains all the annotated tests and suites, mostly because
I have to collect it anyway and it's easy. I put it at the end of the
report because I think it's the least useful and it's easier to ignore
there. Any reason to remove it?

----------Fifth

All this is sitting here on my personal laptop and I think it's
getting to the point where it's increasingly useful. I'd be glad to
put it up on GitHub if anyone's interested. For that matter it could
go into the tools, but unless we also put Hoss' reports there it'd be
an orphan.

I do wonder if it's something we could automate though. That would require:

1> downloading and saving Hoss's reports every week (I try to do it Monday)
2> Having access to the source tree
3> pressing the "go" button
4> mailing the results to the dev list.

Let me know.

**********************************************************
Here's the latest report.

Processing file (History bit 0):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-03-26.csv
Processing file (History bit 1):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-02.csv
Processing file (History bit 2):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-09.csv
Processing file (History bit 3):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-16.csv
Processing file (History bit 4):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-25.csv
Processing file (History bit 5):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-30.csv
Processing file (History bit 6):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-05-14.csv
Processing file (History bit 7):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-05-21.csv
Processing file (History bit 8):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-05-29.csv
Processing file (History bit 9):
/Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-06-05.csv


**********Annotations that didn't fail in the last 4 weeks.

******Methods: 48
   AutoAddReplicasIntegrationTest.testSimple
   ChaosMonkeySafeLeaderWithPullReplicasTest.test
   ComputePlanActionTest.testSelectedCollections
   DocValuesNotIndexedTest.testGroupingDVOnly
   DocValuesNotIndexedTest.testGroupingDocAbsent
   DocValuesNotIndexedTest.testGroupingSorting
   ForceLeaderTest.testReplicasInLIRNoLeader
   HdfsDirectoryTest.testEOF
   LIRRollingUpdatesTest.testNewLeaderAndMixedReplicas
   LIRRollingUpdatesTest.testNewLeaderOldReplica
   LIRRollingUpdatesTest.testOldLeaderAndMixedReplicas
   LeaderElectionIntegrationTest.testSimpleSliceLeaderElection
   MathExpressionTest.testDistributions
   MathExpressionTest.testGammaDistribution
   MathExpressionTest.testMultiVariateNormalDistribution
   MissingSegmentRecoveryTest.testLeaderRecovery
   MoveReplicaHDFSTest.testNormalFailedMove
   MoveReplicaHDFSTest.testNormalMove
   MoveReplicaTest.testFailedMove
   ReplaceNodeNoTargetTest.test
   ScheduledTriggerTest.testTrigger
   ShardSplitTest.test
   SharedFSAutoReplicaFailoverTest.test
   SolrCloudExampleTest.testLoadDocsIntoGettingStartedCollection
   TestCloudSchemaless.test
   TestCollapseQParserPlugin.testStringCollapse
   TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateWithoutCoresThenDelete
   TestControlledRealTimeReopenThread.testCRTReopen
   TestDynamicLoading.testDynamicLoading
   TestICUNormalizer2CharFilter.testRandomStrings
   TestImpersonationWithHadoopAuth.testForwarding
   TestLTRReRankingPipeline.testDifferentTopN
   TestMinMaxOnMultiValuedField.testDoubleFieldCache
   TestMinMaxOnMultiValuedField.testFloatFieldCache
   TestMinMaxOnMultiValuedField.testIntFieldCache
   TestMinMaxOnMultiValuedField.testLongFieldCache
   TestMoreLikeThis.testMultiFieldShouldReturnPerFieldBooleanQuery
   TestPullReplica.testAddDocs
   TestReplicationHandler.doTestIndexAndConfigAliasReplication
   TestSegmentSorting.testAtomicUpdateOfSegmentSortField
   TestSegmentSorting.testSegmentTerminateEarly
   TestStressCloudBlindAtomicUpdates.test_dv_stored
   TestStressInPlaceUpdates.stressTest
   TestV2Request.testCloudSolrClient
   TestV2Request.testHttpSolrClient
   UIMABaseAnalyzerTest.testRandomStrings
   UIMABaseAnalyzerTest.testRandomStringsWithConfigurationParameters
   UIMATypeAwareAnalyzerTest.testRandomStrings

******Suites: 6
   ConcurrentCreateRoutedAliasTest
   HdfsTlogReplayBufferedWhileIndexingTest
   ReplaceNodeNoTargetTest
   ReplicationFactorTest
   ScheduledTriggerIntegrationTest
   TestICUTokenizerCJK


********Failures in Hoss' reports

1669 tests failed in Hoss' rollups. Ordered by week of failure, newest->oldest
each asterisk in 'History' means the test failed in that week
These tests were NOT BadApple'd or AwaitsFix'd

         Failures by Weeks ago    Pct    runs   fails      test
                    06-05   03-26
                    |        |
                    0123456789    2.1     3816     80      BlockCacheTest(suite)
                    0123456789    2.4     3825     90
BlockDirectoryTest(suite)
                    0123456789    3.6     3303    120
CheckHdfsIndexTest(suite)
                    0123456789    0.3     3633     11
CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
                    0123456789    0.3     3633     11
CreateRoutedAliasTest.testTimezoneAbsoluteDate
                    0123456789    0.4     3633     13
CreateRoutedAliasTest.testV1
                    0123456789    0.3     3633     12
CreateRoutedAliasTest.testV2
                    0123456789   35.0      157     55
HdfsBasicDistributedZkTest(suite)
                    0123456789   47.1      191     90
HdfsCollectionsAPIDistributedZkTest(suite)
                    0123456789    2.9     3289     97
HdfsNNFailoverTest(suite)
                    0123456789   51.5      194    100
HdfsSyncSliceTest(suite)
                    0123456789   43.4      175     76
HdfsWriteToMultipleCollectionsTest(suite)
                    0123456789    5.9      674     40
MoveReplicaHDFSTest.testFailedMove
                    0123456789    3.0     3283     97
TestRecoveryHdfs(suite)
                    0123456789    0.8     3867     30
TestReplicationHandler(suite)
                    0123456789   11.4     4352    497
TestReplicationHandler.doTestStressReplication
                    0123456789    4.2     4109    174
TestTimeSource.testEpochTime
                    0123456 89    7.9      506     40
TestLargeCluster.testBasic
                    0123456       1.7     4025     67
IndexSizeTriggerTest.testMixedBounds
                    012345 78     1.1     3235     34
BasicDistributedZkTest.test
                    012345 78     1.4     3436     49
TestTriggerIntegration.testTriggerThrottling
                    012345        4.5     2708    122
SearchRateTriggerTest.testTrigger
                    012345       16.5       91     15
TestDocTermOrdsUninvertLimit.testTriggerUnInvertLimit
                    01234  7 9   13.1      434     57
TestLargeCluster.testNodeLost
                    0123 5678     0.9     3457     32
TestTriggerIntegration.testNodeAddedTrigger
                    0123 5        0.4     2250      9
CollectionsAPISolrJTest.testCreateWithDefaultConfigSet
                    0123  67 9    0.9     2907     25
TestCollectionStateWatchers.testPredicateFailureTimesOut
                    0123  67 9    0.9     2905     26
TestCollectionStateWatchers.testSimpleCollectionWatch
                    0123  67 9    1.0     2902     30
TestCollectionStateWatchers.testWaitForStateWatcherIsRetainedOnPredicateFailure
                    0123  67      0.5     1840      9
TestSolrCloudWithHadoopAuthPlugin(suite)
                    0123   789    0.6     2931     17
TestCollectionStateWatchers.testWatchesWorkForStateFormat1
                    0123   7 9    0.6     2582     16
TestCollectionStateWatchers.testWatcherIsRemovedAfterTimeout
                    0123          1.2     1808     21
MaxSizeAutoCommitTest(suite)
                    0123          2.5     1908     47
MaxSizeAutoCommitTest.deleteTest
                    0123          7.2      180     13
MaxSizeAutoCommitTest.endToEndTest
                    0123          8.4      155     13
TestGenericDistributedQueue.testDistributedQueue
                    0123          2.1     1533     32
TestRandomChains.testRandomChains
                    0123          2.9     1533     45
TestRandomChains.testRandomChainsWithLargeStrings
                    012 456  9    0.7     1830     13
TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
                    012  5 7 9    0.5     2489     12
BasicDistributedZkTest(suite)
                    012  5        0.3     1838      5
TestSkipOverseerOperations.testSkipDownOperations
                    012  5        0.3     1838      6
TestSkipOverseerOperations.testSkipLeaderOperations
                    012   67 9    0.8     2501     21
TestCollectionStateWatchers.testCanWaitForNonexistantCollection
                    012   67 9    0.6     2497     16
TestCollectionStateWatchers.testStateWatcherChecksCurrentStateOnRegister
                    012     8     0.5     1787      9      ShardSplitTest(suite)
                    012           0.2     1506      3
TestTriggerIntegration(suite)
                    01 3456       3.8      213      8
HttpPartitionTest(suite)
                    01 34   89    3.2     2285     73
TestStressCloudBlindAtomicUpdates(suite)
                    01 34   8     0.7     1749     13
MoveReplicaHDFSTest.test
                    01 34         0.4     1430      6
HdfsDirectoryTest.testRandomAccessWrites
                    01 34         0.7     1425     10
HdfsRecoverLeaseTest(suite)
                    01 3  678     0.5     2349     11
RollingRestartTest.test
                    01 3          0.7     1330      9
CustomHighlightComponentTest(suite)
                    01 3          0.4     1372      6      JdbcTest(suite)
                    01 3          0.3     1325      4
StreamDecoratorTest.testExecutorStream
                    01   5 78     0.3     2144      6
TestComputePlanAction.testNodeLost
                    01   5 7     43.8       16      7
HdfsChaosMonkeyNothingIsSafeTest.test
                    01   5        1.7     1080     18
TransactionLogTest.testBigLastAddSize
                    01     7 9    0.4     1626      6
TestCloudRecovery.leaderRecoverFromLogOnStartupTest
                    01      89    0.6     1618     10
SolrExporterTest(suite)
                    01      8     0.5     1302      6
SolrCollectorTest(suite)
                    01      8     0.2     1355      3
TestIndexWriterWithThreads.testIOExceptionDuringAbortWithThreadsOnlyOnce
                    01       9    0.2     1269      3
TestTlogReplica.testBasicLeaderElection
                    01            2.4      251      6
CollectionsAPISolrJTest.testCreateCollWithDefaultClusterProperties
                    01            4.9      738     36
SearchHandlerTest.testRequireZkConnectedDistrib
                    01            0.3      959      3
SolrExporterTest.testExecute
                    01            0.4      953      4
SolrShardReporterTest(suite)
                    01            0.2      956      2
SolrShardReporterTest.test
                    01            0.2      955      2
TestDistributedGrouping.test
                    01            0.5      977      5
TestIndexFileDeleter.testExcInDecRef
                    01            0.2      952      2
TestStandardQParsers.testRegisteredName
                    0 23456 89   79.0       62     49
RestartWhileUpdatingTest(suite)
                    0 234 6789    4.1      704     29
TestTlogReplica.testRecovery
                    0 234 67      1.4     2255     31
SegmentsInfoRequestHandlerTest.testSegmentInfosVersion
                    0 23 5        0.3     1642      5
DeleteReplicaTest.deleteReplicaFromClusterState
                    0 23  6789    1.2     2613     32
FullSolrCloudDistribCmdsTest.test
                    0 23   789    0.8     2286     18
FullSolrCloudDistribCmdsTest(suite)
                    0 23   7 9    0.6     1963     11
LegacyFieldFacetExtrasCloudTest(suite)
                    0 23    8     0.4     1640      6
ShardSplitTest.testSplitStaticIndexReplication
                    0 2 456789    8.0      199     16
HdfsUnloadDistributedZkTest.test
                    0 2 4         0.5     1244      6      GraphTest(suite)
                    0 2  5  8     0.2     1640      4
TestPolicyCloud.testCreateCollectionAddShardWithReplicaTypeUsingPolicy
                    0 2  5   9    0.3     1588      5
TestCloudRecovery(suite)
                    0 2   6  9    0.4     1585      6
CloudSolrClientTest.testRetryUpdatesWhenClusterStateIsStale
                    0 2    789    1.1     1932     22
TestGeo3DPoint.testGeo3DRelations
                    0 2      9    0.3     1224      4
TestCloudPivotFacet.test
                    0 2      9    0.2     1217      3
TestTlogReplica.testDeleteById
                    0 2           0.2      928      2
StreamDecoratorTest.testParallelUpdateStream
                    0 2           0.6      903      5
TestRequestStatusCollectionAPI(suite)
                    0  34 6 89    1.9     1504     28
TriggerIntegrationTest.testEventQueue
                    0  34  7      0.3     1443      5
BasicDistributedZk2Test.test
                    0  34  7      0.8     1189      9
StreamDecoratorTest(suite)
                    0  34   8     0.7     1220      8
MoveReplicaHDFSFailoverTest(suite)
                    0  34         0.7      937      7
HDFSCollectionsAPITest(suite)
                    0  34         0.5      926      5
HdfsThreadLeakTest(suite)
                    0  34         0.3     1093      3      ShardRoutingTest.test
                    0  34         0.4      930      4
TestHdfsBackupRestoreCore(suite)
                    0  3  6789    2.9     1299     38
ChaosMonkeyNothingIsSafeTest(suite)
                    0  3    8     0.7      953      7
HdfsLockFactoryTest(suite)
                    0  3     9    0.3     1104      3
CollectionsAPIDistributedZkTest.testCollectionReload
                    0  3     9    0.8      929      7
HdfsDirectoryFactoryTest(suite)
                    0  3     9    0.3     1105      3
TestTlogReplica.testAddRemoveTlogReplica
                    0  3          0.3      786      2
CleanupOldIndexTest(suite)
                    0  3          0.3      789      2
CleanupOldIndexTest.test
                    0  3          0.3      795      2
CollectionsAPIDistributedZkTest.testMissingRequiredParameters
                    0  3          0.4      693      3
HdfsDirectoryTest.testWritingAndReadingAFile
                    0   45  8     0.9     1498     13
TestSearcherManager(suite)
                    0   45  8     0.6     1500      9
TestSearcherManager.testConcurrentIndexCloseSearchAndRefresh
                    0   4 6       0.8      899      7
CheckHdfsIndexTest.testChecksumsOnlyVerbose
                    0   4   8     6.9     1186     82
TestComputePlanAction.testNodeAdded
                    0   4    9    0.8      898      7
CheckHdfsIndexTest.doTest
                    0   4    9    0.6      898      5
CheckHdfsIndexTest.testDeletedDocs
                    0   4    9    0.8     1064      9
TestBKD.testWastedLeadingBytes
                    0   4         0.6      627      4
CheckHdfsIndexTest.testChecksumsOnly
                    0   4         0.3      723      2
LeaderFailureAfterFreshStartTest.test
                    0   4         0.3      723      2
PingRequestHandlerTest.testPingInClusterWithNoHealthCheck
                    0    5 7      0.4     1122      5
QueryEqualityTest(suite)
                    0    5        0.4      797      3
TestDeleteCollectionOnDownNodes.deleteCollectionWithDownNodes
                    0     6 8     0.3     1098      3
CloudSolrClientTest.checkCollectionParameters
                    0     6       0.5      610      3
TestPKIAuthenticationPlugin.test
                    0      789    0.6     1395      8      RecoveryZkTest(suite)
                    0      78     1.2     1093     13
CdcrBidirectionalTest.testBiDir
                    0      7 9    0.4     1065      4      RecoveryZkTest.test
                    0      7 9    0.3     1077      3
TestTlogReplica.testAddDocs
                    0      7      0.5      747      4
OutputWriterTest(suite)
                    0      7      0.3      752      2
SolrCoreTest.testRequestHandlerRegistry
                    0      7      0.4      494      2
TestLeaderElectionZkExpiry.testLeaderElectionWithZkExpiry
                    0       8     0.3      745      2
StatsReloadRaceTest.testParallelReloadAndStats
                    0       8    18.7      182     34
TestLargeCluster.testAddNode
                    0        9    0.7      405      3
AutoscalingHistoryHandlerTest(suite)
                    0        9    0.4      752      3
CloudSolrClientTest.preferLocalShardsTest
                    0        9    0.3      752      2
CloudSolrClientTest.testAliasHandling
                    0        9    0.3      752      2
CloudSolrClientTest.testOverwriteOption
                    0        9    0.3      718      2
TestStressLiveNodes.testStress
                    0        9   28.6       14      4
TestTlogReplica.testCreateDelete
                    0        9    0.3      720      2
TestTlogReplica.testKillLeader
                    0        9    0.3      720      2
TestTlogReplica.testKillTlogReplica
                    0        9    0.3      720      2
TestTlogReplica.testOutOfOrderDBQWithInPlaceUpdates
                    0        9    0.3      720      2
TestTlogReplica.testRealTimeGet
                    0             0.5      406      2
BlockJoinFacetDistribTest(suite)
                    0             0.2      423      1
CloudSolrClientTest.customHttpClientTest
                    0             0.2      423      1
CloudSolrClientTest.preferReplicaTypesTest
                    0             0.2      423      1
CloudSolrClientTest.stateVersionParamTest
                    0             0.2      423      1
CloudSolrClientTest.testInitializationWithSolrUrls
                    0             0.2      423      1
CloudSolrClientTest.testNonRetryableRequests
                    0             0.2      423      1
CloudSolrClientTest.testParallelUpdateQTime
                    0             0.2      423      1
CloudSolrClientTest.testRouting
                    0             0.2      423      1
CloudSolrClientTest.testWrongZkChrootTest
                    0             0.2      407      1
CollectionTooManyReplicasTest.testAddShard
                    0             0.2      407      1
CollectionTooManyReplicasTest.testAddTooManyReplicas
                    0             0.2      409      1
ComputePlanActionTest.testNodeAdded
                    0             1.0      407      4
ConfigSetsAPITest(suite)
                    0             0.2      424      1
ConfusionMatrixGeneratorTest.testGetConfusionMatrixWithSNB
                    0             0.2      413      1
DistribJoinFromCollectionTest.testScore
                    0             0.2      410      1
DistributedQueueTest.testPeekElements
                    0             0.2      410      1
ExecutePlanActionTest.testExecute
                    0             0.2      410      1
ExecutePlanActionTest.testIntegration
                    0             0.5      404      2
LeaderElectionTest(suite)
                    0             0.2      404      1
LeaderElectionTest.testStressElection
                    0             0.3      367      1
MetricsHistoryHandlerTest.testBasic
                    0             0.2      410      1
NodeLostTriggerTest.testTrigger
                    0             0.5      404      2
RemoteQueryErrorTest(suite)
                    0            11.6      439     51
ResourceLoaderTest.testAwareCompatibility
                    0             1.0      408      4
ScheduledTriggerTest(suite)
                    0             2.4      379      9
SolrRrdBackendFactoryTest.testBasic
                    0             0.4      230      1
StreamExpressionTest.testBasicTextLogitStream
                    0             0.2      416      1
TestBackwardsCompatibility.testUnsupportedOldIndexes
                    0             0.2      406      1
TestBulkSchemaConcurrent.test
                    0             2.9      413     12
TestCloudJSONFacetSKG(suite)
                    0             0.2      415      1
TestCloudJSONFacetSKG.testBespoke
                    0             0.7      415      3
TestCloudJSONFacetSKG.testRandom
                    0             0.2      406      1
TestConfigSetsAPI.testDelete
                    0             0.3      390      1
TestDelegationWithHadoopAuth.testDelegationTokenRenew
                    0             0.5      413      2
TestDeleteCollectionOnDownNodes(suite)
                    0             0.2      412      1
TestDistributedStatsComponentCardinality.test
                    0             0.2      407      1
TestExclusionRuleCollectionAccess.doTest
                    0             2.6      423     11
TestExecutePlanAction.testExecute
                    0             0.2      431      1
TestIndexWriterWithThreads.testIOExceptionDuringWriteSegmentWithThreads
                    0             0.2      408      1
TestLocalFSCloudBackupRestore(suite)
                    0             0.2      419      1
TestLucene70DocValuesFormat.testSortedVariableLengthBigVsStoredFields
                    0             5.5       73      4
TestRecovery.testExistOldBufferLog
                    0             0.5      410      2
TestReplicaProperties(suite)
                    0             0.2      410      1
TestReplicaProperties.test
                    0             0.2      411      1
TestStressCloudBlindAtomicUpdates.test_dv_idx
                    0             0.2      406      1
TestTlogReplica.testOnlyLeaderIndexes
                    0             0.5      412      2      TestZkChroot(suite)
                    0             0.2      412      1
TestZkChroot.testInitPathExists
                    0             0.2      403      1
V2ApiIntegrationTest(suite)
                     123456789    4.8     2667    129      StressHdfsTest(suite)
                     1234567      9.0     3160    284
NodeAddedTriggerTest.testRestoreState
                     12345   9   70.4       27     19
CdcrReplicationDistributedZkTest.testBatchAddsWithDelete
                     12345   9   71.4       28     20
CdcrReplicationDistributedZkTest.testResilienceWithDeleteByQueryOnTarget
                     12345   9   71.4       28     20
CdcrReplicationDistributedZkTest.testUpdateLogSynchronisation
                     12345      100.0       20     20
CdcrReplicationDistributedZkTest.testBatchBoundaries
                     12345      100.0       19     19
CdcrReplicationDistributedZkTest.testBufferOnNonLeader
                     12345      100.0       19     19
CdcrReplicationDistributedZkTest.testOps
                     12345      100.0       20     20
CdcrReplicationDistributedZkTest.testReplicationAfterLeaderChange
                     12345      100.0       19     19
CdcrReplicationDistributedZkTest.testReplicationAfterRestart
                     12345      100.0       19     19
CdcrReplicationDistributedZkTest.testReplicationStartStop
                     12345        0.5     2194     10
TestLRUQueryCache.testBulkScorerLocking
                     1234    9    0.7     2071     15      RangeFacetTest(suite)
                     1234        10.0      200     20
RandomGeoPolygonTest.testCompareSmallPolygons
                     1234         1.1     1762     20
TestExtractionDateUtil.testParseDate
                     123 56  9    0.3     2426      7
TestSolrCloudWithDelegationTokens.testDelegationTokenRenew
                     123  6789    0.3     2742      9
CollectionsAPIDistributedZkTest.testCreateNodeSet
                     123  678     1.1     1817     20
SaslZkACLProviderTest(suite)
                     123  678     0.7     1824     13
SaslZkACLProviderTest.testSaslZkACLProvider
                     123     9    0.3     1505      4
MoveReplicaHDFSFailoverTest.testOldReplicaIsDeletedInRaceCondition
                     123          0.3     1590      4
SearchRateTriggerIntegrationTest.testAboveSearchRate
                     12 45 789    0.6     2714     15
TestSolrCLIRunExample(suite)
                     12 45 7      1.8     1769     31      TestSQLHandler(suite)
                     12 4         0.2     1403      3
TestLRUQueryCache(suite)
                     12  56  9    0.4     1353      6
TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeaderAfterRestart
                     12   6 89    6.5      108      7
LIROnShardRestartTest.testAllReplicasInLIR
                     12   6 89    0.9     2010     18
SystemLogListenerTest.test
                     12   6  9    0.5     1695      9
StreamExpressionTest(suite)
                     12    78     3.1      128      4
HdfsSyncSliceTest.test
                     12    7      0.4     1382      5
DirectSolrConnectionTest(suite)
                     12    7      0.2     1414      3
TestSolrEntityProcessorEndToEnd.testFullImportFqParam
                     12           0.4     1061      4      SchemaTest(suite)
                     12           0.2     1067      2
SchemaTest.addDynamicFieldShouldntBeCalledTwiceWithTheSameName
                     12           0.2     1067      2
SchemaTest.addFieldShouldntBeCalledTwiceWithTheSameName
                     12           0.2     1067      2
SchemaTest.addFieldTypeShouldntBeCalledTwiceWithTheSameName
                     12           0.2     1067      2
SchemaTest.addFieldTypeWithAnalyzerClassAccuracy
                     12           0.2     1067      2
SchemaTest.addFieldTypeWithSimilarityAccuracy
                     12           0.2     1067      2
SchemaTest.copyFieldsShouldFailWhenOneOfTheFieldsDoesntExistInTheSchema
                     12           0.2     1067      2
SchemaTest.deleteCopyFieldShouldFailWhenOneOfTheFieldsDoesntExistInTheSchema
                     12           0.2     1067      2
SchemaTest.deletingADynamicFieldThatDoesntExistInTheSchemaShouldFail
                     12           0.2     1067      2
SchemaTest.deletingAFieldThatDoesntExistInTheSchemaShouldFail
                     12           0.2     1067      2
SchemaTest.deletingAFieldTypeThatDoesntExistInTheSchemaShouldFail
                     12           0.2     1067      2
SchemaTest.testAddDynamicFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testAddFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testAddFieldTypeAccuracy
                     12           0.2     1067      2
SchemaTest.testCopyFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testCopyFieldWithMaxCharsAccuracy
                     12           0.2     1067      2
SchemaTest.testDeleteCopyFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testDeleteDynamicFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testDeleteFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testDeleteFieldTypeAccuracy
                     12           0.2     1067      2
SchemaTest.testGetCopyFieldsAccuracy
                     12           0.2     1067      2
SchemaTest.testGetDynamicFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testGetDynamicFieldsAccuracy
                     12           0.2     1067      2
SchemaTest.testGetFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testGetFieldTypeAccuracy
                     12           0.2     1067      2
SchemaTest.testGetFieldTypesAccuracy
                     12           0.2     1067      2
SchemaTest.testGetFieldsAccuracy
                     12           0.2     1067      2
SchemaTest.testGetGlobalSimilarityAccuracy
                     12           0.2     1067      2
SchemaTest.testGetUniqueKeyAccuracy
                     12           0.2     1067      2
SchemaTest.testMultipleUpdateRequestAccuracy
                     12           0.2     1067      2
SchemaTest.testReplaceDynamicFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testReplaceFieldAccuracy
                     12           0.2     1067      2
SchemaTest.testReplaceFieldTypeAccuracy
                     12           0.2     1067      2
SchemaTest.testSchemaNameRequestAccuracy
                     12           0.2     1067      2
SchemaTest.testSchemaRequestAccuracy
                     12           0.2     1067      2
SchemaTest.testSchemaVersionRequestAccuracy
                     12           0.2     1053      2
ShardSplitTest.testSplitShardWithRule
                     12           0.4     1049      4
TestPolicyCloud(suite)
                     1 34567      0.9     1648     15
TestHdfsUpdateLog(suite)
                     1 34    9    0.3     1555      5
TestSolrConfigHandlerCloud.test
                     1 3   7      0.2     1270      3
TestPullReplica.testRemoveAllWriterReplicas
                     1 3     9    0.7     1251      9
LegacyFieldFacetCloudTest(suite)
                     1 3          2.5       79      2
ChaosMonkeySafeLeaderTest(suite)
                     1 3          0.5      936      5
LegacyQueryFacetCloudTest(suite)
                     1 3          0.3      948      3
SolrZkClientTest(suite)
                     1 3          0.2      954      2
SolrZkClientTest.testSimpleUpdateACLs
                     1 3          0.2      938      2
TestStressCloudBlindAtomicUpdates.test_dv_stored_idx
                     1  45 7      0.4     1578      7
TestComputePlanAction(suite)
                     1  4         0.3      737      2
OverseerTest.testShardAssignment
                     1  4        11.1       27      3
TestDocTermOrdsUninvertLimit(suite)
                     1  4         0.2      870      2
TestLRUQueryCache.testLRUEviction
                     1   5 789    1.4     1345     19
TestReplicationHandler.doTestIndexFetchOnMasterRestart
                     1   5   9    0.2     1254      3
TestCloudRecovery.corruptedLogTest
                     1    678     0.4     1541      6
ZkFailoverTest.testRestartZkWhenClusterDown
                     1    67      0.5     1212      6      StreamingTest(suite)
                     1    6       0.2      865      2
TestDistribDocBasedVersion.test
                     1     789    3.5      115      4
TestInetAddressRangeQueries.testRandomBig
                     1     78     0.2     1267      3
TestIndexingSequenceNumbers.testStressConcurrentCommit
                     1     7      0.5      877      4
ConfigureRecoveryStrategyTest(suite)
                     1     7      0.3      891      3
DistribCursorPagingTest.test
                     1     7      0.5      885      4      EchoParamsTest(suite)
                     1     7      0.6      894      5      JDBCStreamTest(suite)
                     1     7      0.2      891      2
OverseerTaskQueueTest.testPeekElements
                     1     7      0.2      881      2
SolrJmxReporterTest(suite)
                     1     7      0.2      879      2
SolrSlf4jReporterTest.testReporter
                     1     7      0.6      346      2
StreamDecoratorTest.testClassifyStream
                     1      8     3.0       67      2
HdfsCollectionsAPIDistributedZkTest.addReplicaTest
                     1      8     0.2      924      2
TestIndexWriterWithThreads.testIOExceptionDuringAbortWithThreads
                     1      8     0.2      884      2
TestPullReplica.testKillPullReplica
                     1            0.2      550      1
AnalyzingInfixSuggesterTest.testRandomNRT
                     1            0.2      485      1
BlobRepositoryMockingTest(suite)
                     1            0.2      544      1
BufferStoreTest.testBufferTakePut
                     1            0.2      548      1
CdcrBootstrapTest.testConvertClusterToCdcrAndBootstrap
                     1            0.7      545      4
CloudExitableDirectoryReaderTest(suite)
                     1            0.2      550      1
CloudSolrClientBuilderTest.test0Timeouts
                     1            0.2      550      1
CloudSolrClientBuilderTest.testByDefaultConfiguresClientToSendUpdatesOnlyToShardLeaders
                     1            0.2      550      1
CloudSolrClientBuilderTest.testIsDirectUpdatesToLeadersOnlyDefault
                     1            0.2      550      1
CloudSolrClientBuilderTest.testSeveralZkHostsSpecifiedSingly
                     1            0.2      550      1
CloudSolrClientBuilderTest.testSeveralZkHostsSpecifiedTogether
                     1            0.2      550      1
CloudSolrClientBuilderTest.testSingleZkHostSpecified
                     1            0.2      480      1
CloudSolrClientCacheTest(suite)
                     1            0.2      484      1
CloudSolrClientCacheTest.testCaching
                     1            0.2      550      1
CloudSolrClientMultiConstructorTest.testBadChroot
                     1            0.2      550      1
CloudSolrClientMultiConstructorTest.testZkConnectionStringConstructorWithValidChroot
                     1            0.2      550      1
CloudSolrClientMultiConstructorTest.testZkConnectionStringSetterWithValidChroot
                     1            0.2      544      1
CollectionsAPISolrJTest.testAddAndDeleteReplica
                     1            0.2      551      1
ConcurrentUpdateSolrClientBuilderTest.testMissingQueueSize
                     1            0.5      550      3
ConcurrentUpdateSolrClientTest(suite)
                     1            0.2      554      1
ConcurrentUpdateSolrClientTest.testConcurrentUpdate
                     1            0.2      544      1
CustomCollectionTest.testRouteFieldForHashRouter
                     1            0.2      544      1
CustomCollectionTest.testRouteFieldForImplicitRouter
                     1            0.2      544      1
DateMathParserTest.testAdd
                     1            0.2      544      1
DateMathParserTest.testAddZero
                     1            0.2      544      1
DateMathParserTest.testCalendarUnitsConsistency
                     1            0.2      544      1
DateMathParserTest.testFormatter
                     1            0.2      544      1
DateMathParserTest.testParseLenient
                     1            0.2      544      1
DateMathParserTest.testRound
                     1            0.2      544      1
DateMathParserTest.testRoundTrip
                     1            0.4      544      2
DeleteReplicaTest(suite)
                     1            0.2      544      1
DeleteReplicaTest.deleteLiveReplicaTest
                     1            0.2      543      1
DirectoryFactoryTest(suite)
                     1            0.7      545      4
DistribCursorPagingTest(suite)
                     1            0.2      546      1
DistributedFacetExistsSmallTest.test
                     1            0.2      543      1
DistributedFacetPivotWhiteBoxTest.test
                     1            0.2      549      1
DistributedTermsComponentTest.test
                     1            0.4      546      2
ExtractingRequestHandlerTest.testArabicPDF
                     1            0.4      546      2
ExtractingRequestHandlerTest.testExtraction
                     1            0.7      548      4
ExtractingRequestHandlerTest.testLiteralsOverride
                     1            0.4      546      2
ExtractingRequestHandlerTest.testPasswordProtected
                     1            0.2      487      1
HadoopSSLCredentialProviderTest.testConstructorRequiresCredPath
                     1            0.2      487      1
HadoopSSLCredentialProviderTest.testGetCredentials
                     1            0.2      550      1
HttpClientUtilTest.testSSLSystemProperties
                     1            0.2      550      1
HttpClientUtilTest.testToBooleanDefaultIfNull
                     1            0.2      550      1
HttpClientUtilTest.testToBooleanObject
                     1            0.2      548      1
HttpSolrClientBuilderTest(suite)
                     1            0.6      545      3
HttpTriggerListenerTest(suite)
                     1            0.7      549      4
HttpTriggerListenerTest.testHttpListenerIntegration
                     1            0.2      544      1
IgnoreLargeDocumentProcessorFactoryTest.testProcessor
                     1            0.2      547      1
ImplicitSnitchTest.testExceptions
                     1            0.2      476      1
ImplicitSnitchTest.testGetTags_withAllHostNameRequestedTags_returns_all_Tags
                     1            0.2      547      1
ImplicitSnitchTest.testGetTags_withAllIPv4RequestedTags_returns_four_tags
                     1            0.2      547      1
ImplicitSnitchTest.testGetTags_withAllIPv4RequestedTags_with_omitted_zeros_returns_four_tags
                     1            0.2      547      1
ImplicitSnitchTest.testGetTags_withEmptyRequestedTag_returns_nothing
                     1            0.2      476      1
ImplicitSnitchTest.testGetTags_withHostNameRequestedTag_ip3_returns_1_tag
                     1            0.2      476      1
ImplicitSnitchTest.testGetTags_withHostNameRequestedTag_ip99999_returns_nothing
                     1            0.2      547      1
ImplicitSnitchTest.testGetTags_withIPv4RequestedTags_ip2_and_ip4_returns_two_tags
                     1            0.2      547      1
ImplicitSnitchTest.testGetTags_with_correct_ipv6_format_ip_returns_nothing
                     1            0.2      547      1
ImplicitSnitchTest.testGetTags_with_wrong_ipv4_format_ip_returns_nothing
                     1            0.2      547      1
ImplicitSnitchTest.testIsKnownTag_ip1
                     1            0.2      548      1
LBHttpSolrClientBuilderTest(suite)
                     1            0.2      551      1
LBHttpSolrClientTest.testLBHttpSolrClientHttpClientResponseParserStringArray
                     1            0.5      550      3
LargeVolumeEmbeddedTest(suite)
                     1            0.2      551      1
MergeIndexesEmbeddedTest(suite)
                     1            0.2      553      1
MergeIndexesEmbeddedTest.testMergeIndexesByCoreName
                     1            0.2      553      1
MergeIndexesEmbeddedTest.testMergeIndexesByDirName
                     1            0.2      553      1
MergeIndexesEmbeddedTest.testMergeMultipleRequest
                     1            0.2      550      1
NamedListTest.testRemoveArgs
                     1            0.2      550      1
NamedListTest.testShallowMap
                     1            0.2      548      1
PluginInfoTest.testClassRequired
                     1            0.2      548      1
PluginInfoTest.testNameRequired
                     1            0.2      551      1
QueryResponseTest.testGroupResponse
                     1            0.2      551      1
QueryResponseTest.testIntervalFacetsResponse
                     1            0.2      551      1
QueryResponseTest.testRangeFacets
                     1            0.2      551      1
QueryResponseTest.testSimpleGroupResponse
                     1            0.2      543      1
RAMDirectoryFactoryTest.test
                     1            2.1       48      1
ReplicationFactorTest.test
                     1            0.2      557      1
SSLConfigurationsTest.testGetClientKeyStorePasswordFromEnv
                     1            0.2      486      1
SSLConfigurationsTest.testGetClientKeyStorePasswordFromHadoopCredentialProvider
                     1            0.2      557      1
SSLConfigurationsTest.testGetClientKeyStorePasswordFromProperty
                     1            0.2      557      1
SSLConfigurationsTest.testGetClientTrustStorePasswordFromEnv
                     1            0.2      557      1
SSLConfigurationsTest.testGetClientTrustStorePasswordFromProperty
                     1            0.2      486      1
SSLConfigurationsTest.testGetClientTruststorePasswordFromHadoopCredentialProvider
                     1            0.2      557      1
SSLConfigurationsTest.testGetKeyStorePasswordFromEnv
                     1            0.2      486      1
SSLConfigurationsTest.testGetKeyStorePasswordFromHadoopCredentialProvider
                     1            0.2      557      1
SSLConfigurationsTest.testGetKeyStorePasswordFromProperty
                     1            0.2      557      1
SSLConfigurationsTest.testGetTrustStorePasswordFromEnv
                     1            0.2      557      1
SSLConfigurationsTest.testGetTrustStorePasswordFromProperty
                     1            0.2      486      1
SSLConfigurationsTest.testGetTruststorePasswordFromHadoopCredentialProvider
                     1            0.2      486      1
SSLConfigurationsTest.testHadoopCredentialProviderPrioritySysPropAndEnvVars
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigKeystorePwFromBothEnvVars
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigKeystorePwFromClientKeystoreEnvVar
                     1            0.2      486      1
SSLConfigurationsTest.testSslConfigKeystorePwFromClientKeystoreHadoopCredentialProvider
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigKeystorePwFromKeystoreEnvVar
                     1            0.2      486      1
SSLConfigurationsTest.testSslConfigKeystorePwFromKeystoreHadoopCredentialProvider
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigKeystorePwNotOverwrittenIfExists
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigTruststorePwFromBothEnvVars
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigTruststorePwFromClientKeystoreEnvVar
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigTruststorePwFromKeystoreEnvVar
                     1            0.2      557      1
SSLConfigurationsTest.testSslConfigTruststorePwNotOverwrittenIfExists
                     1            0.2      557      1
SSLConfigurationsTest.testSystemPropertyPriorityOverEnvVar
                     1            0.2      557      1
SSLCredentialProviderFactoryTest.testGetProvidersBySysprop
                     1            0.2      557      1
SSLCredentialProviderFactoryTest.testGetProvidersInvalidProvider
                     1            0.2      557      1
SSLCredentialProviderFactoryTest.testGetProvidersOrder
                     1            0.2      557      1
SSLCredentialProviderFactoryTest.testGetProvidersWithCustomProvider
                     1            0.2      487      1
SchemaWatcherTest.testDiscardReaderReference
                     1            0.2      487      1
SchemaWatcherTest.testProcess
                     1            0.4      271      1
ShardParamsTest.testGetShardsTolerantAsBool
                     1            0.2      554      1
SimpleNaiveBayesClassifierTest.testPerformance
                     1            0.2      486      1
SkipExistingDocumentsProcessorFactoryTest(suite)
                     1            0.5      550      3
SolrExampleEmbeddedTest(suite)
                     1            0.2      550      1
SolrExceptionTest.testSolrException
                     1            0.2      544      1
SolrMetricReporterTest.testInit
                     1            0.2      550      1
SolrParamTest.testGetParams
                     1            0.5      550      3
SolrSchemalessExampleTest(suite)
                     1            0.2      552      1
SolrZkClientTest.testCheckInterrupted
                     1            0.4      284      1
StreamExpressionTest.testFeaturesSelectionStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testCloudSolrStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testCloudSolrStreamWithEscapedQuote
                     1            0.2      549      1
StreamExpressionToExpessionTest.testComplementStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testDaemonStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testFacetStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testFeaturesSelectionStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testIntersectStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testJDBCStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testMergeStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testRankStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testReducerStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testSelectStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testStatsStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testTextLogitStreamWithFeaturesSelection
                     1            0.2      549      1
StreamExpressionToExpessionTest.testTopicStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testUniqueStream
                     1            0.2      549      1
StreamExpressionToExpessionTest.testUpdateStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testCloudSolrStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testComplementStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testDaemonStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testFacetStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testIntersectStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testJDBCStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testMergeStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testRankStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testReducerStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testSelectStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testStatsStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testTopicStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testUniqueStream
                     1            0.2      550      1
StreamExpressionToExplanationTest.testUpdateStream
                     1            0.2      545      1
SystemInfoHandlerTest.testMagickGetter
                     1            0.5      550      3
TermsResponseTest(suite)
                     1            0.2      548      1
TestCollectionAPIs.testCommands
                     1            0.2      549      1
TestCollectionAdminRequest.testInvalidAliasNameRejectedWhenCreatingAlias
                     1            0.2      549      1
TestCollectionAdminRequest.testInvalidCollectionNameRejectedWhenCreatingCollection
                     1            0.2      549      1
TestCollectionAdminRequest.testInvalidShardNameRejectedWhenCreatingShard
                     1            0.2      549      1
TestCollectionAdminRequest.testInvalidShardNamesRejectedWhenCallingSetShards
                     1            0.2      549      1
TestCollectionAdminRequest.testInvalidShardNamesRejectedWhenCreatingImplicitCollection
                     1            0.2      551      1
TestConcurrentMergeScheduler(suite)
                     1            0.2      552      1
TestConcurrentMergeScheduler.testLiveMaxMergeCount
                     1            0.2      547      1
TestConfigOverlay.testPaths
                     1            0.2      547      1
TestConfigOverlay.testSetProperty
                     1            0.2      549      1
TestDelegationTokenResponse.testGetResponse
                     1            0.2      549      1
TestDelegationTokenResponse.testRenewResponse
                     1            0.2      550      1
TestDocumentObjectBinder.testDynamicFieldBinding
                     1            0.2      550      1
TestDocumentObjectBinder.testSimple
                     1            0.2      559      1
TestFacetMethods.testBooleanDefaults
                     1            0.2      559      1
TestFacetMethods.testNumericMultiValuedDV
                     1            0.2      559      1
TestFacetMethods.testNumericMultiValuedNoDV
                     1            0.2      559      1
TestFacetMethods.testNumericSingleValuedDV
                     1            0.2      559      1
TestFacetMethods.testNumericSingleValuedNoDV
                     1            0.2      559      1
TestFacetMethods.testPointFields
                     1            0.2      559      1
TestFacetMethods.testTextMultiValuedDV
                     1            0.2      559      1
TestFacetMethods.testTextMultiValuedNoDV
                     1            0.2      559      1
TestFacetMethods.testTextSingleValuedDV
                     1            0.2      559      1
TestFacetMethods.testTextSingleValuedNoDV
                     1            0.2      550      1
TestFastInputStream.testgzip
                     1            0.2      550      1
TestFastLRUCache.testFullAutowarm
                     1            0.2      550      1
TestFastLRUCache.testNoAutowarm
                     1            0.2      550      1
TestFastLRUCache.testOldestItems
                     1            0.2      550      1
TestFastLRUCache.testPercentageAutowarm
                     1            0.2      550      1
TestFastLRUCache.testPercentageAutowarmMultiple
                     1            0.2      550      1
TestFastLRUCache.testRandom
                     1            0.2      550      1
TestFastLRUCache.testSimple
                     1            1.1      558      6
TestIndexWriter.testFullyDeletedSegmentsReleaseFiles
                     1            0.2      550      1
TestIndexWriterReader.testDuringAddDelete
                     1            0.2      547      1
TestInetAddressRangeQueries(suite)
                     1            0.2      550      1
TestJsonRecordReader(suite)
                     1            0.2      553      1
TestJsonRecordReader.testAIOOBE
                     1            0.2      553      1
TestJsonRecordReader.testArrayOfRootObjects
                     1            0.2      553      1
TestJsonRecordReader.testClearPreviousRecordFields
                     1            0.2      553      1
TestJsonRecordReader.testNestedDocs
                     1            0.2      553      1
TestJsonRecordReader.testNestedJsonWithFloats
                     1            0.2      553      1
TestJsonRecordReader.testOneLevelSplit
                     1            0.2      553      1
TestJsonRecordReader.testRecursiveWildCard
                     1            0.2      553      1
TestJsonRecordReader.testRecursiveWildcard2
                     1            0.2      553      1
TestJsonRecordReader.testSrcField
                     1            0.2      541      1
TestLRUCache.testFullAutowarm
                     1            0.2      541      1
TestLRUCache.testMaxRamSize
                     1            0.2      541      1
TestLRUCache.testNoAutowarm
                     1            0.2      541      1
TestLRUCache.testNonAccountableValues
                     1            0.2      541      1
TestLRUCache.testPercentageAutowarm
                     1            0.2      551      1
TestLRUQueryCache.testOnUseWithRandomFirstSegmentSkipping
                     1            0.2      450      1
TestLRUQueryCache.testRamBytesUsedAgreesWithRamUsageTester
                     1            0.2      547      1
TestLTRScoringQuery(suite)
                     1            0.2      548      1
TestMinMaxNormalizer.testInvalidMinMaxMissingMax
                     1            0.2      548      1
TestMinMaxNormalizer.testInvalidMinMaxMissingMin
                     1            0.2      548      1
TestMinMaxNormalizer.testInvalidMinMaxNoParams
                     1            0.2      548      1
TestMinMaxNormalizer.testMinMaxNormalizerMinEqualToMax
                     1            0.2      548      1
TestMinMaxNormalizer.testMinMaxNormalizerMinLargerThanMax
                     1            0.2      548      1
TestMinMaxNormalizer.testNormalizer
                     1            0.2      548      1
TestMinMaxNormalizer.testParamsToMap
                     1            0.2      550      1
TestNamedListCodec.testIterable
                     1            0.2      550      1
TestNamedListCodec.testIterator
                     1            0.2      550      1
TestNamedListCodec.testRandom
                     1            0.2      550      1
TestNamedListCodec.testSimple
                     1            0.2      547      1
TestObjectReleaseTracker.testObjectReleaseTracker
                     1            0.2      550      1      TestPathTrie(suite)
                     1            0.2      551      1
TestPathTrie.testPathTrie
                     1            0.2      542      1
TestPointFields.testLongPointFieldMultiValuedRangeFacet
                     1            0.2      551      1      TestPolicy(suite)
                     1            0.2      553      1
TestPolicy.testComputePlanAfterNodeAdded
                     1            0.2      553      1
TestPolicy.testConditionsSort
                     1            0.2      553      1
TestPolicy.testCoresSuggestions
                     1            0.2      553      1
TestPolicy.testDiskSpaceHint
                     1            0.2      553      1
TestPolicy.testDiskSpaceReqd
                     1            0.2      553      1
TestPolicy.testEmptyClusterState
                     1            0.2      553      1
TestPolicy.testFreeDiskSuggestions
                     1            0.2      553      1
TestPolicy.testGreedyConditions
                     1            0.2      553      1      TestPolicy.testMerge
                     1            0.2      553      1
TestPolicy.testMoveReplica
                     1            0.2      553      1
TestPolicy.testMoveReplicaLeaderlast
                     1            0.2      553      1
TestPolicy.testMoveReplicaSuggester
                     1            0.2      553      1
TestPolicy.testMoveReplicasInMultipleCollections
                     1            0.2      553      1
TestPolicy.testMultiReplicaPlacement
                     1            0.2      553      1
TestPolicy.testMultipleCollections
                     1            0.2      553      1
TestPolicy.testNegativeConditions
                     1            0.2      553      1
TestPolicy.testNodeLost
                     1            0.2      553      1
TestPolicy.testNodeLostMultipleReplica
                     1            0.2      553      1
TestPolicy.testOperands
                     1            0.2      553      1
TestPolicy.testOtherTag
                     1            0.2      553      1
TestPolicy.testPolicyWithReplicaType
                     1            0.2      553      1
TestPolicy.testPortSuggestions
                     1            0.2      553      1
TestPolicy.testReplicaCountSuggestions
                     1            0.2      553      1      TestPolicy.testRow
                     1            0.2      553      1      TestPolicy.testRules
                     1            0.2      553      1
TestPolicy.testScheduledTriggerFailure
                     1            0.2      553      1
TestPolicy.testSessionCaching
                     1            0.4      272      1
TestPolicy.testSortError
                     1            0.2      553      1
TestPolicy.testSyspropSuggestions
                     1            0.2      553      1
TestPolicy.testUtilizeNodeFailure
                     1            0.2      553      1
TestPolicy.testUtilizeNodeFailure2
                     1            0.2      553      1
TestPolicy.testValidate
                     1            0.2      550      1
TestPolicyCloud.testCreateCollectionAddShardUsingPolicy
                     1            0.2      547      1
TestPullReplica.testAddRemovePullReplica
                     1            0.2      547      1
TestPullReplica.testRealTimeGet
                     1            0.4      544      2
TestRandomRequestDistribution(suite)
                     1            0.2      548      1
TestRandomRequestDistribution.test
                     1            0.2      538      1
TestSolrCoreParser.testApacheLuceneSolr
                     1            0.2      538      1
TestSolrCoreParser.testCustomQueryWrapping
                     1            0.2      538      1
TestSolrCoreParser.testGoodbye
                     1            0.2      538      1
TestSolrCoreParser.testHandyQuery
                     1            0.2      538      1
TestSolrCoreParser.testHandySpanQuery
                     1            0.2      538      1
TestSolrCoreParser.testHello
                     1            0.4      551      2
TestSolrProperties(suite)
                     1            0.2      553      1
TestSolrProperties.testProperties
                     1            0.5      550      3
TestSpellCheckResponse(suite)
                     1            0.2      548      1
TestStandardNormalizer.testInvalidSTD
                     1            0.2      548      1
TestStandardNormalizer.testInvalidSTD2
                     1            0.2      548      1
TestStandardNormalizer.testInvalidSTD3
                     1            0.2      548      1
TestStandardNormalizer.testNormalizer
                     1            0.2      548      1
TestStandardNormalizer.testNormalizerNoParams
                     1            0.2      548      1
TestStandardNormalizer.testParamsToMap
                     1            0.2      542      1
TestSystemIdResolver.testResolving
                     1            0.2      542      1
TestSystemIdResolver.testUnsafeResolving
                     1            0.2      546      1
TestTestInjection(suite)
                     1            0.2      546      1
TestTestInjection.testBadSyntax
                     1            0.2      546      1
TestTestInjection.testBasics
                     1            0.2      546      1
TestTestInjection.testGoodSyntax
                     1            0.2      546      1
TestTestInjection.testUsingConsistentRandomization
                     1            0.2      551      1      TestTimeSource(suite)
                     1            0.2      550      1
TestToleratedUpdateError.testParseMapErrorChecking
                     1            0.2      551      1
TestUpdateRequestCodec.simple
                     1            0.2      551      1
TestUpdateRequestCodec.testBackCompat4_5
                     1            0.2      551      1
TestUpdateRequestCodec.testIteratable
                     1            0.3      350      1
TestUpgradeIndexMergePolicy.testFindForcedDeletesMerges
                     1            0.2      551      1
TestV1toV2ApiMapper.testAddReplica
                     1            0.2      551      1
TestV1toV2ApiMapper.testCreate
                     1            0.2      551      1
TestV1toV2ApiMapper.testSetCollectionProperty
                     1            0.2      542      1
TestXmlQParser.testBooleanQueryXML
                     1            0.2      542      1
TestXmlQParser.testBoostingTermQueryXML
                     1            0.2      542      1
TestXmlQParser.testConstantScoreQueryXML
                     1            0.2      542      1
TestXmlQParser.testCustomFieldUserQueryXML
                     1            0.2      542      1
TestXmlQParser.testDisjunctionMaxQueryXML
                     1            0.2      542      1
TestXmlQParser.testMatchAllDocsPlusFilterXML
                     1            0.2      542      1
TestXmlQParser.testNestedBooleanQuery
                     1            0.2      542      1
TestXmlQParser.testPointRangeQuery
                     1            0.2      542      1
TestXmlQParser.testPointRangeQueryWithoutLowerTerm
                     1            0.2      542      1
TestXmlQParser.testPointRangeQueryWithoutRange
                     1            0.2      542      1
TestXmlQParser.testPointRangeQueryWithoutUpperTerm
                     1            0.2      542      1
TestXmlQParser.testRangeQueryXML
                     1            0.2      542      1
TestXmlQParser.testSpanTermXML
                     1            0.2      542      1
TestXmlQParser.testTermQueryEmptyXML
                     1            0.2      542      1
TestXmlQParser.testTermQueryXML
                     1            0.2      542      1
TestXmlQParser.testTermsQueryXML
                     1            0.2      542      1
TestXmlQParser.testUserQueryXML
                     1            0.2      542      1
TestXmlQParser.test_DOCTYPE_TermQueryXML
                     1            0.2      542      1
TestXmlQParser.test_ENTITY_TermQueryXML
                     1            0.2      546      1
UUIDFieldTest.testToInternal
                      23456789   14.7     2989    438
ZkControllerTest(suite)
                      234 6789   11.5      485     56
TestLeaderElectionZkExpiry(suite)
                      234  7      0.4     1529      6      SampleTest(suite)
                      234        12.2     1315    160
DistributedSpellCheckComponentTest.test
                      234         6.9     1282     89
SpellCheckComponentTest.test
                      234         6.1     1286     78
SpellCheckComponentTest.testCollate
                      234         5.4     1285     69
SpellCheckComponentTest.testCollateExtendedResultsWithJsonNl
                      234         6.3     1289     81
SpellCheckComponentTest.testMaximumResultsForSuggest
                      234         5.6     1288     72
SpellCheckComponentTest.testNumericQuery
                      234         5.9     1286     76
SpellCheckComponentTest.testRebuildOnCommit
                      234         4.6       65      3
TestIntRangeFieldQueries.testRandomBig
                      23 56789    1.0     2956     30
TestReplicationHandler.doTestReplicateAfterCoreReload
                      23  6       0.2     1220      3
TestSolrEntityProcessorEndToEnd.testFullImport
                      23   789    1.2     1948     23
TestLogWatcher.testLog4jWatcher
                      23   78     7.1      113      8
TestBinaryDocValuesUpdates.testTonsOfUpdates
                      23   7      3.6       84      3
TestMixedDocValuesUpdates.testTonsOfUpdates
                      23    89    0.3     1534      5
TestSolrConfigHandlerConcurrent.test
                      23          0.2      890      2
CollectionsAPIDistributedZkTest.deletePartiallyCreatedCollection
                      23          0.3      885      3
ConcurrentCreateRoutedAliasTest.testConcurrentCreateRoutedAliasComplex
                      23          0.6      873      5
HttpSolrCallGetCoreTest(suite)
                      23          0.2      937      2
TestConcurrentMergeScheduler.testFlushExceptions
                      23          2.7       73      2
TestGenericDistributedQueue.testDistributedQueueBlocking
                      23          0.3      902      3
TestSolrEntityProcessorEndToEnd.testFullImportWrongSolrUrl
                      23          0.3      884      3
TestStressVersions.testStressGetRealtimeVersions
                      2 45  8     0.3     1527      4
HttpPartitionOnCommitTest.test
                      2 45        0.4     1113      5
SoftAutoCommitTest.testHardCommitWithinAndSoftCommitMaxTimeRapidAdds
                      2 4 6789   24.0      100     24
TestDocTermOrds.testTriggerUnInvertLimit
                      2 4   8     0.3     1186      3
TestSolrEntityProcessorEndToEnd.testFullImportBadConfig
                      2 4    9    0.3      949      3
MoveReplicaHDFSFailoverTest.testDataDirAndUlogAreMaintained
                      2 4    9    0.6     1131      7      QueryFacetTest(suite)
                      2 4         0.2      813      2
TestSolrCLIRunExample.testInteractiveSolrCloudExample
                      2 4         0.2      829      2
TestSolrEntityProcessorEndToEnd.testCursorMarkNoSort
                      2 4         0.2      829      2
TestSolrEntityProcessorEndToEnd.testFullImportFieldsParam
                      2  56       0.6     1173      7
MetricTriggerIntegrationTest.testMetricTrigger
                      2  56      88.9        9      8
SharedFSAutoReplicaFailoverTest(suite)
                      2  5        0.2      875      2
MathExpressionTest(suite)
                      2   67      0.6     1145      7      TestNRTOpen(suite)
                      2   6 89    0.3     1462      5
TestCollectionAPI.test
                      2   6 8     0.3     1161      3
TestPullReplicaErrorHandling.testCantConnectToPullReplica
                      2   6 8     0.3     1188      3
TestSolrEntityProcessorEndToEnd.testFullImportInnerEntity
                      2   6       0.2      811      2      BasicZkTest.testBasic
                      2   6       0.4      830      3
TestBlockJoin.testMultiChildQueriesOfDiffParentLevels
                      2    789    0.6     1732     10
TestReplicationHandler.doTestIndexFetchWithMasterUrl
                      2    7      0.7      835      6
BinaryUpdateRequestHandlerTest(suite)
                      2    7      0.7      837      6
FacetPivotSmallTest(suite)
                      2    7      0.7      839      6
FileBasedSpellCheckerTest(suite)
                      2    7      0.7      840      6      SOLR749Test(suite)
                      2    7      0.4      837      3
SolrCoreCheckLockOnStartupTest(suite)
                      2    7      0.2      840      2
SolrCoreCheckLockOnStartupTest.testNativeLockErrorOnStartup
                      2    7      0.2      840      2
SolrCoreCheckLockOnStartupTest.testSimpleLockErrorOnStartup
                      2    7      0.4      842      3
SpatialRPTFieldTypeTest(suite)
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testDistanceUnitsDegrees
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testDistanceUnitsKilometers
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testGeoDistanceFunctionWithBackCompat
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testGeoDistanceFunctionWithKilometers
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testGeoDistanceFunctionWithMiles
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testJunkValuesForDistanceUnits
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testMaxDistErrConversion
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testShapeToFromStringGeoJSON
                      2    7      0.2      846      2
SpatialRPTFieldTypeTest.testShapeToFromStringWKT
                      2    7      0.7      842      6
TestImplicitCoreProperties(suite)
                      2    7      0.5      839      4
TestInfoStreamLogging(suite)
                      2    7      0.3      886      3
TestNumericDocValuesUpdates.testTonsOfUpdates
                      2    7      0.4      841      3
TestReloadAndDeleteDocs(suite)
                      2    7      0.2      845      2
TestReloadAndDeleteDocs.testReloadAndDeleteDocsNoUpdateLog
                      2    7      0.2      845      2
TestReloadAndDeleteDocs.testReloadAndDeleteDocsWithUpdateLog
                      2    7      0.7      835      6
TestSchemaManager(suite)
                      2    7      0.7      838      6
TestSimpleQParserPlugin(suite)
                      2    7      0.2      858      2
TestSolrCLIRunExample.testInteractiveSolrCloudExampleWithAutoScalingPolicy
                      2    7      0.5      832      4
TestSolrIndexConfig(suite)
                      2     89    0.6     1143      7
TestCollectionAPI(suite)
                      2     8     1.4      855     12
SpellCheckCollatorTest.testEstimatedHitCounts
                      2     8     0.8      791      6
TestLogWatcher.testLog4jWatcherRepeat
                      2      9    0.2      810      2
TestLocalFSCloudBackupRestore.test
                      2           0.2      508      1
AbsoluteValueFunctionTest(suite)
                      2           0.2      510      1
AbsoluteValueFunctionTest.multiValueDoubleTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.multiValueFloatTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.multiValueIntTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.multiValueLongTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.singleValueDoubleTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.singleValueFloatTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.singleValueIntTest
                      2           0.2      510      1
AbsoluteValueFunctionTest.singleValueLongTest
                      2           0.2      508      1
AddFunctionTest(suite)
                      2           0.2      512      1
AddFunctionTest.multipleSingleValueParameterTest
                      2           0.2      512      1
AddFunctionTest.oneMultiOneSingleValueParameterTest
                      2           0.2      512      1
AddFunctionTest.oneMultiValueParameterTest
                      2           0.2      512      1
AddFunctionTest.twoSingleValueParametersTest
                      2           0.2      508      1
AndFunctionTest(suite)
                      2           0.2      509      1
AndFunctionTest.multipleSingleValueParameterTest
                      2           0.2      509      1
AndFunctionTest.oneMultiOneSingleValueParameterTest
                      2           0.2      509      1
AndFunctionTest.oneMultiValueParameterTest
                      2           0.2      509      1
AndFunctionTest.twoSingleValueParametersTest
                      2           0.2      506      1
BasicAuthIntegrationTest(suite)
                      2           0.8      507      4
BooleanFieldsTest(suite)
                      2           0.6      507      3
CarrotClusteringEngineTest(suite)
                      2           0.2      508      1
CastingAnalyticsValueTest(suite)
                      2           0.2      512      1
CastingAnalyticsValueTest.constantConversionTest
                      2           0.2      512      1
CastingAnalyticsValueTest.objectStreamCastingTest
                      2           0.2      508      1
CastingDoubleValueStreamTest(suite)
                      2           0.2      509      1
CastingDoubleValueStreamTest.constantConversionTest
                      2           0.2      509      1
CastingDoubleValueStreamTest.objectStreamCastingTest
                      2           0.2      509      1
CastingDoubleValueStreamTest.stringStreamCastingTest
                      2           0.2      508      1
CastingDoubleValueTest(suite)
                      2           0.2      508      1
CastingDoubleValueTest.constantConversionTest
                      2           0.2      508      1
CastingDoubleValueTest.doubleStreamCastingTest
                      2           0.2      508      1
CastingDoubleValueTest.objectCastingTest
                      2           0.2      508      1
CastingDoubleValueTest.objectStreamCastingTest
                      2           0.2      508      1
CastingDoubleValueTest.stringCastingTest
                      2           0.2      508      1
CastingDoubleValueTest.stringStreamCastingTest
                      2           0.2      508      1
CastingFloatValueStreamTest(suite)
                      2           0.2      510      1
CastingFloatValueStreamTest.constantConversionTest
                      2           0.2      510      1
CastingFloatValueStreamTest.doubleStreamCastingTest
                      2           0.2      510      1
CastingFloatValueStreamTest.objectStreamCastingTest
                      2           0.2      510      1
CastingFloatValueStreamTest.stringStreamCastingTest
                      2           0.2      508      1
CastingFloatValueTest(suite)
                      2           0.2      511      1
CastingFloatValueTest.constantConversionTest
                      2           0.2      511      1
CastingFloatValueTest.doubleCastingTest
                      2           0.2      511      1
CastingFloatValueTest.doubleStreamCastingTest
                      2           0.2      511      1
CastingFloatValueTest.floatStreamCastingTest
                      2           0.2      511      1
CastingFloatValueTest.objectCastingTest
                      2           0.2      511      1
CastingFloatValueTest.objectStreamCastingTest
                      2           0.2      511      1
CastingFloatValueTest.stringCastingTest
                      2           0.2      511      1
CastingFloatValueTest.stringStreamCastingTest
                      2           0.2      508      1
CastingIntValueStreamTest(suite)
                      2           0.2      510      1
CastingIntValueStreamTest.constantConversionTest
                      2           0.2      510      1
CastingIntValueStreamTest.doubleStreamCastingTest
                      2           0.2      510      1
CastingIntValueStreamTest.floatStreamCastingTest
                      2           0.2      510      1
CastingIntValueStreamTest.longStreamCastingTest
                      2           0.2      510      1
CastingIntValueStreamTest.objectStreamCastingTest
                      2           0.2      510      1
CastingIntValueStreamTest.stringStreamCastingTest
                      2           0.2      500      1
CloudExitableDirectoryReaderTest.test
                      2           0.6      507      3
ClusteringComponentTest(suite)
                      2           0.6      508      3
DistributedClusteringComponentTest(suite)
                      2           0.2      510      1
DistributedClusteringComponentTest.test
                      2           0.8      507      4
DoubleFieldsTest(suite)
                      2           0.2      508      1
ExistsFunctionTest(suite)
                      2           0.2      508      1
ExistsFunctionTest.multiValueParameterTest
                      2           0.2      508      1
ExistsFunctionTest.singleValueParameterTest
                      2           0.2      508      1
FillMissingFunctionTest(suite)
                      2           0.2      509      1
FillMissingFunctionTest.castingTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueBooleanTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueDateTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueDoubleTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueFloatTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueIntTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueLongTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueObjectTest
                      2           0.2      509      1
FillMissingFunctionTest.multiValueStringTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueBooleanTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueDateTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueDoubleTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueFloatTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueIntTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueLongTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueObjectTest
                      2           0.2      509      1
FillMissingFunctionTest.singleValueStringTest
                      2           0.8      507      4
FloatFieldsTest(suite)
                      2           0.6      509      3      GetByIdTest(suite)
                      2           5.4       37      2
HdfsAutoAddReplicasIntegrationTest.testSimple
                      2           0.3      598      2
IndexSizeTriggerTest(suite)
                      2           0.2      501      1
InfixSuggestersTest.testReloadDuringBuild
                      2           0.2      507      1      JdbcTest.doTest
                      2           0.4      510      2
JettyWebappTest(suite)
                      2           0.2      514      1
JettyWebappTest.testAdminUI
                      2           1.0      484      5
LIRRollingUpdatesTest(suite)
                      2           0.2      510      1
LargeVolumeEmbeddedTest.testMultiThreaded
                      2           0.2      502      1
LeaderElectionContextKeyTest(suite)
                      2           0.6      507      3
LegacyFacetSortingTest(suite)
                      2           0.6      507      3
LegacyFieldFacetExtrasTest(suite)
                      2           0.8      507      4
LegacyRangeFacetCloudTest(suite)
                      2           0.6      507      3
LegacyRangeFacetTest(suite)
                      2           0.2      508      1
LogFunctionTest(suite)
                      2           0.2      509      1
LogFunctionTest.multiValueParameterTest
                      2           0.2      509      1
LogFunctionTest.oneMultiOneSingleValueParameterTest
                      2           0.2      509      1
LogFunctionTest.oneSingleOneMultiValueParameterTest
                      2           0.2      509      1
LogFunctionTest.singleValueParameterTest
                      2           0.2      509      1
LogFunctionTest.twoSingleValueParametersTest
                      2           0.2      498      1
MigrateRouteKeyTest.multipleShardMigrateTest
                      2           0.2      508      1
MultFunctionTest(suite)
                      2           0.2      511      1
MultFunctionTest.multipleSingleValueParameterTest
                      2           0.2      511      1
MultFunctionTest.oneMultiOneSingleValueParameterTest
                      2           0.2      511      1
MultFunctionTest.oneMultiValueParameterTest
                      2           0.2      511      1
MultFunctionTest.twoSingleValueParametersTest
                      2           0.2      511      1      NoFacetTest.meanTest
                      2           0.2      511      1
NoFacetTest.medianTest
                      2           0.6      509      3
NoOpResponseParserTest(suite)
                      2           0.6      482      3
NodeLostTriggerIntegrationTest(suite)
                      2           0.8      503      4
PKIAuthenticationIntegrationTest(suite)
                      2           0.2      508      1
RoundFunctionTest(suite)
                      2           0.2      511      1
RoundFunctionTest.multiValueDoubleParameterTest
                      2           0.2      511      1
RoundFunctionTest.multiValueFloatParameterTest
                      2           0.2      511      1
RoundFunctionTest.nonDecimalParameterTest
                      2           0.2      511      1
RoundFunctionTest.singleValueDoubleParameterTest
                      2           0.2      511      1
RoundFunctionTest.singleValueFloatParameterTest
                      2           0.2      472      1
SoftAutoCommitTest.testSoftCommitWithinAndHardCommitMaxTimeMixedAdds
                      2           0.2      472      1
SoftAutoCommitTest.testSoftCommitWithinAndHardCommitMaxTimeRapidAdds
                      2           0.6      509      3      SolrPingTest(suite)
                      2           0.8      507      4
StringFieldsTest(suite)
                      2           0.8      501      4
TemplateUpdateProcessorTest(suite)
                      2           0.2      533      1
TestBinaryDocValuesUpdates.testSimple
                      2           0.2      508      1
TestBuiltInEvaluators(suite)
                      2           0.2      511      1
TestBuiltInEvaluators.parseParams
                      2           0.2      511      1
TestBuiltInEvaluators.testDateFormatEvaluator
                      2           0.2      511      1
TestBuiltInEvaluators.testEscapeSolrQueryFunction
                      2           0.2      511      1
TestBuiltInEvaluators.testSqlEscapingEvaluator
                      2           0.2      511      1
TestBuiltInEvaluators.testUrlEvaluator
                      2           0.2      508      1
TestClobTransformer(suite)
                      2           0.2      512      1
TestClobTransformer.simple
                      2           0.8      492      4
TestCloudCollectionsListeners(suite)
                      2           0.4      496      2
TestCloudCollectionsListeners.testCollectionDeletion
                      2           0.4      496      2
TestCloudCollectionsListeners.testSimpleCloudCollectionsListener
                      2           0.4      496      2
TestCloudCollectionsListeners.testWatchesWorkForBothStateFormats
                      2           0.2      501      1
TestCloudNestedDocsSort(suite)
                      2           0.2      501      1
TestCloudNestedDocsSort.test
                      2           0.4      500      2
TestCloudSearcherWarming(suite)
                      2           0.2      523      1
TestCollectionStateWatchers.testWaitForStateChecksCurrentState
                      2           0.4      501      2      TestCryptoKeys(suite)
                      2           0.2      505      1      TestCryptoKeys.test
                      2           0.2      508      1      TestDocBuilder(suite)
                      2           0.2      511      1
TestDocBuilder.loadClass
                      2           0.2      511      1
TestDocBuilder.singleEntityMultipleRows
                      2           0.2      511      1
TestDocBuilder.singleEntityNoRows
                      2           0.2      511      1
TestDocBuilder.singleEntityOneRow
                      2           0.2      511      1
TestDocBuilder.templateXPath
                      2           0.2      511      1
TestDocBuilder.testDeltaImportNoRows_MustNotCommit
                      2           0.2      511      1
TestDocBuilder.testImportCommand
                      2           0.2      508      1
TestEntityProcessorBase(suite)
                      2           0.2      509      1
TestEntityProcessorBase.multiTransformer
                      2           0.6      507      3
TestFoldingMultitermExtrasQuery(suite)
                      2           4.3      230     10
TestHardLinkCopyDirectoryWrapper.testRenameWithHardLink
                      2           0.6      507      3
TestHierarchicalDocBuilder(suite)
                      2           0.6      507      3
TestICUCollationField(suite)
                      2           0.6      507      3
TestICUCollationFieldDocValues(suite)
                      2           0.6      507      3
TestICUCollationFieldOptions(suite)
                      2           0.2      536      1
TestIndexWriterExceptions.testDocumentsWriterExceptionThreads
                      2           0.4      265      1
TestIndexWriterWithThreads.testUpdateSingleDocWithThreads
                      2           0.2      508      1
TestJavaBinCodec.testBackCompatForSolrDocumentWithChildDocs
                      2           0.2      448      1
TestJdbcDataSource(suite)
                      2           0.2      452      1
TestJdbcDataSource.testClosesConnectionWhenExceptionThrownOnSetAutocommit
                      2           0.2      452      1
TestJdbcDataSource.testClosesCurrentResultSetIteratorWhenNewOneIsCreated
                      2           0.2      452      1
TestJdbcDataSource.testClosesResultSetAndStatementWhenDataSourceIsClosed
                      2           0.2      452      1
TestJdbcDataSource.testClosesStatementWhenExceptionThrownOnExecuteQuery
                      2           0.2      452      1
TestJdbcDataSource.testClosesStatementWhenHasNextCalledAndResultSetNull
                      2           0.2      452      1
TestJdbcDataSource.testClosesStatementWhenResultSetNull
                      2           0.2      452      1
TestJdbcDataSource.testEmptyResultSet
                      2           0.2      452      1
TestJdbcDataSource.testMultipleResultsSets_ResultSetResultSet
                      2           0.2      452      1
TestJdbcDataSource.testMultipleResultsSets_UpdateCountUpdateCountResultSet
                      2           0.2      452      1
TestJdbcDataSource.testRetrieveFromDriverManager
                      2           0.2      452      1
TestJdbcDataSource.testRetrieveFromJndi
                      2           0.2      452      1
TestJdbcDataSource.testRetrieveFromJndiFailureNotHidden
                      2           0.2      452      1
TestJdbcDataSource.testRetrieveFromJndiWithCredentials
                      2           0.2      452      1
TestJdbcDataSource.testRetrieveFromJndiWithCredentialsEncryptedAndResolved
                      2           0.2      452      1
TestJdbcDataSource.testRetrieveFromJndiWithCredentialsWithEncryptedAndResolvedPwd
                      2           0.2      497      1
TestJdbcDataSourceConvertType(suite)
                      2           0.2      501      1
TestJdbcDataSourceConvertType.testConvertType
                      2           0.2      508      1
TestLineEntityProcessor(suite)
                      2           0.2      512      1
TestLineEntityProcessor.testNo_xsd_files
                      2           0.2      512      1
TestLineEntityProcessor.testOnly_xml_files
                      2           0.2      512      1
TestLineEntityProcessor.testOnly_xml_files_no_xsd
                      2           0.2      512      1
TestLineEntityProcessor.testSimple
                      2           0.6      507      3
TestNonWritablePersistFile(suite)
                      2           0.2      533      1
TestOfflineSorter.testIntermediateMerges
                      2           4.2       24      1
TestOfflineSorter.testLargerRandom
                      2           0.2      533      1
TestOfflineSorter.testSmallRandom
                      2           0.2      533      1
TestOfflineSorter.testThreadSafety
                      2           0.6      507      3
TestOpenNLPExtractNamedEntitiesUpdateProcessorFactory(suite)
                      2           0.4      501      2
TestRealTimeGet.testStressGetRealtime
                      2           0.2      501      1
TestRequestStatusCollectionAPI.test
                      2           0.6      501      3
TestRestoreCore(suite)
                      2           0.2      505      1
TestRestoreCore.testFailedRestore
                      2           0.2      505      1
TestRestoreCore.testSimpleRestore
                      2           0.2      500      1
TestSSLRandomization.testRandomizedSslAndClientAuth
                      2           0.2      508      1
TestScriptTransformer(suite)
                      2           0.2      512      1
TestScriptTransformer.testBasic
                      2           0.2      512      1
TestScriptTransformer.testCheckScript
                      2           0.2      512      1
TestScriptTransformer.testOneparam
                      2           0.2      512      1
TestScriptTransformer.testReadScriptTag
                      2          10.1      277     28
TestSimpleFSDirectory.testCreateOutputWithPendingDeletes
                      2          10.1      277     28
TestSimpleFSDirectory.testRenameWithPendingDeletes
                      2           0.6      507      3
TestSimplePropertiesWriter(suite)
                      2           0.2      507      1
TestSolrCLIRunExample.testFailExecuteScript
                      2           0.2      507      1
TestSolrCLIRunExample.testSchemalessExample
                      2           0.2      507      1
TestSolrCLIRunExample.testTechproductsExample
                      2           0.4      508      2
TestSolrEntityProcessorEndToEnd(suite)
                      2           0.6      507      3
TestSqlEntityProcessor(suite)
                      2           0.6      507      3
TestSqlEntityProcessorDelta(suite)
                      2           1.0      499      5
TestStressLiveNodes(suite)
                      2           0.2      498      1
TestSystemCollAutoCreate.testAutoCreate
                      2           0.2      508      1
TestTemplateTransformer(suite)
                      2           0.2      510      1
TestTemplateTransformer.testTransformRow
                      2           0.2      510      1
TestTemplateTransformer.testTransformRowMultiValue
                      2           0.4      502      2
TestTikaEntityProcessor(suite)
                      2           0.8      498      4
TestTolerantUpdateProcessorRandomCloud(suite)
                      2           0.2      508      1
TestURLDataSource(suite)
                      2           0.2      512      1
TestURLDataSource.substitutionsOnBaseUrl
                      2           0.2      503      1      TestUtils(suite)
                      2           0.2      504      1
TestUtils.testBinaryCommands
                      2           0.2      504      1
TestUtils.testEscapeTextWithSeparator
                      2           0.2      504      1      TestUtils.testJoin
                      2           0.2      504      1
TestUtils.testNamedLists
                      2           0.2      504      1
TestUtils.testNoggitFlags
                      2           0.2      504      1
TestUtils.testNumberUtils
                      2           0.2      504      1
TestUtils.testSetObjectByPath
                      2           0.2      504      1
TestUtils.testSplitEscaping
                      2           0.2      504      1
TestUtils.testUtilsJSPath
                      2           0.8      509      4      TestV2Request(suite)
                      2           0.2      508      1
TestVariableResolver(suite)
                      2           0.2      512      1
TestVariableResolver.dateNamespaceWithExpr
                      2           0.2      512      1
TestVariableResolver.dateNamespaceWithValue
                      2           0.2      512      1
TestVariableResolver.test3LevelNestedNamespace
                      2           0.2      512      1
TestVariableResolver.testDefaultNamespace
                      2           0.2      512      1
TestVariableResolver.testDefaultNamespace1
                      2           0.2      512      1
TestVariableResolver.testDefaults
                      2           0.2      512      1
TestVariableResolver.testFunctionNamespace1
                      2           0.2      512      1
TestVariableResolver.testNestedNamespace
                      2           0.2      512      1
TestVariableResolver.testSimpleNamespace
                      2           0.6      507      3
TestVariableResolverEndToEnd(suite)
                      2           0.6      507      3      TestWriterImpl(suite)
                      2           1.0      507      5
TestZKPropertiesWriter(suite)
                      2           1.0      387      4
TestZkAclsWithHadoopAuth(suite)
                      2           0.2      501      1
URLClassifyProcessorTest(suite)
                      2           0.2      505      1
URLClassifyProcessorTest.testCanonicalUrl
                      2           0.2      505      1
URLClassifyProcessorTest.testLandingPage
                      2           0.2      505      1
URLClassifyProcessorTest.testLength
                      2           0.2      505      1
URLClassifyProcessorTest.testLevels
                      2           0.2      505      1
URLClassifyProcessorTest.testNormalizations
                      2           0.2      505      1
URLClassifyProcessorTest.testProcessor
                      2           0.2      505      1
URLClassifyProcessorTest.testTopLevelPage
                      2           0.8      509      4
UsingSolrJRefGuideExamplesTest(suite)
                      2           0.6      502      3
V2StandaloneTest(suite)
                      2           0.2      503      1
V2StandaloneTest.testWelcomeMessage
                      2           0.2      497      1      ZkCLITest(suite)
                      2           0.2      501      1
ZkCLITest.testBootstrapWithChroot
                      2           0.2      501      1
ZkCLITest.testCmdConstants
                      2           0.2      501      1      ZkCLITest.testGet
                      2           0.2      501      1      ZkCLITest.testGetFile
                      2           0.2      501      1
ZkCLITest.testGetFileNotExists
                      2           0.2      501      1
ZkCLITest.testInvalidZKAddress
                      2           0.2      501      1      ZkCLITest.testList
                      2           0.2      501      1      ZkCLITest.testLs
                      2           0.2      501      1
ZkCLITest.testMakePath
                      2           0.2      501      1      ZkCLITest.testPut
                      2           0.2      501      1      ZkCLITest.testPutFile
                      2           0.2      501      1
ZkCLITest.testPutFileNotExists
                      2           0.2      501      1
ZkCLITest.testSetClusterProperty
                      2           0.2      501      1
ZkCLITest.testUpConfigLinkConfigClearZk
                      2           0.2      501      1
ZkCLITest.testUpdateAcls
                      2           0.2      504      1
ZkStateReaderTest(suite)
                      2           0.2      508      1
ZkStateReaderTest.testCollectionStateWatcherCaching
                      2           0.2      508      1
ZkStateReaderTest.testExternalCollectionWatchedNotWatched
                      2           0.2      508      1
ZkStateReaderTest.testStateFormatUpdateWithExplicitRefresh
                      2           0.2      508      1
ZkStateReaderTest.testStateFormatUpdateWithExplicitRefreshLazy
                      2           0.2      508      1
ZkStateReaderTest.testStateFormatUpdateWithTimeDelay
                      2           0.2      508      1
ZkStateReaderTest.testStateFormatUpdateWithTimeDelayLazy
                      2           0.2      508      1
ZkStateReaderTest.testWatchedCollectionCreation
                       345 789    0.4     2067      8
TimeRoutedAliasUpdateProcessorTest.test
                       34 67     77.8        9      7
HdfsChaosMonkeySafeLeaderTest(suite)
                       34 6       0.6      855      5
TestRecoveryHdfs.testBufferingFlags
                       34 6       0.6      855      5
TestRecoveryHdfs.testCorruptLog
                       34 6       0.5      855      4
TestRecoveryHdfs.testRemoveOldLogs
                       34 6       0.6      855      5
TestRecoveryHdfs.testReplicationFactor
                       34 6       0.5      855      4
TestRecoveryHdfs.testTruncatedLog
                       34   8     0.3     1029      3
ConcurrentCreateRoutedAliasTest.testConcurrentCreateRoutedAliasMinimal
                       34   8     7.5       67      5
TestDoubleRangeFieldQueries.testRandomBig
                       34   8     4.5       66      3
TestLongRangeFieldQueries.testRandomBig
                       34         0.4      567      2
HdfsRecoverLeaseTest.testBasic
                       34         0.4      567      2
HdfsRecoverLeaseTest.testMultiThreaded
                       34         1.1      567      6
MoveReplicaHDFSTest(suite)
                       34         0.6      685      4
ShardRoutingTest(suite)
                       34        10.7      777     83
SpellCheckComponentTest.testExtendedResultsCount
                       34         0.9      677      6
TestLeaderElectionWithEmptyReplica(suite)
                       34         0.5      575      3
TestRecoveryHdfs.testLogReplay
                       34         0.9      680      6
TimeRoutedAliasUpdateProcessorTest(suite)
                       3  67 9    1.6     1335     22
TestDocTermOrds(suite)
                       3   789   12.5       48      6
HdfsBasicDistributedZk2Test.test
                       3   78    90.0       10      9
HdfsRestartWhileUpdatingTest.test
                       3   78     0.3     1053      3
UninvertDocValuesMergePolicyTest.testIndexAndAddDocValues
                       3   7      0.5      745      4
TestCollectionStateWatchers(suite)
                       3   7      0.4      733      3
TestLockTree.testLocks
                       3    89    0.5      838      4
HDFSCollectionsAPITest.testDataDirIsNotReused
                       3    8     0.3      733      2
AliasIntegrationTest.testDeleteOneOfTwoCollectionsAliased
                       3    8     0.3      747      2
SelectWithEvaluatorsTest(suite)
                       3    8     4.0       50      2
TestFloatRangeFieldQueries.testRandomBig
                       3     9    0.6      698      4
BlockDirectoryTest.testEOF
                       3     9    0.3      693      2
CollectionsAPIDistributedZkTest.testCreateShouldFailOnExistingCore
                       3          0.3      379      1
ActionThrottleTest.testAZeroNanoTimeReturnInWait
                       3          7.7       13      1
CdcrReplicationHandlerTest.testReplicationWithBufferedUpdates
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.deleteCollectionOnlyInZk
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.deleteCollectionRemovesStaleZkCollectionsNode
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testBadActionNames
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testCoresAreDistributedAcrossNodes
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testCreationAndDeletion
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testDeleteNonExistentCollection
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testMaxNodesPerShard
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testNoConfigSetExist
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testSpecificConfigsets
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testTooManyReplicas
                       3          0.3      384      1
CollectionsAPIDistributedZkTest.testZeroNumShards
                       3          1.1      378      4
CurrencyRangeFacetCloudTest(suite)
                       3          0.9      324      3
HdfsDirectoryTest(suite)
                       3          0.5      390      2
LegacyQueryFacetCloudTest.queryTest
                       3          0.3      349      1
MathExpressionTest.testZipFDistribution
                       3          0.3      375      1
MetricsHandlerTest.test
                       3          0.3      375      1
MetricsHandlerTest.testCompact
                       3          0.2      458      1
NodeAddedTriggerTest.testTrigger
                       3          1.3      387      5
OverallAnalyticsTest(suite)
                       3          0.6      333      2      OverseerTest(suite)
                       3          0.3      333      1
OverseerTest.testBadQueueItem
                       3          0.3      333      1
OverseerTest.testDownNodeFailover
                       3          0.3      372      1      PluginInfoTest(suite)
                       3          0.5      383      2
RollingRestartTest(suite)
                       3          1.1      352      4
SearchRateTriggerIntegrationTest(suite)
                       3          0.3      382      1
SimpleMLTQParserTest.doTest
                       3          0.3      376      1      SparseHLLTest(suite)
                       3          0.3      343      1
StreamDecoratorTest.testParallelComplementStream
                       3          1.8       57      1
StreamExpressionTest.testZipFDistribution
                       3          0.5      380      2
TestConfigReload(suite)
                       3          0.3      392      1
TestFixedGapPostingsFormat.testPostingsEnumReuse
                       3          0.3      398      1
TestIndexWriter.testCreateWithReader
                       3          0.3      385      1
TestJmxIntegration.testJmxRegistration
                       3        100.0       20     20
TestLucene50LiveDocsFormat.testOverflow
                       3          2.1      236      5
TestMixedDocValuesUpdates.testResetValueMultipleDocs
                       3          0.3      381      1
TestNumericTerms64(suite)
                       3          0.3      374      1
TestOnReconnectListenerSupport.test
                       3          0.3      373      1
TestRandomFlRTGCloud.testRandomizedUpdatesAndRTGs
                       3          0.3      387      1
TestSimpleTextCompoundFormat.testLargeCFS
                       3        100.0       23     23
TestSimpleTextLiveDocsFormat.testOverflow
                       3          0.3      381      1
TestSort.testRandomFieldNameSorts
                       3          0.3      380      1
TestStressReorder.testStressReorderVersions
                       3          1.2      328      4
TriggerSetPropertiesIntegrationTest(suite)
                       3          0.3      333      1
TriggerSetPropertiesIntegrationTest.testSetProperties
                       3          0.3      391      1
ValueFacetTest.medianTest
                       3          0.2      460      1
ZkControllerTest.testGetHostName
                        456 8     0.5     1123      6
TestHdfsCloudBackupRestore.test
                        456  9    0.8     1313     10
ChaosMonkeyNothingIsSafeWithPullReplicasTest(suite)
                        456  9    0.4     1323      5
ChaosMonkeyNothingIsSafeWithPullReplicasTest.test
                        456       0.3     1014      3
TestPullReplicaErrorHandling.testCantConnectToLeader
                        45  89   11.1       90     10
Test4GBStoredFields.test
                        45  8     0.5     1075      5
TestControlledRealTimeReopenThread.testControlledRealTimeReopenThread
                        45        0.6      679      4
StreamDecoratorTest.testParallelCommitStream
                        45        0.5      638      3
TestSolrCloudWithSecureImpersonation.testForwarding
                        4 678     6.6       76      5
HdfsBasicDistributedZkTest.test
                        4 67 9    0.7     1328      9      TestStressNRT.test
                        4 6       5.1       39      2
TestDuelingCodecsAtNight.testBigEquals
                        4 6       0.8      531      4
TestRecoveryHdfs.testBuffering
                        4 6       0.6      531      3
TestRecoveryHdfs.testCleanShutdown
                        4 6       0.8      531      4
TestRecoveryHdfs.testRecoveryMultipleLogs
                        4 6       0.8      531      4
TestRecoveryHdfs.testVersionsOnRestart
                        4  789    0.3     1314      4
AliasIntegrationTest.testModifyPropertiesV1
                        4  78     0.4     1007      4
CreateRoutedAliasTest.testTimeStampWithMsFails
                        4  7      0.6      641      4
InfixSuggestersTest(suite)
                        4  7      0.6      640      4
TestInPlaceUpdatesDistrib(suite)
                        4  7      0.8      646      5
ZkSolrClientTest(suite)
                        4   8     0.3      653      2
CreateRoutedAliasTest.testRandomRouterNameFails
                        4   8    11.6      709     82
DeleteInactiveReplicaTest.deleteInactiveReplicaTest
                        4   8     3.7       54      2
HdfsCollectionsAPIDistributedZkTest.testCreateNodeSet
                        4   8     0.3      639      2
TestNamedUpdateProcessors.test
                        4   8     5.3       38      2
TestSimpleTextStoredFieldsFormat.testBigDocuments
                        4    9    0.5      380      2
StreamExpressionTest.testExecutorStream
                        4    9    0.8      358      3
TriggerIntegrationTest.testScheduledTrigger
                        4         0.7      305      2
AliasIntegrationTest(suite)
                        4         0.6      309      2
AssignBackwardCompatibilityTest(suite)
                        4         0.3      305      1
AssignTest.testIdIsUnique
                        4         0.6      308      2
BasicDistributedZk2Test(suite)
                        4         0.3      309      1
CreateRoutedAliasTest.testUnParseableFutureFails
                        4         0.4      246      1
HdfsDirectoryFactoryTest.testLocalityReporter
                        4         0.8      249      2
HdfsDirectoryTest.testRename
                        4         0.7      306      2
LeaderFailureAfterFreshStartTest(suite)
                        4         0.3      310      1
SolrCollectorTest.testCollect
                        4         0.6      317      2
TestBackwardsCompatibility(suite)
                        4         0.7      306      2
TestBlobHandler(suite)
                        4         4.0      301     12
TestCloudJSONFacetJoinDomain(suite)
                        4         1.6      313      5
TestDirectoryTaxonomyWriter.testRecreateAndRefresh
                        4         0.3      312      1
TestDistribIDF.testSimpleQuery
                        4         0.3      318      1
TestDoubleRangeFieldQueries.testMultiValued
                        4         7.1      338     24
TestIndexWriterOutOfFileDescriptors.test
                        4         0.3      318      1
TestLRUQueryCache.testMinSegmentSizePredicate
                        4         0.4      282      1
TestLRUQueryCache.testQueryCacheSoftUpdate
                        4         0.3      317      1
TestLongRangeFieldQueries.testRandomMedium
                        4         0.7      303      2
TestNamedUpdateProcessors(suite)
                        4         5.2      305     16
TestNativeFSLockFactory.testStressLocks
                        4         0.3      318      1
TestSearcherManager.testSearcherManager
                        4         5.5      309     17
TestSimpleFSLockFactory.testStressLocks
                        4         2.1      288      6
TestSingleInstanceLockFactory.testStressLocks
                        4         2.3      298      7
TestSleepingLockWrapper.testStressLocks
                        4         0.3      322      1
TestSmartChineseAnalyzer.testRandomHugeStrings
                        4         0.3      307      1
ZkSolrClientTest.testClean
                         56 89    0.3     1357      4
AliasIntegrationTest.testModifyPropertiesV2
                         56       0.3      698      2
CreateRoutedAliasTest.testAliasNameMustBeValid
                         5 7      0.8      716      6
CdcrBootstrapTest(suite)
                         5  8     1.3      397      5
NodeMarkersRegistrationTest.testNodeMarkersRegistration
                         5        0.4      275      1
AliasIntegrationTest.testProperties
                         5        0.3      386      1
ComputePlanActionTest.testNodeWithMultipleReplicasLost
                         5        5.0       20      1      Test2BPostings.test
                         5        0.3      393      1
TestIndexWriterReader(suite)
                         5        4.8       21      1
TestIndexWriterReader.testDuringAddIndexes
                         5        0.5      393      2
TestLRUQueryCache.testEvictEmptySegmentCache
                         5        0.5      393      2
TestLRUQueryCache.testRefuseToCacheTooLargeEntries
                          67      0.7      578      4
ForceLeaderTest.testZombieLeader
                          67      0.3      660      2
TestDocTermOrds.testActuallySingleValued
                          67      0.5      659      3
TestDocTermOrds.testBackToTheFuture
                          67      0.3      661      2
TestDocTermOrds.testRandom
                          67      0.3      659      2
TestDocTermOrds.testSortedTermsEnum
                          67      0.3      657      2      TestLazyCores(suite)
                          67      0.3      663      2
TestPullReplicaErrorHandling.testPullReplicaDisconnectsFromZooKeeper
                          67     19.0      753    143
TestSolr4Spatial2.testLatLonRetrieval
                          67      1.4      666      9
TestSubQueryTransformerDistrib.test
                          6 8     0.5      662      3
TestDocTermOrds.testNumericEncoded64
                          6  9    0.3      616      2
CdcrBootstrapTest.testBootstrapWithSourceCluster
                          6  9    0.3      635      2
TestZKPropertiesWriter.testZKPropertiesWriter
                          6       2.6       38      1
AliasIntegrationTest.testModifyPropertiesCAR
                          6       1.3      310      4      BasicZkTest(suite)
                          6       0.3      325      1
BlockDirectoryTest.testRandomAccessWritesLargeCache
                          6       0.3      307      1
DistributedQueueTest.testDistributedQueueBlocking
                          6       1.5      324      5
Geo3dShapeWGS84ModelRectRelationTest.testGeoPolygonRect
                          6       0.3      312      1
PKIAuthenticationIntegrationTest.testPkiAuth
                          6      10.0       80      8
RandomGeoPolygonTest.testComparePolygons
                          6       0.6      319      2
RecoveryAfterSoftCommitTest.test
                          6       2.9      313      9
SegmentsInfoRequestHandlerTest.testSegmentInfos
                          6       2.3      311      7
SegmentsInfoRequestHandlerTest.testSegmentInfosData
                          6       0.3      319      1
StreamExpressionTest.testSqlStream
                          6       0.3      311      1
TemplateUpdateProcessorTest.testSimple
                          6       0.6      320      2
TestBooleanScorer(suite)
                          6       0.6      326      2
TestBooleanScorer.testSparseClauseOptimization
                          6       0.6      310      2
TestCloudSchemaless(suite)
                          6       0.6      310      2
TestConfigSetsAPI(suite)
                          6       0.3      310      1
TestConfigSetsAPI.testUpload
                          6       0.3      314      1
TestContentStreamDataSource.testCommitWithin
                          6       0.6      308      2
TestDistribDocBasedVersion(suite)
                          6       0.3      316      1
TestDocTermOrds.testEmptyIndex
                          6       0.6      314      2
TestExternalFeatures(suite)
                          6       0.3      324      1
TestIndexWriter.testSoftUpdatesConcurrently
                          6       0.3      320      1
TestIndexWriterOnVMError(suite)
                          6       4.2       24      1
TestIndexWriterOnVMError.testCheckpoint
                          6       0.9      325      3
TestIndexingSequenceNumbers.testStressUpdateSameID
                          6       0.3      319      1
TestLazyCores.testMidUseUnload
                          6       0.3      311      1
TestMiniSolrCloudClusterSSL.testSslAndNoClientAuth
                          6       0.3      322      1
TestPendingSoftDeletes.testUpdateAppliedOnlyOnce
                          6       2.7      257      7
TestUnInvertedFieldException(suite)
                           789    0.9     1046      9
TestIndexSorting.testRandom3
                           789    1.0      608      6
TestReplicationHandler.doTestIndexAndConfigReplication
                           789   11.1       63      7
TestSolr4Spatial2.testLLPDecodeIsStableAndPrecise
                           78     0.9      665      6
BlockJoinFacetRandomTest(suite)
                           78     0.5      569      3
StreamExpressionTest.testGammaDistribution
                           78     0.6      682      4
SuggesterWFSTTest(suite)
                           78     0.3      719      2
TestIndexSorting(suite)
                           78     3.0      692     21
TestRecovery.testBuffering
                           78     0.9      688      6
TestRecovery.testCorruptLog
                           78     1.3      687      9
TestRecovery.testRecoveryMultipleLogs
                           78     1.3      690      9
TestRecovery.testVersionsOnRestart
                           78     0.6      673      4
TestScoreJoinQPScore(suite)
                           7 9    2.4       82      2
StreamExpressionTest.testDistributions
                           7 9    0.3      648      2
TestComputePlanAction.testNodeWithMultipleReplicasLost
                           7 9    0.8      644      5
TestDFRSimilarityFactory(suite)
                           7      0.3      348      1
ActionThrottleTest.testBasics
                           7      0.9      336      3
AddBlockUpdateTest(suite)
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest(suite)
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testCopyFieldByIndexing
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testMultipleFieldsRoundTrip
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testParseAndAddMultipleFieldsRoundTrip
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testSingleField
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldDefaultFieldTypeRoundTrip
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldDefaultTypeMappingRoundTrip
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldMixedFieldTypesRoundTrip
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldRoundTrip
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testStringWithCopyField
                           7      0.3      339      1
AddSchemaFieldsUpdateProcessorFactoryTest.testStringWithCopyFieldAndMaxChars
                           7      0.9      342      3
AlternateDirectoryTest(suite)
                           7      0.9      338      3
AnalysisAfterCoreReloadTest(suite)
                           7      0.9      333      3
AnalysisErrorHandlingTest(suite)
                           7      0.3      340      1
AnalyticsMergeStrategyTest(suite)
                           7      0.9      336      3
AnalyticsQueryTest(suite)
                           7      0.9      336      3
AtomicUpdateProcessorFactoryTest(suite)
                           7      0.9      339      3
AtomicUpdatesTest(suite)
                           7      0.9      336      3      BJQParserTest(suite)
                           7      0.3      343      1
BadComponentTest(suite)
                           7      0.3      343      1
BadComponentTest.testBadElevate
                           7      0.3      337      1
BadIndexSchemaTest(suite)
                           7      0.3      337      1
BadIndexSchemaTest.testPerFieldtypePostingsFormatButNoSchemaCodecFactory
                           7      0.3      337      1
BadIndexSchemaTest.testRootTypeDynamicMissmatchWithUniqueKey
                           7      0.3      337      1
BadIndexSchemaTest.testSimDefaultFieldTypeDoesNotExist
                           7      0.3      337      1
BadIndexSchemaTest.testSimDefaultFieldTypeHasNoExplicitSim
                           7      0.9      340      3
BasicFunctionalityTest(suite)
                           7      0.9      338      3
BlockJoinFacetSimpleTest(suite)
                           7      0.9      338      3
BooleanFieldTest(suite)
                           7      0.9      340      3
CSVRequestHandlerTest(suite)
                           7      0.3      337      1
ChangedSchemaMergeTest(suite)
                           7      0.3      337      1
ChangedSchemaMergeTest.testOptimizeDiffSchemas
                           7      0.9      337      3
ClassificationUpdateProcessorIntegrationTest(suite)
                           7      1.1      277      3
ClassificationUpdateProcessorTest(suite)
                           7      0.9      334      3
CloneFieldUpdateProcessorFactoryTest(suite)
                           7      0.9      342      3
ConvertedLegacyTest(suite)
                           7      0.9      343      3      CopyFieldTest(suite)
                           7      0.9      337      3
CoreAdminCreateDiscoverTest(suite)
                           7      0.9      338      3
CoreAdminHandlerTest(suite)
                           7      0.9      338      3
CoreAdminRequestStatusTest(suite)
                           7      0.9      340      3
CoreMergeIndexesAdminHandlerTest(suite)
                           7      0.9      339      3
CurrencyFieldTypeTest(suite)
                           7      0.9      340      3      CursorMarkTest(suite)
                           7      0.9      339      3
CursorPagingTest(suite)
                           7      0.3      336      1
DataDrivenBlockJoinTest(suite)
                           7      0.3      336      1
DataDrivenBlockJoinTest.testAddNestedDocuments
                           7      0.9      342      3
DateRangeFieldTest(suite)
                           7      0.9      336      3
DebugComponentTest(suite)
                           7      0.9      340      3
DefaultValueUpdateProcessorTest(suite)
                           7      0.9      343      3
DirectSolrSpellCheckerTest(suite)
                           7      0.9      344      3
DirectUpdateHandlerOptimizeTest(suite)
                           7      0.9      338      3
DirectUpdateHandlerTest(suite)
                           7      0.9      341      3
DisMaxRequestHandlerTest(suite)
                           7      0.9      343      3
DistanceFunctionTest(suite)
                           7      0.9      335      3
DistributedExpandComponentTest(suite)
                           7      0.9      338      3
DistributedQueryComponentCustomSortTest(suite)
                           7      0.9      334      3
DocExpirationUpdateProcessorFactoryTest(suite)
                           7      0.9      336      3
DocValuesMissingTest(suite)
                           7      0.9      341      3
DocValuesMultiTest(suite)
                           7      0.9      340      3      DocValuesTest(suite)
                           7      0.9      341      3
DocumentAnalysisRequestHandlerTest(suite)
                           7      0.9      339      3
DocumentBuilderTest(suite)
                           7      0.9      333      3      EnumFieldTest(suite)
                           7      0.9      337      3
ExitableDirectoryReaderTest(suite)
                           7      0.3      340      1
ExternalFileFieldSortTest(suite)
                           7      0.3      340      1
ExternalFileFieldSortTest.testSort
                           7      0.9      341      3
FastVectorHighlighterTest(suite)
                           7      0.9      338      3
FieldAnalysisRequestHandlerTest(suite)
                           7      0.9      343      3
FieldMutatingUpdateProcessorTest(suite)
                           7      0.9      341      3      GraphQueryTest(suite)
                           7      0.9      336      3
HighlighterConfigTest(suite)
                           7      0.9      339      3
HighlighterMaxOffsetTest(suite)
                           7      0.9      342      3
HighlighterTest(suite)
                           7      0.9      334      3
IgnoreCommitOptimizeUpdateProcessorFactoryTest(suite)
                           7      0.9      335      3
IndexBasedSpellCheckerTest(suite)
                           7      0.9      336      3
IndexSchemaRuntimeFieldTest(suite)
                           7      0.9      335      3
IndexSchemaTest(suite)
                           7      0.9      338      3
InfoHandlerTest(suite)
                           7      0.9      338      3      JSONWriterTest(suite)
                           7      0.9      335      3
JavabinLoaderTest(suite)
                           7      0.9      340      3      JsonLoaderTest(suite)
                           7      0.9      339      3      LargeFieldTest(suite)
                           7      0.9      340      3
LoggingHandlerTest(suite)
                           7      0.9      342      3
LukeRequestHandlerTest(suite)
                           7      0.9      336      3
MBeansHandlerTest(suite)
                           7      0.9      339      3
MergeStrategyTest(suite)
                           7      0.9      335      3
MetricsHandlerTest(suite)
                           7      0.9      339      3
MinimalSchemaTest(suite)
                           7      0.9      342      3
MoreLikeThisHandlerTest(suite)
                           7      0.9      337      3      MultiTermTest(suite)
                           7      0.9      340      3
NodeMutatorTest(suite)
                           7      0.9      339      3
NotRequiredUniqueKeyTest(suite)
                           7      0.9      335      3
NumericFieldsTest(suite)
                           7      0.9      339      3
ParsingFieldUpdateProcessorsTest(suite)
                           7      0.9      339      3
PathHierarchyTokenizerFactoryTest(suite)
                           7      0.6      342      2      PeerSyncTest(suite)
                           7      0.3      342      1      PeerSyncTest.test
                           7      0.9      338      3
PingRequestHandlerTest(suite)
                           7      0.9      338      3      PolyFieldTest(suite)
                           7      0.9      339      3
PreAnalyzedFieldTest(suite)
                           7      0.9      337      3
PreAnalyzedUpdateProcessorTest(suite)
                           7      0.9      340      3
PropertiesRequestHandlerTest(suite)
                           7      0.3      342      1
QueryElevationComponentTest(suite)
                           7      0.3      342      1
QueryElevationComponentTest.testElevationReloading
                           7      0.3      342      1
QueryElevationComponentTest.testFieldType
                           7      0.3      342      1
QueryElevationComponentTest.testGroupedQuery
                           7      0.3      342      1
QueryElevationComponentTest.testInterface
                           7      0.3      342      1
QueryElevationComponentTest.testMarkExcludes
                           7      0.3      342      1
QueryElevationComponentTest.testMarker
                           7      0.3      342      1
QueryElevationComponentTest.testSorting
                           7      0.3      342      1
QueryElevationComponentTest.testTrieFieldType
                           7      0.3      342      1
QueryElevationComponentTest.testWithLocalParam
                           7      0.9      336      3
QueryParsingTest(suite)
                           7      0.9      341      3      RankQueryTest(suite)
                           7      0.9      340      3
RegexBoostProcessorTest(suite)
                           7      0.9      341      3
RequestHandlersTest(suite)
                           7      0.9      339      3
RequestLoggingTest(suite)
                           7      0.9      344      3
RequiredFieldsTest(suite)
                           7      0.9      339      3
ResponseBuilderTest(suite)
                           7      0.9      341      3
ResponseLogComponentTest(suite)
                           7      0.9      340      3
ReturnFieldsTest(suite)
                           7      0.3      347      1
SchemaVersionSpecificBehaviorTest(suite)
                           7      0.3      347      1
SchemaVersionSpecificBehaviorTest.testVersionBehavior
                           7      0.9      679      6
SearchHandlerTest(suite)
                           7      0.9      336      3
SegmentsInfoRequestHandlerTest(suite)
                           7      0.3      340      1
ShowFileRequestHandlerTest(suite)
                           7      0.3      340      1
ShowFileRequestHandlerTest.test404Locally
                           7      0.9      339      3
SignatureUpdateProcessorFactoryTest(suite)
                           7      0.9      338      3
SimpleFacetsTest(suite)
                           7      0.9      334      3
SimpleMLTQParserTest(suite)
                           7      0.9      337      3
SmileWriterTest(suite)
                           7      1.0      315      3
SoftAutoCommitTest(suite)
                           7      0.3      337      1
SolrCoreMetricManagerTest(suite)
                           7      0.3      337      1
SolrCoreMetricManagerTest.testLoadReporter
                           7      0.3      337      1
SolrCoreMetricManagerTest.testNonCloudRegistryName
                           7      0.3      337      1
SolrCoreMetricManagerTest.testRegisterMetrics
                           7      0.3      337      1
SolrCoreMetricManagerTest.testRegisterMetricsWithReplacements
                           7      0.3      342      1      SolrCoreTest(suite)
                           7      0.3      342      1
SolrCoreTest.testClose
                           7      0.3      342      1
SolrCoreTest.testConfiguration
                           7      0.3      342      1
SolrCoreTest.testImplicitPlugins
                           7      0.3      342      1
SolrCoreTest.testInfoRegistry
                           7      0.3      342      1
SolrCoreTest.testRefCount
                           7      0.3      342      1
SolrCoreTest.testRefCountMT
                           7      0.3      342      1
SolrCoreTest.testReloadLeak
                           7      0.4      275      1
SolrGangliaReporterTest(suite)
                           7      0.4      275      1
SolrGangliaReporterTest.testReporter
                           7      0.3      337      1
SolrGraphiteReporterTest(suite)
                           7      0.3      337      1
SolrGraphiteReporterTest.testReporter
                           7      0.9      339      3
SolrIndexConfigTest(suite)
                           7      0.3      340      1
SolrIndexMetricsTest(suite)
                           7      0.3      340      1
SolrIndexMetricsTest.testIndexMetricsNoDetails
                           7      0.3      340      1
SolrIndexMetricsTest.testIndexMetricsWithDetails
                           7      0.3      340      1
SolrIndexMetricsTest.testIndexNoMetrics
                           7      0.9      340      3
SolrIndexSplitterTest(suite)
                           7      0.9      340      3
SolrInfoBeanTest(suite)
                           7      0.3      340      1
SolrJmxReporterTest.testClosedCore
                           7      0.3      340      1
SolrJmxReporterTest.testEnabled
                           7      0.3      340      1
SolrJmxReporterTest.testReloadCore
                           7      0.3      340      1
SolrJmxReporterTest.testReportMetrics
                           7      0.3      347      1
SolrMetricsIntegrationTest(suite)
                           7      0.3      347      1
SolrMetricsIntegrationTest.testConfigureReporter
                           7      0.3      347      1
SolrMetricsIntegrationTest.testCoreContainerMetrics
                           7      0.9      339      3
SolrPluginUtilsTest(suite)
                           7      1.1      280      3
SolrRequestParserTest(suite)
                           7      0.3      335      1
SolrSlf4jReporterTest(suite)
                           7      0.9      340      3
SolrTestCaseJ4Test(suite)
                           7      0.9      338      3
SortByFunctionTest(suite)
                           7      0.9      338      3
SortSpecParsingTest(suite)
                           7      0.9      342      3
SpatialFilterTest(suite)
                           7      0.9      345      3
SpellCheckCollatorTest(suite)
                           7      0.9      336      3
SpellCheckCollatorWithCollapseTest(suite)
                           7      0.9      337      3
SpellCheckComponentTest(suite)
                           7      0.9      343      3
StatelessScriptUpdateProcessorFactoryTest(suite)
                           7      0.9      342      3
StatsComponentTest(suite)
                           7      0.9      336      3
StatsReloadRaceTest(suite)
                           7      0.7      150      1
StreamDecoratorTest.testParallelExecutorStream
                           7      0.9      338      3
SuggestComponentContextFilterQueryTest(suite)
                           7      0.9      340      3
SuggestComponentTest(suite)
                           7      0.9      342      3
SuggesterFSTTest(suite)
                           7      0.9      337      3
SuggesterTSTTest(suite)
                           7      0.9      344      3      SuggesterTest(suite)
                           7      0.9      339      3
SynonymTokenizerTest(suite)
                           7      0.9      341      3
TermVectorComponentTest(suite)
                           7      0.9      337      3
TermsComponentTest(suite)
                           7      0.3      339      1
TestAddFieldRealTimeGet(suite)
                           7      0.3      339      1
TestAddFieldRealTimeGet.test
                           7      0.9      343      3
TestAnalyzeInfixSuggestions(suite)
                           7      0.9      338      3
TestAnalyzedSuggestions(suite)
                           7      0.3      339      1
TestAtomicUpdateErrorCases(suite)
                           7      0.3      339      1
TestAtomicUpdateErrorCases.testUpdateNoDistribProcessor
                           7      0.3      339      1
TestAtomicUpdateErrorCases.testUpdateNoTLog
                           7      0.9      338      3
TestBM25SimilarityFactory(suite)
                           7      0.3      339      1      TestBadConfig(suite)
                           7      0.3      339      1
TestBadConfig.testBogusMergePolicy
                           7      0.3      339      1
TestBadConfig.testBogusScriptEngine
                           7      0.3      339      1
TestBadConfig.testInvalidScriptFile
                           7      0.3      339      1
TestBadConfig.testMissingScriptFile
                           7      0.3      339      1
TestBadConfig.testTolerantUpdateProcessorNoUniqueKey
                           7      0.3      339      1
TestBadConfig.testUpdateLogButNoVersionField
                           7      0.3      354      1
TestBinaryDocValuesUpdates(suite)
                           7      0.9      336      3
TestBinaryResponseWriter(suite)
                           7      0.9      337      3
TestBlendedInfixSuggestions(suite)
                           7      0.9      339      3      TestCSVLoader(suite)
                           7      0.9      344      3
TestCSVResponseWriter(suite)
                           7      0.9      341      3
TestCharFilters(suite)
                           7      0.9      341      3
TestChildDocTransformer(suite)
                           7      0.9      338      3
TestClassicSimilarityFactory(suite)
                           7      0.9      340      3
TestCodecSupport(suite)
                           7      0.9      339      3
TestCollapseQParserPlugin(suite)
                           7      0.9      343      3
TestCollationField(suite)
                           7      0.9      336      3
TestCollationFieldDocValues(suite)
                           7      0.9      340      3
TestComplexPhraseLeadingWildcard(suite)
                           7      0.9      335      3
TestComplexPhraseQParserPlugin(suite)
                           7      0.9      337      3
TestComponentsName(suite)
                           7      0.9      340      3      TestConfig(suite)
                           7      0.3      339      1      TestConfigSets(suite)
                           7      0.3      339      1
TestConfigSets.testConfigSetOnCoreReload
                           7      0.3      339      1
TestConfigSets.testConfigSetServiceFindsConfigSets
                           7      0.3      339      1
TestConfigSets.testNonExistentConfigSetThrowsException
                           7      0.9      339      3      TestCoreBackup(suite)
                           7      0.3      341      1
TestCoreContainer(suite)
                           7      0.3      341      1
TestCoreContainer.testClassLoaderHierarchy
                           7      0.3      341      1
TestCoreContainer.testCoreInitFailuresFromEmptyContainer
                           7      0.3      341      1
TestCoreContainer.testCoreInitFailuresOnReload
                           7      0.3      341      1
TestCoreContainer.testCustomHandlers
                           7      0.3      341      1
TestCoreContainer.testDeleteBadCores
                           7      0.3      341      1
TestCoreContainer.testLogWatcherEnabledByDefault
                           7      0.3      341      1
TestCoreContainer.testNoCores
                           7      0.3      341      1
TestCoreContainer.testReloadSequential
                           7      0.3      341      1
TestCoreContainer.testReloadThreaded
                           7      0.3      341      1
TestCoreContainer.testShareSchema
                           7      0.3      341      1
TestCoreContainer.testSharedLib
                           7      0.3      341      1
TestCorePropertiesReload(suite)
                           7      0.3      341      1
TestCorePropertiesReload.testPropertiesReload
                           7      0.9      343      3
TestCrossCoreJoin(suite)
                           7      0.3      341      1
TestCursorMarkWithoutUniqueKey(suite)
                           7      0.3      341      1
TestCursorMarkWithoutUniqueKey.test
                           7      0.9      335      3
TestCustomDocTransformer(suite)
                           7      0.3      353      1
TestCustomSearcherSort(suite)
                           7      0.3      353      1
TestCustomSearcherSort.testFieldSortCustomSearcher
                           7      0.3      353      1
TestCustomSearcherSort.testFieldSortSingleSearcher
                           7      0.9      341      3      TestCustomSort(suite)
                           7      0.9      341      3
TestDFISimilarityFactory(suite)
                           7      0.9      339      3
TestDocBasedVersionConstraints(suite)
                           7      0.3      345      1
TestDocTermOrds.testRandomWithPrefix
                           7      0.3      345      1
TestDocTermOrds.testSimple
                           7      0.9      339      3
TestElisionMultitermQuery(suite)
                           7      0.3      344      1
TestEmbeddedSolrServerAdminHandler(suite)
                           7      0.3      344      1
TestEmbeddedSolrServerAdminHandler.testPathIsAddedToContext
                           7      0.3      339      1
TestEmbeddedSolrServerConstructors(suite)
                           7      0.3      339      1
TestEmbeddedSolrServerConstructors.testNodeConfigConstructor
                           7      1.2      336      4
TestEmbeddedSolrServerSchemaAPI(suite)
                           7      0.9      339      3
TestExceedMaxTermLength(suite)
                           7      0.9      339      3
TestExpandComponent(suite)
                           7      0.9      336      3
TestExportWriter(suite)
                           7      0.9      337      3
TestExtendedDismaxParser(suite)
                           7      0.9      341      3      TestFaceting(suite)
                           7      0.9      338      3
TestFieldSortValues(suite)
                           7      0.9      339      3
TestFileDictionaryLookup(suite)
                           7      0.9      340      3      TestFiltering(suite)
                           7      0.9      344      3
TestFoldingMultitermQuery(suite)
                           7      0.9      338      3
TestFreeTextSuggestions(suite)
                           7      0.9      340      3
TestFunctionQuery(suite)
                           7      0.9      343      3
TestFuzzyAnalyzedSuggestions(suite)
                           7      0.9      340      3
TestGeoJSONResponseWriter(suite)
                           7      0.9      335      3
TestGraphMLResponseWriter(suite)
                           7      0.9      336      3
TestGraphTermsQParserPlugin(suite)
                           7      0.9      339      3
TestGroupingSearch(suite)
                           7      0.9      337      3
TestHalfAndHalfDocValues(suite)
                           7      0.9      341      3
TestHashQParserPlugin(suite)
                           7      0.9      334      3
TestHighFrequencyDictionaryFactory(suite)
                           7      0.3      346      1
TestHttpShardHandlerFactory.testLoadBalancerRequestsMinMax
                           7      0.9      341      3
TestIBSimilarityFactory(suite)
                           7      0.9      334      3
TestInPlaceUpdatesStandalone(suite)
                           7      0.9      341      3
TestIndexSearcher(suite)
                           7      0.3      354      1
TestIndexSorting.testMissingMultiValuedFloatLast
                           7      0.3      353      1
TestIndexWriterOnVMError.testOOM
                           7      0.9      338      3
TestIndexingPerformance(suite)
                           7      0.9      337      3      TestInitParams(suite)
                           7      0.3      340      1
TestInitQParser(suite)
                           7      0.3      340      1
TestInitQParser.testQueryParserInit
                           7      0.9      339      3
TestIntervalFaceting(suite)
                           7      1.9      308      6
TestIntervalQuery.testOrderedNearQueryWidth3
                           7      0.3      308      1
TestIntervalQuery.testOrderedNearQueryWidth4
                           7      0.3      339      1
TestJettySolrRunner(suite)
                           7      0.3      339      1
TestJettySolrRunner.testPassSolrHomeToRunner
                           7      0.9      341      3
TestJmxIntegration(suite)
                           7      0.9      339      3      TestJoin(suite)
                           7      0.9      338      3
TestJsonFacetRefinement(suite)
                           7      0.9      341      3      TestJsonFacets(suite)
                           7      0.3     2046      6
TestJsonFacets.testComplex
                           7      0.9      339      3
TestJsonFacetsWithNestedObjects(suite)
                           7      0.9      337      3
TestJsonRequest(suite)
                           7      0.6      349      2
TestLBHttpSolrClient.testReliability
                           7      0.9      336      3      TestLFUCache(suite)
                           7      0.9      341      3
TestLMDirichletSimilarityFactory(suite)
                           7      0.3      337      1
TestLMJelinekMercerSimilarityFactory(suite)
                           7      0.3      342      1
TestLazyCores.testBadConfigsGenerateErrors
                           7      0.3      354      1
TestLucene70DocValuesFormat(suite)
                           7      0.3      354      1
TestLucene70DocValuesFormat.testGCDCompression
                           7      0.3      342      1
TestLuceneIndexBackCompat(suite)
                           7      0.3      342      1
TestLuceneIndexBackCompat.testOldIndexes
                           7      0.9      343      3
TestLuceneMatchVersion(suite)
                           7      0.9      340      3      TestMacros(suite)
                           7      0.3      343      1
TestManagedSchema(suite)
                           7      0.3      343      1
TestManagedSchema.testAddDynamicField
                           7      0.3      343      1
TestManagedSchema.testAddFieldPersistence
                           7      0.3      343      1
TestManagedSchema.testAddFieldThenReload
                           7      0.3      343      1
TestManagedSchema.testAddFieldWhenItAlreadyExists
                           7      0.3      343      1
TestManagedSchema.testAddFieldWhenNotMutable
                           7      0.3      343      1
TestManagedSchema.testAddSameFieldTwice
                           7      0.3      343      1
TestManagedSchema.testAddWithSchemaCodecFactory
                           7      0.3      343      1
TestManagedSchema.testAddWithSchemaSimilarityFactory
                           7      0.3      343      1
TestManagedSchema.testAddedFieldIndexableAndQueryable
                           7      0.3      343      1
TestManagedSchema.testDefaultSchemaFactory
                           7      0.3      343      1
TestManagedSchema.testPersistUniqueKey
                           7      0.3      343      1
TestManagedSchema.testUpgrade
                           7      0.3      343      1
TestManagedSchema.testUpgradeThenRestart
                           7      0.3      343      1
TestManagedSchema.testUpgradeThenRestartNonManaged
                           7      0.3      343      1
TestManagedSchema.testUpgradeThenRestartNonManagedAfterPuttingBackNonManagedSchema
                           7      0.9      340      3
TestMaxScoreQueryParser(suite)
                           7      0.9      335      3
TestMaxTokenLenTokenizer(suite)
                           7      0.3      341      1
TestMergePolicyConfig(suite)
                           7      0.3      341      1
TestMergePolicyConfig.testDefaultMergePolicyConfig
                           7      0.3      341      1
TestMergePolicyConfig.testLegacyMergePolicyConfig
                           7      0.3      341      1
TestMergePolicyConfig.testLogMergePolicyFactoryConfig
                           7      0.3      341      1
TestMergePolicyConfig.testNoMergePolicyFactoryConfig
                           7      0.3      341      1
TestMergePolicyConfig.testSetNoCFSMergePolicyConfig
                           7      0.3      341      1
TestMergePolicyConfig.testTieredMergePolicyConfig
                           7      0.9      337      3
TestMinMaxOnMultiValuedField(suite)
                           7      0.9      334      3
TestMissingGroups(suite)
                           7      0.3      355      1
TestMixedDocValuesUpdates.testStressMultiThreading
                           7      0.9      340      3
TestMultiWordSynonyms(suite)
                           7      0.9      339      3
TestNestedDocsSort(suite)
                           7      0.9      340      3
TestNoOpRegenerator(suite)
                           7      0.3      348      1
TestNodeAddedTrigger.testRestoreState
                           7      0.6      348      2
TestNodeAddedTrigger.testTrigger
                           7      0.3      339      1
TestNonDefinedSimilarityFactory(suite)
                           7      0.3      339      1
TestNonDefinedSimilarityFactory.testCurrentBM25
                           7      0.9      341      3
TestOmitPositions(suite)
                           7      0.9      335      3
TestOverriddenPrefixQueryForCustomFieldType(suite)
                           7      0.9      339      3
TestPHPSerializedResponseWriter(suite)
                           7     50.0        2      1
TestPKIAuthenticationPlugin.testGetBaseUrlForNodeNameLocal
                           7      0.9      339      3
TestPartialUpdateDeduplication(suite)
                           7      0.9      336      3
TestPayloadCheckQParserPlugin(suite)
                           7      0.9      339      3
TestPayloadScoreQParserPlugin(suite)
                           7      0.3      354      1
TestPerFieldDocValuesFormat(suite)
                           7      0.3      356      1
TestPerFieldDocValuesFormat.testSparseBinaryFixedLengthVsStoredFields
                           7      0.9      337      3
TestPerFieldSimilarity(suite)
                           7      0.9      335      3
TestPerFieldSimilarityWithDefaultOverride(suite)
                           7      0.9      342      3
TestPhraseSuggestions(suite)
                           7      0.9      337      3
TestPointFields(suite)
                           7      0.3      353      1
TestPointQueries(suite)
                           7      3.1       32      1
TestPointQueries.testRandomLongsBig
                           7      0.9      340      3
TestPostingsSolrHighlighter(suite)
                           7      0.9      338      3
TestPseudoReturnFields(suite)
                           7      0.9      337      3
TestQuerySenderListener(suite)
                           7      0.9      339      3
TestQuerySenderNoQuery(suite)
                           7      0.9      338      3      TestQueryTypes(suite)
                           7      0.9      338      3      TestQueryUtils(suite)
                           7      0.9      342      3
TestRandomCollapseQParserPlugin(suite)
                           7      0.9      340      3
TestRandomDVFaceting(suite)
                           7      0.9      342      3
TestRandomFaceting(suite)
                           7      0.9      341      3      TestRangeQuery(suite)
                           7      0.9      338      3
TestRawResponseWriter(suite)
                           7      0.9      339      3
TestRawTransformer(suite)
                           7      0.9      338      3
TestReRankQParserPlugin(suite)
                           7      0.9      343      3
TestRealTimeGet(suite)
                           7      0.9      339      3      TestRecovery(suite)
                           7      0.9      346      3
TestRecovery.testCleanShutdown
                           7      1.2      345      4
TestRecovery.testDropBuffered
                           7      0.9      340      3      TestReload(suite)
                           7      1.1      280      3
TestReversedWildcardFilterFactory(suite)
                           7      0.9      336      3
TestSchemalessBufferedUpdates(suite)
                           7      0.9      342      3
TestScoreJoinQPNoScore(suite)
                           7      0.9      337      3      TestSearchPerf(suite)
                           7      0.9      336      3
TestSearcherReuse(suite)
                           7      0.3      339      1
TestShardHandlerFactory.testXML
                           7      0.9      337      3
TestSimpleTextCodec(suite)
                           7      0.9      341      3
TestSmileRequest(suite)
                           7      0.8      244      2
TestSoftDeletesRetentionMergePolicy(suite)
                           7      0.4      243      1
TestSoftDeletesRetentionMergePolicy.testKeepAllDocsAcrossMerges
                           7      0.8      244      2
TestSoftDeletesRetentionMergePolicy.testSoftDeleteWithRetention
                           7      0.9      342      3
TestSolr4Spatial(suite)
                           7      0.9      337      3
TestSolr4Spatial2(suite)
                           7      0.9      341      3
TestSolrDeletionPolicy1(suite)
                           7      0.9      341      3
TestSolrDeletionPolicy2(suite)
                           7      0.9      335      3
TestSolrFieldCacheBean(suite)
                           7      0.9      337      3
TestSolrQueryParser(suite)
                           7      0.9      343      3      TestSort(suite)
                           7      0.9      340      3
TestSortByMinMaxFunction(suite)
                           7      0.9      340      3
TestSortableTextField(suite)
                           7      0.9      337      3
TestStressInPlaceUpdates(suite)
                           7      0.3      346      1
TestStressLucene.testStressLuceneNRT
                           7      0.9      317      3
TestStressRecovery(suite)
                           7      0.9      339      3
TestStressReorder(suite)
                           7      0.9      333      3
TestStressUserVersions(suite)
                           7      0.9      342      3
TestStressVersions(suite)
                           7      0.9      338      3
TestSubQueryTransformer(suite)
                           7      0.9      337      3
TestSubQueryTransformerCrossCore(suite)
                           7      1.2      338      4
TestSubQueryTransformerDistrib(suite)
                           7      0.9      344      3
TestSurroundQueryParser(suite)
                           7      0.9      340      3
TestSweetSpotSimilarityFactory(suite)
                           7      0.3      347      1
TestTlogReplica(suite)
                           7      0.9      340      3      TestTrie(suite)
                           7      0.9      336      3      TestTrieFacet(suite)
                           7      0.9      336      3
TestUnifiedSolrHighlighter(suite)
                           7      0.9      338      3      TestUpdate(suite)
                           7      0.6      339      2
TestUseDocValuesAsStored(suite)
                           7      0.3      344      1
TestUseDocValuesAsStored.testDuplicateMultiValued
                           7      0.3      344      1
TestUseDocValuesAsStored.testManagedSchema
                           7      0.3      344      1
TestUseDocValuesAsStored.testMultipleSearchResults
                           7      0.3      344      1
TestUseDocValuesAsStored.testMultivaluedOrdering
                           7      0.3      344      1
TestUseDocValuesAsStored.testOnEmptyIndex
                           7      0.3      344      1
TestUseDocValuesAsStored.testRandomSingleAndMultiValued
                           7      0.3      344      1
TestUseDocValuesAsStored.testUseDocValuesAsStoredFalse
                           7      0.9      337      3
TestValueSourceCache(suite)
                           7      0.9      336      3
TestWordDelimiterFilterFactory(suite)
                           7      0.9      337      3      TestWriterPerf(suite)
                           7      0.9      343      3
TestXIncludeConfig(suite)
                           7      0.9      338      3
TestXmlQParserPlugin(suite)
                           7      0.9      336      3
TolerantUpdateProcessorTest(suite)
                           7      0.3      343      1
TriggerIntegrationTest.testTriggerThrottling
                           7      0.9      339      3
UUIDUpdateProcessorFallbackTest(suite)
                           7      0.3      342      1
UninvertDocValuesMergePolicyTest(suite)
                           7      0.3      342      1
UninvertDocValuesMergePolicyTest.testNonIndexedFieldDoesNonFail
                           7      0.9      339      3
UniqFieldsUpdateProcessorFactoryTest(suite)
                           7      0.9      337      3      UpdateLogTest(suite)
                           7      0.9      336      3
UpdateParamsTest(suite)
                           7      0.9      340      3
UpdateRequestProcessorFactoryTest(suite)
                           7      0.3      341      1
VersionInfoTest(suite)
                           7      0.3      341      1
VersionInfoTest.testMaxDocValuesVersionFromIndex
                           7      0.3      341      1
VersionInfoTest.testMaxIndexedVersionFromIndex
                           7      0.9      339      3
WordBreakSolrSpellCheckerTest(suite)
                           7      0.9      339      3
XmlUpdateRequestHandlerTest(suite)
                           7      0.9      339      3
XsltUpdateRequestHandlerTest(suite)
                            89   19.1      320     61
AtomicUpdateProcessorFactoryTest.testMultipleThreads
                            89    0.3      705      2
StreamExpressionTest.testParallelExecutorStream
                            89    0.3      691      2
TestIndexSorting.testMissingDoubleFirst
                            89    0.4      691      3
TestIndexSorting.testMultiValuedRandom1
                            89    0.3      687      2
TestIndexWriterDelete(suite)
                            89    0.9      645      6
TriggerIntegrationTest(suite)
                            89    0.3      572      2
TriggerIntegrationTest.testNodeAddedTriggerRestoreState
                            89    5.6       89      5
TriggerIntegrationTest.testNodeMarkersRegistration
                            89    0.5      572      3
TriggerIntegrationTest.testSetProperties
                            8     0.6      357      2
BlockDirectoryTest.testRandomAccessWrites
                            8     0.3      336      1
CollectionPropsTest.testReadWriteCached
                            8     1.2      331      4      DeleteNodeTest(suite)
                            8     0.3      350      1
GraphExpressionTest(suite)
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.deleteCollectionOnlyInZk
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.deleteCollectionRemovesStaleZkCollectionsNode
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.deletePartiallyCreatedCollection
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.moveReplicaTest
                            8     3.1       32      1
HdfsCollectionsAPIDistributedZkTest.testCollectionReload
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testCoresAreDistributedAcrossNodes
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testCreateShouldFailOnExistingCore
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testCreationAndDeletion
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testDeleteNonExistentCollection
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testMissingNumShards
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testMissingRequiredParameters
                            8     2.6       38      1
HdfsCollectionsAPIDistributedZkTest.testSpecificConfigsets
                            8     4.3       23      1
HdfsWriteToMultipleCollectionsTest.test
                            8     0.3      333      1
SolrJmxReporterCloudTest(suite)
                            8     0.3      361      1
StreamExpressionTest.testInnerJoinStream
                            8     0.3      338      1
TestAuthorizationFramework.authorizationFrameworkTest
                            8     0.3      345      1
TestCrossCoreJoin.testJoin
                            8     0.3      345      1
TestCrossCoreJoin.testScoreJoin
                            8     0.3      332      1
TestCustomStream.testDynamicLoadingCustomStream
                            8     0.3      360      1
TestDemoParallelLeafReader(suite)
                            8     0.3      360      1
TestDemoParallelLeafReader.testRandomMultipleSchemaGensSameField
                            8     0.3      364      1
TestIndexWriterDelete.testDeletesOnDiskFull
                            8     0.3      363      1
TestIndexWriterThreadsToSegments(suite)
                            8     0.3      363      1
TestIndexWriterThreadsToSegments.testSegmentCountOnFlushRandom
                            8     0.3      363      1
TestNumericDocValuesUpdates.testBiasedMixOfRandomUpdates
                            8     0.3      363      1
TestNumericDocValuesUpdates.testDocumentWithNoValue
                            8     0.3      333      1
TestReplicationHandlerBackup.doTestBackup
                            8     0.5      219      1
TestSolrCloudWithHadoopAuthPlugin.testBasics
                            8     0.3      331      1
TestStressCloudBlindAtomicUpdates.test_stored_idx
                            8     0.4      254      1
TriggerIntegrationTest.testCooldown
                            8     0.4      254      1
TriggerIntegrationTest.testMetricTrigger
                            8     0.3      336      1
ZkStateWriterTest(suite)
                             9    0.3      305      1
AutoScalingHandlerTest.testConcurrentUpdates
                             9    0.3      304      1
CdcrVersionReplicationTest.testCdcrDocVersions
                             9    0.3      311      1
CollectionsAPISolrJTest.testCreateAndDeleteCollection
                             9    0.3      311      1
CollectionsAPISolrJTest.testCreateAndDeleteShard
                             9    0.4      255      1
HdfsNNFailoverTest.test
                             9    3.3       30      1
LIROnShardRestartTest.testSeveralReplicasInLIR
                             9    0.4      254      1
MoveReplicaHDFSFailoverTest.testOldReplicaIsDeleted
                             9    0.3      315      1      NoFacetTest(suite)
                             9    0.7      303      2
OverseerRolesTest(suite)
                             9    0.3      344      1
StreamExpressionTest.testCopyOfRange
                             9    0.9      344      3
StreamExpressionTest.testParallelCommitStream
                             9    1.0      310      3      SyncSliceTest(suite)
                             9    0.3      304      1
TestBlobHandler.doBlobHandlerTest
                             9    0.3      306      1
TestCollectionsAPIViaSolrCloudCluster(suite)
                             9    0.3      306      1
TestDistribIDF.testMultiCollectionQuery
                             9    1.3      318      4
TestFileListEntityProcessor.testNTOT
                             9    0.3      324      1
TestIndexSorting.testConcurrentUpdates
                             9    0.3      323      1
TestIndexWriterDelete.testUpdatesOnDiskFull
                             9    0.6      324      2
TestIndexWriterOnVMError.testUnknownError
                             9    0.6      315      2
TestLTROnSolrCloud(suite)
                             9    0.3      318      1
TestLTROnSolrCloud.testSimpleQuery
                             9    0.3      329      1
TestLucene50CompoundFormat.testLargeCFS
                             9    0.3      304      1
TestNodeLostTrigger.testTrigger
                             9    0.3      310      1
TestRebalanceLeaders.test
                             9    0.3      373      1
TestReplicationHandler.doTestDetails
                             9    0.3      373      1
TestReplicationHandler.doTestStopPoll
                             9    0.3      306      1
TestShortCircuitedRequests(suite)
                             9    0.3      310      1
TestShortCircuitedRequests.test
                             9    0.3      314      1
TestTlogReplica.testRemoveLeader
                             9    0.6      318      2
TriggerIntegrationTest.testListeners
                             9    0.9      318      3
TriggerIntegrationTest.testNodeAddedTrigger
                             9    0.9      318      3
TriggerIntegrationTest.testNodeLostTrigger
                             9    1.9       53      1
TriggerIntegrationTest.testSearchRate
                             9    0.6      316      2      ValueFacetTest(suite)
                             9    0.3      322      1
ValueFacetTest.meanTest
Number of AwaitsFix: 16 Number of BadApples: 111

*****************AwaitsFix Annotations:


************Lucene AwaitsFix
TestControlledRealTimeReopenThread.testCRTReopen
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")

TestICUNormalizer2CharFilter.testRandomStrings
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")

TestICUTokenizerCJK.TestICUTokenizerCJK suite
   @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")

TestMoreLikeThis.testMultiFieldShouldReturnPerFieldBooleanQuery
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")

UIMABaseAnalyzerTest.testRandomStrings
   @Test @AwaitsFix(bugUrl =
"https://issues.apache.org/jira/browse/LUCENE-3869")

UIMABaseAnalyzerTest.testRandomStringsWithConfigurationParameters
   @Test @AwaitsFix(bugUrl =
"https://issues.apache.org/jira/browse/LUCENE-3869")

UIMATypeAwareAnalyzerTest.testRandomStrings
   @Test @AwaitsFix(bugUrl =
"https://issues.apache.org/jira/browse/LUCENE-3869")


    ************Solr AwaitsFix
ConcurrentCreateRoutedAliasTest.ConcurrentCreateRoutedAliasTest suite
   @LuceneTestCase.AwaitsFix(bugUrl =
"https://issues.apache.org/jira/browse/SOLR-12386") // "Can't find
resource"

ReplaceNodeNoTargetTest.ReplaceNodeNoTargetTest suite
   @LuceneTestCase.AwaitsFix(bugUrl =
"https://issues.apache.org/jira/browse/SOLR-11067")

TestCollapseQParserPlugin.testStringCollapse
   @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")

TestImpersonationWithHadoopAuth.testForwarding
   @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")

TestLTRReRankingPipeline.testDifferentTopN
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")

TestMinMaxOnMultiValuedField.testDoubleFieldCache
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")

TestMinMaxOnMultiValuedField.testFloatFieldCache
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")

TestMinMaxOnMultiValuedField.testIntFieldCache
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")

TestMinMaxOnMultiValuedField.testLongFieldCache
   @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")



*****************BadApple Annotations:

************Lucene BadApple

    ************Solr BadApple
AddReplicaTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

AssignBackwardCompatibilityTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

AutoAddReplicasIntegrationTest.testSimple
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

AutoAddReplicasPlanActionTest.testSimple
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

AutoScalingHandlerTest.testReadApi
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

AutoscalingHistoryHandlerTest.testHistory
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

BasicAuthIntegrationTest.testBasicAuth
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

CdcrBootstrapTest.testBootstrapWithContinousIndexingOnSourceCluster
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

CdcrReplicationDistributedZkTest.CdcrReplicationDistributedZkTest suite
   @BadApple(bugUrl =
"https://issues.apache.org/jira/browse/SOLR-12028,
https://issues.apache.org/jira/browse/SOLR-10107")

ChaosMonkeyNothingIsSafeTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

ChaosMonkeySafeLeaderTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ChaosMonkeySafeLeaderWithPullReplicasTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

CollectionsAPIDistributedZkTest.testCollectionsAPI
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ComputePlanActionTest.testNodeLost
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

ComputePlanActionTest.testSelectedCollections
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

CustomCollectionTest.testCustomCollectionsAPI
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

DeleteReplicaTest.deleteReplicaOnIndexing
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

DocValuesNotIndexedTest.testGroupingDVOnly
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

DocValuesNotIndexedTest.testGroupingDocAbsent
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

DocValuesNotIndexedTest.testGroupingSorting
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 26-Mar-2018

ForceLeaderTest.testReplicasInLIRNoLeader
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ForceLeaderTest.testReplicasInLowerTerms
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

HdfsBasicDistributedZk2Test.HdfsBasicDistributedZk2Test suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 26-Mar-2018

HdfsChaosMonkeyNothingIsSafeTest.HdfsChaosMonkeyNothingIsSafeTest suite
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
https://issues.apache.org/jira/browse/SOLR-10191")

HdfsDirectoryTest.testEOF
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

HdfsRecoveryZkTest.HdfsRecoveryZkTest suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

HdfsRestartWhileUpdatingTest.HdfsRestartWhileUpdatingTest suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
//2018-03-10

HdfsTlogReplayBufferedWhileIndexingTest.HdfsTlogReplayBufferedWhileIndexingTest
suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

HdfsUnloadDistributedZkTest.HdfsUnloadDistributedZkTest suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

HttpPartitionTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

IndexSizeTriggerTest.testMergeIntegration
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

IndexSizeTriggerTest.testSplitIntegration
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

IndexSizeTriggerTest.testTrigger
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

LIRRollingUpdatesTest.testNewLeaderAndMixedReplicas
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

LIRRollingUpdatesTest.testNewLeaderOldReplica
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

LIRRollingUpdatesTest.testNewReplicaOldLeader
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

LIRRollingUpdatesTest.testOldLeaderAndMixedReplicas
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

LeaderElectionIntegrationTest.testSimpleSliceLeaderElection
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

LeaderFailoverAfterPartitionTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

LeaderVoteWaitTimeoutTest.basicTest
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

LegacyCloudClusterPropTest.testCreateCollectionSwitchLegacyCloud
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

MathExpressionTest.testDistributions
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

MathExpressionTest.testGammaDistribution
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

MathExpressionTest.testMultiVariateNormalDistribution
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
//2018-03-10

MissingSegmentRecoveryTest.testLeaderRecovery
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

MoveReplicaHDFSTest.testNormalFailedMove
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

MoveReplicaHDFSTest.testNormalMove
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
//2018-03-10

MoveReplicaTest.testFailedMove
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 17-Mar-2018 This JIRA is fixed, but this test still fails

MultiThreadedOCPTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

NodeLostTriggerTest.testListenerAcceptance
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 16-Apr-2018

OverseerRolesTest.testOverseerRole
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

PeerSyncReplicationTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ReplaceNodeNoTargetTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ReplicationFactorTest.ReplicationFactorTest suite
   @LuceneTestCase.BadApple(bugUrl =
"https://issues.apache.org/jira/browse/SOLR-6944")

RestartWhileUpdatingTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

SSLMigrationTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 17-Mar-2018

ScheduledMaintenanceTriggerTest.testInactiveShardCleanup
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 17-Mar-2018

ScheduledTriggerIntegrationTest.ScheduledTriggerIntegrationTest suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 26-Mar-2018

ScheduledTriggerTest.testTrigger
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

SearchRateTriggerIntegrationTest.testBelowSearchRate
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

SearchRateTriggerIntegrationTest.testDeleteNode
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

ShardSplitTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ShardSplitTest.testSplitAfterFailedSplit
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

ShardSplitTest.testSplitWithChaosMonkey
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

SharedFSAutoReplicaFailoverTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

SolrCloudExampleTest.testLoadDocsIntoGettingStartedCollection
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

StressHdfsTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestAuthenticationFramework.testBasics
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestCloudSchemaless.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

TestCollectionStateWatchers.testDeletionsTriggerWatches
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateSearchDelete
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateWithoutCoresThenDelete
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

TestDistributedSearch.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

TestDynamicLoading.testDynamicLoading
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestGenericDistributedQueue.TestGenericDistributedQueue suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestHdfsCloudBackupRestore.TestHdfsCloudBackupRestore suite
   @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

TestHdfsUpdateLog.testFSThreadSafety
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestInPlaceUpdatesDistrib.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestLargeCluster.TestLargeCluster suite
   @LuceneTestCase.BadApple(bugUrl =
"https://issues.apache.org/jira/browse/SOLR-12075")

TestLargeCluster.testSearchRate
   @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")

TestLeaderInitiatedRecoveryThread.testPublishDownState
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

TestManagedResourceStorage.TestManagedResourceStorage suite
   @LuceneTestCase.BadApple(bugUrl =
"https://issues.apache.org/jira/browse/SOLR-6443")

TestPrepRecovery.testLeaderNotResponding
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestPrepRecovery.testLeaderUnloaded
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestPullReplica.testAddDocs
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestPullReplica.testCreateDelete
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestPullReplica.testKillLeader
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestReplicationHandler.doTestIndexAndConfigAliasReplication
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

TestSQLHandler.doTest
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestSegmentSorting.testAtomicUpdateOfSegmentSortField
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 26-Mar-2018

TestSegmentSorting.testSegmentTerminateEarly
   @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestSolrCloudWithKerberosAlt.testBasics
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

TestStressCloudBlindAtomicUpdates.test_dv
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestStressCloudBlindAtomicUpdates.test_dv_stored
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestStressInPlaceUpdates.stressTest
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

TestStressRecovery.testStressRecovery
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 04-May-2018

TestTriggerIntegration.testCooldown
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestTriggerIntegration.testEventFromRestoredState
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
//2018-03-10

TestTriggerIntegration.testEventQueue
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 16-Apr-2018

TestTriggerIntegration.testListeners
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestTriggerIntegration.testNodeAddedTriggerRestoreState
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 09-Apr-2018

TestTriggerIntegration.testNodeLostTrigger
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 26-Mar-2018

TestTriggerIntegration.testNodeLostTriggerRestoreState
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestTriggerIntegration.testNodeMarkersRegistration
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestTriggerIntegration.testSearchRate
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestV2Request.testCloudSolrClient
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

TestV2Request.testHttpSolrClient
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

UnloadDistributedZkTest.test
   @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
// 21-May-2018

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


Re: Badapple report, rehabilitating annotated tests. Please read the intro and comment.

Posted by Erick Erickson <er...@gmail.com>.
Got it, thanks Adrien.

Anyone else: If you have tests you don't want enabled, let me know.
I'll add to a permanent list and add to the report.



On Tue, Jun 5, 2018 at 10:06 AM, Adrien Grand <jp...@gmail.com> wrote:
> Hi Erick,
>
> Le mar. 5 juin 2018 à 18:19, Erick Erickson <er...@gmail.com> a
> écrit :
>>
>>      TestControlledRealTimeReopenThread.testCRTReopen
>
>
> This test relies on wall clock time, it needs to be refactored before being
> enabled again.
>
>> TestICUNormalizer2CharFilter.testRandomStrings
>
>
> We did several ICU4J upgrades since we disabled that one, so it's not
> impossible that the issue got fixed. I just ran 1000 beasting iterations
> without a failure. I'm good with re-enabling it.
>
>>
>>      TestICUTokenizerCJK
>
>
> This one is due to a bug in ICU4J which still affects the latest release,
> let's keep it disabled.
>

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


Re: Badapple report, rehabilitating annotated tests. Please read the intro and comment.

Posted by Adrien Grand <jp...@gmail.com>.
Hi Erick,

Le mar. 5 juin 2018 à 18:19, Erick Erickson <er...@gmail.com> a
écrit :

>      TestControlledRealTimeReopenThread.testCRTReopen


This test relies on wall clock time, it needs to be refactored before being
enabled again.

TestICUNormalizer2CharFilter.testRandomStrings
>

We did several ICU4J upgrades since we disabled that one, so it's not
impossible that the issue got fixed. I just ran 1000 beasting iterations
without a failure. I'm good with re-enabling it.


>      TestICUTokenizerCJK
>

This one is due to a bug in ICU4J which still affects the latest release,
let's keep it disabled.

Re: Badapple report, rehabilitating annotated tests. Please read the intro and comment.

Posted by Dawid Weiss <da...@gmail.com>.
Thanks Erick, this looks great. A 4 week window seems very reasonable
to me (could be even shorter if we had faster-running tests :). I
think this code could be published to github or even our own
repository. If we don't want to pollute the codebase we can always
just use a separate branch.

An other small note -- gmail breaks the formatting on those inline
reports for me; an ASCII
attachment would be easier to parse.

Dawid

On Tue, Jun 5, 2018 at 6:18 PM, Erick Erickson <er...@gmail.com> wrote:
> ---------- First
>
> One thing that's been vexing me is that the "noise reduction" is A
> Good Thing, but how do we rehabilitate annotated tests?
>
> Here's the result of my most recent changes to the reporter. The
> change is that I have candidates to un-annotate.
>
> Here's the theory:
>
>> I roll up all of Hoss' reports so I have lists by week (roughly) of test methods and suites that failed.
>
>> I have lists of all methods and suites that are annotated in the source code.
>
>> If an annotated test or suite has NOT failed in the last 4 weeks, it's a candidate to un-annotate. I chose 4 weeks arbitrarily, it's simple to change to more or less.
>
> Below is a new report. If people could take a quick look at the first
> section, up to the line "********Failures in Hoss' reports" and sanity
> check whether these tests seem reasonable to un-annotate I'd
> appreciate it. Next time I BadApple stuff, I'll also un-badApple all
> these unless there are objections.
>
> Besides, seeing things come _off_ the annotations list is encouraging.
>
> ---------- Second
>
> What do people think about the recency report? (the section that
> starts with "********Failures in Hoss' reports"). Is it useful? Is the
> order most useful?
>
> ----------Third
>
> How big should the window be? Since there are 64 bits I could use in a
> long, it's simple to keep this going for that long. Also a waste of
> electrons and makes for massive e-mails.
>
> I propose that the report confine itself to 4 weeks. I'll keep the
> history in case anyone wants to do a longer analysis. I don't seen any
> point in looking at tests that failed N weeks ago as a regular thing,
> We all have committed code that breaks tests and fixed them, so
> letting that kind of information  accumulate forever in  reports seems
> pretty useless.
>
> For instance, way at the end are a bunch of tests that  failed 9 weeks
> ago and haven't failed since. I can't imagine that's useful
> information to see every week.
>
> ----------Fourth
>
> The report contains all the annotated tests and suites, mostly because
> I have to collect it anyway and it's easy. I put it at the end of the
> report because I think it's the least useful and it's easier to ignore
> there. Any reason to remove it?
>
> ----------Fifth
>
> All this is sitting here on my personal laptop and I think it's
> getting to the point where it's increasingly useful. I'd be glad to
> put it up on GitHub if anyone's interested. For that matter it could
> go into the tools, but unless we also put Hoss' reports there it'd be
> an orphan.
>
> I do wonder if it's something we could automate though. That would require:
>
> 1> downloading and saving Hoss's reports every week (I try to do it Monday)
> 2> Having access to the source tree
> 3> pressing the "go" button
> 4> mailing the results to the dev list.
>
> Let me know.
>
> **********************************************************
> Here's the latest report.
>
> Processing file (History bit 0):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-03-26.csv
> Processing file (History bit 1):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-02.csv
> Processing file (History bit 2):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-09.csv
> Processing file (History bit 3):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-16.csv
> Processing file (History bit 4):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-25.csv
> Processing file (History bit 5):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-04-30.csv
> Processing file (History bit 6):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-05-14.csv
> Processing file (History bit 7):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-05-21.csv
> Processing file (History bit 8):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-05-29.csv
> Processing file (History bit 9):
> /Users/Erick/apache/solrJiras/BadApples/HOSS/HOSS-06-05.csv
>
>
> **********Annotations that didn't fail in the last 4 weeks.
>
> ******Methods: 48
>    AutoAddReplicasIntegrationTest.testSimple
>    ChaosMonkeySafeLeaderWithPullReplicasTest.test
>    ComputePlanActionTest.testSelectedCollections
>    DocValuesNotIndexedTest.testGroupingDVOnly
>    DocValuesNotIndexedTest.testGroupingDocAbsent
>    DocValuesNotIndexedTest.testGroupingSorting
>    ForceLeaderTest.testReplicasInLIRNoLeader
>    HdfsDirectoryTest.testEOF
>    LIRRollingUpdatesTest.testNewLeaderAndMixedReplicas
>    LIRRollingUpdatesTest.testNewLeaderOldReplica
>    LIRRollingUpdatesTest.testOldLeaderAndMixedReplicas
>    LeaderElectionIntegrationTest.testSimpleSliceLeaderElection
>    MathExpressionTest.testDistributions
>    MathExpressionTest.testGammaDistribution
>    MathExpressionTest.testMultiVariateNormalDistribution
>    MissingSegmentRecoveryTest.testLeaderRecovery
>    MoveReplicaHDFSTest.testNormalFailedMove
>    MoveReplicaHDFSTest.testNormalMove
>    MoveReplicaTest.testFailedMove
>    ReplaceNodeNoTargetTest.test
>    ScheduledTriggerTest.testTrigger
>    ShardSplitTest.test
>    SharedFSAutoReplicaFailoverTest.test
>    SolrCloudExampleTest.testLoadDocsIntoGettingStartedCollection
>    TestCloudSchemaless.test
>    TestCollapseQParserPlugin.testStringCollapse
>    TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateWithoutCoresThenDelete
>    TestControlledRealTimeReopenThread.testCRTReopen
>    TestDynamicLoading.testDynamicLoading
>    TestICUNormalizer2CharFilter.testRandomStrings
>    TestImpersonationWithHadoopAuth.testForwarding
>    TestLTRReRankingPipeline.testDifferentTopN
>    TestMinMaxOnMultiValuedField.testDoubleFieldCache
>    TestMinMaxOnMultiValuedField.testFloatFieldCache
>    TestMinMaxOnMultiValuedField.testIntFieldCache
>    TestMinMaxOnMultiValuedField.testLongFieldCache
>    TestMoreLikeThis.testMultiFieldShouldReturnPerFieldBooleanQuery
>    TestPullReplica.testAddDocs
>    TestReplicationHandler.doTestIndexAndConfigAliasReplication
>    TestSegmentSorting.testAtomicUpdateOfSegmentSortField
>    TestSegmentSorting.testSegmentTerminateEarly
>    TestStressCloudBlindAtomicUpdates.test_dv_stored
>    TestStressInPlaceUpdates.stressTest
>    TestV2Request.testCloudSolrClient
>    TestV2Request.testHttpSolrClient
>    UIMABaseAnalyzerTest.testRandomStrings
>    UIMABaseAnalyzerTest.testRandomStringsWithConfigurationParameters
>    UIMATypeAwareAnalyzerTest.testRandomStrings
>
> ******Suites: 6
>    ConcurrentCreateRoutedAliasTest
>    HdfsTlogReplayBufferedWhileIndexingTest
>    ReplaceNodeNoTargetTest
>    ReplicationFactorTest
>    ScheduledTriggerIntegrationTest
>    TestICUTokenizerCJK
>
>
> ********Failures in Hoss' reports
>
> 1669 tests failed in Hoss' rollups. Ordered by week of failure, newest->oldest
> each asterisk in 'History' means the test failed in that week
> These tests were NOT BadApple'd or AwaitsFix'd
>
>          Failures by Weeks ago    Pct    runs   fails      test
>                     06-05   03-26
>                     |        |
>                     0123456789    2.1     3816     80      BlockCacheTest(suite)
>                     0123456789    2.4     3825     90
> BlockDirectoryTest(suite)
>                     0123456789    3.6     3303    120
> CheckHdfsIndexTest(suite)
>                     0123456789    0.3     3633     11
> CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>                     0123456789    0.3     3633     11
> CreateRoutedAliasTest.testTimezoneAbsoluteDate
>                     0123456789    0.4     3633     13
> CreateRoutedAliasTest.testV1
>                     0123456789    0.3     3633     12
> CreateRoutedAliasTest.testV2
>                     0123456789   35.0      157     55
> HdfsBasicDistributedZkTest(suite)
>                     0123456789   47.1      191     90
> HdfsCollectionsAPIDistributedZkTest(suite)
>                     0123456789    2.9     3289     97
> HdfsNNFailoverTest(suite)
>                     0123456789   51.5      194    100
> HdfsSyncSliceTest(suite)
>                     0123456789   43.4      175     76
> HdfsWriteToMultipleCollectionsTest(suite)
>                     0123456789    5.9      674     40
> MoveReplicaHDFSTest.testFailedMove
>                     0123456789    3.0     3283     97
> TestRecoveryHdfs(suite)
>                     0123456789    0.8     3867     30
> TestReplicationHandler(suite)
>                     0123456789   11.4     4352    497
> TestReplicationHandler.doTestStressReplication
>                     0123456789    4.2     4109    174
> TestTimeSource.testEpochTime
>                     0123456 89    7.9      506     40
> TestLargeCluster.testBasic
>                     0123456       1.7     4025     67
> IndexSizeTriggerTest.testMixedBounds
>                     012345 78     1.1     3235     34
> BasicDistributedZkTest.test
>                     012345 78     1.4     3436     49
> TestTriggerIntegration.testTriggerThrottling
>                     012345        4.5     2708    122
> SearchRateTriggerTest.testTrigger
>                     012345       16.5       91     15
> TestDocTermOrdsUninvertLimit.testTriggerUnInvertLimit
>                     01234  7 9   13.1      434     57
> TestLargeCluster.testNodeLost
>                     0123 5678     0.9     3457     32
> TestTriggerIntegration.testNodeAddedTrigger
>                     0123 5        0.4     2250      9
> CollectionsAPISolrJTest.testCreateWithDefaultConfigSet
>                     0123  67 9    0.9     2907     25
> TestCollectionStateWatchers.testPredicateFailureTimesOut
>                     0123  67 9    0.9     2905     26
> TestCollectionStateWatchers.testSimpleCollectionWatch
>                     0123  67 9    1.0     2902     30
> TestCollectionStateWatchers.testWaitForStateWatcherIsRetainedOnPredicateFailure
>                     0123  67      0.5     1840      9
> TestSolrCloudWithHadoopAuthPlugin(suite)
>                     0123   789    0.6     2931     17
> TestCollectionStateWatchers.testWatchesWorkForStateFormat1
>                     0123   7 9    0.6     2582     16
> TestCollectionStateWatchers.testWatcherIsRemovedAfterTimeout
>                     0123          1.2     1808     21
> MaxSizeAutoCommitTest(suite)
>                     0123          2.5     1908     47
> MaxSizeAutoCommitTest.deleteTest
>                     0123          7.2      180     13
> MaxSizeAutoCommitTest.endToEndTest
>                     0123          8.4      155     13
> TestGenericDistributedQueue.testDistributedQueue
>                     0123          2.1     1533     32
> TestRandomChains.testRandomChains
>                     0123          2.9     1533     45
> TestRandomChains.testRandomChainsWithLargeStrings
>                     012 456  9    0.7     1830     13
> TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>                     012  5 7 9    0.5     2489     12
> BasicDistributedZkTest(suite)
>                     012  5        0.3     1838      5
> TestSkipOverseerOperations.testSkipDownOperations
>                     012  5        0.3     1838      6
> TestSkipOverseerOperations.testSkipLeaderOperations
>                     012   67 9    0.8     2501     21
> TestCollectionStateWatchers.testCanWaitForNonexistantCollection
>                     012   67 9    0.6     2497     16
> TestCollectionStateWatchers.testStateWatcherChecksCurrentStateOnRegister
>                     012     8     0.5     1787      9      ShardSplitTest(suite)
>                     012           0.2     1506      3
> TestTriggerIntegration(suite)
>                     01 3456       3.8      213      8
> HttpPartitionTest(suite)
>                     01 34   89    3.2     2285     73
> TestStressCloudBlindAtomicUpdates(suite)
>                     01 34   8     0.7     1749     13
> MoveReplicaHDFSTest.test
>                     01 34         0.4     1430      6
> HdfsDirectoryTest.testRandomAccessWrites
>                     01 34         0.7     1425     10
> HdfsRecoverLeaseTest(suite)
>                     01 3  678     0.5     2349     11
> RollingRestartTest.test
>                     01 3          0.7     1330      9
> CustomHighlightComponentTest(suite)
>                     01 3          0.4     1372      6      JdbcTest(suite)
>                     01 3          0.3     1325      4
> StreamDecoratorTest.testExecutorStream
>                     01   5 78     0.3     2144      6
> TestComputePlanAction.testNodeLost
>                     01   5 7     43.8       16      7
> HdfsChaosMonkeyNothingIsSafeTest.test
>                     01   5        1.7     1080     18
> TransactionLogTest.testBigLastAddSize
>                     01     7 9    0.4     1626      6
> TestCloudRecovery.leaderRecoverFromLogOnStartupTest
>                     01      89    0.6     1618     10
> SolrExporterTest(suite)
>                     01      8     0.5     1302      6
> SolrCollectorTest(suite)
>                     01      8     0.2     1355      3
> TestIndexWriterWithThreads.testIOExceptionDuringAbortWithThreadsOnlyOnce
>                     01       9    0.2     1269      3
> TestTlogReplica.testBasicLeaderElection
>                     01            2.4      251      6
> CollectionsAPISolrJTest.testCreateCollWithDefaultClusterProperties
>                     01            4.9      738     36
> SearchHandlerTest.testRequireZkConnectedDistrib
>                     01            0.3      959      3
> SolrExporterTest.testExecute
>                     01            0.4      953      4
> SolrShardReporterTest(suite)
>                     01            0.2      956      2
> SolrShardReporterTest.test
>                     01            0.2      955      2
> TestDistributedGrouping.test
>                     01            0.5      977      5
> TestIndexFileDeleter.testExcInDecRef
>                     01            0.2      952      2
> TestStandardQParsers.testRegisteredName
>                     0 23456 89   79.0       62     49
> RestartWhileUpdatingTest(suite)
>                     0 234 6789    4.1      704     29
> TestTlogReplica.testRecovery
>                     0 234 67      1.4     2255     31
> SegmentsInfoRequestHandlerTest.testSegmentInfosVersion
>                     0 23 5        0.3     1642      5
> DeleteReplicaTest.deleteReplicaFromClusterState
>                     0 23  6789    1.2     2613     32
> FullSolrCloudDistribCmdsTest.test
>                     0 23   789    0.8     2286     18
> FullSolrCloudDistribCmdsTest(suite)
>                     0 23   7 9    0.6     1963     11
> LegacyFieldFacetExtrasCloudTest(suite)
>                     0 23    8     0.4     1640      6
> ShardSplitTest.testSplitStaticIndexReplication
>                     0 2 456789    8.0      199     16
> HdfsUnloadDistributedZkTest.test
>                     0 2 4         0.5     1244      6      GraphTest(suite)
>                     0 2  5  8     0.2     1640      4
> TestPolicyCloud.testCreateCollectionAddShardWithReplicaTypeUsingPolicy
>                     0 2  5   9    0.3     1588      5
> TestCloudRecovery(suite)
>                     0 2   6  9    0.4     1585      6
> CloudSolrClientTest.testRetryUpdatesWhenClusterStateIsStale
>                     0 2    789    1.1     1932     22
> TestGeo3DPoint.testGeo3DRelations
>                     0 2      9    0.3     1224      4
> TestCloudPivotFacet.test
>                     0 2      9    0.2     1217      3
> TestTlogReplica.testDeleteById
>                     0 2           0.2      928      2
> StreamDecoratorTest.testParallelUpdateStream
>                     0 2           0.6      903      5
> TestRequestStatusCollectionAPI(suite)
>                     0  34 6 89    1.9     1504     28
> TriggerIntegrationTest.testEventQueue
>                     0  34  7      0.3     1443      5
> BasicDistributedZk2Test.test
>                     0  34  7      0.8     1189      9
> StreamDecoratorTest(suite)
>                     0  34   8     0.7     1220      8
> MoveReplicaHDFSFailoverTest(suite)
>                     0  34         0.7      937      7
> HDFSCollectionsAPITest(suite)
>                     0  34         0.5      926      5
> HdfsThreadLeakTest(suite)
>                     0  34         0.3     1093      3      ShardRoutingTest.test
>                     0  34         0.4      930      4
> TestHdfsBackupRestoreCore(suite)
>                     0  3  6789    2.9     1299     38
> ChaosMonkeyNothingIsSafeTest(suite)
>                     0  3    8     0.7      953      7
> HdfsLockFactoryTest(suite)
>                     0  3     9    0.3     1104      3
> CollectionsAPIDistributedZkTest.testCollectionReload
>                     0  3     9    0.8      929      7
> HdfsDirectoryFactoryTest(suite)
>                     0  3     9    0.3     1105      3
> TestTlogReplica.testAddRemoveTlogReplica
>                     0  3          0.3      786      2
> CleanupOldIndexTest(suite)
>                     0  3          0.3      789      2
> CleanupOldIndexTest.test
>                     0  3          0.3      795      2
> CollectionsAPIDistributedZkTest.testMissingRequiredParameters
>                     0  3          0.4      693      3
> HdfsDirectoryTest.testWritingAndReadingAFile
>                     0   45  8     0.9     1498     13
> TestSearcherManager(suite)
>                     0   45  8     0.6     1500      9
> TestSearcherManager.testConcurrentIndexCloseSearchAndRefresh
>                     0   4 6       0.8      899      7
> CheckHdfsIndexTest.testChecksumsOnlyVerbose
>                     0   4   8     6.9     1186     82
> TestComputePlanAction.testNodeAdded
>                     0   4    9    0.8      898      7
> CheckHdfsIndexTest.doTest
>                     0   4    9    0.6      898      5
> CheckHdfsIndexTest.testDeletedDocs
>                     0   4    9    0.8     1064      9
> TestBKD.testWastedLeadingBytes
>                     0   4         0.6      627      4
> CheckHdfsIndexTest.testChecksumsOnly
>                     0   4         0.3      723      2
> LeaderFailureAfterFreshStartTest.test
>                     0   4         0.3      723      2
> PingRequestHandlerTest.testPingInClusterWithNoHealthCheck
>                     0    5 7      0.4     1122      5
> QueryEqualityTest(suite)
>                     0    5        0.4      797      3
> TestDeleteCollectionOnDownNodes.deleteCollectionWithDownNodes
>                     0     6 8     0.3     1098      3
> CloudSolrClientTest.checkCollectionParameters
>                     0     6       0.5      610      3
> TestPKIAuthenticationPlugin.test
>                     0      789    0.6     1395      8      RecoveryZkTest(suite)
>                     0      78     1.2     1093     13
> CdcrBidirectionalTest.testBiDir
>                     0      7 9    0.4     1065      4      RecoveryZkTest.test
>                     0      7 9    0.3     1077      3
> TestTlogReplica.testAddDocs
>                     0      7      0.5      747      4
> OutputWriterTest(suite)
>                     0      7      0.3      752      2
> SolrCoreTest.testRequestHandlerRegistry
>                     0      7      0.4      494      2
> TestLeaderElectionZkExpiry.testLeaderElectionWithZkExpiry
>                     0       8     0.3      745      2
> StatsReloadRaceTest.testParallelReloadAndStats
>                     0       8    18.7      182     34
> TestLargeCluster.testAddNode
>                     0        9    0.7      405      3
> AutoscalingHistoryHandlerTest(suite)
>                     0        9    0.4      752      3
> CloudSolrClientTest.preferLocalShardsTest
>                     0        9    0.3      752      2
> CloudSolrClientTest.testAliasHandling
>                     0        9    0.3      752      2
> CloudSolrClientTest.testOverwriteOption
>                     0        9    0.3      718      2
> TestStressLiveNodes.testStress
>                     0        9   28.6       14      4
> TestTlogReplica.testCreateDelete
>                     0        9    0.3      720      2
> TestTlogReplica.testKillLeader
>                     0        9    0.3      720      2
> TestTlogReplica.testKillTlogReplica
>                     0        9    0.3      720      2
> TestTlogReplica.testOutOfOrderDBQWithInPlaceUpdates
>                     0        9    0.3      720      2
> TestTlogReplica.testRealTimeGet
>                     0             0.5      406      2
> BlockJoinFacetDistribTest(suite)
>                     0             0.2      423      1
> CloudSolrClientTest.customHttpClientTest
>                     0             0.2      423      1
> CloudSolrClientTest.preferReplicaTypesTest
>                     0             0.2      423      1
> CloudSolrClientTest.stateVersionParamTest
>                     0             0.2      423      1
> CloudSolrClientTest.testInitializationWithSolrUrls
>                     0             0.2      423      1
> CloudSolrClientTest.testNonRetryableRequests
>                     0             0.2      423      1
> CloudSolrClientTest.testParallelUpdateQTime
>                     0             0.2      423      1
> CloudSolrClientTest.testRouting
>                     0             0.2      423      1
> CloudSolrClientTest.testWrongZkChrootTest
>                     0             0.2      407      1
> CollectionTooManyReplicasTest.testAddShard
>                     0             0.2      407      1
> CollectionTooManyReplicasTest.testAddTooManyReplicas
>                     0             0.2      409      1
> ComputePlanActionTest.testNodeAdded
>                     0             1.0      407      4
> ConfigSetsAPITest(suite)
>                     0             0.2      424      1
> ConfusionMatrixGeneratorTest.testGetConfusionMatrixWithSNB
>                     0             0.2      413      1
> DistribJoinFromCollectionTest.testScore
>                     0             0.2      410      1
> DistributedQueueTest.testPeekElements
>                     0             0.2      410      1
> ExecutePlanActionTest.testExecute
>                     0             0.2      410      1
> ExecutePlanActionTest.testIntegration
>                     0             0.5      404      2
> LeaderElectionTest(suite)
>                     0             0.2      404      1
> LeaderElectionTest.testStressElection
>                     0             0.3      367      1
> MetricsHistoryHandlerTest.testBasic
>                     0             0.2      410      1
> NodeLostTriggerTest.testTrigger
>                     0             0.5      404      2
> RemoteQueryErrorTest(suite)
>                     0            11.6      439     51
> ResourceLoaderTest.testAwareCompatibility
>                     0             1.0      408      4
> ScheduledTriggerTest(suite)
>                     0             2.4      379      9
> SolrRrdBackendFactoryTest.testBasic
>                     0             0.4      230      1
> StreamExpressionTest.testBasicTextLogitStream
>                     0             0.2      416      1
> TestBackwardsCompatibility.testUnsupportedOldIndexes
>                     0             0.2      406      1
> TestBulkSchemaConcurrent.test
>                     0             2.9      413     12
> TestCloudJSONFacetSKG(suite)
>                     0             0.2      415      1
> TestCloudJSONFacetSKG.testBespoke
>                     0             0.7      415      3
> TestCloudJSONFacetSKG.testRandom
>                     0             0.2      406      1
> TestConfigSetsAPI.testDelete
>                     0             0.3      390      1
> TestDelegationWithHadoopAuth.testDelegationTokenRenew
>                     0             0.5      413      2
> TestDeleteCollectionOnDownNodes(suite)
>                     0             0.2      412      1
> TestDistributedStatsComponentCardinality.test
>                     0             0.2      407      1
> TestExclusionRuleCollectionAccess.doTest
>                     0             2.6      423     11
> TestExecutePlanAction.testExecute
>                     0             0.2      431      1
> TestIndexWriterWithThreads.testIOExceptionDuringWriteSegmentWithThreads
>                     0             0.2      408      1
> TestLocalFSCloudBackupRestore(suite)
>                     0             0.2      419      1
> TestLucene70DocValuesFormat.testSortedVariableLengthBigVsStoredFields
>                     0             5.5       73      4
> TestRecovery.testExistOldBufferLog
>                     0             0.5      410      2
> TestReplicaProperties(suite)
>                     0             0.2      410      1
> TestReplicaProperties.test
>                     0             0.2      411      1
> TestStressCloudBlindAtomicUpdates.test_dv_idx
>                     0             0.2      406      1
> TestTlogReplica.testOnlyLeaderIndexes
>                     0             0.5      412      2      TestZkChroot(suite)
>                     0             0.2      412      1
> TestZkChroot.testInitPathExists
>                     0             0.2      403      1
> V2ApiIntegrationTest(suite)
>                      123456789    4.8     2667    129      StressHdfsTest(suite)
>                      1234567      9.0     3160    284
> NodeAddedTriggerTest.testRestoreState
>                      12345   9   70.4       27     19
> CdcrReplicationDistributedZkTest.testBatchAddsWithDelete
>                      12345   9   71.4       28     20
> CdcrReplicationDistributedZkTest.testResilienceWithDeleteByQueryOnTarget
>                      12345   9   71.4       28     20
> CdcrReplicationDistributedZkTest.testUpdateLogSynchronisation
>                      12345      100.0       20     20
> CdcrReplicationDistributedZkTest.testBatchBoundaries
>                      12345      100.0       19     19
> CdcrReplicationDistributedZkTest.testBufferOnNonLeader
>                      12345      100.0       19     19
> CdcrReplicationDistributedZkTest.testOps
>                      12345      100.0       20     20
> CdcrReplicationDistributedZkTest.testReplicationAfterLeaderChange
>                      12345      100.0       19     19
> CdcrReplicationDistributedZkTest.testReplicationAfterRestart
>                      12345      100.0       19     19
> CdcrReplicationDistributedZkTest.testReplicationStartStop
>                      12345        0.5     2194     10
> TestLRUQueryCache.testBulkScorerLocking
>                      1234    9    0.7     2071     15      RangeFacetTest(suite)
>                      1234        10.0      200     20
> RandomGeoPolygonTest.testCompareSmallPolygons
>                      1234         1.1     1762     20
> TestExtractionDateUtil.testParseDate
>                      123 56  9    0.3     2426      7
> TestSolrCloudWithDelegationTokens.testDelegationTokenRenew
>                      123  6789    0.3     2742      9
> CollectionsAPIDistributedZkTest.testCreateNodeSet
>                      123  678     1.1     1817     20
> SaslZkACLProviderTest(suite)
>                      123  678     0.7     1824     13
> SaslZkACLProviderTest.testSaslZkACLProvider
>                      123     9    0.3     1505      4
> MoveReplicaHDFSFailoverTest.testOldReplicaIsDeletedInRaceCondition
>                      123          0.3     1590      4
> SearchRateTriggerIntegrationTest.testAboveSearchRate
>                      12 45 789    0.6     2714     15
> TestSolrCLIRunExample(suite)
>                      12 45 7      1.8     1769     31      TestSQLHandler(suite)
>                      12 4         0.2     1403      3
> TestLRUQueryCache(suite)
>                      12  56  9    0.4     1353      6
> TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeaderAfterRestart
>                      12   6 89    6.5      108      7
> LIROnShardRestartTest.testAllReplicasInLIR
>                      12   6 89    0.9     2010     18
> SystemLogListenerTest.test
>                      12   6  9    0.5     1695      9
> StreamExpressionTest(suite)
>                      12    78     3.1      128      4
> HdfsSyncSliceTest.test
>                      12    7      0.4     1382      5
> DirectSolrConnectionTest(suite)
>                      12    7      0.2     1414      3
> TestSolrEntityProcessorEndToEnd.testFullImportFqParam
>                      12           0.4     1061      4      SchemaTest(suite)
>                      12           0.2     1067      2
> SchemaTest.addDynamicFieldShouldntBeCalledTwiceWithTheSameName
>                      12           0.2     1067      2
> SchemaTest.addFieldShouldntBeCalledTwiceWithTheSameName
>                      12           0.2     1067      2
> SchemaTest.addFieldTypeShouldntBeCalledTwiceWithTheSameName
>                      12           0.2     1067      2
> SchemaTest.addFieldTypeWithAnalyzerClassAccuracy
>                      12           0.2     1067      2
> SchemaTest.addFieldTypeWithSimilarityAccuracy
>                      12           0.2     1067      2
> SchemaTest.copyFieldsShouldFailWhenOneOfTheFieldsDoesntExistInTheSchema
>                      12           0.2     1067      2
> SchemaTest.deleteCopyFieldShouldFailWhenOneOfTheFieldsDoesntExistInTheSchema
>                      12           0.2     1067      2
> SchemaTest.deletingADynamicFieldThatDoesntExistInTheSchemaShouldFail
>                      12           0.2     1067      2
> SchemaTest.deletingAFieldThatDoesntExistInTheSchemaShouldFail
>                      12           0.2     1067      2
> SchemaTest.deletingAFieldTypeThatDoesntExistInTheSchemaShouldFail
>                      12           0.2     1067      2
> SchemaTest.testAddDynamicFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testAddFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testAddFieldTypeAccuracy
>                      12           0.2     1067      2
> SchemaTest.testCopyFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testCopyFieldWithMaxCharsAccuracy
>                      12           0.2     1067      2
> SchemaTest.testDeleteCopyFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testDeleteDynamicFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testDeleteFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testDeleteFieldTypeAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetCopyFieldsAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetDynamicFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetDynamicFieldsAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetFieldTypeAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetFieldTypesAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetFieldsAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetGlobalSimilarityAccuracy
>                      12           0.2     1067      2
> SchemaTest.testGetUniqueKeyAccuracy
>                      12           0.2     1067      2
> SchemaTest.testMultipleUpdateRequestAccuracy
>                      12           0.2     1067      2
> SchemaTest.testReplaceDynamicFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testReplaceFieldAccuracy
>                      12           0.2     1067      2
> SchemaTest.testReplaceFieldTypeAccuracy
>                      12           0.2     1067      2
> SchemaTest.testSchemaNameRequestAccuracy
>                      12           0.2     1067      2
> SchemaTest.testSchemaRequestAccuracy
>                      12           0.2     1067      2
> SchemaTest.testSchemaVersionRequestAccuracy
>                      12           0.2     1053      2
> ShardSplitTest.testSplitShardWithRule
>                      12           0.4     1049      4
> TestPolicyCloud(suite)
>                      1 34567      0.9     1648     15
> TestHdfsUpdateLog(suite)
>                      1 34    9    0.3     1555      5
> TestSolrConfigHandlerCloud.test
>                      1 3   7      0.2     1270      3
> TestPullReplica.testRemoveAllWriterReplicas
>                      1 3     9    0.7     1251      9
> LegacyFieldFacetCloudTest(suite)
>                      1 3          2.5       79      2
> ChaosMonkeySafeLeaderTest(suite)
>                      1 3          0.5      936      5
> LegacyQueryFacetCloudTest(suite)
>                      1 3          0.3      948      3
> SolrZkClientTest(suite)
>                      1 3          0.2      954      2
> SolrZkClientTest.testSimpleUpdateACLs
>                      1 3          0.2      938      2
> TestStressCloudBlindAtomicUpdates.test_dv_stored_idx
>                      1  45 7      0.4     1578      7
> TestComputePlanAction(suite)
>                      1  4         0.3      737      2
> OverseerTest.testShardAssignment
>                      1  4        11.1       27      3
> TestDocTermOrdsUninvertLimit(suite)
>                      1  4         0.2      870      2
> TestLRUQueryCache.testLRUEviction
>                      1   5 789    1.4     1345     19
> TestReplicationHandler.doTestIndexFetchOnMasterRestart
>                      1   5   9    0.2     1254      3
> TestCloudRecovery.corruptedLogTest
>                      1    678     0.4     1541      6
> ZkFailoverTest.testRestartZkWhenClusterDown
>                      1    67      0.5     1212      6      StreamingTest(suite)
>                      1    6       0.2      865      2
> TestDistribDocBasedVersion.test
>                      1     789    3.5      115      4
> TestInetAddressRangeQueries.testRandomBig
>                      1     78     0.2     1267      3
> TestIndexingSequenceNumbers.testStressConcurrentCommit
>                      1     7      0.5      877      4
> ConfigureRecoveryStrategyTest(suite)
>                      1     7      0.3      891      3
> DistribCursorPagingTest.test
>                      1     7      0.5      885      4      EchoParamsTest(suite)
>                      1     7      0.6      894      5      JDBCStreamTest(suite)
>                      1     7      0.2      891      2
> OverseerTaskQueueTest.testPeekElements
>                      1     7      0.2      881      2
> SolrJmxReporterTest(suite)
>                      1     7      0.2      879      2
> SolrSlf4jReporterTest.testReporter
>                      1     7      0.6      346      2
> StreamDecoratorTest.testClassifyStream
>                      1      8     3.0       67      2
> HdfsCollectionsAPIDistributedZkTest.addReplicaTest
>                      1      8     0.2      924      2
> TestIndexWriterWithThreads.testIOExceptionDuringAbortWithThreads
>                      1      8     0.2      884      2
> TestPullReplica.testKillPullReplica
>                      1            0.2      550      1
> AnalyzingInfixSuggesterTest.testRandomNRT
>                      1            0.2      485      1
> BlobRepositoryMockingTest(suite)
>                      1            0.2      544      1
> BufferStoreTest.testBufferTakePut
>                      1            0.2      548      1
> CdcrBootstrapTest.testConvertClusterToCdcrAndBootstrap
>                      1            0.7      545      4
> CloudExitableDirectoryReaderTest(suite)
>                      1            0.2      550      1
> CloudSolrClientBuilderTest.test0Timeouts
>                      1            0.2      550      1
> CloudSolrClientBuilderTest.testByDefaultConfiguresClientToSendUpdatesOnlyToShardLeaders
>                      1            0.2      550      1
> CloudSolrClientBuilderTest.testIsDirectUpdatesToLeadersOnlyDefault
>                      1            0.2      550      1
> CloudSolrClientBuilderTest.testSeveralZkHostsSpecifiedSingly
>                      1            0.2      550      1
> CloudSolrClientBuilderTest.testSeveralZkHostsSpecifiedTogether
>                      1            0.2      550      1
> CloudSolrClientBuilderTest.testSingleZkHostSpecified
>                      1            0.2      480      1
> CloudSolrClientCacheTest(suite)
>                      1            0.2      484      1
> CloudSolrClientCacheTest.testCaching
>                      1            0.2      550      1
> CloudSolrClientMultiConstructorTest.testBadChroot
>                      1            0.2      550      1
> CloudSolrClientMultiConstructorTest.testZkConnectionStringConstructorWithValidChroot
>                      1            0.2      550      1
> CloudSolrClientMultiConstructorTest.testZkConnectionStringSetterWithValidChroot
>                      1            0.2      544      1
> CollectionsAPISolrJTest.testAddAndDeleteReplica
>                      1            0.2      551      1
> ConcurrentUpdateSolrClientBuilderTest.testMissingQueueSize
>                      1            0.5      550      3
> ConcurrentUpdateSolrClientTest(suite)
>                      1            0.2      554      1
> ConcurrentUpdateSolrClientTest.testConcurrentUpdate
>                      1            0.2      544      1
> CustomCollectionTest.testRouteFieldForHashRouter
>                      1            0.2      544      1
> CustomCollectionTest.testRouteFieldForImplicitRouter
>                      1            0.2      544      1
> DateMathParserTest.testAdd
>                      1            0.2      544      1
> DateMathParserTest.testAddZero
>                      1            0.2      544      1
> DateMathParserTest.testCalendarUnitsConsistency
>                      1            0.2      544      1
> DateMathParserTest.testFormatter
>                      1            0.2      544      1
> DateMathParserTest.testParseLenient
>                      1            0.2      544      1
> DateMathParserTest.testRound
>                      1            0.2      544      1
> DateMathParserTest.testRoundTrip
>                      1            0.4      544      2
> DeleteReplicaTest(suite)
>                      1            0.2      544      1
> DeleteReplicaTest.deleteLiveReplicaTest
>                      1            0.2      543      1
> DirectoryFactoryTest(suite)
>                      1            0.7      545      4
> DistribCursorPagingTest(suite)
>                      1            0.2      546      1
> DistributedFacetExistsSmallTest.test
>                      1            0.2      543      1
> DistributedFacetPivotWhiteBoxTest.test
>                      1            0.2      549      1
> DistributedTermsComponentTest.test
>                      1            0.4      546      2
> ExtractingRequestHandlerTest.testArabicPDF
>                      1            0.4      546      2
> ExtractingRequestHandlerTest.testExtraction
>                      1            0.7      548      4
> ExtractingRequestHandlerTest.testLiteralsOverride
>                      1            0.4      546      2
> ExtractingRequestHandlerTest.testPasswordProtected
>                      1            0.2      487      1
> HadoopSSLCredentialProviderTest.testConstructorRequiresCredPath
>                      1            0.2      487      1
> HadoopSSLCredentialProviderTest.testGetCredentials
>                      1            0.2      550      1
> HttpClientUtilTest.testSSLSystemProperties
>                      1            0.2      550      1
> HttpClientUtilTest.testToBooleanDefaultIfNull
>                      1            0.2      550      1
> HttpClientUtilTest.testToBooleanObject
>                      1            0.2      548      1
> HttpSolrClientBuilderTest(suite)
>                      1            0.6      545      3
> HttpTriggerListenerTest(suite)
>                      1            0.7      549      4
> HttpTriggerListenerTest.testHttpListenerIntegration
>                      1            0.2      544      1
> IgnoreLargeDocumentProcessorFactoryTest.testProcessor
>                      1            0.2      547      1
> ImplicitSnitchTest.testExceptions
>                      1            0.2      476      1
> ImplicitSnitchTest.testGetTags_withAllHostNameRequestedTags_returns_all_Tags
>                      1            0.2      547      1
> ImplicitSnitchTest.testGetTags_withAllIPv4RequestedTags_returns_four_tags
>                      1            0.2      547      1
> ImplicitSnitchTest.testGetTags_withAllIPv4RequestedTags_with_omitted_zeros_returns_four_tags
>                      1            0.2      547      1
> ImplicitSnitchTest.testGetTags_withEmptyRequestedTag_returns_nothing
>                      1            0.2      476      1
> ImplicitSnitchTest.testGetTags_withHostNameRequestedTag_ip3_returns_1_tag
>                      1            0.2      476      1
> ImplicitSnitchTest.testGetTags_withHostNameRequestedTag_ip99999_returns_nothing
>                      1            0.2      547      1
> ImplicitSnitchTest.testGetTags_withIPv4RequestedTags_ip2_and_ip4_returns_two_tags
>                      1            0.2      547      1
> ImplicitSnitchTest.testGetTags_with_correct_ipv6_format_ip_returns_nothing
>                      1            0.2      547      1
> ImplicitSnitchTest.testGetTags_with_wrong_ipv4_format_ip_returns_nothing
>                      1            0.2      547      1
> ImplicitSnitchTest.testIsKnownTag_ip1
>                      1            0.2      548      1
> LBHttpSolrClientBuilderTest(suite)
>                      1            0.2      551      1
> LBHttpSolrClientTest.testLBHttpSolrClientHttpClientResponseParserStringArray
>                      1            0.5      550      3
> LargeVolumeEmbeddedTest(suite)
>                      1            0.2      551      1
> MergeIndexesEmbeddedTest(suite)
>                      1            0.2      553      1
> MergeIndexesEmbeddedTest.testMergeIndexesByCoreName
>                      1            0.2      553      1
> MergeIndexesEmbeddedTest.testMergeIndexesByDirName
>                      1            0.2      553      1
> MergeIndexesEmbeddedTest.testMergeMultipleRequest
>                      1            0.2      550      1
> NamedListTest.testRemoveArgs
>                      1            0.2      550      1
> NamedListTest.testShallowMap
>                      1            0.2      548      1
> PluginInfoTest.testClassRequired
>                      1            0.2      548      1
> PluginInfoTest.testNameRequired
>                      1            0.2      551      1
> QueryResponseTest.testGroupResponse
>                      1            0.2      551      1
> QueryResponseTest.testIntervalFacetsResponse
>                      1            0.2      551      1
> QueryResponseTest.testRangeFacets
>                      1            0.2      551      1
> QueryResponseTest.testSimpleGroupResponse
>                      1            0.2      543      1
> RAMDirectoryFactoryTest.test
>                      1            2.1       48      1
> ReplicationFactorTest.test
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetClientKeyStorePasswordFromEnv
>                      1            0.2      486      1
> SSLConfigurationsTest.testGetClientKeyStorePasswordFromHadoopCredentialProvider
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetClientKeyStorePasswordFromProperty
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetClientTrustStorePasswordFromEnv
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetClientTrustStorePasswordFromProperty
>                      1            0.2      486      1
> SSLConfigurationsTest.testGetClientTruststorePasswordFromHadoopCredentialProvider
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetKeyStorePasswordFromEnv
>                      1            0.2      486      1
> SSLConfigurationsTest.testGetKeyStorePasswordFromHadoopCredentialProvider
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetKeyStorePasswordFromProperty
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetTrustStorePasswordFromEnv
>                      1            0.2      557      1
> SSLConfigurationsTest.testGetTrustStorePasswordFromProperty
>                      1            0.2      486      1
> SSLConfigurationsTest.testGetTruststorePasswordFromHadoopCredentialProvider
>                      1            0.2      486      1
> SSLConfigurationsTest.testHadoopCredentialProviderPrioritySysPropAndEnvVars
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigKeystorePwFromBothEnvVars
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigKeystorePwFromClientKeystoreEnvVar
>                      1            0.2      486      1
> SSLConfigurationsTest.testSslConfigKeystorePwFromClientKeystoreHadoopCredentialProvider
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigKeystorePwFromKeystoreEnvVar
>                      1            0.2      486      1
> SSLConfigurationsTest.testSslConfigKeystorePwFromKeystoreHadoopCredentialProvider
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigKeystorePwNotOverwrittenIfExists
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigTruststorePwFromBothEnvVars
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigTruststorePwFromClientKeystoreEnvVar
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigTruststorePwFromKeystoreEnvVar
>                      1            0.2      557      1
> SSLConfigurationsTest.testSslConfigTruststorePwNotOverwrittenIfExists
>                      1            0.2      557      1
> SSLConfigurationsTest.testSystemPropertyPriorityOverEnvVar
>                      1            0.2      557      1
> SSLCredentialProviderFactoryTest.testGetProvidersBySysprop
>                      1            0.2      557      1
> SSLCredentialProviderFactoryTest.testGetProvidersInvalidProvider
>                      1            0.2      557      1
> SSLCredentialProviderFactoryTest.testGetProvidersOrder
>                      1            0.2      557      1
> SSLCredentialProviderFactoryTest.testGetProvidersWithCustomProvider
>                      1            0.2      487      1
> SchemaWatcherTest.testDiscardReaderReference
>                      1            0.2      487      1
> SchemaWatcherTest.testProcess
>                      1            0.4      271      1
> ShardParamsTest.testGetShardsTolerantAsBool
>                      1            0.2      554      1
> SimpleNaiveBayesClassifierTest.testPerformance
>                      1            0.2      486      1
> SkipExistingDocumentsProcessorFactoryTest(suite)
>                      1            0.5      550      3
> SolrExampleEmbeddedTest(suite)
>                      1            0.2      550      1
> SolrExceptionTest.testSolrException
>                      1            0.2      544      1
> SolrMetricReporterTest.testInit
>                      1            0.2      550      1
> SolrParamTest.testGetParams
>                      1            0.5      550      3
> SolrSchemalessExampleTest(suite)
>                      1            0.2      552      1
> SolrZkClientTest.testCheckInterrupted
>                      1            0.4      284      1
> StreamExpressionTest.testFeaturesSelectionStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testCloudSolrStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testCloudSolrStreamWithEscapedQuote
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testComplementStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testDaemonStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testFacetStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testFeaturesSelectionStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testIntersectStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testJDBCStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testMergeStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testRankStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testReducerStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testSelectStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testStatsStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testTextLogitStreamWithFeaturesSelection
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testTopicStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testUniqueStream
>                      1            0.2      549      1
> StreamExpressionToExpessionTest.testUpdateStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testCloudSolrStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testComplementStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testDaemonStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testFacetStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testIntersectStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testJDBCStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testMergeStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testRankStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testReducerStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testSelectStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testStatsStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testTopicStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testUniqueStream
>                      1            0.2      550      1
> StreamExpressionToExplanationTest.testUpdateStream
>                      1            0.2      545      1
> SystemInfoHandlerTest.testMagickGetter
>                      1            0.5      550      3
> TermsResponseTest(suite)
>                      1            0.2      548      1
> TestCollectionAPIs.testCommands
>                      1            0.2      549      1
> TestCollectionAdminRequest.testInvalidAliasNameRejectedWhenCreatingAlias
>                      1            0.2      549      1
> TestCollectionAdminRequest.testInvalidCollectionNameRejectedWhenCreatingCollection
>                      1            0.2      549      1
> TestCollectionAdminRequest.testInvalidShardNameRejectedWhenCreatingShard
>                      1            0.2      549      1
> TestCollectionAdminRequest.testInvalidShardNamesRejectedWhenCallingSetShards
>                      1            0.2      549      1
> TestCollectionAdminRequest.testInvalidShardNamesRejectedWhenCreatingImplicitCollection
>                      1            0.2      551      1
> TestConcurrentMergeScheduler(suite)
>                      1            0.2      552      1
> TestConcurrentMergeScheduler.testLiveMaxMergeCount
>                      1            0.2      547      1
> TestConfigOverlay.testPaths
>                      1            0.2      547      1
> TestConfigOverlay.testSetProperty
>                      1            0.2      549      1
> TestDelegationTokenResponse.testGetResponse
>                      1            0.2      549      1
> TestDelegationTokenResponse.testRenewResponse
>                      1            0.2      550      1
> TestDocumentObjectBinder.testDynamicFieldBinding
>                      1            0.2      550      1
> TestDocumentObjectBinder.testSimple
>                      1            0.2      559      1
> TestFacetMethods.testBooleanDefaults
>                      1            0.2      559      1
> TestFacetMethods.testNumericMultiValuedDV
>                      1            0.2      559      1
> TestFacetMethods.testNumericMultiValuedNoDV
>                      1            0.2      559      1
> TestFacetMethods.testNumericSingleValuedDV
>                      1            0.2      559      1
> TestFacetMethods.testNumericSingleValuedNoDV
>                      1            0.2      559      1
> TestFacetMethods.testPointFields
>                      1            0.2      559      1
> TestFacetMethods.testTextMultiValuedDV
>                      1            0.2      559      1
> TestFacetMethods.testTextMultiValuedNoDV
>                      1            0.2      559      1
> TestFacetMethods.testTextSingleValuedDV
>                      1            0.2      559      1
> TestFacetMethods.testTextSingleValuedNoDV
>                      1            0.2      550      1
> TestFastInputStream.testgzip
>                      1            0.2      550      1
> TestFastLRUCache.testFullAutowarm
>                      1            0.2      550      1
> TestFastLRUCache.testNoAutowarm
>                      1            0.2      550      1
> TestFastLRUCache.testOldestItems
>                      1            0.2      550      1
> TestFastLRUCache.testPercentageAutowarm
>                      1            0.2      550      1
> TestFastLRUCache.testPercentageAutowarmMultiple
>                      1            0.2      550      1
> TestFastLRUCache.testRandom
>                      1            0.2      550      1
> TestFastLRUCache.testSimple
>                      1            1.1      558      6
> TestIndexWriter.testFullyDeletedSegmentsReleaseFiles
>                      1            0.2      550      1
> TestIndexWriterReader.testDuringAddDelete
>                      1            0.2      547      1
> TestInetAddressRangeQueries(suite)
>                      1            0.2      550      1
> TestJsonRecordReader(suite)
>                      1            0.2      553      1
> TestJsonRecordReader.testAIOOBE
>                      1            0.2      553      1
> TestJsonRecordReader.testArrayOfRootObjects
>                      1            0.2      553      1
> TestJsonRecordReader.testClearPreviousRecordFields
>                      1            0.2      553      1
> TestJsonRecordReader.testNestedDocs
>                      1            0.2      553      1
> TestJsonRecordReader.testNestedJsonWithFloats
>                      1            0.2      553      1
> TestJsonRecordReader.testOneLevelSplit
>                      1            0.2      553      1
> TestJsonRecordReader.testRecursiveWildCard
>                      1            0.2      553      1
> TestJsonRecordReader.testRecursiveWildcard2
>                      1            0.2      553      1
> TestJsonRecordReader.testSrcField
>                      1            0.2      541      1
> TestLRUCache.testFullAutowarm
>                      1            0.2      541      1
> TestLRUCache.testMaxRamSize
>                      1            0.2      541      1
> TestLRUCache.testNoAutowarm
>                      1            0.2      541      1
> TestLRUCache.testNonAccountableValues
>                      1            0.2      541      1
> TestLRUCache.testPercentageAutowarm
>                      1            0.2      551      1
> TestLRUQueryCache.testOnUseWithRandomFirstSegmentSkipping
>                      1            0.2      450      1
> TestLRUQueryCache.testRamBytesUsedAgreesWithRamUsageTester
>                      1            0.2      547      1
> TestLTRScoringQuery(suite)
>                      1            0.2      548      1
> TestMinMaxNormalizer.testInvalidMinMaxMissingMax
>                      1            0.2      548      1
> TestMinMaxNormalizer.testInvalidMinMaxMissingMin
>                      1            0.2      548      1
> TestMinMaxNormalizer.testInvalidMinMaxNoParams
>                      1            0.2      548      1
> TestMinMaxNormalizer.testMinMaxNormalizerMinEqualToMax
>                      1            0.2      548      1
> TestMinMaxNormalizer.testMinMaxNormalizerMinLargerThanMax
>                      1            0.2      548      1
> TestMinMaxNormalizer.testNormalizer
>                      1            0.2      548      1
> TestMinMaxNormalizer.testParamsToMap
>                      1            0.2      550      1
> TestNamedListCodec.testIterable
>                      1            0.2      550      1
> TestNamedListCodec.testIterator
>                      1            0.2      550      1
> TestNamedListCodec.testRandom
>                      1            0.2      550      1
> TestNamedListCodec.testSimple
>                      1            0.2      547      1
> TestObjectReleaseTracker.testObjectReleaseTracker
>                      1            0.2      550      1      TestPathTrie(suite)
>                      1            0.2      551      1
> TestPathTrie.testPathTrie
>                      1            0.2      542      1
> TestPointFields.testLongPointFieldMultiValuedRangeFacet
>                      1            0.2      551      1      TestPolicy(suite)
>                      1            0.2      553      1
> TestPolicy.testComputePlanAfterNodeAdded
>                      1            0.2      553      1
> TestPolicy.testConditionsSort
>                      1            0.2      553      1
> TestPolicy.testCoresSuggestions
>                      1            0.2      553      1
> TestPolicy.testDiskSpaceHint
>                      1            0.2      553      1
> TestPolicy.testDiskSpaceReqd
>                      1            0.2      553      1
> TestPolicy.testEmptyClusterState
>                      1            0.2      553      1
> TestPolicy.testFreeDiskSuggestions
>                      1            0.2      553      1
> TestPolicy.testGreedyConditions
>                      1            0.2      553      1      TestPolicy.testMerge
>                      1            0.2      553      1
> TestPolicy.testMoveReplica
>                      1            0.2      553      1
> TestPolicy.testMoveReplicaLeaderlast
>                      1            0.2      553      1
> TestPolicy.testMoveReplicaSuggester
>                      1            0.2      553      1
> TestPolicy.testMoveReplicasInMultipleCollections
>                      1            0.2      553      1
> TestPolicy.testMultiReplicaPlacement
>                      1            0.2      553      1
> TestPolicy.testMultipleCollections
>                      1            0.2      553      1
> TestPolicy.testNegativeConditions
>                      1            0.2      553      1
> TestPolicy.testNodeLost
>                      1            0.2      553      1
> TestPolicy.testNodeLostMultipleReplica
>                      1            0.2      553      1
> TestPolicy.testOperands
>                      1            0.2      553      1
> TestPolicy.testOtherTag
>                      1            0.2      553      1
> TestPolicy.testPolicyWithReplicaType
>                      1            0.2      553      1
> TestPolicy.testPortSuggestions
>                      1            0.2      553      1
> TestPolicy.testReplicaCountSuggestions
>                      1            0.2      553      1      TestPolicy.testRow
>                      1            0.2      553      1      TestPolicy.testRules
>                      1            0.2      553      1
> TestPolicy.testScheduledTriggerFailure
>                      1            0.2      553      1
> TestPolicy.testSessionCaching
>                      1            0.4      272      1
> TestPolicy.testSortError
>                      1            0.2      553      1
> TestPolicy.testSyspropSuggestions
>                      1            0.2      553      1
> TestPolicy.testUtilizeNodeFailure
>                      1            0.2      553      1
> TestPolicy.testUtilizeNodeFailure2
>                      1            0.2      553      1
> TestPolicy.testValidate
>                      1            0.2      550      1
> TestPolicyCloud.testCreateCollectionAddShardUsingPolicy
>                      1            0.2      547      1
> TestPullReplica.testAddRemovePullReplica
>                      1            0.2      547      1
> TestPullReplica.testRealTimeGet
>                      1            0.4      544      2
> TestRandomRequestDistribution(suite)
>                      1            0.2      548      1
> TestRandomRequestDistribution.test
>                      1            0.2      538      1
> TestSolrCoreParser.testApacheLuceneSolr
>                      1            0.2      538      1
> TestSolrCoreParser.testCustomQueryWrapping
>                      1            0.2      538      1
> TestSolrCoreParser.testGoodbye
>                      1            0.2      538      1
> TestSolrCoreParser.testHandyQuery
>                      1            0.2      538      1
> TestSolrCoreParser.testHandySpanQuery
>                      1            0.2      538      1
> TestSolrCoreParser.testHello
>                      1            0.4      551      2
> TestSolrProperties(suite)
>                      1            0.2      553      1
> TestSolrProperties.testProperties
>                      1            0.5      550      3
> TestSpellCheckResponse(suite)
>                      1            0.2      548      1
> TestStandardNormalizer.testInvalidSTD
>                      1            0.2      548      1
> TestStandardNormalizer.testInvalidSTD2
>                      1            0.2      548      1
> TestStandardNormalizer.testInvalidSTD3
>                      1            0.2      548      1
> TestStandardNormalizer.testNormalizer
>                      1            0.2      548      1
> TestStandardNormalizer.testNormalizerNoParams
>                      1            0.2      548      1
> TestStandardNormalizer.testParamsToMap
>                      1            0.2      542      1
> TestSystemIdResolver.testResolving
>                      1            0.2      542      1
> TestSystemIdResolver.testUnsafeResolving
>                      1            0.2      546      1
> TestTestInjection(suite)
>                      1            0.2      546      1
> TestTestInjection.testBadSyntax
>                      1            0.2      546      1
> TestTestInjection.testBasics
>                      1            0.2      546      1
> TestTestInjection.testGoodSyntax
>                      1            0.2      546      1
> TestTestInjection.testUsingConsistentRandomization
>                      1            0.2      551      1      TestTimeSource(suite)
>                      1            0.2      550      1
> TestToleratedUpdateError.testParseMapErrorChecking
>                      1            0.2      551      1
> TestUpdateRequestCodec.simple
>                      1            0.2      551      1
> TestUpdateRequestCodec.testBackCompat4_5
>                      1            0.2      551      1
> TestUpdateRequestCodec.testIteratable
>                      1            0.3      350      1
> TestUpgradeIndexMergePolicy.testFindForcedDeletesMerges
>                      1            0.2      551      1
> TestV1toV2ApiMapper.testAddReplica
>                      1            0.2      551      1
> TestV1toV2ApiMapper.testCreate
>                      1            0.2      551      1
> TestV1toV2ApiMapper.testSetCollectionProperty
>                      1            0.2      542      1
> TestXmlQParser.testBooleanQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testBoostingTermQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testConstantScoreQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testCustomFieldUserQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testDisjunctionMaxQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testMatchAllDocsPlusFilterXML
>                      1            0.2      542      1
> TestXmlQParser.testNestedBooleanQuery
>                      1            0.2      542      1
> TestXmlQParser.testPointRangeQuery
>                      1            0.2      542      1
> TestXmlQParser.testPointRangeQueryWithoutLowerTerm
>                      1            0.2      542      1
> TestXmlQParser.testPointRangeQueryWithoutRange
>                      1            0.2      542      1
> TestXmlQParser.testPointRangeQueryWithoutUpperTerm
>                      1            0.2      542      1
> TestXmlQParser.testRangeQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testSpanTermXML
>                      1            0.2      542      1
> TestXmlQParser.testTermQueryEmptyXML
>                      1            0.2      542      1
> TestXmlQParser.testTermQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testTermsQueryXML
>                      1            0.2      542      1
> TestXmlQParser.testUserQueryXML
>                      1            0.2      542      1
> TestXmlQParser.test_DOCTYPE_TermQueryXML
>                      1            0.2      542      1
> TestXmlQParser.test_ENTITY_TermQueryXML
>                      1            0.2      546      1
> UUIDFieldTest.testToInternal
>                       23456789   14.7     2989    438
> ZkControllerTest(suite)
>                       234 6789   11.5      485     56
> TestLeaderElectionZkExpiry(suite)
>                       234  7      0.4     1529      6      SampleTest(suite)
>                       234        12.2     1315    160
> DistributedSpellCheckComponentTest.test
>                       234         6.9     1282     89
> SpellCheckComponentTest.test
>                       234         6.1     1286     78
> SpellCheckComponentTest.testCollate
>                       234         5.4     1285     69
> SpellCheckComponentTest.testCollateExtendedResultsWithJsonNl
>                       234         6.3     1289     81
> SpellCheckComponentTest.testMaximumResultsForSuggest
>                       234         5.6     1288     72
> SpellCheckComponentTest.testNumericQuery
>                       234         5.9     1286     76
> SpellCheckComponentTest.testRebuildOnCommit
>                       234         4.6       65      3
> TestIntRangeFieldQueries.testRandomBig
>                       23 56789    1.0     2956     30
> TestReplicationHandler.doTestReplicateAfterCoreReload
>                       23  6       0.2     1220      3
> TestSolrEntityProcessorEndToEnd.testFullImport
>                       23   789    1.2     1948     23
> TestLogWatcher.testLog4jWatcher
>                       23   78     7.1      113      8
> TestBinaryDocValuesUpdates.testTonsOfUpdates
>                       23   7      3.6       84      3
> TestMixedDocValuesUpdates.testTonsOfUpdates
>                       23    89    0.3     1534      5
> TestSolrConfigHandlerConcurrent.test
>                       23          0.2      890      2
> CollectionsAPIDistributedZkTest.deletePartiallyCreatedCollection
>                       23          0.3      885      3
> ConcurrentCreateRoutedAliasTest.testConcurrentCreateRoutedAliasComplex
>                       23          0.6      873      5
> HttpSolrCallGetCoreTest(suite)
>                       23          0.2      937      2
> TestConcurrentMergeScheduler.testFlushExceptions
>                       23          2.7       73      2
> TestGenericDistributedQueue.testDistributedQueueBlocking
>                       23          0.3      902      3
> TestSolrEntityProcessorEndToEnd.testFullImportWrongSolrUrl
>                       23          0.3      884      3
> TestStressVersions.testStressGetRealtimeVersions
>                       2 45  8     0.3     1527      4
> HttpPartitionOnCommitTest.test
>                       2 45        0.4     1113      5
> SoftAutoCommitTest.testHardCommitWithinAndSoftCommitMaxTimeRapidAdds
>                       2 4 6789   24.0      100     24
> TestDocTermOrds.testTriggerUnInvertLimit
>                       2 4   8     0.3     1186      3
> TestSolrEntityProcessorEndToEnd.testFullImportBadConfig
>                       2 4    9    0.3      949      3
> MoveReplicaHDFSFailoverTest.testDataDirAndUlogAreMaintained
>                       2 4    9    0.6     1131      7      QueryFacetTest(suite)
>                       2 4         0.2      813      2
> TestSolrCLIRunExample.testInteractiveSolrCloudExample
>                       2 4         0.2      829      2
> TestSolrEntityProcessorEndToEnd.testCursorMarkNoSort
>                       2 4         0.2      829      2
> TestSolrEntityProcessorEndToEnd.testFullImportFieldsParam
>                       2  56       0.6     1173      7
> MetricTriggerIntegrationTest.testMetricTrigger
>                       2  56      88.9        9      8
> SharedFSAutoReplicaFailoverTest(suite)
>                       2  5        0.2      875      2
> MathExpressionTest(suite)
>                       2   67      0.6     1145      7      TestNRTOpen(suite)
>                       2   6 89    0.3     1462      5
> TestCollectionAPI.test
>                       2   6 8     0.3     1161      3
> TestPullReplicaErrorHandling.testCantConnectToPullReplica
>                       2   6 8     0.3     1188      3
> TestSolrEntityProcessorEndToEnd.testFullImportInnerEntity
>                       2   6       0.2      811      2      BasicZkTest.testBasic
>                       2   6       0.4      830      3
> TestBlockJoin.testMultiChildQueriesOfDiffParentLevels
>                       2    789    0.6     1732     10
> TestReplicationHandler.doTestIndexFetchWithMasterUrl
>                       2    7      0.7      835      6
> BinaryUpdateRequestHandlerTest(suite)
>                       2    7      0.7      837      6
> FacetPivotSmallTest(suite)
>                       2    7      0.7      839      6
> FileBasedSpellCheckerTest(suite)
>                       2    7      0.7      840      6      SOLR749Test(suite)
>                       2    7      0.4      837      3
> SolrCoreCheckLockOnStartupTest(suite)
>                       2    7      0.2      840      2
> SolrCoreCheckLockOnStartupTest.testNativeLockErrorOnStartup
>                       2    7      0.2      840      2
> SolrCoreCheckLockOnStartupTest.testSimpleLockErrorOnStartup
>                       2    7      0.4      842      3
> SpatialRPTFieldTypeTest(suite)
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testDistanceUnitsDegrees
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testDistanceUnitsKilometers
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testGeoDistanceFunctionWithBackCompat
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testGeoDistanceFunctionWithKilometers
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testGeoDistanceFunctionWithMiles
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testJunkValuesForDistanceUnits
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testMaxDistErrConversion
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testShapeToFromStringGeoJSON
>                       2    7      0.2      846      2
> SpatialRPTFieldTypeTest.testShapeToFromStringWKT
>                       2    7      0.7      842      6
> TestImplicitCoreProperties(suite)
>                       2    7      0.5      839      4
> TestInfoStreamLogging(suite)
>                       2    7      0.3      886      3
> TestNumericDocValuesUpdates.testTonsOfUpdates
>                       2    7      0.4      841      3
> TestReloadAndDeleteDocs(suite)
>                       2    7      0.2      845      2
> TestReloadAndDeleteDocs.testReloadAndDeleteDocsNoUpdateLog
>                       2    7      0.2      845      2
> TestReloadAndDeleteDocs.testReloadAndDeleteDocsWithUpdateLog
>                       2    7      0.7      835      6
> TestSchemaManager(suite)
>                       2    7      0.7      838      6
> TestSimpleQParserPlugin(suite)
>                       2    7      0.2      858      2
> TestSolrCLIRunExample.testInteractiveSolrCloudExampleWithAutoScalingPolicy
>                       2    7      0.5      832      4
> TestSolrIndexConfig(suite)
>                       2     89    0.6     1143      7
> TestCollectionAPI(suite)
>                       2     8     1.4      855     12
> SpellCheckCollatorTest.testEstimatedHitCounts
>                       2     8     0.8      791      6
> TestLogWatcher.testLog4jWatcherRepeat
>                       2      9    0.2      810      2
> TestLocalFSCloudBackupRestore.test
>                       2           0.2      508      1
> AbsoluteValueFunctionTest(suite)
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.multiValueDoubleTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.multiValueFloatTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.multiValueIntTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.multiValueLongTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.singleValueDoubleTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.singleValueFloatTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.singleValueIntTest
>                       2           0.2      510      1
> AbsoluteValueFunctionTest.singleValueLongTest
>                       2           0.2      508      1
> AddFunctionTest(suite)
>                       2           0.2      512      1
> AddFunctionTest.multipleSingleValueParameterTest
>                       2           0.2      512      1
> AddFunctionTest.oneMultiOneSingleValueParameterTest
>                       2           0.2      512      1
> AddFunctionTest.oneMultiValueParameterTest
>                       2           0.2      512      1
> AddFunctionTest.twoSingleValueParametersTest
>                       2           0.2      508      1
> AndFunctionTest(suite)
>                       2           0.2      509      1
> AndFunctionTest.multipleSingleValueParameterTest
>                       2           0.2      509      1
> AndFunctionTest.oneMultiOneSingleValueParameterTest
>                       2           0.2      509      1
> AndFunctionTest.oneMultiValueParameterTest
>                       2           0.2      509      1
> AndFunctionTest.twoSingleValueParametersTest
>                       2           0.2      506      1
> BasicAuthIntegrationTest(suite)
>                       2           0.8      507      4
> BooleanFieldsTest(suite)
>                       2           0.6      507      3
> CarrotClusteringEngineTest(suite)
>                       2           0.2      508      1
> CastingAnalyticsValueTest(suite)
>                       2           0.2      512      1
> CastingAnalyticsValueTest.constantConversionTest
>                       2           0.2      512      1
> CastingAnalyticsValueTest.objectStreamCastingTest
>                       2           0.2      508      1
> CastingDoubleValueStreamTest(suite)
>                       2           0.2      509      1
> CastingDoubleValueStreamTest.constantConversionTest
>                       2           0.2      509      1
> CastingDoubleValueStreamTest.objectStreamCastingTest
>                       2           0.2      509      1
> CastingDoubleValueStreamTest.stringStreamCastingTest
>                       2           0.2      508      1
> CastingDoubleValueTest(suite)
>                       2           0.2      508      1
> CastingDoubleValueTest.constantConversionTest
>                       2           0.2      508      1
> CastingDoubleValueTest.doubleStreamCastingTest
>                       2           0.2      508      1
> CastingDoubleValueTest.objectCastingTest
>                       2           0.2      508      1
> CastingDoubleValueTest.objectStreamCastingTest
>                       2           0.2      508      1
> CastingDoubleValueTest.stringCastingTest
>                       2           0.2      508      1
> CastingDoubleValueTest.stringStreamCastingTest
>                       2           0.2      508      1
> CastingFloatValueStreamTest(suite)
>                       2           0.2      510      1
> CastingFloatValueStreamTest.constantConversionTest
>                       2           0.2      510      1
> CastingFloatValueStreamTest.doubleStreamCastingTest
>                       2           0.2      510      1
> CastingFloatValueStreamTest.objectStreamCastingTest
>                       2           0.2      510      1
> CastingFloatValueStreamTest.stringStreamCastingTest
>                       2           0.2      508      1
> CastingFloatValueTest(suite)
>                       2           0.2      511      1
> CastingFloatValueTest.constantConversionTest
>                       2           0.2      511      1
> CastingFloatValueTest.doubleCastingTest
>                       2           0.2      511      1
> CastingFloatValueTest.doubleStreamCastingTest
>                       2           0.2      511      1
> CastingFloatValueTest.floatStreamCastingTest
>                       2           0.2      511      1
> CastingFloatValueTest.objectCastingTest
>                       2           0.2      511      1
> CastingFloatValueTest.objectStreamCastingTest
>                       2           0.2      511      1
> CastingFloatValueTest.stringCastingTest
>                       2           0.2      511      1
> CastingFloatValueTest.stringStreamCastingTest
>                       2           0.2      508      1
> CastingIntValueStreamTest(suite)
>                       2           0.2      510      1
> CastingIntValueStreamTest.constantConversionTest
>                       2           0.2      510      1
> CastingIntValueStreamTest.doubleStreamCastingTest
>                       2           0.2      510      1
> CastingIntValueStreamTest.floatStreamCastingTest
>                       2           0.2      510      1
> CastingIntValueStreamTest.longStreamCastingTest
>                       2           0.2      510      1
> CastingIntValueStreamTest.objectStreamCastingTest
>                       2           0.2      510      1
> CastingIntValueStreamTest.stringStreamCastingTest
>                       2           0.2      500      1
> CloudExitableDirectoryReaderTest.test
>                       2           0.6      507      3
> ClusteringComponentTest(suite)
>                       2           0.6      508      3
> DistributedClusteringComponentTest(suite)
>                       2           0.2      510      1
> DistributedClusteringComponentTest.test
>                       2           0.8      507      4
> DoubleFieldsTest(suite)
>                       2           0.2      508      1
> ExistsFunctionTest(suite)
>                       2           0.2      508      1
> ExistsFunctionTest.multiValueParameterTest
>                       2           0.2      508      1
> ExistsFunctionTest.singleValueParameterTest
>                       2           0.2      508      1
> FillMissingFunctionTest(suite)
>                       2           0.2      509      1
> FillMissingFunctionTest.castingTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueBooleanTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueDateTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueDoubleTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueFloatTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueIntTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueLongTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueObjectTest
>                       2           0.2      509      1
> FillMissingFunctionTest.multiValueStringTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueBooleanTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueDateTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueDoubleTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueFloatTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueIntTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueLongTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueObjectTest
>                       2           0.2      509      1
> FillMissingFunctionTest.singleValueStringTest
>                       2           0.8      507      4
> FloatFieldsTest(suite)
>                       2           0.6      509      3      GetByIdTest(suite)
>                       2           5.4       37      2
> HdfsAutoAddReplicasIntegrationTest.testSimple
>                       2           0.3      598      2
> IndexSizeTriggerTest(suite)
>                       2           0.2      501      1
> InfixSuggestersTest.testReloadDuringBuild
>                       2           0.2      507      1      JdbcTest.doTest
>                       2           0.4      510      2
> JettyWebappTest(suite)
>                       2           0.2      514      1
> JettyWebappTest.testAdminUI
>                       2           1.0      484      5
> LIRRollingUpdatesTest(suite)
>                       2           0.2      510      1
> LargeVolumeEmbeddedTest.testMultiThreaded
>                       2           0.2      502      1
> LeaderElectionContextKeyTest(suite)
>                       2           0.6      507      3
> LegacyFacetSortingTest(suite)
>                       2           0.6      507      3
> LegacyFieldFacetExtrasTest(suite)
>                       2           0.8      507      4
> LegacyRangeFacetCloudTest(suite)
>                       2           0.6      507      3
> LegacyRangeFacetTest(suite)
>                       2           0.2      508      1
> LogFunctionTest(suite)
>                       2           0.2      509      1
> LogFunctionTest.multiValueParameterTest
>                       2           0.2      509      1
> LogFunctionTest.oneMultiOneSingleValueParameterTest
>                       2           0.2      509      1
> LogFunctionTest.oneSingleOneMultiValueParameterTest
>                       2           0.2      509      1
> LogFunctionTest.singleValueParameterTest
>                       2           0.2      509      1
> LogFunctionTest.twoSingleValueParametersTest
>                       2           0.2      498      1
> MigrateRouteKeyTest.multipleShardMigrateTest
>                       2           0.2      508      1
> MultFunctionTest(suite)
>                       2           0.2      511      1
> MultFunctionTest.multipleSingleValueParameterTest
>                       2           0.2      511      1
> MultFunctionTest.oneMultiOneSingleValueParameterTest
>                       2           0.2      511      1
> MultFunctionTest.oneMultiValueParameterTest
>                       2           0.2      511      1
> MultFunctionTest.twoSingleValueParametersTest
>                       2           0.2      511      1      NoFacetTest.meanTest
>                       2           0.2      511      1
> NoFacetTest.medianTest
>                       2           0.6      509      3
> NoOpResponseParserTest(suite)
>                       2           0.6      482      3
> NodeLostTriggerIntegrationTest(suite)
>                       2           0.8      503      4
> PKIAuthenticationIntegrationTest(suite)
>                       2           0.2      508      1
> RoundFunctionTest(suite)
>                       2           0.2      511      1
> RoundFunctionTest.multiValueDoubleParameterTest
>                       2           0.2      511      1
> RoundFunctionTest.multiValueFloatParameterTest
>                       2           0.2      511      1
> RoundFunctionTest.nonDecimalParameterTest
>                       2           0.2      511      1
> RoundFunctionTest.singleValueDoubleParameterTest
>                       2           0.2      511      1
> RoundFunctionTest.singleValueFloatParameterTest
>                       2           0.2      472      1
> SoftAutoCommitTest.testSoftCommitWithinAndHardCommitMaxTimeMixedAdds
>                       2           0.2      472      1
> SoftAutoCommitTest.testSoftCommitWithinAndHardCommitMaxTimeRapidAdds
>                       2           0.6      509      3      SolrPingTest(suite)
>                       2           0.8      507      4
> StringFieldsTest(suite)
>                       2           0.8      501      4
> TemplateUpdateProcessorTest(suite)
>                       2           0.2      533      1
> TestBinaryDocValuesUpdates.testSimple
>                       2           0.2      508      1
> TestBuiltInEvaluators(suite)
>                       2           0.2      511      1
> TestBuiltInEvaluators.parseParams
>                       2           0.2      511      1
> TestBuiltInEvaluators.testDateFormatEvaluator
>                       2           0.2      511      1
> TestBuiltInEvaluators.testEscapeSolrQueryFunction
>                       2           0.2      511      1
> TestBuiltInEvaluators.testSqlEscapingEvaluator
>                       2           0.2      511      1
> TestBuiltInEvaluators.testUrlEvaluator
>                       2           0.2      508      1
> TestClobTransformer(suite)
>                       2           0.2      512      1
> TestClobTransformer.simple
>                       2           0.8      492      4
> TestCloudCollectionsListeners(suite)
>                       2           0.4      496      2
> TestCloudCollectionsListeners.testCollectionDeletion
>                       2           0.4      496      2
> TestCloudCollectionsListeners.testSimpleCloudCollectionsListener
>                       2           0.4      496      2
> TestCloudCollectionsListeners.testWatchesWorkForBothStateFormats
>                       2           0.2      501      1
> TestCloudNestedDocsSort(suite)
>                       2           0.2      501      1
> TestCloudNestedDocsSort.test
>                       2           0.4      500      2
> TestCloudSearcherWarming(suite)
>                       2           0.2      523      1
> TestCollectionStateWatchers.testWaitForStateChecksCurrentState
>                       2           0.4      501      2      TestCryptoKeys(suite)
>                       2           0.2      505      1      TestCryptoKeys.test
>                       2           0.2      508      1      TestDocBuilder(suite)
>                       2           0.2      511      1
> TestDocBuilder.loadClass
>                       2           0.2      511      1
> TestDocBuilder.singleEntityMultipleRows
>                       2           0.2      511      1
> TestDocBuilder.singleEntityNoRows
>                       2           0.2      511      1
> TestDocBuilder.singleEntityOneRow
>                       2           0.2      511      1
> TestDocBuilder.templateXPath
>                       2           0.2      511      1
> TestDocBuilder.testDeltaImportNoRows_MustNotCommit
>                       2           0.2      511      1
> TestDocBuilder.testImportCommand
>                       2           0.2      508      1
> TestEntityProcessorBase(suite)
>                       2           0.2      509      1
> TestEntityProcessorBase.multiTransformer
>                       2           0.6      507      3
> TestFoldingMultitermExtrasQuery(suite)
>                       2           4.3      230     10
> TestHardLinkCopyDirectoryWrapper.testRenameWithHardLink
>                       2           0.6      507      3
> TestHierarchicalDocBuilder(suite)
>                       2           0.6      507      3
> TestICUCollationField(suite)
>                       2           0.6      507      3
> TestICUCollationFieldDocValues(suite)
>                       2           0.6      507      3
> TestICUCollationFieldOptions(suite)
>                       2           0.2      536      1
> TestIndexWriterExceptions.testDocumentsWriterExceptionThreads
>                       2           0.4      265      1
> TestIndexWriterWithThreads.testUpdateSingleDocWithThreads
>                       2           0.2      508      1
> TestJavaBinCodec.testBackCompatForSolrDocumentWithChildDocs
>                       2           0.2      448      1
> TestJdbcDataSource(suite)
>                       2           0.2      452      1
> TestJdbcDataSource.testClosesConnectionWhenExceptionThrownOnSetAutocommit
>                       2           0.2      452      1
> TestJdbcDataSource.testClosesCurrentResultSetIteratorWhenNewOneIsCreated
>                       2           0.2      452      1
> TestJdbcDataSource.testClosesResultSetAndStatementWhenDataSourceIsClosed
>                       2           0.2      452      1
> TestJdbcDataSource.testClosesStatementWhenExceptionThrownOnExecuteQuery
>                       2           0.2      452      1
> TestJdbcDataSource.testClosesStatementWhenHasNextCalledAndResultSetNull
>                       2           0.2      452      1
> TestJdbcDataSource.testClosesStatementWhenResultSetNull
>                       2           0.2      452      1
> TestJdbcDataSource.testEmptyResultSet
>                       2           0.2      452      1
> TestJdbcDataSource.testMultipleResultsSets_ResultSetResultSet
>                       2           0.2      452      1
> TestJdbcDataSource.testMultipleResultsSets_UpdateCountUpdateCountResultSet
>                       2           0.2      452      1
> TestJdbcDataSource.testRetrieveFromDriverManager
>                       2           0.2      452      1
> TestJdbcDataSource.testRetrieveFromJndi
>                       2           0.2      452      1
> TestJdbcDataSource.testRetrieveFromJndiFailureNotHidden
>                       2           0.2      452      1
> TestJdbcDataSource.testRetrieveFromJndiWithCredentials
>                       2           0.2      452      1
> TestJdbcDataSource.testRetrieveFromJndiWithCredentialsEncryptedAndResolved
>                       2           0.2      452      1
> TestJdbcDataSource.testRetrieveFromJndiWithCredentialsWithEncryptedAndResolvedPwd
>                       2           0.2      497      1
> TestJdbcDataSourceConvertType(suite)
>                       2           0.2      501      1
> TestJdbcDataSourceConvertType.testConvertType
>                       2           0.2      508      1
> TestLineEntityProcessor(suite)
>                       2           0.2      512      1
> TestLineEntityProcessor.testNo_xsd_files
>                       2           0.2      512      1
> TestLineEntityProcessor.testOnly_xml_files
>                       2           0.2      512      1
> TestLineEntityProcessor.testOnly_xml_files_no_xsd
>                       2           0.2      512      1
> TestLineEntityProcessor.testSimple
>                       2           0.6      507      3
> TestNonWritablePersistFile(suite)
>                       2           0.2      533      1
> TestOfflineSorter.testIntermediateMerges
>                       2           4.2       24      1
> TestOfflineSorter.testLargerRandom
>                       2           0.2      533      1
> TestOfflineSorter.testSmallRandom
>                       2           0.2      533      1
> TestOfflineSorter.testThreadSafety
>                       2           0.6      507      3
> TestOpenNLPExtractNamedEntitiesUpdateProcessorFactory(suite)
>                       2           0.4      501      2
> TestRealTimeGet.testStressGetRealtime
>                       2           0.2      501      1
> TestRequestStatusCollectionAPI.test
>                       2           0.6      501      3
> TestRestoreCore(suite)
>                       2           0.2      505      1
> TestRestoreCore.testFailedRestore
>                       2           0.2      505      1
> TestRestoreCore.testSimpleRestore
>                       2           0.2      500      1
> TestSSLRandomization.testRandomizedSslAndClientAuth
>                       2           0.2      508      1
> TestScriptTransformer(suite)
>                       2           0.2      512      1
> TestScriptTransformer.testBasic
>                       2           0.2      512      1
> TestScriptTransformer.testCheckScript
>                       2           0.2      512      1
> TestScriptTransformer.testOneparam
>                       2           0.2      512      1
> TestScriptTransformer.testReadScriptTag
>                       2          10.1      277     28
> TestSimpleFSDirectory.testCreateOutputWithPendingDeletes
>                       2          10.1      277     28
> TestSimpleFSDirectory.testRenameWithPendingDeletes
>                       2           0.6      507      3
> TestSimplePropertiesWriter(suite)
>                       2           0.2      507      1
> TestSolrCLIRunExample.testFailExecuteScript
>                       2           0.2      507      1
> TestSolrCLIRunExample.testSchemalessExample
>                       2           0.2      507      1
> TestSolrCLIRunExample.testTechproductsExample
>                       2           0.4      508      2
> TestSolrEntityProcessorEndToEnd(suite)
>                       2           0.6      507      3
> TestSqlEntityProcessor(suite)
>                       2           0.6      507      3
> TestSqlEntityProcessorDelta(suite)
>                       2           1.0      499      5
> TestStressLiveNodes(suite)
>                       2           0.2      498      1
> TestSystemCollAutoCreate.testAutoCreate
>                       2           0.2      508      1
> TestTemplateTransformer(suite)
>                       2           0.2      510      1
> TestTemplateTransformer.testTransformRow
>                       2           0.2      510      1
> TestTemplateTransformer.testTransformRowMultiValue
>                       2           0.4      502      2
> TestTikaEntityProcessor(suite)
>                       2           0.8      498      4
> TestTolerantUpdateProcessorRandomCloud(suite)
>                       2           0.2      508      1
> TestURLDataSource(suite)
>                       2           0.2      512      1
> TestURLDataSource.substitutionsOnBaseUrl
>                       2           0.2      503      1      TestUtils(suite)
>                       2           0.2      504      1
> TestUtils.testBinaryCommands
>                       2           0.2      504      1
> TestUtils.testEscapeTextWithSeparator
>                       2           0.2      504      1      TestUtils.testJoin
>                       2           0.2      504      1
> TestUtils.testNamedLists
>                       2           0.2      504      1
> TestUtils.testNoggitFlags
>                       2           0.2      504      1
> TestUtils.testNumberUtils
>                       2           0.2      504      1
> TestUtils.testSetObjectByPath
>                       2           0.2      504      1
> TestUtils.testSplitEscaping
>                       2           0.2      504      1
> TestUtils.testUtilsJSPath
>                       2           0.8      509      4      TestV2Request(suite)
>                       2           0.2      508      1
> TestVariableResolver(suite)
>                       2           0.2      512      1
> TestVariableResolver.dateNamespaceWithExpr
>                       2           0.2      512      1
> TestVariableResolver.dateNamespaceWithValue
>                       2           0.2      512      1
> TestVariableResolver.test3LevelNestedNamespace
>                       2           0.2      512      1
> TestVariableResolver.testDefaultNamespace
>                       2           0.2      512      1
> TestVariableResolver.testDefaultNamespace1
>                       2           0.2      512      1
> TestVariableResolver.testDefaults
>                       2           0.2      512      1
> TestVariableResolver.testFunctionNamespace1
>                       2           0.2      512      1
> TestVariableResolver.testNestedNamespace
>                       2           0.2      512      1
> TestVariableResolver.testSimpleNamespace
>                       2           0.6      507      3
> TestVariableResolverEndToEnd(suite)
>                       2           0.6      507      3      TestWriterImpl(suite)
>                       2           1.0      507      5
> TestZKPropertiesWriter(suite)
>                       2           1.0      387      4
> TestZkAclsWithHadoopAuth(suite)
>                       2           0.2      501      1
> URLClassifyProcessorTest(suite)
>                       2           0.2      505      1
> URLClassifyProcessorTest.testCanonicalUrl
>                       2           0.2      505      1
> URLClassifyProcessorTest.testLandingPage
>                       2           0.2      505      1
> URLClassifyProcessorTest.testLength
>                       2           0.2      505      1
> URLClassifyProcessorTest.testLevels
>                       2           0.2      505      1
> URLClassifyProcessorTest.testNormalizations
>                       2           0.2      505      1
> URLClassifyProcessorTest.testProcessor
>                       2           0.2      505      1
> URLClassifyProcessorTest.testTopLevelPage
>                       2           0.8      509      4
> UsingSolrJRefGuideExamplesTest(suite)
>                       2           0.6      502      3
> V2StandaloneTest(suite)
>                       2           0.2      503      1
> V2StandaloneTest.testWelcomeMessage
>                       2           0.2      497      1      ZkCLITest(suite)
>                       2           0.2      501      1
> ZkCLITest.testBootstrapWithChroot
>                       2           0.2      501      1
> ZkCLITest.testCmdConstants
>                       2           0.2      501      1      ZkCLITest.testGet
>                       2           0.2      501      1      ZkCLITest.testGetFile
>                       2           0.2      501      1
> ZkCLITest.testGetFileNotExists
>                       2           0.2      501      1
> ZkCLITest.testInvalidZKAddress
>                       2           0.2      501      1      ZkCLITest.testList
>                       2           0.2      501      1      ZkCLITest.testLs
>                       2           0.2      501      1
> ZkCLITest.testMakePath
>                       2           0.2      501      1      ZkCLITest.testPut
>                       2           0.2      501      1      ZkCLITest.testPutFile
>                       2           0.2      501      1
> ZkCLITest.testPutFileNotExists
>                       2           0.2      501      1
> ZkCLITest.testSetClusterProperty
>                       2           0.2      501      1
> ZkCLITest.testUpConfigLinkConfigClearZk
>                       2           0.2      501      1
> ZkCLITest.testUpdateAcls
>                       2           0.2      504      1
> ZkStateReaderTest(suite)
>                       2           0.2      508      1
> ZkStateReaderTest.testCollectionStateWatcherCaching
>                       2           0.2      508      1
> ZkStateReaderTest.testExternalCollectionWatchedNotWatched
>                       2           0.2      508      1
> ZkStateReaderTest.testStateFormatUpdateWithExplicitRefresh
>                       2           0.2      508      1
> ZkStateReaderTest.testStateFormatUpdateWithExplicitRefreshLazy
>                       2           0.2      508      1
> ZkStateReaderTest.testStateFormatUpdateWithTimeDelay
>                       2           0.2      508      1
> ZkStateReaderTest.testStateFormatUpdateWithTimeDelayLazy
>                       2           0.2      508      1
> ZkStateReaderTest.testWatchedCollectionCreation
>                        345 789    0.4     2067      8
> TimeRoutedAliasUpdateProcessorTest.test
>                        34 67     77.8        9      7
> HdfsChaosMonkeySafeLeaderTest(suite)
>                        34 6       0.6      855      5
> TestRecoveryHdfs.testBufferingFlags
>                        34 6       0.6      855      5
> TestRecoveryHdfs.testCorruptLog
>                        34 6       0.5      855      4
> TestRecoveryHdfs.testRemoveOldLogs
>                        34 6       0.6      855      5
> TestRecoveryHdfs.testReplicationFactor
>                        34 6       0.5      855      4
> TestRecoveryHdfs.testTruncatedLog
>                        34   8     0.3     1029      3
> ConcurrentCreateRoutedAliasTest.testConcurrentCreateRoutedAliasMinimal
>                        34   8     7.5       67      5
> TestDoubleRangeFieldQueries.testRandomBig
>                        34   8     4.5       66      3
> TestLongRangeFieldQueries.testRandomBig
>                        34         0.4      567      2
> HdfsRecoverLeaseTest.testBasic
>                        34         0.4      567      2
> HdfsRecoverLeaseTest.testMultiThreaded
>                        34         1.1      567      6
> MoveReplicaHDFSTest(suite)
>                        34         0.6      685      4
> ShardRoutingTest(suite)
>                        34        10.7      777     83
> SpellCheckComponentTest.testExtendedResultsCount
>                        34         0.9      677      6
> TestLeaderElectionWithEmptyReplica(suite)
>                        34         0.5      575      3
> TestRecoveryHdfs.testLogReplay
>                        34         0.9      680      6
> TimeRoutedAliasUpdateProcessorTest(suite)
>                        3  67 9    1.6     1335     22
> TestDocTermOrds(suite)
>                        3   789   12.5       48      6
> HdfsBasicDistributedZk2Test.test
>                        3   78    90.0       10      9
> HdfsRestartWhileUpdatingTest.test
>                        3   78     0.3     1053      3
> UninvertDocValuesMergePolicyTest.testIndexAndAddDocValues
>                        3   7      0.5      745      4
> TestCollectionStateWatchers(suite)
>                        3   7      0.4      733      3
> TestLockTree.testLocks
>                        3    89    0.5      838      4
> HDFSCollectionsAPITest.testDataDirIsNotReused
>                        3    8     0.3      733      2
> AliasIntegrationTest.testDeleteOneOfTwoCollectionsAliased
>                        3    8     0.3      747      2
> SelectWithEvaluatorsTest(suite)
>                        3    8     4.0       50      2
> TestFloatRangeFieldQueries.testRandomBig
>                        3     9    0.6      698      4
> BlockDirectoryTest.testEOF
>                        3     9    0.3      693      2
> CollectionsAPIDistributedZkTest.testCreateShouldFailOnExistingCore
>                        3          0.3      379      1
> ActionThrottleTest.testAZeroNanoTimeReturnInWait
>                        3          7.7       13      1
> CdcrReplicationHandlerTest.testReplicationWithBufferedUpdates
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.deleteCollectionOnlyInZk
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.deleteCollectionRemovesStaleZkCollectionsNode
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testBadActionNames
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testCoresAreDistributedAcrossNodes
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testCreationAndDeletion
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testDeleteNonExistentCollection
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testMaxNodesPerShard
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testNoConfigSetExist
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testSpecificConfigsets
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testTooManyReplicas
>                        3          0.3      384      1
> CollectionsAPIDistributedZkTest.testZeroNumShards
>                        3          1.1      378      4
> CurrencyRangeFacetCloudTest(suite)
>                        3          0.9      324      3
> HdfsDirectoryTest(suite)
>                        3          0.5      390      2
> LegacyQueryFacetCloudTest.queryTest
>                        3          0.3      349      1
> MathExpressionTest.testZipFDistribution
>                        3          0.3      375      1
> MetricsHandlerTest.test
>                        3          0.3      375      1
> MetricsHandlerTest.testCompact
>                        3          0.2      458      1
> NodeAddedTriggerTest.testTrigger
>                        3          1.3      387      5
> OverallAnalyticsTest(suite)
>                        3          0.6      333      2      OverseerTest(suite)
>                        3          0.3      333      1
> OverseerTest.testBadQueueItem
>                        3          0.3      333      1
> OverseerTest.testDownNodeFailover
>                        3          0.3      372      1      PluginInfoTest(suite)
>                        3          0.5      383      2
> RollingRestartTest(suite)
>                        3          1.1      352      4
> SearchRateTriggerIntegrationTest(suite)
>                        3          0.3      382      1
> SimpleMLTQParserTest.doTest
>                        3          0.3      376      1      SparseHLLTest(suite)
>                        3          0.3      343      1
> StreamDecoratorTest.testParallelComplementStream
>                        3          1.8       57      1
> StreamExpressionTest.testZipFDistribution
>                        3          0.5      380      2
> TestConfigReload(suite)
>                        3          0.3      392      1
> TestFixedGapPostingsFormat.testPostingsEnumReuse
>                        3          0.3      398      1
> TestIndexWriter.testCreateWithReader
>                        3          0.3      385      1
> TestJmxIntegration.testJmxRegistration
>                        3        100.0       20     20
> TestLucene50LiveDocsFormat.testOverflow
>                        3          2.1      236      5
> TestMixedDocValuesUpdates.testResetValueMultipleDocs
>                        3          0.3      381      1
> TestNumericTerms64(suite)
>                        3          0.3      374      1
> TestOnReconnectListenerSupport.test
>                        3          0.3      373      1
> TestRandomFlRTGCloud.testRandomizedUpdatesAndRTGs
>                        3          0.3      387      1
> TestSimpleTextCompoundFormat.testLargeCFS
>                        3        100.0       23     23
> TestSimpleTextLiveDocsFormat.testOverflow
>                        3          0.3      381      1
> TestSort.testRandomFieldNameSorts
>                        3          0.3      380      1
> TestStressReorder.testStressReorderVersions
>                        3          1.2      328      4
> TriggerSetPropertiesIntegrationTest(suite)
>                        3          0.3      333      1
> TriggerSetPropertiesIntegrationTest.testSetProperties
>                        3          0.3      391      1
> ValueFacetTest.medianTest
>                        3          0.2      460      1
> ZkControllerTest.testGetHostName
>                         456 8     0.5     1123      6
> TestHdfsCloudBackupRestore.test
>                         456  9    0.8     1313     10
> ChaosMonkeyNothingIsSafeWithPullReplicasTest(suite)
>                         456  9    0.4     1323      5
> ChaosMonkeyNothingIsSafeWithPullReplicasTest.test
>                         456       0.3     1014      3
> TestPullReplicaErrorHandling.testCantConnectToLeader
>                         45  89   11.1       90     10
> Test4GBStoredFields.test
>                         45  8     0.5     1075      5
> TestControlledRealTimeReopenThread.testControlledRealTimeReopenThread
>                         45        0.6      679      4
> StreamDecoratorTest.testParallelCommitStream
>                         45        0.5      638      3
> TestSolrCloudWithSecureImpersonation.testForwarding
>                         4 678     6.6       76      5
> HdfsBasicDistributedZkTest.test
>                         4 67 9    0.7     1328      9      TestStressNRT.test
>                         4 6       5.1       39      2
> TestDuelingCodecsAtNight.testBigEquals
>                         4 6       0.8      531      4
> TestRecoveryHdfs.testBuffering
>                         4 6       0.6      531      3
> TestRecoveryHdfs.testCleanShutdown
>                         4 6       0.8      531      4
> TestRecoveryHdfs.testRecoveryMultipleLogs
>                         4 6       0.8      531      4
> TestRecoveryHdfs.testVersionsOnRestart
>                         4  789    0.3     1314      4
> AliasIntegrationTest.testModifyPropertiesV1
>                         4  78     0.4     1007      4
> CreateRoutedAliasTest.testTimeStampWithMsFails
>                         4  7      0.6      641      4
> InfixSuggestersTest(suite)
>                         4  7      0.6      640      4
> TestInPlaceUpdatesDistrib(suite)
>                         4  7      0.8      646      5
> ZkSolrClientTest(suite)
>                         4   8     0.3      653      2
> CreateRoutedAliasTest.testRandomRouterNameFails
>                         4   8    11.6      709     82
> DeleteInactiveReplicaTest.deleteInactiveReplicaTest
>                         4   8     3.7       54      2
> HdfsCollectionsAPIDistributedZkTest.testCreateNodeSet
>                         4   8     0.3      639      2
> TestNamedUpdateProcessors.test
>                         4   8     5.3       38      2
> TestSimpleTextStoredFieldsFormat.testBigDocuments
>                         4    9    0.5      380      2
> StreamExpressionTest.testExecutorStream
>                         4    9    0.8      358      3
> TriggerIntegrationTest.testScheduledTrigger
>                         4         0.7      305      2
> AliasIntegrationTest(suite)
>                         4         0.6      309      2
> AssignBackwardCompatibilityTest(suite)
>                         4         0.3      305      1
> AssignTest.testIdIsUnique
>                         4         0.6      308      2
> BasicDistributedZk2Test(suite)
>                         4         0.3      309      1
> CreateRoutedAliasTest.testUnParseableFutureFails
>                         4         0.4      246      1
> HdfsDirectoryFactoryTest.testLocalityReporter
>                         4         0.8      249      2
> HdfsDirectoryTest.testRename
>                         4         0.7      306      2
> LeaderFailureAfterFreshStartTest(suite)
>                         4         0.3      310      1
> SolrCollectorTest.testCollect
>                         4         0.6      317      2
> TestBackwardsCompatibility(suite)
>                         4         0.7      306      2
> TestBlobHandler(suite)
>                         4         4.0      301     12
> TestCloudJSONFacetJoinDomain(suite)
>                         4         1.6      313      5
> TestDirectoryTaxonomyWriter.testRecreateAndRefresh
>                         4         0.3      312      1
> TestDistribIDF.testSimpleQuery
>                         4         0.3      318      1
> TestDoubleRangeFieldQueries.testMultiValued
>                         4         7.1      338     24
> TestIndexWriterOutOfFileDescriptors.test
>                         4         0.3      318      1
> TestLRUQueryCache.testMinSegmentSizePredicate
>                         4         0.4      282      1
> TestLRUQueryCache.testQueryCacheSoftUpdate
>                         4         0.3      317      1
> TestLongRangeFieldQueries.testRandomMedium
>                         4         0.7      303      2
> TestNamedUpdateProcessors(suite)
>                         4         5.2      305     16
> TestNativeFSLockFactory.testStressLocks
>                         4         0.3      318      1
> TestSearcherManager.testSearcherManager
>                         4         5.5      309     17
> TestSimpleFSLockFactory.testStressLocks
>                         4         2.1      288      6
> TestSingleInstanceLockFactory.testStressLocks
>                         4         2.3      298      7
> TestSleepingLockWrapper.testStressLocks
>                         4         0.3      322      1
> TestSmartChineseAnalyzer.testRandomHugeStrings
>                         4         0.3      307      1
> ZkSolrClientTest.testClean
>                          56 89    0.3     1357      4
> AliasIntegrationTest.testModifyPropertiesV2
>                          56       0.3      698      2
> CreateRoutedAliasTest.testAliasNameMustBeValid
>                          5 7      0.8      716      6
> CdcrBootstrapTest(suite)
>                          5  8     1.3      397      5
> NodeMarkersRegistrationTest.testNodeMarkersRegistration
>                          5        0.4      275      1
> AliasIntegrationTest.testProperties
>                          5        0.3      386      1
> ComputePlanActionTest.testNodeWithMultipleReplicasLost
>                          5        5.0       20      1      Test2BPostings.test
>                          5        0.3      393      1
> TestIndexWriterReader(suite)
>                          5        4.8       21      1
> TestIndexWriterReader.testDuringAddIndexes
>                          5        0.5      393      2
> TestLRUQueryCache.testEvictEmptySegmentCache
>                          5        0.5      393      2
> TestLRUQueryCache.testRefuseToCacheTooLargeEntries
>                           67      0.7      578      4
> ForceLeaderTest.testZombieLeader
>                           67      0.3      660      2
> TestDocTermOrds.testActuallySingleValued
>                           67      0.5      659      3
> TestDocTermOrds.testBackToTheFuture
>                           67      0.3      661      2
> TestDocTermOrds.testRandom
>                           67      0.3      659      2
> TestDocTermOrds.testSortedTermsEnum
>                           67      0.3      657      2      TestLazyCores(suite)
>                           67      0.3      663      2
> TestPullReplicaErrorHandling.testPullReplicaDisconnectsFromZooKeeper
>                           67     19.0      753    143
> TestSolr4Spatial2.testLatLonRetrieval
>                           67      1.4      666      9
> TestSubQueryTransformerDistrib.test
>                           6 8     0.5      662      3
> TestDocTermOrds.testNumericEncoded64
>                           6  9    0.3      616      2
> CdcrBootstrapTest.testBootstrapWithSourceCluster
>                           6  9    0.3      635      2
> TestZKPropertiesWriter.testZKPropertiesWriter
>                           6       2.6       38      1
> AliasIntegrationTest.testModifyPropertiesCAR
>                           6       1.3      310      4      BasicZkTest(suite)
>                           6       0.3      325      1
> BlockDirectoryTest.testRandomAccessWritesLargeCache
>                           6       0.3      307      1
> DistributedQueueTest.testDistributedQueueBlocking
>                           6       1.5      324      5
> Geo3dShapeWGS84ModelRectRelationTest.testGeoPolygonRect
>                           6       0.3      312      1
> PKIAuthenticationIntegrationTest.testPkiAuth
>                           6      10.0       80      8
> RandomGeoPolygonTest.testComparePolygons
>                           6       0.6      319      2
> RecoveryAfterSoftCommitTest.test
>                           6       2.9      313      9
> SegmentsInfoRequestHandlerTest.testSegmentInfos
>                           6       2.3      311      7
> SegmentsInfoRequestHandlerTest.testSegmentInfosData
>                           6       0.3      319      1
> StreamExpressionTest.testSqlStream
>                           6       0.3      311      1
> TemplateUpdateProcessorTest.testSimple
>                           6       0.6      320      2
> TestBooleanScorer(suite)
>                           6       0.6      326      2
> TestBooleanScorer.testSparseClauseOptimization
>                           6       0.6      310      2
> TestCloudSchemaless(suite)
>                           6       0.6      310      2
> TestConfigSetsAPI(suite)
>                           6       0.3      310      1
> TestConfigSetsAPI.testUpload
>                           6       0.3      314      1
> TestContentStreamDataSource.testCommitWithin
>                           6       0.6      308      2
> TestDistribDocBasedVersion(suite)
>                           6       0.3      316      1
> TestDocTermOrds.testEmptyIndex
>                           6       0.6      314      2
> TestExternalFeatures(suite)
>                           6       0.3      324      1
> TestIndexWriter.testSoftUpdatesConcurrently
>                           6       0.3      320      1
> TestIndexWriterOnVMError(suite)
>                           6       4.2       24      1
> TestIndexWriterOnVMError.testCheckpoint
>                           6       0.9      325      3
> TestIndexingSequenceNumbers.testStressUpdateSameID
>                           6       0.3      319      1
> TestLazyCores.testMidUseUnload
>                           6       0.3      311      1
> TestMiniSolrCloudClusterSSL.testSslAndNoClientAuth
>                           6       0.3      322      1
> TestPendingSoftDeletes.testUpdateAppliedOnlyOnce
>                           6       2.7      257      7
> TestUnInvertedFieldException(suite)
>                            789    0.9     1046      9
> TestIndexSorting.testRandom3
>                            789    1.0      608      6
> TestReplicationHandler.doTestIndexAndConfigReplication
>                            789   11.1       63      7
> TestSolr4Spatial2.testLLPDecodeIsStableAndPrecise
>                            78     0.9      665      6
> BlockJoinFacetRandomTest(suite)
>                            78     0.5      569      3
> StreamExpressionTest.testGammaDistribution
>                            78     0.6      682      4
> SuggesterWFSTTest(suite)
>                            78     0.3      719      2
> TestIndexSorting(suite)
>                            78     3.0      692     21
> TestRecovery.testBuffering
>                            78     0.9      688      6
> TestRecovery.testCorruptLog
>                            78     1.3      687      9
> TestRecovery.testRecoveryMultipleLogs
>                            78     1.3      690      9
> TestRecovery.testVersionsOnRestart
>                            78     0.6      673      4
> TestScoreJoinQPScore(suite)
>                            7 9    2.4       82      2
> StreamExpressionTest.testDistributions
>                            7 9    0.3      648      2
> TestComputePlanAction.testNodeWithMultipleReplicasLost
>                            7 9    0.8      644      5
> TestDFRSimilarityFactory(suite)
>                            7      0.3      348      1
> ActionThrottleTest.testBasics
>                            7      0.9      336      3
> AddBlockUpdateTest(suite)
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest(suite)
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testCopyFieldByIndexing
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testMultipleFieldsRoundTrip
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testParseAndAddMultipleFieldsRoundTrip
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testSingleField
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldDefaultFieldTypeRoundTrip
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldDefaultTypeMappingRoundTrip
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldMixedFieldTypesRoundTrip
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testSingleFieldRoundTrip
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testStringWithCopyField
>                            7      0.3      339      1
> AddSchemaFieldsUpdateProcessorFactoryTest.testStringWithCopyFieldAndMaxChars
>                            7      0.9      342      3
> AlternateDirectoryTest(suite)
>                            7      0.9      338      3
> AnalysisAfterCoreReloadTest(suite)
>                            7      0.9      333      3
> AnalysisErrorHandlingTest(suite)
>                            7      0.3      340      1
> AnalyticsMergeStrategyTest(suite)
>                            7      0.9      336      3
> AnalyticsQueryTest(suite)
>                            7      0.9      336      3
> AtomicUpdateProcessorFactoryTest(suite)
>                            7      0.9      339      3
> AtomicUpdatesTest(suite)
>                            7      0.9      336      3      BJQParserTest(suite)
>                            7      0.3      343      1
> BadComponentTest(suite)
>                            7      0.3      343      1
> BadComponentTest.testBadElevate
>                            7      0.3      337      1
> BadIndexSchemaTest(suite)
>                            7      0.3      337      1
> BadIndexSchemaTest.testPerFieldtypePostingsFormatButNoSchemaCodecFactory
>                            7      0.3      337      1
> BadIndexSchemaTest.testRootTypeDynamicMissmatchWithUniqueKey
>                            7      0.3      337      1
> BadIndexSchemaTest.testSimDefaultFieldTypeDoesNotExist
>                            7      0.3      337      1
> BadIndexSchemaTest.testSimDefaultFieldTypeHasNoExplicitSim
>                            7      0.9      340      3
> BasicFunctionalityTest(suite)
>                            7      0.9      338      3
> BlockJoinFacetSimpleTest(suite)
>                            7      0.9      338      3
> BooleanFieldTest(suite)
>                            7      0.9      340      3
> CSVRequestHandlerTest(suite)
>                            7      0.3      337      1
> ChangedSchemaMergeTest(suite)
>                            7      0.3      337      1
> ChangedSchemaMergeTest.testOptimizeDiffSchemas
>                            7      0.9      337      3
> ClassificationUpdateProcessorIntegrationTest(suite)
>                            7      1.1      277      3
> ClassificationUpdateProcessorTest(suite)
>                            7      0.9      334      3
> CloneFieldUpdateProcessorFactoryTest(suite)
>                            7      0.9      342      3
> ConvertedLegacyTest(suite)
>                            7      0.9      343      3      CopyFieldTest(suite)
>                            7      0.9      337      3
> CoreAdminCreateDiscoverTest(suite)
>                            7      0.9      338      3
> CoreAdminHandlerTest(suite)
>                            7      0.9      338      3
> CoreAdminRequestStatusTest(suite)
>                            7      0.9      340      3
> CoreMergeIndexesAdminHandlerTest(suite)
>                            7      0.9      339      3
> CurrencyFieldTypeTest(suite)
>                            7      0.9      340      3      CursorMarkTest(suite)
>                            7      0.9      339      3
> CursorPagingTest(suite)
>                            7      0.3      336      1
> DataDrivenBlockJoinTest(suite)
>                            7      0.3      336      1
> DataDrivenBlockJoinTest.testAddNestedDocuments
>                            7      0.9      342      3
> DateRangeFieldTest(suite)
>                            7      0.9      336      3
> DebugComponentTest(suite)
>                            7      0.9      340      3
> DefaultValueUpdateProcessorTest(suite)
>                            7      0.9      343      3
> DirectSolrSpellCheckerTest(suite)
>                            7      0.9      344      3
> DirectUpdateHandlerOptimizeTest(suite)
>                            7      0.9      338      3
> DirectUpdateHandlerTest(suite)
>                            7      0.9      341      3
> DisMaxRequestHandlerTest(suite)
>                            7      0.9      343      3
> DistanceFunctionTest(suite)
>                            7      0.9      335      3
> DistributedExpandComponentTest(suite)
>                            7      0.9      338      3
> DistributedQueryComponentCustomSortTest(suite)
>                            7      0.9      334      3
> DocExpirationUpdateProcessorFactoryTest(suite)
>                            7      0.9      336      3
> DocValuesMissingTest(suite)
>                            7      0.9      341      3
> DocValuesMultiTest(suite)
>                            7      0.9      340      3      DocValuesTest(suite)
>                            7      0.9      341      3
> DocumentAnalysisRequestHandlerTest(suite)
>                            7      0.9      339      3
> DocumentBuilderTest(suite)
>                            7      0.9      333      3      EnumFieldTest(suite)
>                            7      0.9      337      3
> ExitableDirectoryReaderTest(suite)
>                            7      0.3      340      1
> ExternalFileFieldSortTest(suite)
>                            7      0.3      340      1
> ExternalFileFieldSortTest.testSort
>                            7      0.9      341      3
> FastVectorHighlighterTest(suite)
>                            7      0.9      338      3
> FieldAnalysisRequestHandlerTest(suite)
>                            7      0.9      343      3
> FieldMutatingUpdateProcessorTest(suite)
>                            7      0.9      341      3      GraphQueryTest(suite)
>                            7      0.9      336      3
> HighlighterConfigTest(suite)
>                            7      0.9      339      3
> HighlighterMaxOffsetTest(suite)
>                            7      0.9      342      3
> HighlighterTest(suite)
>                            7      0.9      334      3
> IgnoreCommitOptimizeUpdateProcessorFactoryTest(suite)
>                            7      0.9      335      3
> IndexBasedSpellCheckerTest(suite)
>                            7      0.9      336      3
> IndexSchemaRuntimeFieldTest(suite)
>                            7      0.9      335      3
> IndexSchemaTest(suite)
>                            7      0.9      338      3
> InfoHandlerTest(suite)
>                            7      0.9      338      3      JSONWriterTest(suite)
>                            7      0.9      335      3
> JavabinLoaderTest(suite)
>                            7      0.9      340      3      JsonLoaderTest(suite)
>                            7      0.9      339      3      LargeFieldTest(suite)
>                            7      0.9      340      3
> LoggingHandlerTest(suite)
>                            7      0.9      342      3
> LukeRequestHandlerTest(suite)
>                            7      0.9      336      3
> MBeansHandlerTest(suite)
>                            7      0.9      339      3
> MergeStrategyTest(suite)
>                            7      0.9      335      3
> MetricsHandlerTest(suite)
>                            7      0.9      339      3
> MinimalSchemaTest(suite)
>                            7      0.9      342      3
> MoreLikeThisHandlerTest(suite)
>                            7      0.9      337      3      MultiTermTest(suite)
>                            7      0.9      340      3
> NodeMutatorTest(suite)
>                            7      0.9      339      3
> NotRequiredUniqueKeyTest(suite)
>                            7      0.9      335      3
> NumericFieldsTest(suite)
>                            7      0.9      339      3
> ParsingFieldUpdateProcessorsTest(suite)
>                            7      0.9      339      3
> PathHierarchyTokenizerFactoryTest(suite)
>                            7      0.6      342      2      PeerSyncTest(suite)
>                            7      0.3      342      1      PeerSyncTest.test
>                            7      0.9      338      3
> PingRequestHandlerTest(suite)
>                            7      0.9      338      3      PolyFieldTest(suite)
>                            7      0.9      339      3
> PreAnalyzedFieldTest(suite)
>                            7      0.9      337      3
> PreAnalyzedUpdateProcessorTest(suite)
>                            7      0.9      340      3
> PropertiesRequestHandlerTest(suite)
>                            7      0.3      342      1
> QueryElevationComponentTest(suite)
>                            7      0.3      342      1
> QueryElevationComponentTest.testElevationReloading
>                            7      0.3      342      1
> QueryElevationComponentTest.testFieldType
>                            7      0.3      342      1
> QueryElevationComponentTest.testGroupedQuery
>                            7      0.3      342      1
> QueryElevationComponentTest.testInterface
>                            7      0.3      342      1
> QueryElevationComponentTest.testMarkExcludes
>                            7      0.3      342      1
> QueryElevationComponentTest.testMarker
>                            7      0.3      342      1
> QueryElevationComponentTest.testSorting
>                            7      0.3      342      1
> QueryElevationComponentTest.testTrieFieldType
>                            7      0.3      342      1
> QueryElevationComponentTest.testWithLocalParam
>                            7      0.9      336      3
> QueryParsingTest(suite)
>                            7      0.9      341      3      RankQueryTest(suite)
>                            7      0.9      340      3
> RegexBoostProcessorTest(suite)
>                            7      0.9      341      3
> RequestHandlersTest(suite)
>                            7      0.9      339      3
> RequestLoggingTest(suite)
>                            7      0.9      344      3
> RequiredFieldsTest(suite)
>                            7      0.9      339      3
> ResponseBuilderTest(suite)
>                            7      0.9      341      3
> ResponseLogComponentTest(suite)
>                            7      0.9      340      3
> ReturnFieldsTest(suite)
>                            7      0.3      347      1
> SchemaVersionSpecificBehaviorTest(suite)
>                            7      0.3      347      1
> SchemaVersionSpecificBehaviorTest.testVersionBehavior
>                            7      0.9      679      6
> SearchHandlerTest(suite)
>                            7      0.9      336      3
> SegmentsInfoRequestHandlerTest(suite)
>                            7      0.3      340      1
> ShowFileRequestHandlerTest(suite)
>                            7      0.3      340      1
> ShowFileRequestHandlerTest.test404Locally
>                            7      0.9      339      3
> SignatureUpdateProcessorFactoryTest(suite)
>                            7      0.9      338      3
> SimpleFacetsTest(suite)
>                            7      0.9      334      3
> SimpleMLTQParserTest(suite)
>                            7      0.9      337      3
> SmileWriterTest(suite)
>                            7      1.0      315      3
> SoftAutoCommitTest(suite)
>                            7      0.3      337      1
> SolrCoreMetricManagerTest(suite)
>                            7      0.3      337      1
> SolrCoreMetricManagerTest.testLoadReporter
>                            7      0.3      337      1
> SolrCoreMetricManagerTest.testNonCloudRegistryName
>                            7      0.3      337      1
> SolrCoreMetricManagerTest.testRegisterMetrics
>                            7      0.3      337      1
> SolrCoreMetricManagerTest.testRegisterMetricsWithReplacements
>                            7      0.3      342      1      SolrCoreTest(suite)
>                            7      0.3      342      1
> SolrCoreTest.testClose
>                            7      0.3      342      1
> SolrCoreTest.testConfiguration
>                            7      0.3      342      1
> SolrCoreTest.testImplicitPlugins
>                            7      0.3      342      1
> SolrCoreTest.testInfoRegistry
>                            7      0.3      342      1
> SolrCoreTest.testRefCount
>                            7      0.3      342      1
> SolrCoreTest.testRefCountMT
>                            7      0.3      342      1
> SolrCoreTest.testReloadLeak
>                            7      0.4      275      1
> SolrGangliaReporterTest(suite)
>                            7      0.4      275      1
> SolrGangliaReporterTest.testReporter
>                            7      0.3      337      1
> SolrGraphiteReporterTest(suite)
>                            7      0.3      337      1
> SolrGraphiteReporterTest.testReporter
>                            7      0.9      339      3
> SolrIndexConfigTest(suite)
>                            7      0.3      340      1
> SolrIndexMetricsTest(suite)
>                            7      0.3      340      1
> SolrIndexMetricsTest.testIndexMetricsNoDetails
>                            7      0.3      340      1
> SolrIndexMetricsTest.testIndexMetricsWithDetails
>                            7      0.3      340      1
> SolrIndexMetricsTest.testIndexNoMetrics
>                            7      0.9      340      3
> SolrIndexSplitterTest(suite)
>                            7      0.9      340      3
> SolrInfoBeanTest(suite)
>                            7      0.3      340      1
> SolrJmxReporterTest.testClosedCore
>                            7      0.3      340      1
> SolrJmxReporterTest.testEnabled
>                            7      0.3      340      1
> SolrJmxReporterTest.testReloadCore
>                            7      0.3      340      1
> SolrJmxReporterTest.testReportMetrics
>                            7      0.3      347      1
> SolrMetricsIntegrationTest(suite)
>                            7      0.3      347      1
> SolrMetricsIntegrationTest.testConfigureReporter
>                            7      0.3      347      1
> SolrMetricsIntegrationTest.testCoreContainerMetrics
>                            7      0.9      339      3
> SolrPluginUtilsTest(suite)
>                            7      1.1      280      3
> SolrRequestParserTest(suite)
>                            7      0.3      335      1
> SolrSlf4jReporterTest(suite)
>                            7      0.9      340      3
> SolrTestCaseJ4Test(suite)
>                            7      0.9      338      3
> SortByFunctionTest(suite)
>                            7      0.9      338      3
> SortSpecParsingTest(suite)
>                            7      0.9      342      3
> SpatialFilterTest(suite)
>                            7      0.9      345      3
> SpellCheckCollatorTest(suite)
>                            7      0.9      336      3
> SpellCheckCollatorWithCollapseTest(suite)
>                            7      0.9      337      3
> SpellCheckComponentTest(suite)
>                            7      0.9      343      3
> StatelessScriptUpdateProcessorFactoryTest(suite)
>                            7      0.9      342      3
> StatsComponentTest(suite)
>                            7      0.9      336      3
> StatsReloadRaceTest(suite)
>                            7      0.7      150      1
> StreamDecoratorTest.testParallelExecutorStream
>                            7      0.9      338      3
> SuggestComponentContextFilterQueryTest(suite)
>                            7      0.9      340      3
> SuggestComponentTest(suite)
>                            7      0.9      342      3
> SuggesterFSTTest(suite)
>                            7      0.9      337      3
> SuggesterTSTTest(suite)
>                            7      0.9      344      3      SuggesterTest(suite)
>                            7      0.9      339      3
> SynonymTokenizerTest(suite)
>                            7      0.9      341      3
> TermVectorComponentTest(suite)
>                            7      0.9      337      3
> TermsComponentTest(suite)
>                            7      0.3      339      1
> TestAddFieldRealTimeGet(suite)
>                            7      0.3      339      1
> TestAddFieldRealTimeGet.test
>                            7      0.9      343      3
> TestAnalyzeInfixSuggestions(suite)
>                            7      0.9      338      3
> TestAnalyzedSuggestions(suite)
>                            7      0.3      339      1
> TestAtomicUpdateErrorCases(suite)
>                            7      0.3      339      1
> TestAtomicUpdateErrorCases.testUpdateNoDistribProcessor
>                            7      0.3      339      1
> TestAtomicUpdateErrorCases.testUpdateNoTLog
>                            7      0.9      338      3
> TestBM25SimilarityFactory(suite)
>                            7      0.3      339      1      TestBadConfig(suite)
>                            7      0.3      339      1
> TestBadConfig.testBogusMergePolicy
>                            7      0.3      339      1
> TestBadConfig.testBogusScriptEngine
>                            7      0.3      339      1
> TestBadConfig.testInvalidScriptFile
>                            7      0.3      339      1
> TestBadConfig.testMissingScriptFile
>                            7      0.3      339      1
> TestBadConfig.testTolerantUpdateProcessorNoUniqueKey
>                            7      0.3      339      1
> TestBadConfig.testUpdateLogButNoVersionField
>                            7      0.3      354      1
> TestBinaryDocValuesUpdates(suite)
>                            7      0.9      336      3
> TestBinaryResponseWriter(suite)
>                            7      0.9      337      3
> TestBlendedInfixSuggestions(suite)
>                            7      0.9      339      3      TestCSVLoader(suite)
>                            7      0.9      344      3
> TestCSVResponseWriter(suite)
>                            7      0.9      341      3
> TestCharFilters(suite)
>                            7      0.9      341      3
> TestChildDocTransformer(suite)
>                            7      0.9      338      3
> TestClassicSimilarityFactory(suite)
>                            7      0.9      340      3
> TestCodecSupport(suite)
>                            7      0.9      339      3
> TestCollapseQParserPlugin(suite)
>                            7      0.9      343      3
> TestCollationField(suite)
>                            7      0.9      336      3
> TestCollationFieldDocValues(suite)
>                            7      0.9      340      3
> TestComplexPhraseLeadingWildcard(suite)
>                            7      0.9      335      3
> TestComplexPhraseQParserPlugin(suite)
>                            7      0.9      337      3
> TestComponentsName(suite)
>                            7      0.9      340      3      TestConfig(suite)
>                            7      0.3      339      1      TestConfigSets(suite)
>                            7      0.3      339      1
> TestConfigSets.testConfigSetOnCoreReload
>                            7      0.3      339      1
> TestConfigSets.testConfigSetServiceFindsConfigSets
>                            7      0.3      339      1
> TestConfigSets.testNonExistentConfigSetThrowsException
>                            7      0.9      339      3      TestCoreBackup(suite)
>                            7      0.3      341      1
> TestCoreContainer(suite)
>                            7      0.3      341      1
> TestCoreContainer.testClassLoaderHierarchy
>                            7      0.3      341      1
> TestCoreContainer.testCoreInitFailuresFromEmptyContainer
>                            7      0.3      341      1
> TestCoreContainer.testCoreInitFailuresOnReload
>                            7      0.3      341      1
> TestCoreContainer.testCustomHandlers
>                            7      0.3      341      1
> TestCoreContainer.testDeleteBadCores
>                            7      0.3      341      1
> TestCoreContainer.testLogWatcherEnabledByDefault
>                            7      0.3      341      1
> TestCoreContainer.testNoCores
>                            7      0.3      341      1
> TestCoreContainer.testReloadSequential
>                            7      0.3      341      1
> TestCoreContainer.testReloadThreaded
>                            7      0.3      341      1
> TestCoreContainer.testShareSchema
>                            7      0.3      341      1
> TestCoreContainer.testSharedLib
>                            7      0.3      341      1
> TestCorePropertiesReload(suite)
>                            7      0.3      341      1
> TestCorePropertiesReload.testPropertiesReload
>                            7      0.9      343      3
> TestCrossCoreJoin(suite)
>                            7      0.3      341      1
> TestCursorMarkWithoutUniqueKey(suite)
>                            7      0.3      341      1
> TestCursorMarkWithoutUniqueKey.test
>                            7      0.9      335      3
> TestCustomDocTransformer(suite)
>                            7      0.3      353      1
> TestCustomSearcherSort(suite)
>                            7      0.3      353      1
> TestCustomSearcherSort.testFieldSortCustomSearcher
>                            7      0.3      353      1
> TestCustomSearcherSort.testFieldSortSingleSearcher
>                            7      0.9      341      3      TestCustomSort(suite)
>                            7      0.9      341      3
> TestDFISimilarityFactory(suite)
>                            7      0.9      339      3
> TestDocBasedVersionConstraints(suite)
>                            7      0.3      345      1
> TestDocTermOrds.testRandomWithPrefix
>                            7      0.3      345      1
> TestDocTermOrds.testSimple
>                            7      0.9      339      3
> TestElisionMultitermQuery(suite)
>                            7      0.3      344      1
> TestEmbeddedSolrServerAdminHandler(suite)
>                            7      0.3      344      1
> TestEmbeddedSolrServerAdminHandler.testPathIsAddedToContext
>                            7      0.3      339      1
> TestEmbeddedSolrServerConstructors(suite)
>                            7      0.3      339      1
> TestEmbeddedSolrServerConstructors.testNodeConfigConstructor
>                            7      1.2      336      4
> TestEmbeddedSolrServerSchemaAPI(suite)
>                            7      0.9      339      3
> TestExceedMaxTermLength(suite)
>                            7      0.9      339      3
> TestExpandComponent(suite)
>                            7      0.9      336      3
> TestExportWriter(suite)
>                            7      0.9      337      3
> TestExtendedDismaxParser(suite)
>                            7      0.9      341      3      TestFaceting(suite)
>                            7      0.9      338      3
> TestFieldSortValues(suite)
>                            7      0.9      339      3
> TestFileDictionaryLookup(suite)
>                            7      0.9      340      3      TestFiltering(suite)
>                            7      0.9      344      3
> TestFoldingMultitermQuery(suite)
>                            7      0.9      338      3
> TestFreeTextSuggestions(suite)
>                            7      0.9      340      3
> TestFunctionQuery(suite)
>                            7      0.9      343      3
> TestFuzzyAnalyzedSuggestions(suite)
>                            7      0.9      340      3
> TestGeoJSONResponseWriter(suite)
>                            7      0.9      335      3
> TestGraphMLResponseWriter(suite)
>                            7      0.9      336      3
> TestGraphTermsQParserPlugin(suite)
>                            7      0.9      339      3
> TestGroupingSearch(suite)
>                            7      0.9      337      3
> TestHalfAndHalfDocValues(suite)
>                            7      0.9      341      3
> TestHashQParserPlugin(suite)
>                            7      0.9      334      3
> TestHighFrequencyDictionaryFactory(suite)
>                            7      0.3      346      1
> TestHttpShardHandlerFactory.testLoadBalancerRequestsMinMax
>                            7      0.9      341      3
> TestIBSimilarityFactory(suite)
>                            7      0.9      334      3
> TestInPlaceUpdatesStandalone(suite)
>                            7      0.9      341      3
> TestIndexSearcher(suite)
>                            7      0.3      354      1
> TestIndexSorting.testMissingMultiValuedFloatLast
>                            7      0.3      353      1
> TestIndexWriterOnVMError.testOOM
>                            7      0.9      338      3
> TestIndexingPerformance(suite)
>                            7      0.9      337      3      TestInitParams(suite)
>                            7      0.3      340      1
> TestInitQParser(suite)
>                            7      0.3      340      1
> TestInitQParser.testQueryParserInit
>                            7      0.9      339      3
> TestIntervalFaceting(suite)
>                            7      1.9      308      6
> TestIntervalQuery.testOrderedNearQueryWidth3
>                            7      0.3      308      1
> TestIntervalQuery.testOrderedNearQueryWidth4
>                            7      0.3      339      1
> TestJettySolrRunner(suite)
>                            7      0.3      339      1
> TestJettySolrRunner.testPassSolrHomeToRunner
>                            7      0.9      341      3
> TestJmxIntegration(suite)
>                            7      0.9      339      3      TestJoin(suite)
>                            7      0.9      338      3
> TestJsonFacetRefinement(suite)
>                            7      0.9      341      3      TestJsonFacets(suite)
>                            7      0.3     2046      6
> TestJsonFacets.testComplex
>                            7      0.9      339      3
> TestJsonFacetsWithNestedObjects(suite)
>                            7      0.9      337      3
> TestJsonRequest(suite)
>                            7      0.6      349      2
> TestLBHttpSolrClient.testReliability
>                            7      0.9      336      3      TestLFUCache(suite)
>                            7      0.9      341      3
> TestLMDirichletSimilarityFactory(suite)
>                            7      0.3      337      1
> TestLMJelinekMercerSimilarityFactory(suite)
>                            7      0.3      342      1
> TestLazyCores.testBadConfigsGenerateErrors
>                            7      0.3      354      1
> TestLucene70DocValuesFormat(suite)
>                            7      0.3      354      1
> TestLucene70DocValuesFormat.testGCDCompression
>                            7      0.3      342      1
> TestLuceneIndexBackCompat(suite)
>                            7      0.3      342      1
> TestLuceneIndexBackCompat.testOldIndexes
>                            7      0.9      343      3
> TestLuceneMatchVersion(suite)
>                            7      0.9      340      3      TestMacros(suite)
>                            7      0.3      343      1
> TestManagedSchema(suite)
>                            7      0.3      343      1
> TestManagedSchema.testAddDynamicField
>                            7      0.3      343      1
> TestManagedSchema.testAddFieldPersistence
>                            7      0.3      343      1
> TestManagedSchema.testAddFieldThenReload
>                            7      0.3      343      1
> TestManagedSchema.testAddFieldWhenItAlreadyExists
>                            7      0.3      343      1
> TestManagedSchema.testAddFieldWhenNotMutable
>                            7      0.3      343      1
> TestManagedSchema.testAddSameFieldTwice
>                            7      0.3      343      1
> TestManagedSchema.testAddWithSchemaCodecFactory
>                            7      0.3      343      1
> TestManagedSchema.testAddWithSchemaSimilarityFactory
>                            7      0.3      343      1
> TestManagedSchema.testAddedFieldIndexableAndQueryable
>                            7      0.3      343      1
> TestManagedSchema.testDefaultSchemaFactory
>                            7      0.3      343      1
> TestManagedSchema.testPersistUniqueKey
>                            7      0.3      343      1
> TestManagedSchema.testUpgrade
>                            7      0.3      343      1
> TestManagedSchema.testUpgradeThenRestart
>                            7      0.3      343      1
> TestManagedSchema.testUpgradeThenRestartNonManaged
>                            7      0.3      343      1
> TestManagedSchema.testUpgradeThenRestartNonManagedAfterPuttingBackNonManagedSchema
>                            7      0.9      340      3
> TestMaxScoreQueryParser(suite)
>                            7      0.9      335      3
> TestMaxTokenLenTokenizer(suite)
>                            7      0.3      341      1
> TestMergePolicyConfig(suite)
>                            7      0.3      341      1
> TestMergePolicyConfig.testDefaultMergePolicyConfig
>                            7      0.3      341      1
> TestMergePolicyConfig.testLegacyMergePolicyConfig
>                            7      0.3      341      1
> TestMergePolicyConfig.testLogMergePolicyFactoryConfig
>                            7      0.3      341      1
> TestMergePolicyConfig.testNoMergePolicyFactoryConfig
>                            7      0.3      341      1
> TestMergePolicyConfig.testSetNoCFSMergePolicyConfig
>                            7      0.3      341      1
> TestMergePolicyConfig.testTieredMergePolicyConfig
>                            7      0.9      337      3
> TestMinMaxOnMultiValuedField(suite)
>                            7      0.9      334      3
> TestMissingGroups(suite)
>                            7      0.3      355      1
> TestMixedDocValuesUpdates.testStressMultiThreading
>                            7      0.9      340      3
> TestMultiWordSynonyms(suite)
>                            7      0.9      339      3
> TestNestedDocsSort(suite)
>                            7      0.9      340      3
> TestNoOpRegenerator(suite)
>                            7      0.3      348      1
> TestNodeAddedTrigger.testRestoreState
>                            7      0.6      348      2
> TestNodeAddedTrigger.testTrigger
>                            7      0.3      339      1
> TestNonDefinedSimilarityFactory(suite)
>                            7      0.3      339      1
> TestNonDefinedSimilarityFactory.testCurrentBM25
>                            7      0.9      341      3
> TestOmitPositions(suite)
>                            7      0.9      335      3
> TestOverriddenPrefixQueryForCustomFieldType(suite)
>                            7      0.9      339      3
> TestPHPSerializedResponseWriter(suite)
>                            7     50.0        2      1
> TestPKIAuthenticationPlugin.testGetBaseUrlForNodeNameLocal
>                            7      0.9      339      3
> TestPartialUpdateDeduplication(suite)
>                            7      0.9      336      3
> TestPayloadCheckQParserPlugin(suite)
>                            7      0.9      339      3
> TestPayloadScoreQParserPlugin(suite)
>                            7      0.3      354      1
> TestPerFieldDocValuesFormat(suite)
>                            7      0.3      356      1
> TestPerFieldDocValuesFormat.testSparseBinaryFixedLengthVsStoredFields
>                            7      0.9      337      3
> TestPerFieldSimilarity(suite)
>                            7      0.9      335      3
> TestPerFieldSimilarityWithDefaultOverride(suite)
>                            7      0.9      342      3
> TestPhraseSuggestions(suite)
>                            7      0.9      337      3
> TestPointFields(suite)
>                            7      0.3      353      1
> TestPointQueries(suite)
>                            7      3.1       32      1
> TestPointQueries.testRandomLongsBig
>                            7      0.9      340      3
> TestPostingsSolrHighlighter(suite)
>                            7      0.9      338      3
> TestPseudoReturnFields(suite)
>                            7      0.9      337      3
> TestQuerySenderListener(suite)
>                            7      0.9      339      3
> TestQuerySenderNoQuery(suite)
>                            7      0.9      338      3      TestQueryTypes(suite)
>                            7      0.9      338      3      TestQueryUtils(suite)
>                            7      0.9      342      3
> TestRandomCollapseQParserPlugin(suite)
>                            7      0.9      340      3
> TestRandomDVFaceting(suite)
>                            7      0.9      342      3
> TestRandomFaceting(suite)
>                            7      0.9      341      3      TestRangeQuery(suite)
>                            7      0.9      338      3
> TestRawResponseWriter(suite)
>                            7      0.9      339      3
> TestRawTransformer(suite)
>                            7      0.9      338      3
> TestReRankQParserPlugin(suite)
>                            7      0.9      343      3
> TestRealTimeGet(suite)
>                            7      0.9      339      3      TestRecovery(suite)
>                            7      0.9      346      3
> TestRecovery.testCleanShutdown
>                            7      1.2      345      4
> TestRecovery.testDropBuffered
>                            7      0.9      340      3      TestReload(suite)
>                            7      1.1      280      3
> TestReversedWildcardFilterFactory(suite)
>                            7      0.9      336      3
> TestSchemalessBufferedUpdates(suite)
>                            7      0.9      342      3
> TestScoreJoinQPNoScore(suite)
>                            7      0.9      337      3      TestSearchPerf(suite)
>                            7      0.9      336      3
> TestSearcherReuse(suite)
>                            7      0.3      339      1
> TestShardHandlerFactory.testXML
>                            7      0.9      337      3
> TestSimpleTextCodec(suite)
>                            7      0.9      341      3
> TestSmileRequest(suite)
>                            7      0.8      244      2
> TestSoftDeletesRetentionMergePolicy(suite)
>                            7      0.4      243      1
> TestSoftDeletesRetentionMergePolicy.testKeepAllDocsAcrossMerges
>                            7      0.8      244      2
> TestSoftDeletesRetentionMergePolicy.testSoftDeleteWithRetention
>                            7      0.9      342      3
> TestSolr4Spatial(suite)
>                            7      0.9      337      3
> TestSolr4Spatial2(suite)
>                            7      0.9      341      3
> TestSolrDeletionPolicy1(suite)
>                            7      0.9      341      3
> TestSolrDeletionPolicy2(suite)
>                            7      0.9      335      3
> TestSolrFieldCacheBean(suite)
>                            7      0.9      337      3
> TestSolrQueryParser(suite)
>                            7      0.9      343      3      TestSort(suite)
>                            7      0.9      340      3
> TestSortByMinMaxFunction(suite)
>                            7      0.9      340      3
> TestSortableTextField(suite)
>                            7      0.9      337      3
> TestStressInPlaceUpdates(suite)
>                            7      0.3      346      1
> TestStressLucene.testStressLuceneNRT
>                            7      0.9      317      3
> TestStressRecovery(suite)
>                            7      0.9      339      3
> TestStressReorder(suite)
>                            7      0.9      333      3
> TestStressUserVersions(suite)
>                            7      0.9      342      3
> TestStressVersions(suite)
>                            7      0.9      338      3
> TestSubQueryTransformer(suite)
>                            7      0.9      337      3
> TestSubQueryTransformerCrossCore(suite)
>                            7      1.2      338      4
> TestSubQueryTransformerDistrib(suite)
>                            7      0.9      344      3
> TestSurroundQueryParser(suite)
>                            7      0.9      340      3
> TestSweetSpotSimilarityFactory(suite)
>                            7      0.3      347      1
> TestTlogReplica(suite)
>                            7      0.9      340      3      TestTrie(suite)
>                            7      0.9      336      3      TestTrieFacet(suite)
>                            7      0.9      336      3
> TestUnifiedSolrHighlighter(suite)
>                            7      0.9      338      3      TestUpdate(suite)
>                            7      0.6      339      2
> TestUseDocValuesAsStored(suite)
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testDuplicateMultiValued
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testManagedSchema
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testMultipleSearchResults
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testMultivaluedOrdering
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testOnEmptyIndex
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testRandomSingleAndMultiValued
>                            7      0.3      344      1
> TestUseDocValuesAsStored.testUseDocValuesAsStoredFalse
>                            7      0.9      337      3
> TestValueSourceCache(suite)
>                            7      0.9      336      3
> TestWordDelimiterFilterFactory(suite)
>                            7      0.9      337      3      TestWriterPerf(suite)
>                            7      0.9      343      3
> TestXIncludeConfig(suite)
>                            7      0.9      338      3
> TestXmlQParserPlugin(suite)
>                            7      0.9      336      3
> TolerantUpdateProcessorTest(suite)
>                            7      0.3      343      1
> TriggerIntegrationTest.testTriggerThrottling
>                            7      0.9      339      3
> UUIDUpdateProcessorFallbackTest(suite)
>                            7      0.3      342      1
> UninvertDocValuesMergePolicyTest(suite)
>                            7      0.3      342      1
> UninvertDocValuesMergePolicyTest.testNonIndexedFieldDoesNonFail
>                            7      0.9      339      3
> UniqFieldsUpdateProcessorFactoryTest(suite)
>                            7      0.9      337      3      UpdateLogTest(suite)
>                            7      0.9      336      3
> UpdateParamsTest(suite)
>                            7      0.9      340      3
> UpdateRequestProcessorFactoryTest(suite)
>                            7      0.3      341      1
> VersionInfoTest(suite)
>                            7      0.3      341      1
> VersionInfoTest.testMaxDocValuesVersionFromIndex
>                            7      0.3      341      1
> VersionInfoTest.testMaxIndexedVersionFromIndex
>                            7      0.9      339      3
> WordBreakSolrSpellCheckerTest(suite)
>                            7      0.9      339      3
> XmlUpdateRequestHandlerTest(suite)
>                            7      0.9      339      3
> XsltUpdateRequestHandlerTest(suite)
>                             89   19.1      320     61
> AtomicUpdateProcessorFactoryTest.testMultipleThreads
>                             89    0.3      705      2
> StreamExpressionTest.testParallelExecutorStream
>                             89    0.3      691      2
> TestIndexSorting.testMissingDoubleFirst
>                             89    0.4      691      3
> TestIndexSorting.testMultiValuedRandom1
>                             89    0.3      687      2
> TestIndexWriterDelete(suite)
>                             89    0.9      645      6
> TriggerIntegrationTest(suite)
>                             89    0.3      572      2
> TriggerIntegrationTest.testNodeAddedTriggerRestoreState
>                             89    5.6       89      5
> TriggerIntegrationTest.testNodeMarkersRegistration
>                             89    0.5      572      3
> TriggerIntegrationTest.testSetProperties
>                             8     0.6      357      2
> BlockDirectoryTest.testRandomAccessWrites
>                             8     0.3      336      1
> CollectionPropsTest.testReadWriteCached
>                             8     1.2      331      4      DeleteNodeTest(suite)
>                             8     0.3      350      1
> GraphExpressionTest(suite)
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.deleteCollectionOnlyInZk
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.deleteCollectionRemovesStaleZkCollectionsNode
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.deletePartiallyCreatedCollection
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.moveReplicaTest
>                             8     3.1       32      1
> HdfsCollectionsAPIDistributedZkTest.testCollectionReload
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testCoresAreDistributedAcrossNodes
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testCreateShouldFailOnExistingCore
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testCreationAndDeletion
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testDeleteNonExistentCollection
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testMissingNumShards
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testMissingRequiredParameters
>                             8     2.6       38      1
> HdfsCollectionsAPIDistributedZkTest.testSpecificConfigsets
>                             8     4.3       23      1
> HdfsWriteToMultipleCollectionsTest.test
>                             8     0.3      333      1
> SolrJmxReporterCloudTest(suite)
>                             8     0.3      361      1
> StreamExpressionTest.testInnerJoinStream
>                             8     0.3      338      1
> TestAuthorizationFramework.authorizationFrameworkTest
>                             8     0.3      345      1
> TestCrossCoreJoin.testJoin
>                             8     0.3      345      1
> TestCrossCoreJoin.testScoreJoin
>                             8     0.3      332      1
> TestCustomStream.testDynamicLoadingCustomStream
>                             8     0.3      360      1
> TestDemoParallelLeafReader(suite)
>                             8     0.3      360      1
> TestDemoParallelLeafReader.testRandomMultipleSchemaGensSameField
>                             8     0.3      364      1
> TestIndexWriterDelete.testDeletesOnDiskFull
>                             8     0.3      363      1
> TestIndexWriterThreadsToSegments(suite)
>                             8     0.3      363      1
> TestIndexWriterThreadsToSegments.testSegmentCountOnFlushRandom
>                             8     0.3      363      1
> TestNumericDocValuesUpdates.testBiasedMixOfRandomUpdates
>                             8     0.3      363      1
> TestNumericDocValuesUpdates.testDocumentWithNoValue
>                             8     0.3      333      1
> TestReplicationHandlerBackup.doTestBackup
>                             8     0.5      219      1
> TestSolrCloudWithHadoopAuthPlugin.testBasics
>                             8     0.3      331      1
> TestStressCloudBlindAtomicUpdates.test_stored_idx
>                             8     0.4      254      1
> TriggerIntegrationTest.testCooldown
>                             8     0.4      254      1
> TriggerIntegrationTest.testMetricTrigger
>                             8     0.3      336      1
> ZkStateWriterTest(suite)
>                              9    0.3      305      1
> AutoScalingHandlerTest.testConcurrentUpdates
>                              9    0.3      304      1
> CdcrVersionReplicationTest.testCdcrDocVersions
>                              9    0.3      311      1
> CollectionsAPISolrJTest.testCreateAndDeleteCollection
>                              9    0.3      311      1
> CollectionsAPISolrJTest.testCreateAndDeleteShard
>                              9    0.4      255      1
> HdfsNNFailoverTest.test
>                              9    3.3       30      1
> LIROnShardRestartTest.testSeveralReplicasInLIR
>                              9    0.4      254      1
> MoveReplicaHDFSFailoverTest.testOldReplicaIsDeleted
>                              9    0.3      315      1      NoFacetTest(suite)
>                              9    0.7      303      2
> OverseerRolesTest(suite)
>                              9    0.3      344      1
> StreamExpressionTest.testCopyOfRange
>                              9    0.9      344      3
> StreamExpressionTest.testParallelCommitStream
>                              9    1.0      310      3      SyncSliceTest(suite)
>                              9    0.3      304      1
> TestBlobHandler.doBlobHandlerTest
>                              9    0.3      306      1
> TestCollectionsAPIViaSolrCloudCluster(suite)
>                              9    0.3      306      1
> TestDistribIDF.testMultiCollectionQuery
>                              9    1.3      318      4
> TestFileListEntityProcessor.testNTOT
>                              9    0.3      324      1
> TestIndexSorting.testConcurrentUpdates
>                              9    0.3      323      1
> TestIndexWriterDelete.testUpdatesOnDiskFull
>                              9    0.6      324      2
> TestIndexWriterOnVMError.testUnknownError
>                              9    0.6      315      2
> TestLTROnSolrCloud(suite)
>                              9    0.3      318      1
> TestLTROnSolrCloud.testSimpleQuery
>                              9    0.3      329      1
> TestLucene50CompoundFormat.testLargeCFS
>                              9    0.3      304      1
> TestNodeLostTrigger.testTrigger
>                              9    0.3      310      1
> TestRebalanceLeaders.test
>                              9    0.3      373      1
> TestReplicationHandler.doTestDetails
>                              9    0.3      373      1
> TestReplicationHandler.doTestStopPoll
>                              9    0.3      306      1
> TestShortCircuitedRequests(suite)
>                              9    0.3      310      1
> TestShortCircuitedRequests.test
>                              9    0.3      314      1
> TestTlogReplica.testRemoveLeader
>                              9    0.6      318      2
> TriggerIntegrationTest.testListeners
>                              9    0.9      318      3
> TriggerIntegrationTest.testNodeAddedTrigger
>                              9    0.9      318      3
> TriggerIntegrationTest.testNodeLostTrigger
>                              9    1.9       53      1
> TriggerIntegrationTest.testSearchRate
>                              9    0.6      316      2      ValueFacetTest(suite)
>                              9    0.3      322      1
> ValueFacetTest.meanTest
> Number of AwaitsFix: 16 Number of BadApples: 111
>
> *****************AwaitsFix Annotations:
>
>
> ************Lucene AwaitsFix
> TestControlledRealTimeReopenThread.testCRTReopen
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")
>
> TestICUNormalizer2CharFilter.testRandomStrings
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")
>
> TestICUTokenizerCJK.TestICUTokenizerCJK suite
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>
> TestMoreLikeThis.testMultiFieldShouldReturnPerFieldBooleanQuery
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")
>
> UIMABaseAnalyzerTest.testRandomStrings
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
> UIMABaseAnalyzerTest.testRandomStringsWithConfigurationParameters
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
> UIMATypeAwareAnalyzerTest.testRandomStrings
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
>
>     ************Solr AwaitsFix
> ConcurrentCreateRoutedAliasTest.ConcurrentCreateRoutedAliasTest suite
>    @LuceneTestCase.AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12386") // "Can't find
> resource"
>
> ReplaceNodeNoTargetTest.ReplaceNodeNoTargetTest suite
>    @LuceneTestCase.AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-11067")
>
> TestCollapseQParserPlugin.testStringCollapse
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>
> TestImpersonationWithHadoopAuth.testForwarding
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>
> TestLTRReRankingPipeline.testDifferentTopN
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>
> TestMinMaxOnMultiValuedField.testDoubleFieldCache
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
> TestMinMaxOnMultiValuedField.testFloatFieldCache
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
> TestMinMaxOnMultiValuedField.testIntFieldCache
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
> TestMinMaxOnMultiValuedField.testLongFieldCache
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
>
>
> *****************BadApple Annotations:
>
> ************Lucene BadApple
>
>     ************Solr BadApple
> AddReplicaTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> AssignBackwardCompatibilityTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> AutoAddReplicasIntegrationTest.testSimple
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoAddReplicasPlanActionTest.testSimple
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoScalingHandlerTest.testReadApi
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoscalingHistoryHandlerTest.testHistory
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> BasicAuthIntegrationTest.testBasicAuth
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> CdcrBootstrapTest.testBootstrapWithContinousIndexingOnSourceCluster
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> CdcrReplicationDistributedZkTest.CdcrReplicationDistributedZkTest suite
>    @BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10107")
>
> ChaosMonkeyNothingIsSafeTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> ChaosMonkeySafeLeaderTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ChaosMonkeySafeLeaderWithPullReplicasTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> CollectionsAPIDistributedZkTest.testCollectionsAPI
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ComputePlanActionTest.testNodeLost
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> ComputePlanActionTest.testSelectedCollections
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CustomCollectionTest.testCustomCollectionsAPI
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> DeleteReplicaTest.deleteReplicaOnIndexing
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> DocValuesNotIndexedTest.testGroupingDVOnly
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> DocValuesNotIndexedTest.testGroupingDocAbsent
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> DocValuesNotIndexedTest.testGroupingSorting
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> ForceLeaderTest.testReplicasInLIRNoLeader
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ForceLeaderTest.testReplicasInLowerTerms
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsBasicDistributedZk2Test.HdfsBasicDistributedZk2Test suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> HdfsChaosMonkeyNothingIsSafeTest.HdfsChaosMonkeyNothingIsSafeTest suite
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10191")
>
> HdfsDirectoryTest.testEOF
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsRecoveryZkTest.HdfsRecoveryZkTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsRestartWhileUpdatingTest.HdfsRestartWhileUpdatingTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> HdfsTlogReplayBufferedWhileIndexingTest.HdfsTlogReplayBufferedWhileIndexingTest
> suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsUnloadDistributedZkTest.HdfsUnloadDistributedZkTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> HttpPartitionTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> IndexSizeTriggerTest.testMergeIntegration
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> IndexSizeTriggerTest.testSplitIntegration
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> IndexSizeTriggerTest.testTrigger
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> LIRRollingUpdatesTest.testNewLeaderAndMixedReplicas
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LIRRollingUpdatesTest.testNewLeaderOldReplica
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LIRRollingUpdatesTest.testNewReplicaOldLeader
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> LIRRollingUpdatesTest.testOldLeaderAndMixedReplicas
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LeaderElectionIntegrationTest.testSimpleSliceLeaderElection
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LeaderFailoverAfterPartitionTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> LeaderVoteWaitTimeoutTest.basicTest
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> LegacyCloudClusterPropTest.testCreateCollectionSwitchLegacyCloud
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MathExpressionTest.testDistributions
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MathExpressionTest.testGammaDistribution
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> MathExpressionTest.testMultiVariateNormalDistribution
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> MissingSegmentRecoveryTest.testLeaderRecovery
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MoveReplicaHDFSTest.testNormalFailedMove
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> MoveReplicaHDFSTest.testNormalMove
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> MoveReplicaTest.testFailedMove
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>
> MultiThreadedOCPTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> NodeLostTriggerTest.testListenerAcceptance
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
>
> OverseerRolesTest.testOverseerRole
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> PeerSyncReplicationTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ReplaceNodeNoTargetTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ReplicationFactorTest.ReplicationFactorTest suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6944")
>
> RestartWhileUpdatingTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> SSLMigrationTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> ScheduledMaintenanceTriggerTest.testInactiveShardCleanup
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> ScheduledTriggerIntegrationTest.ScheduledTriggerIntegrationTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> ScheduledTriggerTest.testTrigger
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> SearchRateTriggerIntegrationTest.testBelowSearchRate
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> SearchRateTriggerIntegrationTest.testDeleteNode
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> ShardSplitTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ShardSplitTest.testSplitAfterFailedSplit
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ShardSplitTest.testSplitWithChaosMonkey
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> SharedFSAutoReplicaFailoverTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> SolrCloudExampleTest.testLoadDocsIntoGettingStartedCollection
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> StressHdfsTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestAuthenticationFramework.testBasics
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestCloudSchemaless.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestCollectionStateWatchers.testDeletionsTriggerWatches
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateSearchDelete
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestCollectionsAPIViaSolrCloudCluster.testCollectionCreateWithoutCoresThenDelete
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestDistributedSearch.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestDynamicLoading.testDynamicLoading
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestGenericDistributedQueue.TestGenericDistributedQueue suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestHdfsCloudBackupRestore.TestHdfsCloudBackupRestore suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestHdfsUpdateLog.testFSThreadSafety
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestInPlaceUpdatesDistrib.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestLargeCluster.TestLargeCluster suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12075")
>
> TestLargeCluster.testSearchRate
>    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>
> TestLeaderInitiatedRecoveryThread.testPublishDownState
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestManagedResourceStorage.TestManagedResourceStorage suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6443")
>
> TestPrepRecovery.testLeaderNotResponding
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPrepRecovery.testLeaderUnloaded
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPullReplica.testAddDocs
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPullReplica.testCreateDelete
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestPullReplica.testKillLeader
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestReplicationHandler.doTestIndexAndConfigAliasReplication
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestSQLHandler.doTest
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestSegmentSorting.testAtomicUpdateOfSegmentSortField
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestSegmentSorting.testSegmentTerminateEarly
>    @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestSolrCloudWithKerberosAlt.testBasics
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> TestStressCloudBlindAtomicUpdates.test_dv
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressCloudBlindAtomicUpdates.test_dv_stored
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressInPlaceUpdates.stressTest
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestStressRecovery.testStressRecovery
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestTriggerIntegration.testCooldown
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.testEventFromRestoredState
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> TestTriggerIntegration.testEventQueue
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
>
> TestTriggerIntegration.testListeners
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.testNodeAddedTriggerRestoreState
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestTriggerIntegration.testNodeLostTrigger
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestTriggerIntegration.testNodeLostTriggerRestoreState
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.testNodeMarkersRegistration
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.testSearchRate
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestV2Request.testCloudSolrClient
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestV2Request.testHttpSolrClient
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> UnloadDistributedZkTest.test
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 21-May-2018
>
> ---------------------------------------------------------------------
> To unsubscribe, e-mail: dev-unsubscribe@lucene.apache.org
> For additional commands, e-mail: dev-help@lucene.apache.org
>


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