本文整理匯總了Golang中github.com/FactomProject/factomd/common/interfaces.IMsg類的典型用法代碼示例。如果您正苦於以下問題:Golang IMsg類的具體用法?Golang IMsg怎麽用?Golang IMsg使用的例子?那麽, 這裏精選的類代碼示例或許可以為您提供幫助。
在下文中一共展示了IMsg類的15個代碼示例,這些例子默認根據受歡迎程度排序。您可以為喜歡或者感覺有用的代碼點讚,您的評價將有助於係統推薦出更棒的Golang代碼示例。
示例1: UnmarshalMessage
func UnmarshalMessage(data []byte) (interfaces.IMsg, error) {
if data == nil {
return nil, fmt.Errorf("No data provided")
}
if len(data) == 0 {
return nil, fmt.Errorf("No data provided")
}
messageType := int(data[0])
var msg interfaces.IMsg
switch messageType {
case constants.EOM_MSG:
msg = new(EOM)
case constants.ACK_MSG:
msg = new(Ack)
case constants.AUDIT_SERVER_FAULT_MSG:
msg = new(AuditServerFault)
case constants.COMMIT_CHAIN_MSG:
msg = new(CommitChainMsg)
case constants.COMMIT_ENTRY_MSG:
msg = new(CommitEntryMsg)
case constants.DIRECTORY_BLOCK_SIGNATURE_MSG:
msg = NewDirectoryBlockSignature()
case constants.EOM_TIMEOUT_MSG:
msg = new(EOMTimeout)
case constants.FACTOID_TRANSACTION_MSG:
msg = new(FactoidTransaction)
case constants.HEARTBEAT_MSG:
msg = new(Heartbeat)
case constants.INVALID_ACK_MSG:
msg = new(InvalidAck)
case constants.INVALID_DIRECTORY_BLOCK_MSG:
msg = new(InvalidDirectoryBlock)
case constants.MISSING_ACK_MSG:
msg = new(MissingAck)
case constants.PROMOTION_DEMOTION_MSG:
msg = new(PromotionDemotion)
case constants.REVEAL_ENTRY_MSG:
msg = new(RevealEntryMsg)
case constants.REQUEST_BLOCK_MSG:
msg = new(RequestBlock)
case constants.SIGNATURE_TIMEOUT_MSG:
msg = new(SignatureTimeout)
default:
return nil, fmt.Errorf("Unknown message type")
}
// Unmarshal does not include the message type.
err := msg.UnmarshalBinary(data[:])
if err != nil {
return nil, err
}
return msg, nil
}
示例2: logMessage
func (p *P2PProxy) logMessage(msg interfaces.IMsg, received bool) {
if 2 < p.debugMode {
// if constants.DBSTATE_MSG == msg.Type() {
// fmt.Printf("AppMsgLogging: \n Type: %s \n Network Origin: %s \n Message: %s", msg.Type(), msg.GetNetworkOrigin(), msg.String())
// }
hash := fmt.Sprintf("%x", msg.GetMsgHash().Bytes())
time := time.Now().Unix()
ml := messageLog{hash: hash, received: received, time: time, mtype: msg.Type(), target: msg.GetNetworkOrigin()}
p2p.BlockFreeChannelSend(p.logging, ml)
}
}
示例3: LeaderExecuteEOM
func (s *State) LeaderExecuteEOM(m interfaces.IMsg) {
if !m.IsLocal() {
s.FollowerExecuteEOM(m)
return
}
// The zero based minute for the message is equal to
// the one based "LastMinute". This way we know we are
// generating minutes in order.
eom := m.(*messages.EOM)
pl := s.ProcessLists.Get(s.LLeaderHeight)
vm := pl.VMs[s.LeaderVMIndex]
// Put the System Height and Serial Hash into the EOM
eom.SysHeight = uint32(pl.System.Height)
if pl.System.Height > 1 {
ff, ok := pl.System.List[pl.System.Height-1].(*messages.FullServerFault)
if ok {
eom.SysHash = ff.GetSerialHash()
}
}
if s.Syncing && vm.Synced {
return
} else if !s.Syncing {
s.Syncing = true
s.EOM = true
s.EOMsyncing = true
s.EOMProcessed = 0
for _, vm := range pl.VMs {
vm.Synced = false
}
s.EOMLimit = len(pl.FedServers)
s.EOMMinute = int(s.CurrentMinute)
}
//_, vmindex := pl.GetVirtualServers(s.EOMMinute, s.IdentityChainID)
eom.DBHeight = s.LLeaderHeight
eom.VMIndex = s.LeaderVMIndex
// eom.Minute is zerobased, while LeaderMinute is 1 based. So
// a simple assignment works.
eom.Minute = byte(s.CurrentMinute)
eom.Sign(s)
eom.MsgHash = nil
ack := s.NewAck(m)
s.Acks[eom.GetMsgHash().Fixed()] = ack
m.SetLocal(false)
s.FollowerExecuteEOM(m)
s.UpdateState()
}
示例4: Send
func (f *SimPeer) Send(msg interfaces.IMsg) error {
data, err := msg.MarshalBinary()
f.bytesOut += len(data)
f.computeBandwidth()
if err != nil {
fmt.Println("ERROR on Send: ", err)
return err
}
if len(f.BroadcastOut) < 9000 {
packet := SimPacket{data, time.Now().UnixNano() / 1000000}
f.BroadcastOut <- &packet
}
return nil
}
示例5: AddToSystemList
func (p *ProcessList) AddToSystemList(m interfaces.IMsg) bool {
// Make sure we have a list, and punt if we don't.
if p == nil {
p.State.Holding[m.GetRepeatHash().Fixed()] = m
return false
}
fullFault, ok := m.(*messages.FullServerFault)
if !ok {
return false // Should never happen; Don't pass junk to be added to the System List
}
// If we have already processed past this fault, just ignore.
if p.System.Height > int(fullFault.SystemHeight) {
return false
}
// If the fault is in the future, hold it.
if p.System.Height < int(fullFault.SystemHeight) {
p.State.Holding[m.GetRepeatHash().Fixed()] = m
return false
}
for len(p.System.List) > 0 && p.System.List[len(p.System.List)-1] == nil {
p.System.List = p.System.List[:len(p.System.List)-1]
}
// If we are here, fullFault.SystemHeight == p.System.Height
if len(p.System.List) <= p.System.Height {
// Nothing in our list a this slot yet, so insert this FullFault message
p.System.List = append(p.System.List, fullFault)
return true
}
// Something is in our SystemList at this height;
// We will prioritize the FullFault with the highest VMIndex
existingSystemFault, _ := p.System.List[p.System.Height].(*messages.FullServerFault)
if int(existingSystemFault.VMIndex) >= int(fullFault.VMIndex) {
return false
}
p.System.List[p.System.Height] = fullFault
return true
}
示例6: FollowerExecuteMsg
// Messages that will go into the Process List must match an Acknowledgement.
// The code for this is the same for all such messages, so we put it here.
//
// Returns true if it finds a match, puts the message in holding, or invalidates the message
func (s *State) FollowerExecuteMsg(m interfaces.IMsg) {
s.Holding[m.GetMsgHash().Fixed()] = m
ack, _ := s.Acks[m.GetMsgHash().Fixed()].(*messages.Ack)
if ack != nil {
m.SetLeaderChainID(ack.GetLeaderChainID())
m.SetMinute(ack.Minute)
pl := s.ProcessLists.Get(ack.DBHeight)
pl.AddToProcessList(ack, m)
}
}
示例7: NewAck
// Create a new Acknowledgement. Must be called by a leader. This
// call assumes all the pieces are in place to create a new acknowledgement
func (s *State) NewAck(msg interfaces.IMsg) interfaces.IMsg {
vmIndex := msg.GetVMIndex()
msg.SetLeaderChainID(s.IdentityChainID)
ack := new(messages.Ack)
ack.DBHeight = s.LLeaderHeight
ack.VMIndex = vmIndex
ack.Minute = byte(s.ProcessLists.Get(s.LLeaderHeight).VMs[vmIndex].LeaderMinute)
ack.Timestamp = s.GetTimestamp()
ack.SaltNumber = s.GetSalt(ack.Timestamp)
copy(ack.Salt[:8], s.Salt.Bytes()[:8])
ack.MessageHash = msg.GetMsgHash()
ack.LeaderChainID = s.IdentityChainID
listlen := len(s.LeaderPL.VMs[vmIndex].List)
if listlen == 0 {
ack.Height = 0
ack.SerialHash = ack.MessageHash
} else {
last := s.LeaderPL.GetAckAt(vmIndex, listlen-1)
ack.Height = last.Height + 1
ack.SerialHash, _ = primitives.CreateHash(last.MessageHash, ack.MessageHash)
}
ack.Sign(s)
return ack
}
示例8: FollowerExecuteRevealEntry
func (s *State) FollowerExecuteRevealEntry(m interfaces.IMsg) {
s.Holding[m.GetMsgHash().Fixed()] = m
ack, _ := s.Acks[m.GetMsgHash().Fixed()].(*messages.Ack)
if ack != nil {
m.SetLeaderChainID(ack.GetLeaderChainID())
m.SetMinute(ack.Minute)
pl := s.ProcessLists.Get(ack.DBHeight)
pl.AddToProcessList(ack, m)
// If we added the ack, then it will be cleared from the ack map.
if s.Acks[m.GetMsgHash().Fixed()] == nil {
msg := m.(*messages.RevealEntryMsg)
delete(s.Commits, msg.Entry.GetHash().Fixed())
// Okay the Reveal has been recorded. Record this as an entry that cannot be duplicated.
s.Replay.IsTSValid_(constants.REVEAL_REPLAY, msg.Entry.GetHash().Fixed(), msg.Timestamp, s.GetTimestamp())
}
}
}
示例9: FollowerExecuteEOM
// Messages that will go into the Process List must match an Acknowledgement.
// The code for this is the same for all such messages, so we put it here.
//
// Returns true if it finds a match, puts the message in holding, or invalidates the message
func (s *State) FollowerExecuteEOM(m interfaces.IMsg) {
if m.IsLocal() {
return // This is an internal EOM message. We are not a leader so ignore.
}
s.Holding[m.GetMsgHash().Fixed()] = m
ack, _ := s.Acks[m.GetMsgHash().Fixed()].(*messages.Ack)
if ack != nil {
pl := s.ProcessLists.Get(ack.DBHeight)
pl.AddToProcessList(ack, m)
}
}
示例10: MatchAckFollowerExecute
// Messages that match an acknowledgement, and are added to the process list
// all do the same thing. So that logic is here.
func (s *State) MatchAckFollowerExecute(m interfaces.IMsg) error {
acks := s.GetAcks()
ack, ok := acks[m.GetHash().Fixed()].(*messages.Ack)
if !ok || ack == nil {
s.GetHolding()[m.GetHash().Fixed()] = m
} else {
processlist := s.GetProcessList()[ack.ServerIndex]
for len(processlist) < ack.Height+1 {
processlist = append(processlist, nil)
}
processlist[ack.Height] = m
s.GetProcessList()[ack.ServerIndex] = processlist
delete(acks, m.GetHash().Fixed())
}
return nil
}
示例11: Peers
func Peers(fnode *FactomNode) {
cnt := 0
for {
for i := 0; i < 100 && len(fnode.State.APIQueue()) > 0; i++ {
select {
case msg := <-fnode.State.APIQueue():
if msg == nil {
break
}
repeatHash := msg.GetRepeatHash()
if repeatHash == nil {
fmt.Println("dddd ERROR!", msg.String())
break
}
cnt++
msg.SetOrigin(0)
if fnode.State.Replay.IsTSValid_(constants.NETWORK_REPLAY, repeatHash.Fixed(),
msg.GetTimestamp(),
fnode.State.GetTimestamp()) {
fnode.MLog.add2(fnode, false, fnode.State.FactomNodeName, "API", true, msg)
if len(fnode.State.InMsgQueue()) < 9000 {
fnode.State.InMsgQueue() <- msg
}
}
default:
}
}
// Put any broadcasts from our peers into our BroadcastIn queue
for i, peer := range fnode.Peers {
for j := 0; j < 100; j++ {
var msg interfaces.IMsg
var err error
if !fnode.State.GetNetStateOff() {
msg, err = peer.Recieve()
}
if msg == nil {
// Recieve is not blocking; nothing to do, we get a nil.
break
}
cnt++
if err != nil {
fmt.Println("ERROR recieving message on", fnode.State.FactomNodeName+":", err)
break
}
msg.SetOrigin(i + 1)
if fnode.State.Replay.IsTSValid_(constants.NETWORK_REPLAY, msg.GetRepeatHash().Fixed(),
msg.GetTimestamp(),
fnode.State.GetTimestamp()) {
//if state.GetOut() {
// fnode.State.Println("In Comming!! ",msg)
//}
in := "PeerIn"
if msg.IsPeer2Peer() {
in = "P2P In"
}
nme := fmt.Sprintf("%s %d", in, i+1)
fnode.MLog.add2(fnode, false, peer.GetNameTo(), nme, true, msg)
// Ignore messages if there are too many.
if len(fnode.State.InMsgQueue()) < 9000 {
fnode.State.InMsgQueue() <- msg
}
} else {
fnode.MLog.add2(fnode, false, peer.GetNameTo(), "PeerIn", false, msg)
}
}
}
if cnt == 0 {
time.Sleep(50 * time.Millisecond)
}
cnt = 0
}
}
示例12: LeaderExecuteRevealEntry
func (s *State) LeaderExecuteRevealEntry(m interfaces.IMsg) {
re := m.(*messages.RevealEntryMsg)
eh := re.Entry.GetHash()
commit, rtn := re.ValidateRTN(s)
switch rtn {
case 0:
m.FollowerExecute(s)
case -1:
return
}
now := s.GetTimestamp()
// If we have already recorded a Reveal Entry with this hash in this period, just ignore.
if _, v := s.Replay.Valid(constants.REVEAL_REPLAY, eh.Fixed(), s.GetLeaderTimestamp(), now); !v {
return
}
ack := s.NewAck(m).(*messages.Ack)
m.SetLeaderChainID(ack.GetLeaderChainID())
m.SetMinute(ack.Minute)
// Put the acknowledgement in the Acks so we can tell if AddToProcessList() adds it.
s.Acks[m.GetMsgHash().Fixed()] = ack
s.ProcessLists.Get(ack.DBHeight).AddToProcessList(ack, m)
// If it was added, then get rid of the matching Commit.
if s.Acks[m.GetMsgHash().Fixed()] != nil {
m.FollowerExecute(s)
s.PutCommit(eh, commit)
} else {
// Okay the Reveal has been recorded. Record this as an entry that cannot be duplicated.
s.Replay.IsTSValid_(constants.REVEAL_REPLAY, eh.Fixed(), m.GetTimestamp(), now)
delete(s.Commits, eh.Fixed())
}
}
示例13: AddToProcessList
func (p *ProcessList) AddToProcessList(ack *messages.Ack, m interfaces.IMsg) {
if p == nil {
return
}
// We don't check the SaltNumber if this isn't an actual message, i.e. a response from
// the past.
if !ack.Response && ack.LeaderChainID.IsSameAs(p.State.IdentityChainID) {
num := p.State.GetSalt(ack.Timestamp)
if num != ack.SaltNumber {
os.Stderr.WriteString(fmt.Sprintf("This ChainID %x\n", p.State.IdentityChainID.Bytes()))
os.Stderr.WriteString(fmt.Sprintf("This Salt %x\n", p.State.Salt.Bytes()[:8]))
os.Stderr.WriteString(fmt.Sprintf("This SaltNumber %x\n for this ack", num))
os.Stderr.WriteString(fmt.Sprintf("Ack ChainID %x\n", ack.LeaderChainID.Bytes()))
os.Stderr.WriteString(fmt.Sprintf("Ack Salt %x\n", ack.Salt))
os.Stderr.WriteString(fmt.Sprintf("Ack SaltNumber %x\n for this ack", ack.SaltNumber))
panic("There are two leaders configured with the same Identity in this network! This is a configuration problem!")
}
}
if _, ok := m.(*messages.MissingMsg); ok {
panic("This shouldn't happen")
}
toss := func(hint string) {
fmt.Println("dddd TOSS in Process List", p.State.FactomNodeName, hint)
fmt.Println("dddd TOSS in Process List", p.State.FactomNodeName, ack.String())
fmt.Println("dddd TOSS in Process List", p.State.FactomNodeName, m.String())
delete(p.State.Holding, ack.GetHash().Fixed())
delete(p.State.Acks, ack.GetHash().Fixed())
}
now := p.State.GetTimestamp()
vm := p.VMs[ack.VMIndex]
if len(vm.List) > int(ack.Height) && vm.List[ack.Height] != nil {
_, isNew2 := p.State.Replay.Valid(constants.INTERNAL_REPLAY, m.GetRepeatHash().Fixed(), m.GetTimestamp(), now)
if !isNew2 {
toss("seen before, or too old")
return
}
}
if ack.DBHeight != p.DBHeight {
panic(fmt.Sprintf("Ack is wrong height. Expected: %d Ack: %s", p.DBHeight, ack.String()))
return
}
if len(vm.List) > int(ack.Height) && vm.List[ack.Height] != nil {
if vm.List[ack.Height].GetMsgHash().IsSameAs(m.GetMsgHash()) {
fmt.Printf("dddd %-30s %10s %s\n", "xxxxxxxxx PL Duplicate ", p.State.GetFactomNodeName(), m.String())
fmt.Printf("dddd %-30s %10s %s\n", "xxxxxxxxx PL Duplicate ", p.State.GetFactomNodeName(), ack.String())
fmt.Printf("dddd %-30s %10s %s\n", "xxxxxxxxx PL Duplicate vm", p.State.GetFactomNodeName(), vm.List[ack.Height].String())
fmt.Printf("dddd %-30s %10s %s\n", "xxxxxxxxx PL Duplicate vm", p.State.GetFactomNodeName(), vm.ListAck[ack.Height].String())
toss("2")
return
}
vm.List[ack.Height] = nil
return
}
// From this point on, we consider the transaction recorded. If we detect it has already been
// recorded, then we still treat it as if we recorded it.
vm.heartBeat = 0 // We have heard from this VM
// We have already tested and found m to be a new message. We now record its hashes so later, we
// can detect that it has been recorded. We don't care about the results of IsTSValid_ at this point.
p.State.Replay.IsTSValid_(constants.INTERNAL_REPLAY, m.GetRepeatHash().Fixed(), m.GetTimestamp(), now)
p.State.Replay.IsTSValid_(constants.INTERNAL_REPLAY, m.GetMsgHash().Fixed(), m.GetTimestamp(), now)
delete(p.State.Acks, ack.GetHash().Fixed())
delete(p.State.Holding, m.GetMsgHash().Fixed())
// Both the ack and the message hash to the same GetHash()
m.SetLocal(false)
ack.SetLocal(false)
ack.SetPeer2Peer(false)
m.SetPeer2Peer(false)
ack.SendOut(p.State, ack)
m.SendOut(p.State, m)
for len(vm.List) <= int(ack.Height) {
vm.List = append(vm.List, nil)
vm.ListAck = append(vm.ListAck, nil)
}
p.VMs[ack.VMIndex].List[ack.Height] = m
p.VMs[ack.VMIndex].ListAck[ack.Height] = ack
p.AddOldMsgs(m)
p.OldAcks[m.GetMsgHash().Fixed()] = ack
}
示例14: LeaderExecute
func (s *State) LeaderExecute(m interfaces.IMsg) {
_, ok := s.Replay.Valid(constants.INTERNAL_REPLAY, m.GetRepeatHash().Fixed(), m.GetTimestamp(), s.GetTimestamp())
if !ok {
delete(s.Holding, m.GetRepeatHash().Fixed())
delete(s.Holding, m.GetMsgHash().Fixed())
return
}
ack := s.NewAck(m).(*messages.Ack)
m.SetLeaderChainID(ack.GetLeaderChainID())
m.SetMinute(ack.Minute)
s.ProcessLists.Get(ack.DBHeight).AddToProcessList(ack, m)
}
示例15: Send
func (f *P2PProxy) Send(msg interfaces.IMsg) error {
f.logMessage(msg, false) // NODE_TALK_FIX
data, err := msg.MarshalBinary()
if err != nil {
fmt.Println("ERROR on Send: ", err)
return err
}
hash := fmt.Sprintf("%x", msg.GetMsgHash().Bytes())
appType := fmt.Sprintf("%d", msg.Type())
message := factomMessage{message: data, peerHash: msg.GetNetworkOrigin(), appHash: hash, appType: appType}
switch {
case !msg.IsPeer2Peer():
message.peerHash = p2p.BroadcastFlag
f.trace(message.appHash, message.appType, "P2PProxy.Send() - BroadcastFlag", "a")
case msg.IsPeer2Peer() && 0 == len(message.peerHash): // directed, with no direction of who to send it to
message.peerHash = p2p.RandomPeerFlag
f.trace(message.appHash, message.appType, "P2PProxy.Send() - RandomPeerFlag", "a")
default:
f.trace(message.appHash, message.appType, "P2PProxy.Send() - Addressed by hash", "a")
}
if msg.IsPeer2Peer() && 1 < f.debugMode {
fmt.Printf("%s Sending directed to: %s message: %+v\n", time.Now().String(), message.peerHash, msg.String())
}
p2p.BlockFreeChannelSend(f.BroadcastOut, message)
return nil
}