modules

package
v1.26.3 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: Apr 23, 2024 License: Apache-2.0, MIT Imports: 136 Imported by: 26

Documentation

Index

Constants

View Source
const (
	JWTSecretName   = "auth-jwt-private" //nolint:gosec
	KTJwtHmacSecret = "jwt-hmac-secret"  //nolint:gosec
)
View Source
const (
	EnvDAGStoreCopyConcurrency = "LOTUS_DAGSTORE_COPY_CONCURRENCY"
	DefaultDAGStoreDir         = "dagstore"
)
View Source
const (
	// EnvWatchdogDisabled is an escape hatch to disable the watchdog explicitly
	// in case an OS/kernel appears to report incorrect information. The
	// watchdog will be disabled if the value of this env variable is 1.
	EnvWatchdogDisabled = "LOTUS_DISABLE_WATCHDOG"
)

Variables

View Source
var ManagerWorkPrefix = datastore.NewKey("/stmgr/calls")
View Source
var (
	StagingAreaDirName = "deal-staging"
)
View Source
var WorkerCallsPrefix = datastore.NewKey("/worker/calls")

Functions

func APISecret

func APISecret(keystore types.KeyStore, lr repo.LockedRepo) (*dtypes.APIAlg, error)

func AddressSelector added in v1.2.3

func AddressSelector(addrConf *config.MinerAddressConfig) func() (*ctladdr.AddressSelector, error)

func BadgerHotBlockstore added in v1.5.1

func BadgerHotBlockstore(lc fx.Lifecycle, r repo.LockedRepo) (dtypes.HotBlockstore, error)

func BuiltinBootstrap

func BuiltinBootstrap() (dtypes.BootstrapPeers, error)

func BuiltinDrandConfig added in v0.4.1

func BuiltinDrandConfig() dtypes.DrandSchedule

func ChainBitswap added in v0.6.2

ChainBitswap uses a blockstore that bypasses all caches.

func ChainBlockService added in v0.6.2

func ChainFlatBlockstore added in v1.5.1

func ChainSplitBlockstore added in v1.5.1

func CheckFdLimit added in v1.11.3

func CheckFdLimit(min uint64) func(al *alerting.Alerting)

func CheckFvmConcurrency added in v1.23.3

func CheckFvmConcurrency() func(al *alerting.Alerting)

func CheckUDPBufferSize added in v1.25.2

func CheckUDPBufferSize(wanted int) func(al *alerting.Alerting)

func ClientBlockstore

func ClientBlockstore() dtypes.ClientBlockstore

TODO this should be removed.

func ClientImportMgr added in v0.5.0

func ClientImportMgr(ds dtypes.MetadataDS, r repo.LockedRepo) (dtypes.ClientImportMgr, error)

func ConfigBootstrap

func ConfigBootstrap(peers []string) func() (dtypes.BootstrapPeers, error)

func ConnectSealingService added in v1.11.1

func ConnectSealingService(apiInfo string) func(mctx helpers.MetricsCtx, lc fx.Lifecycle) (MinerSealingService, error)

func ConnectStorageService added in v1.11.1

func ConnectStorageService(apiInfo string) func(mctx helpers.MetricsCtx, lc fx.Lifecycle) (MinerStorageService, error)

func DAGStore added in v1.11.2

DAGStore constructs a DAG store using the supplied minerAPI, and the user configuration. It returns both the DAGStore and the Wrapper suitable for passing to markets.

func Datastore

func Datastore(disableLog bool) func(lc fx.Lifecycle, mctx helpers.MetricsCtx, r repo.LockedRepo) (dtypes.MetadataDS, error)

func DiscardColdBlockstore added in v1.11.1

func DiscardColdBlockstore(lc fx.Lifecycle, bs dtypes.UniversalBlockstore) (dtypes.ColdBlockstore, error)

func DoSetGenesis added in v0.3.0

func DoSetGenesis(_ dtypes.AfterGenesisSet)

func DrandBootstrap added in v0.4.0

func DrandBootstrap(ds dtypes.DrandSchedule) (dtypes.DrandBootstrap, error)

func DummyMsgIndex added in v1.23.1

func DummyMsgIndex() index.MsgIndex

func EnableStoringEvents added in v1.20.0

func EnableStoringEvents(cs *store.ChainStore)

func ExposedSplitBlockstore added in v1.11.1

func ExposedSplitBlockstore(_ fx.Lifecycle, s dtypes.SplitBlockstore) dtypes.ExposedBlockstore

func ExtractEnabledMinerSubsystems added in v1.11.1

func ExtractEnabledMinerSubsystems(cfg config.MinerSubsystemConfig) (res api.MinerSubsystems)

func FallbackChainBlockstore added in v1.1.3

func FallbackChainBlockstore(cbs dtypes.BasicChainBlockstore) dtypes.ChainBlockstore

func FallbackStateBlockstore added in v1.5.1

func FallbackStateBlockstore(sbs dtypes.BasicStateBlockstore) dtypes.StateBlockstore

func GetParams

func GetParams(prover bool) func(spt abi.RegisteredSealProof) error

func Graphsync added in v0.3.0

func Graphsync(parallelTransfersForStorage uint64, parallelTransfersForRetrieval uint64) func(mctx helpers.MetricsCtx, lc fx.Lifecycle, r repo.LockedRepo, clientBs dtypes.ClientBlockstore, chainBs dtypes.ExposedBlockstore, h host.Host) (dtypes.Graphsync, error)

Graphsync creates a graphsync instance from the given loader and storer

func HandleIncomingMessages

func HandleIncomingMessages(mctx helpers.MetricsCtx, lc fx.Lifecycle, ps *pubsub.PubSub, stmgr *stmgr.StateManager, mpool *messagepool.MessagePool, h host.Host, nn dtypes.NetworkName, bootstrapper dtypes.Bootstrapper)

func HandleMigrateClientFunds added in v1.1.3

func HandleMigrateClientFunds(lc fx.Lifecycle, mctx helpers.MetricsCtx, ds dtypes.MetadataDS, wallet full.WalletAPI, fundMgr *market.FundManager)

func HandleMigrateProviderFunds added in v1.1.3

func HandleMigrateProviderFunds(lc fx.Lifecycle, ds dtypes.MetadataDS, node api.FullNode, minerAddress dtypes.MinerAddress)

func HandlePaychManager added in v1.9.0

func HandlePaychManager(lc fx.Lifecycle, pm *paychmgr.Manager)

HandlePaychManager is called by dependency injection to set up hooks

func IndexProvider added in v1.15.1

func InitFallbackBlockstores added in v1.5.1

func InitFallbackBlockstores(cbs dtypes.ChainBlockstore, sbs dtypes.StateBlockstore, rem dtypes.ChainBitswap) error

func IpfsClientBlockstore added in v0.3.0

func IpfsClientBlockstore(ipfsMaddr string, onlineMode bool) func(helpers.MetricsCtx, fx.Lifecycle, dtypes.ClientImportMgr) (dtypes.ClientBlockstore, error)

IpfsClientBlockstore returns a ClientBlockstore implementation backed by an IPFS node. If ipfsMaddr is empty, a local IPFS node is assumed considering IPFS_PATH configuration. If ipfsMaddr is not empty, it will connect to the remote IPFS node with the provided multiaddress. The flag useForRetrieval indicates if the IPFS node will also be used for storing retrieving deals.

func IpfsRetrievalBlockstoreAccessor added in v1.11.2

func IpfsRetrievalBlockstoreAccessor(ipfsBlockstore dtypes.ClientBlockstore) retrievalmarket.BlockstoreAccessor

func IpfsStorageBlockstoreAccessor added in v1.11.2

func IpfsStorageBlockstoreAccessor(ipfsBlockstore dtypes.ClientBlockstore) storagemarket.BlockstoreAccessor

func KeyStore

func KeyStore(lr repo.LockedRepo) (types.KeyStore, error)

func LegacyMarketsEOL added in v1.23.3

func LegacyMarketsEOL(al *alerting.Alerting)

func LoadGenesis

func LoadGenesis(genBytes []byte) func(fx.Lifecycle, helpers.MetricsCtx, dtypes.ChainBlockstore) Genesis

func LocalStorage added in v1.11.0

func LocalStorage(mctx helpers.MetricsCtx, lc fx.Lifecycle, ls paths.LocalStorage, si paths.SectorIndex, urls paths.URLs) (*paths.Local, error)

func LockedRepo

func LockedRepo(lr repo.LockedRepo) func(lc fx.Lifecycle) repo.LockedRepo

func MakeUuidWrapper added in v1.17.2

func MakeUuidWrapper(a v1api.RawFullNodeAPI) v1api.FullNode

func MemoryBlockstore added in v1.16.0

func MemoryBlockstore() dtypes.UniversalBlockstore

func MemoryConstraints added in v1.2.3

func MemoryConstraints() system.MemoryConstraints

MemoryConstraints returns the memory constraints configured for this system.

func MemoryWatchdog added in v1.2.3

func MemoryWatchdog(lr repo.LockedRepo, lc fx.Lifecycle, constraints system.MemoryConstraints)

MemoryWatchdog starts the memory watchdog, applying the computed resource constraints.

func MinerAddress added in v0.3.0

func MinerAddress(ds dtypes.MetadataDS) (dtypes.MinerAddress, error)

func MinerID added in v0.3.0

func MinerID(ma dtypes.MinerAddress) (dtypes.MinerID, error)

func MsgIndex added in v1.23.1

func NetworkName added in v0.3.0

func NewClientDatastore added in v0.3.0

func NewClientDatastore(ds dtypes.MetadataDS) dtypes.ClientDatastore

NewClientDatastore creates a datastore for the client to store its deals

func NewClientGraphsyncDataTransfer added in v0.3.0

func NewClientGraphsyncDataTransfer(lc fx.Lifecycle, h host.Host, gs dtypes.Graphsync, ds dtypes.MetadataDS, r repo.LockedRepo) (dtypes.ClientDataTransfer, error)

NewClientGraphsyncDataTransfer returns a data transfer manager that just uses the clients's Client DAG service for transfers

func NewConsiderOfflineRetrievalDealsConfigFunc added in v0.4.1

func NewConsiderOfflineRetrievalDealsConfigFunc(r repo.LockedRepo) (dtypes.ConsiderOfflineRetrievalDealsConfigFunc, error)

func NewConsiderOfflineStorageDealsConfigFunc added in v0.4.1

func NewConsiderOfflineStorageDealsConfigFunc(r repo.LockedRepo) (dtypes.ConsiderOfflineStorageDealsConfigFunc, error)

func NewConsiderOnlineRetrievalDealsConfigFunc added in v0.4.1

func NewConsiderOnlineRetrievalDealsConfigFunc(r repo.LockedRepo) (dtypes.ConsiderOnlineRetrievalDealsConfigFunc, error)

func NewConsiderOnlineStorageDealsConfigFunc added in v0.4.1

func NewConsiderOnlineStorageDealsConfigFunc(r repo.LockedRepo) (dtypes.ConsiderOnlineStorageDealsConfigFunc, error)

func NewConsiderUnverifiedStorageDealsConfigFunc added in v1.2.3

func NewConsiderUnverifiedStorageDealsConfigFunc(r repo.LockedRepo) (dtypes.ConsiderUnverifiedStorageDealsConfigFunc, error)

func NewConsiderVerifiedStorageDealsConfigFunc added in v1.2.3

func NewConsiderVerifiedStorageDealsConfigFunc(r repo.LockedRepo) (dtypes.ConsiderVerifiedStorageDealsConfigFunc, error)

func NewDefaultMaxFeeFunc added in v1.1.3

func NewDefaultMaxFeeFunc(r repo.LockedRepo) dtypes.DefaultMaxFeeFunc

func NewGetExpectedSealDurationFunc added in v0.5.0

func NewGetExpectedSealDurationFunc(r repo.LockedRepo) (dtypes.GetExpectedSealDurationFunc, error)

func NewGetMaxDealStartDelayFunc added in v1.10.0

func NewGetMaxDealStartDelayFunc(r repo.LockedRepo) (dtypes.GetMaxDealStartDelayFunc, error)

func NewGetSealConfigFunc added in v0.5.0

func NewGetSealConfigFunc(r repo.LockedRepo) (dtypes.GetSealingConfigFunc, error)

func NewLocalDiscovery added in v0.2.1

func NewLocalDiscovery(lc fx.Lifecycle, ds dtypes.MetadataDS) (*discoveryimpl.Local, error)

func NewManager added in v1.9.0

func NewMinerAPI added in v1.11.2

NewMinerAPI creates a new MinerAPI adaptor for the dagstore mounts.

func NewPaychStore added in v1.9.0

func NewPaychStore(ds dtypes.MetadataDS) *paychmgr.Store

func NewProviderDataTransfer added in v1.14.0

NewProviderDataTransfer returns a data transfer manager

func NewProviderPieceStore added in v0.3.0

func NewProviderPieceStore(lc fx.Lifecycle, ds dtypes.MetadataDS) (dtypes.ProviderPieceStore, error)

NewProviderPieceStore creates a statestore for storing metadata about pieces shared by the storage and retrieval providers

func NewProviderTransferNetwork added in v1.14.0

func NewProviderTransferNetwork(h host.Host) dtypes.ProviderTransferNetwork

NewProviderTransferNetwork sets up the libp2p2 protocol networking for data transfer

func NewProviderTransport added in v1.14.0

func NewProviderTransport(h host.Host, gs dtypes.StagingGraphsync) dtypes.ProviderTransport

NewProviderTransport sets up a data transfer transport over graphsync

func NewRPCClient added in v1.19.0

func NewRPCClient(host host.Host) *rpc.Client

func NewRPCServer added in v1.19.0

func NewRPCServer(ctx context.Context, host host.Host, rpcHandler *RPCHandler) error

func NewSetConsiderOfflineRetrievalDealsConfigFunc added in v0.4.1

func NewSetConsiderOfflineRetrievalDealsConfigFunc(r repo.LockedRepo) (dtypes.SetConsiderOfflineRetrievalDealsConfigFunc, error)

func NewSetConsiderOnlineRetrievalDealsConfigFunc added in v0.4.1

func NewSetConsiderOnlineRetrievalDealsConfigFunc(r repo.LockedRepo) (dtypes.SetConsiderOnlineRetrievalDealsConfigFunc, error)

func NewSetConsideringOfflineStorageDealsFunc added in v0.4.1

func NewSetConsideringOfflineStorageDealsFunc(r repo.LockedRepo) (dtypes.SetConsiderOfflineStorageDealsConfigFunc, error)

func NewSetConsideringOnlineStorageDealsFunc added in v0.4.1

func NewSetConsideringOnlineStorageDealsFunc(r repo.LockedRepo) (dtypes.SetConsiderOnlineStorageDealsConfigFunc, error)

func NewSetConsideringUnverifiedStorageDealsFunc added in v1.2.3

func NewSetConsideringUnverifiedStorageDealsFunc(r repo.LockedRepo) (dtypes.SetConsiderUnverifiedStorageDealsConfigFunc, error)

func NewSetConsideringVerifiedStorageDealsFunc added in v1.2.3

func NewSetConsideringVerifiedStorageDealsFunc(r repo.LockedRepo) (dtypes.SetConsiderVerifiedStorageDealsConfigFunc, error)

func NewSetExpectedSealDurationFunc added in v0.5.0

func NewSetExpectedSealDurationFunc(r repo.LockedRepo) (dtypes.SetExpectedSealDurationFunc, error)

func NewSetMaxDealStartDelayFunc added in v1.10.0

func NewSetMaxDealStartDelayFunc(r repo.LockedRepo) (dtypes.SetMaxDealStartDelayFunc, error)

func NewSetSealConfigFunc added in v0.5.0

func NewSetSealConfigFunc(r repo.LockedRepo) (dtypes.SetSealingConfigFunc, error)

func NewSetStorageDealPieceCidBlocklistConfigFunc added in v0.4.1

func NewSetStorageDealPieceCidBlocklistConfigFunc(r repo.LockedRepo) (dtypes.SetStorageDealPieceCidBlocklistConfigFunc, error)

func NewSlashFilter added in v0.5.0

func NewSlashFilter(ds dtypes.MetadataDS) *slashfilter.SlashFilter

func NewStorageAsk added in v0.3.1

func NewStorageDealPieceCidBlocklistConfigFunc added in v0.4.1

func NewStorageDealPieceCidBlocklistConfigFunc(r repo.LockedRepo) (dtypes.StorageDealPieceCidBlocklistConfigFunc, error)

func NewSyncer

func NewSyncer(params SyncerParams) (*chain.Syncer, error)

func NoopGCReferenceProtector added in v1.11.1

func NoopGCReferenceProtector(_ fx.Lifecycle) dtypes.GCReferenceProtector

func OpenFilesystemJournal added in v0.7.1

func OpenFilesystemJournal(lr repo.LockedRepo, lc fx.Lifecycle, disabled journal.DisabledEvents) (journal.Journal, error)

func PreflightChecks added in v1.17.2

func PreflightChecks(mctx helpers.MetricsCtx, lc fx.Lifecycle, api v1api.FullNode, maddr dtypes.MinerAddress) error

func RandomSchedule added in v0.7.0

func RecordValidator

func RecordValidator(ps peerstore.Peerstore) record.Validator

RecordValidator provides namesys compatible routing record validator

func RelayIndexerMessages added in v1.15.1

func RelayIndexerMessages(lc fx.Lifecycle, ps *pubsub.PubSub, nn dtypes.NetworkName, h host.Host, chainModule full.ChainModuleAPI, stateModule full.StateModuleAPI) error

func RemoteStorage added in v1.11.0

func RemoteStorage(lstor *paths.Local, si paths.SectorIndex, sa sealer.StorageAuth, sc config.SealerConfig) *paths.Remote

func RetrievalBlockstoreAccessor added in v1.11.2

func RetrievalBlockstoreAccessor(r repo.LockedRepo) (retrievalmarket.BlockstoreAccessor, error)

RetrievalBlockstoreAccessor returns the default retrieval blockstore accessor using the subdirectory `retrievals` under the repo.

func RetrievalClient added in v0.2.1

RetrievalClient creates a new retrieval client attached to the client blockstore

func RetrievalNetwork added in v1.11.1

func RetrievalNetwork(h host.Host) rmnet.RetrievalMarketNetwork

func RetrievalPricingFunc added in v1.11.0

RetrievalPricingFunc configures the pricing function to use for retrieval deals.

func RetrievalProvider added in v0.2.1

RetrievalProvider creates a new retrieval provider attached to the provider blockstore

func RetrievalResolver

func RetrievalResolver(l *discoveryimpl.Local) discovery.PeerResolver

func RunChainExchange added in v0.6.2

func RunChainExchange(h host.Host, svc exchange.Server)

func RunConsensusFaultReporter added in v1.23.3

func RunConsensusFaultReporter(config config.FaultReporterConfig) func(mctx helpers.MetricsCtx, lc fx.Lifecycle, mod consensusReporterModules) error

func RunHello

func RunHello(mctx helpers.MetricsCtx, lc fx.Lifecycle, h host.Host, svc *hello.Service) error

func RunPeerMgr

func RunPeerMgr(mctx helpers.MetricsCtx, lc fx.Lifecycle, pmgr *peermgr.PeerMgr)

func SealProofType added in v1.2.0

func SealProofType(maddr dtypes.MinerAddress, fnapi v1api.FullNode) (abi.RegisteredSealProof, error)

func SealingPipeline added in v1.17.2

func SealingPipeline(fc config.MinerFeeConfig) func(params SealingPipelineParams) (*sealing.Sealing, error)

func SectorStorage added in v0.3.0

func SplitBlockstore added in v1.5.1

func SplitBlockstoreGCReferenceProtector added in v1.11.1

func SplitBlockstoreGCReferenceProtector(_ fx.Lifecycle, s dtypes.SplitBlockstore) dtypes.GCReferenceProtector

func StagingBlockstore added in v0.2.1

func StagingBlockstore(lc fx.Lifecycle, mctx helpers.MetricsCtx, r repo.LockedRepo) (dtypes.StagingBlockstore, error)

StagingBlockstore creates a blockstore for staging blocks for a miner in a storage deal, prior to sealing

func StagingGraphsync added in v0.2.1

func StagingGraphsync(parallelTransfersForStorage uint64, parallelTransfersForStoragePerPeer uint64, parallelTransfersForRetrieval uint64) func(mctx helpers.MetricsCtx, lc fx.Lifecycle, ibs dtypes.StagingBlockstore, h host.Host) dtypes.StagingGraphsync

StagingGraphsync creates a graphsync instance which reads and writes blocks to the StagingBlockstore

func StateFlatBlockstore added in v1.5.1

func StateManager added in v1.4.2

func StateSplitBlockstore added in v1.5.1

func StorageAuth added in v0.3.0

func StorageAuth(ctx helpers.MetricsCtx, ca v0api.Common) (sealer.StorageAuth, error)

func StorageAuthWithURL added in v1.11.1

func StorageAuthWithURL(apiInfo string) func(ctx helpers.MetricsCtx, ca v0api.Common) (sealer.StorageAuth, error)

func StorageBlockstoreAccessor added in v1.11.2

func StorageBlockstoreAccessor(importmgr dtypes.ClientImportMgr) storagemarket.BlockstoreAccessor

StorageBlockstoreAccessor returns the default storage blockstore accessor from the import manager.

func StorageNetworkName added in v0.3.0

func StorageNetworkName(ctx helpers.MetricsCtx, a v1api.FullNode) (dtypes.NetworkName, error)

func ToSealingConfig added in v1.10.1

func ToSealingConfig(dealmakingCfg config.DealmakingConfig, sealingCfg config.SealingConfig) sealiface.Config

func UniversalBlockstore added in v1.5.1

func UniversalBlockstore(lc fx.Lifecycle, mctx helpers.MetricsCtx, r repo.LockedRepo) (dtypes.UniversalBlockstore, error)

UniversalBlockstore returns a single universal blockstore that stores both chain data and state data. It can be backed by a blockstore directly (e.g. Badger), or by a Splitstore.

func UpgradeSchedule added in v1.16.0

func UpgradeSchedule() stmgr.UpgradeSchedule

func WindowPostScheduler added in v1.15.2

Types

type EventHelperAPI added in v1.26.0

type EventHelperAPI struct {
	fx.In

	full.ChainAPI
	full.StateAPI
}

type Genesis

type Genesis func() (*types.BlockHeader, error)

func ErrorGenesis

func ErrorGenesis() Genesis

type IdxProv added in v1.15.1

type IdxProv struct {
	fx.In

	fx.Lifecycle
	Datastore dtypes.MetadataDS
}

type JwtPayload added in v0.5.0

type JwtPayload struct {
	Allow []auth.Permission
}

type MinerSealingService added in v1.11.1

type MinerSealingService api.StorageMiner

type MinerStorageService added in v1.11.1

type MinerStorageService api.StorageMiner

type MpoolNonceAPI added in v0.9.1

type MpoolNonceAPI struct {
	fx.In

	ChainModule full.ChainModuleAPI
	StateModule full.StateModuleAPI
}

MpoolNonceAPI substitutes the mpool nonce with an implementation that doesn't rely on the mpool - it just gets the nonce from actor state

func (*MpoolNonceAPI) GetActor added in v1.11.0

func (a *MpoolNonceAPI) GetActor(ctx context.Context, addr address.Address, tsk types.TipSetKey) (*types.Actor, error)

func (*MpoolNonceAPI) GetNonce added in v0.9.1

func (a *MpoolNonceAPI) GetNonce(ctx context.Context, addr address.Address, tsk types.TipSetKey) (uint64, error)

GetNonce gets the nonce from current chain head.

type PaychAPI added in v1.9.0

type PaychAPI struct {
	fx.In

	full.MpoolAPI
	full.StateAPI
}

type RPCHandler added in v1.19.0

type RPCHandler struct {
	// contains filtered or unexported fields
}

func NewRPCHandler added in v1.19.0

func NewRPCHandler(mpoolAPI full.MpoolAPI, cons *consensus.Consensus) *RPCHandler

func (*RPCHandler) AddPeer added in v1.19.0

func (h *RPCHandler) AddPeer(ctx context.Context, pid peer.ID, ret *struct{}) error

func (*RPCHandler) MpoolPushMessage added in v1.19.0

func (h *RPCHandler) MpoolPushMessage(ctx context.Context, msgWhole *api.MpoolMessageWhole, ret *types.SignedMessage) error

type RandomBeaconParams added in v0.3.1

type RandomBeaconParams struct {
	fx.In

	PubSub      *pubsub.PubSub `optional:"true"`
	Cs          *store.ChainStore
	DrandConfig dtypes.DrandSchedule
}

type SealingPipelineParams added in v1.17.2

type SealingPipelineParams struct {
	fx.In

	Lifecycle          fx.Lifecycle
	MetricsCtx         helpers.MetricsCtx
	API                v1api.FullNode
	MetadataDS         dtypes.MetadataDS
	Sealer             sealer.SectorManager
	Verifier           storiface.Verifier
	Prover             storiface.Prover
	GetSealingConfigFn dtypes.GetSealingConfigFunc
	Journal            journal.Journal
	AddrSel            *ctladdr.AddressSelector
	Maddr              dtypes.MinerAddress
}

type SyncerParams added in v0.7.1

type SyncerParams struct {
	fx.In

	Lifecycle    fx.Lifecycle
	MetadataDS   dtypes.MetadataDS
	StateManager *stmgr.StateManager
	ChainXchg    exchange.Client
	SyncMgrCtor  chain.SyncManagerCtor
	Host         host.Host
	Beacon       beacon.Schedule
	Gent         chain.Genesis
	Consensus    consensus.Consensus
}

type UuidWrapper added in v1.17.2

type UuidWrapper struct {
	v1api.FullNode
}

func (*UuidWrapper) MpoolPushMessage added in v1.17.2

func (a *UuidWrapper) MpoolPushMessage(ctx context.Context, msg *types.Message, spec *api.MessageSendSpec) (*types.SignedMessage, error)

Directories

Path Synopsis

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL