fix lint and make gen

This commit is contained in:
Shrenuj Bansal 2022-10-17 22:44:00 -04:00
parent 900525f8c2
commit 674427a8b2
6 changed files with 43 additions and 64 deletions

View File

@ -4,10 +4,6 @@ import (
"context"
"errors"
"fmt"
"github.com/filecoin-project/lotus/lib/retry"
"github.com/mitchellh/go-homedir"
"github.com/urfave/cli/v2"
"golang.org/x/xerrors"
"net/http"
"net/url"
"os"
@ -17,12 +13,17 @@ import (
"syscall"
"time"
"github.com/mitchellh/go-homedir"
"github.com/urfave/cli/v2"
"golang.org/x/xerrors"
"github.com/filecoin-project/go-jsonrpc"
"github.com/filecoin-project/lotus/api"
"github.com/filecoin-project/lotus/api/client"
"github.com/filecoin-project/lotus/api/v0api"
"github.com/filecoin-project/lotus/api/v1api"
"github.com/filecoin-project/lotus/lib/retry"
"github.com/filecoin-project/lotus/node/repo"
)

View File

@ -3,15 +3,13 @@ package kit
import (
"context"
"fmt"
"github.com/multiformats/go-multiaddr"
manet "github.com/multiformats/go-multiaddr/net"
"github.com/stretchr/testify/require"
"net"
"net/http"
"net/http/httptest"
"testing"
"time"
"github.com/multiformats/go-multiaddr"
manet "github.com/multiformats/go-multiaddr/net"
"github.com/stretchr/testify/require"
"github.com/filecoin-project/lotus/api/client"
"github.com/filecoin-project/lotus/cmd/lotus-worker/sealworker"
@ -38,21 +36,6 @@ func CreateRPCServer(t *testing.T, handler http.Handler, listener net.Listener)
return testServ, maddr, closer
}
func waitUpTo(fn func(), waitTime time.Duration, errMsg string) {
ch := make(chan struct{})
go func() {
fn()
close(ch)
}()
select {
case <-ch:
case <-time.After(waitTime):
fmt.Println(errMsg)
return
}
}
func fullRpc(t *testing.T, f *TestFullNode) (*TestFullNode, Closer) {
handler, err := node.FullNodeHandler(f.FullNode, false)
require.NoError(t, err)

View File

@ -12,11 +12,6 @@ import (
"github.com/filecoin-project/lotus/node/repo"
)
// ConfigKey is the default configuration key for holding this component's
// configuration section.
var configKey = "raft"
var envConfigKey = "cluster_raft"
// Configuration defaults
var (
DefaultDataSubFolder = "raft-cluster"

View File

@ -77,7 +77,10 @@ func (c ConsensusOp) ApplyTo(state consensus.State) (consensus.State, error) {
// Deep copy to tmp
var buffer bytes.Buffer
c.SignedMsg.MarshalCBOR(&buffer)
err := c.SignedMsg.MarshalCBOR(&buffer)
if err != nil {
return nil, err
}
tmp, err := types.DecodeSignedMessage(buffer.Bytes())
if err != nil {
return nil, err
@ -159,7 +162,7 @@ func NewConsensus(host host.Host, cfg *ClusterRaftConfig, mpool *messagepool.Mes
peers = append(peers, addrInfo.ID)
// Add peer to address book
host.Peerstore().AddAddrs(addrInfo.ID, addrInfo.Addrs, time.Duration(time.Hour*100))
host.Peerstore().AddAddrs(addrInfo.ID, addrInfo.Addrs, time.Hour*100)
}
cc := &Consensus{
@ -291,7 +294,10 @@ func (cc *Consensus) Shutdown(ctx context.Context) error {
}
if cc.config.HostShutdown {
cc.host.Close()
err = cc.host.Close()
if err != nil {
logger.Error(err)
}
}
//cc.shutdown = true
@ -425,7 +431,7 @@ func (cc *Consensus) Commit(ctx context.Context, op *ConsensusOp) error {
}
RETRY:
time.Sleep(time.Duration(cc.config.CommitRetryDelay))
time.Sleep(cc.config.CommitRetryDelay)
}
return finalErr
}
@ -448,12 +454,11 @@ func (cc *Consensus) AddPeer(ctx context.Context, pid peer.ID) error {
}
// Being here means we are the leader and can commit
//cc.shutdownLock.RLock() // do not shutdown while committing
//finalErr = cc.raft.AddPeer(ctx, peer.Encode(pid))
finalErr = cc.raft.AddPeer(ctx, pid)
//cc.shutdownLock.RUnlock()
if finalErr != nil {
time.Sleep(time.Duration(cc.config.CommitRetryDelay))
time.Sleep(cc.config.CommitRetryDelay)
continue
}
logger.Infof("peer added to Raft: %s", pid.Pretty())

View File

@ -4,7 +4,6 @@ import (
"context"
"errors"
"fmt"
"io"
"os"
"path/filepath"
"time"
@ -103,7 +102,7 @@ func newRaftWrapper(
return nil, err
}
logger.Debug("creating Raft")
raftLogger.Debug("creating Raft")
raftW.raft, err = hraft.NewRaft(
cfg.RaftConfig,
fsm,
@ -113,12 +112,11 @@ func newRaftWrapper(
raftW.transport,
)
if err != nil {
logger.Error("initializing raft: ", err)
raftLogger.Error("initializing raft: ", err)
return nil, err
}
raftW.ctx, raftW.cancel = context.WithCancel(context.Background())
//go raftW.observePeers()
return raftW, nil
}
@ -130,7 +128,7 @@ func makeDataFolder(folder string) error {
}
func (rw *raftWrapper) makeTransport() (err error) {
logger.Debug("creating libp2p Raft transport")
raftLogger.Debug("creating libp2p Raft transport")
rw.transport, err = p2praft.NewLibp2pTransport(
rw.host,
rw.config.NetworkTimeout,
@ -139,13 +137,13 @@ func (rw *raftWrapper) makeTransport() (err error) {
}
func (rw *raftWrapper) makeStores() error {
logger.Debug("creating BoltDB store")
raftLogger.Debug("creating BoltDB store")
df := rw.config.GetDataFolder(rw.repo)
store, err := raftboltdb.NewBoltStore(filepath.Join(df, "raft.db"))
if err != nil {
return err
}
//store := hraft.NewInmemStore()
// wraps the store in a LogCache to improve performance.
// See consul/agent/consul/server.go
cacheStore, err := hraft.NewLogCache(RaftLogCacheSize, store)
@ -153,7 +151,7 @@ func (rw *raftWrapper) makeStores() error {
return err
}
logger.Debug("creating raft snapshot store")
raftLogger.Debug("creating raft snapshot store")
snapstore, err := hraft.NewFileSnapshotStoreWithLogger(
df,
RaftMaxSnapshots,
@ -163,8 +161,6 @@ func (rw *raftWrapper) makeStores() error {
return err
}
//snapstore := hraft.NewInmemSnapshotStore()
rw.logStore = cacheStore
rw.stableStore = store
rw.snapshotStore = snapstore
@ -554,24 +550,24 @@ func (rw *raftWrapper) Peers(ctx context.Context) ([]string, error) {
// latestSnapshot looks for the most recent raft snapshot stored at the
// provided basedir. It returns the snapshot's metadata, and a reader
// to the snapshot's bytes
func latestSnapshot(raftDataFolder string) (*hraft.SnapshotMeta, io.ReadCloser, error) {
store, err := hraft.NewFileSnapshotStore(raftDataFolder, RaftMaxSnapshots, nil)
if err != nil {
return nil, nil, err
}
snapMetas, err := store.List()
if err != nil {
return nil, nil, err
}
if len(snapMetas) == 0 { // no error if snapshot isn't found
return nil, nil, nil
}
meta, r, err := store.Open(snapMetas[0].ID)
if err != nil {
return nil, nil, err
}
return meta, r, nil
}
//func latestSnapshot(raftDataFolder string) (*hraft.SnapshotMeta, io.ReadCloser, error) {
// store, err := hraft.NewFileSnapshotStore(raftDataFolder, RaftMaxSnapshots, nil)
// if err != nil {
// return nil, nil, err
// }
// snapMetas, err := store.List()
// if err != nil {
// return nil, nil, err
// }
// if len(snapMetas) == 0 { // no error if snapshot isn't found
// return nil, nil, nil
// }
// meta, r, err := store.Open(snapMetas[0].ID)
// if err != nil {
// return nil, nil, err
// }
// return meta, r, nil
//}
// LastStateRaw returns the bytes of the last snapshot stored, its metadata,
// and a flag indicating whether any snapshot was found.

View File

@ -9,7 +9,6 @@ import (
"github.com/filecoin-project/lotus/api"
"github.com/filecoin-project/lotus/build"
"github.com/filecoin-project/lotus/node/impl/client"
"github.com/filecoin-project/lotus/node/impl/common"
"github.com/filecoin-project/lotus/node/impl/full"