From 4f4d47a62fbd3df4a995d3acf38472b7f3c38825 Mon Sep 17 00:00:00 2001 From: Roderick Yao Date: Wed, 5 Jul 2023 08:56:19 -0700 Subject: [PATCH 1/7] Revert "fix parameter name (#93)" (#100) This reverts commit 76159fd0ba50669321695b94e8b4e27f1e70837b. --- go/vt/vtgate/plugin_mysql_server.go | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/go/vt/vtgate/plugin_mysql_server.go b/go/vt/vtgate/plugin_mysql_server.go index 6bba7553753..2e1b9c1d8b4 100644 --- a/go/vt/vtgate/plugin_mysql_server.go +++ b/go/vt/vtgate/plugin_mysql_server.go @@ -75,7 +75,7 @@ var ( mysqlConnWriteTimeout = flag.Duration("mysql_server_write_timeout", 0, "connection write timeout") mysqlQueryTimeout = flag.Duration("mysql_server_query_timeout", 0, "mysql query timeout") - mysqlConnBufferPooling = flag.Bool("mysql_server_pool_conn_read_buffers", false, "If set, the server will pool incoming connection read buffers") + mysqlConnBufferPooling = flag.Bool("mysql-server-pool-conn-read-buffers", false, "If set, the server will pool incoming connection read buffers") mysqlDefaultWorkloadName = flag.String("mysql_default_workload", "OLTP", "Default session workload (OLTP, OLAP, DBA)") mysqlDefaultWorkload int32 From 82cf45b6183849b01f7fd235812ed6dc46fd723c Mon Sep 17 00:00:00 2001 From: pbibra Date: Mon, 10 Jul 2023 13:39:52 -0400 Subject: [PATCH 2/7] apply patch 12178 to v14 (#102) Signed-off-by: Priya Bibra Signed-off-by: 'Priya Bibra' --- go/vt/discovery/healthcheck.go | 35 +++++++++++------- go/vt/discovery/healthcheck_test.go | 57 ++++++++++++++++++++++++++++- 2 files changed, 77 insertions(+), 15 deletions(-) diff --git a/go/vt/discovery/healthcheck.go b/go/vt/discovery/healthcheck.go index c724ddb2870..5ab5823c5ad 100644 --- a/go/vt/discovery/healthcheck.go +++ b/go/vt/discovery/healthcheck.go @@ -397,8 +397,29 @@ func (hc *HealthCheckImpl) deleteTablet(tablet *topodata.Tablet) { hc.mu.Lock() defer hc.mu.Unlock() - key := KeyFromTablet(tablet) tabletAlias := tabletAliasString(topoproto.TabletAliasString(tablet.Alias)) + defer func() { + // We want to be sure the tablet is gone from the secondary + // maps even if it's already gone from the authoritative map. + // The tablet's type also may have recently changed as well, + // so ensure that the tablet we're removing is removed from + // any possible secondary map keys: + // key: keyspace.shard.tabletType -> val: map[tabletAlias]tabletHealth + for _, tabletType := range topoproto.AllTabletTypes { + key := KeyspaceShardTabletType(fmt.Sprintf("%s.%s.%s", tablet.Keyspace, tablet.Shard, topoproto.TabletTypeLString(tabletType))) + // delete from map by keyspace.shard.tabletType + ths, ok := hc.healthData[key] + if !ok { + continue + } + delete(ths, tabletAlias) + // delete from healthy list + healthy, ok := hc.healthy[key] + if ok && len(healthy) > 0 { + hc.recomputeHealthy(key) + } + } + }() // delete from authoritative map th, ok := hc.healthByAlias[tabletAlias] if !ok { @@ -409,18 +430,6 @@ func (hc *HealthCheckImpl) deleteTablet(tablet *topodata.Tablet) { // which will call finalizeConn, which will close the connection. th.cancelFunc() delete(hc.healthByAlias, tabletAlias) - // delete from map by keyspace.shard.tabletType - ths, ok := hc.healthData[key] - if !ok { - log.Warningf("We have no health data for target: %v", key) - return - } - delete(ths, tabletAlias) - // delete from healthy list - healthy, ok := hc.healthy[key] - if ok && len(healthy) > 0 { - hc.recomputeHealthy(key) - } } func (hc *HealthCheckImpl) updateHealth(th *TabletHealth, prevTarget *query.Target, trivialUpdate bool, up bool) { diff --git a/go/vt/discovery/healthcheck_test.go b/go/vt/discovery/healthcheck_test.go index d2f6d25eaf9..bbe3e4b8d8c 100644 --- a/go/vt/discovery/healthcheck_test.go +++ b/go/vt/discovery/healthcheck_test.go @@ -681,7 +681,7 @@ func TestRemoveTablet(t *testing.T) { // there will be a first result, get and discard it <-resultChan - shr := &querypb.StreamHealthResponse{ + shrReplica := &querypb.StreamHealthResponse{ TabletAlias: tablet.Alias, Target: &querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_REPLICA}, Serving: true, @@ -695,7 +695,7 @@ func TestRemoveTablet(t *testing.T) { Stats: &querypb.RealtimeStats{ReplicationLagSeconds: 1, CpuUsage: 0.2}, PrimaryTermStartTime: 0, }} - input <- shr + input <- shrReplica <-resultChan // check it's there a := hc.GetHealthyTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_REPLICA}) @@ -705,6 +705,59 @@ func TestRemoveTablet(t *testing.T) { hc.RemoveTablet(tablet) a = hc.GetHealthyTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_REPLICA}) assert.Empty(t, a, "wrong result, expected empty list") + + // Now confirm that when a tablet's type changes between when it's added to the cache + // and when it's removed, that the tablet is entirely removed from the cache since + // in the secondary maps it's keyed in part by tablet type. + // Note: we are using GetTabletStats here to check the healthData map (rather than + // the healthy map that we checked above) because that is the data structure that + // is used when printing the contents of the healthcheck cache in the /debug/status + // endpoint and in the SHOW VITESS_TABLETS; SQL command output. + + // Add the tablet back. + hc.AddTablet(tablet) + // Receive and discard the initial result. + <-resultChan + input <- shrReplica + // Confirm it's there in the cache. + a = hc.getTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_REPLICA}) + mustMatch(t, want, a, "unexpected result") + // Change the tablet type to RDONLY. + tablet.Type = topodatapb.TabletType_RDONLY + shrRdonly := &querypb.StreamHealthResponse{ + TabletAlias: tablet.Alias, + Target: &querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_RDONLY}, + Serving: true, + TabletExternallyReparentedTimestamp: 0, + RealtimeStats: &querypb.RealtimeStats{ReplicationLagSeconds: 2, CpuUsage: 0.4}, + } + // Now replace it, which does a Remove and Add. The tablet should + // be removed from the cache and all its maps even though the + // tablet type had changed in-between the initial Add and Remove. + hc.ReplaceTablet(tablet, tablet) + // Confirm that the old entry is gone. + a = hc.getTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_REPLICA}) + assert.Empty(t, a, "wrong result, expected empty list") + // Receive and discard the initial result. + <-resultChan + input <- shrRdonly + // Confirm that the new entry is there in the cache. + want = []*TabletHealth{{ + Tablet: tablet, + Target: &querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_RDONLY}, + Serving: true, + Stats: &querypb.RealtimeStats{ReplicationLagSeconds: 2, CpuUsage: 0.4}, + PrimaryTermStartTime: 0, + }} + a = hc.getTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_RDONLY}) + mustMatch(t, want, a, "unexpected result") + // Delete the tablet, confirm again that it's gone in both + // tablet type forms. + hc.RemoveTablet(tablet) + a = hc.getTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_REPLICA}) + assert.Empty(t, a, "wrong result, expected empty list") + a = hc.getTabletStats(&querypb.Target{Keyspace: "k", Shard: "s", TabletType: topodatapb.TabletType_RDONLY}) + assert.Empty(t, a, "wrong result, expected empty list") } // TestGetHealthyTablets tests the functionality of GetHealthyTabletStats. From a4b60a9a36bac611a6c4ed22e3b31ad27685299d Mon Sep 17 00:00:00 2001 From: "Eduardo J. Ortega U" <5791035+ejortegau@users.noreply.github.com> Date: Wed, 2 Aug 2023 13:04:30 +0200 Subject: [PATCH 3/7] BackportAdd dry-run mode to the TxThrottler This is a backport of upstreamed https://github.com/vitessio/vitess/pull/13604 Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> --- go/flags/endtoend/vttablet.txt | 2 + .../vttablet/tabletserver/tabletenv/config.go | 3 ++ .../tabletserver/txthrottler/tx_throttler.go | 38 +++++++++----- .../txthrottler/tx_throttler_test.go | 51 +++++++++++++++++++ 4 files changed, 82 insertions(+), 12 deletions(-) diff --git a/go/flags/endtoend/vttablet.txt b/go/flags/endtoend/vttablet.txt index a612d484135..f18e71cb136 100644 --- a/go/flags/endtoend/vttablet.txt +++ b/go/flags/endtoend/vttablet.txt @@ -939,6 +939,8 @@ max_rate_approach_threshold: 0.9 ) --tx-throttler-default-priority int Default priority assigned to queries that lack priority information. + --tx-throttler-dry-run bool + If present, the transaction throttler only records metrics about requests received and throttled, but does not actually throttle any requests. --tx-throttler-healthcheck-cells value Synonym to -tx_throttler_healthcheck_cells --tx-throttler-tablet-types value diff --git a/go/vt/vttablet/tabletserver/tabletenv/config.go b/go/vt/vttablet/tabletserver/tabletenv/config.go index 0d642eb7223..635fc27abbc 100644 --- a/go/vt/vttablet/tabletserver/tabletenv/config.go +++ b/go/vt/vttablet/tabletserver/tabletenv/config.go @@ -141,6 +141,7 @@ func init() { flagutil.DualFormatStringListVar(¤tConfig.TxThrottlerHealthCheckCells, "tx_throttler_healthcheck_cells", defaultConfig.TxThrottlerHealthCheckCells, "A comma-separated list of cells. Only tabletservers running in these cells will be monitored for replication lag by the transaction throttler.") flag.IntVar(¤tConfig.TxThrottlerDefaultPriority, "tx-throttler-default-priority", defaultConfig.TxThrottlerDefaultPriority, "Default priority assigned to queries that lack priority information.") topoproto.TabletTypeListVar(¤tConfig.TxThrottlerTabletTypes, "tx-throttler-tablet-types", "A comma-separated list of tablet types. Only tablets of this type are monitored for replication lag by the transaction throttler. Supported types are replica and/or rdonly. (default replica)") + flag.BoolVar(¤tConfig.TxThrottlerDryRun, "tx-throttler-dry-run", defaultConfig.TxThrottlerDryRun, "If present, the transaction throttler only records metrics about requests received and throttled, but does not actually throttle any requests.") flag.BoolVar(&enableHotRowProtection, "enable_hot_row_protection", false, "If true, incoming transactions for the same row (range) will be queued and cannot consume all txpool slots.") flag.BoolVar(&enableHotRowProtectionDryRun, "enable_hot_row_protection_dry_run", false, "If true, hot row protection is not enforced but logs if transactions would have been queued.") @@ -306,6 +307,7 @@ type TabletConfig struct { TxThrottlerHealthCheckCells []string `json:"-"` TxThrottlerDefaultPriority int `json:"-"` TxThrottlerTabletTypes []topodatapb.TabletType `json:"-"` + TxThrottlerDryRun bool `json:"-"` EnableLagThrottler bool `json:"-"` @@ -538,6 +540,7 @@ var defaultConfig = TabletConfig{ TxThrottlerConfig: defaultTxThrottlerConfig(), TxThrottlerHealthCheckCells: []string{}, TxThrottlerDefaultPriority: 0, // This leads to all queries being candidates to throttle + TxThrottlerDryRun: false, EnableLagThrottler: false, // Feature flag; to switch to 'true' at some stage in the future diff --git a/go/vt/vttablet/tabletserver/txthrottler/tx_throttler.go b/go/vt/vttablet/tabletserver/txthrottler/tx_throttler.go index ed726b45d99..9f2f369ffd9 100644 --- a/go/vt/vttablet/tabletserver/txthrottler/tx_throttler.go +++ b/go/vt/vttablet/tabletserver/txthrottler/tx_throttler.go @@ -135,7 +135,7 @@ type txThrottler struct { // state holds an open transaction throttler state. It is nil // if the TransactionThrottler is closed. - state *txThrottlerState + state txThrottlerState target *querypb.Target topoServer *topo.Server @@ -154,6 +154,10 @@ type txThrottlerConfig struct { // returns false. enabled bool + // if dryRun is true, the txThrottler will run only on monitoring mode, meaning that it will increase counters for + // total and actually throttled requests, but it will not actually return that a transaction should be throttled. + dryRun bool + throttlerConfig *throttlerdatapb.Configuration // healthCheckCells stores the cell names in which running vttablets will be monitored for // replication lag. @@ -162,8 +166,14 @@ type txThrottlerConfig struct { tabletTypes []topodatapb.TabletType } -// txThrottlerState holds the state of an open TxThrottler object. -type txThrottlerState struct { +type txThrottlerState interface { + deallocateResources() + StatsUpdate(tabletStats *discovery.LegacyTabletStats) + throttle() bool +} + +// txThrottlerStateImpl holds the state of an open TxThrottler object. +type txThrottlerStateImpl struct { config *txThrottlerConfig // throttleMu serializes calls to throttler.Throttler.Throttle(threadId). @@ -187,7 +197,10 @@ func NewTxThrottler(env tabletenv.Env, topoServer *topo.Server) TxThrottler { log.Errorf("Error creating transaction throttler. Transaction throttling will"+ " be disabled. Error: %v", err) // newTxThrottler with disabled config never returns an error - txThrottler, _ = newTxThrottler(env, topoServer, &txThrottlerConfig{enabled: false}) + txThrottler, _ = newTxThrottler(env, topoServer, &txThrottlerConfig{ + enabled: false, + dryRun: env.Config().TxThrottlerDryRun, + }) } else { log.Infof("Initialized transaction throttler with config: %+v", txThrottler.config) } @@ -201,7 +214,7 @@ func (t *txThrottler) InitDBConfig(target *querypb.Target) { func tryCreateTxThrottler(env tabletenv.Env, topoServer *topo.Server) (*txThrottler, error) { if !env.Config().EnableTxThrottler { - return newTxThrottler(env, topoServer, &txThrottlerConfig{enabled: false}) + return newTxThrottler(env, topoServer, &txThrottlerConfig{enabled: false, dryRun: env.Config().TxThrottlerDryRun}) } var throttlerConfig throttlerdatapb.Configuration @@ -216,6 +229,7 @@ func tryCreateTxThrottler(env tabletenv.Env, topoServer *topo.Server) (*txThrott return newTxThrottler(env, topoServer, &txThrottlerConfig{ enabled: true, + dryRun: env.Config().TxThrottlerDryRun, tabletTypes: env.Config().TxThrottlerTabletTypes, throttlerConfig: &throttlerConfig, healthCheckCells: healthCheckCells, @@ -294,10 +308,10 @@ func (t *txThrottler) Throttle(priority int, workload string) (result bool) { t.requestsThrottled.Add(workload, 1) } - return result + return result && !t.config.dryRun } -func newTxThrottlerState(topoServer *topo.Server, config *txThrottlerConfig, target *querypb.Target) (*txThrottlerState, error) { +func newTxThrottlerState(topoServer *topo.Server, config *txThrottlerConfig, target *querypb.Target) (txThrottlerState, error) { maxReplicationLagModuleConfig := throttler.MaxReplicationLagModuleConfig{Configuration: config.throttlerConfig} t, err := throttlerFactory( @@ -314,7 +328,7 @@ func newTxThrottlerState(topoServer *topo.Server, config *txThrottlerConfig, tar t.Close() return nil, err } - result := &txThrottlerState{ + result := &txThrottlerStateImpl{ config: config, throttler: t, } @@ -337,7 +351,7 @@ func newTxThrottlerState(topoServer *topo.Server, config *txThrottlerConfig, tar return result, nil } -func (ts *txThrottlerState) throttle() bool { +func (ts *txThrottlerStateImpl) throttle() bool { if ts.throttler == nil { log.Error("throttle called after deallocateResources was called") return false @@ -348,7 +362,7 @@ func (ts *txThrottlerState) throttle() bool { return ts.throttler.Throttle(0 /* threadId */) > 0 } -func (ts *txThrottlerState) deallocateResources() { +func (ts *txThrottlerStateImpl) deallocateResources() { // We don't really need to nil out the fields here // as deallocateResources is not expected to be called // more than once, but it doesn't hurt to do so. @@ -360,14 +374,14 @@ func (ts *txThrottlerState) deallocateResources() { ts.healthCheck.Close() ts.healthCheck = nil - // After ts.healthCheck is closed txThrottlerState.StatsUpdate() is guaranteed not + // After ts.healthCheck is closed txThrottlerStateImpl.StatsUpdate() is guaranteed not // to be executing, so we can safely close the throttler. ts.throttler.Close() ts.throttler = nil } // StatsUpdate updates the health of a tablet with the given healthcheck. -func (ts *txThrottlerState) StatsUpdate(tabletStats *discovery.LegacyTabletStats) { +func (ts *txThrottlerStateImpl) StatsUpdate(tabletStats *discovery.LegacyTabletStats) { if ts.config.tabletTypes == nil { return } diff --git a/go/vt/vttablet/tabletserver/txthrottler/tx_throttler_test.go b/go/vt/vttablet/tabletserver/txthrottler/tx_throttler_test.go index ab5fa711dcf..7b9e4bc98bd 100644 --- a/go/vt/vttablet/tabletserver/txthrottler/tx_throttler_test.go +++ b/go/vt/vttablet/tabletserver/txthrottler/tx_throttler_test.go @@ -181,3 +181,54 @@ func TestNewTxThrottler(t *testing.T) { assert.NotNil(t, throttler) } } + +func TestDryRunThrottler(t *testing.T) { + config := tabletenv.NewDefaultConfig() + env := tabletenv.NewEnv(config, t.Name()) + + testCases := []struct { + Name string + txThrottlerStateShouldThrottle bool + throttlerDryRun bool + expectedResult bool + }{ + {Name: "Real run throttles when txThrottlerStateImpl says it should", txThrottlerStateShouldThrottle: true, throttlerDryRun: false, expectedResult: true}, + {Name: "Real run does not throttle when txThrottlerStateImpl says it should not", txThrottlerStateShouldThrottle: false, throttlerDryRun: false, expectedResult: false}, + {Name: "Dry run does not throttle when txThrottlerStateImpl says it should", txThrottlerStateShouldThrottle: true, throttlerDryRun: true, expectedResult: false}, + {Name: "Dry run does not throttle when txThrottlerStateImpl says it should not", txThrottlerStateShouldThrottle: false, throttlerDryRun: true, expectedResult: false}, + } + + for _, aTestCase := range testCases { + theTestCase := aTestCase + + t.Run(theTestCase.Name, func(t *testing.T) { + aTxThrottler := &txThrottler{ + config: &txThrottlerConfig{ + enabled: true, + dryRun: theTestCase.throttlerDryRun, + }, + state: &mockTxThrottlerState{shouldThrottle: theTestCase.txThrottlerStateShouldThrottle}, + throttlerRunning: env.Exporter().NewGauge("TransactionThrottlerRunning", "transaction throttler running state"), + requestsTotal: env.Exporter().NewCountersWithSingleLabel("TransactionThrottlerRequests", "transaction throttler requests", "workload"), + requestsThrottled: env.Exporter().NewCountersWithSingleLabel("TransactionThrottlerThrottled", "transaction throttler requests throttled", "workload"), + } + + assert.Equal(t, theTestCase.expectedResult, aTxThrottler.Throttle(100, "some-workload")) + }) + } +} + +type mockTxThrottlerState struct { + shouldThrottle bool +} + +func (t *mockTxThrottlerState) deallocateResources() { + +} +func (t *mockTxThrottlerState) StatsUpdate(*discovery.LegacyTabletStats) { + +} + +func (t *mockTxThrottlerState) throttle() bool { + return t.shouldThrottle +} From 1900adeb27cee62af72216cf1e5410dd9395d986 Mon Sep 17 00:00:00 2001 From: "Eduardo J. Ortega U" <5791035+ejortegau@users.noreply.github.com> Date: Wed, 2 Aug 2023 13:21:33 +0200 Subject: [PATCH 4/7] Fix test Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> --- go/flags/endtoend/vttablet.txt | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/go/flags/endtoend/vttablet.txt b/go/flags/endtoend/vttablet.txt index f18e71cb136..3b7986547dc 100644 --- a/go/flags/endtoend/vttablet.txt +++ b/go/flags/endtoend/vttablet.txt @@ -940,7 +940,7 @@ max_rate_approach_threshold: 0.9 --tx-throttler-default-priority int Default priority assigned to queries that lack priority information. --tx-throttler-dry-run bool - If present, the transaction throttler only records metrics about requests received and throttled, but does not actually throttle any requests. + If present, the transaction throttler only records metrics about requests received and throttled, but does not actually throttle any requests. --tx-throttler-healthcheck-cells value Synonym to -tx_throttler_healthcheck_cells --tx-throttler-tablet-types value From 3b530d44e3f2b709fed2943684e46a0b08db6100 Mon Sep 17 00:00:00 2001 From: "Eduardo J. Ortega U" <5791035+ejortegau@users.noreply.github.com> Date: Wed, 2 Aug 2023 14:38:54 +0200 Subject: [PATCH 5/7] Fix test Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> --- go/flags/endtoend/vttablet.txt | 2 +- 1 file changed, 1 insertion(+), 1 deletion(-) diff --git a/go/flags/endtoend/vttablet.txt b/go/flags/endtoend/vttablet.txt index 3b7986547dc..25255a88558 100644 --- a/go/flags/endtoend/vttablet.txt +++ b/go/flags/endtoend/vttablet.txt @@ -939,7 +939,7 @@ max_rate_approach_threshold: 0.9 ) --tx-throttler-default-priority int Default priority assigned to queries that lack priority information. - --tx-throttler-dry-run bool + --tx-throttler-dry-run If present, the transaction throttler only records metrics about requests received and throttled, but does not actually throttle any requests. --tx-throttler-healthcheck-cells value Synonym to -tx_throttler_healthcheck_cells From b37228ada483a245c7ecc59ea1e5feebe8fd9f21 Mon Sep 17 00:00:00 2001 From: "Eduardo J. Ortega U" <5791035+ejortegau@users.noreply.github.com> Date: Wed, 2 Aug 2023 19:05:31 +0200 Subject: [PATCH 6/7] Ejortegau/larger runners (#115) * Empty commit to trigger CI Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> * `slack-vitess-r14.0.5-dsdefense`: use larger runner Signed-off-by: Tim Vaillancourt * Use runner group instead Signed-off-by: Tim Vaillancourt * Rename group Signed-off-by: Tim Vaillancourt * Move more jobs to runner group Signed-off-by: Tim Vaillancourt * use vitess-ubuntu20 runner group Signed-off-by: Tim Vaillancourt * Rever change of runner type for e2e ERS PRS new features heavy test Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> --------- Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> Signed-off-by: Tim Vaillancourt Co-authored-by: Tim Vaillancourt --- .github/workflows/cluster_endtoend_12.yml | 3 ++- .github/workflows/cluster_endtoend_13.yml | 3 ++- .github/workflows/cluster_endtoend_15.yml | 3 ++- .github/workflows/cluster_endtoend_18.yml | 3 ++- .github/workflows/cluster_endtoend_19.yml | 3 ++- .github/workflows/cluster_endtoend_21.yml | 3 ++- .github/workflows/cluster_endtoend_22.yml | 3 ++- .github/workflows/cluster_endtoend_24.yml | 3 ++- .github/workflows/cluster_endtoend_26.yml | 3 ++- .github/workflows/cluster_endtoend_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_mysql80.yml | 3 ++- .../workflows/cluster_endtoend_onlineddl_declarative.yml | 3 ++- .../cluster_endtoend_onlineddl_declarative_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_onlineddl_ghost.yml | 3 ++- .../workflows/cluster_endtoend_onlineddl_ghost_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_onlineddl_revert.yml | 3 ++- .../workflows/cluster_endtoend_onlineddl_revert_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_onlineddl_revertible.yml | 3 ++- .../cluster_endtoend_onlineddl_revertible_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_onlineddl_scheduler.yml | 3 ++- .../cluster_endtoend_onlineddl_scheduler_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_onlineddl_singleton.yml | 3 ++- .../cluster_endtoend_onlineddl_singleton_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_onlineddl_vrepl.yml | 5 +++-- .../workflows/cluster_endtoend_onlineddl_vrepl_mysql57.yml | 3 ++- .../workflows/cluster_endtoend_onlineddl_vrepl_stress.yml | 3 ++- .../cluster_endtoend_onlineddl_vrepl_stress_mysql57.yml | 3 ++- .../cluster_endtoend_onlineddl_vrepl_stress_suite.yml | 3 ++- ...luster_endtoend_onlineddl_vrepl_stress_suite_mysql57.yml | 3 ++- .../workflows/cluster_endtoend_onlineddl_vrepl_suite.yml | 3 ++- .../cluster_endtoend_onlineddl_vrepl_suite_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_resharding.yml | 3 ++- .github/workflows/cluster_endtoend_resharding_bytes.yml | 3 ++- .github/workflows/cluster_endtoend_schemadiff_vrepl.yml | 3 ++- .../workflows/cluster_endtoend_schemadiff_vrepl_mysql57.yml | 3 ++- ..._endtoend_shardedrecovery_stress_verticalsplit_heavy.yml | 5 +++-- .github/workflows/cluster_endtoend_tabletmanager_consul.yml | 3 ++- .../workflows/cluster_endtoend_tabletmanager_tablegc.yml | 3 ++- .../cluster_endtoend_tabletmanager_tablegc_mysql57.yml | 3 ++- .../workflows/cluster_endtoend_tabletmanager_throttler.yml | 3 ++- ...uster_endtoend_tabletmanager_throttler_custom_config.yml | 3 ++- .../workflows/cluster_endtoend_topo_connection_cache.yml | 3 ++- .../cluster_endtoend_vreplication_across_db_versions.yml | 3 ++- .github/workflows/cluster_endtoend_vreplication_basic.yml | 3 ++- .../workflows/cluster_endtoend_vreplication_cellalias.yml | 3 ++- .github/workflows/cluster_endtoend_vreplication_migrate.yml | 3 ++- ...ster_endtoend_vreplication_migrate_vdiff2_convert_tz.yml | 3 ++- .../workflows/cluster_endtoend_vreplication_multicell.yml | 3 ++- .github/workflows/cluster_endtoend_vreplication_v2.yml | 3 ++- .github/workflows/cluster_endtoend_vstream_failover.yml | 3 ++- .../cluster_endtoend_vstream_stoponreshard_false.yml | 3 ++- .../cluster_endtoend_vstream_stoponreshard_true.yml | 3 ++- .../cluster_endtoend_vstream_with_keyspaces_to_watch.yml | 3 ++- .github/workflows/cluster_endtoend_vtbackup_transform.yml | 3 ++- ...uster_endtoend_vtctlbackup_sharded_clustertest_heavy.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_concurrentdml.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_gen4.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_general_heavy.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_godriver.yml | 3 ++- .../workflows/cluster_endtoend_vtgate_partial_keyspace.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_queries.yml | 3 ++- .../workflows/cluster_endtoend_vtgate_readafterwrite.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_reservedconn.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_schema.yml | 3 ++- .../workflows/cluster_endtoend_vtgate_schema_tracker.yml | 3 ++- .../cluster_endtoend_vtgate_tablet_healthcheck_cache.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_topo.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_topo_consul.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_topo_etcd.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_transaction.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_unsharded.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_vindex_heavy.yml | 3 ++- .github/workflows/cluster_endtoend_vtgate_vschema.yml | 3 ++- .github/workflows/cluster_endtoend_vtorc.yml | 3 ++- .github/workflows/cluster_endtoend_vtorc_8.0.yml | 3 ++- .github/workflows/cluster_endtoend_worker_vault_heavy.yml | 3 ++- .github/workflows/cluster_endtoend_xb_backup.yml | 3 ++- .github/workflows/cluster_endtoend_xb_backup_mysql57.yml | 3 ++- .github/workflows/cluster_endtoend_xb_recovery.yml | 3 ++- .github/workflows/cluster_endtoend_xb_recovery_mysql57.yml | 3 ++- .github/workflows/cluster_initial_sharding_multi.yml | 3 ++- .github/workflows/docker_test_cluster_10.yml | 3 ++- .github/workflows/docker_test_cluster_25.yml | 3 ++- .github/workflows/e2e_race.yml | 3 ++- .github/workflows/endtoend.yml | 3 ++- .github/workflows/unit_race.yml | 3 ++- .github/workflows/unit_test_mysql57.yml | 3 ++- .github/workflows/unit_test_mysql80.yml | 3 ++- .github/workflows/upgrade_downgrade_test_backups_e2e.yml | 6 ++++-- .../upgrade_downgrade_test_backups_e2e_next_release.yml | 6 ++++-- .github/workflows/upgrade_downgrade_test_backups_manual.yml | 6 ++++-- .../upgrade_downgrade_test_backups_manual_next_release.yml | 6 ++++-- .../upgrade_downgrade_test_query_serving_queries.yml | 6 ++++-- ...de_downgrade_test_query_serving_queries_next_release.yml | 6 ++++-- .../upgrade_downgrade_test_query_serving_schema.yml | 6 ++++-- ...ade_downgrade_test_query_serving_schema_next_release.yml | 6 ++++-- .../workflows/upgrade_downgrade_test_reparent_new_vtctl.yml | 6 ++++-- .../upgrade_downgrade_test_reparent_new_vttablet.yml | 6 ++++-- .../workflows/upgrade_downgrade_test_reparent_old_vtctl.yml | 6 ++++-- .../upgrade_downgrade_test_reparent_old_vttablet.yml | 6 ++++-- test/templates/cluster_endtoend_test.tpl | 3 ++- test/templates/cluster_endtoend_test_docker.tpl | 3 ++- test/templates/cluster_endtoend_test_mysql57.tpl | 3 ++- test/templates/cluster_endtoend_test_self_hosted.tpl | 3 ++- test/templates/unit_test.tpl | 3 ++- test/templates/unit_test_self_hosted.tpl | 3 ++- 106 files changed, 238 insertions(+), 120 deletions(-) diff --git a/.github/workflows/cluster_endtoend_12.yml b/.github/workflows/cluster_endtoend_12.yml index 62989ec3762..4f80aec2e78 100644 --- a/.github/workflows/cluster_endtoend_12.yml +++ b/.github/workflows/cluster_endtoend_12.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (12) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_13.yml b/.github/workflows/cluster_endtoend_13.yml index 3c10735272a..313876b3534 100644 --- a/.github/workflows/cluster_endtoend_13.yml +++ b/.github/workflows/cluster_endtoend_13.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (13) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_15.yml b/.github/workflows/cluster_endtoend_15.yml index 8d1de7d56fb..9a80087f4db 100644 --- a/.github/workflows/cluster_endtoend_15.yml +++ b/.github/workflows/cluster_endtoend_15.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (15) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_18.yml b/.github/workflows/cluster_endtoend_18.yml index ce8888e7067..6262752eefa 100644 --- a/.github/workflows/cluster_endtoend_18.yml +++ b/.github/workflows/cluster_endtoend_18.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (18) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_19.yml b/.github/workflows/cluster_endtoend_19.yml index 121d9284e30..f813b345f03 100644 --- a/.github/workflows/cluster_endtoend_19.yml +++ b/.github/workflows/cluster_endtoend_19.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (19) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_21.yml b/.github/workflows/cluster_endtoend_21.yml index 64518af035c..51a4a1574e2 100644 --- a/.github/workflows/cluster_endtoend_21.yml +++ b/.github/workflows/cluster_endtoend_21.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (21) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_22.yml b/.github/workflows/cluster_endtoend_22.yml index 377e7023ef7..ec02737214d 100644 --- a/.github/workflows/cluster_endtoend_22.yml +++ b/.github/workflows/cluster_endtoend_22.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (22) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_24.yml b/.github/workflows/cluster_endtoend_24.yml index 46e379d6410..004ecea8cea 100644 --- a/.github/workflows/cluster_endtoend_24.yml +++ b/.github/workflows/cluster_endtoend_24.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (24) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_26.yml b/.github/workflows/cluster_endtoend_26.yml index aa84f9c7760..9711167f4f5 100644 --- a/.github/workflows/cluster_endtoend_26.yml +++ b/.github/workflows/cluster_endtoend_26.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (26) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_mysql57.yml b/.github/workflows/cluster_endtoend_mysql57.yml index b21d428003a..5b7067fc665 100644 --- a/.github/workflows/cluster_endtoend_mysql57.yml +++ b/.github/workflows/cluster_endtoend_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (mysql57) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_mysql80.yml b/.github/workflows/cluster_endtoend_mysql80.yml index 71e8fbd7248..44d7aebfbad 100644 --- a/.github/workflows/cluster_endtoend_mysql80.yml +++ b/.github/workflows/cluster_endtoend_mysql80.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (mysql80) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_declarative.yml b/.github/workflows/cluster_endtoend_onlineddl_declarative.yml index 8531293a938..81ea0c9857e 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_declarative.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_declarative.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_declarative) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_declarative_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_declarative_mysql57.yml index 07554aacd85..33ea04343b0 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_declarative_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_declarative_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_declarative) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_ghost.yml b/.github/workflows/cluster_endtoend_onlineddl_ghost.yml index 62c7254e1db..d0e4d0c568d 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_ghost.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_ghost.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_ghost) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_ghost_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_ghost_mysql57.yml index 2c7e0d433b7..d44e496ec03 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_ghost_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_ghost_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_ghost) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_revert.yml b/.github/workflows/cluster_endtoend_onlineddl_revert.yml index 6c712fd1150..f0aa80b3538 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_revert.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_revert.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_revert) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_revert_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_revert_mysql57.yml index 0bb2ea9c13e..303d7159808 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_revert_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_revert_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_revert) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_revertible.yml b/.github/workflows/cluster_endtoend_onlineddl_revertible.yml index 86e0dee5e37..fc472c06fef 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_revertible.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_revertible.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_revertible) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_revertible_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_revertible_mysql57.yml index 85ada42a928..09ec49503f3 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_revertible_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_revertible_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_revertible) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_scheduler.yml b/.github/workflows/cluster_endtoend_onlineddl_scheduler.yml index 617335a15e2..547becc7167 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_scheduler.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_scheduler.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_scheduler) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_scheduler_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_scheduler_mysql57.yml index a42a17b5273..c48c6b188f5 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_scheduler_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_scheduler_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_scheduler) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_singleton.yml b/.github/workflows/cluster_endtoend_onlineddl_singleton.yml index 61c93ea2b10..776fd7eeeac 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_singleton.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_singleton.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_singleton) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_singleton_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_singleton_mysql57.yml index b33c269d4a8..1f607338a78 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_singleton_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_singleton_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_singleton) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl.yml index 3fbbdf342fd..85edce0712e 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped @@ -96,7 +97,7 @@ jobs: if: steps.skip-workflow.outputs.skip-workflow == 'false' && steps.changes.outputs.end_to_end == 'true' uses: nick-fields/retry@v2 with: - timeout_minutes: 60 + timeout_minutes: 45 max_attempts: 3 retry_on: error command: | diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_mysql57.yml index 43b7d2a9104..06c30307083 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress.yml index 23ae76336b6..ae9eadbeeb2 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl_stress) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_mysql57.yml index 0d9d27f4154..79199b7241b 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl_stress) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite.yml index 0430b37de85..0f2e2f98775 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl_stress_suite) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite_mysql57.yml index 882586b4afc..ca6563662c7 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_stress_suite_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl_stress_suite) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite.yml index 319a786de2a..70aaa4dacd0 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl_suite) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite_mysql57.yml b/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite_mysql57.yml index f86e7c44fb4..d16484dd627 100644 --- a/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite_mysql57.yml +++ b/.github/workflows/cluster_endtoend_onlineddl_vrepl_suite_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (onlineddl_vrepl_suite) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_resharding.yml b/.github/workflows/cluster_endtoend_resharding.yml index 1a0fb97a1aa..2f314bae6ea 100644 --- a/.github/workflows/cluster_endtoend_resharding.yml +++ b/.github/workflows/cluster_endtoend_resharding.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (resharding) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_resharding_bytes.yml b/.github/workflows/cluster_endtoend_resharding_bytes.yml index 792d5e2bfb1..4ea1b768e8e 100644 --- a/.github/workflows/cluster_endtoend_resharding_bytes.yml +++ b/.github/workflows/cluster_endtoend_resharding_bytes.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (resharding_bytes) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_schemadiff_vrepl.yml b/.github/workflows/cluster_endtoend_schemadiff_vrepl.yml index 6bcaf0627f7..e648f4ec2b7 100644 --- a/.github/workflows/cluster_endtoend_schemadiff_vrepl.yml +++ b/.github/workflows/cluster_endtoend_schemadiff_vrepl.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (schemadiff_vrepl) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_schemadiff_vrepl_mysql57.yml b/.github/workflows/cluster_endtoend_schemadiff_vrepl_mysql57.yml index 72fbd67f2c8..8aad094157a 100644 --- a/.github/workflows/cluster_endtoend_schemadiff_vrepl_mysql57.yml +++ b/.github/workflows/cluster_endtoend_schemadiff_vrepl_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (schemadiff_vrepl) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml b/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml index 2c981eecf18..4c92ffdc575 100644 --- a/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml +++ b/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (shardedrecovery_stress_verticalsplit_heavy) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped @@ -96,7 +97,7 @@ jobs: if: steps.skip-workflow.outputs.skip-workflow == 'false' && steps.changes.outputs.end_to_end == 'true' uses: nick-fields/retry@v2 with: - timeout_minutes: 60 + timeout_minutes: 45 max_attempts: 3 retry_on: error command: | diff --git a/.github/workflows/cluster_endtoend_tabletmanager_consul.yml b/.github/workflows/cluster_endtoend_tabletmanager_consul.yml index c4b8426ed57..4a35e436fd7 100644 --- a/.github/workflows/cluster_endtoend_tabletmanager_consul.yml +++ b/.github/workflows/cluster_endtoend_tabletmanager_consul.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (tabletmanager_consul) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_tabletmanager_tablegc.yml b/.github/workflows/cluster_endtoend_tabletmanager_tablegc.yml index cddc6af1ce0..60b5e1d546d 100644 --- a/.github/workflows/cluster_endtoend_tabletmanager_tablegc.yml +++ b/.github/workflows/cluster_endtoend_tabletmanager_tablegc.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (tabletmanager_tablegc) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_tabletmanager_tablegc_mysql57.yml b/.github/workflows/cluster_endtoend_tabletmanager_tablegc_mysql57.yml index dc9c1f897e8..64b2df95cf5 100644 --- a/.github/workflows/cluster_endtoend_tabletmanager_tablegc_mysql57.yml +++ b/.github/workflows/cluster_endtoend_tabletmanager_tablegc_mysql57.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (tabletmanager_tablegc) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/.github/workflows/cluster_endtoend_tabletmanager_throttler.yml b/.github/workflows/cluster_endtoend_tabletmanager_throttler.yml index 50dd5449a48..7d26d845581 100644 --- a/.github/workflows/cluster_endtoend_tabletmanager_throttler.yml +++ b/.github/workflows/cluster_endtoend_tabletmanager_throttler.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (tabletmanager_throttler) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_tabletmanager_throttler_custom_config.yml b/.github/workflows/cluster_endtoend_tabletmanager_throttler_custom_config.yml index ef3b288a31f..96c085a31ae 100644 --- a/.github/workflows/cluster_endtoend_tabletmanager_throttler_custom_config.yml +++ b/.github/workflows/cluster_endtoend_tabletmanager_throttler_custom_config.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (tabletmanager_throttler_custom_config) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_topo_connection_cache.yml b/.github/workflows/cluster_endtoend_topo_connection_cache.yml index 098a115ebc7..a3bfb5733d2 100644 --- a/.github/workflows/cluster_endtoend_topo_connection_cache.yml +++ b/.github/workflows/cluster_endtoend_topo_connection_cache.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (topo_connection_cache) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_across_db_versions.yml b/.github/workflows/cluster_endtoend_vreplication_across_db_versions.yml index 50983f80d72..2a4fc32db31 100644 --- a/.github/workflows/cluster_endtoend_vreplication_across_db_versions.yml +++ b/.github/workflows/cluster_endtoend_vreplication_across_db_versions.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vreplication_across_db_versions) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_basic.yml b/.github/workflows/cluster_endtoend_vreplication_basic.yml index ffd2c540613..5cd53e5ad78 100644 --- a/.github/workflows/cluster_endtoend_vreplication_basic.yml +++ b/.github/workflows/cluster_endtoend_vreplication_basic.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vreplication_basic) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_cellalias.yml b/.github/workflows/cluster_endtoend_vreplication_cellalias.yml index f23c3134297..c5b99420f2c 100644 --- a/.github/workflows/cluster_endtoend_vreplication_cellalias.yml +++ b/.github/workflows/cluster_endtoend_vreplication_cellalias.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vreplication_cellalias) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_migrate.yml b/.github/workflows/cluster_endtoend_vreplication_migrate.yml index ef4c917f8b1..64c98408802 100644 --- a/.github/workflows/cluster_endtoend_vreplication_migrate.yml +++ b/.github/workflows/cluster_endtoend_vreplication_migrate.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vreplication_migrate) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_migrate_vdiff2_convert_tz.yml b/.github/workflows/cluster_endtoend_vreplication_migrate_vdiff2_convert_tz.yml index 8f22b74f779..c81cc0ab175 100644 --- a/.github/workflows/cluster_endtoend_vreplication_migrate_vdiff2_convert_tz.yml +++ b/.github/workflows/cluster_endtoend_vreplication_migrate_vdiff2_convert_tz.yml @@ -14,7 +14,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (vreplication_migrate_vdiff2_convert_tz) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_multicell.yml b/.github/workflows/cluster_endtoend_vreplication_multicell.yml index 0ba0bcd1d70..a9f72b82851 100644 --- a/.github/workflows/cluster_endtoend_vreplication_multicell.yml +++ b/.github/workflows/cluster_endtoend_vreplication_multicell.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vreplication_multicell) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vreplication_v2.yml b/.github/workflows/cluster_endtoend_vreplication_v2.yml index ab24652d7df..8a54dee12b5 100644 --- a/.github/workflows/cluster_endtoend_vreplication_v2.yml +++ b/.github/workflows/cluster_endtoend_vreplication_v2.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vreplication_v2) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vstream_failover.yml b/.github/workflows/cluster_endtoend_vstream_failover.yml index 55d7da6100b..eac66109e74 100644 --- a/.github/workflows/cluster_endtoend_vstream_failover.yml +++ b/.github/workflows/cluster_endtoend_vstream_failover.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vstream_failover) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vstream_stoponreshard_false.yml b/.github/workflows/cluster_endtoend_vstream_stoponreshard_false.yml index df046d47b99..3c52e15432b 100644 --- a/.github/workflows/cluster_endtoend_vstream_stoponreshard_false.yml +++ b/.github/workflows/cluster_endtoend_vstream_stoponreshard_false.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vstream_stoponreshard_false) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vstream_stoponreshard_true.yml b/.github/workflows/cluster_endtoend_vstream_stoponreshard_true.yml index 2b15a2d4b73..52d6048e271 100644 --- a/.github/workflows/cluster_endtoend_vstream_stoponreshard_true.yml +++ b/.github/workflows/cluster_endtoend_vstream_stoponreshard_true.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vstream_stoponreshard_true) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vstream_with_keyspaces_to_watch.yml b/.github/workflows/cluster_endtoend_vstream_with_keyspaces_to_watch.yml index f7a1748cf34..0fc8c707275 100644 --- a/.github/workflows/cluster_endtoend_vstream_with_keyspaces_to_watch.yml +++ b/.github/workflows/cluster_endtoend_vstream_with_keyspaces_to_watch.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vstream_with_keyspaces_to_watch) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtbackup_transform.yml b/.github/workflows/cluster_endtoend_vtbackup_transform.yml index e72f35573e3..7525f11137c 100644 --- a/.github/workflows/cluster_endtoend_vtbackup_transform.yml +++ b/.github/workflows/cluster_endtoend_vtbackup_transform.yml @@ -14,7 +14,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (vtbackup_transform) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtctlbackup_sharded_clustertest_heavy.yml b/.github/workflows/cluster_endtoend_vtctlbackup_sharded_clustertest_heavy.yml index 4182f0b6eaf..72519a34f1d 100644 --- a/.github/workflows/cluster_endtoend_vtctlbackup_sharded_clustertest_heavy.yml +++ b/.github/workflows/cluster_endtoend_vtctlbackup_sharded_clustertest_heavy.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtctlbackup_sharded_clustertest_heavy) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_concurrentdml.yml b/.github/workflows/cluster_endtoend_vtgate_concurrentdml.yml index ce3f8da8632..accd238f471 100644 --- a/.github/workflows/cluster_endtoend_vtgate_concurrentdml.yml +++ b/.github/workflows/cluster_endtoend_vtgate_concurrentdml.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_concurrentdml) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_gen4.yml b/.github/workflows/cluster_endtoend_vtgate_gen4.yml index 0475e9907ee..b28b34e0a97 100644 --- a/.github/workflows/cluster_endtoend_vtgate_gen4.yml +++ b/.github/workflows/cluster_endtoend_vtgate_gen4.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_gen4) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_general_heavy.yml b/.github/workflows/cluster_endtoend_vtgate_general_heavy.yml index 6b666bcda80..e8e713be63c 100644 --- a/.github/workflows/cluster_endtoend_vtgate_general_heavy.yml +++ b/.github/workflows/cluster_endtoend_vtgate_general_heavy.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_general_heavy) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_godriver.yml b/.github/workflows/cluster_endtoend_vtgate_godriver.yml index a899c23e1dc..428bf5fcfaa 100644 --- a/.github/workflows/cluster_endtoend_vtgate_godriver.yml +++ b/.github/workflows/cluster_endtoend_vtgate_godriver.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_godriver) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_partial_keyspace.yml b/.github/workflows/cluster_endtoend_vtgate_partial_keyspace.yml index 9961b4f8155..629c99d3c55 100644 --- a/.github/workflows/cluster_endtoend_vtgate_partial_keyspace.yml +++ b/.github/workflows/cluster_endtoend_vtgate_partial_keyspace.yml @@ -14,7 +14,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (vtgate_partial_keyspace) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_queries.yml b/.github/workflows/cluster_endtoend_vtgate_queries.yml index e5eb99e6925..65d3596e6d4 100644 --- a/.github/workflows/cluster_endtoend_vtgate_queries.yml +++ b/.github/workflows/cluster_endtoend_vtgate_queries.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_queries) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_readafterwrite.yml b/.github/workflows/cluster_endtoend_vtgate_readafterwrite.yml index 95d19c772c7..76aa312c0cf 100644 --- a/.github/workflows/cluster_endtoend_vtgate_readafterwrite.yml +++ b/.github/workflows/cluster_endtoend_vtgate_readafterwrite.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_readafterwrite) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_reservedconn.yml b/.github/workflows/cluster_endtoend_vtgate_reservedconn.yml index 1891208ab9f..2755775f14f 100644 --- a/.github/workflows/cluster_endtoend_vtgate_reservedconn.yml +++ b/.github/workflows/cluster_endtoend_vtgate_reservedconn.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_reservedconn) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_schema.yml b/.github/workflows/cluster_endtoend_vtgate_schema.yml index 1fc2547884c..2169fd34e63 100644 --- a/.github/workflows/cluster_endtoend_vtgate_schema.yml +++ b/.github/workflows/cluster_endtoend_vtgate_schema.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_schema) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_schema_tracker.yml b/.github/workflows/cluster_endtoend_vtgate_schema_tracker.yml index f4ac5501585..3b07fd2c521 100644 --- a/.github/workflows/cluster_endtoend_vtgate_schema_tracker.yml +++ b/.github/workflows/cluster_endtoend_vtgate_schema_tracker.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_schema_tracker) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_tablet_healthcheck_cache.yml b/.github/workflows/cluster_endtoend_vtgate_tablet_healthcheck_cache.yml index 311caaf42fc..333c060a618 100644 --- a/.github/workflows/cluster_endtoend_vtgate_tablet_healthcheck_cache.yml +++ b/.github/workflows/cluster_endtoend_vtgate_tablet_healthcheck_cache.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_tablet_healthcheck_cache) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_topo.yml b/.github/workflows/cluster_endtoend_vtgate_topo.yml index c849567be6c..33f27e2157e 100644 --- a/.github/workflows/cluster_endtoend_vtgate_topo.yml +++ b/.github/workflows/cluster_endtoend_vtgate_topo.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_topo) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_topo_consul.yml b/.github/workflows/cluster_endtoend_vtgate_topo_consul.yml index 3fb0055d0ad..100e079612a 100644 --- a/.github/workflows/cluster_endtoend_vtgate_topo_consul.yml +++ b/.github/workflows/cluster_endtoend_vtgate_topo_consul.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_topo_consul) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_topo_etcd.yml b/.github/workflows/cluster_endtoend_vtgate_topo_etcd.yml index fefe613b75b..a066346ad14 100644 --- a/.github/workflows/cluster_endtoend_vtgate_topo_etcd.yml +++ b/.github/workflows/cluster_endtoend_vtgate_topo_etcd.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_topo_etcd) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_transaction.yml b/.github/workflows/cluster_endtoend_vtgate_transaction.yml index e5f077b257b..aafee540536 100644 --- a/.github/workflows/cluster_endtoend_vtgate_transaction.yml +++ b/.github/workflows/cluster_endtoend_vtgate_transaction.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_transaction) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_unsharded.yml b/.github/workflows/cluster_endtoend_vtgate_unsharded.yml index c0c28744dbb..7851a67c7ee 100644 --- a/.github/workflows/cluster_endtoend_vtgate_unsharded.yml +++ b/.github/workflows/cluster_endtoend_vtgate_unsharded.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_unsharded) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_vindex_heavy.yml b/.github/workflows/cluster_endtoend_vtgate_vindex_heavy.yml index 9689d8c766e..5504ddaee95 100644 --- a/.github/workflows/cluster_endtoend_vtgate_vindex_heavy.yml +++ b/.github/workflows/cluster_endtoend_vtgate_vindex_heavy.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_vindex_heavy) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtgate_vschema.yml b/.github/workflows/cluster_endtoend_vtgate_vschema.yml index a9e492dca8e..083d03769b9 100644 --- a/.github/workflows/cluster_endtoend_vtgate_vschema.yml +++ b/.github/workflows/cluster_endtoend_vtgate_vschema.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtgate_vschema) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtorc.yml b/.github/workflows/cluster_endtoend_vtorc.yml index e855284e7c7..33f76d33c40 100644 --- a/.github/workflows/cluster_endtoend_vtorc.yml +++ b/.github/workflows/cluster_endtoend_vtorc.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtorc) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_vtorc_8.0.yml b/.github/workflows/cluster_endtoend_vtorc_8.0.yml index 4ed50e519d4..8a248c8eeca 100644 --- a/.github/workflows/cluster_endtoend_vtorc_8.0.yml +++ b/.github/workflows/cluster_endtoend_vtorc_8.0.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (vtorc_8.0) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_worker_vault_heavy.yml b/.github/workflows/cluster_endtoend_worker_vault_heavy.yml index 459d5650018..a4492e83347 100644 --- a/.github/workflows/cluster_endtoend_worker_vault_heavy.yml +++ b/.github/workflows/cluster_endtoend_worker_vault_heavy.yml @@ -9,7 +9,8 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (worker_vault_heavy) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_xb_backup.yml b/.github/workflows/cluster_endtoend_xb_backup.yml index dd9179cb78d..c31906ef629 100644 --- a/.github/workflows/cluster_endtoend_xb_backup.yml +++ b/.github/workflows/cluster_endtoend_xb_backup.yml @@ -14,7 +14,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (xb_backup) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_xb_backup_mysql57.yml b/.github/workflows/cluster_endtoend_xb_backup_mysql57.yml index d6b159cdf72..3372ef8e048 100644 --- a/.github/workflows/cluster_endtoend_xb_backup_mysql57.yml +++ b/.github/workflows/cluster_endtoend_xb_backup_mysql57.yml @@ -18,7 +18,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (xb_backup) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_xb_recovery.yml b/.github/workflows/cluster_endtoend_xb_recovery.yml index 23c1228cf92..7d5cfbbd6e4 100644 --- a/.github/workflows/cluster_endtoend_xb_recovery.yml +++ b/.github/workflows/cluster_endtoend_xb_recovery.yml @@ -14,7 +14,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (xb_recovery) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_endtoend_xb_recovery_mysql57.yml b/.github/workflows/cluster_endtoend_xb_recovery_mysql57.yml index 4a6653121f8..bf10dd2222e 100644 --- a/.github/workflows/cluster_endtoend_xb_recovery_mysql57.yml +++ b/.github/workflows/cluster_endtoend_xb_recovery_mysql57.yml @@ -18,7 +18,8 @@ env: jobs: build: name: Run endtoend tests on Cluster (xb_recovery) mysql57 - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/cluster_initial_sharding_multi.yml b/.github/workflows/cluster_initial_sharding_multi.yml index e8ea8a44edf..b04f1aaf177 100644 --- a/.github/workflows/cluster_initial_sharding_multi.yml +++ b/.github/workflows/cluster_initial_sharding_multi.yml @@ -4,7 +4,8 @@ jobs: build: name: cluster initial sharding multi - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/docker_test_cluster_10.yml b/.github/workflows/docker_test_cluster_10.yml index ba587d6aa8b..993e8aa8c50 100644 --- a/.github/workflows/docker_test_cluster_10.yml +++ b/.github/workflows/docker_test_cluster_10.yml @@ -4,7 +4,8 @@ jobs: build: name: Docker Test Cluster 10 - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/docker_test_cluster_25.yml b/.github/workflows/docker_test_cluster_25.yml index 4e0311c751d..1b45c166ac7 100644 --- a/.github/workflows/docker_test_cluster_25.yml +++ b/.github/workflows/docker_test_cluster_25.yml @@ -4,7 +4,8 @@ jobs: build: name: Docker Test Cluster 25 - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/e2e_race.yml b/.github/workflows/e2e_race.yml index fa45b9aee4e..ba4558d98a0 100644 --- a/.github/workflows/e2e_race.yml +++ b/.github/workflows/e2e_race.yml @@ -4,7 +4,8 @@ jobs: build: name: End-to-End Test (Race) - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped id: skip-workflow diff --git a/.github/workflows/endtoend.yml b/.github/workflows/endtoend.yml index bc6d21eef67..cd48075c270 100644 --- a/.github/workflows/endtoend.yml +++ b/.github/workflows/endtoend.yml @@ -4,7 +4,8 @@ jobs: build: name: End-to-End Test - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped id: skip-workflow diff --git a/.github/workflows/unit_race.yml b/.github/workflows/unit_race.yml index e9ed81e360c..790c0137c4c 100644 --- a/.github/workflows/unit_race.yml +++ b/.github/workflows/unit_race.yml @@ -8,7 +8,8 @@ jobs: build: name: Unit Test (Race) - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped id: skip-workflow diff --git a/.github/workflows/unit_test_mysql57.yml b/.github/workflows/unit_test_mysql57.yml index b69cc0db5f0..e8870c617b1 100644 --- a/.github/workflows/unit_test_mysql57.yml +++ b/.github/workflows/unit_test_mysql57.yml @@ -8,7 +8,8 @@ concurrency: jobs: test: - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/unit_test_mysql80.yml b/.github/workflows/unit_test_mysql80.yml index f4c7cbf9ca3..5a3e218da4a 100644 --- a/.github/workflows/unit_test_mysql80.yml +++ b/.github/workflows/unit_test_mysql80.yml @@ -8,7 +8,8 @@ concurrency: jobs: test: - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/.github/workflows/upgrade_downgrade_test_backups_e2e.yml b/.github/workflows/upgrade_downgrade_test_backups_e2e.yml index daf1af32a2a..2db8091d69f 100644 --- a/.github/workflows/upgrade_downgrade_test_backups_e2e.yml +++ b/.github/workflows/upgrade_downgrade_test_backups_e2e.yml @@ -11,7 +11,8 @@ jobs: get_previous_release: if: always() name: Get Previous Release - Backups - E2E - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_upgrade_downgrade_label outputs: @@ -34,7 +35,8 @@ jobs: timeout-minutes: 60 if: always() && needs.get_previous_release.result == 'success' name: Run Upgrade Downgrade Test - Backups - E2E - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 needs: - get_previous_release diff --git a/.github/workflows/upgrade_downgrade_test_backups_e2e_next_release.yml b/.github/workflows/upgrade_downgrade_test_backups_e2e_next_release.yml index e7c8d42ebdc..67597378e38 100644 --- a/.github/workflows/upgrade_downgrade_test_backups_e2e_next_release.yml +++ b/.github/workflows/upgrade_downgrade_test_backups_e2e_next_release.yml @@ -11,7 +11,8 @@ jobs: get_next_release: if: always() name: Get Latest Release - Backups - E2E - Next Release - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: next_release: ${{ steps.output-next-release-ref.outputs.next_release_ref }} @@ -32,7 +33,8 @@ jobs: timeout-minutes: 60 if: always() && needs.get_next_release.result == 'success' name: Run Upgrade Downgrade Test - Backups - E2E - Next Release - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 needs: - get_next_release diff --git a/.github/workflows/upgrade_downgrade_test_backups_manual.yml b/.github/workflows/upgrade_downgrade_test_backups_manual.yml index dc61c682a6b..d2ff4690581 100644 --- a/.github/workflows/upgrade_downgrade_test_backups_manual.yml +++ b/.github/workflows/upgrade_downgrade_test_backups_manual.yml @@ -11,7 +11,8 @@ jobs: get_previous_release: if: always() name: Get Previous Release - Backups - Manual - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: previous_release: ${{ steps.output-previous-release-ref.outputs.previous_release_ref }} @@ -33,7 +34,8 @@ jobs: timeout-minutes: 40 if: always() && (needs.get_previous_release.result == 'success') name: Run Upgrade Downgrade Test - Backups - Manual - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 needs: - get_previous_release diff --git a/.github/workflows/upgrade_downgrade_test_backups_manual_next_release.yml b/.github/workflows/upgrade_downgrade_test_backups_manual_next_release.yml index c6d1f6b6d93..cfd545c3b61 100644 --- a/.github/workflows/upgrade_downgrade_test_backups_manual_next_release.yml +++ b/.github/workflows/upgrade_downgrade_test_backups_manual_next_release.yml @@ -11,7 +11,8 @@ jobs: get_next_release: if: always() name: Get Previous Release - Backups - Manual - Next Release - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 outputs: next_release: ${{ steps.output-next-release-ref.outputs.next_release_ref }} @@ -33,7 +34,8 @@ jobs: timeout-minutes: 40 if: always() && (needs.get_next_release.result == 'success') name: Run Upgrade Downgrade Test - Backups - Manual - Next Release - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 needs: - get_next_release diff --git a/.github/workflows/upgrade_downgrade_test_query_serving_queries.yml b/.github/workflows/upgrade_downgrade_test_query_serving_queries.yml index afbecc8aca1..e3677245d4a 100644 --- a/.github/workflows/upgrade_downgrade_test_query_serving_queries.yml +++ b/.github/workflows/upgrade_downgrade_test_query_serving_queries.yml @@ -14,7 +14,8 @@ jobs: get_previous_release: if: always() name: Get Previous Release - Query Serving (Queries) - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: previous_release: ${{ steps.output-previous-release-ref.outputs.previous_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_previous_release.result == 'success') name: Run Upgrade Downgrade Test - Query Serving (Queries) - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_previous_release diff --git a/.github/workflows/upgrade_downgrade_test_query_serving_queries_next_release.yml b/.github/workflows/upgrade_downgrade_test_query_serving_queries_next_release.yml index 9086344400b..f0b14d51fb9 100644 --- a/.github/workflows/upgrade_downgrade_test_query_serving_queries_next_release.yml +++ b/.github/workflows/upgrade_downgrade_test_query_serving_queries_next_release.yml @@ -14,7 +14,8 @@ jobs: get_next_release: if: always() name: Get Latest Release - Query Serving (Queries) Next Release - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: next_release: ${{ steps.output-next-release-ref.outputs.next_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_next_release.result == 'success') name: Run Upgrade Downgrade Test - Query Serving (Queries) Next Release - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_next_release diff --git a/.github/workflows/upgrade_downgrade_test_query_serving_schema.yml b/.github/workflows/upgrade_downgrade_test_query_serving_schema.yml index a49d513f39b..e4158a85509 100644 --- a/.github/workflows/upgrade_downgrade_test_query_serving_schema.yml +++ b/.github/workflows/upgrade_downgrade_test_query_serving_schema.yml @@ -14,7 +14,8 @@ jobs: get_previous_release: if: always() name: Get Previous Release - Query Serving (Schema) - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: previous_release: ${{ steps.output-previous-release-ref.outputs.previous_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_previous_release.result == 'success') name: Run Upgrade Downgrade Test - Query Serving (Schema) - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_previous_release diff --git a/.github/workflows/upgrade_downgrade_test_query_serving_schema_next_release.yml b/.github/workflows/upgrade_downgrade_test_query_serving_schema_next_release.yml index a87aa824563..ef79c0d60af 100644 --- a/.github/workflows/upgrade_downgrade_test_query_serving_schema_next_release.yml +++ b/.github/workflows/upgrade_downgrade_test_query_serving_schema_next_release.yml @@ -14,7 +14,8 @@ jobs: get_next_release: if: always() name: Get Latest Release - Query Serving (Schema) Next Release - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: next_release: ${{ steps.output-next-release-ref.outputs.next_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_next_release.result == 'success') name: Run Upgrade Downgrade Test - Query Serving (Schema) Next Release - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_next_release diff --git a/.github/workflows/upgrade_downgrade_test_reparent_new_vtctl.yml b/.github/workflows/upgrade_downgrade_test_reparent_new_vtctl.yml index b722220b340..25045ade7e2 100644 --- a/.github/workflows/upgrade_downgrade_test_reparent_new_vtctl.yml +++ b/.github/workflows/upgrade_downgrade_test_reparent_new_vtctl.yml @@ -14,7 +14,8 @@ jobs: get_next_release: if: always() name: Get Latest Release - Reparent New Vtctl - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: next_release: ${{ steps.output-next-release-ref.outputs.next_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_next_release.result == 'success') name: Run Upgrade Downgrade Test - Reparent New Vtctl - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_next_release diff --git a/.github/workflows/upgrade_downgrade_test_reparent_new_vttablet.yml b/.github/workflows/upgrade_downgrade_test_reparent_new_vttablet.yml index a3b7ff67a23..8aa4b8ec5e7 100644 --- a/.github/workflows/upgrade_downgrade_test_reparent_new_vttablet.yml +++ b/.github/workflows/upgrade_downgrade_test_reparent_new_vttablet.yml @@ -14,7 +14,8 @@ jobs: get_next_release: if: always() name: Get Latest Release - Reparent New VTTablet - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: next_release: ${{ steps.output-next-release-ref.outputs.next_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_next_release.result == 'success') name: Run Upgrade Downgrade Test - Reparent New VTTablet - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_next_release diff --git a/.github/workflows/upgrade_downgrade_test_reparent_old_vtctl.yml b/.github/workflows/upgrade_downgrade_test_reparent_old_vtctl.yml index c1ec4153681..0fb2fccee59 100644 --- a/.github/workflows/upgrade_downgrade_test_reparent_old_vtctl.yml +++ b/.github/workflows/upgrade_downgrade_test_reparent_old_vtctl.yml @@ -14,7 +14,8 @@ jobs: get_previous_release: if: always() name: Get Previous Release - Reparent Old Vtctl - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: previous_release: ${{ steps.output-previous-release-ref.outputs.previous_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_previous_release.result == 'success') name: Run Upgrade Downgrade Test - Reparent Old Vtctl - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_previous_release diff --git a/.github/workflows/upgrade_downgrade_test_reparent_old_vttablet.yml b/.github/workflows/upgrade_downgrade_test_reparent_old_vttablet.yml index b8a557585be..18e08d504f8 100644 --- a/.github/workflows/upgrade_downgrade_test_reparent_old_vttablet.yml +++ b/.github/workflows/upgrade_downgrade_test_reparent_old_vttablet.yml @@ -14,7 +14,8 @@ jobs: get_previous_release: if: always() name: Get Previous Release - Reparent Old VTTablet - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 outputs: previous_release: ${{ steps.output-previous-release-ref.outputs.previous_release_ref }} @@ -34,7 +35,8 @@ jobs: upgrade_downgrade_test: if: always() && (needs.get_previous_release.result == 'success') name: Run Upgrade Downgrade Test - Reparent Old VTTablet - runs-on: ubuntu-latest + runs-on: + group: vitess-ubuntu20 needs: - get_previous_release diff --git a/test/templates/cluster_endtoend_test.tpl b/test/templates/cluster_endtoend_test.tpl index dd40400d335..3aadd1e550c 100644 --- a/test/templates/cluster_endtoend_test.tpl +++ b/test/templates/cluster_endtoend_test.tpl @@ -14,7 +14,8 @@ env: jobs: build: name: Run endtoend tests on {{.Name}} - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/test/templates/cluster_endtoend_test_docker.tpl b/test/templates/cluster_endtoend_test_docker.tpl index 68810827196..6973ce98400 100644 --- a/test/templates/cluster_endtoend_test_docker.tpl +++ b/test/templates/cluster_endtoend_test_docker.tpl @@ -4,7 +4,8 @@ on: [push, pull_request] jobs: build: name: Run endtoend tests on {{.Name}} - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/test/templates/cluster_endtoend_test_mysql57.tpl b/test/templates/cluster_endtoend_test_mysql57.tpl index bca88449154..f3c8d63c1dc 100644 --- a/test/templates/cluster_endtoend_test_mysql57.tpl +++ b/test/templates/cluster_endtoend_test_mysql57.tpl @@ -7,7 +7,8 @@ concurrency: jobs: build: name: Run endtoend tests on {{.Name}} - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 timeout-minutes: 45 steps: diff --git a/test/templates/cluster_endtoend_test_self_hosted.tpl b/test/templates/cluster_endtoend_test_self_hosted.tpl index df2fc596577..e7e4f714caf 100644 --- a/test/templates/cluster_endtoend_test_self_hosted.tpl +++ b/test/templates/cluster_endtoend_test_self_hosted.tpl @@ -7,7 +7,8 @@ concurrency: jobs: build: name: Run endtoend tests on {{.Name}} - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/test/templates/unit_test.tpl b/test/templates/unit_test.tpl index da85be9785b..78b4b53fc7e 100644 --- a/test/templates/unit_test.tpl +++ b/test/templates/unit_test.tpl @@ -6,7 +6,8 @@ concurrency: jobs: test: - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped diff --git a/test/templates/unit_test_self_hosted.tpl b/test/templates/unit_test_self_hosted.tpl index ae98971726c..c359dfb59e4 100644 --- a/test/templates/unit_test_self_hosted.tpl +++ b/test/templates/unit_test_self_hosted.tpl @@ -6,7 +6,8 @@ concurrency: jobs: test: - runs-on: ubuntu-20.04 + runs-on: + group: vitess-ubuntu20 steps: - name: Check if workflow needs to be skipped From 10c85156fe71619ef5dbaa6cdbb4c32a63bc7ce7 Mon Sep 17 00:00:00 2001 From: "Eduardo J. Ortega U" <5791035+ejortegau@users.noreply.github.com> Date: Thu, 3 Aug 2023 13:40:12 +0200 Subject: [PATCH 7/7] Revert change of runner type for shardedrecovery_stress_verticalsplit_heavy. (#116) We do this because the test is taking a lot longer & failing in some cases with the larger runner. Signed-off-by: Eduardo J. Ortega U <5791035+ejortegau@users.noreply.github.com> --- ...ter_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml | 3 +-- 1 file changed, 1 insertion(+), 2 deletions(-) diff --git a/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml b/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml index 4c92ffdc575..75f984e5623 100644 --- a/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml +++ b/.github/workflows/cluster_endtoend_shardedrecovery_stress_verticalsplit_heavy.yml @@ -9,8 +9,7 @@ concurrency: jobs: build: name: Run endtoend tests on Cluster (shardedrecovery_stress_verticalsplit_heavy) - runs-on: - group: vitess-ubuntu20 + runs-on: ubuntu-20.04 steps: - name: Check if workflow needs to be skipped