Versions in this module Expand all Collapse all v8 v8.0.1 Jun 10, 2022 v8.0.0 Apr 22, 2022 Changes in this version + const AddressedPartitionsMax + const AddressedSectorsMax + const AllowCollisions + const ChainFinality + const ConsensusFaultFactor + const ConsensusFaultIneligibilityDuration + const CronEventProcessEarlyTerminations + const CronEventProvingDeadline + const DeadlineExpirationAmtBitwidth + const DeadlineOptimisticPoStSubmissionsAmtBitwidth + const DeadlinePartitionsAmtBitwidth + const DealLimitDenominator + const DeclarationsMax + const DenyCollisions + const ErrBalanceInvariantBroken + const ExpiredPreCommitCleanUpDelay + const FaultDeclarationCutoff + const MaxAggregateProofSize + const MaxAggregatedSectors + const MaxControlAddresses + const MaxMultiaddrData + const MaxPartitionsPerDeadline + const MaxPeerIDLength + const MaxSectorExpirationExtension + const MinAggregatedSectors + const MinSectorExpiration + const PartitionEarlyTerminationArrayAmtBitwidth + const PartitionExpirationAmtBitwidth + const PreCommitSectorBatchMaxSize + const PrecommitCleanUpAmtBitwidth + const ProveReplicaUpdatesMaxSize + const SectorsAmtBitwidth + const TerminationLifetimeCap + const WPoStChallengeLookback + const WPoStPeriodDeadlines + const WorkerKeyChangeDelay + var BasePenaltyForDisputedWindowPoSt = big.Mul(big.NewInt(20), builtin.TokenPrecision) + var BaseRewardForDisputedWindowPoSt = big.Mul(big.NewInt(4), builtin.TokenPrecision) + var BatchBalancer = big.Mul(big.NewInt(5), builtin.OneNanoFIL) + var BatchDiscount = builtin.BigFrac + var ContinuedFaultFactorDenom = 100 + var ContinuedFaultFactorNum = 351 + var ContinuedFaultProjectionPeriod = abi.ChainEpoch((builtin.EpochsInDay * ContinuedFaultFactorNum) / ContinuedFaultFactorDenom) + var EstimatedSinglePreCommitGasUsage = big.NewInt(16433324) + var EstimatedSingleProveCommitGasUsage = big.NewInt(49299973) + var FaultMaxAge = WPoStProvingPeriod * 42 + var InitialPledgeFactor = 20 + var InitialPledgeLockTarget = builtin.BigFrac + var InitialPledgeMaxPerByte = big.Div(big.NewInt(1e18), big.NewInt(32 << 30)) + var InitialPledgeProjectionPeriod = abi.ChainEpoch(InitialPledgeFactor) * builtin.EpochsInDay + var InvalidWindowPoStProjectionPeriod = abi.ChainEpoch(ContinuedFaultProjectionPeriod + 2*builtin.EpochsInDay) + var LockedRewardFactorDenom = big.NewInt(100) + var LockedRewardFactorNum = big.NewInt(75) + var MaxPreCommitRandomnessLookback = builtin.EpochsInDay + ChainFinality + var MaxProveCommitDuration = map[abi.RegisteredSealProof]abi.ChainEpoch + var PreCommitChallengeDelay = abi.ChainEpoch(150) + var PreCommitDepositFactor = 20 + var PreCommitDepositProjectionPeriod = abi.ChainEpoch(PreCommitDepositFactor) * builtin.EpochsInDay + var PreCommitSealProofTypesV8 = map[abi.RegisteredSealProof]struct + var RewardVestingSpec = VestSpec + var SealedCIDPrefix = cid.Prefix + var TerminationPenaltyLowerBoundProjectionPeriod = abi.ChainEpoch((builtin.EpochsInDay * 35) / 10) + var TerminationRewardFactor = builtin.BigFrac + var WPoStChallengeWindow = abi.ChainEpoch(30 * 60 / builtin.EpochDurationSeconds) + var WPoStDisputeWindow = 2 * ChainFinality + var WPoStProvingPeriod = abi.ChainEpoch(builtin.EpochsInDay) + var WindowPoStProofTypes = map[abi.RegisteredPoStProof]struct + func AggregatePreCommitNetworkFee(aggregateSize int, baseFee abi.TokenAmount) abi.TokenAmount + func AggregateProveCommitNetworkFee(aggregateSize int, baseFee abi.TokenAmount) abi.TokenAmount + func CanExtendSealProofType(_ abi.RegisteredSealProof) bool + func CanPreCommitSealProof(s abi.RegisteredSealProof) bool + func CanWindowPoStProof(s abi.RegisteredPoStProof) bool + func CheckEarlyTerminationQueue(earlyQ BitfieldQueue, terminated bitfield.BitField, ...) int + func CheckMinerBalances(st *State, store adt.Store, balance abi.TokenAmount, ...) + func CheckMinerInfo(info *MinerInfo, acc *builtin.MessageAccumulator) + func CheckPreCommits(st *State, store adt.Store, allocatedSectors map[uint64]bool, ...) + func ConsensusFaultActive(info *MinerInfo, currEpoch abi.ChainEpoch) bool + func ConsensusFaultPenalty(thisEpochReward abi.TokenAmount) abi.TokenAmount + func ExpectedRewardForPower(rewardEstimate, networkQAPowerEstimate smoothing.FilterEstimate, ...) abi.TokenAmount + func ExpectedRewardForPowerClampedAtAttoFIL(rewardEstimate, networkQAPowerEstimate smoothing.FilterEstimate, ...) abi.TokenAmount + func FindSector(store adt.Store, deadlines *Deadlines, sectorNum abi.SectorNumber) (uint64, uint64, error) + func InitialPledgeForPower(qaPower, baselinePower abi.StoragePower, ...) abi.TokenAmount + func NewDeadlineInfo(periodStart abi.ChainEpoch, deadlineIdx uint64, currEpoch abi.ChainEpoch) *dline.Info + func NewDeadlineInfoFromOffsetAndEpoch(periodStartSeed abi.ChainEpoch, currEpoch abi.ChainEpoch) *dline.Info + func PledgePenaltyForContinuedFault(rewardEstimate, networkQAPowerEstimate smoothing.FilterEstimate, ...) abi.TokenAmount + func PledgePenaltyForInvalidWindowPoSt(rewardEstimate, networkQAPowerEstimate smoothing.FilterEstimate, ...) abi.TokenAmount + func PledgePenaltyForTermination(dayReward abi.TokenAmount, sectorAge abi.ChainEpoch, ...) abi.TokenAmount + func PledgePenaltyForTerminationLowerBound(rewardEstimate, networkQAPowerEstimate smoothing.FilterEstimate, ...) abi.TokenAmount + func PreCommitDepositForPower(rewardEstimate, networkQAPowerEstimate smoothing.FilterEstimate, ...) abi.TokenAmount + func QAPowerForSector(size abi.SectorSize, sector *SectorOnChainInfo) abi.StoragePower + func QAPowerForWeight(size abi.SectorSize, duration abi.ChainEpoch, ...) abi.StoragePower + func QualityForWeight(size abi.SectorSize, duration abi.ChainEpoch, ...) abi.SectorQuality + func QuantSpecForDeadline(di *dline.Info) builtin.QuantSpec + func RepayDebtsOrAbort(rt Runtime, st *State) abi.TokenAmount + func RewardForConsensusSlashReport(epochReward abi.TokenAmount) abi.TokenAmount + func RewardForDisputedWindowPoSt(proofType abi.RegisteredPoStProof, disputedPower PowerPair) abi.TokenAmount + func SectorDealsMax(size abi.SectorSize) uint64 + func SectorKey(e abi.SectorNumber) abi.Keyer + type Actor struct + func (a Actor) ApplyRewards(rt Runtime, params *builtin.ApplyRewardParams) *abi.EmptyValue + func (a Actor) ChangeMultiaddrs(rt Runtime, params *ChangeMultiaddrsParams) *abi.EmptyValue + func (a Actor) ChangeOwnerAddress(rt Runtime, newAddress *addr.Address) *abi.EmptyValue + func (a Actor) ChangePeerID(rt Runtime, params *ChangePeerIDParams) *abi.EmptyValue + func (a Actor) ChangeWorkerAddress(rt Runtime, params *ChangeWorkerAddressParams) *abi.EmptyValue + func (a Actor) CheckSectorProven(rt Runtime, params *CheckSectorProvenParams) *abi.EmptyValue + func (a Actor) Code() cid.Cid + func (a Actor) CompactPartitions(rt Runtime, params *CompactPartitionsParams) *abi.EmptyValue + func (a Actor) CompactSectorNumbers(rt Runtime, params *CompactSectorNumbersParams) *abi.EmptyValue + func (a Actor) ConfirmSectorProofsValid(rt Runtime, params *builtin.ConfirmSectorProofsParams) *abi.EmptyValue + func (a Actor) ConfirmUpdateWorkerKey(rt Runtime, params *abi.EmptyValue) *abi.EmptyValue + func (a Actor) Constructor(rt Runtime, params *ConstructorParams) *abi.EmptyValue + func (a Actor) ControlAddresses(rt Runtime, _ *abi.EmptyValue) *GetControlAddressesReturn + func (a Actor) DeclareFaults(rt Runtime, params *DeclareFaultsParams) *abi.EmptyValue + func (a Actor) DeclareFaultsRecovered(rt Runtime, params *DeclareFaultsRecoveredParams) *abi.EmptyValue + func (a Actor) DisputeWindowedPoSt(rt Runtime, params *DisputeWindowedPoStParams) *abi.EmptyValue + func (a Actor) Exports() []interface{} + func (a Actor) ExtendSectorExpiration(rt Runtime, params *ExtendSectorExpirationParams) *abi.EmptyValue + func (a Actor) OnDeferredCronEvent(rt Runtime, params *builtin.DeferredCronEventParams) *abi.EmptyValue + func (a Actor) PreCommitSector(rt Runtime, params *PreCommitSectorParams) *abi.EmptyValue + func (a Actor) PreCommitSectorBatch(rt Runtime, params *PreCommitSectorBatchParams) *abi.EmptyValue + func (a Actor) ProveCommitAggregate(rt Runtime, params *ProveCommitAggregateParams) *abi.EmptyValue + func (a Actor) ProveCommitSector(rt Runtime, params *ProveCommitSectorParams) *abi.EmptyValue + func (a Actor) ProveReplicaUpdates(rt Runtime, params *ProveReplicaUpdatesParams) *bitfield.BitField + func (a Actor) RepayDebt(rt Runtime, _ *abi.EmptyValue) *abi.EmptyValue + func (a Actor) ReportConsensusFault(rt Runtime, params *ReportConsensusFaultParams) *abi.EmptyValue + func (a Actor) State() cbor.Er + func (a Actor) SubmitWindowedPoSt(rt Runtime, params *SubmitWindowedPoStParams) *abi.EmptyValue + func (a Actor) TerminateSectors(rt Runtime, params *TerminateSectorsParams) *TerminateSectorsReturn + func (a Actor) WithdrawBalance(rt Runtime, params *WithdrawBalanceParams) *abi.TokenAmount + type AdvanceDeadlineResult struct + DetectedFaultyPower PowerPair + PledgeDelta abi.TokenAmount + PowerDelta PowerPair + PreviouslyFaultyPower PowerPair + TotalFaultyPower PowerPair + type BitfieldQueue struct + func LoadBitfieldQueue(store adt.Store, root cid.Cid, quant builtin.QuantSpec, bitwidth int) (BitfieldQueue, error) + func (q BitfieldQueue) AddManyToQueueValues(values map[abi.ChainEpoch][]uint64) error + func (q BitfieldQueue) AddToQueue(rawEpoch abi.ChainEpoch, values bitfield.BitField) error + func (q BitfieldQueue) AddToQueueValues(epoch abi.ChainEpoch, values ...uint64) error + func (q BitfieldQueue) Cut(toCut bitfield.BitField) error + func (q BitfieldQueue) ForEach(cb func(epoch abi.ChainEpoch, bf bitfield.BitField) error) error + func (q BitfieldQueue) PopUntil(until abi.ChainEpoch) (values bitfield.BitField, modified bool, err error) + type BurnMethod string + const BurnMethodApplyRewards + const BurnMethodDeclareFaultsRecovered + const BurnMethodDisputeWindowedPoSt + const BurnMethodHandleProvingDeadline + const BurnMethodPreCommitSectorBatch + const BurnMethodProcessEarlyTerminations + const BurnMethodProveCommitAggregate + const BurnMethodRepayDebt + const BurnMethodReportConsensusFault + const BurnMethodWithdrawBalance + type ChangeMultiaddrsParams = miner0.ChangeMultiaddrsParams + type ChangePeerIDParams = miner0.ChangePeerIDParams + type ChangeWorkerAddressParams = miner0.ChangeWorkerAddressParams + type CheckSectorProvenParams = miner0.CheckSectorProvenParams + type CollisionPolicy bool + type CompactPartitionsParams = miner0.CompactPartitionsParams + type CompactSectorNumbersParams = miner0.CompactSectorNumbersParams + type ConstructorParams = power.MinerConstructorParams + type CronEventPayload = miner0.CronEventPayload + type CronEventType = miner0.CronEventType + type Deadline struct + EarlyTerminations bitfield.BitField + ExpirationsEpochs cid.Cid + FaultyPower PowerPair + LiveSectors uint64 + OptimisticPoStSubmissions cid.Cid + OptimisticPoStSubmissionsSnapshot cid.Cid + Partitions cid.Cid + PartitionsPoSted bitfield.BitField + PartitionsSnapshot cid.Cid + SectorsSnapshot cid.Cid + TotalSectors uint64 + func ConstructDeadline(store adt.Store) (*Deadline, error) + func (d *Deadline) AddExpirationPartitions(store adt.Store, expirationEpoch abi.ChainEpoch, partitions []uint64, ...) error + func (d *Deadline) IsLive() (bool, error) + func (d *Deadline) LoadPartition(store adt.Store, partIdx uint64) (*Partition, error) + func (d *Deadline) LoadPartitionSnapshot(store adt.Store, partIdx uint64) (*Partition, error) + func (d *Deadline) OptimisticProofsArray(store adt.Store) (*adt.Array, error) + func (d *Deadline) OptimisticProofsSnapshotArray(store adt.Store) (*adt.Array, error) + func (d *Deadline) PartitionsArray(store adt.Store) (*adt.Array, error) + func (d *Deadline) PartitionsSnapshotArray(store adt.Store) (*adt.Array, error) + func (d *Deadline) SectorsSnapshotArray(store adt.Store) (*adt.Array, error) + func (d *Deadline) ValidateState() error + func (dl *Deadline) AddSectors(store adt.Store, partitionSize uint64, proven bool, ...) (PowerPair, error) + func (dl *Deadline) DeclareFaultsRecovered(store adt.Store, sectors Sectors, ssize abi.SectorSize, ...) (err error) + func (dl *Deadline) LoadPartitionsForDispute(store adt.Store, partitions bitfield.BitField) (*DisputeInfo, error) + func (dl *Deadline) PopEarlyTerminations(store adt.Store, maxPartitions, maxSectors uint64) (result TerminationResult, hasMore bool, err error) + func (dl *Deadline) PopExpiredSectors(store adt.Store, until abi.ChainEpoch, quant builtin.QuantSpec) (*ExpirationSet, error) + func (dl *Deadline) ProcessDeadlineEnd(store adt.Store, quant builtin.QuantSpec, faultExpirationEpoch abi.ChainEpoch, ...) (powerDelta, penalizedPower PowerPair, err error) + func (dl *Deadline) RecordFaults(store adt.Store, sectors Sectors, ssize abi.SectorSize, ...) (powerDelta PowerPair, err error) + func (dl *Deadline) RecordPoStProofs(store adt.Store, partitions bitfield.BitField, proofs []proof.PoStProof) error + func (dl *Deadline) RecordProvenSectors(store adt.Store, sectors Sectors, ssize abi.SectorSize, ...) (*PoStResult, error) + func (dl *Deadline) RemovePartitions(store adt.Store, toRemove bitfield.BitField, quant builtin.QuantSpec) (live, dead bitfield.BitField, removedPower PowerPair, err error) + func (dl *Deadline) TakePoStProofs(store adt.Store, idx uint64) (partitions bitfield.BitField, proofs []proof.PoStProof, err error) + func (dl *Deadline) TerminateSectors(store adt.Store, sectors Sectors, epoch abi.ChainEpoch, ...) (powerLost PowerPair, err error) + func (t *Deadline) MarshalCBOR(w io.Writer) error + func (t *Deadline) UnmarshalCBOR(r io.Reader) error + type DeadlineSectorMap map[uint64]PartitionSectorMap + func (dm DeadlineSectorMap) Add(dlIdx, partIdx uint64, sectorNos bitfield.BitField) error + func (dm DeadlineSectorMap) AddValues(dlIdx, partIdx uint64, sectorNos ...uint64) error + func (dm DeadlineSectorMap) Check(maxPartitions, maxSectors uint64) error + func (dm DeadlineSectorMap) Count() (partitions, sectors uint64, err error) + func (dm DeadlineSectorMap) Deadlines() []uint64 + func (dm DeadlineSectorMap) ForEach(cb func(dlIdx uint64, pm PartitionSectorMap) error) error + type DeadlineStateSummary struct + ActivePower PowerPair + AllSectors bitfield.BitField + FaultyPower PowerPair + FaultySectors bitfield.BitField + LivePower PowerPair + LiveSectors bitfield.BitField + RecoveringSectors bitfield.BitField + TerminatedSectors bitfield.BitField + UnprovenSectors bitfield.BitField + func CheckDeadlineStateInvariants(deadline *Deadline, store adt.Store, quant builtin.QuantSpec, ...) *DeadlineStateSummary + type Deadlines struct + Due [WPoStPeriodDeadlines]cid.Cid + func ConstructDeadlines(emptyDeadlineCid cid.Cid) *Deadlines + func (d *Deadlines) ForEach(store adt.Store, cb func(dlIdx uint64, dl *Deadline) error) error + func (d *Deadlines) LoadDeadline(store adt.Store, dlIdx uint64) (*Deadline, error) + func (d *Deadlines) UpdateDeadline(store adt.Store, dlIdx uint64, deadline *Deadline) error + func (t *Deadlines) MarshalCBOR(w io.Writer) error + func (t *Deadlines) UnmarshalCBOR(r io.Reader) error + type DealSummary struct + SectorExpiration abi.ChainEpoch + SectorStart abi.ChainEpoch + type DeclareFaultsParams = miner0.DeclareFaultsParams + type DeclareFaultsRecoveredParams = miner0.DeclareFaultsRecoveredParams + type DisputeInfo struct + AllSectorNos bitfield.BitField + DisputedPower PowerPair + DisputedSectors PartitionSectorMap + IgnoredSectorNos bitfield.BitField + type DisputeWindowedPoStParams = miner3.DisputeWindowedPoStParams + type ExpirationExtension = miner0.ExpirationExtension + type ExpirationQueue struct + func LoadExpirationQueue(store adt.Store, root cid.Cid, quant builtin.QuantSpec, bitwidth int) (ExpirationQueue, error) + func (q ExpirationQueue) AddActiveSectors(sectors []*SectorOnChainInfo, ssize abi.SectorSize) (bitfield.BitField, PowerPair, abi.TokenAmount, error) + func (q ExpirationQueue) PopUntil(until abi.ChainEpoch) (*ExpirationSet, error) + func (q ExpirationQueue) RemoveSectors(sectors []*SectorOnChainInfo, faults bitfield.BitField, ...) (*ExpirationSet, PowerPair, error) + func (q ExpirationQueue) ReplaceSectors(oldSectors, newSectors []*SectorOnChainInfo, ssize abi.SectorSize) (bitfield.BitField, bitfield.BitField, PowerPair, abi.TokenAmount, error) + func (q ExpirationQueue) RescheduleAllAsFaults(faultExpiration abi.ChainEpoch) error + func (q ExpirationQueue) RescheduleAsFaults(newExpiration abi.ChainEpoch, sectors []*SectorOnChainInfo, ...) (PowerPair, error) + func (q ExpirationQueue) RescheduleRecovered(sectors []*SectorOnChainInfo, ssize abi.SectorSize) (PowerPair, error) + type ExpirationQueueStateSummary struct + ActivePower PowerPair + EarlySectors bitfield.BitField + ExpirationEpochs []abi.ChainEpoch + FaultyPower PowerPair + OnTimePledge abi.TokenAmount + OnTimeSectors bitfield.BitField + func CheckExpirationQueue(expQ ExpirationQueue, liveSectors map[abi.SectorNumber]*SectorOnChainInfo, ...) *ExpirationQueueStateSummary + type ExpirationSet struct + ActivePower PowerPair + EarlySectors bitfield.BitField + FaultyPower PowerPair + OnTimePledge abi.TokenAmount + OnTimeSectors bitfield.BitField + func NewExpirationSet(onTimeSectors, earlySectors bitfield.BitField, onTimePledge abi.TokenAmount, ...) *ExpirationSet + func NewExpirationSetEmpty() *ExpirationSet + func (es *ExpirationSet) Add(onTimeSectors, earlySectors bitfield.BitField, onTimePledge abi.TokenAmount, ...) error + func (es *ExpirationSet) Count() (count uint64, err error) + func (es *ExpirationSet) IsEmpty() (empty bool, err error) + func (es *ExpirationSet) Remove(onTimeSectors, earlySectors bitfield.BitField, onTimePledge abi.TokenAmount, ...) error + func (es *ExpirationSet) ValidateState() error + func (t *ExpirationSet) MarshalCBOR(w io.Writer) error + func (t *ExpirationSet) UnmarshalCBOR(r io.Reader) error + type ExtendSectorExpirationParams = miner0.ExtendSectorExpirationParams + type FaultDeclaration = miner0.FaultDeclaration + type GetControlAddressesReturn = miner2.GetControlAddressesReturn + type MinerInfo struct + ConsensusFaultElapsed abi.ChainEpoch + ControlAddresses []addr.Address + Multiaddrs []abi.Multiaddrs + Owner addr.Address + PeerId abi.PeerID + PendingOwnerAddress *addr.Address + PendingWorkerKey *WorkerKeyChange + SectorSize abi.SectorSize + WindowPoStPartitionSectors uint64 + WindowPoStProofType abi.RegisteredPoStProof + Worker addr.Address + func ConstructMinerInfo(owner, worker addr.Address, controlAddrs []addr.Address, pid []byte, ...) (*MinerInfo, error) + func (t *MinerInfo) MarshalCBOR(w io.Writer) error + func (t *MinerInfo) UnmarshalCBOR(r io.Reader) error + type Partition struct + EarlyTerminated cid.Cid + ExpirationsEpochs cid.Cid + Faults bitfield.BitField + FaultyPower PowerPair + LivePower PowerPair + Recoveries bitfield.BitField + RecoveringPower PowerPair + Sectors bitfield.BitField + Terminated bitfield.BitField + Unproven bitfield.BitField + UnprovenPower PowerPair + func ConstructPartition(store adt.Store) (*Partition, error) + func (p *Partition) ActivateUnproven() PowerPair + func (p *Partition) ActivePower() PowerPair + func (p *Partition) ActiveSectors() (bitfield.BitField, error) + func (p *Partition) AddSectors(store adt.Store, proven bool, sectors []*SectorOnChainInfo, ...) (PowerPair, error) + func (p *Partition) DeclareFaultsRecovered(sectors Sectors, ssize abi.SectorSize, sectorNos bitfield.BitField) (err error) + func (p *Partition) LiveSectors() (bitfield.BitField, error) + func (p *Partition) PopEarlyTerminations(store adt.Store, maxSectors uint64) (result TerminationResult, hasMore bool, err error) + func (p *Partition) PopExpiredSectors(store adt.Store, until abi.ChainEpoch, quant builtin.QuantSpec) (*ExpirationSet, error) + func (p *Partition) RecordFaults(store adt.Store, sectors Sectors, sectorNos bitfield.BitField, ...) (newFaults bitfield.BitField, powerDelta, newFaultyPower PowerPair, err error) + func (p *Partition) RecordMissedPost(store adt.Store, faultExpiration abi.ChainEpoch, quant builtin.QuantSpec) (powerDelta, penalizedPower, newFaultyPower PowerPair, err error) + func (p *Partition) RecordSkippedFaults(store adt.Store, sectors Sectors, ssize abi.SectorSize, ...) (powerDelta, newFaultPower, retractedRecoveryPower PowerPair, hasNewFaults bool, ...) + func (p *Partition) RecoverFaults(store adt.Store, sectors Sectors, ssize abi.SectorSize, ...) (PowerPair, error) + func (p *Partition) ReplaceSectors(store adt.Store, oldSectors, newSectors []*SectorOnChainInfo, ...) (PowerPair, abi.TokenAmount, error) + func (p *Partition) TerminateSectors(store adt.Store, sectors Sectors, epoch abi.ChainEpoch, ...) (*ExpirationSet, error) + func (p *Partition) ValidateBFState() error + func (p *Partition) ValidatePowerState() error + func (p *Partition) ValidateState() error + func (t *Partition) MarshalCBOR(w io.Writer) error + func (t *Partition) UnmarshalCBOR(r io.Reader) error + type PartitionSectorMap map[uint64]bitfield.BitField + func (pm PartitionSectorMap) Add(partIdx uint64, sectorNos bitfield.BitField) error + func (pm PartitionSectorMap) AddValues(partIdx uint64, sectorNos ...uint64) error + func (pm PartitionSectorMap) Count() (partitions, sectors uint64, err error) + func (pm PartitionSectorMap) ForEach(cb func(partIdx uint64, sectorNos bitfield.BitField) error) error + func (pm PartitionSectorMap) Partitions() []uint64 + type PartitionStateSummary struct + ActivePower PowerPair + AllSectors bitfield.BitField + EarlyTerminationCount int + ExpirationEpochs []abi.ChainEpoch + FaultyPower PowerPair + FaultySectors bitfield.BitField + LivePower PowerPair + LiveSectors bitfield.BitField + RecoveringPower PowerPair + RecoveringSectors bitfield.BitField + TerminatedSectors bitfield.BitField + UnprovenSectors bitfield.BitField + func CheckPartitionStateInvariants(partition *Partition, store adt.Store, quant builtin.QuantSpec, ...) *PartitionStateSummary + type PoStPartition = miner0.PoStPartition + type PoStResult struct + IgnoredSectors bitfield.BitField + NewFaultyPower PowerPair + Partitions bitfield.BitField + PowerDelta PowerPair + RecoveredPower PowerPair + RetractedRecoveryPower PowerPair + Sectors bitfield.BitField + type PowerPair struct + QA abi.StoragePower + Raw abi.StoragePower + func NewPowerPair(raw, qa abi.StoragePower) PowerPair + func NewPowerPairZero() PowerPair + func PowerForSector(sectorSize abi.SectorSize, sector *SectorOnChainInfo) PowerPair + func PowerForSectors(ssize abi.SectorSize, sectors []*SectorOnChainInfo) PowerPair + func (pp *PowerPair) Equals(other PowerPair) bool + func (pp PowerPair) Add(other PowerPair) PowerPair + func (pp PowerPair) IsZero() bool + func (pp PowerPair) Mul(m big.Int) PowerPair + func (pp PowerPair) Neg() PowerPair + func (pp PowerPair) Sub(other PowerPair) PowerPair + func (t *PowerPair) MarshalCBOR(w io.Writer) error + func (t *PowerPair) UnmarshalCBOR(r io.Reader) error + type PreCommitSectorBatchParams = miner5.PreCommitSectorBatchParams + type PreCommitSectorParams = miner0.SectorPreCommitInfo + type ProveCommitAggregateParams = miner5.ProveCommitAggregateParams + type ProveCommitSectorParams = miner0.ProveCommitSectorParams + type ProveReplicaUpdatesParams = miner7.ProveReplicaUpdatesParams + type RecoveryDeclaration = miner0.RecoveryDeclaration + type ReplicaUpdate = miner7.ReplicaUpdate + type ReportConsensusFaultParams = miner0.ReportConsensusFaultParams + type Runtime = runtime.Runtime + type SealVerifyStuff struct + DealIDs []abi.DealID + InteractiveEpoch abi.ChainEpoch + Proof []byte + SealRandEpoch abi.ChainEpoch + SealedCID cid.Cid + type SectorOnChainInfo struct + Activation abi.ChainEpoch + DealIDs []abi.DealID + DealWeight abi.DealWeight + ExpectedDayReward abi.TokenAmount + ExpectedStoragePledge abi.TokenAmount + Expiration abi.ChainEpoch + InitialPledge abi.TokenAmount + ReplacedDayReward abi.TokenAmount + ReplacedSectorAge abi.ChainEpoch + SealProof abi.RegisteredSealProof + SealedCID cid.Cid + SectorKeyCID *cid.Cid + SectorNumber abi.SectorNumber + VerifiedDealWeight abi.DealWeight + func (t *SectorOnChainInfo) MarshalCBOR(w io.Writer) error + func (t *SectorOnChainInfo) UnmarshalCBOR(r io.Reader) error + type SectorPreCommitInfo struct + DealIDs []abi.DealID + Expiration abi.ChainEpoch + ReplaceCapacity bool + ReplaceSectorDeadline uint64 + ReplaceSectorNumber abi.SectorNumber + ReplaceSectorPartition uint64 + SealProof abi.RegisteredSealProof + SealRandEpoch abi.ChainEpoch + SealedCID cid.Cid + SectorNumber abi.SectorNumber + func (t *SectorPreCommitInfo) MarshalCBOR(w io.Writer) error + func (t *SectorPreCommitInfo) UnmarshalCBOR(r io.Reader) error + type SectorPreCommitOnChainInfo struct + DealWeight abi.DealWeight + Info SectorPreCommitInfo + PreCommitDeposit abi.TokenAmount + PreCommitEpoch abi.ChainEpoch + VerifiedDealWeight abi.DealWeight + func (t *SectorPreCommitOnChainInfo) MarshalCBOR(w io.Writer) error + func (t *SectorPreCommitOnChainInfo) UnmarshalCBOR(r io.Reader) error + type Sectors struct + func LoadSectors(store adt.Store, root cid.Cid) (Sectors, error) + func (sa Sectors) Get(sectorNumber abi.SectorNumber) (info *SectorOnChainInfo, found bool, err error) + func (sa Sectors) Load(sectorNos bitfield.BitField) ([]*SectorOnChainInfo, error) + func (sa Sectors) LoadForProof(provenSectors, expectedFaults bitfield.BitField) ([]*SectorOnChainInfo, error) + func (sa Sectors) LoadWithFaultMask(sectors bitfield.BitField, faults bitfield.BitField, ...) ([]*SectorOnChainInfo, error) + func (sa Sectors) MustGet(sectorNumber abi.SectorNumber) (info *SectorOnChainInfo, err error) + func (sa Sectors) Store(infos ...*SectorOnChainInfo) error + type State struct + AllocatedSectors cid.Cid + CurrentDeadline uint64 + DeadlineCronActive bool + Deadlines cid.Cid + EarlyTerminations bitfield.BitField + FeeDebt abi.TokenAmount + Info cid.Cid + InitialPledge abi.TokenAmount + LockedFunds abi.TokenAmount + PreCommitDeposits abi.TokenAmount + PreCommittedSectors cid.Cid + PreCommittedSectorsCleanUp cid.Cid + ProvingPeriodStart abi.ChainEpoch + Sectors cid.Cid + VestingFunds cid.Cid + func ConstructState(store adt.Store, infoCid cid.Cid, periodStart abi.ChainEpoch, ...) (*State, error) + func (st *State) AddInitialPledge(amount abi.TokenAmount) error + func (st *State) AddLockedFunds(store adt.Store, currEpoch abi.ChainEpoch, vestingSum abi.TokenAmount, ...) (vested abi.TokenAmount, err error) + func (st *State) AddPreCommitCleanUps(store adt.Store, cleanUpEvents map[abi.ChainEpoch][]uint64) error + func (st *State) AddPreCommitDeposit(amount abi.TokenAmount) error + func (st *State) AdvanceDeadline(store adt.Store, currEpoch abi.ChainEpoch) (*AdvanceDeadlineResult, error) + func (st *State) AllocateSectorNumbers(store adt.Store, sectorNos bitfield.BitField, policy CollisionPolicy) error + func (st *State) ApplyPenalty(penalty abi.TokenAmount) error + func (st *State) AssignSectorsToDeadlines(store adt.Store, currentEpoch abi.ChainEpoch, sectors []*SectorOnChainInfo, ...) error + func (st *State) CheckBalanceInvariants(balance abi.TokenAmount) error + func (st *State) CheckSectorActive(store adt.Store, dlIdx, pIdx uint64, sector abi.SectorNumber, ...) (bool, error) + func (st *State) CheckVestedFunds(store adt.Store, currEpoch abi.ChainEpoch) (abi.TokenAmount, error) + func (st *State) CleanUpExpiredPreCommits(store adt.Store, currEpoch abi.ChainEpoch) (depositToBurn abi.TokenAmount, err error) + func (st *State) ContinueDeadlineCron() bool + func (st *State) CurrentProvingPeriodStart(currEpoch abi.ChainEpoch) abi.ChainEpoch + func (st *State) DeadlineInfo(currEpoch abi.ChainEpoch) *dline.Info + func (st *State) DeletePrecommittedSectors(store adt.Store, sectorNos ...abi.SectorNumber) error + func (st *State) DeleteSectors(store adt.Store, sectorNos bitfield.BitField) error + func (st *State) FindPrecommittedSectors(store adt.Store, sectorNos ...abi.SectorNumber) ([]*SectorPreCommitOnChainInfo, error) + func (st *State) FindSector(store adt.Store, sno abi.SectorNumber) (uint64, uint64, error) + func (st *State) ForEachSector(store adt.Store, f func(*SectorOnChainInfo)) error + func (st *State) GetAllPrecommittedSectors(store adt.Store, sectorNos bitfield.BitField) ([]*SectorPreCommitOnChainInfo, error) + func (st *State) GetAvailableBalance(actorBalance abi.TokenAmount) (abi.TokenAmount, error) + func (st *State) GetInfo(store adt.Store) (*MinerInfo, error) + func (st *State) GetPrecommittedSector(store adt.Store, sectorNo abi.SectorNumber) (*SectorPreCommitOnChainInfo, bool, error) + func (st *State) GetSector(store adt.Store, sectorNo abi.SectorNumber) (*SectorOnChainInfo, bool, error) + func (st *State) GetUnlockedBalance(actorBalance abi.TokenAmount) (abi.TokenAmount, error) + func (st *State) HasSectorNo(store adt.Store, sectorNo abi.SectorNumber) (bool, error) + func (st *State) IsDebtFree() bool + func (st *State) LoadDeadlines(store adt.Store) (*Deadlines, error) + func (st *State) LoadSectorInfos(store adt.Store, sectors bitfield.BitField) ([]*SectorOnChainInfo, error) + func (st *State) LoadVestingFunds(store adt.Store) (*VestingFunds, error) + func (st *State) PopEarlyTerminations(store adt.Store, maxPartitions, maxSectors uint64) (result TerminationResult, hasMore bool, err error) + func (st *State) PutPrecommittedSectors(store adt.Store, precommits ...*SectorPreCommitOnChainInfo) error + func (st *State) PutSectors(store adt.Store, newSectors ...*SectorOnChainInfo) error + func (st *State) QuantSpecEveryDeadline() builtin.QuantSpec + func (st *State) QuantSpecForDeadline(dlIdx uint64) builtin.QuantSpec + func (st *State) RecordedDeadlineInfo(currEpoch abi.ChainEpoch) *dline.Info + func (st *State) RepayPartialDebtInPriorityOrder(store adt.Store, currEpoch abi.ChainEpoch, currBalance abi.TokenAmount) (fromVesting abi.TokenAmount, fromBalance abi.TokenAmount, err error) + func (st *State) SaveDeadlines(store adt.Store, deadlines *Deadlines) error + func (st *State) SaveInfo(store adt.Store, info *MinerInfo) error + func (st *State) SaveVestingFunds(store adt.Store, funds *VestingFunds) error + func (st *State) UnlockUnvestedFunds(store adt.Store, currEpoch abi.ChainEpoch, target abi.TokenAmount) (abi.TokenAmount, error) + func (st *State) UnlockVestedFunds(store adt.Store, currEpoch abi.ChainEpoch) (abi.TokenAmount, error) + func (t *State) MarshalCBOR(w io.Writer) error + func (t *State) UnmarshalCBOR(r io.Reader) error + type StateSummary struct + ActivePower PowerPair + DeadlineCronActive bool + Deals map[abi.DealID]DealSummary + FaultyPower PowerPair + LivePower PowerPair + WindowPoStProofType abi.RegisteredPoStProof + func CheckStateInvariants(st *State, store adt.Store, balance abi.TokenAmount) (*StateSummary, *builtin.MessageAccumulator) + type SubmitWindowedPoStParams = miner0.SubmitWindowedPoStParams + type TerminateSectorsParams = miner0.TerminateSectorsParams + type TerminateSectorsReturn = miner0.TerminateSectorsReturn + type TerminationDeclaration = miner0.TerminationDeclaration + type TerminationResult struct + PartitionsProcessed uint64 + Sectors map[abi.ChainEpoch]bitfield.BitField + SectorsProcessed uint64 + func (t *TerminationResult) Add(newResult TerminationResult) error + func (t *TerminationResult) BelowLimit(maxPartitions, maxSectors uint64) bool + func (t *TerminationResult) ForEach(cb func(epoch abi.ChainEpoch, sectors bitfield.BitField) error) error + func (t *TerminationResult) IsEmpty() bool + type VestSpec struct + InitialDelay abi.ChainEpoch + Quantization abi.ChainEpoch + StepDuration abi.ChainEpoch + VestPeriod abi.ChainEpoch + func LockedRewardFromReward(reward abi.TokenAmount) (abi.TokenAmount, *VestSpec) + type VestingFund struct + Amount abi.TokenAmount + Epoch abi.ChainEpoch + func (t *VestingFund) MarshalCBOR(w io.Writer) error + func (t *VestingFund) UnmarshalCBOR(r io.Reader) error + type VestingFunds struct + Funds []VestingFund + func ConstructVestingFunds() *VestingFunds + func (t *VestingFunds) MarshalCBOR(w io.Writer) error + func (t *VestingFunds) UnmarshalCBOR(r io.Reader) error + type WindowedPoSt struct + Partitions bitfield.BitField + Proofs []proof.PoStProof + func (t *WindowedPoSt) MarshalCBOR(w io.Writer) error + func (t *WindowedPoSt) UnmarshalCBOR(r io.Reader) error + type WithdrawBalanceParams = miner0.WithdrawBalanceParams + type WorkerKeyChange struct + EffectiveAt abi.ChainEpoch + NewWorker addr.Address + func (t *WorkerKeyChange) MarshalCBOR(w io.Writer) error + func (t *WorkerKeyChange) UnmarshalCBOR(r io.Reader) error Other modules containing this package github.com/filecoin-project/specs-actors github.com/filecoin-project/specs-actors/v2 github.com/filecoin-project/specs-actors/v3 github.com/filecoin-project/specs-actors/v4 github.com/filecoin-project/specs-actors/v5 github.com/filecoin-project/specs-actors/v6 github.com/filecoin-project/specs-actors/v7