Skip to content

Commit

Permalink
*: update import paths to "go.etcd.io/etcd"
Browse files Browse the repository at this point in the history
Signed-off-by: Gyuho Lee <leegyuho@amazon.com>
  • Loading branch information
gyuho committed Aug 29, 2018
1 parent 2ac0438 commit d37f152
Show file tree
Hide file tree
Showing 278 changed files with 623 additions and 623 deletions.
2 changes: 1 addition & 1 deletion client/client.go
Original file line number Diff line number Diff line change
Expand Up @@ -29,7 +29,7 @@ import (
"sync"
"time"

"github.com/coreos/etcd/version"
"go.etcd.io/etcd/version"
)

var (
Expand Down
4 changes: 2 additions & 2 deletions client/client_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -29,8 +29,8 @@ import (
"testing"
"time"

"github.com/coreos/etcd/pkg/testutil"
"github.com/coreos/etcd/version"
"go.etcd.io/etcd/pkg/testutil"
"go.etcd.io/etcd/version"
)

type actionAssertingHTTPClient struct {
Expand Down
2 changes: 1 addition & 1 deletion client/discover.go
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@
package client

import (
"github.com/coreos/etcd/pkg/srv"
"go.etcd.io/etcd/pkg/srv"
)

// Discoverer is an interface that wraps the Discover method.
Expand Down
2 changes: 1 addition & 1 deletion client/doc.go
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ Create a Config and exchange it for a Client:
"net/http"
"context"
"github.com/coreos/etcd/client"
"go.etcd.io/etcd/client"
)
cfg := client.Config{
Expand Down
2 changes: 1 addition & 1 deletion client/example_keys_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ import (
"log"
"sort"

"github.com/coreos/etcd/client"
"go.etcd.io/etcd/client"
)

func ExampleKeysAPI_directory() {
Expand Down
6 changes: 3 additions & 3 deletions client/integration/client_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -24,9 +24,9 @@ import (
"sync/atomic"
"testing"

"github.com/coreos/etcd/client"
"github.com/coreos/etcd/integration"
"github.com/coreos/etcd/pkg/testutil"
"go.etcd.io/etcd/client"
"go.etcd.io/etcd/integration"
"go.etcd.io/etcd/pkg/testutil"
)

// TestV2NoRetryEOF tests destructive api calls won't retry on a disconnection.
Expand Down
2 changes: 1 addition & 1 deletion client/integration/main_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@ import (
"os"
"testing"

"github.com/coreos/etcd/pkg/testutil"
"go.etcd.io/etcd/pkg/testutil"
)

func TestMain(m *testing.M) {
Expand Down
2 changes: 1 addition & 1 deletion client/keys.go
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ import (
"strings"
"time"

"github.com/coreos/etcd/pkg/pathutil"
"go.etcd.io/etcd/pkg/pathutil"
"github.com/ugorji/go/codec"
)

Expand Down
6 changes: 3 additions & 3 deletions client/main_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,9 +23,9 @@ import (
"testing"
"time"

"github.com/coreos/etcd/integration"
"github.com/coreos/etcd/pkg/testutil"
"github.com/coreos/etcd/pkg/transport"
"go.etcd.io/etcd/integration"
"go.etcd.io/etcd/pkg/testutil"
"go.etcd.io/etcd/pkg/transport"
)

var exampleEndpoints []string
Expand Down
2 changes: 1 addition & 1 deletion client/members.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ import (
"net/url"
"path"

"github.com/coreos/etcd/pkg/types"
"go.etcd.io/etcd/pkg/types"
)

var (
Expand Down
2 changes: 1 addition & 1 deletion client/members_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ import (
"reflect"
"testing"

"github.com/coreos/etcd/pkg/types"
"go.etcd.io/etcd/pkg/types"
)

func TestMembersAPIActionList(t *testing.T) {
Expand Down
2 changes: 1 addition & 1 deletion contrib/raftexample/httpapi.go
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ import (
"net/http"
"strconv"

"github.com/coreos/etcd/raft/raftpb"
"go.etcd.io/etcd/raft/raftpb"
)

// Handler for a http based key-value store backed by raft
Expand Down
2 changes: 1 addition & 1 deletion contrib/raftexample/kvstore.go
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ import (
"log"
"sync"

"github.com/coreos/etcd/etcdserver/api/snap"
"go.etcd.io/etcd/etcdserver/api/snap"
)

// a key-value store backed by raft
Expand Down
2 changes: 1 addition & 1 deletion contrib/raftexample/main.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"flag"
"strings"

"github.com/coreos/etcd/raft/raftpb"
"go.etcd.io/etcd/raft/raftpb"
)

func main() {
Expand Down
18 changes: 9 additions & 9 deletions contrib/raftexample/raft.go
Original file line number Diff line number Diff line change
Expand Up @@ -24,15 +24,15 @@ import (
"strconv"
"time"

"github.com/coreos/etcd/etcdserver/api/rafthttp"
"github.com/coreos/etcd/etcdserver/api/snap"
stats "github.com/coreos/etcd/etcdserver/api/v2stats"
"github.com/coreos/etcd/pkg/fileutil"
"github.com/coreos/etcd/pkg/types"
"github.com/coreos/etcd/raft"
"github.com/coreos/etcd/raft/raftpb"
"github.com/coreos/etcd/wal"
"github.com/coreos/etcd/wal/walpb"
"go.etcd.io/etcd/etcdserver/api/rafthttp"
"go.etcd.io/etcd/etcdserver/api/snap"
stats "go.etcd.io/etcd/etcdserver/api/v2stats"
"go.etcd.io/etcd/pkg/fileutil"
"go.etcd.io/etcd/pkg/types"
"go.etcd.io/etcd/raft"
"go.etcd.io/etcd/raft/raftpb"
"go.etcd.io/etcd/wal"
"go.etcd.io/etcd/wal/walpb"

"go.uber.org/zap"
)
Expand Down
2 changes: 1 addition & 1 deletion contrib/raftexample/raftexample_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ import (
"os"
"testing"

"github.com/coreos/etcd/raft/raftpb"
"go.etcd.io/etcd/raft/raftpb"
)

type cluster struct {
Expand Down
4 changes: 2 additions & 2 deletions contrib/recipes/barrier.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,8 +17,8 @@ package recipe
import (
"context"

v3 "github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/mvcc/mvccpb"
v3 "go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/mvcc/mvccpb"
)

// Barrier creates a key in etcd to block processes, then deletes the key to
Expand Down
4 changes: 2 additions & 2 deletions contrib/recipes/client.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,8 @@ import (
"context"
"errors"

v3 "github.com/coreos/etcd/clientv3"
spb "github.com/coreos/etcd/mvcc/mvccpb"
v3 "go.etcd.io/etcd/clientv3"
spb "go.etcd.io/etcd/mvcc/mvccpb"
)

var (
Expand Down
6 changes: 3 additions & 3 deletions contrib/recipes/double_barrier.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,9 +17,9 @@ package recipe
import (
"context"

"github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/clientv3/concurrency"
"github.com/coreos/etcd/mvcc/mvccpb"
"go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/clientv3/concurrency"
"go.etcd.io/etcd/mvcc/mvccpb"
)

// DoubleBarrier blocks processes on Enter until an expected count enters, then
Expand Down
4 changes: 2 additions & 2 deletions contrib/recipes/key.go
Original file line number Diff line number Diff line change
Expand Up @@ -20,8 +20,8 @@ import (
"strings"
"time"

v3 "github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/clientv3/concurrency"
v3 "go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/clientv3/concurrency"
)

// RemoteKV is a key/revision pair created by the client and stored on etcd
Expand Down
4 changes: 2 additions & 2 deletions contrib/recipes/priority_queue.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,8 @@ import (
"context"
"fmt"

v3 "github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/mvcc/mvccpb"
v3 "go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/mvcc/mvccpb"
)

// PriorityQueue implements a multi-reader, multi-writer distributed queue.
Expand Down
4 changes: 2 additions & 2 deletions contrib/recipes/queue.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,8 +17,8 @@ package recipe
import (
"context"

v3 "github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/mvcc/mvccpb"
v3 "go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/mvcc/mvccpb"
)

// Queue implements a multi-reader, multi-writer distributed queue.
Expand Down
6 changes: 3 additions & 3 deletions contrib/recipes/rwmutex.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,9 +17,9 @@ package recipe
import (
"context"

v3 "github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/clientv3/concurrency"
"github.com/coreos/etcd/mvcc/mvccpb"
v3 "go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/clientv3/concurrency"
"go.etcd.io/etcd/mvcc/mvccpb"
)

type RWMutex struct {
Expand Down
4 changes: 2 additions & 2 deletions contrib/recipes/watch.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,8 +17,8 @@ package recipe
import (
"context"

"github.com/coreos/etcd/clientv3"
"github.com/coreos/etcd/mvcc/mvccpb"
"go.etcd.io/etcd/clientv3"
"go.etcd.io/etcd/mvcc/mvccpb"
)

// WaitEvents waits on a key until it observes the given events and returns the final one.
Expand Down
20 changes: 10 additions & 10 deletions embed/config.go
Original file line number Diff line number Diff line change
Expand Up @@ -27,14 +27,14 @@ import (
"sync"
"time"

"github.com/coreos/etcd/etcdserver"
"github.com/coreos/etcd/etcdserver/api/v3compactor"
"github.com/coreos/etcd/pkg/flags"
"github.com/coreos/etcd/pkg/netutil"
"github.com/coreos/etcd/pkg/srv"
"github.com/coreos/etcd/pkg/tlsutil"
"github.com/coreos/etcd/pkg/transport"
"github.com/coreos/etcd/pkg/types"
"go.etcd.io/etcd/etcdserver"
"go.etcd.io/etcd/etcdserver/api/v3compactor"
"go.etcd.io/etcd/pkg/flags"
"go.etcd.io/etcd/pkg/netutil"
"go.etcd.io/etcd/pkg/srv"
"go.etcd.io/etcd/pkg/tlsutil"
"go.etcd.io/etcd/pkg/transport"
"go.etcd.io/etcd/pkg/types"

"github.com/ghodss/yaml"
"go.uber.org/zap"
Expand Down Expand Up @@ -162,7 +162,7 @@ type Config struct {
//
// If single-node, it advances ticks regardless.
//
// See https://github.com/coreos/etcd/issues/9333 for more detail.
// See https://go.etcd.io/etcd/issues/9333 for more detail.
InitialElectionTickAdvance bool `json:"initial-election-tick-advance"`

QuotaBackendBytes int64 `json:"quota-backend-bytes"`
Expand Down Expand Up @@ -246,7 +246,7 @@ type Config struct {
// CVE-2018-5702 reference:
// - https://bugs.chromium.org/p/project-zero/issues/detail?id=1447#c2
// - https://github.com/transmission/transmission/pull/468
// - https://github.com/coreos/etcd/issues/9353
// - https://go.etcd.io/etcd/issues/9353
HostWhitelist map[string]struct{}

// UserHandlers is for registering users handlers and only used for
Expand Down
4 changes: 2 additions & 2 deletions embed/config_logging.go
Original file line number Diff line number Diff line change
Expand Up @@ -24,7 +24,7 @@ import (
"sort"
"sync"

"github.com/coreos/etcd/pkg/logutil"
"go.etcd.io/etcd/pkg/logutil"

"github.com/coreos/pkg/capnslog"
"go.uber.org/zap"
Expand Down Expand Up @@ -93,7 +93,7 @@ func (cfg *Config) setupLogging() error {

// TODO: deprecate with "capnslog"
if cfg.LogPkgLevels != "" {
repoLog := capnslog.MustRepoLogger("github.com/coreos/etcd")
repoLog := capnslog.MustRepoLogger("go.etcd.io/etcd")
settings, err := repoLog.ParseLogLevelConfig(cfg.LogPkgLevels)
if err != nil {
plog.Warningf("couldn't parse log level string: %s, continuing with default levels", err.Error())
Expand Down
2 changes: 1 addition & 1 deletion embed/config_logging_journal_unix.go
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ import (
"fmt"
"os"

"github.com/coreos/etcd/pkg/logutil"
"go.etcd.io/etcd/pkg/logutil"

"go.uber.org/zap/zapcore"
)
Expand Down
2 changes: 1 addition & 1 deletion embed/config_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ import (
"os"
"testing"

"github.com/coreos/etcd/pkg/transport"
"go.etcd.io/etcd/pkg/transport"

"github.com/ghodss/yaml"
)
Expand Down
2 changes: 1 addition & 1 deletion embed/doc.go
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@ Launch an embedded etcd server using the configuration defaults:
"log"
"time"
"github.com/coreos/etcd/embed"
"go.etcd.io/etcd/embed"
)
func main() {
Expand Down
28 changes: 14 additions & 14 deletions embed/etcd.go
Original file line number Diff line number Diff line change
Expand Up @@ -29,18 +29,18 @@ import (
"sync"
"time"

"github.com/coreos/etcd/etcdserver"
"github.com/coreos/etcd/etcdserver/api/etcdhttp"
"github.com/coreos/etcd/etcdserver/api/rafthttp"
"github.com/coreos/etcd/etcdserver/api/v2http"
"github.com/coreos/etcd/etcdserver/api/v2v3"
"github.com/coreos/etcd/etcdserver/api/v3client"
"github.com/coreos/etcd/etcdserver/api/v3rpc"
"github.com/coreos/etcd/pkg/debugutil"
runtimeutil "github.com/coreos/etcd/pkg/runtime"
"github.com/coreos/etcd/pkg/transport"
"github.com/coreos/etcd/pkg/types"
"github.com/coreos/etcd/version"
"go.etcd.io/etcd/etcdserver"
"go.etcd.io/etcd/etcdserver/api/etcdhttp"
"go.etcd.io/etcd/etcdserver/api/rafthttp"
"go.etcd.io/etcd/etcdserver/api/v2http"
"go.etcd.io/etcd/etcdserver/api/v2v3"
"go.etcd.io/etcd/etcdserver/api/v3client"
"go.etcd.io/etcd/etcdserver/api/v3rpc"
"go.etcd.io/etcd/pkg/debugutil"
runtimeutil "go.etcd.io/etcd/pkg/runtime"
"go.etcd.io/etcd/pkg/transport"
"go.etcd.io/etcd/pkg/types"
"go.etcd.io/etcd/version"

"github.com/coreos/pkg/capnslog"
"github.com/grpc-ecosystem/go-grpc-prometheus"
Expand All @@ -50,7 +50,7 @@ import (
"google.golang.org/grpc/keepalive"
)

var plog = capnslog.NewPackageLogger("github.com/coreos/etcd", "embed")
var plog = capnslog.NewPackageLogger("go.etcd.io/etcd", "embed")

const (
// internal fd usage includes disk usage and transport usage.
Expand Down Expand Up @@ -412,7 +412,7 @@ func stopServers(ctx context.Context, ss *servers) {

// do not grpc.Server.GracefulStop with TLS enabled etcd server
// See https://github.com/grpc/grpc-go/issues/1384#issuecomment-317124531
// and https://github.com/coreos/etcd/issues/8916
// and https://go.etcd.io/etcd/issues/8916
if ss.secure {
shutdownNow()
return
Expand Down
Loading

0 comments on commit d37f152

Please sign in to comment.