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/05/21 15:00:10 UTC

BadApple candidates

I'm going to change how I collect the badapple candidates. After
getting a little
overwhelmed by the number of failure e-mails (even ignoring the ones with
BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
know where that comes from, hint: Old music involving a pickle).

Since I collect failures for a week then run filter them by what's
also in Hoss's
results from two  weeks ago, that's really equivalent to creating the candidate
list from the intersection of the most recent week of Hoss's results and the
results from _three_ weeks ago. Much faster too. Thanks Hoss!

So that's what I'll do going forward.

Meanwhile, here's the list for this Thursday.

BadApple candidates: I'll BadApple these on Thursday unless there are objections
  org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
   org.apache.solr.TestDistributedSearch.test
   org.apache.solr.cloud.AddReplicaTest.test
   org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
   org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
   org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
   org.apache.solr.cloud.CreateRoutedAliasTest.testV1
   org.apache.solr.cloud.CreateRoutedAliasTest.testV2
   org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
   org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
   org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
   org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
   org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
   org.apache.solr.cloud.RestartWhileUpdatingTest.test
   org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
   org.apache.solr.cloud.TestPullReplica.testCreateDelete
   org.apache.solr.cloud.TestPullReplica.testKillLeader
   org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
   org.apache.solr.cloud.UnloadDistributedZkTest.test
   org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
   org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
   org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
   org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
   org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
   org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
   org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
   org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
   org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
   org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
   org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
   org.apache.solr.cloud.hdfs.StressHdfsTest.test
   org.apache.solr.handler.TestSQLHandler.doTest
   org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
   org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
   org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
   org.apache.solr.update.TestInPlaceUpdatesDistrib.test


Number of AwaitsFix: 21 Number of BadApples: 99

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


************Lucene AwaitsFix
GeoPolygonTest.java
   testLUCENE8276_case3()
   //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")

GeoPolygonTest.java
   testLUCENE8280()
   //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")

GeoPolygonTest.java
   testLUCENE8281()
   //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")

RandomGeoPolygonTest.java
   testCompareBigPolygons()
   //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")

RandomGeoPolygonTest.java
   testCompareSmallPolygons()
   //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")

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

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

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

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

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

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

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


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

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

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

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

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

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

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

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



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

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

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

AliasIntegrationTest.java
   testModifyPropertiesCAR()
   //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

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

AliasIntegrationTest.java
   testProperties()
   //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

TestCloudRecovery.java
   leaderRecoverFromLogOnStartupTest()
   // Removed BadApple on 18-May-2018

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

TestTlogReplica.java
   testOnlyLeaderIndexes()
   // Removed BadApple on 2018-05-21

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

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

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

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

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

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

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

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

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

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

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

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


Re: BadApple candidates

Posted by Erick Erickson <er...@gmail.com>.
Sure....

On Mon, May 21, 2018, 15:11 Alan Woodward <ro...@gmail.com> wrote:

> Looks like it was an OOM, can you leave that one be for now?
>
> > On 21 May 2018, at 19:11, Erick Erickson <er...@gmail.com>
> wrote:
> >
> > Alan:
> >
> >
> http://fucit.org/solr-jenkins-reports/job-data/sarowe/Lucene-Solr-Nightly-7.x/256/
> >
> > You can get there from Hoss's rollup reports here:
> > http://fucit.org/solr-jenkins-reports/failure-report.html
> >
> > To be included in any potential BadApple, two things must be true:
> > 1> it must have failed since last Monday
> > 2> it must have failed in the report collected two weeks ago Monday
> >
> > Erick
> >
> >
> > On Mon, May 21, 2018 at 12:40 PM, Alan Woodward <ro...@gmail.com>
> wrote:
> >> When did TestLRUQueryCache fail?  I haven’t seen that one.
> >>
> >>> On 21 May 2018, at 16:00, Erick Erickson <er...@gmail.com>
> wrote:
> >>>
> >>> I'm going to change how I collect the badapple candidates. After
> >>> getting a little
> >>> overwhelmed by the number of failure e-mails (even ignoring the ones
> with
> >>> BadApple enabled), "It come to me in a vision! In a flash!"" (points
> if you
> >>> know where that comes from, hint: Old music involving a pickle).
> >>>
> >>> Since I collect failures for a week then run filter them by what's
> >>> also in Hoss's
> >>> results from two  weeks ago, that's really equivalent to creating the
> candidate
> >>> list from the intersection of the most recent week of Hoss's results
> and the
> >>> results from _three_ weeks ago. Much faster too. Thanks Hoss!
> >>>
> >>> So that's what I'll do going forward.
> >>>
> >>> Meanwhile, here's the list for this Thursday.
> >>>
> >>> BadApple candidates: I'll BadApple these on Thursday unless there are
> objections
> >>> org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
> >>> org.apache.solr.TestDistributedSearch.test
> >>> org.apache.solr.cloud.AddReplicaTest.test
> >>> org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
> >>>
> org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
> >>> org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
> >>> org.apache.solr.cloud.CreateRoutedAliasTest.testV1
> >>> org.apache.solr.cloud.CreateRoutedAliasTest.testV2
> >>>
> org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
> >>> org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
> >>> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
> >>>
> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
> >>> org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
> >>> org.apache.solr.cloud.RestartWhileUpdatingTest.test
> >>>
> org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
> >>> org.apache.solr.cloud.TestPullReplica.testCreateDelete
> >>> org.apache.solr.cloud.TestPullReplica.testKillLeader
> >>> org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
> >>> org.apache.solr.cloud.UnloadDistributedZkTest.test
> >>>
> org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
> >>>
> org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
> >>> org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
> >>>
> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
> >>>
> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
> >>> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
> >>> org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
> >>>
> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
> >>>
> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
> >>> org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
> >>> org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
> >>> org.apache.solr.cloud.hdfs.StressHdfsTest.test
> >>> org.apache.solr.handler.TestSQLHandler.doTest
> >>> org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
> >>> org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
> >>> org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
> >>> org.apache.solr.update.TestInPlaceUpdatesDistrib.test
> >>>
> >>>
> >>> Number of AwaitsFix: 21 Number of BadApples: 99
> >>>
> >>> *****************AwaitsFix Annotations:
> >>>
> >>>
> >>> ************Lucene AwaitsFix
> >>> GeoPolygonTest.java
> >>> testLUCENE8276_case3()
> >>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276
> ")
> >>>
> >>> GeoPolygonTest.java
> >>> testLUCENE8280()
> >>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280
> ")
> >>>
> >>> GeoPolygonTest.java
> >>> testLUCENE8281()
> >>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281
> ")
> >>>
> >>> RandomGeoPolygonTest.java
> >>> testCompareBigPolygons()
> >>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281
> ")
> >>>
> >>> RandomGeoPolygonTest.java
> >>> testCompareSmallPolygons()
> >>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281
> ")
> >>>
> >>> TestControlledRealTimeReopenThread.java
> >>> testCRTReopen()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737
> ")
> >>>
> >>> TestICUNormalizer2CharFilter.java
> >>> testRandomStrings()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595
> ")
> >>>
> >>> TestICUTokenizerCJK.java
> >>> TestICUTokenizerCJK suite
> >>> @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
> >>>
> >>> TestMoreLikeThis.java
> >>> testMultiFieldShouldReturnPerFieldBooleanQuery()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161
> ")
> >>>
> >>> UIMABaseAnalyzerTest.java
> >>> testRandomStrings()
> >>> @Test @AwaitsFix(bugUrl =
> >>> "https://issues.apache.org/jira/browse/LUCENE-3869")
> >>>
> >>> UIMABaseAnalyzerTest.java
> >>> testRandomStringsWithConfigurationParameters()
> >>> @Test @AwaitsFix(bugUrl =
> >>> "https://issues.apache.org/jira/browse/LUCENE-3869")
> >>>
> >>> UIMATypeAwareAnalyzerTest.java
> >>> testRandomStrings()
> >>> @Test @AwaitsFix(bugUrl =
> >>> "https://issues.apache.org/jira/browse/LUCENE-3869")
> >>>
> >>>
> >>>  ************Solr AwaitsFix
> >>> ReplaceNodeNoTargetTest.java
> >>> ReplaceNodeNoTargetTest suite
> >>> @LuceneTestCase.AwaitsFix(bugUrl =
> >>> "https://issues.apache.org/jira/browse/SOLR-11067")
> >>>
> >>> TestCollapseQParserPlugin.java
> >>> testStringCollapse()
> >>> @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
> >>>
> >>> TestImpersonationWithHadoopAuth.java
> >>> testForwarding()
> >>> @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
> >>>
> >>> TestLTRReRankingPipeline.java
> >>> testDifferentTopN()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134
> ")
> >>>
> >>> TestMinMaxOnMultiValuedField.java
> >>> testDoubleFieldCache()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
> >>>
> >>> TestMinMaxOnMultiValuedField.java
> >>> testFloatFieldCache()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
> >>>
> >>> TestMinMaxOnMultiValuedField.java
> >>> testIntFieldCache()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
> >>>
> >>> TestMinMaxOnMultiValuedField.java
> >>> testLongFieldCache()
> >>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
> >>>
> >>>
> >>>
> >>> *****************BadApple Annotations:
> >>>
> >>> ************Lucene BadApple
> >>>
> >>>  ************Solr BadApple
> >>> AddReplicaTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> AliasIntegrationTest.java
> >>> testModifyPropertiesCAR()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> AliasIntegrationTest.java
> >>> testModifyPropertiesV1()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> AliasIntegrationTest.java
> >>> testProperties()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> AutoAddReplicasIntegrationTest.java
> >>> testSimple()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> AutoAddReplicasPlanActionTest.java
> >>> testSimple()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> AutoScalingHandlerTest.java
> >>> testReadApi()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> AutoscalingHistoryHandlerTest.java
> >>> testHistory()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> CdcrBootstrapTest.java
> >>> testBootstrapWithContinousIndexingOnSourceCluster()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> CdcrReplicationDistributedZkTest.java
> >>> CdcrReplicationDistributedZkTest suite
> >>> @BadApple(bugUrl =
> >>> "https://issues.apache.org/jira/browse/SOLR-12028,
> >>> https://issues.apache.org/jira/browse/SOLR-10107")
> >>>
> >>> ChaosMonkeyNothingIsSafeTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> ChaosMonkeySafeLeaderTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ChaosMonkeySafeLeaderWithPullReplicasTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> CollectionsAPIDistributedZkTest.java
> >>> testCollectionsAPI()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ComputePlanActionTest.java
> >>> testSelectedCollections()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> CreateRoutedAliasTest.java
> >>> testCollectionNamesMustBeAbsent()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> CreateRoutedAliasTest.java
> >>> testTimezoneAbsoluteDate()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> CreateRoutedAliasTest.java
> >>> testV1()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> CreateRoutedAliasTest.java
> >>> testV2()
> >>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> DeleteReplicaTest.java
> >>> deleteReplicaOnIndexing()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> DocValuesNotIndexedTest.java
> >>> testGroupingDVOnly()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> DocValuesNotIndexedTest.java
> >>> testGroupingDocAbsent()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> DocValuesNotIndexedTest.java
> >>> testGroupingSorting()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> ForceLeaderTest.java
> >>> testReplicasInLIRNoLeader()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ForceLeaderTest.java
> >>> testReplicasInLowerTerms()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> HdfsBasicDistributedZk2Test.java
> >>> HdfsBasicDistributedZk2Test suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> HdfsChaosMonkeyNothingIsSafeTest.java
> >>> HdfsChaosMonkeyNothingIsSafeTest suite
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> >>> https://issues.apache.org/jira/browse/SOLR-10191")
> >>>
> >>> HdfsDirectoryTest.java
> >>> testEOF()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> HdfsRecoveryZkTest.java
> >>> HdfsRecoveryZkTest suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> HdfsRestartWhileUpdatingTest.java
> >>> HdfsRestartWhileUpdatingTest suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>> //2018-03-10
> >>>
> >>> HdfsTlogReplayBufferedWhileIndexingTest.java
> >>> HdfsTlogReplayBufferedWhileIndexingTest suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> HttpPartitionTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> LIRRollingUpdatesTest.java
> >>> testNewLeaderAndMixedReplicas()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> LIRRollingUpdatesTest.java
> >>> testNewLeaderOldReplica()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> LIRRollingUpdatesTest.java
> >>> testOldLeaderAndMixedReplicas()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> LeaderElectionIntegrationTest.java
> >>> testSimpleSliceLeaderElection()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> LeaderFailoverAfterPartitionTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> LegacyCloudClusterPropTest.java
> >>> testCreateCollectionSwitchLegacyCloud()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> MathExpressionTest.java
> >>> testDistributions()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> MathExpressionTest.java
> >>> testGammaDistribution()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> MathExpressionTest.java
> >>> testMultiVariateNormalDistribution()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> //2018-03-10
> >>>
> >>> MissingSegmentRecoveryTest.java
> >>> testLeaderRecovery()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> MoveReplicaHDFSTest.java
> >>> testNormalFailedMove()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> MoveReplicaHDFSTest.java
> >>> testNormalMove()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> //2018-03-10
> >>>
> >>> MoveReplicaTest.java
> >>> testFailedMove()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 17-Mar-2018 This JIRA is fixed, but this test still fails
> >>>
> >>> MultiThreadedOCPTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> NodeLostTriggerTest.java
> >>> testListenerAcceptance()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 16-Apr-2018
> >>>
> >>> OverseerRolesTest.java
> >>> testOverseerRole()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> PeerSyncReplicationTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ReplaceNodeNoTargetTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ReplicationFactorTest.java
> >>> ReplicationFactorTest suite
> >>> @LuceneTestCase.BadApple(bugUrl =
> >>> "https://issues.apache.org/jira/browse/SOLR-6944")
> >>>
> >>> RestartWhileUpdatingTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> SSLMigrationTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 17-Mar-2018
> >>>
> >>> ScheduledMaintenanceTriggerTest.java
> >>> testInactiveShardCleanup()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 17-Mar-2018
> >>>
> >>> ScheduledTriggerIntegrationTest.java
> >>> ScheduledTriggerIntegrationTest suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> ScheduledTriggerTest.java
> >>> testTrigger()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> ShardSplitTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ShardSplitTest.java
> >>> testSplitAfterFailedSplit()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ShardSplitTest.java
> >>> testSplitWithChaosMonkey()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> SharedFSAutoReplicaFailoverTest.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> SolrCloudExampleTest.java
> >>> testLoadDocsIntoGettingStartedCollection()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> TestAuthenticationFramework.java
> >>> testBasics()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestCloudRecovery.java
> >>> leaderRecoverFromLogOnStartupTest()
> >>> // Removed BadApple on 18-May-2018
> >>>
> >>> TestCloudSchemaless.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> TestCollectionStateWatchers.java
> >>> testDeletionsTriggerWatches()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> TestCollectionsAPIViaSolrCloudCluster.java
> >>> testCollectionCreateSearchDelete()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestCollectionsAPIViaSolrCloudCluster.java
> >>> testCollectionCreateWithoutCoresThenDelete()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> TestDistributedSearch.java
> >>> test()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> TestDynamicLoading.java
> >>> testDynamicLoading()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestGenericDistributedQueue.java
> >>> TestGenericDistributedQueue suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestHdfsCloudBackupRestore.java
> >>> TestHdfsCloudBackupRestore suite
> >>> @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> TestLargeCluster.java
> >>> TestLargeCluster suite
> >>> @LuceneTestCase.BadApple(bugUrl =
> >>> "https://issues.apache.org/jira/browse/SOLR-12075")
> >>>
> >>> TestLargeCluster.java
> >>> testSearchRate()
> >>> @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
> >>>
> >>> TestLeaderElectionZkExpiry.java
> >>> testLeaderElectionWithZkExpiry()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 17-Mar-2018
> >>>
> >>> TestLeaderInitiatedRecoveryThread.java
> >>> testPublishDownState()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> TestManagedResourceStorage.java
> >>> TestManagedResourceStorage suite
> >>> @LuceneTestCase.BadApple(bugUrl =
> >>> "https://issues.apache.org/jira/browse/SOLR-6443")
> >>>
> >>> TestPrepRecovery.java
> >>> testLeaderNotResponding()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestPrepRecovery.java
> >>> testLeaderUnloaded()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestPullReplica.java
> >>> testAddDocs()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestPullReplica.java
> >>> testKillLeader()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> TestReplicationHandler.java
> >>> doTestIndexAndConfigAliasReplication()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> TestSegmentSorting.java
> >>> testAtomicUpdateOfSegmentSortField()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> TestSegmentSorting.java
> >>> testSegmentTerminateEarly()
> >>> @Test@BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestStressCloudBlindAtomicUpdates.java
> >>> test_dv()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestStressCloudBlindAtomicUpdates.java
> >>> test_dv_stored()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestStressInPlaceUpdates.java
> >>> stressTest()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> TestStressRecovery.java
> >>> testStressRecovery()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 04-May-2018
> >>>
> >>> TestTlogReplica.java
> >>> testOnlyLeaderIndexes()
> >>> // Removed BadApple on 2018-05-21
> >>>
> >>> TestTriggerIntegration.java
> >>> testCooldown()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestTriggerIntegration.java
> >>> testEventFromRestoredState()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> //2018-03-10
> >>>
> >>> TestTriggerIntegration.java
> >>> testEventQueue()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 16-Apr-2018
> >>>
> >>> TestTriggerIntegration.java
> >>> testListeners()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestTriggerIntegration.java
> >>> testNodeAddedTriggerRestoreState()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 09-Apr-2018
> >>>
> >>> TestTriggerIntegration.java
> >>> testNodeLostTrigger()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>> // 26-Mar-2018
> >>>
> >>> TestTriggerIntegration.java
> >>> testNodeLostTriggerRestoreState()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestTriggerIntegration.java
> >>> testNodeMarkersRegistration()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestTriggerIntegration.java
> >>> testSearchRate()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestV2Request.java
> >>> testCloudSolrClient()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> TestV2Request.java
> >>> testHttpSolrClient()
> >>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >>>
> >>> ---------------------------------------------------------------------
> >>> 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
> >>
> >
> > ---------------------------------------------------------------------
> > 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
>
>

Re: BadApple candidates

Posted by Alan Woodward <ro...@gmail.com>.
Looks like it was an OOM, can you leave that one be for now?

> On 21 May 2018, at 19:11, Erick Erickson <er...@gmail.com> wrote:
> 
> Alan:
> 
> http://fucit.org/solr-jenkins-reports/job-data/sarowe/Lucene-Solr-Nightly-7.x/256/
> 
> You can get there from Hoss's rollup reports here:
> http://fucit.org/solr-jenkins-reports/failure-report.html
> 
> To be included in any potential BadApple, two things must be true:
> 1> it must have failed since last Monday
> 2> it must have failed in the report collected two weeks ago Monday
> 
> Erick
> 
> 
> On Mon, May 21, 2018 at 12:40 PM, Alan Woodward <ro...@gmail.com> wrote:
>> When did TestLRUQueryCache fail?  I haven’t seen that one.
>> 
>>> On 21 May 2018, at 16:00, Erick Erickson <er...@gmail.com> wrote:
>>> 
>>> I'm going to change how I collect the badapple candidates. After
>>> getting a little
>>> overwhelmed by the number of failure e-mails (even ignoring the ones with
>>> BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
>>> know where that comes from, hint: Old music involving a pickle).
>>> 
>>> Since I collect failures for a week then run filter them by what's
>>> also in Hoss's
>>> results from two  weeks ago, that's really equivalent to creating the candidate
>>> list from the intersection of the most recent week of Hoss's results and the
>>> results from _three_ weeks ago. Much faster too. Thanks Hoss!
>>> 
>>> So that's what I'll do going forward.
>>> 
>>> Meanwhile, here's the list for this Thursday.
>>> 
>>> BadApple candidates: I'll BadApple these on Thursday unless there are objections
>>> org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>>> org.apache.solr.TestDistributedSearch.test
>>> org.apache.solr.cloud.AddReplicaTest.test
>>> org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>>> org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>>> org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>>> org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>>> org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>>> org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>>> org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>>> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>>> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>>> org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>>> org.apache.solr.cloud.RestartWhileUpdatingTest.test
>>> org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>>> org.apache.solr.cloud.TestPullReplica.testCreateDelete
>>> org.apache.solr.cloud.TestPullReplica.testKillLeader
>>> org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>>> org.apache.solr.cloud.UnloadDistributedZkTest.test
>>> org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>>> org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>>> org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>>> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>>> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>>> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>>> org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>>> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>>> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>>> org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>>> org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>>> org.apache.solr.cloud.hdfs.StressHdfsTest.test
>>> org.apache.solr.handler.TestSQLHandler.doTest
>>> org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>>> org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>>> org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>>> org.apache.solr.update.TestInPlaceUpdatesDistrib.test
>>> 
>>> 
>>> Number of AwaitsFix: 21 Number of BadApples: 99
>>> 
>>> *****************AwaitsFix Annotations:
>>> 
>>> 
>>> ************Lucene AwaitsFix
>>> GeoPolygonTest.java
>>> testLUCENE8276_case3()
>>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")
>>> 
>>> GeoPolygonTest.java
>>> testLUCENE8280()
>>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")
>>> 
>>> GeoPolygonTest.java
>>> testLUCENE8281()
>>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>> 
>>> RandomGeoPolygonTest.java
>>> testCompareBigPolygons()
>>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>> 
>>> RandomGeoPolygonTest.java
>>> testCompareSmallPolygons()
>>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>> 
>>> TestControlledRealTimeReopenThread.java
>>> testCRTReopen()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")
>>> 
>>> TestICUNormalizer2CharFilter.java
>>> testRandomStrings()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")
>>> 
>>> TestICUTokenizerCJK.java
>>> TestICUTokenizerCJK suite
>>> @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>>> 
>>> TestMoreLikeThis.java
>>> testMultiFieldShouldReturnPerFieldBooleanQuery()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")
>>> 
>>> UIMABaseAnalyzerTest.java
>>> testRandomStrings()
>>> @Test @AwaitsFix(bugUrl =
>>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>> 
>>> UIMABaseAnalyzerTest.java
>>> testRandomStringsWithConfigurationParameters()
>>> @Test @AwaitsFix(bugUrl =
>>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>> 
>>> UIMATypeAwareAnalyzerTest.java
>>> testRandomStrings()
>>> @Test @AwaitsFix(bugUrl =
>>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>> 
>>> 
>>>  ************Solr AwaitsFix
>>> ReplaceNodeNoTargetTest.java
>>> ReplaceNodeNoTargetTest suite
>>> @LuceneTestCase.AwaitsFix(bugUrl =
>>> "https://issues.apache.org/jira/browse/SOLR-11067")
>>> 
>>> TestCollapseQParserPlugin.java
>>> testStringCollapse()
>>> @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>>> 
>>> TestImpersonationWithHadoopAuth.java
>>> testForwarding()
>>> @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>>> 
>>> TestLTRReRankingPipeline.java
>>> testDifferentTopN()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>>> 
>>> TestMinMaxOnMultiValuedField.java
>>> testDoubleFieldCache()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>> 
>>> TestMinMaxOnMultiValuedField.java
>>> testFloatFieldCache()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>> 
>>> TestMinMaxOnMultiValuedField.java
>>> testIntFieldCache()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>> 
>>> TestMinMaxOnMultiValuedField.java
>>> testLongFieldCache()
>>> @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>> 
>>> 
>>> 
>>> *****************BadApple Annotations:
>>> 
>>> ************Lucene BadApple
>>> 
>>>  ************Solr BadApple
>>> AddReplicaTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> AliasIntegrationTest.java
>>> testModifyPropertiesCAR()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> AliasIntegrationTest.java
>>> testModifyPropertiesV1()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> AliasIntegrationTest.java
>>> testProperties()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> AutoAddReplicasIntegrationTest.java
>>> testSimple()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> AutoAddReplicasPlanActionTest.java
>>> testSimple()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> AutoScalingHandlerTest.java
>>> testReadApi()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> AutoscalingHistoryHandlerTest.java
>>> testHistory()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> CdcrBootstrapTest.java
>>> testBootstrapWithContinousIndexingOnSourceCluster()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> CdcrReplicationDistributedZkTest.java
>>> CdcrReplicationDistributedZkTest suite
>>> @BadApple(bugUrl =
>>> "https://issues.apache.org/jira/browse/SOLR-12028,
>>> https://issues.apache.org/jira/browse/SOLR-10107")
>>> 
>>> ChaosMonkeyNothingIsSafeTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> ChaosMonkeySafeLeaderTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> CollectionsAPIDistributedZkTest.java
>>> testCollectionsAPI()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ComputePlanActionTest.java
>>> testSelectedCollections()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> CreateRoutedAliasTest.java
>>> testCollectionNamesMustBeAbsent()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> CreateRoutedAliasTest.java
>>> testTimezoneAbsoluteDate()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> CreateRoutedAliasTest.java
>>> testV1()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> CreateRoutedAliasTest.java
>>> testV2()
>>> //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> DeleteReplicaTest.java
>>> deleteReplicaOnIndexing()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> DocValuesNotIndexedTest.java
>>> testGroupingDVOnly()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> DocValuesNotIndexedTest.java
>>> testGroupingDocAbsent()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> DocValuesNotIndexedTest.java
>>> testGroupingSorting()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> ForceLeaderTest.java
>>> testReplicasInLIRNoLeader()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ForceLeaderTest.java
>>> testReplicasInLowerTerms()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> HdfsBasicDistributedZk2Test.java
>>> HdfsBasicDistributedZk2Test suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> HdfsChaosMonkeyNothingIsSafeTest.java
>>> HdfsChaosMonkeyNothingIsSafeTest suite
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
>>> https://issues.apache.org/jira/browse/SOLR-10191")
>>> 
>>> HdfsDirectoryTest.java
>>> testEOF()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> HdfsRecoveryZkTest.java
>>> HdfsRecoveryZkTest suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> HdfsRestartWhileUpdatingTest.java
>>> HdfsRestartWhileUpdatingTest suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> //2018-03-10
>>> 
>>> HdfsTlogReplayBufferedWhileIndexingTest.java
>>> HdfsTlogReplayBufferedWhileIndexingTest suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> HttpPartitionTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> LIRRollingUpdatesTest.java
>>> testNewLeaderAndMixedReplicas()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> LIRRollingUpdatesTest.java
>>> testNewLeaderOldReplica()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> LIRRollingUpdatesTest.java
>>> testOldLeaderAndMixedReplicas()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> LeaderElectionIntegrationTest.java
>>> testSimpleSliceLeaderElection()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> LeaderFailoverAfterPartitionTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> LegacyCloudClusterPropTest.java
>>> testCreateCollectionSwitchLegacyCloud()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> MathExpressionTest.java
>>> testDistributions()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> MathExpressionTest.java
>>> testGammaDistribution()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> MathExpressionTest.java
>>> testMultiVariateNormalDistribution()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> //2018-03-10
>>> 
>>> MissingSegmentRecoveryTest.java
>>> testLeaderRecovery()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> MoveReplicaHDFSTest.java
>>> testNormalFailedMove()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> MoveReplicaHDFSTest.java
>>> testNormalMove()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> //2018-03-10
>>> 
>>> MoveReplicaTest.java
>>> testFailedMove()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>>> 
>>> MultiThreadedOCPTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> NodeLostTriggerTest.java
>>> testListenerAcceptance()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 16-Apr-2018
>>> 
>>> OverseerRolesTest.java
>>> testOverseerRole()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> PeerSyncReplicationTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ReplaceNodeNoTargetTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ReplicationFactorTest.java
>>> ReplicationFactorTest suite
>>> @LuceneTestCase.BadApple(bugUrl =
>>> "https://issues.apache.org/jira/browse/SOLR-6944")
>>> 
>>> RestartWhileUpdatingTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> SSLMigrationTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 17-Mar-2018
>>> 
>>> ScheduledMaintenanceTriggerTest.java
>>> testInactiveShardCleanup()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 17-Mar-2018
>>> 
>>> ScheduledTriggerIntegrationTest.java
>>> ScheduledTriggerIntegrationTest suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> ScheduledTriggerTest.java
>>> testTrigger()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> ShardSplitTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ShardSplitTest.java
>>> testSplitAfterFailedSplit()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ShardSplitTest.java
>>> testSplitWithChaosMonkey()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> SharedFSAutoReplicaFailoverTest.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> SolrCloudExampleTest.java
>>> testLoadDocsIntoGettingStartedCollection()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> TestAuthenticationFramework.java
>>> testBasics()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestCloudRecovery.java
>>> leaderRecoverFromLogOnStartupTest()
>>> // Removed BadApple on 18-May-2018
>>> 
>>> TestCloudSchemaless.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> TestCollectionStateWatchers.java
>>> testDeletionsTriggerWatches()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> TestCollectionsAPIViaSolrCloudCluster.java
>>> testCollectionCreateSearchDelete()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestCollectionsAPIViaSolrCloudCluster.java
>>> testCollectionCreateWithoutCoresThenDelete()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> TestDistributedSearch.java
>>> test()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> TestDynamicLoading.java
>>> testDynamicLoading()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestGenericDistributedQueue.java
>>> TestGenericDistributedQueue suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestHdfsCloudBackupRestore.java
>>> TestHdfsCloudBackupRestore suite
>>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> TestLargeCluster.java
>>> TestLargeCluster suite
>>> @LuceneTestCase.BadApple(bugUrl =
>>> "https://issues.apache.org/jira/browse/SOLR-12075")
>>> 
>>> TestLargeCluster.java
>>> testSearchRate()
>>> @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>>> 
>>> TestLeaderElectionZkExpiry.java
>>> testLeaderElectionWithZkExpiry()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 17-Mar-2018
>>> 
>>> TestLeaderInitiatedRecoveryThread.java
>>> testPublishDownState()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> TestManagedResourceStorage.java
>>> TestManagedResourceStorage suite
>>> @LuceneTestCase.BadApple(bugUrl =
>>> "https://issues.apache.org/jira/browse/SOLR-6443")
>>> 
>>> TestPrepRecovery.java
>>> testLeaderNotResponding()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestPrepRecovery.java
>>> testLeaderUnloaded()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestPullReplica.java
>>> testAddDocs()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestPullReplica.java
>>> testKillLeader()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> TestReplicationHandler.java
>>> doTestIndexAndConfigAliasReplication()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> TestSegmentSorting.java
>>> testAtomicUpdateOfSegmentSortField()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> TestSegmentSorting.java
>>> testSegmentTerminateEarly()
>>> @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestStressCloudBlindAtomicUpdates.java
>>> test_dv()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestStressCloudBlindAtomicUpdates.java
>>> test_dv_stored()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestStressInPlaceUpdates.java
>>> stressTest()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> TestStressRecovery.java
>>> testStressRecovery()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 04-May-2018
>>> 
>>> TestTlogReplica.java
>>> testOnlyLeaderIndexes()
>>> // Removed BadApple on 2018-05-21
>>> 
>>> TestTriggerIntegration.java
>>> testCooldown()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestTriggerIntegration.java
>>> testEventFromRestoredState()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> //2018-03-10
>>> 
>>> TestTriggerIntegration.java
>>> testEventQueue()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 16-Apr-2018
>>> 
>>> TestTriggerIntegration.java
>>> testListeners()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestTriggerIntegration.java
>>> testNodeAddedTriggerRestoreState()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 09-Apr-2018
>>> 
>>> TestTriggerIntegration.java
>>> testNodeLostTrigger()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> // 26-Mar-2018
>>> 
>>> TestTriggerIntegration.java
>>> testNodeLostTriggerRestoreState()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestTriggerIntegration.java
>>> testNodeMarkersRegistration()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestTriggerIntegration.java
>>> testSearchRate()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestV2Request.java
>>> testCloudSolrClient()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> TestV2Request.java
>>> testHttpSolrClient()
>>> @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>> 
>>> ---------------------------------------------------------------------
>>> 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
>> 
> 
> ---------------------------------------------------------------------
> 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


Re: BadApple candidates

Posted by Erick Erickson <er...@gmail.com>.
Alan:

http://fucit.org/solr-jenkins-reports/job-data/sarowe/Lucene-Solr-Nightly-7.x/256/

You can get there from Hoss's rollup reports here:
http://fucit.org/solr-jenkins-reports/failure-report.html

To be included in any potential BadApple, two things must be true:
1> it must have failed since last Monday
2> it must have failed in the report collected two weeks ago Monday

Erick


On Mon, May 21, 2018 at 12:40 PM, Alan Woodward <ro...@gmail.com> wrote:
> When did TestLRUQueryCache fail?  I haven’t seen that one.
>
>> On 21 May 2018, at 16:00, Erick Erickson <er...@gmail.com> wrote:
>>
>> I'm going to change how I collect the badapple candidates. After
>> getting a little
>> overwhelmed by the number of failure e-mails (even ignoring the ones with
>> BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
>> know where that comes from, hint: Old music involving a pickle).
>>
>> Since I collect failures for a week then run filter them by what's
>> also in Hoss's
>> results from two  weeks ago, that's really equivalent to creating the candidate
>> list from the intersection of the most recent week of Hoss's results and the
>> results from _three_ weeks ago. Much faster too. Thanks Hoss!
>>
>> So that's what I'll do going forward.
>>
>> Meanwhile, here's the list for this Thursday.
>>
>> BadApple candidates: I'll BadApple these on Thursday unless there are objections
>> org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>>  org.apache.solr.TestDistributedSearch.test
>>  org.apache.solr.cloud.AddReplicaTest.test
>>  org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>>  org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>>  org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>>  org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>>  org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>>  org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>>  org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>>  org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>>  org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>>  org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>>  org.apache.solr.cloud.RestartWhileUpdatingTest.test
>>  org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>>  org.apache.solr.cloud.TestPullReplica.testCreateDelete
>>  org.apache.solr.cloud.TestPullReplica.testKillLeader
>>  org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>>  org.apache.solr.cloud.UnloadDistributedZkTest.test
>>  org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>>  org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>>  org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>>  org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>>  org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>>  org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>>  org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>>  org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>>  org.apache.solr.cloud.hdfs.StressHdfsTest.test
>>  org.apache.solr.handler.TestSQLHandler.doTest
>>  org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>>  org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>>  org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>>  org.apache.solr.update.TestInPlaceUpdatesDistrib.test
>>
>>
>> Number of AwaitsFix: 21 Number of BadApples: 99
>>
>> *****************AwaitsFix Annotations:
>>
>>
>> ************Lucene AwaitsFix
>> GeoPolygonTest.java
>>  testLUCENE8276_case3()
>>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")
>>
>> GeoPolygonTest.java
>>  testLUCENE8280()
>>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")
>>
>> GeoPolygonTest.java
>>  testLUCENE8281()
>>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> RandomGeoPolygonTest.java
>>  testCompareBigPolygons()
>>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> RandomGeoPolygonTest.java
>>  testCompareSmallPolygons()
>>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> TestControlledRealTimeReopenThread.java
>>  testCRTReopen()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")
>>
>> TestICUNormalizer2CharFilter.java
>>  testRandomStrings()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")
>>
>> TestICUTokenizerCJK.java
>>  TestICUTokenizerCJK suite
>>  @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>>
>> TestMoreLikeThis.java
>>  testMultiFieldShouldReturnPerFieldBooleanQuery()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")
>>
>> UIMABaseAnalyzerTest.java
>>  testRandomStrings()
>>  @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>> UIMABaseAnalyzerTest.java
>>  testRandomStringsWithConfigurationParameters()
>>  @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>> UIMATypeAwareAnalyzerTest.java
>>  testRandomStrings()
>>  @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>>
>>   ************Solr AwaitsFix
>> ReplaceNodeNoTargetTest.java
>>  ReplaceNodeNoTargetTest suite
>>  @LuceneTestCase.AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-11067")
>>
>> TestCollapseQParserPlugin.java
>>  testStringCollapse()
>>  @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>>
>> TestImpersonationWithHadoopAuth.java
>>  testForwarding()
>>  @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>>
>> TestLTRReRankingPipeline.java
>>  testDifferentTopN()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>>
>> TestMinMaxOnMultiValuedField.java
>>  testDoubleFieldCache()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>  testFloatFieldCache()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>  testIntFieldCache()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>  testLongFieldCache()
>>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>>
>>
>> *****************BadApple Annotations:
>>
>> ************Lucene BadApple
>>
>>   ************Solr BadApple
>> AddReplicaTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> AliasIntegrationTest.java
>>  testModifyPropertiesCAR()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AliasIntegrationTest.java
>>  testModifyPropertiesV1()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> AliasIntegrationTest.java
>>  testProperties()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoAddReplicasIntegrationTest.java
>>  testSimple()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoAddReplicasPlanActionTest.java
>>  testSimple()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoScalingHandlerTest.java
>>  testReadApi()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoscalingHistoryHandlerTest.java
>>  testHistory()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CdcrBootstrapTest.java
>>  testBootstrapWithContinousIndexingOnSourceCluster()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> CdcrReplicationDistributedZkTest.java
>>  CdcrReplicationDistributedZkTest suite
>>  @BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-12028,
>> https://issues.apache.org/jira/browse/SOLR-10107")
>>
>> ChaosMonkeyNothingIsSafeTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> ChaosMonkeySafeLeaderTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> CollectionsAPIDistributedZkTest.java
>>  testCollectionsAPI()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ComputePlanActionTest.java
>>  testSelectedCollections()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>  testCollectionNamesMustBeAbsent()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>  testTimezoneAbsoluteDate()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>  testV1()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>  testV2()
>>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> DeleteReplicaTest.java
>>  deleteReplicaOnIndexing()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> DocValuesNotIndexedTest.java
>>  testGroupingDVOnly()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> DocValuesNotIndexedTest.java
>>  testGroupingDocAbsent()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> DocValuesNotIndexedTest.java
>>  testGroupingSorting()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> ForceLeaderTest.java
>>  testReplicasInLIRNoLeader()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ForceLeaderTest.java
>>  testReplicasInLowerTerms()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsBasicDistributedZk2Test.java
>>  HdfsBasicDistributedZk2Test suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> HdfsChaosMonkeyNothingIsSafeTest.java
>>  HdfsChaosMonkeyNothingIsSafeTest suite
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
>> https://issues.apache.org/jira/browse/SOLR-10191")
>>
>> HdfsDirectoryTest.java
>>  testEOF()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsRecoveryZkTest.java
>>  HdfsRecoveryZkTest suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsRestartWhileUpdatingTest.java
>>  HdfsRestartWhileUpdatingTest suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> HdfsTlogReplayBufferedWhileIndexingTest.java
>>  HdfsTlogReplayBufferedWhileIndexingTest suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HttpPartitionTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> LIRRollingUpdatesTest.java
>>  testNewLeaderAndMixedReplicas()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LIRRollingUpdatesTest.java
>>  testNewLeaderOldReplica()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LIRRollingUpdatesTest.java
>>  testOldLeaderAndMixedReplicas()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LeaderElectionIntegrationTest.java
>>  testSimpleSliceLeaderElection()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LeaderFailoverAfterPartitionTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> LegacyCloudClusterPropTest.java
>>  testCreateCollectionSwitchLegacyCloud()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MathExpressionTest.java
>>  testDistributions()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MathExpressionTest.java
>>  testGammaDistribution()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> MathExpressionTest.java
>>  testMultiVariateNormalDistribution()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> MissingSegmentRecoveryTest.java
>>  testLeaderRecovery()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MoveReplicaHDFSTest.java
>>  testNormalFailedMove()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MoveReplicaHDFSTest.java
>>  testNormalMove()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> MoveReplicaTest.java
>>  testFailedMove()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>>
>> MultiThreadedOCPTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> NodeLostTriggerTest.java
>>  testListenerAcceptance()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 16-Apr-2018
>>
>> OverseerRolesTest.java
>>  testOverseerRole()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> PeerSyncReplicationTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ReplaceNodeNoTargetTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ReplicationFactorTest.java
>>  ReplicationFactorTest suite
>>  @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-6944")
>>
>> RestartWhileUpdatingTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> SSLMigrationTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> ScheduledMaintenanceTriggerTest.java
>>  testInactiveShardCleanup()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> ScheduledTriggerIntegrationTest.java
>>  ScheduledTriggerIntegrationTest suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> ScheduledTriggerTest.java
>>  testTrigger()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> ShardSplitTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ShardSplitTest.java
>>  testSplitAfterFailedSplit()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ShardSplitTest.java
>>  testSplitWithChaosMonkey()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> SharedFSAutoReplicaFailoverTest.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> SolrCloudExampleTest.java
>>  testLoadDocsIntoGettingStartedCollection()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestAuthenticationFramework.java
>>  testBasics()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestCloudRecovery.java
>>  leaderRecoverFromLogOnStartupTest()
>>  // Removed BadApple on 18-May-2018
>>
>> TestCloudSchemaless.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestCollectionStateWatchers.java
>>  testDeletionsTriggerWatches()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestCollectionsAPIViaSolrCloudCluster.java
>>  testCollectionCreateSearchDelete()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestCollectionsAPIViaSolrCloudCluster.java
>>  testCollectionCreateWithoutCoresThenDelete()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestDistributedSearch.java
>>  test()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestDynamicLoading.java
>>  testDynamicLoading()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestGenericDistributedQueue.java
>>  TestGenericDistributedQueue suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestHdfsCloudBackupRestore.java
>>  TestHdfsCloudBackupRestore suite
>>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestLargeCluster.java
>>  TestLargeCluster suite
>>  @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-12075")
>>
>> TestLargeCluster.java
>>  testSearchRate()
>>  @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>>
>> TestLeaderElectionZkExpiry.java
>>  testLeaderElectionWithZkExpiry()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> TestLeaderInitiatedRecoveryThread.java
>>  testPublishDownState()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestManagedResourceStorage.java
>>  TestManagedResourceStorage suite
>>  @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-6443")
>>
>> TestPrepRecovery.java
>>  testLeaderNotResponding()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPrepRecovery.java
>>  testLeaderUnloaded()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPullReplica.java
>>  testAddDocs()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPullReplica.java
>>  testKillLeader()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestReplicationHandler.java
>>  doTestIndexAndConfigAliasReplication()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestSegmentSorting.java
>>  testAtomicUpdateOfSegmentSortField()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestSegmentSorting.java
>>  testSegmentTerminateEarly()
>>  @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressCloudBlindAtomicUpdates.java
>>  test_dv()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressCloudBlindAtomicUpdates.java
>>  test_dv_stored()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressInPlaceUpdates.java
>>  stressTest()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestStressRecovery.java
>>  testStressRecovery()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestTlogReplica.java
>>  testOnlyLeaderIndexes()
>>  // Removed BadApple on 2018-05-21
>>
>> TestTriggerIntegration.java
>>  testCooldown()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>  testEventFromRestoredState()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> TestTriggerIntegration.java
>>  testEventQueue()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 16-Apr-2018
>>
>> TestTriggerIntegration.java
>>  testListeners()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>  testNodeAddedTriggerRestoreState()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestTriggerIntegration.java
>>  testNodeLostTrigger()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestTriggerIntegration.java
>>  testNodeLostTriggerRestoreState()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>  testNodeMarkersRegistration()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>  testSearchRate()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestV2Request.java
>>  testCloudSolrClient()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestV2Request.java
>>  testHttpSolrClient()
>>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ---------------------------------------------------------------------
>> 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
>

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


Re: BadApple candidates

Posted by Alan Woodward <ro...@gmail.com>.
When did TestLRUQueryCache fail?  I haven’t seen that one.

> On 21 May 2018, at 16:00, Erick Erickson <er...@gmail.com> wrote:
> 
> I'm going to change how I collect the badapple candidates. After
> getting a little
> overwhelmed by the number of failure e-mails (even ignoring the ones with
> BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
> know where that comes from, hint: Old music involving a pickle).
> 
> Since I collect failures for a week then run filter them by what's
> also in Hoss's
> results from two  weeks ago, that's really equivalent to creating the candidate
> list from the intersection of the most recent week of Hoss's results and the
> results from _three_ weeks ago. Much faster too. Thanks Hoss!
> 
> So that's what I'll do going forward.
> 
> Meanwhile, here's the list for this Thursday.
> 
> BadApple candidates: I'll BadApple these on Thursday unless there are objections
> org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>  org.apache.solr.TestDistributedSearch.test
>  org.apache.solr.cloud.AddReplicaTest.test
>  org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>  org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>  org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>  org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>  org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>  org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>  org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>  org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>  org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>  org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>  org.apache.solr.cloud.RestartWhileUpdatingTest.test
>  org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>  org.apache.solr.cloud.TestPullReplica.testCreateDelete
>  org.apache.solr.cloud.TestPullReplica.testKillLeader
>  org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>  org.apache.solr.cloud.UnloadDistributedZkTest.test
>  org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>  org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>  org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>  org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>  org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>  org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>  org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>  org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>  org.apache.solr.cloud.hdfs.StressHdfsTest.test
>  org.apache.solr.handler.TestSQLHandler.doTest
>  org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>  org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>  org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>  org.apache.solr.update.TestInPlaceUpdatesDistrib.test
> 
> 
> Number of AwaitsFix: 21 Number of BadApples: 99
> 
> *****************AwaitsFix Annotations:
> 
> 
> ************Lucene AwaitsFix
> GeoPolygonTest.java
>  testLUCENE8276_case3()
>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")
> 
> GeoPolygonTest.java
>  testLUCENE8280()
>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")
> 
> GeoPolygonTest.java
>  testLUCENE8281()
>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
> 
> RandomGeoPolygonTest.java
>  testCompareBigPolygons()
>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
> 
> RandomGeoPolygonTest.java
>  testCompareSmallPolygons()
>  //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
> 
> TestControlledRealTimeReopenThread.java
>  testCRTReopen()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")
> 
> TestICUNormalizer2CharFilter.java
>  testRandomStrings()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")
> 
> TestICUTokenizerCJK.java
>  TestICUTokenizerCJK suite
>  @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
> 
> TestMoreLikeThis.java
>  testMultiFieldShouldReturnPerFieldBooleanQuery()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")
> 
> UIMABaseAnalyzerTest.java
>  testRandomStrings()
>  @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
> 
> UIMABaseAnalyzerTest.java
>  testRandomStringsWithConfigurationParameters()
>  @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
> 
> UIMATypeAwareAnalyzerTest.java
>  testRandomStrings()
>  @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
> 
> 
>   ************Solr AwaitsFix
> ReplaceNodeNoTargetTest.java
>  ReplaceNodeNoTargetTest suite
>  @LuceneTestCase.AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-11067")
> 
> TestCollapseQParserPlugin.java
>  testStringCollapse()
>  @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
> 
> TestImpersonationWithHadoopAuth.java
>  testForwarding()
>  @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
> 
> TestLTRReRankingPipeline.java
>  testDifferentTopN()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
> 
> TestMinMaxOnMultiValuedField.java
>  testDoubleFieldCache()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
> 
> TestMinMaxOnMultiValuedField.java
>  testFloatFieldCache()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
> 
> TestMinMaxOnMultiValuedField.java
>  testIntFieldCache()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
> 
> TestMinMaxOnMultiValuedField.java
>  testLongFieldCache()
>  @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
> 
> 
> 
> *****************BadApple Annotations:
> 
> ************Lucene BadApple
> 
>   ************Solr BadApple
> AddReplicaTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> AliasIntegrationTest.java
>  testModifyPropertiesCAR()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> AliasIntegrationTest.java
>  testModifyPropertiesV1()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> AliasIntegrationTest.java
>  testProperties()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> AutoAddReplicasIntegrationTest.java
>  testSimple()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> AutoAddReplicasPlanActionTest.java
>  testSimple()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> AutoScalingHandlerTest.java
>  testReadApi()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> AutoscalingHistoryHandlerTest.java
>  testHistory()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> CdcrBootstrapTest.java
>  testBootstrapWithContinousIndexingOnSourceCluster()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> CdcrReplicationDistributedZkTest.java
>  CdcrReplicationDistributedZkTest suite
>  @BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10107")
> 
> ChaosMonkeyNothingIsSafeTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> ChaosMonkeySafeLeaderTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> CollectionsAPIDistributedZkTest.java
>  testCollectionsAPI()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ComputePlanActionTest.java
>  testSelectedCollections()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> CreateRoutedAliasTest.java
>  testCollectionNamesMustBeAbsent()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> CreateRoutedAliasTest.java
>  testTimezoneAbsoluteDate()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> CreateRoutedAliasTest.java
>  testV1()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> CreateRoutedAliasTest.java
>  testV2()
>  //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> DeleteReplicaTest.java
>  deleteReplicaOnIndexing()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> DocValuesNotIndexedTest.java
>  testGroupingDVOnly()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> DocValuesNotIndexedTest.java
>  testGroupingDocAbsent()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> DocValuesNotIndexedTest.java
>  testGroupingSorting()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> ForceLeaderTest.java
>  testReplicasInLIRNoLeader()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ForceLeaderTest.java
>  testReplicasInLowerTerms()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> HdfsBasicDistributedZk2Test.java
>  HdfsBasicDistributedZk2Test suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> HdfsChaosMonkeyNothingIsSafeTest.java
>  HdfsChaosMonkeyNothingIsSafeTest suite
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10191")
> 
> HdfsDirectoryTest.java
>  testEOF()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> HdfsRecoveryZkTest.java
>  HdfsRecoveryZkTest suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> HdfsRestartWhileUpdatingTest.java
>  HdfsRestartWhileUpdatingTest suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
> 
> HdfsTlogReplayBufferedWhileIndexingTest.java
>  HdfsTlogReplayBufferedWhileIndexingTest suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> HttpPartitionTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> LIRRollingUpdatesTest.java
>  testNewLeaderAndMixedReplicas()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> LIRRollingUpdatesTest.java
>  testNewLeaderOldReplica()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> LIRRollingUpdatesTest.java
>  testOldLeaderAndMixedReplicas()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> LeaderElectionIntegrationTest.java
>  testSimpleSliceLeaderElection()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> LeaderFailoverAfterPartitionTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> LegacyCloudClusterPropTest.java
>  testCreateCollectionSwitchLegacyCloud()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> MathExpressionTest.java
>  testDistributions()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> MathExpressionTest.java
>  testGammaDistribution()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> MathExpressionTest.java
>  testMultiVariateNormalDistribution()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
> 
> MissingSegmentRecoveryTest.java
>  testLeaderRecovery()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> MoveReplicaHDFSTest.java
>  testNormalFailedMove()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> MoveReplicaHDFSTest.java
>  testNormalMove()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
> 
> MoveReplicaTest.java
>  testFailedMove()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018 This JIRA is fixed, but this test still fails
> 
> MultiThreadedOCPTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> NodeLostTriggerTest.java
>  testListenerAcceptance()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
> 
> OverseerRolesTest.java
>  testOverseerRole()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> PeerSyncReplicationTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ReplaceNodeNoTargetTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ReplicationFactorTest.java
>  ReplicationFactorTest suite
>  @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6944")
> 
> RestartWhileUpdatingTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> SSLMigrationTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
> 
> ScheduledMaintenanceTriggerTest.java
>  testInactiveShardCleanup()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
> 
> ScheduledTriggerIntegrationTest.java
>  ScheduledTriggerIntegrationTest suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> ScheduledTriggerTest.java
>  testTrigger()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> ShardSplitTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ShardSplitTest.java
>  testSplitAfterFailedSplit()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ShardSplitTest.java
>  testSplitWithChaosMonkey()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> SharedFSAutoReplicaFailoverTest.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> SolrCloudExampleTest.java
>  testLoadDocsIntoGettingStartedCollection()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> TestAuthenticationFramework.java
>  testBasics()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestCloudRecovery.java
>  leaderRecoverFromLogOnStartupTest()
>  // Removed BadApple on 18-May-2018
> 
> TestCloudSchemaless.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> TestCollectionStateWatchers.java
>  testDeletionsTriggerWatches()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> TestCollectionsAPIViaSolrCloudCluster.java
>  testCollectionCreateSearchDelete()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestCollectionsAPIViaSolrCloudCluster.java
>  testCollectionCreateWithoutCoresThenDelete()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> TestDistributedSearch.java
>  test()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> TestDynamicLoading.java
>  testDynamicLoading()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestGenericDistributedQueue.java
>  TestGenericDistributedQueue suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestHdfsCloudBackupRestore.java
>  TestHdfsCloudBackupRestore suite
>  @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> TestLargeCluster.java
>  TestLargeCluster suite
>  @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12075")
> 
> TestLargeCluster.java
>  testSearchRate()
>  @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
> 
> TestLeaderElectionZkExpiry.java
>  testLeaderElectionWithZkExpiry()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
> 
> TestLeaderInitiatedRecoveryThread.java
>  testPublishDownState()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> TestManagedResourceStorage.java
>  TestManagedResourceStorage suite
>  @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6443")
> 
> TestPrepRecovery.java
>  testLeaderNotResponding()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestPrepRecovery.java
>  testLeaderUnloaded()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestPullReplica.java
>  testAddDocs()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestPullReplica.java
>  testKillLeader()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> TestReplicationHandler.java
>  doTestIndexAndConfigAliasReplication()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> TestSegmentSorting.java
>  testAtomicUpdateOfSegmentSortField()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> TestSegmentSorting.java
>  testSegmentTerminateEarly()
>  @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestStressCloudBlindAtomicUpdates.java
>  test_dv()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestStressCloudBlindAtomicUpdates.java
>  test_dv_stored()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestStressInPlaceUpdates.java
>  stressTest()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> TestStressRecovery.java
>  testStressRecovery()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
> 
> TestTlogReplica.java
>  testOnlyLeaderIndexes()
>  // Removed BadApple on 2018-05-21
> 
> TestTriggerIntegration.java
>  testCooldown()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestTriggerIntegration.java
>  testEventFromRestoredState()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
> 
> TestTriggerIntegration.java
>  testEventQueue()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
> 
> TestTriggerIntegration.java
>  testListeners()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestTriggerIntegration.java
>  testNodeAddedTriggerRestoreState()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
> 
> TestTriggerIntegration.java
>  testNodeLostTrigger()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
> 
> TestTriggerIntegration.java
>  testNodeLostTriggerRestoreState()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestTriggerIntegration.java
>  testNodeMarkersRegistration()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestTriggerIntegration.java
>  testSearchRate()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestV2Request.java
>  testCloudSolrClient()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> TestV2Request.java
>  testHttpSolrClient()
>  @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> 
> ---------------------------------------------------------------------
> 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


Re: BadApple candidates

Posted by Erick Erickson <er...@gmail.com>.
OK, not BadAppl-ing those tests.

I _think_ that my change to go from Hoss' test results as a baseline
will automagically just use 7x and master. Before I was copy/pasting
from messages to the dev list and if I didn't pay close enough
attention to the header I'd pick up other builds.

Erick

On Tue, May 22, 2018 at 5:14 PM, David Smiley <da...@gmail.com> wrote:
> Please don't bad-apple:
> * CreateRoutedAliasTest.  The failure I observed, thetaphi build 226  was on
> branch_7_3 which does not have SOLR-12308 (which is on master and branch7x)
> that I think solves that failure.
>
> Could you change your failure reporting to only considers master & branch7x?
>
> I just now applied @AwaitsFix to ConcurrentCreateRoutedAliasTest (similar
> name but not same) after filing SOLR-12386 for it -- the infamous (to us)
> "Can't find resource" relating to a configset file that ought to be there.
>
> AFAICT there is no other "alias" related fails pending.
>
> On Mon, May 21, 2018 at 11:01 AM Erick Erickson <er...@gmail.com>
> wrote:
>>
>> I'm going to change how I collect the badapple candidates. After
>> getting a little
>> overwhelmed by the number of failure e-mails (even ignoring the ones with
>> BadApple enabled), "It come to me in a vision! In a flash!"" (points if
>> you
>> know where that comes from, hint: Old music involving a pickle).
>>
>> Since I collect failures for a week then run filter them by what's
>> also in Hoss's
>> results from two  weeks ago, that's really equivalent to creating the
>> candidate
>> list from the intersection of the most recent week of Hoss's results and
>> the
>> results from _three_ weeks ago. Much faster too. Thanks Hoss!
>>
>> So that's what I'll do going forward.
>>
>> Meanwhile, here's the list for this Thursday.
>>
>> BadApple candidates: I'll BadApple these on Thursday unless there are
>> objections
>>   org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>>    org.apache.solr.TestDistributedSearch.test
>>    org.apache.solr.cloud.AddReplicaTest.test
>>    org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>>
>> org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>>
>> org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>>    org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>>    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>>
>> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>>    org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>>    org.apache.solr.cloud.RestartWhileUpdatingTest.test
>>
>> org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>>    org.apache.solr.cloud.TestPullReplica.testCreateDelete
>>    org.apache.solr.cloud.TestPullReplica.testKillLeader
>>    org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>>    org.apache.solr.cloud.UnloadDistributedZkTest.test
>>
>> org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>>
>> org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>>    org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>>
>> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>>
>> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>>    org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>>
>> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>>
>> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>>    org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>>    org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>>    org.apache.solr.cloud.hdfs.StressHdfsTest.test
>>    org.apache.solr.handler.TestSQLHandler.doTest
>>    org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>>    org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>>    org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>>    org.apache.solr.update.TestInPlaceUpdatesDistrib.test
>>
>>
>> Number of AwaitsFix: 21 Number of BadApples: 99
>>
>> *****************AwaitsFix Annotations:
>>
>>
>> ************Lucene AwaitsFix
>> GeoPolygonTest.java
>>    testLUCENE8276_case3()
>>
>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")
>>
>> GeoPolygonTest.java
>>    testLUCENE8280()
>>
>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")
>>
>> GeoPolygonTest.java
>>    testLUCENE8281()
>>
>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> RandomGeoPolygonTest.java
>>    testCompareBigPolygons()
>>
>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> RandomGeoPolygonTest.java
>>    testCompareSmallPolygons()
>>
>> //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> TestControlledRealTimeReopenThread.java
>>    testCRTReopen()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-5737")
>>
>> TestICUNormalizer2CharFilter.java
>>    testRandomStrings()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-5595")
>>
>> TestICUTokenizerCJK.java
>>    TestICUTokenizerCJK suite
>>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>>
>> TestMoreLikeThis.java
>>    testMultiFieldShouldReturnPerFieldBooleanQuery()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-7161")
>>
>> UIMABaseAnalyzerTest.java
>>    testRandomStrings()
>>    @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>> UIMABaseAnalyzerTest.java
>>    testRandomStringsWithConfigurationParameters()
>>    @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>> UIMATypeAwareAnalyzerTest.java
>>    testRandomStrings()
>>    @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>>
>>     ************Solr AwaitsFix
>> ReplaceNodeNoTargetTest.java
>>    ReplaceNodeNoTargetTest suite
>>    @LuceneTestCase.AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-11067")
>>
>> TestCollapseQParserPlugin.java
>>    testStringCollapse()
>>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>>
>> TestImpersonationWithHadoopAuth.java
>>    testForwarding()
>>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>>
>> TestLTRReRankingPipeline.java
>>    testDifferentTopN()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testDoubleFieldCache()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testFloatFieldCache()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testIntFieldCache()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testLongFieldCache()
>>    @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>>
>>
>> *****************BadApple Annotations:
>>
>> ************Lucene BadApple
>>
>>     ************Solr BadApple
>> AddReplicaTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> AliasIntegrationTest.java
>>    testModifyPropertiesCAR()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AliasIntegrationTest.java
>>    testModifyPropertiesV1()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> AliasIntegrationTest.java
>>    testProperties()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoAddReplicasIntegrationTest.java
>>    testSimple()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoAddReplicasPlanActionTest.java
>>    testSimple()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoScalingHandlerTest.java
>>    testReadApi()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoscalingHistoryHandlerTest.java
>>    testHistory()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CdcrBootstrapTest.java
>>    testBootstrapWithContinousIndexingOnSourceCluster()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> CdcrReplicationDistributedZkTest.java
>>    CdcrReplicationDistributedZkTest suite
>>    @BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-12028,
>> https://issues.apache.org/jira/browse/SOLR-10107")
>>
>> ChaosMonkeyNothingIsSafeTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> ChaosMonkeySafeLeaderTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> CollectionsAPIDistributedZkTest.java
>>    testCollectionsAPI()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ComputePlanActionTest.java
>>    testSelectedCollections()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testCollectionNamesMustBeAbsent()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testTimezoneAbsoluteDate()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testV1()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testV2()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> DeleteReplicaTest.java
>>    deleteReplicaOnIndexing()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> DocValuesNotIndexedTest.java
>>    testGroupingDVOnly()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> DocValuesNotIndexedTest.java
>>    testGroupingDocAbsent()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> DocValuesNotIndexedTest.java
>>    testGroupingSorting()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> ForceLeaderTest.java
>>    testReplicasInLIRNoLeader()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ForceLeaderTest.java
>>    testReplicasInLowerTerms()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsBasicDistributedZk2Test.java
>>    HdfsBasicDistributedZk2Test suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> HdfsChaosMonkeyNothingIsSafeTest.java
>>    HdfsChaosMonkeyNothingIsSafeTest suite
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
>> https://issues.apache.org/jira/browse/SOLR-10191")
>>
>> HdfsDirectoryTest.java
>>    testEOF()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsRecoveryZkTest.java
>>    HdfsRecoveryZkTest suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsRestartWhileUpdatingTest.java
>>    HdfsRestartWhileUpdatingTest suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> HdfsTlogReplayBufferedWhileIndexingTest.java
>>    HdfsTlogReplayBufferedWhileIndexingTest suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HttpPartitionTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> LIRRollingUpdatesTest.java
>>    testNewLeaderAndMixedReplicas()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LIRRollingUpdatesTest.java
>>    testNewLeaderOldReplica()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LIRRollingUpdatesTest.java
>>    testOldLeaderAndMixedReplicas()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LeaderElectionIntegrationTest.java
>>    testSimpleSliceLeaderElection()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LeaderFailoverAfterPartitionTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> LegacyCloudClusterPropTest.java
>>    testCreateCollectionSwitchLegacyCloud()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MathExpressionTest.java
>>    testDistributions()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MathExpressionTest.java
>>    testGammaDistribution()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> MathExpressionTest.java
>>    testMultiVariateNormalDistribution()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> MissingSegmentRecoveryTest.java
>>    testLeaderRecovery()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MoveReplicaHDFSTest.java
>>    testNormalFailedMove()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MoveReplicaHDFSTest.java
>>    testNormalMove()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> MoveReplicaTest.java
>>    testFailedMove()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>>
>> MultiThreadedOCPTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> NodeLostTriggerTest.java
>>    testListenerAcceptance()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 16-Apr-2018
>>
>> OverseerRolesTest.java
>>    testOverseerRole()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> PeerSyncReplicationTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ReplaceNodeNoTargetTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ReplicationFactorTest.java
>>    ReplicationFactorTest suite
>>    @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-6944")
>>
>> RestartWhileUpdatingTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> SSLMigrationTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> ScheduledMaintenanceTriggerTest.java
>>    testInactiveShardCleanup()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> ScheduledTriggerIntegrationTest.java
>>    ScheduledTriggerIntegrationTest suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> ScheduledTriggerTest.java
>>    testTrigger()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> ShardSplitTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ShardSplitTest.java
>>    testSplitAfterFailedSplit()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ShardSplitTest.java
>>    testSplitWithChaosMonkey()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> SharedFSAutoReplicaFailoverTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> SolrCloudExampleTest.java
>>    testLoadDocsIntoGettingStartedCollection()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestAuthenticationFramework.java
>>    testBasics()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestCloudRecovery.java
>>    leaderRecoverFromLogOnStartupTest()
>>    // Removed BadApple on 18-May-2018
>>
>> TestCloudSchemaless.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestCollectionStateWatchers.java
>>    testDeletionsTriggerWatches()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestCollectionsAPIViaSolrCloudCluster.java
>>    testCollectionCreateSearchDelete()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestCollectionsAPIViaSolrCloudCluster.java
>>    testCollectionCreateWithoutCoresThenDelete()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestDistributedSearch.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestDynamicLoading.java
>>    testDynamicLoading()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestGenericDistributedQueue.java
>>    TestGenericDistributedQueue suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestHdfsCloudBackupRestore.java
>>    TestHdfsCloudBackupRestore suite
>>
>> @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestLargeCluster.java
>>    TestLargeCluster suite
>>    @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-12075")
>>
>> TestLargeCluster.java
>>    testSearchRate()
>>    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>>
>> TestLeaderElectionZkExpiry.java
>>    testLeaderElectionWithZkExpiry()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> TestLeaderInitiatedRecoveryThread.java
>>    testPublishDownState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestManagedResourceStorage.java
>>    TestManagedResourceStorage suite
>>    @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-6443")
>>
>> TestPrepRecovery.java
>>    testLeaderNotResponding()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPrepRecovery.java
>>    testLeaderUnloaded()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPullReplica.java
>>    testAddDocs()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPullReplica.java
>>    testKillLeader()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestReplicationHandler.java
>>    doTestIndexAndConfigAliasReplication()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestSegmentSorting.java
>>    testAtomicUpdateOfSegmentSortField()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestSegmentSorting.java
>>    testSegmentTerminateEarly()
>>
>> @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressCloudBlindAtomicUpdates.java
>>    test_dv()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressCloudBlindAtomicUpdates.java
>>    test_dv_stored()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressInPlaceUpdates.java
>>    stressTest()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestStressRecovery.java
>>    testStressRecovery()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestTlogReplica.java
>>    testOnlyLeaderIndexes()
>>    // Removed BadApple on 2018-05-21
>>
>> TestTriggerIntegration.java
>>    testCooldown()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testEventFromRestoredState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> TestTriggerIntegration.java
>>    testEventQueue()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 16-Apr-2018
>>
>> TestTriggerIntegration.java
>>    testListeners()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testNodeAddedTriggerRestoreState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestTriggerIntegration.java
>>    testNodeLostTrigger()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestTriggerIntegration.java
>>    testNodeLostTriggerRestoreState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testNodeMarkersRegistration()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testSearchRate()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestV2Request.java
>>    testCloudSolrClient()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestV2Request.java
>>    testHttpSolrClient()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ---------------------------------------------------------------------
>> To unsubscribe, e-mail: dev-unsubscribe@lucene.apache.org
>> For additional commands, e-mail: dev-help@lucene.apache.org
>>
> --
> Lucene/Solr Search Committer, Consultant, Developer, Author, Speaker
> LinkedIn: http://linkedin.com/in/davidwsmiley | Book:
> http://www.solrenterprisesearchserver.com

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


Re: BadApple candidates

Posted by David Smiley <da...@gmail.com>.
Please don't bad-apple:
* CreateRoutedAliasTest.  The failure I observed, thetaphi build 226  was
on branch_7_3 which does not have SOLR-12308 (which is on master and
branch7x) that I think solves that failure.

Could you change your failure reporting to only considers master & branch7x?

I just now applied @AwaitsFix to ConcurrentCreateRoutedAliasTest (similar
name but not same) after filing SOLR-12386 for it -- the infamous (to us)
"Can't find resource" relating to a configset file that ought to be there.

AFAICT there is no other "alias" related fails pending.

On Mon, May 21, 2018 at 11:01 AM Erick Erickson <er...@gmail.com>
wrote:

> I'm going to change how I collect the badapple candidates. After
> getting a little
> overwhelmed by the number of failure e-mails (even ignoring the ones with
> BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
> know where that comes from, hint: Old music involving a pickle).
>
> Since I collect failures for a week then run filter them by what's
> also in Hoss's
> results from two  weeks ago, that's really equivalent to creating the
> candidate
> list from the intersection of the most recent week of Hoss's results and
> the
> results from _three_ weeks ago. Much faster too. Thanks Hoss!
>
> So that's what I'll do going forward.
>
> Meanwhile, here's the list for this Thursday.
>
> BadApple candidates: I'll BadApple these on Thursday unless there are
> objections
>   org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>    org.apache.solr.TestDistributedSearch.test
>    org.apache.solr.cloud.AddReplicaTest.test
>    org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>
>  org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>    org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>    org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>    org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>
>  org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>    org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>
>  org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>    org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>    org.apache.solr.cloud.RestartWhileUpdatingTest.test
>
>  org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>    org.apache.solr.cloud.TestPullReplica.testCreateDelete
>    org.apache.solr.cloud.TestPullReplica.testKillLeader
>    org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>    org.apache.solr.cloud.UnloadDistributedZkTest.test
>
>  org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>
>  org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>    org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>
>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>
>  org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>    org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>
>  org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>
>  org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>    org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>    org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>    org.apache.solr.cloud.hdfs.StressHdfsTest.test
>    org.apache.solr.handler.TestSQLHandler.doTest
>    org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>    org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>    org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>    org.apache.solr.update.TestInPlaceUpdatesDistrib.test
>
>
> Number of AwaitsFix: 21 Number of BadApples: 99
>
> *****************AwaitsFix Annotations:
>
>
> ************Lucene AwaitsFix
> GeoPolygonTest.java
>    testLUCENE8276_case3()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276
> ")
>
> GeoPolygonTest.java
>    testLUCENE8280()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280
> ")
>
> GeoPolygonTest.java
>    testLUCENE8281()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281
> ")
>
> RandomGeoPolygonTest.java
>    testCompareBigPolygons()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281
> ")
>
> RandomGeoPolygonTest.java
>    testCompareSmallPolygons()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281
> ")
>
> TestControlledRealTimeReopenThread.java
>    testCRTReopen()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737
> ")
>
> TestICUNormalizer2CharFilter.java
>    testRandomStrings()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595
> ")
>
> TestICUTokenizerCJK.java
>    TestICUTokenizerCJK suite
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>
> TestMoreLikeThis.java
>    testMultiFieldShouldReturnPerFieldBooleanQuery()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161
> ")
>
> UIMABaseAnalyzerTest.java
>    testRandomStrings()
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
> UIMABaseAnalyzerTest.java
>    testRandomStringsWithConfigurationParameters()
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
> UIMATypeAwareAnalyzerTest.java
>    testRandomStrings()
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
>
>     ************Solr AwaitsFix
> ReplaceNodeNoTargetTest.java
>    ReplaceNodeNoTargetTest suite
>    @LuceneTestCase.AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-11067")
>
> TestCollapseQParserPlugin.java
>    testStringCollapse()
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>
> TestImpersonationWithHadoopAuth.java
>    testForwarding()
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>
> TestLTRReRankingPipeline.java
>    testDifferentTopN()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>
> TestMinMaxOnMultiValuedField.java
>    testDoubleFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
>
> TestMinMaxOnMultiValuedField.java
>    testFloatFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
>
> TestMinMaxOnMultiValuedField.java
>    testIntFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
>
> TestMinMaxOnMultiValuedField.java
>    testLongFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709
> ")
>
>
>
> *****************BadApple Annotations:
>
> ************Lucene BadApple
>
>     ************Solr BadApple
> AddReplicaTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> AliasIntegrationTest.java
>    testModifyPropertiesCAR()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AliasIntegrationTest.java
>    testModifyPropertiesV1()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> AliasIntegrationTest.java
>    testProperties()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoAddReplicasIntegrationTest.java
>    testSimple()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoAddReplicasPlanActionTest.java
>    testSimple()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoScalingHandlerTest.java
>    testReadApi()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoscalingHistoryHandlerTest.java
>    testHistory()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CdcrBootstrapTest.java
>    testBootstrapWithContinousIndexingOnSourceCluster()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> CdcrReplicationDistributedZkTest.java
>    CdcrReplicationDistributedZkTest suite
>    @BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10107")
>
> ChaosMonkeyNothingIsSafeTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> ChaosMonkeySafeLeaderTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> CollectionsAPIDistributedZkTest.java
>    testCollectionsAPI()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ComputePlanActionTest.java
>    testSelectedCollections()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testCollectionNamesMustBeAbsent()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testTimezoneAbsoluteDate()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testV1()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testV2()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> DeleteReplicaTest.java
>    deleteReplicaOnIndexing()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> DocValuesNotIndexedTest.java
>    testGroupingDVOnly()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> DocValuesNotIndexedTest.java
>    testGroupingDocAbsent()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> DocValuesNotIndexedTest.java
>    testGroupingSorting()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> ForceLeaderTest.java
>    testReplicasInLIRNoLeader()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ForceLeaderTest.java
>    testReplicasInLowerTerms()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsBasicDistributedZk2Test.java
>    HdfsBasicDistributedZk2Test suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> HdfsChaosMonkeyNothingIsSafeTest.java
>    HdfsChaosMonkeyNothingIsSafeTest suite
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10191")
>
> HdfsDirectoryTest.java
>    testEOF()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsRecoveryZkTest.java
>    HdfsRecoveryZkTest suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsRestartWhileUpdatingTest.java
>    HdfsRestartWhileUpdatingTest suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> HdfsTlogReplayBufferedWhileIndexingTest.java
>    HdfsTlogReplayBufferedWhileIndexingTest suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
>
> HttpPartitionTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> LIRRollingUpdatesTest.java
>    testNewLeaderAndMixedReplicas()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LIRRollingUpdatesTest.java
>    testNewLeaderOldReplica()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LIRRollingUpdatesTest.java
>    testOldLeaderAndMixedReplicas()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LeaderElectionIntegrationTest.java
>    testSimpleSliceLeaderElection()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LeaderFailoverAfterPartitionTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> LegacyCloudClusterPropTest.java
>    testCreateCollectionSwitchLegacyCloud()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MathExpressionTest.java
>    testDistributions()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MathExpressionTest.java
>    testGammaDistribution()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> MathExpressionTest.java
>    testMultiVariateNormalDistribution()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> MissingSegmentRecoveryTest.java
>    testLeaderRecovery()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MoveReplicaHDFSTest.java
>    testNormalFailedMove()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MoveReplicaHDFSTest.java
>    testNormalMove()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> MoveReplicaTest.java
>    testFailedMove()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>
> MultiThreadedOCPTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> NodeLostTriggerTest.java
>    testListenerAcceptance()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
>
> OverseerRolesTest.java
>    testOverseerRole()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> PeerSyncReplicationTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ReplaceNodeNoTargetTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ReplicationFactorTest.java
>    ReplicationFactorTest suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6944")
>
> RestartWhileUpdatingTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> SSLMigrationTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> ScheduledMaintenanceTriggerTest.java
>    testInactiveShardCleanup()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> ScheduledTriggerIntegrationTest.java
>    ScheduledTriggerIntegrationTest suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> ScheduledTriggerTest.java
>    testTrigger()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> ShardSplitTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ShardSplitTest.java
>    testSplitAfterFailedSplit()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ShardSplitTest.java
>    testSplitWithChaosMonkey()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> SharedFSAutoReplicaFailoverTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> SolrCloudExampleTest.java
>    testLoadDocsIntoGettingStartedCollection()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestAuthenticationFramework.java
>    testBasics()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestCloudRecovery.java
>    leaderRecoverFromLogOnStartupTest()
>    // Removed BadApple on 18-May-2018
>
> TestCloudSchemaless.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestCollectionStateWatchers.java
>    testDeletionsTriggerWatches()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestCollectionsAPIViaSolrCloudCluster.java
>    testCollectionCreateSearchDelete()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestCollectionsAPIViaSolrCloudCluster.java
>    testCollectionCreateWithoutCoresThenDelete()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestDistributedSearch.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestDynamicLoading.java
>    testDynamicLoading()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestGenericDistributedQueue.java
>    TestGenericDistributedQueue suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestHdfsCloudBackupRestore.java
>    TestHdfsCloudBackupRestore suite
>    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestLargeCluster.java
>    TestLargeCluster suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12075")
>
> TestLargeCluster.java
>    testSearchRate()
>    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>
> TestLeaderElectionZkExpiry.java
>    testLeaderElectionWithZkExpiry()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> TestLeaderInitiatedRecoveryThread.java
>    testPublishDownState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestManagedResourceStorage.java
>    TestManagedResourceStorage suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6443")
>
> TestPrepRecovery.java
>    testLeaderNotResponding()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPrepRecovery.java
>    testLeaderUnloaded()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPullReplica.java
>    testAddDocs()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPullReplica.java
>    testKillLeader()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestReplicationHandler.java
>    doTestIndexAndConfigAliasReplication()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestSegmentSorting.java
>    testAtomicUpdateOfSegmentSortField()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestSegmentSorting.java
>    testSegmentTerminateEarly()
>    @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
>
> TestStressCloudBlindAtomicUpdates.java
>    test_dv()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressCloudBlindAtomicUpdates.java
>    test_dv_stored()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressInPlaceUpdates.java
>    stressTest()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestStressRecovery.java
>    testStressRecovery()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestTlogReplica.java
>    testOnlyLeaderIndexes()
>    // Removed BadApple on 2018-05-21
>
> TestTriggerIntegration.java
>    testCooldown()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testEventFromRestoredState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> TestTriggerIntegration.java
>    testEventQueue()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
>
> TestTriggerIntegration.java
>    testListeners()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testNodeAddedTriggerRestoreState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestTriggerIntegration.java
>    testNodeLostTrigger()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestTriggerIntegration.java
>    testNodeLostTriggerRestoreState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testNodeMarkersRegistration()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testSearchRate()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestV2Request.java
>    testCloudSolrClient()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestV2Request.java
>    testHttpSolrClient()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ---------------------------------------------------------------------
> To unsubscribe, e-mail: dev-unsubscribe@lucene.apache.org
> For additional commands, e-mail: dev-help@lucene.apache.org
>
> --
Lucene/Solr Search Committer, Consultant, Developer, Author, Speaker
LinkedIn: http://linkedin.com/in/davidwsmiley | Book:
http://www.solrenterprisesearchserver.com

Re: BadApple candidates

Posted by Erick Erickson <er...@gmail.com>.
Well, the problem is that nobody noticed because of all the noise,
that's the point. That test has been failing in each week prior to
3/26
4/02
4/09
4/16
4/25
4/30
I skipped this one
5/14

It was BadApple'd about three weeks ago. I have no objection to
raising a specific JIRA and substituting that back in for the bug url,
feel free. Nor do I have any objection to un-BadApple'ing a test if
there's value there (although I request people just comment it out so
we have a trail). And I have no doubt I'll inappropriately BadApple
some tests.

It's worth repeating that what I'm trying to do is just a triage. I
make the effort to publish the candidates specifically so people can
say "that's not right". I have no investment in keeping the bug url
pointing to 12028, it's just the placeholder so people can be
confident that tackling the test failure won't step on any ongoing
work or think that somebody else is working on it.

One of the points of the exercise is to see just how bad the problem
is. People don't just "sweep failures under the rug", they apparently
ignore Jenkins failures entirely. Or spend about an hour a day just
looking through failure cases. At least marking the test as BadApple
(even if sometimes wrong) means someone's noticed....

One thought I have had is to go from Hoss's rollups, that's something
of a historical record, though not quite a "historical pass rate".
Hmmm, could it be made so? I already collect the previous week's worth
every Monday (ok, occasionally I miss one, so sue me). I've had it in
the back of my mind that these could be made better use of. These
results include BadApple'd tests. It would be straightforward to
compare each week's rollup report with either (or both) of

> tests that had ever been mentioned in the rollups since I first started collecting them
> tests that had failed in week N but not week N-1

Do you think that would be a bite-sized list that we can actually use
rather than how I've been going about collecting them so far? Let me
give that a spin, 'cause going through the Jenkins failures is getting
too tedious. And if nobody looks I have little sympathy.

I'd hoped that after a few weeks the list of BadApple=false failures
and e-mails to go through would get more tractable and we'd get to a
place where failures of BadApple=false tests would be, in fact,
regressions. That people could take seriously. And look at regularly
(may need some specific label to make this easy). And be chastised if
they let things build up again. And draw a line in the sand where new
failures would be addressed and we can start working on the BadApple'd
tests. But that's not really panning out.

I'll probably continue the current process for two more weeks, but if
there are still large lists of non-BadApple'd tests that fail then I'm
thinking it's not worth the effort and there are some fundamental
issues with how we test that keep popping out in different places at
different times. In which case playing Whack-a-Mole with BadApple-ing
tests is a waste.

Erick


On Fri, May 25, 2018 at 8:34 AM, Yonik Seeley <ys...@gmail.com> wrote:
> I don't know what happened with TestStressRecovery, but IIRC it was
> not a flakey test and should have a 100% pass rate. This suggests a
> recent change introducing a bug (and demonstrates why historical pass
> rate is so important).  It feels like rather than sweeping these under
> the rug, a JIRA should be opened specific to the issue?
>
> -Yonik
>
>
> On Mon, May 21, 2018 at 11:00 AM, Erick Erickson
> <er...@gmail.com> wrote:
>> I'm going to change how I collect the badapple candidates. After
>> getting a little
>> overwhelmed by the number of failure e-mails (even ignoring the ones with
>> BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
>> know where that comes from, hint: Old music involving a pickle).
>>
>> Since I collect failures for a week then run filter them by what's
>> also in Hoss's
>> results from two  weeks ago, that's really equivalent to creating the candidate
>> list from the intersection of the most recent week of Hoss's results and the
>> results from _three_ weeks ago. Much faster too. Thanks Hoss!
>>
>> So that's what I'll do going forward.
>>
>> Meanwhile, here's the list for this Thursday.
>>
>> BadApple candidates: I'll BadApple these on Thursday unless there are objections
>>   org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>>    org.apache.solr.TestDistributedSearch.test
>>    org.apache.solr.cloud.AddReplicaTest.test
>>    org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>>    org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>>    org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>>    org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>>    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>>    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>>    org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>>    org.apache.solr.cloud.RestartWhileUpdatingTest.test
>>    org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>>    org.apache.solr.cloud.TestPullReplica.testCreateDelete
>>    org.apache.solr.cloud.TestPullReplica.testKillLeader
>>    org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>>    org.apache.solr.cloud.UnloadDistributedZkTest.test
>>    org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>>    org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>>    org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>>    org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>>    org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>>    org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>>    org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>>    org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>>    org.apache.solr.cloud.hdfs.StressHdfsTest.test
>>    org.apache.solr.handler.TestSQLHandler.doTest
>>    org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>>    org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>>    org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>>    org.apache.solr.update.TestInPlaceUpdatesDistrib.test
>>
>>
>> Number of AwaitsFix: 21 Number of BadApples: 99
>>
>> *****************AwaitsFix Annotations:
>>
>>
>> ************Lucene AwaitsFix
>> GeoPolygonTest.java
>>    testLUCENE8276_case3()
>>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")
>>
>> GeoPolygonTest.java
>>    testLUCENE8280()
>>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")
>>
>> GeoPolygonTest.java
>>    testLUCENE8281()
>>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> RandomGeoPolygonTest.java
>>    testCompareBigPolygons()
>>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> RandomGeoPolygonTest.java
>>    testCompareSmallPolygons()
>>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>>
>> TestControlledRealTimeReopenThread.java
>>    testCRTReopen()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")
>>
>> TestICUNormalizer2CharFilter.java
>>    testRandomStrings()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")
>>
>> TestICUTokenizerCJK.java
>>    TestICUTokenizerCJK suite
>>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>>
>> TestMoreLikeThis.java
>>    testMultiFieldShouldReturnPerFieldBooleanQuery()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")
>>
>> UIMABaseAnalyzerTest.java
>>    testRandomStrings()
>>    @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>> UIMABaseAnalyzerTest.java
>>    testRandomStringsWithConfigurationParameters()
>>    @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>> UIMATypeAwareAnalyzerTest.java
>>    testRandomStrings()
>>    @Test @AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/LUCENE-3869")
>>
>>
>>     ************Solr AwaitsFix
>> ReplaceNodeNoTargetTest.java
>>    ReplaceNodeNoTargetTest suite
>>    @LuceneTestCase.AwaitsFix(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-11067")
>>
>> TestCollapseQParserPlugin.java
>>    testStringCollapse()
>>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>>
>> TestImpersonationWithHadoopAuth.java
>>    testForwarding()
>>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>>
>> TestLTRReRankingPipeline.java
>>    testDifferentTopN()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testDoubleFieldCache()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testFloatFieldCache()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testIntFieldCache()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>> TestMinMaxOnMultiValuedField.java
>>    testLongFieldCache()
>>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>>
>>
>>
>> *****************BadApple Annotations:
>>
>> ************Lucene BadApple
>>
>>     ************Solr BadApple
>> AddReplicaTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> AliasIntegrationTest.java
>>    testModifyPropertiesCAR()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AliasIntegrationTest.java
>>    testModifyPropertiesV1()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> AliasIntegrationTest.java
>>    testProperties()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoAddReplicasIntegrationTest.java
>>    testSimple()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoAddReplicasPlanActionTest.java
>>    testSimple()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoScalingHandlerTest.java
>>    testReadApi()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> AutoscalingHistoryHandlerTest.java
>>    testHistory()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CdcrBootstrapTest.java
>>    testBootstrapWithContinousIndexingOnSourceCluster()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> CdcrReplicationDistributedZkTest.java
>>    CdcrReplicationDistributedZkTest suite
>>    @BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-12028,
>> https://issues.apache.org/jira/browse/SOLR-10107")
>>
>> ChaosMonkeyNothingIsSafeTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> ChaosMonkeySafeLeaderTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> CollectionsAPIDistributedZkTest.java
>>    testCollectionsAPI()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ComputePlanActionTest.java
>>    testSelectedCollections()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testCollectionNamesMustBeAbsent()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testTimezoneAbsoluteDate()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testV1()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> CreateRoutedAliasTest.java
>>    testV2()
>>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> DeleteReplicaTest.java
>>    deleteReplicaOnIndexing()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> DocValuesNotIndexedTest.java
>>    testGroupingDVOnly()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> DocValuesNotIndexedTest.java
>>    testGroupingDocAbsent()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> DocValuesNotIndexedTest.java
>>    testGroupingSorting()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> ForceLeaderTest.java
>>    testReplicasInLIRNoLeader()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ForceLeaderTest.java
>>    testReplicasInLowerTerms()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsBasicDistributedZk2Test.java
>>    HdfsBasicDistributedZk2Test suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> HdfsChaosMonkeyNothingIsSafeTest.java
>>    HdfsChaosMonkeyNothingIsSafeTest suite
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
>> https://issues.apache.org/jira/browse/SOLR-10191")
>>
>> HdfsDirectoryTest.java
>>    testEOF()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsRecoveryZkTest.java
>>    HdfsRecoveryZkTest suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HdfsRestartWhileUpdatingTest.java
>>    HdfsRestartWhileUpdatingTest suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> HdfsTlogReplayBufferedWhileIndexingTest.java
>>    HdfsTlogReplayBufferedWhileIndexingTest suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> HttpPartitionTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> LIRRollingUpdatesTest.java
>>    testNewLeaderAndMixedReplicas()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LIRRollingUpdatesTest.java
>>    testNewLeaderOldReplica()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LIRRollingUpdatesTest.java
>>    testOldLeaderAndMixedReplicas()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LeaderElectionIntegrationTest.java
>>    testSimpleSliceLeaderElection()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> LeaderFailoverAfterPartitionTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> LegacyCloudClusterPropTest.java
>>    testCreateCollectionSwitchLegacyCloud()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MathExpressionTest.java
>>    testDistributions()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MathExpressionTest.java
>>    testGammaDistribution()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> MathExpressionTest.java
>>    testMultiVariateNormalDistribution()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> MissingSegmentRecoveryTest.java
>>    testLeaderRecovery()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MoveReplicaHDFSTest.java
>>    testNormalFailedMove()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> MoveReplicaHDFSTest.java
>>    testNormalMove()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> MoveReplicaTest.java
>>    testFailedMove()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>>
>> MultiThreadedOCPTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> NodeLostTriggerTest.java
>>    testListenerAcceptance()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 16-Apr-2018
>>
>> OverseerRolesTest.java
>>    testOverseerRole()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> PeerSyncReplicationTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ReplaceNodeNoTargetTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ReplicationFactorTest.java
>>    ReplicationFactorTest suite
>>    @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-6944")
>>
>> RestartWhileUpdatingTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> SSLMigrationTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> ScheduledMaintenanceTriggerTest.java
>>    testInactiveShardCleanup()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> ScheduledTriggerIntegrationTest.java
>>    ScheduledTriggerIntegrationTest suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> ScheduledTriggerTest.java
>>    testTrigger()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> ShardSplitTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ShardSplitTest.java
>>    testSplitAfterFailedSplit()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ShardSplitTest.java
>>    testSplitWithChaosMonkey()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> SharedFSAutoReplicaFailoverTest.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> SolrCloudExampleTest.java
>>    testLoadDocsIntoGettingStartedCollection()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestAuthenticationFramework.java
>>    testBasics()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestCloudRecovery.java
>>    leaderRecoverFromLogOnStartupTest()
>>    // Removed BadApple on 18-May-2018
>>
>> TestCloudSchemaless.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestCollectionStateWatchers.java
>>    testDeletionsTriggerWatches()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestCollectionsAPIViaSolrCloudCluster.java
>>    testCollectionCreateSearchDelete()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestCollectionsAPIViaSolrCloudCluster.java
>>    testCollectionCreateWithoutCoresThenDelete()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestDistributedSearch.java
>>    test()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestDynamicLoading.java
>>    testDynamicLoading()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestGenericDistributedQueue.java
>>    TestGenericDistributedQueue suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestHdfsCloudBackupRestore.java
>>    TestHdfsCloudBackupRestore suite
>>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestLargeCluster.java
>>    TestLargeCluster suite
>>    @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-12075")
>>
>> TestLargeCluster.java
>>    testSearchRate()
>>    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>>
>> TestLeaderElectionZkExpiry.java
>>    testLeaderElectionWithZkExpiry()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 17-Mar-2018
>>
>> TestLeaderInitiatedRecoveryThread.java
>>    testPublishDownState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestManagedResourceStorage.java
>>    TestManagedResourceStorage suite
>>    @LuceneTestCase.BadApple(bugUrl =
>> "https://issues.apache.org/jira/browse/SOLR-6443")
>>
>> TestPrepRecovery.java
>>    testLeaderNotResponding()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPrepRecovery.java
>>    testLeaderUnloaded()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPullReplica.java
>>    testAddDocs()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestPullReplica.java
>>    testKillLeader()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestReplicationHandler.java
>>    doTestIndexAndConfigAliasReplication()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestSegmentSorting.java
>>    testAtomicUpdateOfSegmentSortField()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestSegmentSorting.java
>>    testSegmentTerminateEarly()
>>    @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressCloudBlindAtomicUpdates.java
>>    test_dv()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressCloudBlindAtomicUpdates.java
>>    test_dv_stored()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestStressInPlaceUpdates.java
>>    stressTest()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestStressRecovery.java
>>    testStressRecovery()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 04-May-2018
>>
>> TestTlogReplica.java
>>    testOnlyLeaderIndexes()
>>    // Removed BadApple on 2018-05-21
>>
>> TestTriggerIntegration.java
>>    testCooldown()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testEventFromRestoredState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> //2018-03-10
>>
>> TestTriggerIntegration.java
>>    testEventQueue()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 16-Apr-2018
>>
>> TestTriggerIntegration.java
>>    testListeners()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testNodeAddedTriggerRestoreState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 09-Apr-2018
>>
>> TestTriggerIntegration.java
>>    testNodeLostTrigger()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>> // 26-Mar-2018
>>
>> TestTriggerIntegration.java
>>    testNodeLostTriggerRestoreState()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testNodeMarkersRegistration()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestTriggerIntegration.java
>>    testSearchRate()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestV2Request.java
>>    testCloudSolrClient()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> TestV2Request.java
>>    testHttpSolrClient()
>>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>>
>> ---------------------------------------------------------------------
>> 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
>

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


Re: BadApple candidates

Posted by David Smiley <da...@gmail.com>.
"historical pass rate" would be awesome.  Has anyone mentioned plans to
track this somehow?  Maybe Hoss's fucit.org should track this?

On Fri, May 25, 2018 at 11:34 AM Yonik Seeley <ys...@gmail.com> wrote:

> I don't know what happened with TestStressRecovery, but IIRC it was
> not a flakey test and should have a 100% pass rate. This suggests a
> recent change introducing a bug (and demonstrates why historical pass
> rate is so important).  It feels like rather than sweeping these under
> the rug, a JIRA should be opened specific to the issue?
>
> -Yonik
>
>
> On Mon, May 21, 2018 at 11:00 AM, Erick Erickson
> <er...@gmail.com> wrote:
> > I'm going to change how I collect the badapple candidates. After
> > getting a little
> > overwhelmed by the number of failure e-mails (even ignoring the ones with
> > BadApple enabled), "It come to me in a vision! In a flash!"" (points if
> you
> > know where that comes from, hint: Old music involving a pickle).
> >
> > Since I collect failures for a week then run filter them by what's
> > also in Hoss's
> > results from two  weeks ago, that's really equivalent to creating the
> candidate
> > list from the intersection of the most recent week of Hoss's results and
> the
> > results from _three_ weeks ago. Much faster too. Thanks Hoss!
> >
> > So that's what I'll do going forward.
> >
> > Meanwhile, here's the list for this Thursday.
> >
> > BadApple candidates: I'll BadApple these on Thursday unless there are
> objections
> >   org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
> >    org.apache.solr.TestDistributedSearch.test
> >    org.apache.solr.cloud.AddReplicaTest.test
> >    org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
> >
> org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
> >    org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
> >    org.apache.solr.cloud.CreateRoutedAliasTest.testV1
> >    org.apache.solr.cloud.CreateRoutedAliasTest.testV2
> >
> org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
> >    org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
> >    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
> >
> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
> >    org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
> >    org.apache.solr.cloud.RestartWhileUpdatingTest.test
> >
> org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
> >    org.apache.solr.cloud.TestPullReplica.testCreateDelete
> >    org.apache.solr.cloud.TestPullReplica.testKillLeader
> >    org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
> >    org.apache.solr.cloud.UnloadDistributedZkTest.test
> >
> org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
> >
> org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
> >    org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
> >
> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
> >
> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
> >    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
> >
> org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
> >
> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
> >
> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
> >    org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
> >    org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
> >    org.apache.solr.cloud.hdfs.StressHdfsTest.test
> >    org.apache.solr.handler.TestSQLHandler.doTest
> >    org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
> >    org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
> >    org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
> >    org.apache.solr.update.TestInPlaceUpdatesDistrib.test
> >
> >
> > Number of AwaitsFix: 21 Number of BadApples: 99
> >
> > *****************AwaitsFix Annotations:
> >
> >
> > ************Lucene AwaitsFix
> > GeoPolygonTest.java
> >    testLUCENE8276_case3()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8276")
> >
> > GeoPolygonTest.java
> >    testLUCENE8280()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8280")
> >
> > GeoPolygonTest.java
> >    testLUCENE8281()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8281")
> >
> > RandomGeoPolygonTest.java
> >    testCompareBigPolygons()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8281")
> >
> > RandomGeoPolygonTest.java
> >    testCompareSmallPolygons()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8281")
> >
> > TestControlledRealTimeReopenThread.java
> >    testCRTReopen()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-5737")
> >
> > TestICUNormalizer2CharFilter.java
> >    testRandomStrings()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-5595")
> >
> > TestICUTokenizerCJK.java
> >    TestICUTokenizerCJK suite
> >    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222
> ")
> >
> > TestMoreLikeThis.java
> >    testMultiFieldShouldReturnPerFieldBooleanQuery()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-7161")
> >
> > UIMABaseAnalyzerTest.java
> >    testRandomStrings()
> >    @Test @AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/LUCENE-3869")
> >
> > UIMABaseAnalyzerTest.java
> >    testRandomStringsWithConfigurationParameters()
> >    @Test @AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/LUCENE-3869")
> >
> > UIMATypeAwareAnalyzerTest.java
> >    testRandomStrings()
> >    @Test @AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/LUCENE-3869")
> >
> >
> >     ************Solr AwaitsFix
> > ReplaceNodeNoTargetTest.java
> >    ReplaceNodeNoTargetTest suite
> >    @LuceneTestCase.AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-11067")
> >
> > TestCollapseQParserPlugin.java
> >    testStringCollapse()
> >    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
> >
> > TestImpersonationWithHadoopAuth.java
> >    testForwarding()
> >    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893
> ")
> >
> > TestLTRReRankingPipeline.java
> >    testDifferentTopN()
> >    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134
> ")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testDoubleFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testFloatFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testIntFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testLongFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> >
> >
> > *****************BadApple Annotations:
> >
> > ************Lucene BadApple
> >
> >     ************Solr BadApple
> > AddReplicaTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > AliasIntegrationTest.java
> >    testModifyPropertiesCAR()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> >
> > AliasIntegrationTest.java
> >    testModifyPropertiesV1()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > AliasIntegrationTest.java
> >    testProperties()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> >
> > AutoAddReplicasIntegrationTest.java
> >    testSimple()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > AutoAddReplicasPlanActionTest.java
> >    testSimple()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > AutoScalingHandlerTest.java
> >    testReadApi()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > AutoscalingHistoryHandlerTest.java
> >    testHistory()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > CdcrBootstrapTest.java
> >    testBootstrapWithContinousIndexingOnSourceCluster()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > CdcrReplicationDistributedZkTest.java
> >    CdcrReplicationDistributedZkTest suite
> >    @BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-12028,
> > https://issues.apache.org/jira/browse/SOLR-10107")
> >
> > ChaosMonkeyNothingIsSafeTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > ChaosMonkeySafeLeaderTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ChaosMonkeySafeLeaderWithPullReplicasTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > CollectionsAPIDistributedZkTest.java
> >    testCollectionsAPI()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ComputePlanActionTest.java
> >    testSelectedCollections()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testCollectionNamesMustBeAbsent()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testTimezoneAbsoluteDate()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testV1()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testV2()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > DeleteReplicaTest.java
> >    deleteReplicaOnIndexing()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > DocValuesNotIndexedTest.java
> >    testGroupingDVOnly()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > DocValuesNotIndexedTest.java
> >    testGroupingDocAbsent()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > DocValuesNotIndexedTest.java
> >    testGroupingSorting()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > ForceLeaderTest.java
> >    testReplicasInLIRNoLeader()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ForceLeaderTest.java
> >    testReplicasInLowerTerms()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HdfsBasicDistributedZk2Test.java
> >    HdfsBasicDistributedZk2Test suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > HdfsChaosMonkeyNothingIsSafeTest.java
> >    HdfsChaosMonkeyNothingIsSafeTest suite
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> > https://issues.apache.org/jira/browse/SOLR-10191")
> >
> > HdfsDirectoryTest.java
> >    testEOF()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HdfsRecoveryZkTest.java
> >    HdfsRecoveryZkTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HdfsRestartWhileUpdatingTest.java
> >    HdfsRestartWhileUpdatingTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > HdfsTlogReplayBufferedWhileIndexingTest.java
> >    HdfsTlogReplayBufferedWhileIndexingTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HttpPartitionTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > LIRRollingUpdatesTest.java
> >    testNewLeaderAndMixedReplicas()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LIRRollingUpdatesTest.java
> >    testNewLeaderOldReplica()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LIRRollingUpdatesTest.java
> >    testOldLeaderAndMixedReplicas()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LeaderElectionIntegrationTest.java
> >    testSimpleSliceLeaderElection()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LeaderFailoverAfterPartitionTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > LegacyCloudClusterPropTest.java
> >    testCreateCollectionSwitchLegacyCloud()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MathExpressionTest.java
> >    testDistributions()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MathExpressionTest.java
> >    testGammaDistribution()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > MathExpressionTest.java
> >    testMultiVariateNormalDistribution()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > MissingSegmentRecoveryTest.java
> >    testLeaderRecovery()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MoveReplicaHDFSTest.java
> >    testNormalFailedMove()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MoveReplicaHDFSTest.java
> >    testNormalMove()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > MoveReplicaTest.java
> >    testFailedMove()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018 This JIRA is fixed, but this test still fails
> >
> > MultiThreadedOCPTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > NodeLostTriggerTest.java
> >    testListenerAcceptance()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 16-Apr-2018
> >
> > OverseerRolesTest.java
> >    testOverseerRole()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > PeerSyncReplicationTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ReplaceNodeNoTargetTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ReplicationFactorTest.java
> >    ReplicationFactorTest suite
> >    @LuceneTestCase.BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-6944")
> >
> > RestartWhileUpdatingTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > SSLMigrationTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018
> >
> > ScheduledMaintenanceTriggerTest.java
> >    testInactiveShardCleanup()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018
> >
> > ScheduledTriggerIntegrationTest.java
> >    ScheduledTriggerIntegrationTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > ScheduledTriggerTest.java
> >    testTrigger()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > ShardSplitTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ShardSplitTest.java
> >    testSplitAfterFailedSplit()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ShardSplitTest.java
> >    testSplitWithChaosMonkey()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > SharedFSAutoReplicaFailoverTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > SolrCloudExampleTest.java
> >    testLoadDocsIntoGettingStartedCollection()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestAuthenticationFramework.java
> >    testBasics()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestCloudRecovery.java
> >    leaderRecoverFromLogOnStartupTest()
> >    // Removed BadApple on 18-May-2018
> >
> > TestCloudSchemaless.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestCollectionStateWatchers.java
> >    testDeletionsTriggerWatches()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestCollectionsAPIViaSolrCloudCluster.java
> >    testCollectionCreateSearchDelete()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestCollectionsAPIViaSolrCloudCluster.java
> >    testCollectionCreateWithoutCoresThenDelete()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestDistributedSearch.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestDynamicLoading.java
> >    testDynamicLoading()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestGenericDistributedQueue.java
> >    TestGenericDistributedQueue suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestHdfsCloudBackupRestore.java
> >    TestHdfsCloudBackupRestore suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestLargeCluster.java
> >    TestLargeCluster suite
> >    @LuceneTestCase.BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-12075")
> >
> > TestLargeCluster.java
> >    testSearchRate()
> >    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714
> ")
> >
> > TestLeaderElectionZkExpiry.java
> >    testLeaderElectionWithZkExpiry()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018
> >
> > TestLeaderInitiatedRecoveryThread.java
> >    testPublishDownState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestManagedResourceStorage.java
> >    TestManagedResourceStorage suite
> >    @LuceneTestCase.BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-6443")
> >
> > TestPrepRecovery.java
> >    testLeaderNotResponding()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestPrepRecovery.java
> >    testLeaderUnloaded()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestPullReplica.java
> >    testAddDocs()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestPullReplica.java
> >    testKillLeader()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > TestReplicationHandler.java
> >    doTestIndexAndConfigAliasReplication()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestSegmentSorting.java
> >    testAtomicUpdateOfSegmentSortField()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > TestSegmentSorting.java
> >    testSegmentTerminateEarly()
> >    @Test@BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestStressCloudBlindAtomicUpdates.java
> >    test_dv()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestStressCloudBlindAtomicUpdates.java
> >    test_dv_stored()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestStressInPlaceUpdates.java
> >    stressTest()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestStressRecovery.java
> >    testStressRecovery()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestTlogReplica.java
> >    testOnlyLeaderIndexes()
> >    // Removed BadApple on 2018-05-21
> >
> > TestTriggerIntegration.java
> >    testCooldown()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testEventFromRestoredState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > TestTriggerIntegration.java
> >    testEventQueue()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 16-Apr-2018
> >
> > TestTriggerIntegration.java
> >    testListeners()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testNodeAddedTriggerRestoreState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestTriggerIntegration.java
> >    testNodeLostTrigger()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > TestTriggerIntegration.java
> >    testNodeLostTriggerRestoreState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testNodeMarkersRegistration()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testSearchRate()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestV2Request.java
> >    testCloudSolrClient()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestV2Request.java
> >    testHttpSolrClient()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ---------------------------------------------------------------------
> > 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
>
> --
Lucene/Solr Search Committer, Consultant, Developer, Author, Speaker
LinkedIn: http://linkedin.com/in/davidwsmiley | Book:
http://www.solrenterprisesearchserver.com

Re: BadApple candidates

Posted by Mark Miller <ma...@gmail.com>.
This was one of the motivations of the test report. When it's regularly
running, eventually you can get to the point where it flags this type of
thing in the summary - if people pay attention and react.

I havn't run them in a couple weeks. Something happened where the
bitballoon ruby gem I'm using to publish the html started getting some
error and I have not had a chance to figure out why. I may have to use an
http api or something to avoid relying on this gem.

My motivation for this report was just this mass @BadApple situation
though. Doing it in mass based on all the jenkins emails puts you in a
scary situation. The report is meant to tell you stability grade for a test
in a known good environment and hardware. Theoretically, you can consult
the report and understand if the test is failing due to the jenkins env vs
being a flaky test in general.

The report also highlights @BadApples and @AwaitsFix tests (though not by
method) and tries to create a summary that gives high value items to
address, as well as highlighting tests that have instability introduced.

I started publishing the report before I had a lot of time to push on the
results, so the last couple weeks I lost the motivation to work around the
bitballoon thing by hand (though it takes 60 seconds and to be fair I was
busy), but I don't see how this is overall going to be a winning strategy
without that kind of info being generated and monitored and responded to
over time.

Hopefully this tying @BadApples to one JIRA is a tmp thing that will go
away, but I can see it's value in the short term. We should worry about the
stuff getting swept under the rug, but that seems like a good impetus too
look into why a test is under the broom - it's hard to even know there is a
problem with a specific test in all the email fails, so the test or feature
quality would still be pretty unknown even if the test passes a lot.

- Mark

On Fri, May 25, 2018 at 10:34 AM Yonik Seeley <ys...@gmail.com> wrote:

> I don't know what happened with TestStressRecovery, but IIRC it was
> not a flakey test and should have a 100% pass rate. This suggests a
> recent change introducing a bug (and demonstrates why historical pass
> rate is so important).  It feels like rather than sweeping these under
> the rug, a JIRA should be opened specific to the issue?
>
> -Yonik
>
>
> On Mon, May 21, 2018 at 11:00 AM, Erick Erickson
> <er...@gmail.com> wrote:
> > I'm going to change how I collect the badapple candidates. After
> > getting a little
> > overwhelmed by the number of failure e-mails (even ignoring the ones with
> > BadApple enabled), "It come to me in a vision! In a flash!"" (points if
> you
> > know where that comes from, hint: Old music involving a pickle).
> >
> > Since I collect failures for a week then run filter them by what's
> > also in Hoss's
> > results from two  weeks ago, that's really equivalent to creating the
> candidate
> > list from the intersection of the most recent week of Hoss's results and
> the
> > results from _three_ weeks ago. Much faster too. Thanks Hoss!
> >
> > So that's what I'll do going forward.
> >
> > Meanwhile, here's the list for this Thursday.
> >
> > BadApple candidates: I'll BadApple these on Thursday unless there are
> objections
> >   org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
> >    org.apache.solr.TestDistributedSearch.test
> >    org.apache.solr.cloud.AddReplicaTest.test
> >    org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
> >
> org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
> >    org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
> >    org.apache.solr.cloud.CreateRoutedAliasTest.testV1
> >    org.apache.solr.cloud.CreateRoutedAliasTest.testV2
> >
> org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
> >    org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
> >    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
> >
> org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
> >    org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
> >    org.apache.solr.cloud.RestartWhileUpdatingTest.test
> >
> org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
> >    org.apache.solr.cloud.TestPullReplica.testCreateDelete
> >    org.apache.solr.cloud.TestPullReplica.testKillLeader
> >    org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
> >    org.apache.solr.cloud.UnloadDistributedZkTest.test
> >
> org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
> >
> org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
> >    org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
> >
> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
> >
> org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
> >    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
> >
> org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
> >
> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
> >
> org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
> >    org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
> >    org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
> >    org.apache.solr.cloud.hdfs.StressHdfsTest.test
> >    org.apache.solr.handler.TestSQLHandler.doTest
> >    org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
> >    org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
> >    org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
> >    org.apache.solr.update.TestInPlaceUpdatesDistrib.test
> >
> >
> > Number of AwaitsFix: 21 Number of BadApples: 99
> >
> > *****************AwaitsFix Annotations:
> >
> >
> > ************Lucene AwaitsFix
> > GeoPolygonTest.java
> >    testLUCENE8276_case3()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8276")
> >
> > GeoPolygonTest.java
> >    testLUCENE8280()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8280")
> >
> > GeoPolygonTest.java
> >    testLUCENE8281()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8281")
> >
> > RandomGeoPolygonTest.java
> >    testCompareBigPolygons()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8281")
> >
> > RandomGeoPolygonTest.java
> >    testCompareSmallPolygons()
> >    //@AwaitsFix(bugUrl="
> https://issues.apache.org/jira/browse/LUCENE-8281")
> >
> > TestControlledRealTimeReopenThread.java
> >    testCRTReopen()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-5737")
> >
> > TestICUNormalizer2CharFilter.java
> >    testRandomStrings()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-5595")
> >
> > TestICUTokenizerCJK.java
> >    TestICUTokenizerCJK suite
> >    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222
> ")
> >
> > TestMoreLikeThis.java
> >    testMultiFieldShouldReturnPerFieldBooleanQuery()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-7161")
> >
> > UIMABaseAnalyzerTest.java
> >    testRandomStrings()
> >    @Test @AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/LUCENE-3869")
> >
> > UIMABaseAnalyzerTest.java
> >    testRandomStringsWithConfigurationParameters()
> >    @Test @AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/LUCENE-3869")
> >
> > UIMATypeAwareAnalyzerTest.java
> >    testRandomStrings()
> >    @Test @AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/LUCENE-3869")
> >
> >
> >     ************Solr AwaitsFix
> > ReplaceNodeNoTargetTest.java
> >    ReplaceNodeNoTargetTest suite
> >    @LuceneTestCase.AwaitsFix(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-11067")
> >
> > TestCollapseQParserPlugin.java
> >    testStringCollapse()
> >    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
> >
> > TestImpersonationWithHadoopAuth.java
> >    testForwarding()
> >    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893
> ")
> >
> > TestLTRReRankingPipeline.java
> >    testDifferentTopN()
> >    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134
> ")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testDoubleFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testFloatFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testIntFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> > TestMinMaxOnMultiValuedField.java
> >    testLongFieldCache()
> >    @AwaitsFix(bugUrl = "
> https://issues.apache.org/jira/browse/LUCENE-6709")
> >
> >
> >
> > *****************BadApple Annotations:
> >
> > ************Lucene BadApple
> >
> >     ************Solr BadApple
> > AddReplicaTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > AliasIntegrationTest.java
> >    testModifyPropertiesCAR()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> >
> > AliasIntegrationTest.java
> >    testModifyPropertiesV1()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > AliasIntegrationTest.java
> >    testProperties()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> >
> > AutoAddReplicasIntegrationTest.java
> >    testSimple()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > AutoAddReplicasPlanActionTest.java
> >    testSimple()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > AutoScalingHandlerTest.java
> >    testReadApi()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > AutoscalingHistoryHandlerTest.java
> >    testHistory()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > CdcrBootstrapTest.java
> >    testBootstrapWithContinousIndexingOnSourceCluster()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > CdcrReplicationDistributedZkTest.java
> >    CdcrReplicationDistributedZkTest suite
> >    @BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-12028,
> > https://issues.apache.org/jira/browse/SOLR-10107")
> >
> > ChaosMonkeyNothingIsSafeTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > ChaosMonkeySafeLeaderTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ChaosMonkeySafeLeaderWithPullReplicasTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > CollectionsAPIDistributedZkTest.java
> >    testCollectionsAPI()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ComputePlanActionTest.java
> >    testSelectedCollections()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testCollectionNamesMustBeAbsent()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testTimezoneAbsoluteDate()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testV1()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > CreateRoutedAliasTest.java
> >    testV2()
> >    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028
> ")
> > // 09-Apr-2018
> >
> > DeleteReplicaTest.java
> >    deleteReplicaOnIndexing()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > DocValuesNotIndexedTest.java
> >    testGroupingDVOnly()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > DocValuesNotIndexedTest.java
> >    testGroupingDocAbsent()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > DocValuesNotIndexedTest.java
> >    testGroupingSorting()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > ForceLeaderTest.java
> >    testReplicasInLIRNoLeader()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ForceLeaderTest.java
> >    testReplicasInLowerTerms()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HdfsBasicDistributedZk2Test.java
> >    HdfsBasicDistributedZk2Test suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > HdfsChaosMonkeyNothingIsSafeTest.java
> >    HdfsChaosMonkeyNothingIsSafeTest suite
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> > https://issues.apache.org/jira/browse/SOLR-10191")
> >
> > HdfsDirectoryTest.java
> >    testEOF()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HdfsRecoveryZkTest.java
> >    HdfsRecoveryZkTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HdfsRestartWhileUpdatingTest.java
> >    HdfsRestartWhileUpdatingTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > HdfsTlogReplayBufferedWhileIndexingTest.java
> >    HdfsTlogReplayBufferedWhileIndexingTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > HttpPartitionTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > LIRRollingUpdatesTest.java
> >    testNewLeaderAndMixedReplicas()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LIRRollingUpdatesTest.java
> >    testNewLeaderOldReplica()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LIRRollingUpdatesTest.java
> >    testOldLeaderAndMixedReplicas()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LeaderElectionIntegrationTest.java
> >    testSimpleSliceLeaderElection()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > LeaderFailoverAfterPartitionTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > LegacyCloudClusterPropTest.java
> >    testCreateCollectionSwitchLegacyCloud()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MathExpressionTest.java
> >    testDistributions()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MathExpressionTest.java
> >    testGammaDistribution()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > MathExpressionTest.java
> >    testMultiVariateNormalDistribution()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > MissingSegmentRecoveryTest.java
> >    testLeaderRecovery()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MoveReplicaHDFSTest.java
> >    testNormalFailedMove()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > MoveReplicaHDFSTest.java
> >    testNormalMove()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > MoveReplicaTest.java
> >    testFailedMove()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018 This JIRA is fixed, but this test still fails
> >
> > MultiThreadedOCPTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > NodeLostTriggerTest.java
> >    testListenerAcceptance()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 16-Apr-2018
> >
> > OverseerRolesTest.java
> >    testOverseerRole()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > PeerSyncReplicationTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ReplaceNodeNoTargetTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ReplicationFactorTest.java
> >    ReplicationFactorTest suite
> >    @LuceneTestCase.BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-6944")
> >
> > RestartWhileUpdatingTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > SSLMigrationTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018
> >
> > ScheduledMaintenanceTriggerTest.java
> >    testInactiveShardCleanup()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018
> >
> > ScheduledTriggerIntegrationTest.java
> >    ScheduledTriggerIntegrationTest suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > ScheduledTriggerTest.java
> >    testTrigger()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > ShardSplitTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ShardSplitTest.java
> >    testSplitAfterFailedSplit()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ShardSplitTest.java
> >    testSplitWithChaosMonkey()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > SharedFSAutoReplicaFailoverTest.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > SolrCloudExampleTest.java
> >    testLoadDocsIntoGettingStartedCollection()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestAuthenticationFramework.java
> >    testBasics()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestCloudRecovery.java
> >    leaderRecoverFromLogOnStartupTest()
> >    // Removed BadApple on 18-May-2018
> >
> > TestCloudSchemaless.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestCollectionStateWatchers.java
> >    testDeletionsTriggerWatches()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestCollectionsAPIViaSolrCloudCluster.java
> >    testCollectionCreateSearchDelete()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestCollectionsAPIViaSolrCloudCluster.java
> >    testCollectionCreateWithoutCoresThenDelete()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestDistributedSearch.java
> >    test()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestDynamicLoading.java
> >    testDynamicLoading()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestGenericDistributedQueue.java
> >    TestGenericDistributedQueue suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestHdfsCloudBackupRestore.java
> >    TestHdfsCloudBackupRestore suite
> >    @LuceneTestCase.BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestLargeCluster.java
> >    TestLargeCluster suite
> >    @LuceneTestCase.BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-12075")
> >
> > TestLargeCluster.java
> >    testSearchRate()
> >    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714
> ")
> >
> > TestLeaderElectionZkExpiry.java
> >    testLeaderElectionWithZkExpiry()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 17-Mar-2018
> >
> > TestLeaderInitiatedRecoveryThread.java
> >    testPublishDownState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestManagedResourceStorage.java
> >    TestManagedResourceStorage suite
> >    @LuceneTestCase.BadApple(bugUrl =
> > "https://issues.apache.org/jira/browse/SOLR-6443")
> >
> > TestPrepRecovery.java
> >    testLeaderNotResponding()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestPrepRecovery.java
> >    testLeaderUnloaded()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestPullReplica.java
> >    testAddDocs()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestPullReplica.java
> >    testKillLeader()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > TestReplicationHandler.java
> >    doTestIndexAndConfigAliasReplication()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestSegmentSorting.java
> >    testAtomicUpdateOfSegmentSortField()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > TestSegmentSorting.java
> >    testSegmentTerminateEarly()
> >    @Test@BadApple(bugUrl="
> https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestStressCloudBlindAtomicUpdates.java
> >    test_dv()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestStressCloudBlindAtomicUpdates.java
> >    test_dv_stored()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestStressInPlaceUpdates.java
> >    stressTest()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestStressRecovery.java
> >    testStressRecovery()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 04-May-2018
> >
> > TestTlogReplica.java
> >    testOnlyLeaderIndexes()
> >    // Removed BadApple on 2018-05-21
> >
> > TestTriggerIntegration.java
> >    testCooldown()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testEventFromRestoredState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > //2018-03-10
> >
> > TestTriggerIntegration.java
> >    testEventQueue()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 16-Apr-2018
> >
> > TestTriggerIntegration.java
> >    testListeners()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testNodeAddedTriggerRestoreState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 09-Apr-2018
> >
> > TestTriggerIntegration.java
> >    testNodeLostTrigger()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> > // 26-Mar-2018
> >
> > TestTriggerIntegration.java
> >    testNodeLostTriggerRestoreState()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testNodeMarkersRegistration()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestTriggerIntegration.java
> >    testSearchRate()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestV2Request.java
> >    testCloudSolrClient()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > TestV2Request.java
> >    testHttpSolrClient()
> >    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> >
> > ---------------------------------------------------------------------
> > 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
>
> --
- Mark
about.me/markrmiller

Re: BadApple candidates

Posted by Yonik Seeley <ys...@gmail.com>.
I don't know what happened with TestStressRecovery, but IIRC it was
not a flakey test and should have a 100% pass rate. This suggests a
recent change introducing a bug (and demonstrates why historical pass
rate is so important).  It feels like rather than sweeping these under
the rug, a JIRA should be opened specific to the issue?

-Yonik


On Mon, May 21, 2018 at 11:00 AM, Erick Erickson
<er...@gmail.com> wrote:
> I'm going to change how I collect the badapple candidates. After
> getting a little
> overwhelmed by the number of failure e-mails (even ignoring the ones with
> BadApple enabled), "It come to me in a vision! In a flash!"" (points if you
> know where that comes from, hint: Old music involving a pickle).
>
> Since I collect failures for a week then run filter them by what's
> also in Hoss's
> results from two  weeks ago, that's really equivalent to creating the candidate
> list from the intersection of the most recent week of Hoss's results and the
> results from _three_ weeks ago. Much faster too. Thanks Hoss!
>
> So that's what I'll do going forward.
>
> Meanwhile, here's the list for this Thursday.
>
> BadApple candidates: I'll BadApple these on Thursday unless there are objections
>   org.apache.lucene.search.TestLRUQueryCache.testBulkScorerLocking
>    org.apache.solr.TestDistributedSearch.test
>    org.apache.solr.cloud.AddReplicaTest.test
>    org.apache.solr.cloud.AssignBackwardCompatibilityTest.test
>    org.apache.solr.cloud.CreateRoutedAliasTest.testCollectionNamesMustBeAbsent
>    org.apache.solr.cloud.CreateRoutedAliasTest.testTimezoneAbsoluteDate
>    org.apache.solr.cloud.CreateRoutedAliasTest.testV1
>    org.apache.solr.cloud.CreateRoutedAliasTest.testV2
>    org.apache.solr.cloud.DeleteReplicaTest.raceConditionOnDeleteAndRegisterReplica
>    org.apache.solr.cloud.LIRRollingUpdatesTest.testNewReplicaOldLeader
>    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.basicTest
>    org.apache.solr.cloud.LeaderVoteWaitTimeoutTest.testMostInSyncReplicasCanWinElection
>    org.apache.solr.cloud.MoveReplicaHDFSTest.testFailedMove
>    org.apache.solr.cloud.RestartWhileUpdatingTest.test
>    org.apache.solr.cloud.TestCloudConsistency.testOutOfSyncReplicasCannotBecomeLeader
>    org.apache.solr.cloud.TestPullReplica.testCreateDelete
>    org.apache.solr.cloud.TestPullReplica.testKillLeader
>    org.apache.solr.cloud.TestSolrCloudWithKerberosAlt.testBasics
>    org.apache.solr.cloud.UnloadDistributedZkTest.test
>    org.apache.solr.cloud.api.collections.CollectionsAPIAsyncDistributedZkTest.testAsyncRequests
>    org.apache.solr.cloud.api.collections.CustomCollectionTest.testCustomCollectionsAPI
>    org.apache.solr.cloud.autoscaling.ComputePlanActionTest.testNodeLost
>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testMergeIntegration
>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testSplitIntegration
>    org.apache.solr.cloud.autoscaling.IndexSizeTriggerTest.testTrigger
>    org.apache.solr.cloud.autoscaling.NodeAddedTriggerTest.testRestoreState
>    org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testBelowSearchRate
>    org.apache.solr.cloud.autoscaling.SearchRateTriggerIntegrationTest.testDeleteNode
>    org.apache.solr.cloud.autoscaling.SearchRateTriggerTest.testTrigger
>    org.apache.solr.cloud.hdfs.HdfsUnloadDistributedZkTest.test
>    org.apache.solr.cloud.hdfs.StressHdfsTest.test
>    org.apache.solr.handler.TestSQLHandler.doTest
>    org.apache.solr.security.BasicAuthIntegrationTest.testBasicAuth
>    org.apache.solr.uninverting.TestDocTermOrds.testTriggerUnInvertLimit
>    org.apache.solr.update.TestHdfsUpdateLog.testFSThreadSafety
>    org.apache.solr.update.TestInPlaceUpdatesDistrib.test
>
>
> Number of AwaitsFix: 21 Number of BadApples: 99
>
> *****************AwaitsFix Annotations:
>
>
> ************Lucene AwaitsFix
> GeoPolygonTest.java
>    testLUCENE8276_case3()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8276")
>
> GeoPolygonTest.java
>    testLUCENE8280()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8280")
>
> GeoPolygonTest.java
>    testLUCENE8281()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>
> RandomGeoPolygonTest.java
>    testCompareBigPolygons()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>
> RandomGeoPolygonTest.java
>    testCompareSmallPolygons()
>    //@AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8281")
>
> TestControlledRealTimeReopenThread.java
>    testCRTReopen()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5737")
>
> TestICUNormalizer2CharFilter.java
>    testRandomStrings()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-5595")
>
> TestICUTokenizerCJK.java
>    TestICUTokenizerCJK suite
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/LUCENE-8222")
>
> TestMoreLikeThis.java
>    testMultiFieldShouldReturnPerFieldBooleanQuery()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-7161")
>
> UIMABaseAnalyzerTest.java
>    testRandomStrings()
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
> UIMABaseAnalyzerTest.java
>    testRandomStringsWithConfigurationParameters()
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
> UIMATypeAwareAnalyzerTest.java
>    testRandomStrings()
>    @Test @AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/LUCENE-3869")
>
>
>     ************Solr AwaitsFix
> ReplaceNodeNoTargetTest.java
>    ReplaceNodeNoTargetTest suite
>    @LuceneTestCase.AwaitsFix(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-11067")
>
> TestCollapseQParserPlugin.java
>    testStringCollapse()
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/SOLR-11974")
>
> TestImpersonationWithHadoopAuth.java
>    testForwarding()
>    @AwaitsFix(bugUrl="https://issues.apache.org/jira/browse/HADOOP-9893")
>
> TestLTRReRankingPipeline.java
>    testDifferentTopN()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11134")
>
> TestMinMaxOnMultiValuedField.java
>    testDoubleFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
> TestMinMaxOnMultiValuedField.java
>    testFloatFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
> TestMinMaxOnMultiValuedField.java
>    testIntFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
> TestMinMaxOnMultiValuedField.java
>    testLongFieldCache()
>    @AwaitsFix(bugUrl = "https://issues.apache.org/jira/browse/LUCENE-6709")
>
>
>
> *****************BadApple Annotations:
>
> ************Lucene BadApple
>
>     ************Solr BadApple
> AddReplicaTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> AliasIntegrationTest.java
>    testModifyPropertiesCAR()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AliasIntegrationTest.java
>    testModifyPropertiesV1()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> AliasIntegrationTest.java
>    testProperties()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoAddReplicasIntegrationTest.java
>    testSimple()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoAddReplicasPlanActionTest.java
>    testSimple()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoScalingHandlerTest.java
>    testReadApi()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> AutoscalingHistoryHandlerTest.java
>    testHistory()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CdcrBootstrapTest.java
>    testBootstrapWithContinousIndexingOnSourceCluster()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> CdcrReplicationDistributedZkTest.java
>    CdcrReplicationDistributedZkTest suite
>    @BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10107")
>
> ChaosMonkeyNothingIsSafeTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> ChaosMonkeySafeLeaderTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ChaosMonkeySafeLeaderWithPullReplicasTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> CollectionsAPIDistributedZkTest.java
>    testCollectionsAPI()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ComputePlanActionTest.java
>    testSelectedCollections()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testCollectionNamesMustBeAbsent()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testTimezoneAbsoluteDate()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testV1()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> CreateRoutedAliasTest.java
>    testV2()
>    //@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> DeleteReplicaTest.java
>    deleteReplicaOnIndexing()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> DocValuesNotIndexedTest.java
>    testGroupingDVOnly()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> DocValuesNotIndexedTest.java
>    testGroupingDocAbsent()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> DocValuesNotIndexedTest.java
>    testGroupingSorting()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> ForceLeaderTest.java
>    testReplicasInLIRNoLeader()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ForceLeaderTest.java
>    testReplicasInLowerTerms()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsBasicDistributedZk2Test.java
>    HdfsBasicDistributedZk2Test suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> HdfsChaosMonkeyNothingIsSafeTest.java
>    HdfsChaosMonkeyNothingIsSafeTest suite
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028,
> https://issues.apache.org/jira/browse/SOLR-10191")
>
> HdfsDirectoryTest.java
>    testEOF()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsRecoveryZkTest.java
>    HdfsRecoveryZkTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HdfsRestartWhileUpdatingTest.java
>    HdfsRestartWhileUpdatingTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> HdfsTlogReplayBufferedWhileIndexingTest.java
>    HdfsTlogReplayBufferedWhileIndexingTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> HttpPartitionTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> LIRRollingUpdatesTest.java
>    testNewLeaderAndMixedReplicas()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LIRRollingUpdatesTest.java
>    testNewLeaderOldReplica()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LIRRollingUpdatesTest.java
>    testOldLeaderAndMixedReplicas()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LeaderElectionIntegrationTest.java
>    testSimpleSliceLeaderElection()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> LeaderFailoverAfterPartitionTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> LegacyCloudClusterPropTest.java
>    testCreateCollectionSwitchLegacyCloud()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MathExpressionTest.java
>    testDistributions()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MathExpressionTest.java
>    testGammaDistribution()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> MathExpressionTest.java
>    testMultiVariateNormalDistribution()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> MissingSegmentRecoveryTest.java
>    testLeaderRecovery()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MoveReplicaHDFSTest.java
>    testNormalFailedMove()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> MoveReplicaHDFSTest.java
>    testNormalMove()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> MoveReplicaTest.java
>    testFailedMove()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018 This JIRA is fixed, but this test still fails
>
> MultiThreadedOCPTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> NodeLostTriggerTest.java
>    testListenerAcceptance()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
>
> OverseerRolesTest.java
>    testOverseerRole()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> PeerSyncReplicationTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ReplaceNodeNoTargetTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ReplicationFactorTest.java
>    ReplicationFactorTest suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6944")
>
> RestartWhileUpdatingTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> SSLMigrationTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> ScheduledMaintenanceTriggerTest.java
>    testInactiveShardCleanup()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> ScheduledTriggerIntegrationTest.java
>    ScheduledTriggerIntegrationTest suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> ScheduledTriggerTest.java
>    testTrigger()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> ShardSplitTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ShardSplitTest.java
>    testSplitAfterFailedSplit()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ShardSplitTest.java
>    testSplitWithChaosMonkey()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> SharedFSAutoReplicaFailoverTest.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> SolrCloudExampleTest.java
>    testLoadDocsIntoGettingStartedCollection()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestAuthenticationFramework.java
>    testBasics()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestCloudRecovery.java
>    leaderRecoverFromLogOnStartupTest()
>    // Removed BadApple on 18-May-2018
>
> TestCloudSchemaless.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestCollectionStateWatchers.java
>    testDeletionsTriggerWatches()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestCollectionsAPIViaSolrCloudCluster.java
>    testCollectionCreateSearchDelete()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestCollectionsAPIViaSolrCloudCluster.java
>    testCollectionCreateWithoutCoresThenDelete()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestDistributedSearch.java
>    test()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestDynamicLoading.java
>    testDynamicLoading()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestGenericDistributedQueue.java
>    TestGenericDistributedQueue suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestHdfsCloudBackupRestore.java
>    TestHdfsCloudBackupRestore suite
>    @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestLargeCluster.java
>    TestLargeCluster suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-12075")
>
> TestLargeCluster.java
>    testSearchRate()
>    @BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-11714")
>
> TestLeaderElectionZkExpiry.java
>    testLeaderElectionWithZkExpiry()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 17-Mar-2018
>
> TestLeaderInitiatedRecoveryThread.java
>    testPublishDownState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestManagedResourceStorage.java
>    TestManagedResourceStorage suite
>    @LuceneTestCase.BadApple(bugUrl =
> "https://issues.apache.org/jira/browse/SOLR-6443")
>
> TestPrepRecovery.java
>    testLeaderNotResponding()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPrepRecovery.java
>    testLeaderUnloaded()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPullReplica.java
>    testAddDocs()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestPullReplica.java
>    testKillLeader()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestReplicationHandler.java
>    doTestIndexAndConfigAliasReplication()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestSegmentSorting.java
>    testAtomicUpdateOfSegmentSortField()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestSegmentSorting.java
>    testSegmentTerminateEarly()
>    @Test@BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressCloudBlindAtomicUpdates.java
>    test_dv()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressCloudBlindAtomicUpdates.java
>    test_dv_stored()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestStressInPlaceUpdates.java
>    stressTest()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestStressRecovery.java
>    testStressRecovery()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 04-May-2018
>
> TestTlogReplica.java
>    testOnlyLeaderIndexes()
>    // Removed BadApple on 2018-05-21
>
> TestTriggerIntegration.java
>    testCooldown()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testEventFromRestoredState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> //2018-03-10
>
> TestTriggerIntegration.java
>    testEventQueue()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 16-Apr-2018
>
> TestTriggerIntegration.java
>    testListeners()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testNodeAddedTriggerRestoreState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 09-Apr-2018
>
> TestTriggerIntegration.java
>    testNodeLostTrigger()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
> // 26-Mar-2018
>
> TestTriggerIntegration.java
>    testNodeLostTriggerRestoreState()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testNodeMarkersRegistration()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestTriggerIntegration.java
>    testSearchRate()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestV2Request.java
>    testCloudSolrClient()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> TestV2Request.java
>    testHttpSolrClient()
>    @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028")
>
> ---------------------------------------------------------------------
> 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