Skip to content

Commit

Permalink
[#22238] DocDB: Disabling consistently failing tests on macOS
Browse files Browse the repository at this point in the history
Summary:
The following tests are failing consistently on macOS for a variety of reasons. We want to disable these until they can be stabilized to reduce wasted machine resources.

SnapshotTxnTest.BankAccountsDelayAddLeaderPending/0
CDCServiceTest.TestGetChangesWithDeadline
XClusterTopologiesTestClusterFailure.TestBroadcastWithConsumerFailure
XClusterTabletSplitITest.SplittingWithXClusterReplicationOnConsumer
XClusterTabletSplitITest.SplittingOnProducerAndConsumer
FailOnConflict/SnapshotTxnTest.BankAccountsDelayAddLeaderPending/0
XClusterAutomaticTabletSplitITest.AutomaticTabletSplitting
TestRpcSecureCompression.CantAllocateReadBuffer
BackgroundTaskTest.RunsTaskOnInterval
PgSingleTServerTest.HybridTimeFilterDuringConflictResolution
MasterPathHandlersItest.ShowDeletedTablets
TestRpc.TestConnectionKeepalive
CreateTableStressTest.TestHeartbeatDeadline
CompactionTestWithTTL.CompactionAfterExpiry
MasterPathHandlersItest.TestTableJsonEndpointValidTableName
DebugUtilTest.TestGetStackTraceWhileCreatingThreads
KVTableTest.BigValues
MasterPathHandlersItest.TestTableJsonEndpointValidTableId
Jira: DB-11158

Test Plan: Jenkins: build platform: mac

Reviewers: xCluster, hsunder

Reviewed By: hsunder

Subscribers: yql, ybase

Differential Revision: https://phorge.dev.yugabyte.com/D34694
  • Loading branch information
lingamsandeep committed May 3, 2024
1 parent 1626058 commit c2b8a40
Show file tree
Hide file tree
Showing 12 changed files with 31 additions and 25 deletions.
2 changes: 1 addition & 1 deletion src/yb/client/snapshot-txn-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -430,7 +430,7 @@ TEST_P(SnapshotTxnTest, BankAccountsDelayCreate) {
0.0 /* select_update_probability */);
}

TEST_P(SnapshotTxnTest, BankAccountsDelayAddLeaderPending) {
TEST_P(SnapshotTxnTest, YB_DISABLE_TEST_ON_MACOS(BankAccountsDelayAddLeaderPending)) {
ANNOTATE_UNPROTECTED_WRITE(FLAGS_TEST_disallow_lmp_failures) = true;
ANNOTATE_UNPROTECTED_WRITE(FLAGS_enable_multi_raft_heartbeat_batcher) = false;
ANNOTATE_UNPROTECTED_WRITE(FLAGS_TEST_inject_mvcc_delay_add_leader_pending_ms) = 20;
Expand Down
2 changes: 1 addition & 1 deletion src/yb/integration-tests/cdc_service-int-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -906,7 +906,7 @@ TEST_F(CDCServiceTest, TestGetChanges) {
VerifyStreamDeletedFromCdcState(client_.get(), stream_id_, tablet_id);
}

TEST_F(CDCServiceTest, TestGetChangesWithDeadline) {
TEST_F(CDCServiceTest, YB_DISABLE_TEST_ON_MACOS(TestGetChangesWithDeadline)) {
ANNOTATE_UNPROTECTED_WRITE(FLAGS_cdc_populate_end_markers_transactions) = false;
docdb::DisableYcqlPackedRow();
stream_id_ = ASSERT_RESULT(CreateCDCStream(cdc_proxy_, table_.table()->id()));
Expand Down
4 changes: 2 additions & 2 deletions src/yb/integration-tests/compaction-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -645,7 +645,7 @@ TEST_F(CompactionTest, FilesOverMaxSizeWithTableTTLStillGetManualCompacted) {
}
}

TEST_F(CompactionTest, MaxFileSizeIgnoredIfNoTableTTL) {
TEST_F(CompactionTest, YB_DISABLE_TEST_ON_MACOS(MaxFileSizeIgnoredIfNoTableTTL)) {
const int kNumFilesToWrite = 10;
// Auto compactions will be triggered every kNumFilesToWrite files written.
ANNOTATE_UNPROTECTED_WRITE(FLAGS_rocksdb_level0_file_num_compaction_trigger) = kNumFilesToWrite;
Expand Down Expand Up @@ -1185,7 +1185,7 @@ class CompactionTestWithTTL : public CompactionTest {
const int kTTLSec = 1;
};

TEST_F(CompactionTestWithTTL, CompactionAfterExpiry) {
TEST_F(CompactionTestWithTTL, YB_DISABLE_TEST_ON_MACOS(CompactionAfterExpiry)) {
ANNOTATE_UNPROTECTED_WRITE(FLAGS_timestamp_history_retention_interval_sec) = 0;
ANNOTATE_UNPROTECTED_WRITE(FLAGS_rocksdb_level0_file_num_compaction_trigger) = 10;
// Testing compaction without compaction file filtering for TTL expiration.
Expand Down
2 changes: 1 addition & 1 deletion src/yb/integration-tests/create-table-stress-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -443,7 +443,7 @@ TEST_F(CreateSmallHBTableStressTest, TestRestartMasterDuringFullHeartbeat) {
}
}

TEST_F(CreateTableStressTest, TestHeartbeatDeadline) {
TEST_F(CreateTableStressTest, YB_DISABLE_TEST_ON_MACOS(TestHeartbeatDeadline)) {
DontVerifyClusterBeforeNextTearDown();

// 500ms deadline / 50 ms wait ~= 10 Tablets processed before Master hits deadline
Expand Down
2 changes: 1 addition & 1 deletion src/yb/integration-tests/kv_table-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -209,7 +209,7 @@ class KVTableSingleTabletTest : public KVTableTest {
// after this tservers joined raft group again.
//
// Also check that we track such operations.
TEST_F_EX(KVTableTest, BigValues, KVTableSingleTabletTest) {
TEST_F_EX(KVTableTest, YB_DISABLE_TEST_ON_MACOS(BigValues), KVTableSingleTabletTest) {
std::atomic_bool stop_requested_flag(false);
SetFlagOnExit set_flag_on_exit(&stop_requested_flag);
int rows = 100;
Expand Down
12 changes: 7 additions & 5 deletions src/yb/integration-tests/master_path_handlers-itest.cc
Original file line number Diff line number Diff line change
Expand Up @@ -441,7 +441,7 @@ void verifyTestTableTablets(const rapidjson::Value* json_obj) {
}
}

TEST_F(MasterPathHandlersItest, TestTableJsonEndpointValidTableId) {
TEST_F(MasterPathHandlersItest, YB_DISABLE_TEST_ON_MACOS(TestTableJsonEndpointValidTableId)) {
auto client = ASSERT_RESULT(cluster_->CreateClient());
ASSERT_OK(client->CreateNamespaceIfNotExists(kKeyspaceName));

Expand Down Expand Up @@ -469,7 +469,7 @@ TEST_F(MasterPathHandlersItest, TestTableJsonEndpointValidTableId) {
verifyTestTableTablets(json_obj);
}

TEST_F(MasterPathHandlersItest, TestTableJsonEndpointValidTableName) {
TEST_F(MasterPathHandlersItest, YB_DISABLE_TEST_ON_MACOS(TestTableJsonEndpointValidTableName)) {
auto client = ASSERT_RESULT(cluster_->CreateClient());
ASSERT_OK(client->CreateNamespaceIfNotExists(kKeyspaceName));

Expand Down Expand Up @@ -503,7 +503,7 @@ TEST_F(MasterPathHandlersItest, TestTableJsonEndpointValidTableName) {
verifyTestTableTablets(json_obj);
}

TEST_F(MasterPathHandlersItest, TestTableJsonEndpointInvalidTableId) {
TEST_F(MasterPathHandlersItest, YB_DISABLE_TEST_ON_MACOS(TestTableJsonEndpointInvalidTableId)) {
auto client = ASSERT_RESULT(cluster_->CreateClient());

// Call endpoint and validate format of response.
Expand Down Expand Up @@ -644,7 +644,8 @@ class TabletSplitMasterPathHandlersItest : public MasterPathHandlersItest {
}
};

TEST_F_EX(MasterPathHandlersItest, ShowDeletedTablets, TabletSplitMasterPathHandlersItest) {
TEST_F_EX(MasterPathHandlersItest, YB_DISABLE_TEST_ON_MACOS(ShowDeletedTablets),
TabletSplitMasterPathHandlersItest) {
CreateTestTable(1 /* num_tablets */);

client::TableHandle table;
Expand Down Expand Up @@ -686,7 +687,8 @@ TEST_F_EX(MasterPathHandlersItest, ShowDeletedTablets, TabletSplitMasterPathHand

// Hidden split parent tablet shouldn't be shown as leaderless.
TEST_F_EX(
MasterPathHandlersItest, TestHiddenSplitParentTablet, TabletSplitMasterPathHandlersItest) {
MasterPathHandlersItest, YB_DISABLE_TEST_ON_MACOS(TestHiddenSplitParentTablet),
TabletSplitMasterPathHandlersItest) {
const auto kLeaderlessTabletAlertDelaySecs = 5;
ANNOTATE_UNPROTECTED_WRITE(FLAGS_leaderless_tablet_alert_delay_secs) =
kLeaderlessTabletAlertDelaySecs;
Expand Down
12 changes: 7 additions & 5 deletions src/yb/integration-tests/xcluster/xcluster-tablet-split-itest.cc
Original file line number Diff line number Diff line change
Expand Up @@ -561,7 +561,8 @@ TEST_P(xClusterTabletMapTest, MoreConsumerTablets) {
RunSetUp(3, 8);
}

TEST_F(XClusterTabletSplitITest, SplittingWithXClusterReplicationOnConsumer) {
TEST_F(XClusterTabletSplitITest,
YB_DISABLE_TEST_ON_MACOS(SplittingWithXClusterReplicationOnConsumer)) {
// Perform a split on the consumer side and ensure replication still works.

// To begin with, cluster_ will be our producer.
Expand All @@ -584,7 +585,8 @@ TEST_F(XClusterTabletSplitITest, SplittingWithXClusterReplicationOnConsumer) {
ASSERT_OK(CheckForNumRowsOnConsumer(2 * kDefaultNumRows));
}

TEST_F(XClusterTabletSplitITest, SplittingWithXClusterReplicationOnProducer) {
TEST_F(XClusterTabletSplitITest,
YB_DISABLE_TEST_ON_MACOS(SplittingWithXClusterReplicationOnProducer)) {
// Perform a split on the producer side and ensure replication still works.

// Default cluster_ will be our producer.
Expand Down Expand Up @@ -664,7 +666,7 @@ TEST_F(XClusterTabletSplitITest, MultipleSplitsInSequence) {
ASSERT_OK(CheckForNumRowsOnConsumer(2 * kDefaultNumRows));
}

TEST_F(XClusterTabletSplitITest, SplittingOnProducerAndConsumer) {
TEST_F(XClusterTabletSplitITest, YB_DISABLE_TEST_ON_MACOS(SplittingOnProducerAndConsumer)) {
// Test splits on both producer and consumer while writes to the producer are happening.

// Default cluster_ will be our producer.
Expand Down Expand Up @@ -1048,7 +1050,7 @@ class XClusterAutomaticTabletSplitITest : public XClusterTabletSplitITest {

// This test is very flaky in TSAN as we spend a long time waiting for children tablets to be
// ready, and will often then time out.
TEST_F(XClusterAutomaticTabletSplitITest, AutomaticTabletSplitting) {
TEST_F(XClusterAutomaticTabletSplitITest, YB_DISABLE_TEST_ON_MACOS(AutomaticTabletSplitting)) {
constexpr auto num_active_tablets = 6;

// Setup a new thread for continuous writing to producer.
Expand Down Expand Up @@ -1210,7 +1212,7 @@ TEST_F(NotSupportedTabletSplitITest, SplittingWithCdcStream) {
ASSERT_RESULT(SplitTabletAndCheckForNotSupported());
}

TEST_F(NotSupportedTabletSplitITest, SplittingWithBootstrappedStream) {
TEST_F(NotSupportedTabletSplitITest, YB_DISABLE_TEST_ON_MACOS(SplittingWithBootstrappedStream)) {
ANNOTATE_UNPROTECTED_WRITE(FLAGS_enable_tablet_split_of_xcluster_replicated_tables) = true;
ANNOTATE_UNPROTECTED_WRITE(FLAGS_enable_tablet_split_of_xcluster_bootstrapping_tables) = false;
// Default cluster_ will be our producer.
Expand Down
6 changes: 4 additions & 2 deletions src/yb/integration-tests/xcluster/xcluster_topologies-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -380,7 +380,8 @@ class XClusterTopologiesTestClusterFailure : public XClusterTopologiesTest {
};

// Testing that 1:N replication still works even when a consumer drops.
TEST_F(XClusterTopologiesTestClusterFailure, TestBroadcastWithConsumerFailure) {
TEST_F(XClusterTopologiesTestClusterFailure,
YB_DISABLE_TEST_ON_MACOS(TestBroadcastWithConsumerFailure)) {
constexpr int kNTabletsPerTable = 3;
constexpr int kNumTables = 3;
uint32_t kReplicationFactor = NonTsanVsTsan(3, 1);
Expand Down Expand Up @@ -416,7 +417,8 @@ TEST_F(XClusterTopologiesTestClusterFailure, TestBroadcastWithConsumerFailure) {
}

// Testing that 1:N replication still works even when a producer drops.
TEST_F(XClusterTopologiesTestClusterFailure, TestBroadcastWithProducerFailure) {
TEST_F(XClusterTopologiesTestClusterFailure,
YB_DISABLE_TEST_ON_MACOS(TestBroadcastWithProducerFailure)) {
constexpr int kNTabletsPerTable = 3;
constexpr int kNumTables = 3;
uint32_t kReplicationFactor = NonTsanVsTsan(3, 1);
Expand Down
8 changes: 4 additions & 4 deletions src/yb/rpc/rpc-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -355,7 +355,7 @@ TEST_F(TestRpc, TestHighFDs) {
}

// Test that connections are kept alive by ScanIdleConnections between calls.
TEST_F(TestRpc, TestConnectionKeepalive) {
TEST_F(TestRpc, YB_DISABLE_TEST_ON_MACOS(TestConnectionKeepalive)) {
google::FlagSaver saver;

// Only run one reactor per messenger, so we can grab the metrics from that
Expand Down Expand Up @@ -541,7 +541,7 @@ TEST_F(TestRpc, TestNegotiationTimeout) {

// Test that client calls get failed properly when the server they're connected to
// shuts down.
TEST_F(TestRpc, TestServerShutsDown) {
TEST_F(TestRpc, YB_DISABLE_TEST_ON_MACOS(TestServerShutsDown)) {
// Set up a simple socket server which accepts a connection.
HostPort server_addr;
Socket listen_sock;
Expand Down Expand Up @@ -1167,7 +1167,7 @@ void TestCantAllocateReadBuffer(CalculatorServiceProxy* proxy) {

} // namespace

TEST_F(TestRpc, CantAllocateReadBuffer) {
TEST_F(TestRpc, YB_DISABLE_TEST_ON_MACOS(CantAllocateReadBuffer)) {
RunPlainTest(&TestCantAllocateReadBuffer, SetupServerForTestCantAllocateReadBuffer());
}

Expand Down Expand Up @@ -1474,7 +1474,7 @@ TEST_F(TestRpcSecureCompression, ConcurrentOps) {
RunSecureCompressionTest(&TestConcurrentOps);
}

TEST_F(TestRpcSecureCompression, CantAllocateReadBuffer) {
TEST_F(TestRpcSecureCompression, YB_DISABLE_TEST_ON_MACOS(CantAllocateReadBuffer)) {
RunSecureCompressionTest(&TestCantAllocateReadBuffer, SetupServerForTestCantAllocateReadBuffer());
}

Expand Down
2 changes: 1 addition & 1 deletion src/yb/util/background_task-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -76,7 +76,7 @@ TEST_F(BackgroundTaskTest, RunsTaskOnWake) {
bg_task->Shutdown();
}

TEST_F(BackgroundTaskTest, RunsTaskOnInterval) {
TEST_F(BackgroundTaskTest, YB_DISABLE_TEST_ON_MACOS(RunsTaskOnInterval)) {
constexpr int kNumTaskRuns = 1000;

auto interval = 10ms * kTimeMultiplier;
Expand Down
2 changes: 1 addition & 1 deletion src/yb/util/debug-util-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -504,7 +504,7 @@ TEST_F(DebugUtilTest, LongOperationTracker) {
}
}

TEST_F(DebugUtilTest, TestGetStackTraceWhileCreatingThreads) {
TEST_F(DebugUtilTest, YB_DISABLE_TEST_ON_MACOS(TestGetStackTraceWhileCreatingThreads)) {
// This test makes sure we can collect stack traces while threads are being created.
// We create 10 threads that create threads in a loop. Then we create 100 threads that collect
// stack traces from the other 10 threads.
Expand Down
2 changes: 1 addition & 1 deletion src/yb/yql/pgwrapper/pg_single_tserver-test.cc
Original file line number Diff line number Diff line change
Expand Up @@ -354,7 +354,7 @@ TEST_F_EX(PgSingleTServerTest, ScanWithPackedRow, PgMiniBigPrefetchTest) {
/* compact= */ false, /* aggregate= */ false);
}

TEST_F_EX(PgSingleTServerTest, HybridTimeFilterDuringConflictResolution,
TEST_F_EX(PgSingleTServerTest, YB_DISABLE_TEST_ON_MACOS(HybridTimeFilterDuringConflictResolution),
PgMiniSmallMemstoreAndCacheTest) {
constexpr int kNumColumns = 10;

Expand Down

0 comments on commit c2b8a40

Please sign in to comment.