Skip to content

Commit

Permalink
tests: Cleanup endpoints
Browse files Browse the repository at this point in the history
Signed-off-by: Marek Siarkowicz <[email protected]>
  • Loading branch information
serathius committed Apr 3, 2023
1 parent 7c7f636 commit 0cbd56e
Show file tree
Hide file tree
Showing 25 changed files with 53 additions and 67 deletions.
4 changes: 2 additions & 2 deletions tests/e2e/cluster_downgrade_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -155,7 +155,7 @@ func startEtcd(t *testing.T, ep e2e.EtcdProcess, execPath string) {
}

func downgradeEnable(t *testing.T, epc *e2e.EtcdProcessCluster, ver *semver.Version) {
c, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
c, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)
testutils.ExecuteWithTimeout(t, 20*time.Second, func() {
err := c.DowngradeEnable(context.TODO(), ver.String())
Expand Down Expand Up @@ -195,7 +195,7 @@ func leader(t *testing.T, epc *e2e.EtcdProcessCluster) e2e.EtcdProcess {
ctx, cancel := context.WithTimeout(context.Background(), time.Second*10)
defer cancel()
for i := 0; i < len(epc.Procs); i++ {
endpoints := epc.Procs[i].EndpointsV3()
endpoints := epc.Procs[i].EndpointsGRPC()
cli, err := clientv3.New(clientv3.Config{
Endpoints: endpoints,
DialTimeout: 3 * time.Second,
Expand Down
6 changes: 3 additions & 3 deletions tests/e2e/corrupt_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -61,7 +61,7 @@ func corruptTest(cx ctlCtx) {
time.Sleep(3 * time.Second)

cx.t.Log("connecting clientv3...")
eps := cx.epc.EndpointsV3()
eps := cx.epc.EndpointsGRPC()
cli1, err := clientv3.New(clientv3.Config{Endpoints: []string{eps[1]}, DialTimeout: 3 * time.Second})
if err != nil {
cx.t.Fatal(err)
Expand Down Expand Up @@ -116,7 +116,7 @@ func TestPeriodicCheckDetectsCorruption(t *testing.T) {
}
})

cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)

for i := 0; i < 10; i++ {
Expand Down Expand Up @@ -164,7 +164,7 @@ func TestCompactHashCheckDetectCorruption(t *testing.T) {
}
})

cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)

for i := 0; i < 10; i++ {
Expand Down
4 changes: 2 additions & 2 deletions tests/e2e/ctl_v3_auth_cluster_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -69,9 +69,9 @@ func TestAuthCluster(t *testing.T) {
}

// make sure writes to both endpoints are successful
endpoints := epc.EndpointsV3()
endpoints := epc.EndpointsGRPC()
assert.Equal(t, len(endpoints), 2)
for _, endpoint := range epc.EndpointsV3() {
for _, endpoint := range epc.EndpointsGRPC() {
if err := epc.Client(testUserClientOpts, e2e.WithEndpoints([]string{endpoint})).Put(ctx, "/test/key", endpoint, config.PutOptions{}); err != nil {
t.Fatalf("failed to write to Put to %q (%v)", endpoint, err)
}
Expand Down
4 changes: 2 additions & 2 deletions tests/e2e/ctl_v3_auth_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -493,7 +493,7 @@ func authTestRevisionConsistency(cx ctlCtx) {

// get node0 auth revision
node0 := cx.epc.Procs[0]
endpoint := node0.EndpointsV3()[0]
endpoint := node0.EndpointsGRPC()[0]
cli, err := clientv3.New(clientv3.Config{Endpoints: []string{endpoint}, Username: cx.user, Password: cx.pass, DialTimeout: 3 * time.Second})
if err != nil {
cx.t.Fatal(err)
Expand Down Expand Up @@ -575,7 +575,7 @@ func authTestCacheReload(cx ctlCtx) {
}

node0 := cx.epc.Procs[0]
endpoint := node0.EndpointsV3()[0]
endpoint := node0.EndpointsGRPC()[0]

// create a client
c, err := clientv3.New(clientv3.Config{Endpoints: []string{endpoint}, DialTimeout: 3 * time.Second})
Expand Down
8 changes: 4 additions & 4 deletions tests/e2e/ctl_v3_move_leader_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -78,7 +78,7 @@ func testCtlV3MoveLeader(t *testing.T, cfg e2e.EtcdProcessClusterConfig, envVars
var leadIdx int
var leaderID uint64
var transferee uint64
for i, ep := range epc.EndpointsV3() {
for i, ep := range epc.EndpointsGRPC() {
cli, err := clientv3.New(clientv3.Config{
Endpoints: []string{ep},
DialTimeout: 3 * time.Second,
Expand Down Expand Up @@ -117,17 +117,17 @@ func testCtlV3MoveLeader(t *testing.T, cfg e2e.EtcdProcessClusterConfig, envVars
expectErr bool
}{
{ // request to non-leader
[]string{cx.epc.EndpointsV3()[(leadIdx+1)%3]},
[]string{cx.epc.EndpointsGRPC()[(leadIdx+1)%3]},
"no leader endpoint given at ",
true,
},
{ // request to leader
[]string{cx.epc.EndpointsV3()[leadIdx]},
[]string{cx.epc.EndpointsGRPC()[leadIdx]},
fmt.Sprintf("Leadership transferred from %s to %s", types.ID(leaderID), types.ID(transferee)),
false,
},
{ // request to all endpoints
cx.epc.EndpointsV3(),
cx.epc.EndpointsGRPC(),
"Leadership transferred",
false,
},
Expand Down
2 changes: 1 addition & 1 deletion tests/e2e/ctl_v3_snapshot_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -186,7 +186,7 @@ func testIssue6361(t *testing.T) {
}()

dialTimeout := 10 * time.Second
prefixArgs := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(epc.EndpointsV3(), ","), "--dial-timeout", dialTimeout.String()}
prefixArgs := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(epc.EndpointsGRPC(), ","), "--dial-timeout", dialTimeout.String()}

t.Log("Writing some keys...")
kvs := []kv{{"foo1", "val1"}, {"foo2", "val2"}, {"foo3", "val3"}}
Expand Down
4 changes: 2 additions & 2 deletions tests/e2e/ctl_v3_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -111,7 +111,7 @@ func TestCtlV3DialWithHTTPScheme(t *testing.T) {
}

func dialWithSchemeTest(cx ctlCtx) {
cmdArgs := append(cx.prefixArgs(cx.epc.EndpointsV3()), "put", "foo", "bar")
cmdArgs := append(cx.prefixArgs(cx.epc.EndpointsGRPC()), "put", "foo", "bar")
if err := e2e.SpawnWithExpectWithEnv(cmdArgs, cx.envMap, "OK"); err != nil {
cx.t.Fatal(err)
}
Expand Down Expand Up @@ -331,7 +331,7 @@ func (cx *ctlCtx) prefixArgs(eps []string) []string {
// PrefixArgs prefixes etcdctl command.
// Make sure to unset environment variables after tests.
func (cx *ctlCtx) PrefixArgs() []string {
return cx.prefixArgs(cx.epc.EndpointsV3())
return cx.prefixArgs(cx.epc.EndpointsGRPC())
}

// PrefixArgsUtl returns prefix of the command that is etcdutl
Expand Down
6 changes: 3 additions & 3 deletions tests/e2e/discovery_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -53,7 +53,7 @@ func testClusterUsingDiscovery(t *testing.T, size int, peerTLS bool) {
}
defer dc.Close()

dcc := MustNewHTTPClient(t, dc.EndpointsV2(), nil)
dcc := MustNewHTTPClient(t, dc.EndpointsHTTP(), nil)
dkapi := client.NewKeysAPI(dcc)
ctx, cancel := context.WithTimeout(context.Background(), integration.RequestTimeout)
if _, err := dkapi.Create(ctx, "/_config/size", fmt.Sprintf("%d", size)); err != nil {
Expand All @@ -65,14 +65,14 @@ func testClusterUsingDiscovery(t *testing.T, size int, peerTLS bool) {
e2e.WithBasePort(3000),
e2e.WithClusterSize(size),
e2e.WithIsPeerTLS(peerTLS),
e2e.WithDiscovery(dc.EndpointsV2()[0]+"/v2/keys"),
e2e.WithDiscovery(dc.EndpointsHTTP()[0]+"/v2/keys"),
)
if err != nil {
t.Fatalf("could not start etcd process cluster (%v)", err)
}
defer c.Close()

kubectl := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(c.EndpointsV3(), ",")}
kubectl := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(c.EndpointsGRPC(), ",")}
if err := e2e.SpawnWithExpect(append(kubectl, "put", "key", "value"), "OK"); err != nil {
t.Fatal(err)
}
Expand Down
4 changes: 2 additions & 2 deletions tests/e2e/discovery_v3_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -68,14 +68,14 @@ func testClusterUsingV3Discovery(t *testing.T, discoveryClusterSize, targetClust
}

// step 3: start the etcd cluster
epc, err := bootstrapEtcdClusterUsingV3Discovery(t, ds.EndpointsV3(), discoveryToken, targetClusterSize, clientTlsType, isClientAutoTls)
epc, err := bootstrapEtcdClusterUsingV3Discovery(t, ds.EndpointsGRPC(), discoveryToken, targetClusterSize, clientTlsType, isClientAutoTls)
if err != nil {
t.Fatalf("could not start etcd process cluster (%v)", err)
}
defer epc.Close()

// step 4: sanity test on the etcd cluster
etcdctl := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(epc.EndpointsV3(), ",")}
etcdctl := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(epc.EndpointsGRPC(), ",")}
if err := e2e.SpawnWithExpect(append(etcdctl, "put", "key", "value"), "OK"); err != nil {
t.Fatal(err)
}
Expand Down
2 changes: 1 addition & 1 deletion tests/e2e/etcd_config_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -411,7 +411,7 @@ func TestEtcdHealthyWithTinySnapshotCatchupEntries(t *testing.T) {
for i := 0; i < 10; i++ {
clientId := i
g.Go(func() error {
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
if err != nil {
return err
}
Expand Down
2 changes: 1 addition & 1 deletion tests/e2e/gateway_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -34,7 +34,7 @@ func TestGateway(t *testing.T) {
}
defer ec.Stop()

eps := strings.Join(ec.EndpointsV3(), ",")
eps := strings.Join(ec.EndpointsGRPC(), ",")

p := startGateway(t, eps)
defer func() {
Expand Down
4 changes: 2 additions & 2 deletions tests/e2e/promote_experimental_flag_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -42,7 +42,7 @@ func TestWarningApplyDuration(t *testing.T) {
}
})

cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
require.NoError(t, err)
err = cc.Put(context.TODO(), "foo", "bar", config.PutOptions{})
assert.NoError(t, err, "error on put")
Expand Down Expand Up @@ -70,7 +70,7 @@ func TestExperimentalWarningApplyDuration(t *testing.T) {
}
})

cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
require.NoError(t, err)
err = cc.Put(context.TODO(), "foo", "bar", config.PutOptions{})
assert.NoError(t, err, "error on put")
Expand Down
2 changes: 1 addition & 1 deletion tests/e2e/utl_migrate_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -135,7 +135,7 @@ func TestEtctlutlMigrate(t *testing.T) {
}()

dialTimeout := 10 * time.Second
prefixArgs := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(epc.EndpointsV3(), ","), "--dial-timeout", dialTimeout.String()}
prefixArgs := []string{e2e.BinPath.Etcdctl, "--endpoints", strings.Join(epc.EndpointsGRPC(), ","), "--dial-timeout", dialTimeout.String()}

t.Log("Write keys to ensure wal snapshot is created and all v3.5 fields are set...")
for i := 0; i < 10; i++ {
Expand Down
8 changes: 4 additions & 4 deletions tests/e2e/v2store_deprecation_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -115,13 +115,13 @@ func TestV2DeprecationSnapshotMatches(t *testing.T) {
var snapshotCount uint64 = 10
epc := runEtcdAndCreateSnapshot(t, e2e.LastVersion, lastReleaseData, snapshotCount)
oldMemberDataDir := epc.Procs[0].Config().DataDirPath
cc1, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc1, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)
members1 := addAndRemoveKeysAndMembers(ctx, t, cc1, snapshotCount)
assert.NoError(t, epc.Close())
epc = runEtcdAndCreateSnapshot(t, e2e.CurrentVersion, currentReleaseData, snapshotCount)
newMemberDataDir := epc.Procs[0].Config().DataDirPath
cc2, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc2, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)
members2 := addAndRemoveKeysAndMembers(ctx, t, cc2, snapshotCount)
assert.NoError(t, epc.Close())
Expand Down Expand Up @@ -152,7 +152,7 @@ func TestV2DeprecationSnapshotRecover(t *testing.T) {
}
epc := runEtcdAndCreateSnapshot(t, e2e.LastVersion, dataDir, 10)

cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err := e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)

lastReleaseGetResponse, err := cc.Get(ctx, "", config.GetOptions{Prefix: true})
Expand All @@ -169,7 +169,7 @@ func TestV2DeprecationSnapshotRecover(t *testing.T) {
epc, err = e2e.NewEtcdProcessCluster(context.TODO(), t, e2e.WithConfig(cfg))
assert.NoError(t, err)

cc, err = e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3())
cc, err = e2e.NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC())
assert.NoError(t, err)
currentReleaseGetResponse, err := cc.Get(ctx, "", config.GetOptions{Prefix: true})
assert.NoError(t, err)
Expand Down
6 changes: 3 additions & 3 deletions tests/e2e/watch_delay_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -89,7 +89,7 @@ func TestWatchDelayForPeriodicProgressNotification(t *testing.T) {
clus, err := e2e.NewEtcdProcessCluster(context.Background(), t, e2e.WithConfig(&tc.config))
require.NoError(t, err)
defer clus.Close()
c := newClient(t, clus.EndpointsV3(), tc.config.Client)
c := newClient(t, clus.EndpointsGRPC(), tc.config.Client)
require.NoError(t, fillEtcdWithData(context.Background(), c, tc.dbSizeBytes))

ctx, cancel := context.WithTimeout(context.Background(), watchTestDuration)
Expand All @@ -109,7 +109,7 @@ func TestWatchDelayForManualProgressNotification(t *testing.T) {
clus, err := e2e.NewEtcdProcessCluster(context.Background(), t, e2e.WithConfig(&tc.config))
require.NoError(t, err)
defer clus.Close()
c := newClient(t, clus.EndpointsV3(), tc.config.Client)
c := newClient(t, clus.EndpointsGRPC(), tc.config.Client)
require.NoError(t, fillEtcdWithData(context.Background(), c, tc.dbSizeBytes))

ctx, cancel := context.WithTimeout(context.Background(), watchTestDuration)
Expand Down Expand Up @@ -142,7 +142,7 @@ func TestWatchDelayForEvent(t *testing.T) {
clus, err := e2e.NewEtcdProcessCluster(context.Background(), t, e2e.WithConfig(&tc.config))
require.NoError(t, err)
defer clus.Close()
c := newClient(t, clus.EndpointsV3(), tc.config.Client)
c := newClient(t, clus.EndpointsGRPC(), tc.config.Client)
require.NoError(t, fillEtcdWithData(context.Background(), c, tc.dbSizeBytes))

ctx, cancel := context.WithTimeout(context.Background(), watchTestDuration)
Expand Down
10 changes: 1 addition & 9 deletions tests/framework/e2e/cluster.go
Original file line number Diff line number Diff line change
Expand Up @@ -702,14 +702,6 @@ func (cfg *EtcdProcessClusterConfig) TlsArgs() (args []string) {
return args
}

func (epc *EtcdProcessCluster) EndpointsV2() []string {
return epc.Endpoints(func(ep EtcdProcess) []string { return ep.EndpointsV2() })
}

func (epc *EtcdProcessCluster) EndpointsV3() []string {
return epc.Endpoints(func(ep EtcdProcess) []string { return ep.EndpointsV3() })
}

func (epc *EtcdProcessCluster) EndpointsGRPC() []string {
return epc.Endpoints(func(ep EtcdProcess) []string { return ep.EndpointsGRPC() })
}
Expand Down Expand Up @@ -887,7 +879,7 @@ func (epc *EtcdProcessCluster) Stop() (err error) {
}

func (epc *EtcdProcessCluster) Client(opts ...config.ClientOption) *EtcdctlV3 {
etcdctl, err := NewEtcdctl(epc.Cfg.Client, epc.EndpointsV3(), opts...)
etcdctl, err := NewEtcdctl(epc.Cfg.Client, epc.EndpointsGRPC(), opts...)
if err != nil {
panic(err)
}
Expand Down
4 changes: 1 addition & 3 deletions tests/framework/e2e/cluster_proxy.go
Original file line number Diff line number Diff line change
Expand Up @@ -58,8 +58,6 @@ func NewProxyEtcdProcess(cfg *EtcdServerProcessConfig) (*proxyEtcdProcess, error

func (p *proxyEtcdProcess) Config() *EtcdServerProcessConfig { return p.etcdProc.Config() }

func (p *proxyEtcdProcess) EndpointsV2() []string { return p.EndpointsHTTP() }
func (p *proxyEtcdProcess) EndpointsV3() []string { return p.EndpointsGRPC() }
func (p *proxyEtcdProcess) EndpointsHTTP() []string { return p.proxyV2.endpoints() }
func (p *proxyEtcdProcess) EndpointsGRPC() []string { return p.proxyV3.endpoints() }
func (p *proxyEtcdProcess) EndpointsMetrics() []string {
Expand Down Expand Up @@ -103,7 +101,7 @@ func (p *proxyEtcdProcess) Close() error {
}

func (p *proxyEtcdProcess) Client(opts ...config.ClientOption) *EtcdctlV3 {
etcdctl, err := NewEtcdctl(p.etcdProc.Config().Client, p.etcdProc.EndpointsV3(), opts...)
etcdctl, err := NewEtcdctl(p.etcdProc.Config().Client, p.etcdProc.EndpointsGRPC(), opts...)
if err != nil {
panic(err)
}
Expand Down
6 changes: 3 additions & 3 deletions tests/framework/e2e/e2e.go
Original file line number Diff line number Diff line change
Expand Up @@ -96,12 +96,12 @@ type e2eCluster struct {
}

func (c *e2eCluster) Client(opts ...config.ClientOption) (intf.Client, error) {
etcdctl, err := NewEtcdctl(c.Cfg.Client, c.EndpointsV3(), opts...)
etcdctl, err := NewEtcdctl(c.Cfg.Client, c.EndpointsGRPC(), opts...)
return e2eClient{etcdctl}, err
}

func (c *e2eCluster) Endpoints() []string {
return c.EndpointsV3()
return c.EndpointsGRPC()
}

func (c *e2eCluster) Members() (ms []intf.Member) {
Expand All @@ -121,7 +121,7 @@ type e2eMember struct {
}

func (m e2eMember) Client() intf.Client {
etcdctl, err := NewEtcdctl(m.Cfg.Client, m.EndpointsV3())
etcdctl, err := NewEtcdctl(m.Cfg.Client, m.EndpointsGRPC())
if err != nil {
panic(err)
}
Expand Down
6 changes: 1 addition & 5 deletions tests/framework/e2e/etcd_process.go
Original file line number Diff line number Diff line change
Expand Up @@ -42,8 +42,6 @@ var (

// EtcdProcess is a process that serves etcd requests.
type EtcdProcess interface {
EndpointsV2() []string
EndpointsV3() []string
EndpointsGRPC() []string
EndpointsHTTP() []string
EndpointsMetrics() []string
Expand Down Expand Up @@ -117,8 +115,6 @@ func NewEtcdServerProcess(cfg *EtcdServerProcessConfig) (*EtcdServerProcess, err
return ep, nil
}

func (ep *EtcdServerProcess) EndpointsV2() []string { return ep.EndpointsHTTP() }
func (ep *EtcdServerProcess) EndpointsV3() []string { return ep.EndpointsGRPC() }
func (ep *EtcdServerProcess) EndpointsGRPC() []string { return []string{ep.cfg.ClientURL} }
func (ep *EtcdServerProcess) EndpointsHTTP() []string {
if ep.cfg.ClientHTTPURL == "" {
Expand All @@ -129,7 +125,7 @@ func (ep *EtcdServerProcess) EndpointsHTTP() []string {
func (ep *EtcdServerProcess) EndpointsMetrics() []string { return []string{ep.cfg.MetricsURL} }

func (epc *EtcdServerProcess) Client(opts ...config.ClientOption) *EtcdctlV3 {
etcdctl, err := NewEtcdctl(epc.Config().Client, epc.EndpointsV3(), opts...)
etcdctl, err := NewEtcdctl(epc.Config().Client, epc.EndpointsGRPC(), opts...)
if err != nil {
panic(err)
}
Expand Down
2 changes: 1 addition & 1 deletion tests/integration/clientv3/concurrency/main_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import (

var lazyCluster = integration.NewLazyCluster()

func exampleEndpoints() []string { return lazyCluster.EndpointsV3() }
func exampleEndpoints() []string { return lazyCluster.EndpointsGRPC() }

func forUnitTestsRunInMockedContext(mocking func(), example func()) {
// For integration tests runs in the provided environment
Expand Down
2 changes: 1 addition & 1 deletion tests/integration/clientv3/examples/main_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -36,7 +36,7 @@ var lazyCluster = integration.NewLazyClusterWithConfig(
WatchProgressNotifyInterval: 200 * time.Millisecond,
DisableStrictReconfigCheck: true})

func exampleEndpoints() []string { return lazyCluster.EndpointsV3() }
func exampleEndpoints() []string { return lazyCluster.EndpointsGRPC() }

func forUnitTestsRunInMockedContext(_ func(), example func()) {
// For integration tests runs in the provided environment
Expand Down
Loading

0 comments on commit 0cbd56e

Please sign in to comment.