Skip to content

Commit

Permalink
raft: change import paths to "go.etcd.io/etcd"
Browse files Browse the repository at this point in the history
Signed-off-by: Gyuho Lee <[email protected]>
  • Loading branch information
gyuho committed Aug 29, 2018
1 parent c763265 commit 5cee95b
Show file tree
Hide file tree
Showing 27 changed files with 34 additions and 34 deletions.
10 changes: 5 additions & 5 deletions README.md
Original file line number Diff line number Diff line change
Expand Up @@ -13,15 +13,15 @@ To keep the codebase small as well as provide flexibility, the library only impl

In order to easily test the Raft library, its behavior should be deterministic. To achieve this determinism, the library models Raft as a state machine. The state machine takes a `Message` as input. A message can either be a local timer update or a network message sent from a remote peer. The state machine's output is a 3-tuple `{[]Messages, []LogEntries, NextState}` consisting of an array of `Messages`, `log entries`, and `Raft state changes`. For state machines with the same state, the same state machine input should always generate the same state machine output.

A simple example application, _raftexample_, is also available to help illustrate how to use this package in practice: https://github.com/coreos/etcd/tree/master/contrib/raftexample
A simple example application, _raftexample_, is also available to help illustrate how to use this package in practice: https://github.com/etcd-io/etcd/tree/master/contrib/raftexample

# Features

This raft implementation is a full feature implementation of Raft protocol. Features includes:

- Leader election
- Log replication
- Log compaction
- Log compaction
- Membership changes
- Leadership transfer extension
- Efficient linearizable read-only queries served by both the leader and followers
Expand All @@ -40,13 +40,13 @@ This raft implementation also includes a few optional enhancements:
- Batching log entries to reduce disk synchronized I/O
- Writing to leader's disk in parallel
- Internal proposal redirection from followers to leader
- Automatic stepping down when the leader loses quorum
- Automatic stepping down when the leader loses quorum

## Notable Users

- [cockroachdb](https://github.com/cockroachdb/cockroach) A Scalable, Survivable, Strongly-Consistent SQL Database
- [dgraph](https://github.com/dgraph-io/dgraph) A Scalable, Distributed, Low Latency, High Throughput Graph Database
- [etcd](https://github.com/coreos/etcd) A distributed reliable key-value store
- [etcd](https://github.com/etcd-io/etcd) A distributed reliable key-value store
- [tikv](https://github.com/pingcap/tikv) A Distributed transactional key value database powered by Rust and Raft
- [swarmkit](https://github.com/docker/swarmkit) A toolkit for orchestrating distributed systems at any scale.
- [chain core](https://github.com/chain/chain) Software for operating permissioned, multi-asset blockchain networks
Expand Down Expand Up @@ -166,7 +166,7 @@ To propose changes to the state machine from the node to take application data,
n.Propose(ctx, data)
```

If the proposal is committed, data will appear in committed entries with type raftpb.EntryNormal. There is no guarantee that a proposed command will be committed; the command may have to be reproposed after a timeout.
If the proposal is committed, data will appear in committed entries with type raftpb.EntryNormal. There is no guarantee that a proposed command will be committed; the command may have to be reproposed after a timeout.

To add or remove node in a cluster, build ConfChange struct 'cc' and call:

Expand Down
2 changes: 1 addition & 1 deletion doc.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ For more details on Raft, see "In Search of an Understandable Consensus Algorith
A simple example application, _raftexample_, is also available to help illustrate
how to use this package in practice:
https://github.com/coreos/etcd/tree/master/contrib/raftexample
https://go.etcd.io/etcd/tree/master/contrib/raftexample
Usage
Expand Down
2 changes: 1 addition & 1 deletion example_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@
package raft

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

func applyToStore(ents []pb.Entry) {}
Expand Down
2 changes: 1 addition & 1 deletion log.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"fmt"
"log"

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

type raftLog struct {
Expand Down
2 changes: 1 addition & 1 deletion log_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"reflect"
"testing"

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

func TestFindConflict(t *testing.T) {
Expand Down
2 changes: 1 addition & 1 deletion log_unstable.go
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@

package raft

import pb "github.com/coreos/etcd/raft/raftpb"
import pb "go.etcd.io/etcd/raft/raftpb"

// unstable.entries[i] has raft log position i+unstable.offset.
// Note that unstable.offset may be less than the highest log
Expand Down
2 changes: 1 addition & 1 deletion log_unstable_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"reflect"
"testing"

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

func TestUnstableMaybeFirstIndex(t *testing.T) {
Expand Down
2 changes: 1 addition & 1 deletion node.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"context"
"errors"

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

type SnapshotStatus int
Expand Down
4 changes: 2 additions & 2 deletions node_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -22,8 +22,8 @@ import (
"testing"
"time"

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

// readyWithTimeout selects from n.Ready() with a 1-second timeout. It
Expand Down
2 changes: 1 addition & 1 deletion raft.go
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,7 @@ import (
"sync"
"time"

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

// None is a placeholder node ID used when there is no leader.
Expand Down
2 changes: 1 addition & 1 deletion raft_flow_control_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ package raft
import (
"testing"

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

// TestMsgAppFlowControlFull ensures:
Expand Down
2 changes: 1 addition & 1 deletion raft_paper_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@ import (
"reflect"
"sort"

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

func TestFollowerUpdateTermFromMessage(t *testing.T) {
Expand Down
2 changes: 1 addition & 1 deletion raft_snap_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ package raft
import (
"testing"

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

var (
Expand Down
4 changes: 2 additions & 2 deletions raft_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ import (
"strings"
"testing"

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

// nextEnts returns the appliable entries and updates the applied index
Expand Down Expand Up @@ -1439,7 +1439,7 @@ func TestHandleHeartbeatResp(t *testing.T) {

// TestRaftFreesReadOnlyMem ensures raft will free read request from
// readOnly readIndexQueue and pendingReadIndex map.
// related issue: https://github.com/coreos/etcd/issues/7571
// related issue: https://go.etcd.io/etcd/issues/7571
func TestRaftFreesReadOnlyMem(t *testing.T) {
sm := newTestRaft(1, []uint64{1, 2}, 5, 1, NewMemoryStorage())
sm.becomeCandidate()
Expand Down
2 changes: 1 addition & 1 deletion rafttest/network.go
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ import (
"sync"
"time"

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

// a network interface
Expand Down
2 changes: 1 addition & 1 deletion rafttest/network_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"testing"
"time"

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

func TestNetworkDrop(t *testing.T) {
Expand Down
4 changes: 2 additions & 2 deletions rafttest/node.go
Original file line number Diff line number Diff line change
Expand Up @@ -20,8 +20,8 @@ import (
"sync"
"time"

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

type node struct {
Expand Down
2 changes: 1 addition & 1 deletion rafttest/node_bench_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ import (
"testing"
"time"

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

func BenchmarkProposal3Nodes(b *testing.B) {
Expand Down
2 changes: 1 addition & 1 deletion rafttest/node_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ import (
"testing"
"time"

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

func TestBasicProgress(t *testing.T) {
Expand Down
2 changes: 1 addition & 1 deletion rawnode.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ package raft
import (
"errors"

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

// ErrStepLocalMsg is returned when try to step a local raft message
Expand Down
2 changes: 1 addition & 1 deletion rawnode_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ import (
"reflect"
"testing"

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

// TestRawNodeStep ensures that RawNode.Step ignore local message.
Expand Down
2 changes: 1 addition & 1 deletion read_only.go
Original file line number Diff line number Diff line change
Expand Up @@ -14,7 +14,7 @@

package raft

import pb "github.com/coreos/etcd/raft/raftpb"
import pb "go.etcd.io/etcd/raft/raftpb"

// ReadState provides state for read only query.
// It's caller's responsibility to call ReadIndex first before getting
Expand Down
2 changes: 1 addition & 1 deletion status.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ package raft
import (
"fmt"

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

type Status struct {
Expand Down
2 changes: 1 addition & 1 deletion storage.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"errors"
"sync"

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

// ErrCompacted is returned by Storage.Entries/Compact when a requested
Expand Down
2 changes: 1 addition & 1 deletion storage_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,7 @@ import (
"reflect"
"testing"

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

func TestStorageTerm(t *testing.T) {
Expand Down
2 changes: 1 addition & 1 deletion util.go
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,7 @@ import (
"bytes"
"fmt"

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

func (st StateType) MarshalJSON() ([]byte, error) {
Expand Down
2 changes: 1 addition & 1 deletion util_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -20,7 +20,7 @@ import (
"strings"
"testing"

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

var testFormatter EntryFormatter = func(data []byte) string {
Expand Down

0 comments on commit 5cee95b

Please sign in to comment.