2019-07-29 18:57:23 +00:00
|
|
|
package storage
|
|
|
|
|
|
|
|
import (
|
|
|
|
"context"
|
|
|
|
|
|
|
|
"github.com/ipfs/go-cid"
|
|
|
|
"github.com/ipfs/go-datastore"
|
|
|
|
logging "github.com/ipfs/go-log"
|
|
|
|
host "github.com/libp2p/go-libp2p-core/host"
|
|
|
|
"github.com/pkg/errors"
|
2019-09-18 02:50:03 +00:00
|
|
|
"golang.org/x/xerrors"
|
2019-07-29 18:57:23 +00:00
|
|
|
|
2019-08-27 19:54:39 +00:00
|
|
|
"github.com/filecoin-project/go-lotus/api"
|
|
|
|
"github.com/filecoin-project/go-lotus/build"
|
|
|
|
"github.com/filecoin-project/go-lotus/chain/actors"
|
|
|
|
"github.com/filecoin-project/go-lotus/chain/address"
|
|
|
|
"github.com/filecoin-project/go-lotus/chain/store"
|
|
|
|
"github.com/filecoin-project/go-lotus/chain/types"
|
2019-07-29 18:57:23 +00:00
|
|
|
"github.com/filecoin-project/go-lotus/lib/sectorbuilder"
|
2019-09-16 16:40:26 +00:00
|
|
|
"github.com/filecoin-project/go-lotus/storage/commitment"
|
2019-08-27 19:54:39 +00:00
|
|
|
"github.com/filecoin-project/go-lotus/storage/sector"
|
2019-07-29 18:57:23 +00:00
|
|
|
)
|
|
|
|
|
|
|
|
var log = logging.Logger("storageminer")
|
|
|
|
|
|
|
|
type Miner struct {
|
|
|
|
api storageMinerApi
|
|
|
|
|
2019-08-14 20:27:10 +00:00
|
|
|
secst *sector.Store
|
2019-09-16 16:40:26 +00:00
|
|
|
commt *commitment.Tracker
|
2019-07-29 18:57:23 +00:00
|
|
|
|
|
|
|
maddr address.Address
|
|
|
|
|
|
|
|
worker address.Address
|
|
|
|
|
|
|
|
h host.Host
|
|
|
|
|
|
|
|
ds datastore.Batching
|
|
|
|
}
|
|
|
|
|
|
|
|
type storageMinerApi interface {
|
|
|
|
// I think I want this... but this is tricky
|
|
|
|
//ReadState(ctx context.Context, addr address.Address) (????, error)
|
|
|
|
|
|
|
|
// Call a read only method on actors (no interaction with the chain required)
|
2019-09-06 06:26:02 +00:00
|
|
|
StateCall(ctx context.Context, msg *types.Message, ts *types.TipSet) (*types.MessageReceipt, error)
|
2019-09-18 02:50:03 +00:00
|
|
|
StateMinerWorker(context.Context, address.Address, *types.TipSet) (address.Address, error)
|
|
|
|
StateMinerProvingPeriodEnd(context.Context, address.Address, *types.TipSet) (uint64, error)
|
|
|
|
StateMinerProvingSet(context.Context, address.Address, *types.TipSet) ([]*api.SectorInfo, error)
|
2019-07-29 18:57:23 +00:00
|
|
|
|
|
|
|
MpoolPush(context.Context, *types.SignedMessage) error
|
|
|
|
MpoolGetNonce(context.Context, address.Address) (uint64, error)
|
|
|
|
|
|
|
|
ChainWaitMsg(context.Context, cid.Cid) (*api.MsgWait, error)
|
2019-07-30 00:46:56 +00:00
|
|
|
ChainNotify(context.Context) (<-chan *store.HeadChange, error)
|
2019-09-18 02:50:03 +00:00
|
|
|
ChainGetRandomness(context.Context, *types.TipSet, []*types.Ticket, int) ([]byte, error)
|
2019-09-18 00:08:49 +00:00
|
|
|
ChainGetTipSetByHeight(context.Context, uint64, *types.TipSet) (*types.TipSet, error)
|
2019-08-08 04:24:49 +00:00
|
|
|
|
|
|
|
WalletBalance(context.Context, address.Address) (types.BigInt, error)
|
|
|
|
WalletSign(context.Context, address.Address, []byte) (*types.Signature, error)
|
2019-08-08 17:29:23 +00:00
|
|
|
WalletHas(context.Context, address.Address) (bool, error)
|
2019-07-29 18:57:23 +00:00
|
|
|
}
|
|
|
|
|
2019-09-16 16:40:26 +00:00
|
|
|
func NewMiner(api storageMinerApi, addr address.Address, h host.Host, ds datastore.Batching, secst *sector.Store, commt *commitment.Tracker) (*Miner, error) {
|
2019-07-29 18:57:23 +00:00
|
|
|
return &Miner{
|
|
|
|
api: api,
|
|
|
|
maddr: addr,
|
|
|
|
h: h,
|
|
|
|
ds: ds,
|
2019-08-14 20:27:10 +00:00
|
|
|
secst: secst,
|
2019-09-16 16:40:26 +00:00
|
|
|
commt: commt,
|
2019-07-29 18:57:23 +00:00
|
|
|
}, nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *Miner) Run(ctx context.Context) error {
|
|
|
|
if err := m.runPreflightChecks(ctx); err != nil {
|
|
|
|
return errors.Wrap(err, "miner preflight checks failed")
|
|
|
|
}
|
|
|
|
|
|
|
|
go m.handlePostingSealedSectors(ctx)
|
|
|
|
go m.runPoSt(ctx)
|
|
|
|
return nil
|
|
|
|
}
|
|
|
|
|
|
|
|
func (m *Miner) handlePostingSealedSectors(ctx context.Context) {
|
2019-08-14 20:27:10 +00:00
|
|
|
incoming := m.secst.Incoming()
|
|
|
|
defer m.secst.CloseIncoming(incoming)
|
|
|
|
|
2019-07-29 18:57:23 +00:00
|
|
|
for {
|
|
|
|
select {
|
2019-08-14 20:27:10 +00:00
|
|
|
case sinfo, ok := <-incoming:
|
2019-07-29 18:57:23 +00:00
|
|
|
if !ok {
|
|
|
|
// TODO: set some state variable so that this state can be
|
|
|
|
// visible via some status command
|
|
|
|
log.Warning("sealed sector channel closed, aborting process")
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2019-07-30 00:46:56 +00:00
|
|
|
if err := m.commitSector(ctx, sinfo); err != nil {
|
|
|
|
log.Errorf("failed to commit sector: %s", err)
|
|
|
|
continue
|
|
|
|
}
|
|
|
|
|
2019-07-29 18:57:23 +00:00
|
|
|
case <-ctx.Done():
|
|
|
|
log.Warning("exiting seal posting routine")
|
|
|
|
return
|
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
2019-07-30 00:46:56 +00:00
|
|
|
|
2019-07-29 18:57:23 +00:00
|
|
|
func (m *Miner) commitSector(ctx context.Context, sinfo sectorbuilder.SectorSealingStatus) error {
|
2019-08-12 21:48:18 +00:00
|
|
|
log.Info("committing sector")
|
|
|
|
|
2019-08-27 19:54:14 +00:00
|
|
|
ok, err := sectorbuilder.VerifySeal(build.SectorSize, sinfo.CommR[:], sinfo.CommD[:], sinfo.CommRStar[:], m.maddr, sinfo.SectorID, sinfo.Proof)
|
2019-08-08 01:16:58 +00:00
|
|
|
if err != nil {
|
|
|
|
log.Error("failed to verify seal we just created: ", err)
|
|
|
|
}
|
|
|
|
if !ok {
|
|
|
|
log.Error("seal we just created failed verification")
|
|
|
|
}
|
|
|
|
|
2019-07-29 18:57:23 +00:00
|
|
|
params := &actors.CommitSectorParams{
|
2019-08-29 00:01:46 +00:00
|
|
|
SectorID: sinfo.SectorID,
|
2019-07-30 00:46:56 +00:00
|
|
|
CommD: sinfo.CommD[:],
|
|
|
|
CommR: sinfo.CommR[:],
|
|
|
|
CommRStar: sinfo.CommRStar[:],
|
2019-07-29 18:57:23 +00:00
|
|
|
Proof: sinfo.Proof,
|
|
|
|
}
|
2019-07-30 00:46:56 +00:00
|
|
|
enc, aerr := actors.SerializeParams(params)
|
|
|
|
if aerr != nil {
|
|
|
|
return errors.Wrap(aerr, "could not serialize commit sector parameters")
|
2019-07-29 18:57:23 +00:00
|
|
|
}
|
|
|
|
|
2019-07-30 00:46:56 +00:00
|
|
|
msg := types.Message{
|
2019-07-29 18:57:23 +00:00
|
|
|
To: m.maddr,
|
|
|
|
From: m.worker,
|
|
|
|
Method: actors.MAMethods.CommitSector,
|
2019-07-30 00:46:56 +00:00
|
|
|
Params: enc,
|
2019-07-29 18:57:23 +00:00
|
|
|
Value: types.NewInt(0), // TODO: need to ensure sufficient collateral
|
2019-09-06 22:35:56 +00:00
|
|
|
GasLimit: types.NewInt(100000 /* i dont know help */),
|
2019-07-29 18:57:23 +00:00
|
|
|
GasPrice: types.NewInt(1),
|
|
|
|
}
|
|
|
|
|
|
|
|
nonce, err := m.api.MpoolGetNonce(ctx, m.worker)
|
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "failed to get nonce")
|
|
|
|
}
|
|
|
|
|
|
|
|
msg.Nonce = nonce
|
|
|
|
|
|
|
|
data, err := msg.Serialize()
|
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "serializing commit sector message")
|
|
|
|
}
|
|
|
|
|
2019-08-08 04:24:49 +00:00
|
|
|
sig, err := m.api.WalletSign(ctx, m.worker, data)
|
2019-07-29 18:57:23 +00:00
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "signing commit sector message")
|
|
|
|
}
|
|
|
|
|
|
|
|
smsg := &types.SignedMessage{
|
|
|
|
Message: msg,
|
2019-07-30 00:46:56 +00:00
|
|
|
Signature: *sig,
|
2019-07-29 18:57:23 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
if err := m.api.MpoolPush(ctx, smsg); err != nil {
|
|
|
|
return errors.Wrap(err, "pushing commit sector message to mpool")
|
|
|
|
}
|
|
|
|
|
2019-09-16 18:05:22 +00:00
|
|
|
if err := m.commt.TrackCommitSectorMsg(m.maddr, sinfo.SectorID, smsg.Cid()); err != nil {
|
2019-09-16 16:40:26 +00:00
|
|
|
return errors.Wrap(err, "tracking sector commitment")
|
|
|
|
}
|
2019-07-29 18:57:23 +00:00
|
|
|
|
2019-09-16 16:40:26 +00:00
|
|
|
return nil
|
2019-07-29 18:57:23 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (m *Miner) runPoSt(ctx context.Context) {
|
2019-09-18 02:50:03 +00:00
|
|
|
// TODO: most of this method can probably be replaced by the events module once it works on top of the api
|
2019-09-17 22:43:47 +00:00
|
|
|
notifs, err := m.api.ChainNotify(ctx)
|
|
|
|
if err != nil {
|
|
|
|
// TODO: this is probably 'crash the node' level serious
|
|
|
|
log.Errorf("POST ROUTINE FAILED: failed to get chain notifications stream: %s", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
curhead := <-notifs
|
|
|
|
if curhead.Type != store.HCCurrent {
|
|
|
|
// TODO: this is probably 'crash the node' level serious
|
|
|
|
log.Warning("expected to get current best tipset from chain notifications stream")
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
|
|
|
postCtx, cancel := context.WithCancel(ctx)
|
2019-09-18 02:50:03 +00:00
|
|
|
postWaitCh, onBlock, err := m.maybeDoPost(postCtx, curhead.Val)
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("initial 'maybeDoPost' call failed: %s", err)
|
|
|
|
return
|
|
|
|
}
|
2019-09-17 22:43:47 +00:00
|
|
|
|
|
|
|
for {
|
|
|
|
select {
|
|
|
|
case <-ctx.Done():
|
|
|
|
case ch, ok := <-notifs:
|
|
|
|
if !ok {
|
|
|
|
log.Warning("chain notifications stream terminated")
|
|
|
|
// TODO: attempt to restart it if the context isnt cancelled
|
|
|
|
return
|
|
|
|
}
|
|
|
|
|
2019-09-18 02:50:03 +00:00
|
|
|
switch ch.Type {
|
|
|
|
case store.HCApply:
|
|
|
|
postWaitCh, onBlock, err = m.maybeDoPost(postCtx, ch.Val)
|
|
|
|
if err != nil {
|
|
|
|
log.Errorf("maybeDoPost failed: %s", err)
|
|
|
|
return
|
|
|
|
}
|
|
|
|
case store.HCRevert:
|
|
|
|
if onBlock != nil {
|
|
|
|
if ch.Val.Contains(onBlock.Cid()) {
|
|
|
|
// Our post may now be invalid!
|
|
|
|
cancel() // probably the right thing to do?
|
|
|
|
}
|
|
|
|
}
|
|
|
|
case store.HCCurrent:
|
|
|
|
log.Warn("got 'current' chain notification in middle of stream")
|
2019-09-17 22:43:47 +00:00
|
|
|
}
|
2019-09-18 02:50:03 +00:00
|
|
|
case perr := <-postWaitCh:
|
|
|
|
if perr != nil {
|
|
|
|
log.Errorf("got error back from postWaitCh: %s", err)
|
|
|
|
// TODO: what do we even do here?
|
|
|
|
return
|
|
|
|
}
|
|
|
|
postWaitCh = nil
|
|
|
|
onBlock = nil
|
|
|
|
// yay?
|
|
|
|
log.Infof("post successfully submitted")
|
2019-09-17 22:43:47 +00:00
|
|
|
}
|
|
|
|
}
|
|
|
|
}
|
|
|
|
|
2019-09-18 00:08:49 +00:00
|
|
|
func (m *Miner) maybeDoPost(ctx context.Context, ts *types.TipSet) (<-chan error, *types.BlockHeader, error) {
|
2019-09-18 02:50:03 +00:00
|
|
|
ppe, err := m.api.StateMinerProvingPeriodEnd(ctx, m.maddr, ts)
|
2019-09-18 00:08:49 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, nil, xerrors.Errorf("failed to get proving period end for miner: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
if ppe < ts.Height() {
|
|
|
|
return nil, nil, nil
|
|
|
|
}
|
|
|
|
|
2019-09-18 02:50:03 +00:00
|
|
|
sset, err := m.api.StateMinerProvingSet(ctx, m.maddr, ts)
|
2019-09-18 00:08:49 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, nil, xerrors.Errorf("failed to get proving set for miner: %w", err)
|
|
|
|
}
|
|
|
|
|
2019-09-18 02:50:03 +00:00
|
|
|
r, err := m.api.ChainGetRandomness(ctx, ts, nil, int(ts.Height()-ppe))
|
2019-09-18 00:08:49 +00:00
|
|
|
if err != nil {
|
|
|
|
return nil, nil, xerrors.Errorf("failed to get chain randomness for post: %w", err)
|
|
|
|
}
|
|
|
|
|
|
|
|
sourceTs, err := m.api.ChainGetTipSetByHeight(ctx, ppe, ts)
|
|
|
|
if err != nil {
|
|
|
|
return nil, nil, xerrors.Errorf("failed to get post start tipset: %w", err)
|
|
|
|
}
|
2019-09-17 22:43:47 +00:00
|
|
|
|
2019-09-18 00:08:49 +00:00
|
|
|
ret := make(chan error, 1)
|
|
|
|
go func() {
|
2019-09-18 03:32:52 +00:00
|
|
|
var faults []uint64
|
|
|
|
proof, err := m.secst.RunPoSt(ctx, sset, r, faults)
|
2019-09-18 02:50:03 +00:00
|
|
|
if err != nil {
|
|
|
|
ret <- xerrors.Errorf("running post failed: %w", err)
|
|
|
|
return
|
|
|
|
}
|
2019-09-18 00:08:49 +00:00
|
|
|
|
2019-09-18 02:50:03 +00:00
|
|
|
// TODO: submit post...
|
|
|
|
_ = proof
|
|
|
|
|
|
|
|
// make sure it succeeds...
|
|
|
|
// m.api.ChainWaitMsg()
|
|
|
|
|
|
|
|
}()
|
2019-09-18 00:08:49 +00:00
|
|
|
|
|
|
|
return ret, sourceTs.MinTicketBlock(), nil
|
2019-07-29 18:57:23 +00:00
|
|
|
}
|
|
|
|
|
|
|
|
func (m *Miner) runPreflightChecks(ctx context.Context) error {
|
2019-09-18 00:08:49 +00:00
|
|
|
worker, err := m.api.StateMinerWorker(ctx, m.maddr, nil)
|
2019-07-29 18:57:23 +00:00
|
|
|
if err != nil {
|
|
|
|
return err
|
|
|
|
}
|
|
|
|
|
|
|
|
m.worker = worker
|
|
|
|
|
2019-08-08 17:29:23 +00:00
|
|
|
has, err := m.api.WalletHas(ctx, worker)
|
2019-07-30 00:46:56 +00:00
|
|
|
if err != nil {
|
|
|
|
return errors.Wrap(err, "failed to check wallet for worker key")
|
|
|
|
}
|
|
|
|
|
|
|
|
if !has {
|
|
|
|
return errors.New("key for worker not found in local wallet")
|
2019-07-29 18:57:23 +00:00
|
|
|
}
|
|
|
|
|
2019-07-30 00:46:56 +00:00
|
|
|
log.Infof("starting up miner %s, worker addr %s", m.maddr, m.worker)
|
2019-07-29 18:57:23 +00:00
|
|
|
return nil
|
|
|
|
}
|