From commits-return-102028-archive-asf-public=cust-asf.ponee.io@lucene.apache.org Thu Jul 5 22:47:57 2018 Return-Path: X-Original-To: archive-asf-public@cust-asf.ponee.io Delivered-To: archive-asf-public@cust-asf.ponee.io Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by mx-eu-01.ponee.io (Postfix) with SMTP id E5A5D180657 for ; Thu, 5 Jul 2018 22:47:56 +0200 (CEST) Received: (qmail 52231 invoked by uid 500); 5 Jul 2018 20:47:56 -0000 Mailing-List: contact commits-help@lucene.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@lucene.apache.org Delivered-To: mailing list commits@lucene.apache.org Received: (qmail 52222 invoked by uid 99); 5 Jul 2018 20:47:56 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Thu, 05 Jul 2018 20:47:55 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id D8386DFB1C; Thu, 5 Jul 2018 20:47:55 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: erick@apache.org To: commits@lucene.apache.org Message-Id: <5507d490f5e3438484894e566dea79d9@git.apache.org> X-Mailer: ASF-Git Admin Mailer Subject: lucene-solr:master: SOLR-12028: BadApple and AwaitsFix annotations usage Date: Thu, 5 Jul 2018 20:47:55 +0000 (UTC) Repository: lucene-solr Updated Branches: refs/heads/master 302df4dbf -> a09f3facf SOLR-12028: BadApple and AwaitsFix annotations usage Project: http://git-wip-us.apache.org/repos/asf/lucene-solr/repo Commit: http://git-wip-us.apache.org/repos/asf/lucene-solr/commit/a09f3fac Tree: http://git-wip-us.apache.org/repos/asf/lucene-solr/tree/a09f3fac Diff: http://git-wip-us.apache.org/repos/asf/lucene-solr/diff/a09f3fac Branch: refs/heads/master Commit: a09f3facfc5d9d096661a2c45458fc5b55a07819 Parents: 302df4d Author: Erick Erickson Authored: Thu Jul 5 13:47:51 2018 -0700 Committer: Erick Erickson Committed: Thu Jul 5 13:47:51 2018 -0700 ---------------------------------------------------------------------- .../src/test/org/apache/solr/TestDistributedSearch.java | 2 +- .../apache/solr/cloud/AssignBackwardCompatibilityTest.java | 2 +- .../org/apache/solr/cloud/ChaosMonkeyNothingIsSafeTest.java | 2 +- .../test/org/apache/solr/cloud/SaslZkACLProviderTest.java | 1 + .../apache/solr/cloud/api/collections/ShardSplitTest.java | 2 +- .../cloud/api/collections/TestHdfsCloudBackupRestore.java | 3 +-- .../apache/solr/cloud/autoscaling/IndexSizeTriggerTest.java | 7 +++++-- .../apache/solr/cloud/autoscaling/sim/TestLargeCluster.java | 2 +- .../solr/cloud/autoscaling/sim/TestSimDistributedQueue.java | 1 + .../solr/cloud/cdcr/CdcrReplicationDistributedZkTest.java | 9 +++++++++ 10 files changed, 22 insertions(+), 9 deletions(-) ---------------------------------------------------------------------- http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/TestDistributedSearch.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/TestDistributedSearch.java b/solr/core/src/test/org/apache/solr/TestDistributedSearch.java index d4ad79d..8a29db6 100644 --- a/solr/core/src/test/org/apache/solr/TestDistributedSearch.java +++ b/solr/core/src/test/org/apache/solr/TestDistributedSearch.java @@ -108,7 +108,7 @@ public class TestDistributedSearch extends BaseDistributedSearchTestCase { } @Test - @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 09-Apr-2018 + //05-Jul-2018 @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 09-Apr-2018 public void test() throws Exception { QueryResponse rsp = null; int backupStress = stress; // make a copy so we can restore http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java b/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java index 534aeb8..74cf252 100644 --- a/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java +++ b/solr/core/src/test/org/apache/solr/cloud/AssignBackwardCompatibilityTest.java @@ -56,7 +56,7 @@ public class AssignBackwardCompatibilityTest extends SolrCloudTestCase { } @Test - @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 21-May-2018 + //05-Jul-2018 @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 21-May-2018 public void test() throws IOException, SolrServerException, KeeperException, InterruptedException { Set coreNames = new HashSet<>(); Set coreNodeNames = new HashSet<>(); http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/ChaosMonkeyNothingIsSafeTest.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/ChaosMonkeyNothingIsSafeTest.java b/solr/core/src/test/org/apache/solr/cloud/ChaosMonkeyNothingIsSafeTest.java index c14e0bc..b40870c 100644 --- a/solr/core/src/test/org/apache/solr/cloud/ChaosMonkeyNothingIsSafeTest.java +++ b/solr/core/src/test/org/apache/solr/cloud/ChaosMonkeyNothingIsSafeTest.java @@ -112,7 +112,7 @@ public class ChaosMonkeyNothingIsSafeTest extends AbstractFullDistribZkTestBase } @Test - @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 09-Apr-2018 + //05-Jul-2018 @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 09-Apr-2018 public void test() throws Exception { // None of the operations used here are particularly costly, so this should work. // Using this low timeout will also help us catch index stalling. http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/SaslZkACLProviderTest.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/SaslZkACLProviderTest.java b/solr/core/src/test/org/apache/solr/cloud/SaslZkACLProviderTest.java index 16b67a3..b5b5d17 100644 --- a/solr/core/src/test/org/apache/solr/cloud/SaslZkACLProviderTest.java +++ b/solr/core/src/test/org/apache/solr/cloud/SaslZkACLProviderTest.java @@ -114,6 +114,7 @@ public class SaslZkACLProviderTest extends SolrTestCaseJ4 { } @Test + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testSaslZkACLProvider() throws Exception { // Test with Sasl enabled SolrZkClient zkClient = new SolrZkClientWithACLs(zkServer.getZkAddress(), AbstractZkTestCase.TIMEOUT); http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/api/collections/ShardSplitTest.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/api/collections/ShardSplitTest.java b/solr/core/src/test/org/apache/solr/cloud/api/collections/ShardSplitTest.java index 4411bc4..92fd4d5 100644 --- a/solr/core/src/test/org/apache/solr/cloud/api/collections/ShardSplitTest.java +++ b/solr/core/src/test/org/apache/solr/cloud/api/collections/ShardSplitTest.java @@ -259,7 +259,7 @@ public class ShardSplitTest extends BasicDistributedZkTest { * See SOLR-9439 */ @Test - @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") + //05-Jul-2018 @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") public void testSplitAfterFailedSplit() throws Exception { waitForThingsToLevelOut(15); http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/api/collections/TestHdfsCloudBackupRestore.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/api/collections/TestHdfsCloudBackupRestore.java b/solr/core/src/test/org/apache/solr/cloud/api/collections/TestHdfsCloudBackupRestore.java index 1b2ed4c..9029cc1 100644 --- a/solr/core/src/test/org/apache/solr/cloud/api/collections/TestHdfsCloudBackupRestore.java +++ b/solr/core/src/test/org/apache/solr/cloud/api/collections/TestHdfsCloudBackupRestore.java @@ -33,7 +33,6 @@ import org.apache.hadoop.fs.FileSystem; import org.apache.hadoop.hdfs.DistributedFileSystem; import org.apache.hadoop.hdfs.MiniDFSCluster; import org.apache.hadoop.hdfs.protocol.HdfsConstants.SafeModeAction; -import org.apache.lucene.util.LuceneTestCase; import org.apache.solr.client.solrj.impl.CloudSolrClient; import org.apache.solr.client.solrj.request.CollectionAdminRequest; import org.apache.solr.cloud.hdfs.HdfsTestUtil; @@ -61,7 +60,7 @@ import static org.apache.solr.core.backup.BackupManager.ZK_STATE_DIR; @ThreadLeakFilters(defaultFilters = true, filters = { BadHdfsThreadsFilter.class // hdfs currently leaks thread(s) }) -@LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 04-May-2018 +//05-Jul-2018 @LuceneTestCase.BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 04-May-2018 public class TestHdfsCloudBackupRestore extends AbstractCloudBackupRestoreTestCase { public static final String SOLR_XML = "\n" + "\n" + http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/autoscaling/IndexSizeTriggerTest.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/IndexSizeTriggerTest.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/IndexSizeTriggerTest.java index 00e1b31..daf9867 100644 --- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/IndexSizeTriggerTest.java +++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/IndexSizeTriggerTest.java @@ -30,7 +30,6 @@ import java.util.concurrent.TimeUnit; import java.util.concurrent.atomic.AtomicBoolean; import java.util.concurrent.atomic.AtomicReference; -import org.apache.lucene.util.LuceneTestCase; import org.apache.lucene.util.TestUtil; import org.apache.solr.client.solrj.SolrClient; import org.apache.solr.client.solrj.SolrRequest; @@ -68,7 +67,7 @@ import static org.apache.solr.common.cloud.ZkStateReader.SOLR_AUTOSCALING_CONF_P * */ @LogLevel("org.apache.solr.cloud.autoscaling=DEBUG") -@LuceneTestCase.BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-12392") +//05-Jul-2018 @LuceneTestCase.BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-12392") public class IndexSizeTriggerTest extends SolrCloudTestCase { private static final Logger log = LoggerFactory.getLogger(MethodHandles.lookup().lookupClass()); @@ -138,6 +137,7 @@ public class IndexSizeTriggerTest extends SolrCloudTestCase { } @Test + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testTrigger() throws Exception { String collectionName = "testTrigger_collection"; CollectionAdminRequest.Create create = CollectionAdminRequest.createCollection(collectionName, @@ -235,6 +235,7 @@ public class IndexSizeTriggerTest extends SolrCloudTestCase { } @Test + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testSplitIntegration() throws Exception { String collectionName = "testSplitIntegration_collection"; CollectionAdminRequest.Create create = CollectionAdminRequest.createCollection(collectionName, @@ -347,6 +348,7 @@ public class IndexSizeTriggerTest extends SolrCloudTestCase { } @Test + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testMergeIntegration() throws Exception { String collectionName = "testMergeIntegration_collection"; CollectionAdminRequest.Create create = CollectionAdminRequest.createCollection(collectionName, @@ -456,6 +458,7 @@ public class IndexSizeTriggerTest extends SolrCloudTestCase { } @Test + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testMixedBounds() throws Exception { // if (cloudManager instanceof SimCloudManager) { // log.warn("Requires SOLR-12208"); http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestLargeCluster.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestLargeCluster.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestLargeCluster.java index a6b6743..2b7acd2 100644 --- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestLargeCluster.java +++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestLargeCluster.java @@ -76,7 +76,7 @@ import static org.apache.solr.cloud.autoscaling.AutoScalingHandlerTest.createAut @TimeoutSuite(millis = 4 * 3600 * 1000) @LogLevel("org.apache.solr.cloud.autoscaling=DEBUG") @ThreadLeakLingering(linger = 20000) // ComputePlanAction may take significant time to complete -@LuceneTestCase.BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-12075") +//05-Jul-2018 @LuceneTestCase.BadApple(bugUrl = "https://issues.apache.org/jira/browse/SOLR-12075") public class TestLargeCluster extends SimSolrCloudTestCase { private static final Logger log = LoggerFactory.getLogger(MethodHandles.lookup().lookupClass()); http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimDistributedQueue.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimDistributedQueue.java b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimDistributedQueue.java index 1c41795..35dc1fa 100644 --- a/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimDistributedQueue.java +++ b/solr/core/src/test/org/apache/solr/cloud/autoscaling/sim/TestSimDistributedQueue.java @@ -39,6 +39,7 @@ public class TestSimDistributedQueue extends SolrTestCaseJ4 { protected ExecutorService executor = ExecutorUtil.newMDCAwareSingleThreadExecutor(new SolrjNamedThreadFactory("sdqtest-")); @Test + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testDistributedQueue() throws Exception { String dqZNode = "/distqueue/test1"; byte[] data = "hello world".getBytes(UTF8); http://git-wip-us.apache.org/repos/asf/lucene-solr/blob/a09f3fac/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrReplicationDistributedZkTest.java ---------------------------------------------------------------------- diff --git a/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrReplicationDistributedZkTest.java b/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrReplicationDistributedZkTest.java index a1e2604..82da287 100644 --- a/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrReplicationDistributedZkTest.java +++ b/solr/core/src/test/org/apache/solr/cloud/cdcr/CdcrReplicationDistributedZkTest.java @@ -149,6 +149,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testReplicationStartStop() throws Exception { int start = 0; List docs = new ArrayList<>(); @@ -209,6 +210,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testReplicationAfterRestart() throws Exception { log.info("Starting CDCR"); @@ -279,6 +281,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testReplicationAfterLeaderChange() throws Exception { log.info("Starting CDCR"); @@ -362,6 +365,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testUpdateLogSynchronisation() throws Exception { this.invokeCdcrAction(shardToLeaderJetty.get(SOURCE_COLLECTION).get(SHARD1), CdcrParams.CdcrAction.START); this.waitForCdcrStateReplication(SOURCE_COLLECTION); @@ -412,6 +416,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testBufferOnNonLeader() throws Exception { // buffering is enabled by default, so disable it this.invokeCdcrAction(shardToLeaderJetty.get(SOURCE_COLLECTION).get(SHARD1), CdcrParams.CdcrAction.DISABLEBUFFER); @@ -449,6 +454,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testOps() throws Exception { // Index documents List docs = new ArrayList<>(); @@ -482,6 +488,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testBatchAddsWithDelete() throws Exception { // Index 50 documents int start = 0; @@ -539,6 +546,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testBatchBoundaries() throws Exception { this.invokeCdcrAction(shardToLeaderJetty.get(SOURCE_COLLECTION).get(SHARD1), CdcrParams.CdcrAction.START); this.waitForCdcrStateReplication(SOURCE_COLLECTION); @@ -570,6 +578,7 @@ public class CdcrReplicationDistributedZkTest extends BaseCdcrDistributedZkTest */ @Test @ShardsFixed(num = 4) + @BadApple(bugUrl="https://issues.apache.org/jira/browse/SOLR-12028") // 05-Jul-2018 public void testResilienceWithDeleteByQueryOnTarget() throws Exception { // Index 50 documents int start = 0;