Versions in this module Expand all Collapse all v1 v1.13.0 Feb 18, 2021 Changes in this version + const BATCH_SIZE + const Range + var ControlPanelAllowedSize int = 2 + var CurrentMessageQueueApiGeneralVec = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var CurrentMessageQueueInMsgGeneralVec = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var ESAsking = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESAvgRequests = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESDBHTComplete = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESFirstMissing = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESFound = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESHighestAsking = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESHighestMissing = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESMissing = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var ESMissingQueue = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var EntrySyncMax = 750 + var EntrySyncMaxEBlocks = 200 + var EntrySyncRetry = time.Second * 10 + var EntrySyncWarning = 16 + var FACTOID_CHAINID_HASH = primitives.NewHash(constants.FACTOID_CHAINID) + var FilterTimeLimit = int64(Range * 60 * 2 * 1000000000) + var FollowerEOMExecutions = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var FollowerExecutions = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var FollowerMissingMsgExecutions = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HighestAck = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var HighestCompleted = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var HighestKnown = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var HighestSaved = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var HoldingQueueCommitChainInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueCommitChainOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueCommitEntryInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueCommitEntryOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueDBSigInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueDBSigOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueRevealEntryInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var HoldingQueueRevealEntryOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var InstantTransactionPerSecond = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var LeaderEOMExecutions = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var LeaderExecutions = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var LeaderSyncAckDelay = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var LeaderSyncAckPairDelay = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var LeaderSyncMsgDelay = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var MAIN_FACTOM_IDENTITY_LIST = "888888001750ede0eff4b05f0c3f557890b256450cabbb84cada937f9c258327" + var MMR_enable bool = true + var TIME_WINDOW uint32 = 144 + var TotalAckLoopTime = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalAcksInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalAcksOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalCommitsInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalCommitsOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalEmptyLoopTime = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalExecuteMsgTime = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalHoldingQueueInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalHoldingQueueOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalHoldingQueueRecycles = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalMessageQueueApiGeneralVec = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var TotalMessageQueueInMsgGeneralVec = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var TotalMessageQueueNetOutMsgGeneralVec = prometheus.NewGaugeVec(prometheus.GaugeOpts{ ... }, []string{ ... }) + var TotalMsgQueueInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalMsgQueueOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalProcessEOMs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalProcessListInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalProcessListProcesses = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalProcessProcChanTime = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalProcessXReviewTime = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalReviewHoldingTime = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalTransactionPerSecond = prometheus.NewGauge(prometheus.GaugeOpts{ ... }) + var TotalXReviewQueueInputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var TotalXReviewQueueOutputs = prometheus.NewCounter(prometheus.CounterOpts{ ... }) + var ValidationDebug bool = false + func AppendExtIDs(extIDs [][]byte, start int, end int) ([]byte, error) + func BytesToUint32(data []byte) (ret uint32, err error) + func CheckDBKeyMR(s *State, ht uint32, hash string) error + func CheckGrants() + func CheckLength(length int, item []byte) bool + func CheckSig(idKey interfaces.IHash, pub []byte, msg []byte, sig []byte) bool + func DeleteFile(filename string) error + func FaultCheck(pl *ProcessList) + func FedServerVM(serverMap [10][64]int, numberOfFedServers int, minute int, fedIndex int) int + func GenerateGenesisBlocks(networkID uint32, bootstrapIdentity interfaces.IHash) (interfaces.IDirectoryBlock, interfaces.IAdminBlock, interfaces.IFBlock, ...) + func GetGrantPayoutsFor(currentDBHeight uint32) []interfaces.ITransAddress + func GetMapHash(bmap map[[32]byte]int64) interfaces.IHash + func HeightToHash(height uint32, minute int) [32]byte + func LoadDatabase(s *State) + func LoadFromFile(s *State, filename string) ([]byte, error) + func MakeMap(numberFedServers int, dbheight uint32) (serverMap [10][64]int) + func Minutes(unix int64) int + func NetworkIDToFilename(networkName string, fileLocation string) string + func NonBlockingChannelAdd(channel chan interfaces.IMsg, msg interfaces.IMsg) bool + func PopBalanceMap(buf *primitives.Buffer) (map[[32]byte]int64, error) + func PopBucketMap(buf *primitives.Buffer) (map[[32]byte]int, error) + func PrintState(state *State) + func ProcessIdentityToAdminBlock(st *State, chainID interfaces.IHash, servertype int) bool + func PushBalanceMap(b *primitives.Buffer, m map[[32]byte]int64) error + func PushBucketMap(b *primitives.Buffer, m map[[32]byte]int) error + func RandomServer() interfaces.IServer + func RegisterPrometheus() + func SaveToFile(s *State, dbht uint32, b []byte, filename string) error + func SortServers(servers []interfaces.IServer) []interfaces.IServer + func Uint32ToBytes(val uint32) ([]byte, error) + type ACKMap struct + Acks map[MsgHeight]interfaces.IMsg + MsgOrder [1000]MsgHeight + N int + func (a *ACKMap) Add(msg interfaces.IMsg) + func (a *ACKMap) Get(DBHeight int, vmIndex int, height int) interfaces.IMsg + type APIMSGQueue chan interfaces.IMsg + func (q APIMSGQueue) BlockingDequeue() interfaces.IMsg + func (q APIMSGQueue) Cap() int + func (q APIMSGQueue) Dequeue() interfaces.IMsg + func (q APIMSGQueue) Enqueue(m interfaces.IMsg) + func (q APIMSGQueue) Length() int + func NewAPIQueue(capacity int) APIMSGQueue + type AckMsgPairCache struct + CurrentWorkingHeight int + MsgPairMap map[int]map[plRef]*MsgPair + func NewAckMsgCache() *AckMsgPairCache + func (a *AckMsgPairCache) AddMsgPair(pair *MsgPair) + func (a *AckMsgPairCache) Expire(newHeight int) + func (a *AckMsgPairCache) Get(dbHeight, vmIndex, plHeight int) *MsgPair + func (a *AckMsgPairCache) HeightTooOld(height int) bool + func (a *AckMsgPairCache) UpdateWorkingHeight(newHeight int) + type ByKey [][32]byte + func (f ByKey) Len() int + func (f ByKey) Less(i, j int) bool + func (f ByKey) Swap(i, j int) + type CrossReplayFilter struct + Currentheight int + LowestHeight int + func NewCrossReplayFilter(path string) *CrossReplayFilter + func (c *CrossReplayFilter) AddSalt(height uint32, salt [8]byte) error + func (c *CrossReplayFilter) Close() + func (c *CrossReplayFilter) ExistOldSalt(salt [8]byte) bool + func (c *CrossReplayFilter) ExistSalt(salt [8]byte) (bool, error) + func (c *CrossReplayFilter) Run() + type DBSig struct + ChainID interfaces.IHash + Signature interfaces.IFullSignature + VMIndex int + type DBState struct + ABHash interfaces.IHash + Added interfaces.Timestamp + AdminBlock interfaces.IAdminBlock + DBHash interfaces.IHash + DirectoryBlock interfaces.IDirectoryBlock + ECHash interfaces.IHash + Entries []interfaces.IEBEntry + EntryBlocks []interfaces.IEntryBlock + EntryCreditBlock interfaces.IEntryCreditBlock + FBHash interfaces.IHash + FactoidBlock interfaces.IFBlock + FinalExchangeRate uint64 + IsNew bool + Locked bool + NextTimestamp interfaces.Timestamp + ReadyToSave bool + Repeat bool + SaveStruct *SaveState + Saved bool + Signed bool + func (a *DBState) IsSameAs(b *DBState) bool + func (d *DBState) ValidNext(state *State, next *messages.DBStateMsg) int + func (dbs *DBState) GetAdminBlock() interfaces.IAdminBlock + func (dbs *DBState) GetDirectoryBlock() interfaces.IDirectoryBlock + func (dbs *DBState) GetEntries() []interfaces.IEBEntry + func (dbs *DBState) GetEntryBlocks() []interfaces.IEntryBlock + func (dbs *DBState) GetEntryCreditBlock() interfaces.IEntryCreditBlock + func (dbs *DBState) GetFactoidBlock() interfaces.IFBlock + func (dbs *DBState) Init() + func (dbs *DBState) MarshalBinary() (rval []byte, err error) + func (dbs *DBState) UnmarshalBinary(p []byte) error + func (dbs *DBState) UnmarshalBinaryData(p []byte) (newData []byte, err error) + func (ds *DBState) String() string + type DBStateList struct + Base uint32 + Complete uint32 + DBStates []*DBState + LastBegin int + LastEnd int + ProcessHeight uint32 + SavedHeight uint32 + State *State + TimeToAsk interfaces.Timestamp + func (a *DBStateList) IsSameAs(b *DBStateList) bool + func (dbsl *DBStateList) Init() + func (dbsl *DBStateList) MarshalBinary() (rval []byte, err error) + func (dbsl *DBStateList) UnmarshalBinary(p []byte) error + func (dbsl *DBStateList) UnmarshalBinaryData(p []byte) (newData []byte, err error) + func (list *DBStateList) Catchup() + func (list *DBStateList) FixupLinks(p *DBState, d *DBState) (progress bool) + func (list *DBStateList) Get(height int) *DBState + func (list *DBStateList) GetHighestCompletedBlk() uint32 + func (list *DBStateList) GetHighestLockedSignedAndSavesBlk() uint32 + func (list *DBStateList) GetHighestSavedBlk() uint32 + func (list *DBStateList) GetHighestSignedBlk() uint32 + func (list *DBStateList) Highest() uint32 + func (list *DBStateList) Last() *DBState + func (list *DBStateList) NewDBState(isNew bool, directoryBlock interfaces.IDirectoryBlock, ...) *DBState + func (list *DBStateList) ProcessBlocks(d *DBState) (progress bool) + func (list *DBStateList) Put(dbState *DBState) bool + func (list *DBStateList) SaveDBStateToDB(d *DBState) (progress bool) + func (list *DBStateList) SignDB(d *DBState) (process bool) + func (list *DBStateList) String() string + func (list *DBStateList) UpdateState() (progress bool) + func (list *DBStateList) WriteDBStateToDebugFile(d *DBState) + type DisplayState struct + Authorities []*Authority + ControlPanelPort int + ControlPanelSetting int + CurrentEBDBHeight uint32 + CurrentLeaderHeight uint32 + CurrentNodeHeight uint32 + Election string + Identities []*Identity + IdentityChainID interfaces.IHash + IgnoreDone bool + LastDirectoryBlock interfaces.IDirectoryBlock + LeaderHeight uint32 + NodeName string + PLEntry []EntryTransaction + PLFactoid []FactoidTransaction + PrintMap string + ProcessList string + ProcessList0 string + ProcessList2 string + PublicKey *primitives.PublicKey + RawSummary string + SimElection string + SyncingState [256]string + SyncingStateCurrent int + func DeepStateDisplayCopy(s *State) (*DisplayState, error) + func DeepStateDisplayCopyDifference(s *State, prev *DisplayState) (*DisplayState, error) + func NewDisplayState() *DisplayState + func (d *DisplayState) Clone() *DisplayState + func (ds *DisplayState) CopyDirectoryBlock(s *State, prev *DisplayState, height uint32) + type ElectionQueue chan interfaces.IMsg + func (q ElectionQueue) BlockingDequeue() interfaces.IMsg + func (q ElectionQueue) Cap() int + func (q ElectionQueue) Dequeue() interfaces.IMsg + func (q ElectionQueue) Enqueue(m interfaces.IMsg) + func (q ElectionQueue) Length() int + func NewElectionQueue(capacity int) ElectionQueue + type EntrySync struct + func NewEntrySync(s *State) *EntrySync + func (es *EntrySync) AskedFor(hash interfaces.IHash) bool + func (es *EntrySync) DelayedStart() + func (es *EntrySync) Position() uint32 + func (es *EntrySync) Stop() + func (es *EntrySync) SyncHeight() + type EntryTransaction struct + ChainID string + EntryHash string + type EntryUpdate struct + Hash interfaces.IHash + Timestamp interfaces.Timestamp + type FactoidState struct + CurrentBlock interfaces.IFBlock + DBHeight uint32 + State *State + Wallet interfaces.ISCWallet + func (fs *FactoidState) AddECBlock(blk interfaces.IEntryCreditBlock) error + func (fs *FactoidState) AddTransaction(index int, trans interfaces.ITransaction) error + func (fs *FactoidState) AddTransactionBlock(blk interfaces.IFBlock) error + func (fs *FactoidState) EndOfPeriod(period int) + func (fs *FactoidState) GetBalanceHash(TempBalanceHash bool) (rval interfaces.IHash) + func (fs *FactoidState) GetCoinbaseTransaction(dbheight uint32, ftime interfaces.Timestamp) interfaces.ITransaction + func (fs *FactoidState) GetCurrentBlock() interfaces.IFBlock + func (fs *FactoidState) GetECBalance(address [32]byte) int64 + func (fs *FactoidState) GetFactoidBalance(address [32]byte) int64 + func (fs *FactoidState) GetMultipleECBalances(singleAdd [32]byte) (uint32, uint32, int64, int64, string) + func (fs *FactoidState) GetMultipleFactoidBalances(singleAdd [32]byte) (uint32, uint32, int64, int64, string) + func (fs *FactoidState) ProcessEndOfBlock(state interfaces.IState) + func (fs *FactoidState) UpdateECTransaction(rt bool, trans interfaces.IECBlockEntry) error + func (fs *FactoidState) UpdateTransaction(rt bool, trans interfaces.ITransaction) error + func (fs *FactoidState) Validate(index int, trans interfaces.ITransaction) (err error, holdAddr [32]byte) + func (fs *FactoidState) ValidateTransactionAge(trans interfaces.ITransaction) error + type FactoidTransaction struct + Hash string + Status string + TotalInput string + TotalInputs int + TotalOutputs int + TxID string + type FaultCore struct + AuditServerID interfaces.IHash + DBHeight uint32 + Height uint32 + ServerID interfaces.IHash + SystemHeight uint32 + Timestamp interfaces.Timestamp + VMIndex byte + func (fc *FaultCore) GetHash() (rval interfaces.IHash) + func (fc *FaultCore) MarshalCore() (data []byte, err error) + type GeneralMSGQueue chan interfaces.IMsg + func (q GeneralMSGQueue) BlockingDequeue() interfaces.IMsg + func (q GeneralMSGQueue) Cap() int + func (q GeneralMSGQueue) Dequeue() interfaces.IMsg + func (q GeneralMSGQueue) Enqueue(t interfaces.IMsg) + func (q GeneralMSGQueue) Length() int + type GenericListItem interface + Height func() uint32 + type HardGrant struct + Address interfaces.IAddress + Amount uint64 + DBh uint32 + func GetHardCodedGrants() []HardGrant + type HoldingList struct + func (l *HoldingList) Add(h [32]byte, msg interfaces.IMsg) bool + func (l *HoldingList) ExecuteForNewHeight(ht uint32, minute int) + func (l *HoldingList) Get(h [32]byte) []interfaces.IMsg + func (l *HoldingList) GetDependentMsg(h [32]byte) interfaces.IMsg + func (l *HoldingList) GetSize() int + func (l *HoldingList) Init(s *State) + func (l *HoldingList) Messages() map[[32]byte][]interfaces.IMsg + func (l *HoldingList) RemoveDependentMsg(h [32]byte, reason string) + func (l *HoldingList) Review() + type IPrometheusRateMethods interface + SetArrivalBackup func(v float64) + SetArrivalInstantAvg func(v float64) + SetArrivalTotalAvg func(v float64) + SetCompleteInstantAvg func(v float64) + SetCompleteTotalAvg func(v float64) + SetMovingArrival func(v float64) + SetMovingComplete func(v float64) + type IdentityEntry struct + Blockheight uint32 + Entry interfaces.IEBEntry + Timestamp interfaces.Timestamp + type InMsgMSGQueue chan interfaces.IMsg + func (q InMsgMSGQueue) BlockingDequeue() interfaces.IMsg + func (q InMsgMSGQueue) Cap() int + func (q InMsgMSGQueue) Dequeue() interfaces.IMsg + func (q InMsgMSGQueue) Enqueue(m interfaces.IMsg) + func (q InMsgMSGQueue) Length() int + func NewInMsgQueue(capacity int) InMsgMSGQueue + type Last100 struct + func (list *Last100) Add(msg interfaces.IMsg) + func (list *Last100) Get(h [32]byte) interfaces.IMsg + type MMRInfo struct + type MSGMap struct + MsgOrder [1000][32]byte + Msgs map[[32]byte]interfaces.IMsg + N int + type MSgPair struct + type MarshalableUint32 uint32 + func (m *MarshalableUint32) MarshalBinary() (rval []byte, err error) + func (m *MarshalableUint32) UnmarshalBinary(data []byte) error + func (m *MarshalableUint32) UnmarshalBinaryData(data []byte) ([]byte, error) + type MissingEntry struct + Cnt int + DBHeight uint32 + EBHash interfaces.IHash + EntryHash interfaces.IHash + LastTime time.Time + func RandomMissingEntry() *MissingEntry + func (s *MissingEntry) IsSameAs(b *MissingEntry) bool + func (s *MissingEntry) MarshalBinary() (rval []byte, err error) + func (s *MissingEntry) UnmarshalBinary(p []byte) error + func (s *MissingEntry) UnmarshalBinaryData(p []byte) (newData []byte, err error) + type MissingEntryBlock struct + DBHeight uint32 + EBHash interfaces.IHash + func RandomMissingEntryBlock() *MissingEntryBlock + func (s *MissingEntryBlock) IsSameAs(b *MissingEntryBlock) bool + func (s *MissingEntryBlock) MarshalBinary() (rval []byte, err error) + func (s *MissingEntryBlock) UnmarshalBinary(p []byte) error + func (s *MissingEntryBlock) UnmarshalBinaryData(p []byte) (newData []byte, err error) + type MissingMessageResponseCache struct + AckMessageCache *AckMsgPairCache + MissingMsgRequests chan interfaces.IMsg + ProcessedPairs chan *MsgPair + func NewMissingMessageReponseCache(s *State) *MissingMessageResponseCache + func (mmrc *MissingMessageResponseCache) Close() + func (mmrc *MissingMessageResponseCache) NotifyNewMsgPair(ack interfaces.IMsg, msg interfaces.IMsg) + func (mmrc *MissingMessageResponseCache) NotifyPeerMissingMsg(missingMsg interfaces.IMsg) + func (mmrc *MissingMessageResponseCache) Run() + type MissingState struct + func NewMissingState(height uint32) *MissingState + func (s *MissingState) Height() uint32 + type MovingAverage struct + Window int + func NewMovingAverage(window int) *MovingAverage + func (ma *MovingAverage) Add(val float64) + func (ma *MovingAverage) Avg() float64 + type MsgHeight struct + DBHeight int + Height int + VM int + type MsgPair struct + Ack interfaces.IMsg + Msg interfaces.IMsg + type NetOutMsgQueue chan interfaces.IMsg + func (q NetOutMsgQueue) BlockingDequeue() interfaces.IMsg + func (q NetOutMsgQueue) Cap() int + func (q NetOutMsgQueue) Dequeue() interfaces.IMsg + func (q NetOutMsgQueue) Enqueue(m interfaces.IMsg) + func (q NetOutMsgQueue) Length() int + func NewNetOutMsgQueue(capacity int) NetOutMsgQueue + type ProcessList struct + AdminBlock interfaces.IAdminBlock + AuditServers []interfaces.IServer + DBHeight uint32 + DBSigAlreadySent bool + DBSignatures []DBSig + DirectoryBlock interfaces.IDirectoryBlock + ECBalancesT map[[32]byte]int64 + ECBalancesTMutex sync.Mutex + EntryCreditBlock interfaces.IEntryCreditBlock + FactoidBalancesT map[[32]byte]int64 + FactoidBalancesTMutex sync.Mutex + FedServers []interfaces.IServer + Matryoshka []interfaces.IHash + NewEBlocks map[[32]byte]interfaces.IEntryBlock + NewEntries map[[32]byte]interfaces.IEntry + NewEntriesMutex sync.RWMutex + NextHeightToProcess [64]int + OldAcks map[[32]byte]interfaces.IMsg + OldMsgs map[[32]byte]interfaces.IMsg + PendingChainHeads *SafeMsgMap + ServerMap [10][64]int + StartingAuditServers []interfaces.IServer + StartingFedServers []interfaces.IServer + State *State + System VM + VMs []*VM + func NewProcessList(state interfaces.IState, previous *ProcessList, dbheight uint32) *ProcessList + func (p *ProcessList) AddAuditServer(identityChainID interfaces.IHash) int + func (p *ProcessList) AddDBSig(serverID interfaces.IHash, sig interfaces.IFullSignature) + func (p *ProcessList) AddFedServer(identityChainID interfaces.IHash) int + func (p *ProcessList) AddNewEBlocks(key interfaces.IHash, value interfaces.IEntryBlock) + func (p *ProcessList) AddNewEntry(key interfaces.IHash, value interfaces.IEntry) + func (p *ProcessList) AddOldMsgs(m interfaces.IMsg) + func (p *ProcessList) AddToProcessList(s *State, ack *messages.Ack, m interfaces.IMsg) + func (p *ProcessList) CheckDiffSigTally() bool + func (p *ProcessList) Complete() bool + func (p *ProcessList) ContainsDBSig(serverID interfaces.IHash) bool + func (p *ProcessList) CountFederatedServersAddedAndRemoved() (added int, removed int) + func (p *ProcessList) FedServerFor(minute int, hash []byte) interfaces.IServer + func (p *ProcessList) GetAckAt(vmIndex int, height int) *messages.Ack + func (p *ProcessList) GetAuditServerIndexHash(identityChainID interfaces.IHash) (bool, int) + func (p *ProcessList) GetDBHeight() uint32 + func (p *ProcessList) GetFedServerIndexHash(identityChainID interfaces.IHash) (bool, int) + func (p *ProcessList) GetKeysNewEntries() (keys [][32]byte) + func (p *ProcessList) GetNewEBlocks(key interfaces.IHash) interfaces.IEntryBlock + func (p *ProcessList) GetNewEntry(key [32]byte) interfaces.IEntry + func (p *ProcessList) GetOldAck(key interfaces.IHash) interfaces.IMsg + func (p *ProcessList) GetVMStatsForFedServer(index int) (vmIndex int, listHeight int, listLength int, nextNil int) + func (p *ProcessList) GetVirtualServers(minute int, identityChainID interfaces.IHash) (found bool, index int) + func (p *ProcessList) IncrementDiffSigTally() + func (p *ProcessList) IsPendingChainHead(chainid interfaces.IHash) bool + func (p *ProcessList) LenNewEntries() int + func (p *ProcessList) LogPrintLeaders(log string) + func (p *ProcessList) MakeMap() + func (p *ProcessList) PrintMap() string + func (p *ProcessList) Process(s *State) (progress bool) + func (p *ProcessList) RemoveAuditServerHash(identityChainID interfaces.IHash) + func (p *ProcessList) RemoveFedServerHash(identityChainID interfaces.IHash) + func (p *ProcessList) RemoveFromPL(vm *VM, j int, reason string) + func (p *ProcessList) Reset() bool + func (p *ProcessList) ResetDiffSigTally() + func (p *ProcessList) SetStartingAuthoritySet() + func (p *ProcessList) Sort(serv []interfaces.IServer) bool + func (p *ProcessList) SortAuditServers() + func (p *ProcessList) SortDBSigs() + func (p *ProcessList) SortFedServers() + func (p *ProcessList) String() string + func (p *ProcessList) TrimVMList(h uint32, vmIndex int) + func (p *ProcessList) UpdateStatus(s *State) + func (p *ProcessList) VMIndexFor(hash []byte) int + type ProcessLists struct + DBHeightBase uint32 + Lists []*ProcessList + SetString bool + State *State + Str string + func NewProcessLists(state interfaces.IState) *ProcessLists + func (lists *ProcessLists) Get(dbheight uint32) *ProcessList + func (lists *ProcessLists) GetSafe(dbheight uint32) (pl *ProcessList) + func (lists *ProcessLists) LastList() *ProcessList + func (lists *ProcessLists) String() string + func (lists *ProcessLists) UpdateState(dbheight uint32) (progress bool) + type RateCalculator struct + func NewRateCalculator(p IPrometheusRateMethods) *RateCalculator + func NewRateCalculatorTime(p IPrometheusRateMethods, td time.Duration) *RateCalculator + func (r *RateCalculator) Arrival() + func (r *RateCalculator) Complete() + func (r *RateCalculator) Start() + func (r *RateCalculator) StartTime(start time.Time) + type ReceivedState struct + func NewReceivedState(msg *messages.DBStateMsg) *ReceivedState + func (s *ReceivedState) Height() uint32 + func (s *ReceivedState) Message() *messages.DBStateMsg + type RecentMessage struct + AcksMap ACKMap + MsgsMap MSGMap + NewMsgs chan interfaces.IMsg + func (am *RecentMessage) GetAckAndMsg(DBHeight int, vmIndex int, height int, s interfaces.IState) (ack interfaces.IMsg, msg interfaces.IMsg) + func (m *RecentMessage) Add(msg interfaces.IMsg) + func (m *RecentMessage) HandleRejection(msg interfaces.IMsg, iAck interfaces.IMsg) + type Replay struct + Basetime int + Buckets [numBuckets]map[[32]byte]int + Center int + Mutex sync.Mutex + func RandomReplay() *Replay + func (a *Replay) IsSameAs(b *Replay) bool + func (r *Replay) Clear(mask int, hash [32]byte) + func (r *Replay) Init() + func (r *Replay) IsHashUnique(mask int, hash [32]byte) bool + func (r *Replay) IsHashUnique_internal(mask int, hash [32]byte) bool + func (r *Replay) IsTSValid(mask int, hash interfaces.IHash, timestamp interfaces.Timestamp) bool + func (r *Replay) IsTSValidAndUpdateState(mask int, hash [32]byte, timestamp interfaces.Timestamp, ...) (rval bool) + func (r *Replay) MarshalBinary() (rval []byte, err error) + func (r *Replay) Recenter(systemtime interfaces.Timestamp) + func (r *Replay) Save() *Replay + func (r *Replay) SetHashNow(mask int, hash [32]byte, now interfaces.Timestamp) bool + func (r *Replay) UnmarshalBinary(p []byte) error + func (r *Replay) UnmarshalBinaryData(p []byte) ([]byte, error) + func (r *Replay) Valid(mask int, hash [32]byte, timestamp interfaces.Timestamp, ...) (index int, valid bool) + type SafeMsgMap struct + func NewSafeMsgMap(name string, s *State) *SafeMsgMap + func (m *SafeMsgMap) Cleanup(s *State) + func (m *SafeMsgMap) Copy() *SafeMsgMap + func (m *SafeMsgMap) Delete(key [32]byte) (msg interfaces.IMsg, found bool) + func (m *SafeMsgMap) Get(key [32]byte) (msg interfaces.IMsg) + func (m *SafeMsgMap) GetRaw() map[[32]byte]interfaces.IMsg + func (m *SafeMsgMap) Len() int + func (m *SafeMsgMap) Put(key [32]byte, msg interfaces.IMsg) + func (m *SafeMsgMap) RemoveExpired(s *State) + func (m *SafeMsgMap) Reset() + type SaveState struct + Acks map[[32]byte]interfaces.IMsg + AuditServers []interfaces.IServer + AuthorityServerCount int + Commits *SafeMsgMap + CurrentMinute int + DBHeight uint32 + DBSig bool + DBSigDone bool + DBSigLimit int + DBSigProcessed int + DBSigSys bool + ECBalancesP map[[32]byte]int64 + EOM bool + EOMDone bool + EOMLimit int + EOMMinute int + EOMProcessed int + EOMSys bool + EOMsyncing bool + EntryBlockDBHeightComplete uint32 + EntryBlockDBHeightProcessing uint32 + ExchangeRateAuthorityPublicKey string + FERChainId string + FERChangeHeight uint32 + FERChangePrice uint64 + FERPriority uint32 + FERPrioritySetHeight uint32 + FactoidBalancesP map[[32]byte]int64 + FactoshisPerEC uint64 + FedServers []interfaces.IServer + Holding map[[32]byte]interfaces.IMsg + IdentityControl *IdentityManager + InvalidMessages map[[32]byte]interfaces.IMsg + LLeaderHeight uint32 + Leader bool + LeaderPL *ProcessList + LeaderTimestamp interfaces.Timestamp + LeaderVMIndex int + Newblk bool + Saving bool + Syncing bool + XReview []interfaces.IMsg + func SaveFactomdState(state *State, d *DBState) (ss *SaveState) + func (a *SaveState) IsSameAs(b *SaveState) bool + func (e *SaveState) JSONByte() ([]byte, error) + func (e *SaveState) JSONString() (string, error) + func (e *SaveState) String() string + func (ss *SaveState) Init() + func (ss *SaveState) MarshalBinary() (rval []byte, err error) + func (ss *SaveState) RestoreFactomdState(s *State) + func (ss *SaveState) TrimBack(s *State, d *DBState) + func (ss *SaveState) UnmarshalBinary(p []byte) error + func (ss *SaveState) UnmarshalBinaryData(p []byte) (newData []byte, err error) + type Server struct + ChainID interfaces.IHash + Name string + Online bool + Replace interfaces.IHash + func (e *Server) JSONByte() ([]byte, error) + func (e *Server) JSONString() (string, error) + func (s *Server) GetChainID() (rval interfaces.IHash) + func (s *Server) GetName() string + func (s *Server) Init() + func (s *Server) IsOnline() bool + func (s *Server) IsSameAs(b interfaces.IServer) bool + func (s *Server) LeaderToReplace() (rval interfaces.IHash) + func (s *Server) MarshalBinary() (rval []byte, err error) + func (s *Server) SetOnline(o bool) + func (s *Server) SetReplace(h interfaces.IHash) + func (s *Server) String() string + func (s *Server) UnmarshalBinary(p []byte) error + func (s *Server) UnmarshalBinaryData(p []byte) (newData []byte, err error) + type State struct + AckChange uint32 + Acks map[[32]byte]interfaces.IMsg + AcksLast int64 + AcksMap map[[32]byte]interfaces.IMsg + AcksMutex sync.RWMutex + Anchor interfaces.IAnchor + AuditHeartBeats []interfaces.IMsg + AuthorityDeltas string + AuthorityServerCount int + AuthoritySetString string + Balancehash interfaces.IHash + BoltDBPath string + BootTime int64 + Cfg interfaces.IFactomConfig + ChainCommits Last100 + CheckChainHeads struct{ ... } + CloneDBType string + Commits *SafeMsgMap + ConfigFilePath string + ConsoleLogLevel string + ControlPanelChannel chan DisplayState + ControlPanelDataRequest bool + ControlPanelPort int + ControlPanelSetting int + CorsDomains []string + CreatedLastBlockFromDBState bool + CrossReplay *CrossReplayFilter + CurrentBlockStartTime int64 + CurrentMinute int + CurrentMinuteStartTime int64 + CustomBootstrapIdentity string + CustomBootstrapKey string + CustomNetworkID []byte + CustomNetworkPort string + CustomSeedURL string + CustomSpecialPeers string + DB interfaces.DBOverlaySimple + DBFinished bool + DBHeightAtBoot uint32 + DBSig bool + DBSigDone bool + DBSigFails int + DBSigLimit int + DBSigProcessed int + DBSigSys bool + DBStateAppliedCnt int + DBStateAskCnt int + DBStateIgnoreCnt int + DBStateManager interfaces.IManagerController + DBStateReplyCnt int + DBStates *DBStateList + DBStatesReceived []*messages.DBStateMsg + DBStatesReceivedBase int + DBStatesSent []*interfaces.DBStateSent + DBType string + DebugConsensus bool + Delay int64 + DirectoryBlockInSeconds int + DropRate int + ECBalancesP map[[32]byte]int64 + ECBalancesPMutex sync.Mutex + ECBalancesPapi map[[32]byte]int64 + ECCommits int + ECommits int + EFactory interfaces.IElectionsFactory + EOM bool + EOMDone bool + EOMIssueTime int64 + EOMLimit int + EOMMinute int + EOMProcessed int + EOMSyncEnd int64 + EOMSyncTime int64 + EOMSys bool + EOMfaultIndex int + EOMsyncing bool + Election0 string + Election1 string + Election2 string + Election3 string + Elections interfaces.IElections + EntryBlockDBHeightComplete uint32 + EntryBlockDBHeightProcessing uint32 + EntrySync *EntrySync + EventService events.EventService + ExchangeRateAuthorityPublicKey string + ExpireCnt int + ExportData bool + ExportDataSubpath string + FCTSubmits int + FERChainId string + FERChangeHeight uint32 + FERChangePrice uint64 + FERPriority uint32 + FERPrioritySetHeight uint32 + FReplay *Replay + FactoidBalancesP map[[32]byte]int64 + FactoidBalancesPMutex sync.Mutex + FactoidBalancesPapi map[[32]byte]int64 + FactoidState interfaces.IFactoidState + FactoidTrans int + FactomNodeName string + FactomdLocations string + FactomdTLSCertFile string + FactomdTLSEnable bool + FactomdTLSKeyFile string + FactomdVersion string + FactoshisPerEC uint64 + FastBoot bool + FastBootLocation string + FastSaveRate int + FaultTimeout int + FaultWait int + HighestCompletedTorrent uint32 + Hold HoldingList + Holding map[[32]byte]interfaces.IMsg + HoldingLast int64 + HoldingList chan [32]byte + HoldingMap map[[32]byte]interfaces.IMsg + HoldingMutex sync.RWMutex + HoldingVM int + IdentityChainID interfaces.IHash + IdentityControl *IdentityManager + IgnoreDone bool + IgnoreMissing bool + InputRegEx *regexp.Regexp + InputRegExString string + InvalidMessages map[[32]byte]interfaces.IMsg + InvalidMessagesMutex *sync.RWMutex + IsReplaying bool + JournalFile string + Journaling bool + KeepMismatch bool + LLeaderHeight uint32 + LastDisplayState *DisplayState + LastPrint string + LastPrintCnt int + LastTiebreak int64 + LdbPath string + Leader bool + LeaderPL *ProcessList + LeaderTimestamp interfaces.Timestamp + LeaderVMIndex int + LocalNetworkPort string + LocalSeedURL string + LocalServerPrivKey string + LocalSpecialPeers string + LogBits int64 + LogLevel string + LogPath string + Logger *log.Entry + LogstashURL string + MainNetworkPort string + MainSeedURL string + MainSpecialPeers string + MaxTimeOffset interfaces.Timestamp + MessageTalliesReceived [constants.NUM_MESSAGES]int + MessageTalliesSent [constants.NUM_MESSAGES]int + MessageTally bool + MissingEntries chan *MissingEntry + MissingEntryBlockRepeat interfaces.Timestamp + MissingMessageResponseHandler *MissingMessageResponseCache + MissingRequestAskCnt int + MissingRequestIgnoreCnt int + MissingRequestReplyCnt int + MissingResponseAppliedCnt int + NetStateOff bool + Network string + NetworkController *p2p.Network + NetworkNumber int + NewEntries int + NewEntryChains int + NodeMode string + NumEntries int + NumEntryBlocks int + NumFCTTrans int + NumNewChains int + NumNewEntries int + NumTransactions int + OneLeader bool + OutputAllowed bool + OutputRegEx *regexp.Regexp + OutputRegExString string + PLProcessHeight uint32 + PeersFile string + Port int + PortNumber int + Prefix string + PreviousMinuteStartTime int64 + ProcessListProcessCnt int64 + ProcessLists *ProcessLists + ProcessTime interfaces.Timestamp + Replay *Replay + ReplayTimestamp interfaces.Timestamp + RequestLimit int + RequestTimeout int + ResendCnt int + ResendHolding interfaces.Timestamp + ResetCnt int + ResetRequest bool + ResetTryCnt int + RestoreEC map[[32]byte]int64 + RestoreFCT map[[32]byte]int64 + Reveals Last100 + RpcAuthHash []byte + RpcPass string + RpcUser string + RunLeader bool + RunState runstate.RunState + Salt interfaces.IHash + Saving bool + ServerPrivKey *primitives.PrivateKey + ServerPubKey *primitives.PublicKey + ShutdownChan chan int + StartDelay int64 + StartDelayLimit int64 + Starttime time.Time + StateProcessCnt int64 + StateSaverStruct StateSaverStruct + StateUpdateState int64 + StatesMissing *StatesMissing + StatesReceived *StatesReceived + StatesWaiting *StatesWaiting + Status int + StatusMutex sync.Mutex + StatusStrs []string + Syncing bool + SyncingState [256]string + SyncingStateCurrent int + TempBalanceHash interfaces.IHash + TestNetworkPort string + TestSeedURL string + TestSpecialPeers string + TimeOffset interfaces.Timestamp + TimestampAtBoot interfaces.Timestamp + UpdateEntryHash chan *EntryUpdate + Uploader *UploadController + UseLogstash bool + ValidatorLoopSleepCnt int64 + WaitForEntries bool + WriteEntry chan interfaces.IEBEntry + XReview []interfaces.IMsg + func (s *State) APIQueue() interfaces.IQueue + func (s *State) AckQueue() chan interfaces.IMsg + func (s *State) Add(h [32]byte, msg interfaces.IMsg) int + func (s *State) AddAuditServer(dbheight uint32, hash interfaces.IHash) int + func (s *State) AddAuthorityDelta(authSet string) + func (s *State) AddDBSig(dbheight uint32, chainID interfaces.IHash, sig interfaces.IFullSignature) + func (s *State) AddDBState(isNew bool, directoryBlock interfaces.IDirectoryBlock, ...) *DBState + func (s *State) AddFedServer(dbheight uint32, hash interfaces.IHash) int + func (s *State) AddPrefix(prefix string) + func (s *State) AddStatus(status string) + func (s *State) AddToHolding(hash [32]byte, msg interfaces.IMsg) + func (s *State) AddToReplayFilter(mask int, hash [32]byte, timestamp interfaces.Timestamp, ...) (rval bool) + func (s *State) Ask(DBHeight int, vmIndex int, height int, when int64) bool + func (s *State) CalculateTransactionRate() (totalTPS float64, instantTPS float64) + func (s *State) CheckFileName(name string) bool + func (s *State) CheckForIDChange() + func (s *State) Clone(cloneNumber int) interfaces.IState + func (s *State) ComputeVMIndex(hash []byte) int + func (s *State) ConstructAuthoritySetString() (authSets []string) + func (s *State) CopyStateToControlPanel() error + func (s *State) CreateDBSig(dbheight uint32, vmIndex int) (interfaces.IMsg, interfaces.IMsg) + func (s *State) CreateEOM(force bool, m interfaces.IMsg, vmIdx int) (eom *messages.EOM, ack interfaces.IMsg) + func (s *State) CrossReplayAddSalt(height uint32, salt [8]byte) error + func (s *State) DataMsgQueue() chan interfaces.IMsg + func (s *State) DatabaseContains(hash interfaces.IHash) bool + func (s *State) DebugExec() (ret bool) + func (s *State) DeleteFromHolding(hash [32]byte, msg interfaces.IMsg, reason string) + func (s *State) DidCreateLastBlockFromDBState() bool + func (s *State) DoProcessing() + func (s *State) DoReset() + func (s *State) ElectionsQueue() interfaces.IQueue + func (s *State) EmitDirectoryBlockEventsFromHeight(height uint32, end uint32) + func (s *State) ExecuteFromHolding(h [32]byte) + func (s *State) ExpireHolding() + func (s *State) FactomSecond() time.Duration + func (s *State) FetchECTransactionByHash(hash interfaces.IHash) (interfaces.IECBlockEntry, error) + func (s *State) FetchEntryByHash(hash interfaces.IHash) (interfaces.IEBEntry, error) + func (s *State) FetchEntryHashFromProcessListsByTxID(txID string) (interfaces.IHash, error) + func (s *State) FetchEntryRevealAndCommitFromHolding(hash interfaces.IHash) (reveal interfaces.IMsg, commit interfaces.IMsg) + func (s *State) FetchFactoidTransactionByHash(hash interfaces.IHash) (interfaces.ITransaction, error) + func (s *State) FetchHoldingMessageByHash(hash interfaces.IHash) (int, byte, interfaces.IMsg, error) + func (s *State) FetchIdentityChainEntriesInCreateOrder(chainid interfaces.IHash) ([]IdentityEntry, error) + func (s *State) FetchPaidFor(hash interfaces.IHash) (interfaces.IHash, error) + func (s *State) FixMissingKeys(id *Identity) error + func (s *State) FollowerExecuteAck(msg interfaces.IMsg) + func (s *State) FollowerExecuteCommitChain(m interfaces.IMsg) + func (s *State) FollowerExecuteCommitEntry(m interfaces.IMsg) + func (s *State) FollowerExecuteDBState(msg interfaces.IMsg) + func (s *State) FollowerExecuteDataResponse(m interfaces.IMsg) + func (s *State) FollowerExecuteEOM(m interfaces.IMsg) + func (s *State) FollowerExecuteFullFault(m interfaces.IMsg) + func (s *State) FollowerExecuteMMR(m interfaces.IMsg) + func (s *State) FollowerExecuteMissingMsg(msg interfaces.IMsg) + func (s *State) FollowerExecuteMsg(m interfaces.IMsg) + func (s *State) FollowerExecuteRevealEntry(m interfaces.IMsg) + func (s *State) FollowerExecuteSFault(m interfaces.IMsg) + func (s *State) GetACKStatus(hash interfaces.IHash) (int, interfaces.IHash, interfaces.Timestamp, interfaces.Timestamp, error) + func (s *State) GetAckChange() (bool, error) + func (s *State) GetAnchor() interfaces.IAnchor + func (s *State) GetAuditHeartBeats() []interfaces.IMsg + func (s *State) GetAuditServers(dbheight uint32) []interfaces.IServer + func (s *State) GetAuthorities() []interfaces.IAuthority + func (s *State) GetAuthorityDeltas() string + func (s *State) GetAuthorityInterface(chainid interfaces.IHash) interfaces.IAuthority + func (s *State) GetAuthoritySetString() string + func (s *State) GetBootTime() int64 + func (s *State) GetCfg() interfaces.IFactomConfig + func (s *State) GetConfigPath() string + func (s *State) GetCorsDomains() []string + func (s *State) GetCurrentBlockStartTime() int64 + func (s *State) GetCurrentMinute() int + func (s *State) GetCurrentMinuteStartTime() int64 + func (s *State) GetCurrentTime() int64 + func (s *State) GetDB() interfaces.DBOverlaySimple + func (s *State) GetDBFinished() bool + func (s *State) GetDBHeightAtBoot() uint32 + func (s *State) GetDBHeightComplete() uint32 + func (s *State) GetDBState(height uint32) *DBState + func (s *State) GetDBStatesSent() []*interfaces.DBStateSent + func (s *State) GetDelay() int64 + func (s *State) GetDirectoryBlock() interfaces.IDirectoryBlock + func (s *State) GetDirectoryBlockByHeight(height uint32) interfaces.IDirectoryBlock + func (s *State) GetDirectoryBlockInSeconds() int + func (s *State) GetDropRate() int + func (s *State) GetE(rt bool, adr [32]byte) (v int64) + func (s *State) GetEBlockKeyMRFromEntryHash(entryHash interfaces.IHash) (rval interfaces.IHash) + func (s *State) GetElections() interfaces.IElections + func (s *State) GetEntryBlockDBHeightComplete() uint32 + func (s *State) GetEntryBlockDBHeightProcessing() uint32 + func (s *State) GetEntryCommitAckByEntryHash(hash interfaces.IHash) (status int, commit interfaces.IMsg) + func (s *State) GetEntryCommitAckByTXID(hash interfaces.IHash) (status int, blktime interfaces.Timestamp, commit interfaces.IMsg, ...) + func (s *State) GetEntryRevealAckByEntryHash(hash interfaces.IHash) (status int, blktime interfaces.Timestamp, commit interfaces.IMsg) + func (s *State) GetEventService() events.EventService + func (s *State) GetF(rt bool, adr [32]byte) (v int64) + func (s *State) GetFactoidState() interfaces.IFactoidState + func (s *State) GetFactomNodeName() string + func (s *State) GetFactomdLocations() string + func (s *State) GetFactomdVersion() string + func (s *State) GetFactoshisPerEC() uint64 + func (s *State) GetFaultTimeout() int + func (s *State) GetFaultWait() int + func (s *State) GetFedServers(dbheight uint32) []interfaces.IServer + func (s *State) GetHighestAck() uint32 + func (s *State) GetHighestCompletedBlk() uint32 + func (s *State) GetHighestKnownBlock() uint32 + func (s *State) GetHighestLockedSignedAndSavesBlk() uint32 + func (s *State) GetHighestSavedBlk() uint32 + func (s *State) GetIdentityChainID() (rval interfaces.IHash) + func (s *State) GetIgnoreDone() bool + func (s *State) GetInputRegEx() (*regexp.Regexp, string) + func (s *State) GetInvalidMsg(hash interfaces.IHash) interfaces.IMsg + func (s *State) GetJournalMessages() [][]byte + func (s *State) GetLLeaderHeight() uint32 + func (s *State) GetLastStatus() string + func (s *State) GetLeaderHeight() uint32 + func (s *State) GetLeaderPL() interfaces.IProcessList + func (s *State) GetLeaderTimestamp() interfaces.Timestamp + func (s *State) GetLeaderVM() int + func (s *State) GetMatryoshka(dbheight uint32) (rval interfaces.IHash) + func (s *State) GetMessageFilterTimestamp() interfaces.Timestamp + func (s *State) GetMessageTalliesReceived(i int) int + func (s *State) GetMessageTalliesSent(i int) int + func (s *State) GetMinuteDuration() time.Duration + func (s *State) GetMissingDBState(height uint32) error + func (s *State) GetMissingEntryCount() uint32 + func (s *State) GetMsg(vmIndex int, dbheight int, height int) (interfaces.IMsg, error) + func (s *State) GetNetStateOff() bool + func (s *State) GetNetworkBootStrapIdentity() (rval interfaces.IHash) + func (s *State) GetNetworkBootStrapKey() (rval interfaces.IHash) + func (s *State) GetNetworkID() uint32 + func (s *State) GetNetworkIdentityRegistrationChain() (rval interfaces.IHash) + func (s *State) GetNetworkName() string + func (s *State) GetNetworkNumber() int + func (s *State) GetNetworkSkeletonIdentity() (rval interfaces.IHash) + func (s *State) GetNewEBlocks(dbheight uint32, hash interfaces.IHash) interfaces.IEntryBlock + func (s *State) GetNewHash() (rval interfaces.IHash) + func (s *State) GetOnlineAuditServers(dbheight uint32) []interfaces.IServer + func (s *State) GetOut() bool + func (s *State) GetOutputRegEx() (*regexp.Regexp, string) + func (s *State) GetPendingEntries(params interface{}) []interfaces.IPendingEntry + func (s *State) GetPendingTransactions(params string) []interfaces.IPendingTransaction + func (s *State) GetPort() int + func (s *State) GetPreviousMinuteStartTime() int64 + func (s *State) GetRpcAuthHash() []byte + func (s *State) GetRpcPass() string + func (s *State) GetRpcUser() string + func (s *State) GetRunState() runstate.RunState + func (s *State) GetSalt(ts interfaces.Timestamp) uint32 + func (s *State) GetServerPrivateKey() *primitives.PrivateKey + func (s *State) GetServerPublicKey() *primitives.PublicKey + func (s *State) GetServerPublicKeyString() string + func (s *State) GetSpecificACKStatus(hash interfaces.IHash) (int, interfaces.IHash, interfaces.Timestamp, interfaces.Timestamp, error) + func (s *State) GetStatus() []string + func (s *State) GetSystemHeight(dbheight uint32) int + func (s *State) GetSystemMsg(dbheight uint32, height uint32) interfaces.IMsg + func (s *State) GetTimeOffset() interfaces.Timestamp + func (s *State) GetTimestamp() interfaces.Timestamp + func (s *State) GetTlsInfo() (bool, string, string) + func (s *State) GetTrueLeaderHeight() uint32 + func (s *State) GetUnsyncedServers() (ids []interfaces.IHash, vms []int) + func (s *State) GetUnsyncedServersString() string + func (s *State) GetVirtualServers(dbheight uint32, minute int, identityChainID interfaces.IHash) (bool, int) + func (s *State) GotHeartbeat(heartbeatTS interfaces.Timestamp, dbheight uint32) + func (s *State) HoldForHeight(ht uint32, minute int, msg interfaces.IMsg) int + func (s *State) HookLogstash() error + func (s *State) InMsgQueue() interfaces.IQueue + func (s *State) InMsgQueue2() interfaces.IQueue + func (s *State) IncDBStateAnswerCnt() + func (s *State) IncECCommits() + func (s *State) IncECommits() + func (s *State) IncEntries() + func (s *State) IncEntryChains() + func (s *State) IncFCTSubmits() + func (s *State) IncFactoidTrans() + func (s *State) Init() + func (s *State) InitBoltDB() error + func (s *State) InitLevelDB() error + func (s *State) InitMapDB() error + func (s *State) IsActive(id activations.ActivationType) bool + func (s *State) IsHighestCommit(hash interfaces.IHash, msg interfaces.IMsg) bool + func (s *State) IsLeader() bool + func (s *State) IsNewOrPendingEBlocks(dbheight uint32, hash interfaces.IHash) bool + func (s *State) IsRunLeader() bool + func (s *State) IsStalled() bool + func (s *State) IsStateFullySynced() bool + func (s *State) IsSyncing() bool + func (s *State) IsSyncingDBSigs() bool + func (s *State) IsSyncingEOMs() bool + func (s *State) JournalMessage(msg interfaces.IMsg) + func (s *State) LeaderExecute(m interfaces.IMsg) + func (s *State) LeaderExecuteCommitChain(m interfaces.IMsg) + func (s *State) LeaderExecuteCommitEntry(m interfaces.IMsg) + func (s *State) LeaderExecuteDBSig(m interfaces.IMsg) + func (s *State) LeaderExecuteEOM(m interfaces.IMsg) + func (s *State) LeaderExecuteRevealEntry(m interfaces.IMsg) + func (s *State) LoadAcksMap() map[[32]byte]interfaces.IMsg + func (s *State) LoadConfig(filename string, networkFlag string) + func (s *State) LoadDBState(dbheight uint32) (interfaces.IMsg, error) + func (s *State) LoadDataByHash(requestedHash interfaces.IHash) (interfaces.BinaryMarshallable, int, error) + func (s *State) LoadHoldingMap() map[[32]byte]interfaces.IMsg + func (s *State) LoadSpecificMsg(dbheight uint32, vm int, plistheight uint32) (interfaces.IMsg, error) + func (s *State) LoadSpecificMsgAndAck(dbheight uint32, vmIndex int, plistheight uint32) (interfaces.IMsg, interfaces.IMsg, error) + func (s *State) Log(level string, message string) + func (s *State) LogMessage(logName string, comment string, msg interfaces.IMsg) + func (s *State) LogPrintf(logName string, format string, more ...interface{}) + func (s *State) Logf(level string, format string, args ...interface{}) + func (s *State) MMRDummy() + func (s *State) MoveStateToHeight(dbheight uint32, newMinute int) + func (s *State) MsgQueue() chan interfaces.IMsg + func (s *State) Needed(eb interfaces.IEntryBlock) bool + func (s *State) NetworkInvalidMsgQueue() chan interfaces.IMsg + func (s *State) NetworkOutMsgQueue() interfaces.IQueue + func (s *State) NewAck(msg interfaces.IMsg, balanceHash interfaces.IHash) interfaces.IMsg + func (s *State) NextCommit(hash interfaces.IHash) interfaces.IMsg + func (s *State) NoEntryYet(entryhash interfaces.IHash, ts interfaces.Timestamp) bool + func (s *State) PassInputRegEx(RegEx *regexp.Regexp, RegExString string) + func (s *State) PassOutputRegEx(RegEx *regexp.Regexp, RegExString string) + func (s *State) Print(a ...interface{}) (n int, err error) + func (s *State) Println(a ...interface{}) (n int, err error) + func (s *State) PrioritizedMsgQueue() chan interfaces.IMsg + func (s *State) Process() (progress bool) + func (s *State) ProcessAddServer(dbheight uint32, addServerMsg interfaces.IMsg) bool + func (s *State) ProcessChangeServerKey(dbheight uint32, changeServerKeyMsg interfaces.IMsg) bool + func (s *State) ProcessCommitChain(dbheight uint32, commitChain interfaces.IMsg) bool + func (s *State) ProcessCommitEntry(dbheight uint32, commitEntry interfaces.IMsg) bool + func (s *State) ProcessDBSig(dbheight uint32, msg interfaces.IMsg) bool + func (s *State) ProcessEOM(dbheight uint32, msg interfaces.IMsg) bool + func (s *State) ProcessInvalidMsgQueue() + func (s *State) ProcessRemoveServer(dbheight uint32, removeServerMsg interfaces.IMsg) bool + func (s *State) ProcessRevealEntry(dbheight uint32, m interfaces.IMsg) (worked bool) + func (s *State) PutCommit(hash interfaces.IHash, msg interfaces.IMsg) + func (s *State) PutE(rt bool, adr [32]byte, v int64) + func (s *State) PutF(rt bool, adr [32]byte, v int64) + func (s *State) PutNewEBlocks(dbheight uint32, hash interfaces.IHash, eb interfaces.IEntryBlock) + func (s *State) PutNewEntries(dbheight uint32, hash interfaces.IHash, e interfaces.IEntry) + func (s *State) ReadCfg(filename string) interfaces.IFactomConfig + func (s *State) RemoveAuditServer(dbheight uint32, hash interfaces.IHash) + func (s *State) RemoveFedServer(dbheight uint32, hash interfaces.IHash) + func (s *State) RepairAuthorities() + func (s *State) Reset() + func (s *State) ReviewHolding() + func (s *State) RunUploadController() + func (s *State) SendDBSig(dbheight uint32, vmIndex int) + func (s *State) SendHeartBeat() + func (s *State) SetAuthoritySetString(authSet string) + func (s *State) SetDBStateManagerCompletedHeight(height uint32) error + func (s *State) SetDBStatesSent(sents []*interfaces.DBStateSent) + func (s *State) SetDelay(delay int64) + func (s *State) SetDirectoryBlockInSeconds(t int) + func (s *State) SetDropRate(droprate int) + func (s *State) SetEntryBlockDBHeightComplete(newHeight uint32) + func (s *State) SetEntryBlockDBHeightProcessing(newHeight uint32) + func (s *State) SetFactoidState(dbheight uint32, fs interfaces.IFactoidState) + func (s *State) SetFactoshisPerEC(factoshisPerEC uint64) + func (s *State) SetFaultTimeout(timeout int) + func (s *State) SetFaultWait(wait int) + func (s *State) SetHighestAck(dbht uint32) + func (s *State) SetHighestKnownBlock(dbht uint32) + func (s *State) SetIdentityChainID(chainID interfaces.IHash) + func (s *State) SetIsDoneReplaying() + func (s *State) SetIsReplaying() + func (s *State) SetLeaderTimestamp(ts interfaces.Timestamp) + func (s *State) SetMessageFilterTimestamp(requestedTS interfaces.Timestamp) + func (s *State) SetNetStateOff(net bool) + func (s *State) SetOut(o bool) + func (s *State) SetPendingSigningKey(p *primitives.PrivateKey) + func (s *State) SetPort(port int) + func (s *State) SetRpcAuthHash(authHash []byte) + func (s *State) SetString() + func (s *State) SetStringConsensus() + func (s *State) SetStringQueues() + func (s *State) SetTorrentUploader(setVal bool) + func (s *State) SetUseTorrent(setVal bool) + func (s *State) SetupCrossBootReplay(path string) + func (s *State) ShortString() string + func (s *State) ShutdownNode(exitCode int) + func (s *State) Sign(b []byte) interfaces.IFullSignature + func (s *State) SimGetSigKey() string + func (s *State) SimSetNewKeys(p *primitives.PrivateKey) + func (s *State) StartMMR() + func (s *State) StartTorrentSyncing() error + func (s *State) String() string + func (s *State) SummaryHeader() string + func (s *State) TallyReceived(msgType int) + func (s *State) TallySent(msgType int) + func (s *State) TickerQueue() chan int + func (s *State) TimerMsgQueue() chan interfaces.IMsg + func (s *State) TorrentUploader() bool + func (s *State) TrimVMList(dbheight uint32, height uint32, vmIndex int) + func (s *State) UpdateECs(ec interfaces.IEntryCreditBlock) + func (s *State) UpdateState() (progress bool) + func (s *State) UploadDBState(dbheight uint32) + func (s *State) UsingTorrent() bool + func (s *State) Validate(msg interfaces.IMsg) (validToSend int, validToExec int) + func (s *State) ValidatePrevious(dbheight uint32) error + func (s *State) ValidatorLoop() + func (s *State) WriteEntries() + func (st *State) AddIdentityEblocks(cid interfaces.IHash, rootChain bool) error + func (st *State) AddIdentityFromChainID(cid interfaces.IHash) error + func (st *State) AddNewIdentityEblocks(eblocks []interfaces.IEntryBlock, dblockTimestamp interfaces.Timestamp) + func (st *State) FastVerifyAuthoritySignature(msg []byte, sig interfaces.IFullSignature, dbheight uint32) (int, error) + func (st *State) GetAuthority(serverID interfaces.IHash) (*Authority, int) + func (st *State) GetAuthorityServerType(chainID interfaces.IHash) int + func (st *State) GetNetworkSkeletonKey() (rval interfaces.IHash) + func (st *State) GetSigningKey(id interfaces.IHash) (interfaces.IHash, int) + func (st *State) InitiateNetworkIdentityRegistration() error + func (st *State) IntiateNetworkSkeletonIdentity() error + func (st *State) LoadIdentityByEntry(ent interfaces.IEBEntry, height uint32, dblockTimestamp interfaces.Timestamp, ...) + func (st *State) LookupIdentityInBlockchainByChainID(cid interfaces.IHash) error + func (st *State) SyncIdentities(d *DBState) + func (st *State) UpdateAuthSigningKeys(height uint32) + func (st *State) UpdateAuthorityFromABEntry(entry interfaces.IABEntry) error + func (st *State) VerifyAuthoritySignature(msg []byte, sig *[constants.SIGNATURE_LENGTH]byte, dbheight uint32) (rval int, err error) + func (st *State) VerifyIsAuthority(cid interfaces.IHash) bool + func (this *State) ExchangeRateAuthorityIsValid(e interfaces.IEBEntry) bool + func (this *State) FerEntryIsValid(passedFEREntry interfaces.IFEREntry) bool + func (this *State) GetPredictiveFER() uint64 + func (this *State) ProcessRecentFERChainEntries() + type StateSaverStruct struct + FastBoot bool + FastBootLocation string + Mutex sync.Mutex + Stop bool + TmpDBHt uint32 + TmpState []byte + func (sss *StateSaverStruct) DeleteSaveState(networkName string) error + func (sss *StateSaverStruct) LoadDBStateList(s *State, statelist *DBStateList, networkName string) error + func (sss *StateSaverStruct) SaveDBStateList(s *State, ss *DBStateList, networkName string) error + func (sss *StateSaverStruct) StopSaving() + type StatesMissing struct + List *list.List + func NewStatesMissing() *StatesMissing + func (l *StatesMissing) Add(height uint32) + func (l *StatesMissing) DeleteLockless(height uint32) + func (l *StatesMissing) Get(height uint32) *MissingState + func (l *StatesMissing) GetFront() *MissingState + func (l *StatesMissing) GetNext() *MissingState + func (l *StatesMissing) Len() int + func (l *StatesMissing) LockAndDelete(height uint32) + func (l *StatesMissing) NextConsecutiveMissing(n int) (uint32, uint32) + type StatesReceived struct + List *list.List + Notify chan *messages.DBStateMsg + func NewStatesReceived() *StatesReceived + func (l *StatesReceived) Add(height uint32, msg *messages.DBStateMsg) + func (l *StatesReceived) Base() uint32 + func (l *StatesReceived) Get(height uint32) *ReceivedState + func (l *StatesReceived) GetNext() *ReceivedState + func (l *StatesReceived) Has(height uint32) bool + func (l *StatesReceived) Heighestreceived() uint32 + func (l *StatesReceived) ListAsSlice() []uint32 + func (l *StatesReceived) LockAndDelete(height uint32) + func (l *StatesReceived) SetBase(height uint32) + func (l *StatesReceived) SetBaseLockless(height uint32) + type StatesWaiting struct + List *list.List + func NewStatesWaiting() *StatesWaiting + func (l *StatesWaiting) Add(height uint32) + func (l *StatesWaiting) Get(height uint32) *WaitingState + func (l *StatesWaiting) GetEnd() *WaitingState + func (l *StatesWaiting) Has(height uint32) bool + func (l *StatesWaiting) Len() int + func (l *StatesWaiting) ListAsSlice() []*WaitingState + func (l *StatesWaiting) LockAndDelete(height uint32) + type UploadController struct + DBStateManager interfaces.IManagerController + func NewUploadController(dbsm interfaces.IManagerController) *UploadController + func (u *UploadController) Close() + type VM struct + EomMinuteIssued int + FaultFlag int + Height int + HighestNil int + LeaderMinute int + List []interfaces.IMsg + ListAck []*messages.Ack + ProcessTime interfaces.Timestamp + Signed bool + Synced bool + VmIndex int + WhenFaulted int64 + func (vm *VM) ReportMissing(height int, delay int64) + type WaitingState struct + func NewWaitingState(height uint32) *WaitingState + func (s *WaitingState) Height() uint32 + func (s *WaitingState) RequestAge() time.Duration + func (s *WaitingState) ResetRequestAge() + type WholeBlock struct + ABlock interfaces.IAdminBlock + DBlock interfaces.IDirectoryBlock + EBlocks []interfaces.IEntryBlock + ECBlock interfaces.IEntryCreditBlock + Entries []interfaces.IEBEntry + FBlock interfaces.IFBlock + SigList []interfaces.IFullSignature + func NewWholeBlock() *WholeBlock + func ReadDBStateFromDebugFile(filename string) (*WholeBlock, error) + func (a *WholeBlock) IsSameAs(b *WholeBlock) (resp bool) + func (wb *WholeBlock) AddEblock(eb interfaces.IEntryBlock) + func (wb *WholeBlock) AddEntry(e interfaces.IEntry) + func (wb *WholeBlock) AddIEBEntry(e interfaces.IEBEntry) + func (wb *WholeBlock) BlockToDBStateMsg() interfaces.IMsg + func (wb *WholeBlock) MarshalBinary() (b []byte, err error) + func (wb *WholeBlock) UnmarshalBinary(data []byte) (err error) + func (wb *WholeBlock) UnmarshalBinaryData(data []byte) (newData []byte, err error) + func (wb *WholeBlock) UnmarshalBinaryDataBuffer(buffer io.ReadSeeker, whence int) (read int64, err error) Incompatible versions in this module v6.11.0+incompatible Nov 14, 2020 v6.5.2+incompatible Feb 5, 2020 v6.4.2-rc2+incompatible Sep 18, 2019 v6.3.2+incompatible Jun 9, 2019