Skip to content

Commit

Permalink
tests: rename StartNewTestCluster to StartCluster
Browse files Browse the repository at this point in the history
This follows for symmetry with `StartServer`.

This is a simple search-replace substitution:

`serverutils.StartNewTestCluster` -> `serverutils.StartCluster`

Release note: None
  • Loading branch information
knz committed Aug 14, 2023
1 parent b1db60c commit 05d3fa0
Show file tree
Hide file tree
Showing 88 changed files with 225 additions and 223 deletions.
4 changes: 2 additions & 2 deletions pkg/ccl/backupccl/backupinfo/manifest_handling_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -40,7 +40,7 @@ func TestManifestHandlingIteratorOperations(t *testing.T) {
const changesPerDescriptor = 3

ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{})
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{})
defer tc.Stopper().Stop(ctx)

store, err := cloud.ExternalStorageFromURI(ctx, "userfile:///foo",
Expand Down Expand Up @@ -108,7 +108,7 @@ func TestManifestHandlingEmptyIterators(t *testing.T) {
defer leaktest.AfterTest(t)()

ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{})
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{})
defer tc.Stopper().Stop(ctx)

store, err := cloud.ExternalStorageFromURI(ctx, "userfile:///foo",
Expand Down
6 changes: 3 additions & 3 deletions pkg/ccl/changefeedccl/changefeed_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -5601,7 +5601,7 @@ func TestChangefeedHandlesDrainingNodes(t *testing.T) {
sinkDir, cleanupFn := testutils.TempDir(t)
defer cleanupFn()

tc := serverutils.StartNewTestCluster(t, 4, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 4, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
// Test uses SPLIT AT, which isn't currently supported for
// secondary tenants. Tracked with #76378.
Expand Down Expand Up @@ -5758,7 +5758,7 @@ func TestChangefeedHandlesRollingRestart(t *testing.T) {
}
}

tc := serverutils.StartNewTestCluster(t, numNodes, base.TestClusterArgs{
tc := serverutils.StartCluster(t, numNodes, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
ServerArgsPerNode: func() map[int]base.TestServerArgs {
perNode := make(map[int]base.TestServerArgs)
Expand Down Expand Up @@ -5896,7 +5896,7 @@ func TestChangefeedPropagatesTerminalError(t *testing.T) {
}
}

tc := serverutils.StartNewTestCluster(t, numNodes,
tc := serverutils.StartCluster(t, numNodes,
base.TestClusterArgs{
ServerArgsPerNode: perServerKnobs,
ReplicationMode: base.ReplicationManual,
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/cloudccl/cloudprivilege/privileges_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -34,7 +34,7 @@ func TestURIRequiresAdminOrPrivilege(t *testing.T) {
const nodes = 1

ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, nodes, base.TestClusterArgs{ServerArgs: base.TestServerArgs{
tc := serverutils.StartCluster(t, nodes, base.TestClusterArgs{ServerArgs: base.TestServerArgs{
SQLMemoryPoolSize: 256 << 20,
}})
defer tc.Stopper().Stop(ctx)
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/importerccl/ccl_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -477,7 +477,7 @@ func TestImportInMultiServerTenant(t *testing.T) {
DefaultTestTenant: base.TODOTestTenantDisabled,
ExternalIODir: baseDir,
}
tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{ServerArgs: args})
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{ServerArgs: args})
defer tc.Stopper().Stop(ctx)

// Setup a SQL server on a tenant.
Expand Down
6 changes: 3 additions & 3 deletions pkg/ccl/serverccl/admin_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -48,8 +48,8 @@ func TestAdminAPIDataDistributionPartitioning(t *testing.T) {

// TODO(clust-obs): This test should work with just a single node,
// i.e. using serverutils.StartServer` instead of
// `StartNewTestCluster`.
testCluster := serverutils.StartNewTestCluster(t, 3,
// `StartCluster`.
testCluster := serverutils.StartCluster(t, 3,
base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
// The code below ought to work when this is omitted. This
Expand Down Expand Up @@ -114,7 +114,7 @@ func TestAdminAPIChartCatalog(t *testing.T) {
defer leaktest.AfterTest(t)()
defer log.Scope(t).Close(t)

testCluster := serverutils.StartNewTestCluster(t, 3, base.TestClusterArgs{})
testCluster := serverutils.StartCluster(t, 3, base.TestClusterArgs{})
defer testCluster.Stopper().Stop(context.Background())

firstServer := testCluster.Server(0)
Expand Down
4 changes: 2 additions & 2 deletions pkg/ccl/serverccl/server_controller_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -62,7 +62,7 @@ func TestSharedProcessTenantNodeLocalAccess(t *testing.T) {
}
}()

tc := serverutils.StartNewTestCluster(t, nodeCount, base.TestClusterArgs{
tc := serverutils.StartCluster(t, nodeCount, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
DefaultTestTenant: base.TestControlsTenantsExplicitly,
},
Expand Down Expand Up @@ -391,7 +391,7 @@ func TestServerControllerMultiNodeTenantStartup(t *testing.T) {

t.Logf("starting test cluster")
numNodes := 3
tc := serverutils.StartNewTestCluster(t, numNodes, base.TestClusterArgs{
tc := serverutils.StartCluster(t, numNodes, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
Knobs: base.TestingKnobs{
JobsTestingKnobs: jobs.NewTestingKnobsWithShortIntervals(),
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/serverccl/server_sql_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -72,7 +72,7 @@ func TestTenantCannotSetClusterSetting(t *testing.T) {
defer log.Scope(t).Close(t)
ctx := context.Background()

tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{ServerArgs: base.TestServerArgs{
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{ServerArgs: base.TestServerArgs{
DefaultTestTenant: base.TestControlsTenantsExplicitly,
}})
defer tc.Stopper().Stop(ctx)
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/serverccl/shared_process_tenant_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ func TestSharedProcessTenantNoSpanLimit(t *testing.T) {

ctx := context.Background()

tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
DefaultTestTenant: base.TestControlsTenantsExplicitly,
}})
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/serverccl/statusccl/tenant_grpc_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -35,7 +35,7 @@ func TestTenantGRPCServices(t *testing.T) {

ctx := context.Background()

testCluster := serverutils.StartNewTestCluster(t, 3, base.TestClusterArgs{
testCluster := serverutils.StartCluster(t, 3, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
DefaultTestTenant: base.TestControlsTenantsExplicitly,
},
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/serverccl/statusccl/tenant_status_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -375,7 +375,7 @@ func TestTenantCannotSeeNonTenantStats(t *testing.T) {
defer log.Scope(t).Close(t)

ctx := context.Background()
testCluster := serverutils.StartNewTestCluster(t, 3 /* numNodes */, base.TestClusterArgs{
testCluster := serverutils.StartCluster(t, 3 /* numNodes */, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
Knobs: base.TestingKnobs{
SpanConfig: &spanconfig.TestingKnobs{
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/serverccl/tenant_decommissioned_host_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -40,7 +40,7 @@ func TestTenantWithDecommissionedID(t *testing.T) {
// as sql connection timeouts.

ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{ServerArgs: base.TestServerArgs{
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{ServerArgs: base.TestServerArgs{
DefaultTestTenant: base.TestControlsTenantsExplicitly,
}})
defer tc.Stopper().Stop(ctx)
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/serverccl/tenant_test_utils.go
Original file line number Diff line number Diff line change
Expand Up @@ -143,7 +143,7 @@ func NewTestTenantHelper(
) TenantTestHelper {
t.Helper()

testCluster := serverutils.StartNewTestCluster(t, 1 /* numNodes */, base.TestClusterArgs{
testCluster := serverutils.StartCluster(t, 1 /* numNodes */, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
Knobs: knobs,
DefaultTestTenant: base.TestControlsTenantsExplicitly,
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/sqlproxyccl/tenant/directory_cache_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -654,7 +654,7 @@ func newTestDirectoryCache(
directoryCache tenant.DirectoryCache,
tds *tenantdirsvr.TestDirectoryServer,
) {
tc = serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{
tc = serverutils.StartCluster(t, 1, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
// We need to start the cluster insecure in order to not
// care about TLS settings for the RPC client connection.
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/telemetryccl/telemetry_logging_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -172,7 +172,7 @@ func TestBulkJobTelemetryLogging(t *testing.T) {

dir, dirCleanupFn := testutils.TempDir(t)

testCluster := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{
testCluster := serverutils.StartCluster(t, 1, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
Knobs: base.TestingKnobs{
EventLog: &sql.EventLogTestingKnobs{
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/testccl/sqlccl/run_control_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -39,7 +39,7 @@ type runControlTestCase struct {
func makeRunControlTestCases(t *testing.T) ([]runControlTestCase, func()) {
t.Helper()
testCases := make([]runControlTestCase, 2)
tc := serverutils.StartNewTestCluster(
tc := serverutils.StartCluster(
t, 2 /* numNodes */, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
// Disable the implicit default test tenant so that we can start our own.
Expand Down
2 changes: 1 addition & 1 deletion pkg/ccl/testccl/sqlccl/temp_table_clean_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -92,7 +92,7 @@ func TestTenantTempTableCleanup(t *testing.T) {
},
},
}
tc := serverutils.StartNewTestCluster(
tc := serverutils.StartCluster(
t, 3 /* numNodes */, base.TestClusterArgs{ReplicationMode: base.ReplicationManual,
ServerArgs: base.TestServerArgs{
// Disable the default test tenant so that we can start it.
Expand Down
2 changes: 1 addition & 1 deletion pkg/cli/zip_table_registry_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -161,7 +161,7 @@ func TestCustomQuery(t *testing.T) {
defer leaktest.AfterTest(t)()
defer log.Scope(t).Close(t)

cluster := serverutils.StartNewTestCluster(t, 3 /* numNodes */, base.TestClusterArgs{
cluster := serverutils.StartCluster(t, 3 /* numNodes */, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{},
})
defer cluster.Stopper().Stop(context.Background())
Expand Down
4 changes: 2 additions & 2 deletions pkg/kv/kvserver/client_lease_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -1481,7 +1481,7 @@ func TestLeaseTransfersUseExpirationLeasesAndBumpToEpochBasedOnes(t *testing.T)
kvserver.ExpirationLeasesOnly.Override(ctx, &st.SV, false) // override metamorphism

manualClock := hlc.NewHybridManualClock()
tci := serverutils.StartNewTestCluster(t, 2, base.TestClusterArgs{
tci := serverutils.StartCluster(t, 2, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
ServerArgs: base.TestServerArgs{
Settings: st,
Expand Down Expand Up @@ -1552,7 +1552,7 @@ func TestLeaseUpgradeVersionGate(t *testing.T) {
)
kvserver.ExpirationLeasesOnly.Override(ctx, &st.SV, false) // override metamorphism

tci := serverutils.StartNewTestCluster(t, 2, base.TestClusterArgs{
tci := serverutils.StartCluster(t, 2, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
ServerArgs: base.TestServerArgs{
Settings: st,
Expand Down
2 changes: 1 addition & 1 deletion pkg/kv/kvserver/client_merge_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -5131,7 +5131,7 @@ func setupClusterWithSubsumedRange(
},
},
}
tc = serverutils.StartNewTestCluster(t, numNodes, clusterArgs)
tc = serverutils.StartCluster(t, numNodes, clusterArgs)
scratch := tc.ScratchRange(t)
ts := tc.Server(0)
stores, _ := ts.GetStores().(*kvserver.Stores)
Expand Down
2 changes: 1 addition & 1 deletion pkg/kv/kvserver/closed_timestamp_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -1242,7 +1242,7 @@ SET CLUSTER SETTING kv.allocator.load_based_rebalancing = 'off';
func setupTestClusterWithDummyRange(
t *testing.T, clusterArgs base.TestClusterArgs, dbName, tableName string, numNodes int,
) (serverutils.TestClusterInterface, roachpb.RangeDescriptor) {
tc := serverutils.StartNewTestCluster(t, numNodes, clusterArgs)
tc := serverutils.StartCluster(t, numNodes, clusterArgs)
db0 := tc.ServerConn(0)

if _, err := db0.Exec(fmt.Sprintf(`
Expand Down
2 changes: 1 addition & 1 deletion pkg/kv/kvserver/intent_resolver_integration_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -311,7 +311,7 @@ func TestReliableIntentCleanup(t *testing.T) {
},
},
}
tc := serverutils.StartNewTestCluster(t, 3, clusterArgs)
tc := serverutils.StartCluster(t, 3, clusterArgs)
defer tc.Stopper().Stop(ctx)

srv := tc.Server(0)
Expand Down
2 changes: 1 addition & 1 deletion pkg/kv/kvserver/replica_lease_renewal_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -46,7 +46,7 @@ func TestLeaseRenewer(t *testing.T) {
ctx := context.Background()
st := cluster.MakeTestingClusterSettings()
ExpirationLeasesOnly.Override(ctx, &st.SV, expOnly)
tc := serverutils.StartNewTestCluster(t, 3, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 3, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
Settings: st,
// Speed up lease extensions to speed up the test, but adjust tick-based
Expand Down
4 changes: 2 additions & 2 deletions pkg/kv/kvserver/replica_rangefeed_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -1285,7 +1285,7 @@ func TestRangefeedCheckpointsRecoverFromLeaseExpiration(t *testing.T) {
},
},
}
tci := serverutils.StartNewTestCluster(t, 2, cargs)
tci := serverutils.StartCluster(t, 2, cargs)
tc := tci.(*testcluster.TestCluster)
defer tc.Stopper().Stop(ctx)

Expand Down Expand Up @@ -1476,7 +1476,7 @@ func TestNewRangefeedForceLeaseRetry(t *testing.T) {
},
},
}
tci := serverutils.StartNewTestCluster(t, 2, cargs)
tci := serverutils.StartCluster(t, 2, cargs)
tc := tci.(*testcluster.TestCluster)
defer tc.Stopper().Stop(ctx)

Expand Down
6 changes: 3 additions & 3 deletions pkg/kv/kvserver/replica_rankings_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -107,7 +107,7 @@ func TestAddSSTQPSStat(t *testing.T) {
defer log.Scope(t).Close(t)
ctx := context.Background()

tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
})

Expand Down Expand Up @@ -219,7 +219,7 @@ func TestWriteLoadStatsAccounting(t *testing.T) {
ReplicationMode: base.ReplicationManual,
}
args.ServerArgs.Knobs.Store = &StoreTestingKnobs{DisableCanAckBeforeApplication: true}
tc := serverutils.StartNewTestCluster(t, 1, args)
tc := serverutils.StartCluster(t, 1, args)

const epsilonAllowed = 4

Expand Down Expand Up @@ -309,7 +309,7 @@ func TestReadLoadMetricAccounting(t *testing.T) {
defer log.Scope(t).Close(t)
ctx := context.Background()

tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
})

Expand Down
8 changes: 4 additions & 4 deletions pkg/kv/kvserver/replica_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -8235,7 +8235,7 @@ func TestMVCCStatsGCCommutesWithWrites(t *testing.T) {
defer log.Scope(t).Close(t)

ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{})
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{})
defer tc.Stopper().Stop(ctx)
key := tc.ScratchRange(t)
store, err := tc.Server(0).GetStores().(*Stores).GetStore(tc.Server(0).GetFirstStoreID())
Expand Down Expand Up @@ -8467,7 +8467,7 @@ func TestGCThresholdRacesWithRead(t *testing.T) {
testutils.RunTrueAndFalse(t, "followerRead", func(t *testing.T, followerRead bool) {
testutils.RunTrueAndFalse(t, "thresholdFirst", func(t *testing.T, thresholdFirst bool) {
ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 2, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 2, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
ServerArgs: base.TestServerArgs{
Knobs: base.TestingKnobs{
Expand Down Expand Up @@ -13933,7 +13933,7 @@ func TestRangeSplitRacesWithRead(t *testing.T) {

testutils.RunTrueAndFalse(t, "followerRead", func(t *testing.T, followerRead bool) {
ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 2, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 2, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
})
defer tc.Stopper().Stop(ctx)
Expand Down Expand Up @@ -14063,7 +14063,7 @@ func TestRangeSplitAndRHSRemovalRacesWithFollowerRead(t *testing.T) {
startSplit := make(chan struct{})
unblockRead := make(chan struct{})
scratchRangeID := roachpb.RangeID(-1)
tc := serverutils.StartNewTestCluster(t, 2, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 2, base.TestClusterArgs{
ReplicationMode: base.ReplicationManual,
ServerArgsPerNode: map[int]base.TestServerArgs{
1: {
Expand Down
6 changes: 3 additions & 3 deletions pkg/kv/kvserver/reports/reporter_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -52,7 +52,7 @@ func TestConstraintConformanceReportIntegration(t *testing.T) {
skip.UnderDeadlock(t, "takes >1min under deadlock")

ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 5, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 5, base.TestClusterArgs{
ServerArgsPerNode: map[int]base.TestServerArgs{
0: {Locality: roachpb.Locality{Tiers: []roachpb.Tier{{Key: "region", Value: "r1"}}}},
1: {Locality: roachpb.Locality{Tiers: []roachpb.Tier{{Key: "region", Value: "r1"}}}},
Expand Down Expand Up @@ -129,7 +129,7 @@ func TestCriticalLocalitiesReportIntegration(t *testing.T) {
defer log.Scope(t).Close(t)
ctx := context.Background()
// 2 regions, 3 dcs per region.
tc := serverutils.StartNewTestCluster(t, 6, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 6, base.TestClusterArgs{
// We're going to do our own replication.
// All the system ranges will start with a single replica on node 1.
ReplicationMode: base.ReplicationManual,
Expand Down Expand Up @@ -310,7 +310,7 @@ func TestReplicationStatusReportIntegration(t *testing.T) {
defer leaktest.AfterTest(t)()
defer log.Scope(t).Close(t)
ctx := context.Background()
tc := serverutils.StartNewTestCluster(t, 4, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 4, base.TestClusterArgs{
// We're going to do our own replication.
// All the system ranges will start with a single replica on node 1.
ReplicationMode: base.ReplicationManual,
Expand Down
2 changes: 1 addition & 1 deletion pkg/kv/kvserver/store_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -2323,7 +2323,7 @@ func TestStoreScanIntentsRespectsLimit(t *testing.T) {
commitCh := make(chan struct{})
// intentsLaidDownCh is signalled when the writer is done laying down intents.
intentsLaidDownCh := make(chan struct{})
tc := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{
tc := serverutils.StartCluster(t, 1, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
Knobs: base.TestingKnobs{
Store: &StoreTestingKnobs{
Expand Down
4 changes: 2 additions & 2 deletions pkg/kv/txn_external_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -192,7 +192,7 @@ func TestRollbackAfterAmbiguousCommit(t *testing.T) {
},
},
}
tci := serverutils.StartNewTestCluster(t, 2, base.TestClusterArgs{ServerArgs: args})
tci := serverutils.StartCluster(t, 2, base.TestClusterArgs{ServerArgs: args})
tc := tci.(*testcluster.TestCluster)
defer tc.Stopper().Stop(ctx)

Expand Down Expand Up @@ -527,7 +527,7 @@ func TestRevScanAndGet(t *testing.T) {
defer log.Scope(t).Close(t)
ctx := context.Background()

tci := serverutils.StartNewTestCluster(t, 1, base.TestClusterArgs{})
tci := serverutils.StartCluster(t, 1, base.TestClusterArgs{})
tc := tci.(*testcluster.TestCluster)
defer tc.Stopper().Stop(ctx)
db := tc.Servers[0].DB()
Expand Down
2 changes: 1 addition & 1 deletion pkg/server/api_v2_ranges_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -125,7 +125,7 @@ func TestNodesV2(t *testing.T) {
defer leaktest.AfterTest(t)()
defer log.Scope(t).Close(t)

testCluster := serverutils.StartNewTestCluster(t, 3, base.TestClusterArgs{
testCluster := serverutils.StartCluster(t, 3, base.TestClusterArgs{
ServerArgs: base.TestServerArgs{
StoreSpecs: []base.StoreSpec{
base.DefaultTestStoreSpec,
Expand Down
Loading

0 comments on commit 05d3fa0

Please sign in to comment.