Documentation ¶
Index ¶
- Constants
- Variables
- func IssueAndValidateMessageApproval(t *testing.T, messageAlias string, eventMock *EventMock, ...)
- func MessageCaller(handler interface{}, params ...interface{})
- func MessageIDCaller(handler interface{}, params ...interface{})
- func MessageInvalidCaller(handler interface{}, params ...interface{})
- func NodeIDCaller(handler interface{}, params ...interface{})
- func PrepareReferences(strongParents MessageIDs, issuingTime time.Time, tangle *Tangle) (references ParentMessageIDs, referenceNotPossible MessageIDs, err error)
- func RegisterMessageIDAlias(messageID MessageID, alias string)
- func SyncChangedCaller(handler interface{}, params ...interface{})
- func UnregisterMessageIDAliases()
- type ActivityLog
- func (a *ActivityLog) Active(lowerBound, upperBound time.Time) (active, empty bool)
- func (a *ActivityLog) Add(t time.Time) (added bool)
- func (a *ActivityLog) Bytes() (marshaledBranchWeight []byte)
- func (a *ActivityLog) Clone() *ActivityLog
- func (a *ActivityLog) String() string
- func (a *ActivityLog) Times() (times []int64)
- type ApprovalWeightManager
- func (a *ApprovalWeightManager) Setup()
- func (a *ApprovalWeightManager) Shutdown()
- func (a *ApprovalWeightManager) VotersOfBranch(branchID ledgerstate.BranchID) (voters *Voters)
- func (a *ApprovalWeightManager) WeightOfBranch(branchID ledgerstate.BranchID) (weight float64)
- func (a *ApprovalWeightManager) WeightOfMarker(marker *markers.Marker, anchorTime time.Time) (weight float64)
- type ApprovalWeightManagerEvents
- type Approver
- func (a *Approver) ApproverMessageID() MessageID
- func (a *Approver) Bytes() []byte
- func (a *Approver) FromBytes(bytes []byte) (result *Approver, err error)
- func (a *Approver) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (approver *Approver, err error)
- func (a *Approver) FromObjectStorage(key, _ []byte) (objectstorage.StorableObject, error)
- func (a *Approver) ObjectStorageKey() []byte
- func (a *Approver) ObjectStorageValue() (result []byte)
- func (a *Approver) ReferencedMessageID() MessageID
- func (a *Approver) String() string
- func (a *Approver) Type() ApproverType
- type ApproverType
- type Attachment
- func (a *Attachment) Bytes() []byte
- func (a *Attachment) FromBytes(bytes []byte) (result *Attachment, err error)
- func (a *Attachment) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (attachment *Attachment, err error)
- func (a *Attachment) FromObjectStorage(key, _ []byte) (objectstorage.StorableObject, error)
- func (a *Attachment) MessageID() MessageID
- func (a *Attachment) ObjectStorageKey() []byte
- func (a *Attachment) ObjectStorageValue() (data []byte)
- func (a *Attachment) String() string
- func (a *Attachment) TransactionID() ledgerstate.TransactionID
- type Booker
- func (b *Booker) BookMessage(messageID MessageID) (err error)
- func (b *Booker) MessageBranchIDs(messageID MessageID) (branchIDs ledgerstate.BranchIDs, err error)
- func (b *Booker) PayloadBranchIDs(messageID MessageID) (branchIDs ledgerstate.BranchIDs, err error)
- func (b *Booker) PropagateForkedBranch(transactionID ledgerstate.TransactionID, forkedBranchID ledgerstate.BranchID) (err error)
- func (b *Booker) Setup()
- func (b *Booker) Shutdown()
- type BookerEvents
- type BranchMarkersMapper
- func (b *BranchMarkersMapper) Ceiling(referenceMarker *markers.Marker) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
- func (b *BranchMarkersMapper) Floor(referenceMarker *markers.Marker) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
- func (b *BranchMarkersMapper) ForEachBranchIDMapping(sequenceID markers.SequenceID, thresholdIndex markers.Index, ...)
- func (b *BranchMarkersMapper) ForEachMarkerReferencingMarker(referencedMarker *markers.Marker, ...)
- func (b *BranchMarkersMapper) InheritStructureDetails(message *Message, structureDetails []*markers.StructureDetails) (newStructureDetails *markers.StructureDetails, newSequenceCreated bool)
- func (b *BranchMarkersMapper) MessageID(marker *markers.Marker) (messageID MessageID)
- func (b *BranchMarkersMapper) PendingBranchIDs(marker *markers.Marker) (branchIDs ledgerstate.BranchIDs, err error)
- func (b *BranchMarkersMapper) SetBranchIDs(marker *markers.Marker, branchIDs ledgerstate.BranchIDs) (updated bool)
- func (b *BranchMarkersMapper) SetMessageID(marker *markers.Marker, messageID MessageID)
- type BranchMarkersMapperEvents
- type BranchVote
- type BranchVoters
- func (b *BranchVoters) AddVoter(voter Voter) (added bool)
- func (b *BranchVoters) AddVoters(voters *Voters) (added bool)
- func (b *BranchVoters) BranchID() (branchID ledgerstate.BranchID)
- func (b *BranchVoters) Bytes() (marshaledBranchVoters []byte)
- func (b *BranchVoters) DeleteVoter(voter Voter) (deleted bool)
- func (b *BranchVoters) FromBytes(bytes []byte) (branchVoters *BranchVoters, err error)
- func (b *BranchVoters) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (branchVoters *BranchVoters, err error)
- func (b *BranchVoters) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (b *BranchVoters) Has(voter Voter) bool
- func (b *BranchVoters) ObjectStorageKey() []byte
- func (b *BranchVoters) ObjectStorageValue() []byte
- func (b *BranchVoters) String() string
- func (b *BranchVoters) Voters() (voters *Voters)
- type BranchWeight
- func (b *BranchWeight) BranchID() (branchID ledgerstate.BranchID)
- func (b *BranchWeight) Bytes() (marshaledBranchWeight []byte)
- func (b *BranchWeight) FromBytes(bytes []byte) (branchWeight *BranchWeight, err error)
- func (b *BranchWeight) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (branchWeight *BranchWeight, err error)
- func (b *BranchWeight) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (b *BranchWeight) ObjectStorageKey() []byte
- func (b *BranchWeight) ObjectStorageValue() []byte
- func (b *BranchWeight) SetWeight(weight float64) (modified bool)
- func (b *BranchWeight) String() string
- func (b *BranchWeight) Weight() (weight float64)
- type BranchWeightChangedEvent
- type BytesFilter
- type BytesRejectedEvent
- type CManaWeightProvider
- func (c *CManaWeightProvider) ActiveNodes() (activeNodes map[identity.ID]*ActivityLog)
- func (c *CManaWeightProvider) Shutdown()
- func (c *CManaWeightProvider) Update(t time.Time, nodeID identity.ID)
- func (c *CManaWeightProvider) Weight(message *Message) (weight, totalWeight float64)
- func (c *CManaWeightProvider) WeightsOfRelevantVoters() (weights map[identity.ID]float64, totalWeight float64)
- type CachedLatestMarkerVotesByVoter
- type ConfirmationEvents
- type ConfirmationOracle
- type DBStatsResult
- type Dispatcher
- type DispatcherEvents
- type EventMock
- func (e *EventMock) AssertExpectations(t mock.TestingT) bool
- func (e *EventMock) BranchWeightChanged(event *BranchWeightChangedEvent)
- func (e *EventMock) DetachAll()
- func (e *EventMock) Expect(eventName string, arguments ...interface{})
- func (e *EventMock) MarkerWeightChanged(event *MarkerWeightChangedEvent)
- func (e *EventMock) MessageProcessed(messageID MessageID)
- type Events
- type FutureMarkerUpdate
- type LastConfirmedMessage
- type LatestBranchVotes
- func (l *LatestBranchVotes) Bytes() []byte
- func (l *LatestBranchVotes) FromBytes(bytes []byte) (latestBranchVotes *LatestBranchVotes, err error)
- func (l *LatestBranchVotes) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (latestBranchVotes *LatestBranchVotes, err error)
- func (l *LatestBranchVotes) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (l *LatestBranchVotes) ObjectStorageKey() []byte
- func (l *LatestBranchVotes) ObjectStorageValue() []byte
- func (l *LatestBranchVotes) Store(vote *BranchVote) (stored bool)
- func (l *LatestBranchVotes) String() string
- func (l *LatestBranchVotes) Vote(branchID ledgerstate.BranchID) (vote *BranchVote, exists bool)
- type LatestMarkerVotes
- func (l *LatestMarkerVotes) Bytes() []byte
- func (l *LatestMarkerVotes) FromBytes(bytes []byte) (latestMarkerVotes *LatestMarkerVotes, err error)
- func (l *LatestMarkerVotes) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (latestMarkerVotes *LatestMarkerVotes, err error)
- func (l *LatestMarkerVotes) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (l *LatestMarkerVotes) ObjectStorageKey() []byte
- func (l *LatestMarkerVotes) ObjectStorageValue() []byte
- func (l *LatestMarkerVotes) Power(index markers.Index) (power VotePower, exists bool)
- func (l *LatestMarkerVotes) Store(index markers.Index, power VotePower) (stored bool, previousHighestIndex markers.Index)
- func (l *LatestMarkerVotes) String() string
- func (l *LatestMarkerVotes) Voter() Voter
- type LedgerState
- func (l *LedgerState) BookTransaction(transaction *ledgerstate.Transaction, messageID MessageID) (targetBranches ledgerstate.BranchIDs, err error)
- func (l *LedgerState) BranchIDs(transactionID ledgerstate.TransactionID) (branchIDs ledgerstate.BranchIDs)
- func (l *LedgerState) CachedOutput(outputID ledgerstate.OutputID) *objectstorage.CachedObject[ledgerstate.Output]
- func (l *LedgerState) CachedOutputMetadata(outputID ledgerstate.OutputID) *objectstorage.CachedObject[*ledgerstate.OutputMetadata]
- func (l *LedgerState) CachedOutputsOnAddress(address ledgerstate.Address) (cachedOutputs objectstorage.CachedObjects[ledgerstate.Output])
- func (l *LedgerState) CachedTransactionMetadata(transactionID ledgerstate.TransactionID) *objectstorage.CachedObject[*ledgerstate.TransactionMetadata]
- func (l *LedgerState) CheckTransaction(transaction *ledgerstate.Transaction) (err error)
- func (l *LedgerState) ConfirmedConsumer(outputID ledgerstate.OutputID) (consumerID ledgerstate.TransactionID)
- func (l *LedgerState) ConflictSet(transactionID ledgerstate.TransactionID) (conflictSet ledgerstate.TransactionIDs)
- func (l *LedgerState) ConsumedOutputs(transaction *ledgerstate.Transaction) (cachedInputs objectstorage.CachedObjects[ledgerstate.Output])
- func (l *LedgerState) Consumers(outputID ledgerstate.OutputID) (cachedTransactions objectstorage.CachedObjects[*ledgerstate.Consumer])
- func (l *LedgerState) LoadSnapshot(snapshot *ledgerstate.Snapshot) (err error)
- func (l *LedgerState) ReturnTransaction(transactionID ledgerstate.TransactionID) (transaction *ledgerstate.Transaction)
- func (l *LedgerState) Setup()
- func (l *LedgerState) Shutdown()
- func (l *LedgerState) SnapshotUTXO() (snapshot *ledgerstate.Snapshot)
- func (l *LedgerState) TotalSupply() (totalSupply uint64)
- func (l *LedgerState) Transaction(transactionID ledgerstate.TransactionID) *objectstorage.CachedObject[*ledgerstate.Transaction]
- func (l *LedgerState) TransactionConflicting(transactionID ledgerstate.TransactionID) bool
- func (l *LedgerState) TransactionMetadata(transactionID ledgerstate.TransactionID) (...)
- func (l *LedgerState) TransactionValid(transaction *ledgerstate.Transaction, messageID MessageID) (err error)
- func (l *LedgerState) Transactions() (transactions map[ledgerstate.TransactionID]*ledgerstate.Transaction)
- type LikedConflictMembers
- type ManaRetrieverFunc
- type MarkerIndexBranchIDMapping
- func (m *MarkerIndexBranchIDMapping) BranchIDs(markerIndex markers.Index) (branchIDs ledgerstate.BranchIDs)
- func (m *MarkerIndexBranchIDMapping) Bytes() []byte
- func (m *MarkerIndexBranchIDMapping) Ceiling(index markers.Index) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
- func (m *MarkerIndexBranchIDMapping) DeleteBranchID(index markers.Index)
- func (m *MarkerIndexBranchIDMapping) Floor(index markers.Index) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
- func (m *MarkerIndexBranchIDMapping) FromBytes(bytes []byte) (markerIndexBranchIDMapping objectstorage.StorableObject, err error)
- func (m *MarkerIndexBranchIDMapping) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (markerIndexBranchIDMapping *MarkerIndexBranchIDMapping, err error)
- func (m *MarkerIndexBranchIDMapping) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (m *MarkerIndexBranchIDMapping) ObjectStorageKey() []byte
- func (m *MarkerIndexBranchIDMapping) ObjectStorageValue() []byte
- func (m *MarkerIndexBranchIDMapping) SequenceID() markers.SequenceID
- func (m *MarkerIndexBranchIDMapping) SetBranchIDs(index markers.Index, branchIDs ledgerstate.BranchIDs)
- func (m *MarkerIndexBranchIDMapping) String() string
- type MarkerMessageMapping
- func (m *MarkerMessageMapping) Bytes() []byte
- func (m *MarkerMessageMapping) FromBytes(bytes []byte) (individuallyMappedMessage objectstorage.StorableObject, err error)
- func (m *MarkerMessageMapping) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (markerMessageMapping *MarkerMessageMapping, err error)
- func (m *MarkerMessageMapping) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (m *MarkerMessageMapping) Marker() *markers.Marker
- func (m *MarkerMessageMapping) MessageID() MessageID
- func (m *MarkerMessageMapping) ObjectStorageKey() []byte
- func (m *MarkerMessageMapping) ObjectStorageValue() []byte
- func (m *MarkerMessageMapping) String() string
- type MarkerWeightChangedEvent
- type Message
- func (m *Message) Bytes() []byte
- func (m *Message) ForEachParent(consumer func(parent Parent))
- func (m *Message) ForEachParentByType(parentType ParentsType, consumer func(parentMessageID MessageID) bool)
- func (m *Message) FromBytes(bytes []byte) (message *Message, err error)
- func (m *Message) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (*Message, error)
- func (m *Message) FromObjectStorage(key, data []byte) (result objectstorage.StorableObject, err error)
- func (m *Message) ID() (result MessageID)
- func (m *Message) IDBytes() []byte
- func (m *Message) IssuerPublicKey() ed25519.PublicKey
- func (m *Message) IssuingTime() time.Time
- func (m *Message) Nonce() uint64
- func (m *Message) ObjectStorageKey() []byte
- func (m *Message) ObjectStorageValue() []byte
- func (m *Message) ParentsByType(parentType ParentsType) MessageIDs
- func (m *Message) ParentsCountByType(parentType ParentsType) uint8
- func (m *Message) Payload() payload.Payload
- func (m *Message) SequenceNumber() uint64
- func (m *Message) Signature() ed25519.Signature
- func (m *Message) Size() int
- func (m *Message) String() string
- func (m *Message) VerifySignature() bool
- func (m *Message) Version() uint8
- type MessageFactory
- func (f *MessageFactory) IssuePayload(p payload.Payload, parentsCount ...int) (*Message, error)
- func (f *MessageFactory) IssuePayloadWithReferences(p payload.Payload, references ParentMessageIDs) (*Message, error)
- func (f *MessageFactory) SetTimeout(timeout time.Duration)
- func (f *MessageFactory) SetWorker(worker Worker)
- func (f *MessageFactory) Shutdown()
- type MessageFactoryEvents
- type MessageFilter
- type MessageID
- type MessageIDs
- func (m MessageIDs) Add(messageID MessageID) MessageIDs
- func (m MessageIDs) AddAll(messageIDs MessageIDs) MessageIDs
- func (m MessageIDs) Base58() (result []string)
- func (m MessageIDs) Clone() (clonedMessageIDs MessageIDs)
- func (m MessageIDs) Contains(target MessageID) (contains bool)
- func (m MessageIDs) Empty() (empty bool)
- func (m MessageIDs) First() MessageID
- func (m MessageIDs) Slice() []MessageID
- func (m MessageIDs) String() string
- func (m MessageIDs) Subtract(other MessageIDs) MessageIDs
- type MessageInvalidEvent
- type MessageMetadata
- func (m *MessageMetadata) AddBranchID(branchID ledgerstate.BranchID) (modified bool)
- func (m *MessageMetadata) AddedBranchIDs() ledgerstate.BranchIDs
- func (m *MessageMetadata) BookedTime() time.Time
- func (m *MessageMetadata) Bytes() []byte
- func (m *MessageMetadata) DiscardedTime() time.Time
- func (m *MessageMetadata) FromBytes(bytes []byte) (result *MessageMetadata, err error)
- func (m *MessageMetadata) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (messageMetadata *MessageMetadata, err error)
- func (m *MessageMetadata) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (m *MessageMetadata) GradeOfFinality() (result gof.GradeOfFinality)
- func (m *MessageMetadata) GradeOfFinalityTime() time.Time
- func (m *MessageMetadata) ID() MessageID
- func (m *MessageMetadata) IsBooked() (result bool)
- func (m *MessageMetadata) IsObjectivelyInvalid() (result bool)
- func (m *MessageMetadata) IsSolid() (result bool)
- func (m *MessageMetadata) IsSubjectivelyInvalid() (result bool)
- func (m *MessageMetadata) ObjectStorageKey() []byte
- func (m *MessageMetadata) ObjectStorageValue() []byte
- func (m *MessageMetadata) QueuedTime() time.Time
- func (m *MessageMetadata) ReceivedTime() time.Time
- func (m *MessageMetadata) Scheduled() (result bool)
- func (m *MessageMetadata) ScheduledTime() time.Time
- func (m *MessageMetadata) SetAddedBranchIDs(addedBranchIDs ledgerstate.BranchIDs) (modified bool)
- func (m *MessageMetadata) SetBooked(booked bool) (modified bool)
- func (m *MessageMetadata) SetDiscardedTime(discardedTime time.Time)
- func (m *MessageMetadata) SetGradeOfFinality(gradeOfFinality gof.GradeOfFinality) (modified bool)
- func (m *MessageMetadata) SetObjectivelyInvalid(invalid bool) (modified bool)
- func (m *MessageMetadata) SetQueuedTime(queuedTime time.Time)
- func (m *MessageMetadata) SetScheduled(scheduled bool) (modified bool)
- func (m *MessageMetadata) SetSolid(solid bool) (modified bool)
- func (m *MessageMetadata) SetStructureDetails(structureDetails *markers.StructureDetails) (modified bool)
- func (m *MessageMetadata) SetSubjectivelyInvalid(invalid bool) (modified bool)
- func (m *MessageMetadata) SetSubtractedBranchIDs(subtractedBranchIDs ledgerstate.BranchIDs) (modified bool)
- func (m *MessageMetadata) SolidificationTime() time.Time
- func (m *MessageMetadata) String() string
- func (m *MessageMetadata) StructureDetails() *markers.StructureDetails
- func (m *MessageMetadata) SubtractedBranchIDs() ledgerstate.BranchIDs
- type MessageOption
- func WithColoredOutput(alias string, balances map[ledgerstate.Color]uint64) MessageOption
- func WithInputs(inputAliases ...string) MessageOption
- func WithIssuer(issuer ed25519.PublicKey) MessageOption
- func WithIssuingTime(issuingTime time.Time) MessageOption
- func WithOutput(alias string, balance uint64) MessageOption
- func WithReattachment(messageAlias string) MessageOption
- func WithSequenceNumber(sequenceNumber uint64) MessageOption
- func WithShallowDislikeParents(messageAliases ...string) MessageOption
- func WithShallowLikeParents(messageAliases ...string) MessageOption
- func WithStrongParents(messageAliases ...string) MessageOption
- func WithWeakParents(messageAliases ...string) MessageOption
- type MessageParsedEvent
- type MessageRejectedEvent
- type MessageSignatureFilter
- func (f *MessageSignatureFilter) Close() error
- func (f *MessageSignatureFilter) Filter(msg *Message, peer *peer.Peer)
- func (f *MessageSignatureFilter) OnAccept(callback func(msg *Message, peer *peer.Peer))
- func (f *MessageSignatureFilter) OnReject(callback func(msg *Message, err error, peer *peer.Peer))
- type MessageTestFramework
- func (m *MessageTestFramework) Branch(messageAlias string) (b *ledgerstate.Branch)
- func (m *MessageTestFramework) BranchID(alias string) (branchID ledgerstate.BranchID)
- func (m *MessageTestFramework) BranchIDFromMessage(messageAlias string) ledgerstate.BranchID
- func (m *MessageTestFramework) BranchIDs(aliases ...string) (branchIDs ledgerstate.BranchIDs)
- func (m *MessageTestFramework) CreateMessage(messageAlias string, messageOptions ...MessageOption) (message *Message)
- func (m *MessageTestFramework) IncreaseMarkersIndexCallback(markers.SequenceID, markers.Index) bool
- func (m *MessageTestFramework) IssueMessages(messageAliases ...string) *MessageTestFramework
- func (m *MessageTestFramework) Message(alias string) (message *Message)
- func (m *MessageTestFramework) MessageMetadata(alias string) (messageMetadata *MessageMetadata)
- func (m *MessageTestFramework) OutputMetadata(outputID ledgerstate.OutputID) (outMeta *ledgerstate.OutputMetadata)
- func (m *MessageTestFramework) PreventNewMarkers(enabled bool) *MessageTestFramework
- func (m *MessageTestFramework) RegisterBranchID(alias, messageAlias string)
- func (m *MessageTestFramework) Transaction(messageAlias string) (tx *ledgerstate.Transaction)
- func (m *MessageTestFramework) TransactionID(messageAlias string) ledgerstate.TransactionID
- func (m *MessageTestFramework) TransactionMetadata(messageAlias string) (txMeta *ledgerstate.TransactionMetadata)
- func (m *MessageTestFramework) WaitApprovalWeightProcessed() *MessageTestFramework
- func (m *MessageTestFramework) WaitMessagesBooked() *MessageTestFramework
- type MessageTestFrameworkMessageOptions
- type MessageTestFrameworkOption
- type MessageTestFrameworkOptions
- type MissingMessage
- func (m *MissingMessage) Bytes() []byte
- func (m *MissingMessage) FromBytes(bytes []byte) (result *MissingMessage, err error)
- func (m *MissingMessage) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (result *MissingMessage, err error)
- func (m *MissingMessage) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
- func (m *MissingMessage) MessageID() MessageID
- func (m *MissingMessage) MissingSince() time.Time
- func (m *MissingMessage) ObjectStorageKey() []byte
- func (m *MissingMessage) ObjectStorageValue() (result []byte)
- type MockConfirmationOracle
- func (m *MockConfirmationOracle) Events() *ConfirmationEvents
- func (m *MockConfirmationOracle) FirstUnconfirmedMarkerIndex(sequenceID markers.SequenceID) (unconfirmedMarkerIndex markers.Index)
- func (m *MockConfirmationOracle) IsBranchConfirmed(branchID ledgerstate.BranchID) bool
- func (m *MockConfirmationOracle) IsMarkerConfirmed(*markers.Marker) bool
- func (m *MockConfirmationOracle) IsMessageConfirmed(msgID MessageID) bool
- func (m *MockConfirmationOracle) IsOutputConfirmed(outputID ledgerstate.OutputID) bool
- func (m *MockConfirmationOracle) IsTransactionConfirmed(transactionID ledgerstate.TransactionID) bool
- type MockWeightProvider
- func (m *MockWeightProvider) Shutdown()
- func (m *MockWeightProvider) Update(t time.Time, nodeID identity.ID)
- func (m *MockWeightProvider) Weight(message *Message) (weight, totalWeight float64)
- func (m *MockWeightProvider) WeightsOfRelevantVoters() (weights map[identity.ID]float64, totalWeight float64)
- type NodeIdentities
- type OTVConsensusManager
- type Opinion
- type Option
- func ApprovalWeights(weightProvider WeightProvider) Option
- func CacheTimeProvider(cacheTimeProvider *database.CacheTimeProvider) Option
- func GenesisNode(genesisNodeBase58 string) Option
- func Identity(identity *identity.LocalIdentity) Option
- func IncreaseMarkersIndexCallback(callback markers.IncreaseIndexCallback) Option
- func MergeBranches(mergeBranches bool) Option
- func RateSetterConfig(params RateSetterParams) Option
- func SchedulerConfig(config SchedulerParams) Option
- func StartSynced(startSynced bool) Option
- func Store(store kvstore.KVStore) Option
- func SyncTimeWindow(syncTimeWindow time.Duration) Option
- func TimeSinceConfirmationThreshold(tscThreshold time.Duration) Option
- func Width(width int) Option
- type Options
- type Parent
- type ParentMessageIDs
- func (p ParentMessageIDs) Add(parentType ParentsType, messageID MessageID) ParentMessageIDs
- func (p ParentMessageIDs) AddAll(parentType ParentsType, messageIDs MessageIDs) ParentMessageIDs
- func (p ParentMessageIDs) AddStrong(messageID MessageID) ParentMessageIDs
- func (p ParentMessageIDs) Clone() ParentMessageIDs
- type ParentsBlock
- type ParentsType
- type Parser
- type ParserEvents
- type PowFilter
- type PrePostStepTuple
- type RateSetter
- type RateSetterEvents
- type RateSetterParams
- type RecentlySeenBytesFilter
- type ReferencesFunc
- type Requester
- type RequesterEvents
- type RequesterOption
- type RequesterOptions
- type Scheduler
- func (s *Scheduler) AccessManaCache() *schedulerutils.AccessManaCache
- func (s *Scheduler) BufferSize() int
- func (s *Scheduler) Clear()
- func (s *Scheduler) GetManaFromCache(nodeID identity.ID) float64
- func (s *Scheduler) MaxBufferSize() int
- func (s *Scheduler) NodeQueueSize(nodeID identity.ID) int
- func (s *Scheduler) NodeQueueSizes() map[identity.ID]int
- func (s *Scheduler) Rate() time.Duration
- func (s *Scheduler) Ready(messageID MessageID) (err error)
- func (s *Scheduler) ReadyMessagesCount() int
- func (s *Scheduler) Running() bool
- func (s *Scheduler) SetRate(rate time.Duration)
- func (s *Scheduler) Setup()
- func (s *Scheduler) Shutdown()
- func (s *Scheduler) Start()
- func (s *Scheduler) Submit(messageID MessageID) (err error)
- func (s *Scheduler) SubmitAndReady(messageID MessageID) (err error)
- func (s *Scheduler) TotalMessagesCount() int
- func (s *Scheduler) Unsubmit(messageID MessageID) (err error)
- type SchedulerEvents
- type SchedulerParams
- type SendRequestEvent
- type SimpleMockOnTangleVoting
- type Solidifier
- type SolidifierEvents
- type Storage
- func (s *Storage) AllLatestMarkerVotes(sequenceID markers.SequenceID) (cachedLatestMarkerVotesByVoter CachedLatestMarkerVotesByVoter)
- func (s *Storage) Approvers(messageID MessageID, optionalApproverType ...ApproverType) (cachedApprovers objectstorage.CachedObjects[*Approver])
- func (s *Storage) AttachmentMessageIDs(transactionID ledgerstate.TransactionID) (messageIDs MessageIDs)
- func (s *Storage) Attachments(transactionID ledgerstate.TransactionID) (cachedAttachments objectstorage.CachedObjects[*Attachment])
- func (s *Storage) BranchVoters(branchID ledgerstate.BranchID, ...) *objectstorage.CachedObject[*BranchVoters]
- func (s *Storage) BranchWeight(branchID ledgerstate.BranchID, ...) *objectstorage.CachedObject[*BranchWeight]
- func (s *Storage) DBStats() (res DBStatsResult)
- func (s *Storage) DeleteMarkerMessageMapping(branchID ledgerstate.BranchID, messageID MessageID)
- func (s *Storage) DeleteMessage(messageID MessageID)
- func (s *Storage) DeleteMissingMessage(messageID MessageID)
- func (s *Storage) IsTransactionAttachedByMessage(transactionID ledgerstate.TransactionID, messageID MessageID) (attached bool)
- func (s *Storage) LatestBranchVotes(voter Voter, computeIfAbsentCallback ...func(voter Voter) *LatestBranchVotes) *objectstorage.CachedObject[*LatestBranchVotes]
- func (s *Storage) LatestMarkerVotes(sequenceID markers.SequenceID, voter Voter, ...) *objectstorage.CachedObject[*LatestMarkerVotes]
- func (s *Storage) MarkerIndexBranchIDMapping(sequenceID markers.SequenceID, ...) *objectstorage.CachedObject[*MarkerIndexBranchIDMapping]
- func (s *Storage) MarkerMessageMapping(marker *markers.Marker) (cachedMarkerMessageMappings *objectstorage.CachedObject[*MarkerMessageMapping])
- func (s *Storage) MarkerMessageMappings(sequenceID markers.SequenceID) (cachedMarkerMessageMappings objectstorage.CachedObjects[*MarkerMessageMapping])
- func (s *Storage) Message(messageID MessageID) *objectstorage.CachedObject[*Message]
- func (s *Storage) MessageMetadata(messageID MessageID, computeIfAbsentCallback ...func() *MessageMetadata) *objectstorage.CachedObject[*MessageMetadata]
- func (s *Storage) MissingMessages() (ids []MessageID)
- func (s *Storage) Prune() error
- func (s *Storage) RetrieveAllTips() (tips []MessageID)
- func (s *Storage) Setup()
- func (s *Storage) Shutdown()
- func (s *Storage) StoreAttachment(transactionID ledgerstate.TransactionID, messageID MessageID) (cachedAttachment *objectstorage.CachedObject[*Attachment], stored bool)
- func (s *Storage) StoreMarkerMessageMapping(markerMessageMapping *MarkerMessageMapping)
- func (s *Storage) StoreMessage(message *Message)
- func (s *Storage) StoreMissingMessage(missingMessage *MissingMessage) (cachedMissingMessage *objectstorage.CachedObject[*MissingMessage], stored bool)
- type StorageEvents
- type SyncChangedEvent
- type Tangle
- func (t *Tangle) Configure(options ...Option)
- func (t *Tangle) IssuePayload(p payload.Payload, parentsCount ...int) (message *Message, err error)
- func (t *Tangle) ProcessGossipMessage(messageBytes []byte, peer *peer.Peer)
- func (t *Tangle) Prune() (err error)
- func (t *Tangle) Setup()
- func (t *Tangle) Shutdown()
- func (t *Tangle) Synced() (synced bool)
- type TestScenario
- type TestStep
- type TimeManager
- type TimeManagerEvents
- type TimeRetrieverFunc
- type TimedTaskExecutor
- func (t *TimedTaskExecutor) Cancel(identifier interface{}) (canceled bool)
- func (t *TimedTaskExecutor) ExecuteAfter(identifier interface{}, callback func(), delay time.Duration) *timedexecutor.ScheduledTask
- func (t *TimedTaskExecutor) ExecuteAt(identifier interface{}, callback func(), executionTime time.Time) *timedexecutor.ScheduledTask
- type TipEvent
- type TipManager
- type TipManagerEvents
- type TipSelector
- type TipSelectorFunc
- type TransactionFilter
- type Utils
- func (u *Utils) AllBranchesLiked(branchIDs ledgerstate.BranchIDs) bool
- func (u *Utils) AllTransactionsApprovedByMessages(transactionIDs ledgerstate.TransactionIDs, messageIDs MessageIDs) (approved bool)
- func (u *Utils) ApprovingMessageIDs(messageID MessageID, optionalApproverType ...ApproverType) (approvingMessageIDs MessageIDs)
- func (u *Utils) ComputeIfTransaction(messageID MessageID, compute func(ledgerstate.TransactionID)) (computed bool)
- func (u *Utils) FirstAttachment(transactionID ledgerstate.TransactionID) (oldestAttachmentTime time.Time, oldestAttachmentMessageID MessageID, err error)
- func (u *Utils) MessageApprovedBy(approvedMessageID MessageID, approvingMessageID MessageID) (approved bool)
- func (u *Utils) TransactionApprovedByMessage(transactionID ledgerstate.TransactionID, messageID MessageID) (approved bool)
- func (u *Utils) WalkMessage(callback func(message *Message, walker *walker.Walker[MessageID]), ...)
- func (u *Utils) WalkMessageAndMetadata(callback func(message *Message, messageMetadata *MessageMetadata, ...), ...)
- func (u *Utils) WalkMessageID(callback func(messageID MessageID, walker *walker.Walker[MessageID]), ...)
- func (u *Utils) WalkMessageMetadata(...)
- type VotePower
- type Voter
- type Voters
- type WeightProvider
- type Worker
- type WorkerFunc
Constants ¶
const ( // MessageVersion defines the version of the message structure. MessageVersion uint8 = 1 // MaxMessageSize defines the maximum size of a message. MaxMessageSize = 64 * 1024 // MessageIDLength defines the length of an MessageID. MessageIDLength = 32 // MinParentsCount defines the minimum number of parents each parents block must have. MinParentsCount = 1 // MaxParentsCount defines the maximum number of parents each parents block must have. MaxParentsCount = 8 // MinParentsBlocksCount defines the minimum number of parents each parents block must have. MinParentsBlocksCount = 1 // MaxParentsBlocksCount defines the maximum number of parents each parents block must have. MaxParentsBlocksCount = 4 // MinStrongParentsCount defines the minimum number of strong parents a message must have. MinStrongParentsCount = 1 )
const ( // MaxLocalQueueSize is the maximum local (containing the message to be issued) queue size in bytes. MaxLocalQueueSize = 20 * MaxMessageSize // Backoff is the local threshold for rate setting; < MaxQueueWeight. Backoff = 25.0 // RateSettingIncrease is the global additive increase parameter. RateSettingIncrease = 1.0 // RateSettingDecrease global multiplicative decrease parameter (larger than 1). RateSettingDecrease = 1.5 // RateSettingPause is the time to wait before next rate's update after a backoff. RateSettingPause = 2 )
const ( // MaxDeficit is the maximum cap for accumulated deficit, i.e. max bytes that can be scheduled without waiting. // It must be >= MaxMessageSize. MaxDeficit = MaxMessageSize // MinMana is the minimum amount of Mana needed to issue messages. // MaxMessageSize / MinMana is also the upper bound of iterations inside one schedule call, as such it should not be too small. MinMana float64 = 1.0 )
const ( // PrefixMessage defines the storage prefix for message. PrefixMessage byte = iota // PrefixMessageMetadata defines the storage prefix for message metadata. PrefixMessageMetadata // PrefixApprovers defines the storage prefix for approvers. PrefixApprovers // PrefixMissingMessage defines the storage prefix for missing message. PrefixMissingMessage // PrefixAttachments defines the storage prefix for attachments. PrefixAttachments // PrefixMarkerBranchIDMapping defines the storage prefix for the PrefixMarkerBranchIDMapping. PrefixMarkerBranchIDMapping // PrefixBranchVoters defines the storage prefix for the BranchVoters. PrefixBranchVoters // PrefixLatestBranchVotes defines the storage prefix for the LatestBranchVotes. PrefixLatestBranchVotes // PrefixLatestMarkerVotes defines the storage prefix for the LatestMarkerVotes. PrefixLatestMarkerVotes // PrefixBranchWeight defines the storage prefix for the BranchWeight. PrefixBranchWeight // PrefixMarkerMessageMapping defines the storage prefix for the MarkerMessageMapping. PrefixMarkerMessageMapping // DBSequenceNumber defines the db sequence number. DBSequenceNumber = "seq" )
const ( // DefaultGenesisTime is the default time (Unix in seconds) of the genesis, i.e., the start of the epochs at 2021-03-19 9:00:00 UTC. DefaultGenesisTime int64 = 1616144400 // DefaultSyncTimeWindow is the default sync time window. DefaultSyncTimeWindow = 2 * time.Minute )
const ApproverTypeLength = 1
ApproverTypeLength contains the amount of bytes that a marshaled version of the ApproverType contains.
const AttachmentLength = ledgerstate.TransactionIDLength + MessageIDLength
AttachmentLength holds the length of a marshaled Attachment in bytes.
const ( // LastValidBlockType counts StrongParents, WeakParents, ShallowLikeParents, ShallowDislikeParents. LastValidBlockType = ShallowDislikeParentType )
const ( // MaxReattachmentTimeMin defines the max reattachment time. MaxReattachmentTimeMin = 10 * time.Minute )
Variables ¶
var ( // ErrNotSynced is triggered when somebody tries to issue a Payload before the Tangle is fully synced. ErrNotSynced = errors.New("tangle not synced") // ErrParentsInvalid is returned when one or more parents of a message is invalid. ErrParentsInvalid = errors.New("one or more parents is invalid") )
var ( // ErrNoStrongParents is triggered if there no strong parents. ErrNoStrongParents = errors.New("missing strong messages in first parent block") // ErrBlocksNotOrderedByType is triggered when the blocks are not ordered by their type. ErrBlocksNotOrderedByType = errors.New("blocks should be ordered in ascending order according to their type") // ErrBlockTypeIsUnknown is triggered when the block type is unknown. ErrBlockTypeIsUnknown = errors.Errorf("block types must range from %d-%d", 1, LastValidBlockType-1) // ErrParentsOutOfRange is triggered when a block is out of range. ErrParentsOutOfRange = errors.Errorf("a block must have at least %d-%d parents", MinParentsCount, MaxParentsCount) // ErrParentsNotLexicographicallyOrdered is triggred when parents are not lexicographically ordered. ErrParentsNotLexicographicallyOrdered = errors.New("messages within blocks must be lexicographically ordered") // ErrRepeatingBlockTypes is triggered if there are repeating block types in the message. ErrRepeatingBlockTypes = errors.New("block types within a message must not repeat") // ErrRepeatingReferencesInBlock is triggered if there are duplicate parents in a message block. ErrRepeatingReferencesInBlock = errors.New("duplicate parents in a message block") // ErrConflictingReferenceAcrossBlocks is triggered if there conflicting references across blocks. ErrConflictingReferenceAcrossBlocks = errors.New("different blocks have conflicting references") )
var ( // ErrInvalidPOWDifficultly is returned when the nonce of a message does not fulfill the PoW difficulty. ErrInvalidPOWDifficultly = errors.New("invalid PoW") // ErrMessageTooSmall is returned when the message does not contain enough data for the PoW. ErrMessageTooSmall = errors.New("message too small") // ErrInvalidSignature is returned when a message contains an invalid signature. ErrInvalidSignature = fmt.Errorf("invalid signature") // ErrReceivedDuplicateBytes is returned when duplicated bytes are rejected. ErrReceivedDuplicateBytes = fmt.Errorf("received duplicate bytes") // ErrInvalidMessageAndTransactionTimestamp is returned when the message its transaction timestamps are invalid. ErrInvalidMessageAndTransactionTimestamp = fmt.Errorf("invalid message and transaction timestamp") )
var ( // ErrInvalidIssuer is returned when an invalid message is passed to the rate setter. ErrInvalidIssuer = errors.New("message not issued by local node") // ErrStopped is returned when a message is passed to a stopped rate setter. ErrStopped = errors.New("rate setter stopped") )
var DefaultRequesterOptions = &RequesterOptions{ RetryInterval: 10 * time.Second, RetryJitter: 10 * time.Second, MaxRequestThreshold: 500, }
DefaultRequesterOptions defines the default options that are used when creating Requester instances.
var EmptyMessageID = MessageID{}
EmptyMessageID is an empty id.
var ErrNotRunning = errors.New("scheduler stopped")
ErrNotRunning is returned when a message is submitted when the scheduler has been stopped.
var Initial = 20000.0
Initial is the rate in bytes per second.
var LatestMarkerVotesKeyPartition = objectstorage.PartitionKey(markers.SequenceIDLength, identity.IDLength)
LatestMarkerVotesKeyPartition defines the partition of the storage key of the LastMarkerVotes model.
var MarkerMessageMappingPartitionKeys = objectstorage.PartitionKey(markers.SequenceIDLength, markers.IndexLength)
MarkerMessageMappingPartitionKeys defines the "layout" of the key. This enables prefix iterations in the object storage.
var ParentTypeToApproverType = map[ParentsType]ApproverType{ StrongParentType: StrongApprover, WeakParentType: WeakApprover, ShallowLikeParentType: ShallowLikeApprover, ShallowDislikeParentType: ShallowDislikeApprover, }
ParentTypeToApproverType represents a convenient mapping between a parent type and the approver type.
var ZeroWorker = WorkerFunc(func([]byte) (uint64, error) { return 0, nil })
ZeroWorker is a PoW worker that always returns 0 as the nonce.
Functions ¶
func IssueAndValidateMessageApproval ¶
func IssueAndValidateMessageApproval(t *testing.T, messageAlias string, eventMock *EventMock, testFramework *MessageTestFramework, expectedBranchWeights map[string]float64, expectedMarkerWeights map[markers.Marker]float64)
IssueAndValidateMessageApproval issues the msg by the given alias and assets the expected weights.
func MessageCaller ¶
func MessageCaller(handler interface{}, params ...interface{})
MessageCaller is the caller function for events that hand over a Message.
func MessageIDCaller ¶
func MessageIDCaller(handler interface{}, params ...interface{})
MessageIDCaller is the caller function for events that hand over a MessageID.
func MessageInvalidCaller ¶
func MessageInvalidCaller(handler interface{}, params ...interface{})
MessageInvalidCaller is the caller function for events that had over an invalid message.
func NodeIDCaller ¶
func NodeIDCaller(handler interface{}, params ...interface{})
NodeIDCaller is the caller function for events that hand over a NodeID.
func PrepareReferences ¶
func PrepareReferences(strongParents MessageIDs, issuingTime time.Time, tangle *Tangle) (references ParentMessageIDs, referenceNotPossible MessageIDs, err error)
PrepareReferences is an implementation of ReferencesFunc.
func RegisterMessageIDAlias ¶
RegisterMessageIDAlias registers an alias that will modify the String() output of the MessageID to show a human readable string instead of the base58 encoded version of itself.
func SyncChangedCaller ¶
func SyncChangedCaller(handler interface{}, params ...interface{})
SyncChangedCaller is the caller function for sync changed event.
func UnregisterMessageIDAliases ¶
func UnregisterMessageIDAliases()
UnregisterMessageIDAliases removes all aliases registered through the RegisterMessageIDAlias function.
Types ¶
type ActivityLog ¶
type ActivityLog struct {
// contains filtered or unexported fields
}
ActivityLog is a time-based log of node activity. It stores information when a node was active and provides functionality to query for certain timeframes.
func NewActivityLog ¶
func NewActivityLog() *ActivityLog
NewActivityLog is the constructor for ActivityLog.
func (*ActivityLog) Active ¶
func (a *ActivityLog) Active(lowerBound, upperBound time.Time) (active, empty bool)
Active returns true if the node was active between lower and upper bound. It cleans up the log on the fly, meaning that old/stale times are deleted. If the log ends up empty after cleaning up, empty is set to true.
func (*ActivityLog) Add ¶
func (a *ActivityLog) Add(t time.Time) (added bool)
Add adds a node activity to the log.
func (*ActivityLog) Bytes ¶
func (a *ActivityLog) Bytes() (marshaledBranchWeight []byte)
Bytes returns a marshaled version of the ActivityLog.
func (*ActivityLog) Clone ¶
func (a *ActivityLog) Clone() *ActivityLog
Clone clones the ActivityLog.
func (*ActivityLog) String ¶
func (a *ActivityLog) String() string
String returns a human-readable version of ActivityLog.
func (*ActivityLog) Times ¶
func (a *ActivityLog) Times() (times []int64)
Times returns all times stored in this ActivityLog.
type ApprovalWeightManager ¶
type ApprovalWeightManager struct { Events *ApprovalWeightManagerEvents // contains filtered or unexported fields }
ApprovalWeightManager is a Tangle component to keep track of relative weights of branches and markers so that consensus can be based on the heaviest perception on the tangle as a data structure.
func NewApprovalWeightManager ¶
func NewApprovalWeightManager(tangle *Tangle) (approvalWeightManager *ApprovalWeightManager)
NewApprovalWeightManager is the constructor for ApprovalWeightManager.
func (*ApprovalWeightManager) Setup ¶
func (a *ApprovalWeightManager) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
func (*ApprovalWeightManager) Shutdown ¶
func (a *ApprovalWeightManager) Shutdown()
Shutdown shuts down the ApprovalWeightManager and persists its state.
func (*ApprovalWeightManager) VotersOfBranch ¶
func (a *ApprovalWeightManager) VotersOfBranch(branchID ledgerstate.BranchID) (voters *Voters)
VotersOfBranch returns the Voters of the given branch ledgerstate.BranchID.
func (*ApprovalWeightManager) WeightOfBranch ¶
func (a *ApprovalWeightManager) WeightOfBranch(branchID ledgerstate.BranchID) (weight float64)
WeightOfBranch returns the weight of the given Branch that was added by Voters of the given epoch.
func (*ApprovalWeightManager) WeightOfMarker ¶
func (a *ApprovalWeightManager) WeightOfMarker(marker *markers.Marker, anchorTime time.Time) (weight float64)
WeightOfMarker returns the weight of the given marker based on the anchorTime.
type ApprovalWeightManagerEvents ¶
type ApprovalWeightManagerEvents struct { // MessageProcessed is triggered once a message is finished being processed by the ApprovalWeightManager. MessageProcessed *events.Event // BranchWeightChanged is triggered when a branch's weight changed. BranchWeightChanged *events.Event // MarkerWeightChanged is triggered when a marker's weight changed. MarkerWeightChanged *events.Event }
ApprovalWeightManagerEvents represents events happening in the ApprovalWeightManager.
type Approver ¶
type Approver struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
Approver is an approver of a given referenced message.
func NewApprover ¶
func NewApprover(approverType ApproverType, referencedMessageID MessageID, approverMessageID MessageID) *Approver
NewApprover creates a new approver relation to the given approved/referenced message.
func (*Approver) ApproverMessageID ¶
ApproverMessageID returns the ID of the message which referenced the given approved message.
func (*Approver) FromMarshalUtil ¶
func (a *Approver) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (approver *Approver, err error)
FromMarshalUtil parses a new approver from the given marshal util.
func (*Approver) FromObjectStorage ¶
func (a *Approver) FromObjectStorage(key, _ []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an Approver from sequences of key and bytes.
func (*Approver) ObjectStorageKey ¶
ObjectStorageKey marshals the keys of the stored approver into a byte array. This includes the referencedMessageID and the approverMessageID.
func (*Approver) ObjectStorageValue ¶
ObjectStorageValue returns the value of the stored approver object.
func (*Approver) ReferencedMessageID ¶
ReferencedMessageID returns the ID of the message which is referenced by the approver.
func (*Approver) Type ¶
func (a *Approver) Type() ApproverType
Type returns the type of the Approver reference.
type ApproverType ¶
type ApproverType uint8
ApproverType is a type that represents the different kind of reverse mapping that we have for references formed by strong and weak parents.
const ( // StrongApprover is the ApproverType that represents references formed by strong parents. StrongApprover ApproverType = iota // WeakApprover is the ApproverType that represents references formed by weak parents. WeakApprover // ShallowLikeApprover is the ApproverType that represents references formed by shallow like parents. ShallowLikeApprover // ShallowDislikeApprover is the ApproverType that represents references formed by shallow dislike parents. ShallowDislikeApprover )
func ApproverTypeFromBytes ¶
func ApproverTypeFromBytes(bytes []byte) (approverType ApproverType, consumedBytes int, err error)
ApproverTypeFromBytes unmarshals an ApproverType from a sequence of bytes.
func ApproverTypeFromMarshalUtil ¶
func ApproverTypeFromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (approverType ApproverType, err error)
ApproverTypeFromMarshalUtil unmarshals an ApproverType using a MarshalUtil (for easier unmarshaling).
func (ApproverType) Bytes ¶
func (a ApproverType) Bytes() []byte
Bytes returns a marshaled version of the ApproverType.
func (ApproverType) String ¶
func (a ApproverType) String() string
String returns a human readable version of the ApproverType.
type Attachment ¶
type Attachment struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
Attachment stores the information which transaction was attached by which message. We need this to be able to perform reverse lookups from transactions to their corresponding messages that attach them.
func NewAttachment ¶
func NewAttachment(transactionID ledgerstate.TransactionID, messageID MessageID) *Attachment
NewAttachment creates an attachment object with the given information.
func (*Attachment) Bytes ¶
func (a *Attachment) Bytes() []byte
Bytes marshals the Attachment into a sequence of bytes.
func (*Attachment) FromBytes ¶
func (a *Attachment) FromBytes(bytes []byte) (result *Attachment, err error)
FromBytes unmarshals an Attachment from a sequence of bytes - it either creates a new object or fills the optionally provided one with the parsed information.
func (*Attachment) FromMarshalUtil ¶
func (a *Attachment) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (attachment *Attachment, err error)
FromMarshalUtil is a wrapper for simplified unmarshaling of Attachments from a byte stream using the marshalUtil package.
func (*Attachment) FromObjectStorage ¶
func (a *Attachment) FromObjectStorage(key, _ []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an Attachment from sequences of key and bytes.
func (*Attachment) MessageID ¶
func (a *Attachment) MessageID() MessageID
MessageID returns the messageID of this Attachment.
func (*Attachment) ObjectStorageKey ¶
func (a *Attachment) ObjectStorageKey() []byte
ObjectStorageKey returns the key that is used to store the object in the database.
func (*Attachment) ObjectStorageValue ¶
func (a *Attachment) ObjectStorageValue() (data []byte)
ObjectStorageValue marshals the "content part" of an Attachment to a sequence of bytes. Since all of the information for this object are stored in its key, this method does nothing and is only required to conform with the interface.
func (*Attachment) String ¶
func (a *Attachment) String() string
String returns a human readable version of the Attachment.
func (*Attachment) TransactionID ¶
func (a *Attachment) TransactionID() ledgerstate.TransactionID
TransactionID returns the transactionID of this Attachment.
type Booker ¶
type Booker struct { // Events is a dictionary for the Booker related Events. Events *BookerEvents MarkersManager *BranchMarkersMapper // contains filtered or unexported fields }
Booker is a Tangle component that takes care of booking Messages and Transactions by assigning them to the corresponding Branch of the ledger state.
func (*Booker) BookMessage ¶
BookMessage tries to book the given Message (and potentially its contained Transaction) into the LedgerState and the Tangle. It fires a MessageBooked event if it succeeds. If the Message is invalid it fires a MessageInvalid event. Booking a message essentially means that parents are examined, the branch of the message determined based on the branch inheritance rules of the like switch and markers are inherited. If everything is valid, the message is marked as booked. Following, the message branch is set, and it can continue in the dataflow to add support to the determined branches and markers.
func (*Booker) MessageBranchIDs ¶
func (b *Booker) MessageBranchIDs(messageID MessageID) (branchIDs ledgerstate.BranchIDs, err error)
MessageBranchIDs returns the BranchIDs of the given Message.
func (*Booker) PayloadBranchIDs ¶
func (b *Booker) PayloadBranchIDs(messageID MessageID) (branchIDs ledgerstate.BranchIDs, err error)
PayloadBranchIDs returns the BranchIDs of the payload contained in the given Message.
func (*Booker) PropagateForkedBranch ¶
func (b *Booker) PropagateForkedBranch(transactionID ledgerstate.TransactionID, forkedBranchID ledgerstate.BranchID) (err error)
PropagateForkedBranch propagates the forked BranchID to the future cone of the attachments of the given Transaction.
type BookerEvents ¶
type BookerEvents struct { // MessageBooked is triggered when a Message was booked (it's Branch, and it's Payload's Branch were determined). MessageBooked *events.Event // MessageBranchUpdated is triggered when the BranchID of a Message is changed in its MessageMetadata. MessageBranchUpdated *events.Event // MarkerBranchAdded is triggered when a Marker is mapped to a new BranchID. MarkerBranchAdded *events.Event // Error gets triggered when the Booker faces an unexpected error. Error *events.Event }
BookerEvents represents events happening in the Booker.
type BranchMarkersMapper ¶
type BranchMarkersMapper struct { *markers.Manager Events *BranchMarkersMapperEvents // contains filtered or unexported fields }
BranchMarkersMapper is a Tangle component that takes care of managing the Markers which are used to infer structural information about the Tangle in an efficient way.
func NewBranchMarkersMapper ¶
func NewBranchMarkersMapper(tangle *Tangle) (b *BranchMarkersMapper)
NewBranchMarkersMapper is the constructor of the MarkersManager.
func (*BranchMarkersMapper) Ceiling ¶
func (b *BranchMarkersMapper) Ceiling(referenceMarker *markers.Marker) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
Ceiling returns the smallest Index that is >= the given Marker, it's BranchID and a boolean value indicating if it exists.
func (*BranchMarkersMapper) Floor ¶
func (b *BranchMarkersMapper) Floor(referenceMarker *markers.Marker) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
Floor returns the largest Index that is <= the given Marker, it's BranchIDs and a boolean value indicating if it exists.
func (*BranchMarkersMapper) ForEachBranchIDMapping ¶
func (b *BranchMarkersMapper) ForEachBranchIDMapping(sequenceID markers.SequenceID, thresholdIndex markers.Index, callback func(mappedMarker *markers.Marker, mappedBranchIDs ledgerstate.BranchIDs))
ForEachBranchIDMapping iterates over all BranchID mappings in the given Sequence that are bigger than the given thresholdIndex. Setting the thresholdIndex to 0 will iterate over all existing mappings.
func (*BranchMarkersMapper) ForEachMarkerReferencingMarker ¶
func (b *BranchMarkersMapper) ForEachMarkerReferencingMarker(referencedMarker *markers.Marker, callback func(referencingMarker *markers.Marker))
ForEachMarkerReferencingMarker executes the callback function for each Marker of other Sequences that directly reference the given Marker.
func (*BranchMarkersMapper) InheritStructureDetails ¶
func (b *BranchMarkersMapper) InheritStructureDetails(message *Message, structureDetails []*markers.StructureDetails) (newStructureDetails *markers.StructureDetails, newSequenceCreated bool)
InheritStructureDetails returns the structure Details of a Message that are derived from the StructureDetails of its strong and like parents.
func (*BranchMarkersMapper) MessageID ¶
func (b *BranchMarkersMapper) MessageID(marker *markers.Marker) (messageID MessageID)
MessageID retrieves the MessageID of the given Marker.
func (*BranchMarkersMapper) PendingBranchIDs ¶
func (b *BranchMarkersMapper) PendingBranchIDs(marker *markers.Marker) (branchIDs ledgerstate.BranchIDs, err error)
PendingBranchIDs returns the pending BranchIDs that are associated with the given Marker.
func (*BranchMarkersMapper) SetBranchIDs ¶
func (b *BranchMarkersMapper) SetBranchIDs(marker *markers.Marker, branchIDs ledgerstate.BranchIDs) (updated bool)
SetBranchIDs associates ledgerstate.BranchIDs with the given Marker.
func (*BranchMarkersMapper) SetMessageID ¶
func (b *BranchMarkersMapper) SetMessageID(marker *markers.Marker, messageID MessageID)
SetMessageID associates a MessageID with the given Marker.
type BranchMarkersMapperEvents ¶
type BranchMarkersMapperEvents struct { // FutureMarkerUpdated is triggered when a message's future marker is updated. FutureMarkerUpdated *events.Event }
BranchMarkersMapperEvents represents events happening in the BranchMarkersMapper.
type BranchVote ¶
type BranchVote struct { Voter Voter BranchID ledgerstate.BranchID Opinion Opinion VotePower VotePower }
BranchVote represents a struct that holds information about what Opinion a certain Voter has on a Branch.
func VoteFromMarshalUtil ¶
func VoteFromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (vote *BranchVote, err error)
VoteFromMarshalUtil unmarshals a Vote structure using a MarshalUtil (for easier unmarshalling).
func (*BranchVote) String ¶
func (v *BranchVote) String() string
String returns a human-readable version of the Vote.
func (*BranchVote) WithBranchID ¶
func (v *BranchVote) WithBranchID(branchID ledgerstate.BranchID) (rejectedVote *BranchVote)
WithBranchID derives a vote for the given BranchID.
func (*BranchVote) WithOpinion ¶
func (v *BranchVote) WithOpinion(opinion Opinion) (voteWithOpinion *BranchVote)
WithOpinion derives a vote for the given Opinion.
type BranchVoters ¶
type BranchVoters struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
BranchVoters is a data structure that tracks which nodes support a branch.
func NewBranchVoters ¶
func NewBranchVoters(branchID ledgerstate.BranchID) (branchVoters *BranchVoters)
NewBranchVoters is the constructor for the BranchVoters object.
func (*BranchVoters) AddVoter ¶
func (b *BranchVoters) AddVoter(voter Voter) (added bool)
AddVoter adds a new Voter to the tracked BranchID.
func (*BranchVoters) AddVoters ¶
func (b *BranchVoters) AddVoters(voters *Voters) (added bool)
AddVoters adds the Voters set to the tracked BranchID.
func (*BranchVoters) BranchID ¶
func (b *BranchVoters) BranchID() (branchID ledgerstate.BranchID)
BranchID returns the BranchID that is being tracked.
func (*BranchVoters) Bytes ¶
func (b *BranchVoters) Bytes() (marshaledBranchVoters []byte)
Bytes returns a marshaled version of the BranchVoters.
func (*BranchVoters) DeleteVoter ¶
func (b *BranchVoters) DeleteVoter(voter Voter) (deleted bool)
DeleteVoter deletes a Voter from the tracked BranchID.
func (*BranchVoters) FromBytes ¶
func (b *BranchVoters) FromBytes(bytes []byte) (branchVoters *BranchVoters, err error)
FromBytes unmarshals a BranchVoters object from a sequence of bytes.
func (*BranchVoters) FromMarshalUtil ¶
func (b *BranchVoters) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (branchVoters *BranchVoters, err error)
FromMarshalUtil unmarshals a BranchVoters object using a MarshalUtil (for easier unmarshalling).
func (*BranchVoters) FromObjectStorage ¶
func (b *BranchVoters) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an BranchVoters from sequences of key and bytes.
func (*BranchVoters) Has ¶
func (b *BranchVoters) Has(voter Voter) bool
Has returns true if the given Voter is currently supporting this Branch.
func (*BranchVoters) ObjectStorageKey ¶
func (b *BranchVoters) ObjectStorageKey() []byte
ObjectStorageKey returns the key that is used to store the object in the database. It is required to match the StorableObject interface.
func (*BranchVoters) ObjectStorageValue ¶
func (b *BranchVoters) ObjectStorageValue() []byte
ObjectStorageValue marshals the BranchVoters into a sequence of bytes that are used as the value part in the object storage.
func (*BranchVoters) String ¶
func (b *BranchVoters) String() string
String returns a human-readable version of the BranchVoters.
func (*BranchVoters) Voters ¶
func (b *BranchVoters) Voters() (voters *Voters)
Voters returns the set of Voters that are supporting the given BranchID.
type BranchWeight ¶
type BranchWeight struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
BranchWeight is a data structure that tracks the weight of a BranchID.
func NewBranchWeight ¶
func NewBranchWeight(branchID ledgerstate.BranchID) (branchWeight *BranchWeight)
NewBranchWeight creates a new BranchWeight.
func (*BranchWeight) BranchID ¶
func (b *BranchWeight) BranchID() (branchID ledgerstate.BranchID)
BranchID returns the BranchID that is being tracked.
func (*BranchWeight) Bytes ¶
func (b *BranchWeight) Bytes() (marshaledBranchWeight []byte)
Bytes returns a marshaled version of the BranchWeight.
func (*BranchWeight) FromBytes ¶
func (b *BranchWeight) FromBytes(bytes []byte) (branchWeight *BranchWeight, err error)
FromBytes unmarshals a BranchWeight object from a sequence of bytes.
func (*BranchWeight) FromMarshalUtil ¶
func (b *BranchWeight) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (branchWeight *BranchWeight, err error)
FromMarshalUtil unmarshals a BranchWeight object using a MarshalUtil (for easier unmarshalling).
func (*BranchWeight) FromObjectStorage ¶
func (b *BranchWeight) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an BranchWeight from sequences of key and bytes.
func (*BranchWeight) ObjectStorageKey ¶
func (b *BranchWeight) ObjectStorageKey() []byte
ObjectStorageKey returns the key that is used to store the object in the database. It is required to match the StorableObject interface.
func (*BranchWeight) ObjectStorageValue ¶
func (b *BranchWeight) ObjectStorageValue() []byte
ObjectStorageValue marshals the BranchWeight into a sequence of bytes that are used as the value part in the object storage.
func (*BranchWeight) SetWeight ¶
func (b *BranchWeight) SetWeight(weight float64) (modified bool)
SetWeight sets the weight for the BranchID and returns true if it was modified.
func (*BranchWeight) String ¶
func (b *BranchWeight) String() string
String returns a human-readable version of the BranchWeight.
func (*BranchWeight) Weight ¶
func (b *BranchWeight) Weight() (weight float64)
Weight returns the weight of the BranchID.
type BranchWeightChangedEvent ¶
type BranchWeightChangedEvent struct { BranchID ledgerstate.BranchID Weight float64 }
BranchWeightChangedEvent holds information about a branch and its updated weight.
type BytesFilter ¶
type BytesFilter interface { // Filter filters up on the given bytes and peer and calls the acceptance callback // if the input passes or the rejection callback if the input is rejected. Filter(bytes []byte, peer *peer.Peer) // OnAccept registers the given callback as the acceptance function of the filter. OnAccept(callback func(bytes []byte, peer *peer.Peer)) // OnReject registers the given callback as the rejection function of the filter. OnReject(callback func(bytes []byte, err error, peer *peer.Peer)) }
BytesFilter filters based on byte slices and peers.
type BytesRejectedEvent ¶
BytesRejectedEvent holds the information provided by the BytesRejected event that gets triggered when the bytes of a Message did not pass the parsing step.
type CManaWeightProvider ¶
type CManaWeightProvider struct {
// contains filtered or unexported fields
}
CManaWeightProvider is a WeightProvider for consensus mana. It keeps track of active nodes based on their time-based activity in relation to activeTimeThreshold.
func NewCManaWeightProvider ¶
func NewCManaWeightProvider(manaRetrieverFunc ManaRetrieverFunc, timeRetrieverFunc TimeRetrieverFunc, store ...kvstore.KVStore) (cManaWeightProvider *CManaWeightProvider)
NewCManaWeightProvider is the constructor for CManaWeightProvider.
func (*CManaWeightProvider) ActiveNodes ¶
func (c *CManaWeightProvider) ActiveNodes() (activeNodes map[identity.ID]*ActivityLog)
ActiveNodes returns the map of the active nodes.
func (*CManaWeightProvider) Shutdown ¶
func (c *CManaWeightProvider) Shutdown()
Shutdown shuts down the WeightProvider and persists its state.
func (*CManaWeightProvider) Update ¶
func (c *CManaWeightProvider) Update(t time.Time, nodeID identity.ID)
Update updates the underlying data structure and keeps track of active nodes.
func (*CManaWeightProvider) Weight ¶
func (c *CManaWeightProvider) Weight(message *Message) (weight, totalWeight float64)
Weight returns the weight and total weight for the given message.
func (*CManaWeightProvider) WeightsOfRelevantVoters ¶
func (c *CManaWeightProvider) WeightsOfRelevantVoters() (weights map[identity.ID]float64, totalWeight float64)
WeightsOfRelevantVoters returns all relevant weights.
type CachedLatestMarkerVotesByVoter ¶
type CachedLatestMarkerVotesByVoter map[Voter]*objectstorage.CachedObject[*LatestMarkerVotes]
CachedLatestMarkerVotesByVoter represents a cached LatestMarkerVotesByVoter mapped by Voter.
func (CachedLatestMarkerVotesByVoter) Consume ¶
func (c CachedLatestMarkerVotesByVoter) Consume(consumer func(latestMarkerVotes *LatestMarkerVotes), forceRelease ...bool) (consumed bool)
Consume unwraps the CachedObject and passes a type-casted version to the consumer (if the object is not empty - it exists). It automatically releases the object when the consumer finishes.
type ConfirmationEvents ¶
type ConfirmationEvents struct { MessageConfirmed *events.Event BranchConfirmed *events.Event TransactionConfirmed *events.Event }
ConfirmationEvents are events entailing confirmation.
type ConfirmationOracle ¶
type ConfirmationOracle interface { IsMarkerConfirmed(marker *markers.Marker) bool IsMessageConfirmed(msgID MessageID) bool IsBranchConfirmed(branchID ledgerstate.BranchID) bool IsTransactionConfirmed(transactionID ledgerstate.TransactionID) bool IsOutputConfirmed(outputID ledgerstate.OutputID) bool FirstUnconfirmedMarkerIndex(sequenceID markers.SequenceID) (unconfirmedMarkerIndex markers.Index) Events() *ConfirmationEvents }
ConfirmationOracle answers questions about entities' confirmation.
type DBStatsResult ¶
type DBStatsResult struct { StoredCount int SolidCount int BookedCount int ScheduledCount int SumSolidificationReceivedTime time.Duration SumBookedReceivedTime time.Duration SumSchedulerReceivedTime time.Duration SumSchedulerBookedTime time.Duration MissingMessageCount int }
DBStatsResult is a structure containing all the statistics retrieved by DBStats() method.
type Dispatcher ¶
type Dispatcher struct { Events *DispatcherEvents // contains filtered or unexported fields }
Dispatcher is a Tangle component that dispatches messages after being scheduled.
func NewDispatcher ¶
func NewDispatcher(tangle *Tangle) (dispatcher *Dispatcher)
NewDispatcher is the constructor for the Dispatcher.
func (*Dispatcher) Setup ¶
func (d *Dispatcher) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
type DispatcherEvents ¶
type DispatcherEvents struct { // MessageDispatched is triggered when a message is already scheduled and thus ready to be dispatched. MessageDispatched *events.Event }
DispatcherEvents represents events happening in the Dispatcher.
type EventMock ¶
EventMock acts as a container for event mocks.
func NewEventMock ¶
func NewEventMock(t *testing.T, approvalWeightManager *ApprovalWeightManager) *EventMock
NewEventMock creates a new EventMock.
func (*EventMock) AssertExpectations ¶
AssertExpectations asserts expectations.
func (*EventMock) BranchWeightChanged ¶
func (e *EventMock) BranchWeightChanged(event *BranchWeightChangedEvent)
BranchWeightChanged is the mocked BranchWeightChanged function.
func (*EventMock) DetachAll ¶
func (e *EventMock) DetachAll()
DetachAll detaches all event handlers.
func (*EventMock) MarkerWeightChanged ¶
func (e *EventMock) MarkerWeightChanged(event *MarkerWeightChangedEvent)
MarkerWeightChanged is the mocked MarkerWeightChanged function.
func (*EventMock) MessageProcessed ¶
MessageProcessed is the mocked MessageProcessed function.
type Events ¶
type Events struct { // MessageInvalid is triggered when a Message is detected to be objectively invalid. MessageInvalid *events.Event // Error is triggered when the Tangle faces an error from which it can not recover. Error *events.Event }
Events represents events happening in the Tangle.
type FutureMarkerUpdate ¶
FutureMarkerUpdate contains the messageID of the future marker of a message.
type LastConfirmedMessage ¶
LastConfirmedMessage is a wrapper type for the last confirmed message, consisting of MessageID and time.
func (LastConfirmedMessage) Bytes ¶
func (l LastConfirmedMessage) Bytes() (marshaledLastConfirmedMessage []byte)
Bytes returns a marshaled version of the LastConfirmedMessage.
func (LastConfirmedMessage) String ¶
func (l LastConfirmedMessage) String() string
String returns a human readable version of the LastConfirmedMessage.
type LatestBranchVotes ¶
type LatestBranchVotes struct { sync.RWMutex objectstorage.StorableObjectFlags // contains filtered or unexported fields }
LatestBranchVotes represents the branch supported from an Issuer.
func NewLatestBranchVotes ¶
func NewLatestBranchVotes(voter Voter) (latestBranchVotes *LatestBranchVotes)
NewLatestBranchVotes creates a new LatestBranchVotes.
func (*LatestBranchVotes) Bytes ¶
func (l *LatestBranchVotes) Bytes() []byte
Bytes returns a marshaled version of the LatestBranchVotes.
func (*LatestBranchVotes) FromBytes ¶
func (l *LatestBranchVotes) FromBytes(bytes []byte) (latestBranchVotes *LatestBranchVotes, err error)
FromBytes unmarshals a LatestBranchVotes object from a sequence of bytes.
func (*LatestBranchVotes) FromMarshalUtil ¶
func (l *LatestBranchVotes) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (latestBranchVotes *LatestBranchVotes, err error)
FromMarshalUtil unmarshals a LatestBranchVotes object using a MarshalUtil (for easier unmarshalling).
func (*LatestBranchVotes) FromObjectStorage ¶
func (l *LatestBranchVotes) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an LatestBranchVotes from sequences of key and bytes.
func (*LatestBranchVotes) ObjectStorageKey ¶
func (l *LatestBranchVotes) ObjectStorageKey() []byte
ObjectStorageKey returns the key that is used to store the object in the database. It is required to match the StorableObject interface.
func (*LatestBranchVotes) ObjectStorageValue ¶
func (l *LatestBranchVotes) ObjectStorageValue() []byte
ObjectStorageValue marshals the LatestBranchVotes into a sequence of bytes that are used as the value part in the object storage.
func (*LatestBranchVotes) Store ¶
func (l *LatestBranchVotes) Store(vote *BranchVote) (stored bool)
Store stores the vote for the LatestBranchVotes.
func (*LatestBranchVotes) String ¶
func (l *LatestBranchVotes) String() string
String returns a human-readable version of the LatestBranchVotes.
func (*LatestBranchVotes) Vote ¶
func (l *LatestBranchVotes) Vote(branchID ledgerstate.BranchID) (vote *BranchVote, exists bool)
Vote returns the Vote for the LatestBranchVotes.
type LatestMarkerVotes ¶
type LatestMarkerVotes struct { sync.RWMutex objectstorage.StorableObjectFlags // contains filtered or unexported fields }
LatestMarkerVotes keeps track of the most up-to-date for a certain Voter casted on a specific Marker SequenceID. Votes can be casted on Markers (SequenceID, Index), but can arrive in any arbitrary order. Due to the nature of a Sequence, a vote casted for a certain Index clobbers votes for every lower index. Similarly, if a vote for an Index is casted and an existing vote for an higher Index exists, the operation has no effect.
func NewLatestMarkerVotes ¶
func NewLatestMarkerVotes(sequenceID markers.SequenceID, voter Voter) (newLatestMarkerVotes *LatestMarkerVotes)
NewLatestMarkerVotes creates a new NewLatestMarkerVotes instance associated with the given details.
func (*LatestMarkerVotes) Bytes ¶
func (l *LatestMarkerVotes) Bytes() []byte
Bytes returns a marshaled version of the LatestMarkerVotes.
func (*LatestMarkerVotes) FromBytes ¶
func (l *LatestMarkerVotes) FromBytes(bytes []byte) (latestMarkerVotes *LatestMarkerVotes, err error)
FromBytes unmarshals a LatestMarkerVotes from a sequence of bytes.
func (*LatestMarkerVotes) FromMarshalUtil ¶
func (l *LatestMarkerVotes) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (latestMarkerVotes *LatestMarkerVotes, err error)
FromMarshalUtil unmarshals a LatestMarkerVotes using a MarshalUtil (for easier unmarshalling).
func (*LatestMarkerVotes) FromObjectStorage ¶
func (l *LatestMarkerVotes) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an LatestMarkerVotes from sequences of key and bytes.
func (*LatestMarkerVotes) ObjectStorageKey ¶
func (l *LatestMarkerVotes) ObjectStorageKey() []byte
ObjectStorageKey returns the storage key for this instance of LatestMarkerVotes.
func (*LatestMarkerVotes) ObjectStorageValue ¶
func (l *LatestMarkerVotes) ObjectStorageValue() []byte
ObjectStorageValue returns the storage value for this instance of LatestMarkerVotes.
func (*LatestMarkerVotes) Power ¶
func (l *LatestMarkerVotes) Power(index markers.Index) (power VotePower, exists bool)
Power returns the power of the vote for the given marker Index.
func (*LatestMarkerVotes) Store ¶
func (l *LatestMarkerVotes) Store(index markers.Index, power VotePower) (stored bool, previousHighestIndex markers.Index)
Store stores the vote with the given marker Index and votePower. The votePower parameter is used to determine the order of the vote.
func (*LatestMarkerVotes) String ¶
func (l *LatestMarkerVotes) String() string
String returns a human-readable version of the LatestMarkerVotes.
func (*LatestMarkerVotes) Voter ¶
func (l *LatestMarkerVotes) Voter() Voter
Voter returns the Voter for the LatestMarkerVotes.
type LedgerState ¶
type LedgerState struct { *ledgerstate.Ledgerstate // contains filtered or unexported fields }
LedgerState is a Tangle component that wraps the components of the ledgerstate package and makes them available at a "single point of contact".
func NewLedgerState ¶
func NewLedgerState(tangle *Tangle) (ledgerState *LedgerState)
NewLedgerState is the constructor of the LedgerState component.
func (*LedgerState) BookTransaction ¶
func (l *LedgerState) BookTransaction(transaction *ledgerstate.Transaction, messageID MessageID) (targetBranches ledgerstate.BranchIDs, err error)
BookTransaction books the given Transaction into the underlying LedgerState and returns the target Branch and an eventual error.
func (*LedgerState) BranchIDs ¶
func (l *LedgerState) BranchIDs(transactionID ledgerstate.TransactionID) (branchIDs ledgerstate.BranchIDs)
BranchIDs returns the branchIDs of the given transactionID.
func (*LedgerState) CachedOutput ¶
func (l *LedgerState) CachedOutput(outputID ledgerstate.OutputID) *objectstorage.CachedObject[ledgerstate.Output]
CachedOutput returns the Output with the given ID.
func (*LedgerState) CachedOutputMetadata ¶
func (l *LedgerState) CachedOutputMetadata(outputID ledgerstate.OutputID) *objectstorage.CachedObject[*ledgerstate.OutputMetadata]
CachedOutputMetadata returns the OutputMetadata with the given ID.
func (*LedgerState) CachedOutputsOnAddress ¶
func (l *LedgerState) CachedOutputsOnAddress(address ledgerstate.Address) (cachedOutputs objectstorage.CachedObjects[ledgerstate.Output])
CachedOutputsOnAddress retrieves all the Outputs that are associated with an address.
func (*LedgerState) CachedTransactionMetadata ¶
func (l *LedgerState) CachedTransactionMetadata(transactionID ledgerstate.TransactionID) *objectstorage.CachedObject[*ledgerstate.TransactionMetadata]
CachedTransactionMetadata returns the TransactionMetadata with the given ID.
func (*LedgerState) CheckTransaction ¶
func (l *LedgerState) CheckTransaction(transaction *ledgerstate.Transaction) (err error)
CheckTransaction contains fast checks that have to be performed before booking a Transaction.
func (*LedgerState) ConfirmedConsumer ¶
func (l *LedgerState) ConfirmedConsumer(outputID ledgerstate.OutputID) (consumerID ledgerstate.TransactionID)
ConfirmedConsumer returns the confirmed transactionID consuming the given outputID.
func (*LedgerState) ConflictSet ¶
func (l *LedgerState) ConflictSet(transactionID ledgerstate.TransactionID) (conflictSet ledgerstate.TransactionIDs)
ConflictSet returns the list of transactionIDs conflicting with the given transactionID.
func (*LedgerState) ConsumedOutputs ¶
func (l *LedgerState) ConsumedOutputs(transaction *ledgerstate.Transaction) (cachedInputs objectstorage.CachedObjects[ledgerstate.Output])
ConsumedOutputs returns the consumed (cached)Outputs of the given Transaction.
func (*LedgerState) Consumers ¶
func (l *LedgerState) Consumers(outputID ledgerstate.OutputID) (cachedTransactions objectstorage.CachedObjects[*ledgerstate.Consumer])
Consumers returns the (cached) consumers of the given outputID.
func (*LedgerState) LoadSnapshot ¶
func (l *LedgerState) LoadSnapshot(snapshot *ledgerstate.Snapshot) (err error)
LoadSnapshot creates a set of outputs in the UTXO-DAG, that are forming the genesis for future transactions.
func (*LedgerState) ReturnTransaction ¶
func (l *LedgerState) ReturnTransaction(transactionID ledgerstate.TransactionID) (transaction *ledgerstate.Transaction)
ReturnTransaction returns a specific transaction.
func (*LedgerState) Setup ¶
func (l *LedgerState) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
func (*LedgerState) Shutdown ¶
func (l *LedgerState) Shutdown()
Shutdown shuts down the LedgerState and persists its state.
func (*LedgerState) SnapshotUTXO ¶
func (l *LedgerState) SnapshotUTXO() (snapshot *ledgerstate.Snapshot)
SnapshotUTXO returns the UTXO snapshot, which is a list of transactions with unspent outputs.
func (*LedgerState) TotalSupply ¶
func (l *LedgerState) TotalSupply() (totalSupply uint64)
TotalSupply returns the total supply.
func (*LedgerState) Transaction ¶
func (l *LedgerState) Transaction(transactionID ledgerstate.TransactionID) *objectstorage.CachedObject[*ledgerstate.Transaction]
Transaction retrieves the Transaction with the given TransactionID from the object storage.
func (*LedgerState) TransactionConflicting ¶
func (l *LedgerState) TransactionConflicting(transactionID ledgerstate.TransactionID) bool
TransactionConflicting returns whether the given transaction is part of a conflict.
func (*LedgerState) TransactionMetadata ¶
func (l *LedgerState) TransactionMetadata(transactionID ledgerstate.TransactionID) (cachedTransactionMetadata *objectstorage.CachedObject[*ledgerstate.TransactionMetadata])
TransactionMetadata retrieves the TransactionMetadata with the given TransactionID from the object storage.
func (*LedgerState) TransactionValid ¶
func (l *LedgerState) TransactionValid(transaction *ledgerstate.Transaction, messageID MessageID) (err error)
TransactionValid performs some fast checks of the Transaction and triggers a MessageInvalid event if the checks do not pass.
func (*LedgerState) Transactions ¶
func (l *LedgerState) Transactions() (transactions map[ledgerstate.TransactionID]*ledgerstate.Transaction)
Transactions returns all the transactions.
type LikedConflictMembers ¶
type LikedConflictMembers struct {
// contains filtered or unexported fields
}
LikedConflictMembers is a struct that holds information about which Branch is the liked one out of a set of ConflictMembers.
type ManaRetrieverFunc ¶
ManaRetrieverFunc is a function type to retrieve consensus mana (e.g. via the mana plugin).
type MarkerIndexBranchIDMapping ¶
type MarkerIndexBranchIDMapping struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
MarkerIndexBranchIDMapping is a data structure that allows to map marker Indexes to a BranchID.
func NewMarkerIndexBranchIDMapping ¶
func NewMarkerIndexBranchIDMapping(sequenceID markers.SequenceID) (markerBranchMapping *MarkerIndexBranchIDMapping)
NewMarkerIndexBranchIDMapping creates a new MarkerIndexBranchIDMapping for the given SequenceID.
func (*MarkerIndexBranchIDMapping) BranchIDs ¶
func (m *MarkerIndexBranchIDMapping) BranchIDs(markerIndex markers.Index) (branchIDs ledgerstate.BranchIDs)
BranchIDs returns the BranchID that is associated to the given marker Index.
func (*MarkerIndexBranchIDMapping) Bytes ¶
func (m *MarkerIndexBranchIDMapping) Bytes() []byte
Bytes returns a marshaled version of the MarkerIndexBranchIDMapping.
func (*MarkerIndexBranchIDMapping) Ceiling ¶
func (m *MarkerIndexBranchIDMapping) Ceiling(index markers.Index) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
Ceiling returns the smallest Index that is >= the given Index which has a mapped BranchID (and a boolean value indicating if it exists).
func (*MarkerIndexBranchIDMapping) DeleteBranchID ¶
func (m *MarkerIndexBranchIDMapping) DeleteBranchID(index markers.Index)
DeleteBranchID deletes a mapping between the given marker Index and the stored BranchID.
func (*MarkerIndexBranchIDMapping) Floor ¶
func (m *MarkerIndexBranchIDMapping) Floor(index markers.Index) (marker markers.Index, branchIDs ledgerstate.BranchIDs, exists bool)
Floor returns the largest Index that is <= the given Index which has a mapped BranchID (and a boolean value indicating if it exists).
func (*MarkerIndexBranchIDMapping) FromBytes ¶
func (m *MarkerIndexBranchIDMapping) FromBytes(bytes []byte) (markerIndexBranchIDMapping objectstorage.StorableObject, err error)
FromBytes unmarshals a MarkerIndexBranchIDMapping from a sequence of bytes.
func (*MarkerIndexBranchIDMapping) FromMarshalUtil ¶
func (m *MarkerIndexBranchIDMapping) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (markerIndexBranchIDMapping *MarkerIndexBranchIDMapping, err error)
FromMarshalUtil unmarshals a MarkerIndexBranchIDMapping using a MarshalUtil (for easier unmarshalling).
func (*MarkerIndexBranchIDMapping) FromObjectStorage ¶
func (m *MarkerIndexBranchIDMapping) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an MarkerIndexBranchIDMapping from sequences of key and bytes.
func (*MarkerIndexBranchIDMapping) ObjectStorageKey ¶
func (m *MarkerIndexBranchIDMapping) ObjectStorageKey() []byte
ObjectStorageKey returns the key that is used to store the object in the database. It is required to match the StorableObject interface.
func (*MarkerIndexBranchIDMapping) ObjectStorageValue ¶
func (m *MarkerIndexBranchIDMapping) ObjectStorageValue() []byte
ObjectStorageValue marshals the Branch into a sequence of bytes that are used as the value part in the object storage.
func (*MarkerIndexBranchIDMapping) SequenceID ¶
func (m *MarkerIndexBranchIDMapping) SequenceID() markers.SequenceID
SequenceID returns the SequenceID that this MarkerIndexBranchIDMapping represents.
func (*MarkerIndexBranchIDMapping) SetBranchIDs ¶
func (m *MarkerIndexBranchIDMapping) SetBranchIDs(index markers.Index, branchIDs ledgerstate.BranchIDs)
SetBranchIDs creates a mapping between the given marker Index and the given BranchID.
func (*MarkerIndexBranchIDMapping) String ¶
func (m *MarkerIndexBranchIDMapping) String() string
String returns a human-readable version of the MarkerIndexBranchIDMapping.
type MarkerMessageMapping ¶
type MarkerMessageMapping struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
MarkerMessageMapping is a data structure that denotes a mapping from a Marker to a Message.
func NewMarkerMessageMapping ¶
func NewMarkerMessageMapping(marker *markers.Marker, messageID MessageID) *MarkerMessageMapping
NewMarkerMessageMapping is the constructor for the MarkerMessageMapping.
func (*MarkerMessageMapping) Bytes ¶
func (m *MarkerMessageMapping) Bytes() []byte
Bytes returns a marshaled version of the MarkerMessageMapping.
func (*MarkerMessageMapping) FromBytes ¶
func (m *MarkerMessageMapping) FromBytes(bytes []byte) (individuallyMappedMessage objectstorage.StorableObject, err error)
FromBytes unmarshals an MarkerMessageMapping from a sequence of bytes.
func (*MarkerMessageMapping) FromMarshalUtil ¶
func (m *MarkerMessageMapping) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (markerMessageMapping *MarkerMessageMapping, err error)
FromMarshalUtil unmarshals an MarkerMessageMapping using a MarshalUtil (for easier unmarshalling).
func (*MarkerMessageMapping) FromObjectStorage ¶
func (m *MarkerMessageMapping) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an MarkerMessageMapping from sequences of key and bytes.
func (*MarkerMessageMapping) Marker ¶
func (m *MarkerMessageMapping) Marker() *markers.Marker
Marker returns the Marker that is mapped to a MessageID.
func (*MarkerMessageMapping) MessageID ¶
func (m *MarkerMessageMapping) MessageID() MessageID
MessageID returns the MessageID of the Marker.
func (*MarkerMessageMapping) ObjectStorageKey ¶
func (m *MarkerMessageMapping) ObjectStorageKey() []byte
ObjectStorageKey returns the key that is used to store the object in the database. It is required to match the StorableObject interface.
func (*MarkerMessageMapping) ObjectStorageValue ¶
func (m *MarkerMessageMapping) ObjectStorageValue() []byte
ObjectStorageValue marshals the MarkerMessageMapping into a sequence of bytes that are used as the value part in the object storage.
func (*MarkerMessageMapping) String ¶
func (m *MarkerMessageMapping) String() string
String returns a human-readable version of the MarkerMessageMapping.
type MarkerWeightChangedEvent ¶
MarkerWeightChangedEvent holds information about a marker and its updated weight.
type Message ¶
type Message struct { // base functionality of StorableObject objectstorage.StorableObjectFlags // contains filtered or unexported fields }
Message represents the core message for the base layer Tangle.
func NewMessage ¶
func NewMessage(references ParentMessageIDs, issuingTime time.Time, issuerPublicKey ed25519.PublicKey, sequenceNumber uint64, msgPayload payload.Payload, nonce uint64, signature ed25519.Signature) (*Message, error)
NewMessage creates a new message with the details provided by the issuer.
func (*Message) ForEachParent ¶
ForEachParent executes a consumer func for each parent.
func (*Message) ForEachParentByType ¶
func (m *Message) ForEachParentByType(parentType ParentsType, consumer func(parentMessageID MessageID) bool)
ForEachParentByType executes a consumer func for each strong parent.
func (*Message) FromMarshalUtil ¶
func (m *Message) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (*Message, error)
FromMarshalUtil parses a message from the given marshal util.
func (*Message) FromObjectStorage ¶
func (m *Message) FromObjectStorage(key, data []byte) (result objectstorage.StorableObject, err error)
FromObjectStorage parses the given key and bytes into a message.
func (*Message) ID ¶
ID returns the id of the message which is made up of the content id and parent1/parent2 ids. This id can be used for merkle proofs.
func (*Message) IDBytes ¶
IDBytes implements Element interface in scheduler NodeQueue that returns the MessageID of the message in bytes.
func (*Message) IssuerPublicKey ¶
IssuerPublicKey returns the public key of the message issuer.
func (*Message) IssuingTime ¶
IssuingTime returns the time when this message was created.
func (*Message) ObjectStorageKey ¶
ObjectStorageKey returns the key of the stored message object. This returns the bytes of the message ID.
func (*Message) ObjectStorageValue ¶
ObjectStorageValue returns the value stored in object storage. This returns the bytes of message.
func (*Message) ParentsByType ¶
func (m *Message) ParentsByType(parentType ParentsType) MessageIDs
ParentsByType returns a slice of all parents of the desired type.
func (*Message) ParentsCountByType ¶
func (m *Message) ParentsCountByType(parentType ParentsType) uint8
ParentsCountByType returns the total parents count of this message.
func (*Message) SequenceNumber ¶
SequenceNumber returns the sequence number of this message.
func (*Message) VerifySignature ¶
VerifySignature verifies the signature of the message.
type MessageFactory ¶
type MessageFactory struct { Events *MessageFactoryEvents // contains filtered or unexported fields }
MessageFactory acts as a factory to create new messages.
func NewMessageFactory ¶
func NewMessageFactory(tangle *Tangle, selector TipSelector, referencesFunc ReferencesFunc) *MessageFactory
NewMessageFactory creates a new message factory.
func (*MessageFactory) IssuePayload ¶
IssuePayload creates a new message including sequence number and tip selection and returns it.
func (*MessageFactory) IssuePayloadWithReferences ¶
func (f *MessageFactory) IssuePayloadWithReferences(p payload.Payload, references ParentMessageIDs) (*Message, error)
IssuePayloadWithReferences creates a new message with the references submit.
func (*MessageFactory) SetTimeout ¶
func (f *MessageFactory) SetTimeout(timeout time.Duration)
SetTimeout sets the timeout for PoW.
func (*MessageFactory) SetWorker ¶
func (f *MessageFactory) SetWorker(worker Worker)
SetWorker sets the PoW worker to be used for the messages.
func (*MessageFactory) Shutdown ¶
func (f *MessageFactory) Shutdown()
Shutdown closes the MessageFactory and persists the sequence number.
type MessageFactoryEvents ¶
type MessageFactoryEvents struct { // Fired when a message is built including tips, sequence number and other metadata. MessageConstructed *events.Event // MessageReferenceImpossible is fired when references for a message can't be constructed and the message can never become a parent. MessageReferenceImpossible *events.Event // Fired when an error occurred. Error *events.Event }
MessageFactoryEvents represents events happening on a message factory.
type MessageFilter ¶
type MessageFilter interface { // Filter filters up on the given message and peer and calls the acceptance callback // if the input passes or the rejection callback if the input is rejected. Filter(msg *Message, peer *peer.Peer) // OnAccept registers the given callback as the acceptance function of the filter. OnAccept(callback func(msg *Message, peer *peer.Peer)) // OnReject registers the given callback as the rejection function of the filter. OnReject(callback func(msg *Message, err error, peer *peer.Peer)) // Closer closes the filter. io.Closer }
MessageFilter filters based on messages and peers.
type MessageID ¶
type MessageID [MessageIDLength]byte
MessageID identifies a message via its BLAKE2b-256 hash of its bytes.
func MessageIDFromBytes ¶
MessageIDFromBytes unmarshals a message id from a sequence of bytes.
func NewMessageID ¶
NewMessageID creates a new message id.
func ReferenceFromMarshalUtil ¶
func ReferenceFromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (MessageID, error)
ReferenceFromMarshalUtil is a wrapper for simplified unmarshaling in a byte stream using the marshalUtil package.
func (MessageID) CompareTo ¶
CompareTo does a lexicographical comparison to another messageID. Returns 0 if equal, -1 if smaller, or 1 if larger than other. Passing nil as other will result in a panic.
func (*MessageID) MarshalBinary ¶
MarshalBinary marshals the MessageID into bytes.
func (*MessageID) UnmarshalBinary ¶
UnmarshalBinary unmarshals the bytes into an MessageID.
type MessageIDs ¶
MessageIDs is a set of MessageIDs where every MessageID is stored only once.
func NewMessageIDs ¶
func NewMessageIDs(msgIDs ...MessageID) MessageIDs
NewMessageIDs construct a new MessageID collection from the optional MessageIDs.
func (MessageIDs) Add ¶
func (m MessageIDs) Add(messageID MessageID) MessageIDs
Add adds a MessageID to the collection and returns the collection to enable chaining.
func (MessageIDs) AddAll ¶
func (m MessageIDs) AddAll(messageIDs MessageIDs) MessageIDs
AddAll adds all MessageIDs to the collection and returns the collection to enable chaining.
func (MessageIDs) Base58 ¶
func (m MessageIDs) Base58() (result []string)
Base58 returns a string slice of base58 MessageID.
func (MessageIDs) Clone ¶
func (m MessageIDs) Clone() (clonedMessageIDs MessageIDs)
Clone creates a copy of the MessageIDs.
func (MessageIDs) Contains ¶
func (m MessageIDs) Contains(target MessageID) (contains bool)
Contains checks if the given target MessageID is part of the MessageIDs.
func (MessageIDs) Empty ¶
func (m MessageIDs) Empty() (empty bool)
Empty checks if MessageIDs is empty.
func (MessageIDs) First ¶
func (m MessageIDs) First() MessageID
First returns the first element in MessageIDs (not ordered). This method only makes sense if there is exactly one element in the collection.
func (MessageIDs) Slice ¶
func (m MessageIDs) Slice() []MessageID
Slice converts the set of MessageIDs into a slice of MessageIDs.
func (MessageIDs) String ¶
func (m MessageIDs) String() string
String returns a human-readable version of the MessageIDs.
func (MessageIDs) Subtract ¶
func (m MessageIDs) Subtract(other MessageIDs) MessageIDs
Subtract removes all other from the collection and returns the collection to enable chaining.
type MessageInvalidEvent ¶
MessageInvalidEvent is struct that is passed along with triggering a messageInvalidEvent.
type MessageMetadata ¶
type MessageMetadata struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
MessageMetadata defines the metadata for a message.
func NewMessageMetadata ¶
func NewMessageMetadata(messageID MessageID) *MessageMetadata
NewMessageMetadata creates a new MessageMetadata from the specified messageID.
func (*MessageMetadata) AddBranchID ¶
func (m *MessageMetadata) AddBranchID(branchID ledgerstate.BranchID) (modified bool)
AddBranchID sets the BranchIDs of the added Branches.
func (*MessageMetadata) AddedBranchIDs ¶
func (m *MessageMetadata) AddedBranchIDs() ledgerstate.BranchIDs
AddedBranchIDs returns the BranchIDs of the added Branches of the Message.
func (*MessageMetadata) BookedTime ¶
func (m *MessageMetadata) BookedTime() time.Time
BookedTime returns the time when the message represented by this metadata was booked.
func (*MessageMetadata) Bytes ¶
func (m *MessageMetadata) Bytes() []byte
Bytes returns a marshaled version of the whole MessageMetadata object.
func (*MessageMetadata) DiscardedTime ¶
func (m *MessageMetadata) DiscardedTime() time.Time
DiscardedTime returns when the message was discarded.
func (*MessageMetadata) FromBytes ¶
func (m *MessageMetadata) FromBytes(bytes []byte) (result *MessageMetadata, err error)
FromBytes unmarshals the given bytes into a MessageMetadata.
func (*MessageMetadata) FromMarshalUtil ¶
func (m *MessageMetadata) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (messageMetadata *MessageMetadata, err error)
FromMarshalUtil parses a Message from the given MarshalUtil.
func (*MessageMetadata) FromObjectStorage ¶
func (m *MessageMetadata) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an MessageMetadata from sequences of key and bytes.
func (*MessageMetadata) GradeOfFinality ¶
func (m *MessageMetadata) GradeOfFinality() (result gof.GradeOfFinality)
GradeOfFinality returns the grade of finality.
func (*MessageMetadata) GradeOfFinalityTime ¶
func (m *MessageMetadata) GradeOfFinalityTime() time.Time
GradeOfFinalityTime returns the time the grade of finality was set.
func (*MessageMetadata) ID ¶
func (m *MessageMetadata) ID() MessageID
ID returns the MessageID of the Message that this MessageMetadata object belongs to.
func (*MessageMetadata) IsBooked ¶
func (m *MessageMetadata) IsBooked() (result bool)
IsBooked returns true if the message represented by this metadata is booked. False otherwise.
func (*MessageMetadata) IsObjectivelyInvalid ¶
func (m *MessageMetadata) IsObjectivelyInvalid() (result bool)
IsObjectivelyInvalid returns true if the message represented by this metadata is objectively invalid.
func (*MessageMetadata) IsSolid ¶
func (m *MessageMetadata) IsSolid() (result bool)
IsSolid returns true if the message represented by this metadata is solid. False otherwise.
func (*MessageMetadata) IsSubjectivelyInvalid ¶
func (m *MessageMetadata) IsSubjectivelyInvalid() (result bool)
IsSubjectivelyInvalid returns true if the message represented by this metadata is subjectively invalid.
func (*MessageMetadata) ObjectStorageKey ¶
func (m *MessageMetadata) ObjectStorageKey() []byte
ObjectStorageKey returns the key of the stored message metadata object. This returns the bytes of the messageID.
func (*MessageMetadata) ObjectStorageValue ¶
func (m *MessageMetadata) ObjectStorageValue() []byte
ObjectStorageValue returns the value of the stored message metadata object. This includes the receivedTime, solidificationTime and solid status.
func (*MessageMetadata) QueuedTime ¶
func (m *MessageMetadata) QueuedTime() time.Time
QueuedTime returns the time a message entered the scheduling queue.
func (*MessageMetadata) ReceivedTime ¶
func (m *MessageMetadata) ReceivedTime() time.Time
ReceivedTime returns the time when the message was received.
func (*MessageMetadata) Scheduled ¶
func (m *MessageMetadata) Scheduled() (result bool)
Scheduled returns true if the message represented by this metadata was scheduled. False otherwise.
func (*MessageMetadata) ScheduledTime ¶
func (m *MessageMetadata) ScheduledTime() time.Time
ScheduledTime returns the time when the message represented by this metadata was scheduled.
func (*MessageMetadata) SetAddedBranchIDs ¶
func (m *MessageMetadata) SetAddedBranchIDs(addedBranchIDs ledgerstate.BranchIDs) (modified bool)
SetAddedBranchIDs sets the BranchIDs of the added Branches.
func (*MessageMetadata) SetBooked ¶
func (m *MessageMetadata) SetBooked(booked bool) (modified bool)
SetBooked sets the message associated with this metadata as booked. It returns true if the booked status is modified. False otherwise.
func (*MessageMetadata) SetDiscardedTime ¶
func (m *MessageMetadata) SetDiscardedTime(discardedTime time.Time)
SetDiscardedTime add the discarded time of a message to the metadata.
func (*MessageMetadata) SetGradeOfFinality ¶
func (m *MessageMetadata) SetGradeOfFinality(gradeOfFinality gof.GradeOfFinality) (modified bool)
SetGradeOfFinality sets the grade of finality associated with this metadata. It returns true if the grade of finality is modified. False otherwise.
func (*MessageMetadata) SetObjectivelyInvalid ¶
func (m *MessageMetadata) SetObjectivelyInvalid(invalid bool) (modified bool)
SetObjectivelyInvalid sets the message associated with this metadata as objectively invalid - it returns true if the status was changed.
func (*MessageMetadata) SetQueuedTime ¶
func (m *MessageMetadata) SetQueuedTime(queuedTime time.Time)
SetQueuedTime records the time the message entered the scheduler queue.
func (*MessageMetadata) SetScheduled ¶
func (m *MessageMetadata) SetScheduled(scheduled bool) (modified bool)
SetScheduled sets the message associated with this metadata as scheduled. It returns true if the scheduled status is modified. False otherwise.
func (*MessageMetadata) SetSolid ¶
func (m *MessageMetadata) SetSolid(solid bool) (modified bool)
SetSolid sets the message associated with this metadata as solid. It returns true if the solid status is modified. False otherwise.
func (*MessageMetadata) SetStructureDetails ¶
func (m *MessageMetadata) SetStructureDetails(structureDetails *markers.StructureDetails) (modified bool)
SetStructureDetails sets the structureDetails of the message.
func (*MessageMetadata) SetSubjectivelyInvalid ¶
func (m *MessageMetadata) SetSubjectivelyInvalid(invalid bool) (modified bool)
SetSubjectivelyInvalid sets the message associated with this metadata as subjectively invalid - it returns true if the status was changed.
func (*MessageMetadata) SetSubtractedBranchIDs ¶
func (m *MessageMetadata) SetSubtractedBranchIDs(subtractedBranchIDs ledgerstate.BranchIDs) (modified bool)
SetSubtractedBranchIDs sets the BranchIDs of the subtracted Branches.
func (*MessageMetadata) SolidificationTime ¶
func (m *MessageMetadata) SolidificationTime() time.Time
SolidificationTime returns the time when the message was marked to be solid.
func (*MessageMetadata) String ¶
func (m *MessageMetadata) String() string
String returns a human readable version of the MessageMetadata.
func (*MessageMetadata) StructureDetails ¶
func (m *MessageMetadata) StructureDetails() *markers.StructureDetails
StructureDetails returns the structureDetails of the message.
func (*MessageMetadata) SubtractedBranchIDs ¶
func (m *MessageMetadata) SubtractedBranchIDs() ledgerstate.BranchIDs
SubtractedBranchIDs returns the BranchIDs of the subtracted Branches of the Message.
type MessageOption ¶
type MessageOption func(*MessageTestFrameworkMessageOptions)
MessageOption is the type that is used for options that can be passed into the CreateMessage method to configure its behavior.
func WithColoredOutput ¶
func WithColoredOutput(alias string, balances map[ledgerstate.Color]uint64) MessageOption
WithColoredOutput returns a MessageOption that is used to define a colored Output for the Transaction in the Message.
func WithInputs ¶
func WithInputs(inputAliases ...string) MessageOption
WithInputs returns a MessageOption that is used to provide the Inputs of the Transaction.
func WithIssuer ¶
func WithIssuer(issuer ed25519.PublicKey) MessageOption
WithIssuer returns a MessageOption that is used to define the issuer of the Message.
func WithIssuingTime ¶
func WithIssuingTime(issuingTime time.Time) MessageOption
WithIssuingTime returns a MessageOption that is used to set issuing time of the Message.
func WithOutput ¶
func WithOutput(alias string, balance uint64) MessageOption
WithOutput returns a MessageOption that is used to define a non-colored Output for the Transaction in the Message.
func WithReattachment ¶
func WithReattachment(messageAlias string) MessageOption
WithReattachment returns a MessageOption that is used to select payload of which Message should be reattached.
func WithSequenceNumber ¶
func WithSequenceNumber(sequenceNumber uint64) MessageOption
WithSequenceNumber returns a MessageOption that is used to define the sequence number of the Message.
func WithShallowDislikeParents ¶
func WithShallowDislikeParents(messageAliases ...string) MessageOption
WithShallowDislikeParents returns a MessageOption that is used to define the shallow dislike parents of the Message.
func WithShallowLikeParents ¶
func WithShallowLikeParents(messageAliases ...string) MessageOption
WithShallowLikeParents returns a MessageOption that is used to define the shallow like parents of the Message.
func WithStrongParents ¶
func WithStrongParents(messageAliases ...string) MessageOption
WithStrongParents returns a MessageOption that is used to define the strong parents of the Message.
func WithWeakParents ¶
func WithWeakParents(messageAliases ...string) MessageOption
WithWeakParents returns a MessageOption that is used to define the weak parents of the Message.
type MessageParsedEvent ¶
type MessageParsedEvent struct { // Message contains the parsed Message. Message *Message // Peer contains the node that sent this Message to the node. Peer *peer.Peer }
MessageParsedEvent holds the information provided by the MessageParsed event that gets triggered when a message was fully parsed and syntactically validated.
type MessageRejectedEvent ¶
MessageRejectedEvent holds the information provided by the MessageRejected event that gets triggered when the Message was detected to be invalid.
type MessageSignatureFilter ¶
type MessageSignatureFilter struct {
// contains filtered or unexported fields
}
MessageSignatureFilter filters messages based on whether their signatures are valid.
func NewMessageSignatureFilter ¶
func NewMessageSignatureFilter() *MessageSignatureFilter
NewMessageSignatureFilter creates a new message signature filter.
func (*MessageSignatureFilter) Close ¶
func (f *MessageSignatureFilter) Close() error
Close closes the filter.
func (*MessageSignatureFilter) Filter ¶
func (f *MessageSignatureFilter) Filter(msg *Message, peer *peer.Peer)
Filter filters up on the given bytes and peer and calls the acceptance callback if the input passes or the rejection callback if the input is rejected.
type MessageTestFramework ¶
type MessageTestFramework struct {
// contains filtered or unexported fields
}
MessageTestFramework implements a framework for conveniently issuing messages in a tangle as part of unit tests in a simplified way.
func NewMessageTestFramework ¶
func NewMessageTestFramework(tangle *Tangle, options ...MessageTestFrameworkOption) (messageTestFramework *MessageTestFramework)
NewMessageTestFramework is the constructor of the MessageTestFramework.
func (*MessageTestFramework) Branch ¶
func (m *MessageTestFramework) Branch(messageAlias string) (b *ledgerstate.Branch)
Branch returns the branch emerging from the transaction contained within the given message. This function thus only works on the message creating ledgerstate.Branch. Panics if the message's payload isn't a transaction.
func (*MessageTestFramework) BranchID ¶
func (m *MessageTestFramework) BranchID(alias string) (branchID ledgerstate.BranchID)
BranchID returns the BranchID registered with the given alias.
func (*MessageTestFramework) BranchIDFromMessage ¶
func (m *MessageTestFramework) BranchIDFromMessage(messageAlias string) ledgerstate.BranchID
BranchIDFromMessage returns the BranchID of the Transaction contained in the Message associated with the given alias.
func (*MessageTestFramework) BranchIDs ¶
func (m *MessageTestFramework) BranchIDs(aliases ...string) (branchIDs ledgerstate.BranchIDs)
BranchIDs returns the BranchIDs registered with the given aliases.
func (*MessageTestFramework) CreateMessage ¶
func (m *MessageTestFramework) CreateMessage(messageAlias string, messageOptions ...MessageOption) (message *Message)
CreateMessage creates a Message with the given alias and MessageTestFrameworkMessageOptions.
func (*MessageTestFramework) IncreaseMarkersIndexCallback ¶
func (m *MessageTestFramework) IncreaseMarkersIndexCallback(markers.SequenceID, markers.Index) bool
IncreaseMarkersIndexCallback is the IncreaseMarkersIndexCallback that the MessageTestFramework uses to determine when to assign new Markers to messages.
func (*MessageTestFramework) IssueMessages ¶
func (m *MessageTestFramework) IssueMessages(messageAliases ...string) *MessageTestFramework
IssueMessages stores the given Messages in the Storage and triggers the processing by the Tangle.
func (*MessageTestFramework) Message ¶
func (m *MessageTestFramework) Message(alias string) (message *Message)
Message retrieves the Messages that is associated with the given alias.
func (*MessageTestFramework) MessageMetadata ¶
func (m *MessageTestFramework) MessageMetadata(alias string) (messageMetadata *MessageMetadata)
MessageMetadata retrieves the MessageMetadata that is associated with the given alias.
func (*MessageTestFramework) OutputMetadata ¶
func (m *MessageTestFramework) OutputMetadata(outputID ledgerstate.OutputID) (outMeta *ledgerstate.OutputMetadata)
OutputMetadata returns the given output metadata.
func (*MessageTestFramework) PreventNewMarkers ¶
func (m *MessageTestFramework) PreventNewMarkers(enabled bool) *MessageTestFramework
PreventNewMarkers disables the generation of new Markers for the given Messages.
func (*MessageTestFramework) RegisterBranchID ¶
func (m *MessageTestFramework) RegisterBranchID(alias, messageAlias string)
RegisterBranchID registers a BranchID from the given Messages' transactions with the MessageTestFramework and also an alias when printing the BranchID.
func (*MessageTestFramework) Transaction ¶
func (m *MessageTestFramework) Transaction(messageAlias string) (tx *ledgerstate.Transaction)
Transaction returns the transaction contained within the given message. Panics if the message's payload isn't a transaction.
func (*MessageTestFramework) TransactionID ¶
func (m *MessageTestFramework) TransactionID(messageAlias string) ledgerstate.TransactionID
TransactionID returns the TransactionID of the Transaction contained in the Message associated with the given alias.
func (*MessageTestFramework) TransactionMetadata ¶
func (m *MessageTestFramework) TransactionMetadata(messageAlias string) (txMeta *ledgerstate.TransactionMetadata)
TransactionMetadata returns the transaction metadata of the transaction contained within the given message. Panics if the message's payload isn't a transaction.
func (*MessageTestFramework) WaitApprovalWeightProcessed ¶
func (m *MessageTestFramework) WaitApprovalWeightProcessed() *MessageTestFramework
WaitApprovalWeightProcessed waits for all Messages to be processed by the ApprovalWeightManager.
func (*MessageTestFramework) WaitMessagesBooked ¶
func (m *MessageTestFramework) WaitMessagesBooked() *MessageTestFramework
WaitMessagesBooked waits for all Messages to be processed by the Booker.
type MessageTestFrameworkMessageOptions ¶
type MessageTestFrameworkMessageOptions struct {
// contains filtered or unexported fields
}
MessageTestFrameworkMessageOptions is a struct that represents a collection of options that can be set when creating a Message with the MessageTestFramework.
func NewMessageTestFrameworkMessageOptions ¶
func NewMessageTestFrameworkMessageOptions(options ...MessageOption) (messageOptions *MessageTestFrameworkMessageOptions)
NewMessageTestFrameworkMessageOptions is the constructor for the MessageTestFrameworkMessageOptions.
type MessageTestFrameworkOption ¶
type MessageTestFrameworkOption func(*MessageTestFrameworkOptions)
MessageTestFrameworkOption is the type that is used for options that can be passed into the MessageTestFramework to configure its behavior.
func WithColoredGenesisOutput ¶
func WithColoredGenesisOutput(alias string, balances map[ledgerstate.Color]uint64) MessageTestFrameworkOption
WithColoredGenesisOutput returns a MessageTestFrameworkOption that defines a genesis Output that is loaded as part of the initial snapshot and that supports colored coins.
func WithGenesisOutput ¶
func WithGenesisOutput(alias string, balance uint64) MessageTestFrameworkOption
WithGenesisOutput returns a MessageTestFrameworkOption that defines a genesis Output that is loaded as part of the initial snapshot.
type MessageTestFrameworkOptions ¶
type MessageTestFrameworkOptions struct {
// contains filtered or unexported fields
}
MessageTestFrameworkOptions is a container that holds the values of all configurable options of the MessageTestFramework.
func NewMessageTestFrameworkOptions ¶
func NewMessageTestFrameworkOptions(options ...MessageTestFrameworkOption) (frameworkOptions *MessageTestFrameworkOptions)
NewMessageTestFrameworkOptions is the constructor for the MessageTestFrameworkOptions.
type MissingMessage ¶
type MissingMessage struct { objectstorage.StorableObjectFlags // contains filtered or unexported fields }
MissingMessage represents a missing message.
func NewMissingMessage ¶
func NewMissingMessage(messageID MessageID) *MissingMessage
NewMissingMessage creates new missing message with the specified messageID.
func (*MissingMessage) Bytes ¶
func (m *MissingMessage) Bytes() []byte
Bytes returns a marshaled version of this MissingMessage.
func (*MissingMessage) FromBytes ¶
func (m *MissingMessage) FromBytes(bytes []byte) (result *MissingMessage, err error)
FromBytes parses the given bytes into a MissingMessage.
func (*MissingMessage) FromMarshalUtil ¶
func (m *MissingMessage) FromMarshalUtil(marshalUtil *marshalutil.MarshalUtil) (result *MissingMessage, err error)
FromMarshalUtil parses a MissingMessage from the given MarshalUtil.
func (*MissingMessage) FromObjectStorage ¶
func (m *MissingMessage) FromObjectStorage(key, bytes []byte) (objectstorage.StorableObject, error)
FromObjectStorage creates an MissingMessage from sequences of key and bytes.
func (*MissingMessage) MessageID ¶
func (m *MissingMessage) MessageID() MessageID
MessageID returns the id of the message.
func (*MissingMessage) MissingSince ¶
func (m *MissingMessage) MissingSince() time.Time
MissingSince returns the time since when this message is missing.
func (*MissingMessage) ObjectStorageKey ¶
func (m *MissingMessage) ObjectStorageKey() []byte
ObjectStorageKey returns the key of the stored missing message. This returns the bytes of the messageID of the missing message.
func (*MissingMessage) ObjectStorageValue ¶
func (m *MissingMessage) ObjectStorageValue() (result []byte)
ObjectStorageValue returns the value of the stored missing message.
type MockConfirmationOracle ¶
type MockConfirmationOracle struct{}
MockConfirmationOracle is a mock of a ConfirmationOracle.
func (*MockConfirmationOracle) Events ¶
func (m *MockConfirmationOracle) Events() *ConfirmationEvents
Events mocks its interface function.
func (*MockConfirmationOracle) FirstUnconfirmedMarkerIndex ¶
func (m *MockConfirmationOracle) FirstUnconfirmedMarkerIndex(sequenceID markers.SequenceID) (unconfirmedMarkerIndex markers.Index)
FirstUnconfirmedMarkerIndex mocks its interface function.
func (*MockConfirmationOracle) IsBranchConfirmed ¶
func (m *MockConfirmationOracle) IsBranchConfirmed(branchID ledgerstate.BranchID) bool
IsBranchConfirmed mocks its interface function.
func (*MockConfirmationOracle) IsMarkerConfirmed ¶
func (m *MockConfirmationOracle) IsMarkerConfirmed(*markers.Marker) bool
IsMarkerConfirmed mocks its interface function.
func (*MockConfirmationOracle) IsMessageConfirmed ¶
func (m *MockConfirmationOracle) IsMessageConfirmed(msgID MessageID) bool
IsMessageConfirmed mocks its interface function.
func (*MockConfirmationOracle) IsOutputConfirmed ¶
func (m *MockConfirmationOracle) IsOutputConfirmed(outputID ledgerstate.OutputID) bool
IsOutputConfirmed mocks its interface function.
func (*MockConfirmationOracle) IsTransactionConfirmed ¶
func (m *MockConfirmationOracle) IsTransactionConfirmed(transactionID ledgerstate.TransactionID) bool
IsTransactionConfirmed mocks its interface function.
type MockWeightProvider ¶
type MockWeightProvider struct{}
MockWeightProvider is a mock of a WeightProvider.
func (*MockWeightProvider) Shutdown ¶
func (m *MockWeightProvider) Shutdown()
Shutdown mocks its interface function.
func (*MockWeightProvider) Update ¶
func (m *MockWeightProvider) Update(t time.Time, nodeID identity.ID)
Update mocks its interface function.
func (*MockWeightProvider) Weight ¶
func (m *MockWeightProvider) Weight(message *Message) (weight, totalWeight float64)
Weight mocks its interface function.
func (*MockWeightProvider) WeightsOfRelevantVoters ¶
func (m *MockWeightProvider) WeightsOfRelevantVoters() (weights map[identity.ID]float64, totalWeight float64)
WeightsOfRelevantVoters mocks its interface function.
type NodeIdentities ¶
NodeIdentities defines a set of node identities mapped through an alias.
type OTVConsensusManager ¶
OTVConsensusManager is the component in charge of forming opinions about branches.
func NewOTVConsensusManager ¶
func NewOTVConsensusManager(otvConsensusMechanism consensus.Mechanism) *OTVConsensusManager
NewOTVConsensusManager returns a new Mechanism.
type Opinion ¶
type Opinion uint8
Opinion is a type that represents the Opinion of a node on a certain Branch.
type Option ¶
type Option func(*Options)
Option represents the return type of optional parameters that can be handed into the constructor of the Tangle to configure its behavior.
func ApprovalWeights ¶
func ApprovalWeights(weightProvider WeightProvider) Option
ApprovalWeights is an Option for the Tangle that allows to define how the approval weights of Messages is determined.
func CacheTimeProvider ¶
func CacheTimeProvider(cacheTimeProvider *database.CacheTimeProvider) Option
CacheTimeProvider is an Option for the Tangle that allows to override hard coded cache time.
func GenesisNode ¶
GenesisNode is an Option for the Tangle that allows to set the GenesisNode, i.e., the node that is allowed to attach to the Genesis Message.
func Identity ¶
func Identity(identity *identity.LocalIdentity) Option
Identity is an Option for the Tangle that allows to specify the node identity which is used to issue Messages.
func IncreaseMarkersIndexCallback ¶
func IncreaseMarkersIndexCallback(callback markers.IncreaseIndexCallback) Option
IncreaseMarkersIndexCallback is an Option for the Tangle that allows to change the strategy how new Markers are assigned in the Tangle.
func MergeBranches ¶
MergeBranches is an Option for the Tangle that prevents the LedgerState from merging Branches.
func RateSetterConfig ¶
func RateSetterConfig(params RateSetterParams) Option
RateSetterConfig is an Option for the Tangle that allows to set the rate setter.
func SchedulerConfig ¶
func SchedulerConfig(config SchedulerParams) Option
SchedulerConfig is an Option for the Tangle that allows to set the scheduler.
func StartSynced ¶
StartSynced is an Option for the Tangle that allows to define if the node starts as synced.
func Store ¶
Store is an Option for the Tangle that allows to specify which storage layer is supposed to be used to persist data.
func SyncTimeWindow ¶
SyncTimeWindow is an Option for the Tangle that allows to define the time window in which the node will consider itself in sync.
func TimeSinceConfirmationThreshold ¶
TimeSinceConfirmationThreshold is an Option for the Tangle that allows to set threshold for Time Since Confirmation check.
type Options ¶
type Options struct { Store kvstore.KVStore Identity *identity.LocalIdentity IncreaseMarkersIndexCallback markers.IncreaseIndexCallback TangleWidth int GenesisNode *ed25519.PublicKey SchedulerParams SchedulerParams RateSetterParams RateSetterParams WeightProvider WeightProvider SyncTimeWindow time.Duration TimeSinceConfirmationThreshold time.Duration StartSynced bool CacheTimeProvider *database.CacheTimeProvider LedgerState struct{ MergeBranches bool } }
Options is a container for all configurable parameters of the Tangle.
type Parent ¶
type Parent struct { ID MessageID Type ParentsType }
Parent is a parent that can be either strong or weak.
type ParentMessageIDs ¶
type ParentMessageIDs map[ParentsType]MessageIDs
ParentMessageIDs is a map of ParentType to MessageIDs.
func NewParentMessageIDs ¶
func NewParentMessageIDs() ParentMessageIDs
NewParentMessageIDs constructs a new ParentMessageIDs.
func (ParentMessageIDs) Add ¶
func (p ParentMessageIDs) Add(parentType ParentsType, messageID MessageID) ParentMessageIDs
Add adds a parent to the map.
func (ParentMessageIDs) AddAll ¶
func (p ParentMessageIDs) AddAll(parentType ParentsType, messageIDs MessageIDs) ParentMessageIDs
AddAll adds a collection of parents to the map.
func (ParentMessageIDs) AddStrong ¶
func (p ParentMessageIDs) AddStrong(messageID MessageID) ParentMessageIDs
AddStrong adds a strong parent to the map.
func (ParentMessageIDs) Clone ¶
func (p ParentMessageIDs) Clone() ParentMessageIDs
Clone returns a copy of map.
type ParentsBlock ¶
type ParentsBlock struct { ParentsType References []MessageID }
ParentsBlock is the container for parents in a Message.
type ParentsType ¶
type ParentsType uint8
ParentsType is a type that defines the type of the parent.
const ( // UndefinedParentType is the undefined parent. UndefinedParentType ParentsType = iota // StrongParentType is the ParentsType for a strong parent. StrongParentType // WeakParentType is the ParentsType for a weak parent. WeakParentType // ShallowLikeParentType is the ParentsType for the shallow like parent. ShallowLikeParentType // ShallowDislikeParentType is the ParentsType for a shallow dislike parent. ShallowDislikeParentType )
func (ParentsType) String ¶
func (bp ParentsType) String() string
String returns string representation of ParentsType.
type Parser ¶
type Parser struct { Events *ParserEvents // contains filtered or unexported fields }
Parser parses messages and bytes and emits corresponding events for parsed and rejected messages.
func (*Parser) AddBytesFilter ¶
func (p *Parser) AddBytesFilter(filter BytesFilter)
AddBytesFilter adds the given bytes filter to the parser.
func (*Parser) AddMessageFilter ¶
func (p *Parser) AddMessageFilter(filter MessageFilter)
AddMessageFilter adds a new message filter to the parser.
type ParserEvents ¶
type ParserEvents struct { // Fired when a message was parsed. MessageParsed *events.Event // Fired when submitted bytes are rejected by a filter. BytesRejected *events.Event // Fired when a message got rejected by a filter. MessageRejected *events.Event }
ParserEvents represents events happening in the Parser.
type PowFilter ¶
type PowFilter struct {
// contains filtered or unexported fields
}
PowFilter is a message bytes filter validating the PoW nonce.
func NewPowFilter ¶
NewPowFilter creates a new PoW bytes filter.
func (*PowFilter) Filter ¶
Filter checks whether the given bytes pass the PoW validation and calls the corresponding callback.
type PrePostStepTuple ¶
PrePostStepTuple is a tuple of TestStep(s) called before and after the actual test step is called.
type RateSetter ¶
type RateSetter struct { Events *RateSetterEvents // contains filtered or unexported fields }
RateSetter is a Tangle component that takes care of congestion control of local node.
func NewRateSetter ¶
func NewRateSetter(tangle *Tangle) *RateSetter
NewRateSetter returns a new RateSetter.
func (*RateSetter) Issue ¶
func (r *RateSetter) Issue(message *Message) error
Issue submits a message to the local issuing queue.
func (*RateSetter) Rate ¶
func (r *RateSetter) Rate() float64
Rate returns the rate of the rate setter.
func (*RateSetter) Setup ¶
func (r *RateSetter) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of the other components.
func (*RateSetter) Size ¶
func (r *RateSetter) Size() int
Size returns the size of the issuing queue.
type RateSetterEvents ¶
RateSetterEvents represents events happening in the rate setter.
type RateSetterParams ¶
type RateSetterParams struct {
Initial *float64
}
RateSetterParams represents the parameters for RateSetter.
type RecentlySeenBytesFilter ¶
type RecentlySeenBytesFilter struct {
// contains filtered or unexported fields
}
RecentlySeenBytesFilter filters so that bytes which were recently seen don't pass the filter.
func NewRecentlySeenBytesFilter ¶
func NewRecentlySeenBytesFilter() *RecentlySeenBytesFilter
NewRecentlySeenBytesFilter creates a new recently seen bytes filter.
func (*RecentlySeenBytesFilter) Filter ¶
func (r *RecentlySeenBytesFilter) Filter(bytes []byte, peer *peer.Peer)
Filter filters up on the given bytes and peer and calls the acceptance callback if the input passes or the rejection callback if the input is rejected.
type ReferencesFunc ¶
type ReferencesFunc func(strongParents MessageIDs, issuingTime time.Time, tangle *Tangle) (references ParentMessageIDs, referenceNotPossible MessageIDs, err error)
ReferencesFunc is a function type that returns like references a given set of parents of a Message.
type Requester ¶
type Requester struct { Events RequesterEvents // contains filtered or unexported fields }
Requester takes care of requesting messages.
func NewRequester ¶
func NewRequester(tangle *Tangle, optionalOptions ...RequesterOption) *Requester
NewRequester creates a new message requester.
func (*Requester) RequestQueueSize ¶
RequestQueueSize returns the number of scheduled message requests.
func (*Requester) Setup ¶
func (r *Requester) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
func (*Requester) StartRequest ¶
StartRequest initiates a regular triggering of the StartRequest event until it has been stopped using StopRequest.
func (*Requester) StopRequest ¶
StopRequest stops requests for the given message to further happen.
type RequesterEvents ¶
type RequesterEvents struct { // RequestIssued is an event that is triggered when the requester wants to request the given Message from its // neighbors. RequestIssued *events.Event // RequestStarted is an event that is triggered when a new request is started. RequestStarted *events.Event // RequestStopped is an event that is triggered when a request is stopped. RequestStopped *events.Event // RequestFailed is an event that is triggered when a request is stopped after too many attempts. RequestFailed *events.Event }
RequesterEvents represents events happening on a message requester.
type RequesterOption ¶
type RequesterOption func(*RequesterOptions)
RequesterOption is a function which inits an option.
func MaxRequestThreshold ¶
func MaxRequestThreshold(maxRequestThreshold int) RequesterOption
MaxRequestThreshold creates an option which defines how often the Requester should try to request messages before canceling the request.
func RetryInterval ¶
func RetryInterval(interval time.Duration) RequesterOption
RetryInterval creates an option which sets the retry interval to the given value.
func RetryJitter ¶
func RetryJitter(retryJitter time.Duration) RequesterOption
RetryJitter creates an option which sets the retry jitter to the given value.
type RequesterOptions ¶
type RequesterOptions struct { // RetryInterval represents an option which defines in which intervals the Requester will try to ask for missing // messages. RetryInterval time.Duration // RetryJitter defines how much the RetryInterval should be randomized, so that the nodes don't always send messages // at exactly the same interval. RetryJitter time.Duration // MaxRequestThreshold represents an option which defines how often the Requester should try to request messages // before canceling the request MaxRequestThreshold int }
RequesterOptions holds options for a message requester.
func (RequesterOptions) Apply ¶
func (r RequesterOptions) Apply(optionalOptions ...RequesterOption) (updatedOptions RequesterOptions)
Apply applies the optional Options to the RequesterOptions.
type Scheduler ¶
type Scheduler struct { Events *SchedulerEvents // contains filtered or unexported fields }
Scheduler is a Tangle component that takes care of scheduling the messages that shall be booked.
func NewScheduler ¶
NewScheduler returns a new Scheduler.
func (*Scheduler) AccessManaCache ¶
func (s *Scheduler) AccessManaCache() *schedulerutils.AccessManaCache
AccessManaCache returns the object which caches access mana values.
func (*Scheduler) BufferSize ¶
BufferSize returns the size of the buffer.
func (*Scheduler) Clear ¶
func (s *Scheduler) Clear()
Clear removes all submitted messages (ready or not) from the scheduler. The MessageDiscarded event is triggered for each of these messages.
func (*Scheduler) GetManaFromCache ¶
GetManaFromCache allows you to get the cached mana for a node ID. This is exposed for analytics purposes.
func (*Scheduler) MaxBufferSize ¶
MaxBufferSize returns the max size of the buffer.
func (*Scheduler) NodeQueueSize ¶
NodeQueueSize returns the size of the nodeIDs queue.
func (*Scheduler) NodeQueueSizes ¶
NodeQueueSizes returns the size for each node queue.
func (*Scheduler) Ready ¶
Ready marks a previously submitted message as ready to be scheduled. If Ready is called without a previous Submit, it has no effect.
func (*Scheduler) ReadyMessagesCount ¶
ReadyMessagesCount returns the size buffer.
func (*Scheduler) Setup ¶
func (s *Scheduler) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of the other components.
func (*Scheduler) Shutdown ¶
func (s *Scheduler) Shutdown()
Shutdown shuts down the Scheduler. Shutdown blocks until the scheduler has been shutdown successfully.
func (*Scheduler) Submit ¶
Submit submits a message to be considered by the scheduler. This transactions will be included in all the control metrics, but it will never be scheduled until Ready(messageID) has been called.
func (*Scheduler) SubmitAndReady ¶
SubmitAndReady submits the message to the scheduler and marks it ready right away.
func (*Scheduler) TotalMessagesCount ¶
TotalMessagesCount returns the size buffer.
type SchedulerEvents ¶
type SchedulerEvents struct { // MessageScheduled is triggered when a message is ready to be scheduled. MessageScheduled *events.Event // MessageDiscarded is triggered when a message is removed from the longest mana-scaled queue when the buffer is full. MessageDiscarded *events.Event // MessageSkipped is triggered when a message is confirmed before it's scheduled, and is skipped by the scheduler. MessageSkipped *events.Event NodeBlacklisted *events.Event Error *events.Event }
SchedulerEvents represents events happening in the Scheduler.
type SchedulerParams ¶
type SchedulerParams struct { MaxBufferSize int Rate time.Duration AccessManaRetrieveFunc func(identity.ID) float64 TotalAccessManaRetrieveFunc func() float64 AccessManaMapRetrieverFunc func() map[identity.ID]float64 ConfirmedMessageScheduleThreshold time.Duration }
SchedulerParams defines the scheduler config parameters.
type SendRequestEvent ¶
type SendRequestEvent struct {
ID MessageID
}
SendRequestEvent represents the parameters of sendRequestEventHandler
type SimpleMockOnTangleVoting ¶
type SimpleMockOnTangleVoting struct {
// contains filtered or unexported fields
}
SimpleMockOnTangleVoting is mock of OTV mechanism.
func (*SimpleMockOnTangleVoting) BranchLiked ¶
func (o *SimpleMockOnTangleVoting) BranchLiked(branchID ledgerstate.BranchID) (branchLiked bool)
BranchLiked returns whether the branch is the winner across all conflict sets (it is in the liked reality).
func (*SimpleMockOnTangleVoting) LikedConflictMember ¶
func (o *SimpleMockOnTangleVoting) LikedConflictMember(branchID ledgerstate.BranchID) (likedBranchID ledgerstate.BranchID, conflictMembers ledgerstate.BranchIDs)
LikedConflictMember returns branches that are liked instead of a disliked branch as predefined.
type Solidifier ¶
type Solidifier struct { // Events contains the Solidifier related events. Events *SolidifierEvents // contains filtered or unexported fields }
Solidifier is the Tangle's component that solidifies messages.
func NewSolidifier ¶
func NewSolidifier(tangle *Tangle) (solidifier *Solidifier)
NewSolidifier is the constructor of the Solidifier.
func (*Solidifier) RetrieveMissingMessage ¶
func (s *Solidifier) RetrieveMissingMessage(messageID MessageID) (messageWasMissing bool)
RetrieveMissingMessage checks if the message is missing and triggers the corresponding events to request it. It returns true if the message has been missing.
func (*Solidifier) Setup ¶
func (s *Solidifier) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of the other components.
func (*Solidifier) Solidify ¶
func (s *Solidifier) Solidify(messageID MessageID)
Solidify solidifies the given Message.
type SolidifierEvents ¶
type SolidifierEvents struct { // MessageSolid is triggered when a message becomes solid, i.e. its past cone is known and solid. MessageSolid *events.Event // MessageMissing is triggered when a message references an unknown parent Message. MessageMissing *events.Event }
SolidifierEvents represents events happening in the Solidifier.
type Storage ¶
type Storage struct { Events *StorageEvents // contains filtered or unexported fields }
Storage represents the storage of messages.
func NewStorage ¶
NewStorage creates a new Storage.
func (*Storage) AllLatestMarkerVotes ¶
func (s *Storage) AllLatestMarkerVotes(sequenceID markers.SequenceID) (cachedLatestMarkerVotesByVoter CachedLatestMarkerVotesByVoter)
AllLatestMarkerVotes retrieves all LatestMarkerVotes for the named Sequence.
func (*Storage) Approvers ¶
func (s *Storage) Approvers(messageID MessageID, optionalApproverType ...ApproverType) (cachedApprovers objectstorage.CachedObjects[*Approver])
Approvers retrieves the Approvers of a Message from the object storage. It is possible to provide an optional ApproverType to only return the corresponding Approvers.
func (*Storage) AttachmentMessageIDs ¶
func (s *Storage) AttachmentMessageIDs(transactionID ledgerstate.TransactionID) (messageIDs MessageIDs)
AttachmentMessageIDs returns the messageIDs of the transaction in attachmentStorage.
func (*Storage) Attachments ¶
func (s *Storage) Attachments(transactionID ledgerstate.TransactionID) (cachedAttachments objectstorage.CachedObjects[*Attachment])
Attachments retrieves the attachment of a transaction in attachmentStorage.
func (*Storage) BranchVoters ¶
func (s *Storage) BranchVoters(branchID ledgerstate.BranchID, computeIfAbsentCallback ...func(branchID ledgerstate.BranchID) *BranchVoters) *objectstorage.CachedObject[*BranchVoters]
BranchVoters retrieves the BranchVoters with the given ledgerstate.BranchID.
func (*Storage) BranchWeight ¶
func (s *Storage) BranchWeight(branchID ledgerstate.BranchID, computeIfAbsentCallback ...func(branchID ledgerstate.BranchID) *BranchWeight) *objectstorage.CachedObject[*BranchWeight]
BranchWeight retrieves the BranchWeight with the given BranchID.
func (*Storage) DBStats ¶
func (s *Storage) DBStats() (res DBStatsResult)
DBStats returns the number of solid messages and total number of messages in the database (messageMetadataStorage, that should contain the messages as messageStorage), the number of messages in missingMessageStorage, furthermore the average time it takes to solidify messages.
func (*Storage) DeleteMarkerMessageMapping ¶
func (s *Storage) DeleteMarkerMessageMapping(branchID ledgerstate.BranchID, messageID MessageID)
DeleteMarkerMessageMapping deleted a MarkerMessageMapping in the underlying object storage.
func (*Storage) DeleteMessage ¶
DeleteMessage deletes a message and its association to approvees by un-marking the given message as an approver.
func (*Storage) DeleteMissingMessage ¶
DeleteMissingMessage deletes a message from the missingMessageStorage.
func (*Storage) IsTransactionAttachedByMessage ¶
func (s *Storage) IsTransactionAttachedByMessage(transactionID ledgerstate.TransactionID, messageID MessageID) (attached bool)
IsTransactionAttachedByMessage checks whether Transaction with transactionID is attached by Message with messageID.
func (*Storage) LatestBranchVotes ¶
func (s *Storage) LatestBranchVotes(voter Voter, computeIfAbsentCallback ...func(voter Voter) *LatestBranchVotes) *objectstorage.CachedObject[*LatestBranchVotes]
LatestBranchVotes retrieves the LatestBranchVotes of the given Voter.
func (*Storage) LatestMarkerVotes ¶
func (s *Storage) LatestMarkerVotes(sequenceID markers.SequenceID, voter Voter, computeIfAbsentCallback ...func(sequenceID markers.SequenceID, voter Voter) *LatestMarkerVotes) *objectstorage.CachedObject[*LatestMarkerVotes]
LatestMarkerVotes retrieves the LatestMarkerVotes of the given voter for the named Sequence.
func (*Storage) MarkerIndexBranchIDMapping ¶
func (s *Storage) MarkerIndexBranchIDMapping(sequenceID markers.SequenceID, computeIfAbsentCallback ...func(sequenceID markers.SequenceID) *MarkerIndexBranchIDMapping) *objectstorage.CachedObject[*MarkerIndexBranchIDMapping]
MarkerIndexBranchIDMapping retrieves the MarkerIndexBranchIDMapping for the given SequenceID. It accepts an optional computeIfAbsent callback that can be used to dynamically create a MarkerIndexBranchIDMapping if it doesn't exist, yet.
func (*Storage) MarkerMessageMapping ¶
func (s *Storage) MarkerMessageMapping(marker *markers.Marker) (cachedMarkerMessageMappings *objectstorage.CachedObject[*MarkerMessageMapping])
MarkerMessageMapping retrieves the MarkerMessageMapping associated with the given details.
func (*Storage) MarkerMessageMappings ¶
func (s *Storage) MarkerMessageMappings(sequenceID markers.SequenceID) (cachedMarkerMessageMappings objectstorage.CachedObjects[*MarkerMessageMapping])
MarkerMessageMappings retrieves the MarkerMessageMappings of a Sequence in the object storage.
func (*Storage) Message ¶
func (s *Storage) Message(messageID MessageID) *objectstorage.CachedObject[*Message]
Message retrieves a message from the message store.
func (*Storage) MessageMetadata ¶
func (s *Storage) MessageMetadata(messageID MessageID, computeIfAbsentCallback ...func() *MessageMetadata) *objectstorage.CachedObject[*MessageMetadata]
MessageMetadata retrieves the MessageMetadata with the given MessageID.
func (*Storage) MissingMessages ¶
MissingMessages return the ids of messages in missingMessageStorage
func (*Storage) Prune ¶
Prune resets the database and deletes all objects (good for testing or "node resets").
func (*Storage) RetrieveAllTips ¶
RetrieveAllTips returns the tips (i.e., solid messages that are not part of the approvers list). It iterates over the messageMetadataStorage, thus only use this method if necessary. TODO: improve this function.
func (*Storage) Setup ¶
func (s *Storage) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
func (*Storage) Shutdown ¶
func (s *Storage) Shutdown()
Shutdown marks the tangle as stopped, so it will not accept any new messages (waits for all backgroundTasks to finish).
func (*Storage) StoreAttachment ¶
func (s *Storage) StoreAttachment(transactionID ledgerstate.TransactionID, messageID MessageID) (cachedAttachment *objectstorage.CachedObject[*Attachment], stored bool)
StoreAttachment stores a new attachment if not already stored.
func (*Storage) StoreMarkerMessageMapping ¶
func (s *Storage) StoreMarkerMessageMapping(markerMessageMapping *MarkerMessageMapping)
StoreMarkerMessageMapping stores a MarkerMessageMapping in the underlying object storage.
func (*Storage) StoreMessage ¶
StoreMessage stores a new message to the message store.
func (*Storage) StoreMissingMessage ¶
func (s *Storage) StoreMissingMessage(missingMessage *MissingMessage) (cachedMissingMessage *objectstorage.CachedObject[*MissingMessage], stored bool)
StoreMissingMessage stores a new MissingMessage entry in the object storage.
type StorageEvents ¶
type StorageEvents struct { // Fired when a message has been stored. MessageStored *events.Event // Fired when a message was removed from storage. MessageRemoved *events.Event // Fired when a message which was previously marked as missing was received. MissingMessageStored *events.Event }
StorageEvents represents events happening on the message store.
type SyncChangedEvent ¶
type SyncChangedEvent struct {
Synced bool
}
SyncChangedEvent represents a sync changed event.
type Tangle ¶
type Tangle struct { Options *Options Parser *Parser Storage *Storage Solidifier *Solidifier Scheduler *Scheduler Dispatcher *Dispatcher Booker *Booker ApprovalWeightManager *ApprovalWeightManager TimeManager *TimeManager OTVConsensusManager *OTVConsensusManager TipManager *TipManager Requester *Requester MessageFactory *MessageFactory LedgerState *LedgerState Utils *Utils WeightProvider WeightProvider Events *Events ConfirmationOracle ConfirmationOracle // contains filtered or unexported fields }
Tangle is the central data structure of the IOTA protocol.
func NewTestTangle ¶
NewTestTangle returns a Tangle instance with a testing schedulerConfig.
func (*Tangle) IssuePayload ¶
IssuePayload allows to attach a payload (i.e. a Transaction) to the Tangle.
func (*Tangle) ProcessGossipMessage ¶
ProcessGossipMessage is used to feed new Messages from the gossip layer into the Tangle.
func (*Tangle) Prune ¶
Prune resets the database and deletes all stored objects (good for testing or "node resets").
func (*Tangle) Setup ¶
func (t *Tangle) Setup()
Setup sets up the data flow by connecting the different components (by calling their corresponding Setup method).
type TestScenario ¶
type TestScenario struct { Steps []TestStep PostStep TestStep Tangle *Tangle // contains filtered or unexported fields }
TestScenario is a sequence of steps applied onto test scenario.
func ProcessMessageScenario ¶
func ProcessMessageScenario(t *testing.T) *TestScenario
ProcessMessageScenario the approval weight and voter adjustments.
func ProcessMessageScenario2 ¶
func ProcessMessageScenario2(t *testing.T) *TestScenario
ProcessMessageScenario2 creates a scenario useful to validate strong / weak propagation paths.
func (*TestScenario) Cleanup ¶
func (s *TestScenario) Cleanup(t *testing.T) error
Cleanup cleans up the scenario.
func (*TestScenario) HasNext ¶
func (s *TestScenario) HasNext() bool
HasNext returns whether the scenario has a next step.
func (*TestScenario) Next ¶
func (s *TestScenario) Next(prePostStepTuple *PrePostStepTuple)
Next returns the next step or panics if non is available.
type TestStep ¶
type TestStep func(t *testing.T, testFramework *MessageTestFramework, testEventMock *EventMock, nodes NodeIdentities)
TestStep defines a test scenario step.
type TimeManager ¶
type TimeManager struct { Events *TimeManagerEvents // contains filtered or unexported fields }
TimeManager is a Tangle component that keeps track of the TangleTime. The TangleTime can be seen as a clock for the entire network as it tracks the time of the last confirmed message. Comparing the issuing time of the last confirmed message to the node's current wall clock time then yields a reasonable assessment of how much in sync the node is.
func NewTimeManager ¶
func NewTimeManager(tangle *Tangle) *TimeManager
NewTimeManager is the constructor for TimeManager.
func (*TimeManager) LastConfirmedMessage ¶
func (t *TimeManager) LastConfirmedMessage() LastConfirmedMessage
LastConfirmedMessage returns the last confirmed message.
func (*TimeManager) Setup ¶
func (t *TimeManager) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
func (*TimeManager) Shutdown ¶
func (t *TimeManager) Shutdown()
Shutdown shuts down the TimeManager and persists its state.
func (*TimeManager) Synced ¶
func (t *TimeManager) Synced() bool
Synced returns whether the node is in sync based on the difference between TangleTime and current wall time which can be configured via SyncTimeWindow.
func (*TimeManager) Time ¶
func (t *TimeManager) Time() time.Time
Time returns the TangleTime, i.e., the issuing time of the last confirmed message.
type TimeManagerEvents ¶
type TimeManagerEvents struct { // Fired when the nodes sync status changes. SyncChanged *events.Event }
TimeManagerEvents represents events happening in the TimeManager.
type TimeRetrieverFunc ¶
TimeRetrieverFunc is a function type to retrieve the time.
type TimedTaskExecutor ¶
type TimedTaskExecutor struct { *timedexecutor.TimedExecutor // contains filtered or unexported fields }
TimedTaskExecutor is a TimedExecutor that internally manages the scheduled callbacks as tasks with a unique identifier. It allows to replace existing scheduled tasks and cancel them using the same identifier.
func NewTimedTaskExecutor ¶
func NewTimedTaskExecutor(workerCount int) *TimedTaskExecutor
NewTimedTaskExecutor is the constructor of the TimedTaskExecutor.
func (*TimedTaskExecutor) Cancel ¶
func (t *TimedTaskExecutor) Cancel(identifier interface{}) (canceled bool)
Cancel cancels a queued task.
func (*TimedTaskExecutor) ExecuteAfter ¶
func (t *TimedTaskExecutor) ExecuteAfter(identifier interface{}, callback func(), delay time.Duration) *timedexecutor.ScheduledTask
ExecuteAfter executes the given function after the given delay.
func (*TimedTaskExecutor) ExecuteAt ¶
func (t *TimedTaskExecutor) ExecuteAt(identifier interface{}, callback func(), executionTime time.Time) *timedexecutor.ScheduledTask
ExecuteAt executes the given function at the given time.
type TipEvent ¶
type TipEvent struct { // MessageID of the added/removed tip. MessageID MessageID }
TipEvent holds the information provided by the TipEvent event that gets triggered when a message gets added or removed as tip.
type TipManager ¶
type TipManager struct { Events *TipManagerEvents // contains filtered or unexported fields }
TipManager manages a map of tips and emits events for their removal and addition.
func NewTipManager ¶
func NewTipManager(tangle *Tangle, tips ...MessageID) *TipManager
NewTipManager creates a new tip-selector.
func (*TipManager) AddTip ¶
func (t *TipManager) AddTip(message *Message)
AddTip adds the message to the tip pool if its issuing time is within the tipLifeGracePeriod. Parents of a message that are currently tip lose the tip status and are removed.
func (*TipManager) AllTips ¶
func (t *TipManager) AllTips() MessageIDs
AllTips returns a list of all tips that are stored in the TipManger.
func (*TipManager) Setup ¶
func (t *TipManager) Setup()
Setup sets up the behavior of the component by making it attach to the relevant events of other components.
func (*TipManager) TipCount ¶
func (t *TipManager) TipCount() int
TipCount the amount of strong tips.
func (*TipManager) Tips ¶
func (t *TipManager) Tips(p payload.Payload, countParents int) (parents MessageIDs, err error)
Tips returns count number of tips, maximum MaxParentsCount.
type TipManagerEvents ¶
type TipManagerEvents struct { // Fired when a tip is added. TipAdded *events.Event // Fired when a tip is removed. TipRemoved *events.Event }
TipManagerEvents represents events happening on the TipManager.
type TipSelector ¶
type TipSelector interface {
Tips(p payload.Payload, countParents int) (parents MessageIDs, err error)
}
A TipSelector selects two tips, parent2 and parent1, for a new message to attach to.
type TipSelectorFunc ¶
type TipSelectorFunc func(p payload.Payload, countParents int) (parents MessageIDs, err error)
The TipSelectorFunc type is an adapter to allow the use of ordinary functions as tip selectors.
func (TipSelectorFunc) Tips ¶
func (f TipSelectorFunc) Tips(p payload.Payload, countParents int) (parents MessageIDs, err error)
Tips calls f().
type TransactionFilter ¶
type TransactionFilter struct {
// contains filtered or unexported fields
}
TransactionFilter filters messages based on their timestamps and transaction timestamp.
func NewTransactionFilter ¶
func NewTransactionFilter() *TransactionFilter
NewTransactionFilter creates a new transaction filter.
func (*TransactionFilter) Close ¶
func (f *TransactionFilter) Close() error
Close closes the filter.
func (*TransactionFilter) Filter ¶
func (f *TransactionFilter) Filter(msg *Message, peer *peer.Peer)
Filter compares the timestamps between the message, and it's transaction payload and calls the corresponding callback.
type Utils ¶
type Utils struct {
// contains filtered or unexported fields
}
Utils is a Tangle component that bundles methods that can be used to interact with the Tangle, that do not belong into public API.
func (*Utils) AllBranchesLiked ¶
func (u *Utils) AllBranchesLiked(branchIDs ledgerstate.BranchIDs) bool
AllBranchesLiked returs true if all the passed branches are liked.
func (*Utils) AllTransactionsApprovedByMessages ¶
func (u *Utils) AllTransactionsApprovedByMessages(transactionIDs ledgerstate.TransactionIDs, messageIDs MessageIDs) (approved bool)
AllTransactionsApprovedByMessages checks if all Transactions were attached by at least one Message that was directly or indirectly approved by the given Message.
func (*Utils) ApprovingMessageIDs ¶
func (u *Utils) ApprovingMessageIDs(messageID MessageID, optionalApproverType ...ApproverType) (approvingMessageIDs MessageIDs)
ApprovingMessageIDs returns the MessageIDs that approve a given Message. It accepts an optional ApproverType to filter the Approvers.
func (*Utils) ComputeIfTransaction ¶
func (u *Utils) ComputeIfTransaction(messageID MessageID, compute func(ledgerstate.TransactionID)) (computed bool)
ComputeIfTransaction computes the given callback if the given messageID contains a transaction.
func (*Utils) FirstAttachment ¶
func (u *Utils) FirstAttachment(transactionID ledgerstate.TransactionID) (oldestAttachmentTime time.Time, oldestAttachmentMessageID MessageID, err error)
FirstAttachment returns the MessageID and timestamp of the first (oldest) attachment of a given transaction.
func (*Utils) MessageApprovedBy ¶
func (u *Utils) MessageApprovedBy(approvedMessageID MessageID, approvingMessageID MessageID) (approved bool)
MessageApprovedBy checks if the Message given by approvedMessageID is directly or indirectly approved by the Message given by approvingMessageID.
func (*Utils) TransactionApprovedByMessage ¶
func (u *Utils) TransactionApprovedByMessage(transactionID ledgerstate.TransactionID, messageID MessageID) (approved bool)
TransactionApprovedByMessage checks if the Transaction was attached by at least one Message that was directly or indirectly approved by the given Message.
func (*Utils) WalkMessage ¶
func (u *Utils) WalkMessage(callback func(message *Message, walker *walker.Walker[MessageID]), entryPoints MessageIDs, revisitElements ...bool)
WalkMessage is a generic Tangle walker that executes a custom callback for every visited Message, starting from the given entry points. It accepts an optional boolean parameter which can be set to true if a Message should be visited more than once following different paths. The callback receives a Walker object as the last parameter which can be used to control the behavior of the walk similar to how a "Context" is used in some parts of the stdlib.
func (*Utils) WalkMessageAndMetadata ¶
func (u *Utils) WalkMessageAndMetadata(callback func(message *Message, messageMetadata *MessageMetadata, walker *walker.Walker[MessageID]), entryPoints MessageIDs, revisitElements ...bool)
WalkMessageAndMetadata is a generic Tangle walker that executes a custom callback for every visited Message and MessageMetadata, starting from the given entry points. It accepts an optional boolean parameter which can be set to true if a Message should be visited more than once following different paths. The callback receives a Walker object as the last parameter which can be used to control the behavior of the walk similar to how a "Context" is used in some parts of the stdlib.
func (*Utils) WalkMessageID ¶
func (u *Utils) WalkMessageID(callback func(messageID MessageID, walker *walker.Walker[MessageID]), entryPoints MessageIDs, revisitElements ...bool)
WalkMessageID is a generic Tangle walker that executes a custom callback for every visited MessageID, starting from the given entry points. It accepts an optional boolean parameter which can be set to true if a Message should be visited more than once following different paths. The callback receives a Walker object as the last parameter which can be used to control the behavior of the walk similar to how a "Context" is used in some parts of the stdlib.
func (*Utils) WalkMessageMetadata ¶
func (u *Utils) WalkMessageMetadata(callback func(messageMetadata *MessageMetadata, walker *walker.Walker[MessageID]), entryPoints MessageIDs, revisitElements ...bool)
WalkMessageMetadata is a generic Tangle walker that executes a custom callback for every visited MessageMetadata, starting from the given entry points. It accepts an optional boolean parameter which can be set to true if a Message should be visited more than once following different paths. The callback receives a Walker object as the last parameter which can be used to control the behavior of the walk similar to how a "Context" is used in some parts of the stdlib.
type VotePower ¶
type VotePower = uint64
VotePower is used to establish an absolute order of votes, regarldless of their arrival order. Currently, the used VotePower is the SequenceNumber embedded in the Message Layout, so that, regardless of the order in which votes are received, the same conclusion is computed. Alternatively, the objective timestamp of a Message could be used.
type Voter ¶
Voter is a type wrapper for identity.ID and defines a node that supports a branch or marker.
type Voters ¶
Voters is a set of node identities that votes for a particular Branch.
type WeightProvider ¶
type WeightProvider interface { // Update updates the underlying data structure and keeps track of active nodes. Update(t time.Time, nodeID identity.ID) // Weight returns the weight and total weight for the given message. Weight(message *Message) (weight, totalWeight float64) // WeightsOfRelevantVoters returns all relevant weights. WeightsOfRelevantVoters() (weights map[identity.ID]float64, totalWeight float64) // Shutdown shuts down the WeightProvider and persists its state. Shutdown() }
WeightProvider is an interface that allows the ApprovalWeightManager to determine approval weights of Messages in a flexible way, independently of a specific implementation.
Source Files ¶
- approvalweightmanager.go
- approvalweightmanager.models.go
- booker.go
- cmanaweightprovider.go
- consensusmanager.go
- dispatcher.go
- errors.go
- ledgerstate.go
- markersmanager.go
- markersmanager.models.go
- message.go
- messagefactory.go
- parser.go
- ratesetter.go
- requester.go
- scenarios.go
- scheduler.go
- solidifier.go
- storage.go
- tangle.go
- testutils.go
- timemanager.go
- tipmanager.go
- utils.go