package consensus
import (
"bytes"
"encoding/binary"
"time"
"github.com/ethereum/go-ethereum/common"
"github.com/ethereum/go-ethereum/rlp"
"github.com/harmony-one/harmony/consensus/quorum"
"github.com/harmony-one/harmony/core/types"
bls_core "github.com/harmony-one/bls/ffi/go/bls"
msg_pb "github.com/harmony-one/harmony/api/proto/message"
"github.com/harmony-one/harmony/crypto/bls"
bls_cosi "github.com/harmony-one/harmony/crypto/bls"
"github.com/harmony-one/harmony/internal/chain"
"github.com/harmony-one/harmony/internal/utils"
"github.com/harmony-one/harmony/multibls"
"github.com/pkg/errors"
"github.com/rs/zerolog"
)
const (
// ValidPayloadLength is the valid length for viewchange payload
ValidPayloadLength = 32 + bls . BLSSignatureSizeInBytes
)
// viewChange encapsulate all the view change related data structure and functions
type viewChange struct {
// Commits collected from view change
// for each viewID, we need keep track of corresponding sigs and bitmap
// until one of the viewID has enough votes (>=2f+1)
// after one of viewID has enough votes, we can reset and clean the map
// honest nodes will never double votes on different viewID
// bhpSigs: blockHashPreparedSigs is the signature on m1 type message
bhpSigs map [ uint64 ] map [ string ] * bls_core . Sign
// nilSigs: there is no prepared message when view change,
// it's signature on m2 type (i.e. nil) messages
nilSigs map [ uint64 ] map [ string ] * bls_core . Sign
viewIDSigs map [ uint64 ] map [ string ] * bls_core . Sign
bhpBitmap map [ uint64 ] * bls_cosi . Mask
nilBitmap map [ uint64 ] * bls_cosi . Mask
viewIDBitmap map [ uint64 ] * bls_cosi . Mask
newViewMsg map [ uint64 ] map [ string ] uint64
m1Payload [ ] byte // message payload for type m1 := |vcBlockHash|prepared_agg_sigs|prepared_bitmap|, new leader only need one
verifyBlock VerifyBlockFunc
viewChangeDuration time . Duration
}
// newViewChange returns a new viewChange object
func newViewChange ( ) * viewChange {
vc := viewChange { }
vc . Reset ( )
return & vc
}
// SetVerifyBlock ..
func ( vc * viewChange ) SetVerifyBlock ( verifyBlock VerifyBlockFunc ) {
vc . verifyBlock = verifyBlock
}
// AddViewIDKeyIfNotExist ..
func ( vc * viewChange ) AddViewIDKeyIfNotExist ( viewID uint64 , members multibls . PublicKeys ) {
if _ , ok := vc . bhpSigs [ viewID ] ; ! ok {
vc . bhpSigs [ viewID ] = map [ string ] * bls_core . Sign { }
}
if _ , ok := vc . nilSigs [ viewID ] ; ! ok {
vc . nilSigs [ viewID ] = map [ string ] * bls_core . Sign { }
}
if _ , ok := vc . viewIDSigs [ viewID ] ; ! ok {
vc . viewIDSigs [ viewID ] = map [ string ] * bls_core . Sign { }
}
if _ , ok := vc . bhpBitmap [ viewID ] ; ! ok {
bhpBitmap , _ := bls_cosi . NewMask ( members , nil )
vc . bhpBitmap [ viewID ] = bhpBitmap
}
if _ , ok := vc . nilBitmap [ viewID ] ; ! ok {
nilBitmap , _ := bls_cosi . NewMask ( members , nil )
vc . nilBitmap [ viewID ] = nilBitmap
}
if _ , ok := vc . viewIDBitmap [ viewID ] ; ! ok {
viewIDBitmap , _ := bls_cosi . NewMask ( members , nil )
vc . viewIDBitmap [ viewID ] = viewIDBitmap
}
}
Mainnet Release Candidate 2023.1.2 (#4376)
* remove default timeouts
* store the evm call timeout in rosetta object
* [cmd] actually apply ToRPCServerConfig
* Removed unused method.
* Rotate external leaders on non-beacon chains.
* Fix nil panic.
* Bump github.com/aws/aws-sdk-go from 1.33.0 to 1.34.0
Bumps [github.com/aws/aws-sdk-go](https://github.com/aws/aws-sdk-go) from 1.33.0 to 1.34.0.
- [Release notes](https://github.com/aws/aws-sdk-go/releases)
- [Changelog](https://github.com/aws/aws-sdk-go/blob/v1.34.0/CHANGELOG.md)
- [Commits](https://github.com/aws/aws-sdk-go/compare/v1.33.0...v1.34.0)
---
updated-dependencies:
- dependency-name: github.com/aws/aws-sdk-go
dependency-type: direct:production
...
Signed-off-by: dependabot[bot] <support@github.com>
* Bump github.com/ipld/go-ipld-prime from 0.9.0 to 0.19.0
Bumps [github.com/ipld/go-ipld-prime](https://github.com/ipld/go-ipld-prime) from 0.9.0 to 0.19.0.
- [Release notes](https://github.com/ipld/go-ipld-prime/releases)
- [Changelog](https://github.com/ipld/go-ipld-prime/blob/master/CHANGELOG.md)
- [Commits](https://github.com/ipld/go-ipld-prime/compare/v0.9.0...v0.19.0)
---
updated-dependencies:
- dependency-name: github.com/ipld/go-ipld-prime
dependency-type: indirect
...
Signed-off-by: dependabot[bot] <support@github.com>
* Bump golang.org/x/net from 0.3.0 to 0.7.0
Bumps [golang.org/x/net](https://github.com/golang/net) from 0.3.0 to 0.7.0.
- [Release notes](https://github.com/golang/net/releases)
- [Commits](https://github.com/golang/net/compare/v0.3.0...v0.7.0)
---
updated-dependencies:
- dependency-name: golang.org/x/net
dependency-type: indirect
...
Signed-off-by: dependabot[bot] <support@github.com>
* Small fixes.
* in progress.
* in progress.
* in progress.
* consensus check is forked
* update master
* fix leader
* check leader for N blocks
* fix
* fix
* Cleanup and fix update pub keys.
* Rotate leader.
* fix
fix
fix
fix
fix
* Cleaned.
* Cache for `GetLeaderPubKeyFromCoinbase`, removed `NthNextHmyExt`.
* activate epoch
* comment activation
* 295 epoch
* Fix failed tests.
* Fixed code review.
* Fix review "--port flag".
* Fix review comments.
* Returned locks in rotateLeader.
* Rebased onto dev.
* Commented golangci.
* staged stream sync v1.0
* fix protocol tests
* fix spell
* remove unused struct
* fix rosetta test
* add comments and refactor verify sig
* add comments, remove extra function
* add comment
* refactor errors, rename metrics
* refactor p2p host creation
* fix initsync and host creation
* fix short range hash chain
* fix beacon node detection for p2p protocol
* refactor stream peer cooldown and fix protocol beacon node field
* refactor p2p host and routing
* fix p2p discovery test issue
* add MaxAdvertiseWaitTime to handle advertisements interval and address stream connection issue
* terminal print the peer id and proto id
* fix boot complete message when node is shut down
* add new config option ( ForceReachabilityPublic ) to fix local-net consensus issue
* fix self query issue
* fix test NewDNSSyncingPeerProvider
* [testnet] disable leader rotation
* fix discovery issue for legacy sync
* add watermark low/high options for p2p connection manager
* add test for new conn manager flags
* fix dedent
* add comment to inform about p2p connection manager options
* fix max height issue
* add a separate log for get max height error
* fix log
* feat: triesInMemory flag
* fix: panic if TriesInMemory is 1 to 2
* in progress.
* consensus check is forked
* fix
* Cleanup and fix update pub keys.
* fix
fix
fix
fix
fix
* activate epoch
* EpochTBD for leader rotation epoch.
* 295 epoch
* Decider no longer requires public keys as a dependency. (#4289)
* Consensus doesn't require anymore `Node` as a circular dependency.
* Proper blockchain initialization.
* Rwlock consensus.
* Removed channels.
* Removed view change locks.
* Removed timers locks.
* Removed fbft locks.
* Removed multiSigMutex locks.
* Removed leader locks.
* Removed additional locks and isViewChange.
* Added locks detected by race.
* Added locks detected by race.
* Locks for start.
* Removed additional logs.
* Removed additional locks.
* Removed additional locks.
* Make func private.
* Make VerifyBlock private.
* Make IsLeader private.
* Make ParseFBFTMessage private.
* Fix remove locks.
* Added additional locks.
* Added additional locks.
* Added readSignatureBitmapPayload locks.
* Added HandleMessageUpdate locks.
* Added LastMile locks.
* Locks for IsValidatorInCommittee.
* Fixed locks.
* Fixed tests.
* Fixed tests.
* Fixed lock.
* Rebased over leader rotation.
* Fix formatting.
* Rebased onto dev.
* in progress.
* consensus check is forked
* update master
* fix leader
* check leader for N blocks
* fix
* fix
* Cleanup and fix update pub keys.
* Rotate leader.
* fix
fix
fix
fix
fix
* Cleaned.
* Cache for `GetLeaderPubKeyFromCoinbase`, removed `NthNextHmyExt`.
* comment activation
* 295 epoch
* Fix failed tests.
* Fixed code review.
* Fix review comments.
* Merged leader rotation.
* Rebased on dev.
* Rebased on dev.
* Fix usage of private methods.
* Fix usage of private methods.
* Fix usage of private methods.
* Removed deadcode, LockedFBFTPhase.
* Fix review comment.
* Fix review comment.
* Go mod tidy.
* Set to EpochTBD.
* Fix tests.
* [core] fix state handling of self destruct
If a contract self destructs to self and then receives funds within the
same transaction, it is possible for its stale state to be saved. This
change removes that possibility by checking for deleted state objects
before returning them.
* Fixed race error.
* rpc: add configurable http and `eth_call` timeout
* remove default timeouts
* store the evm call timeout in rosetta object
* [cmd] actually apply ToRPCServerConfig
* Removed unused method.
* Rotate external leaders on non-beacon chains.
* Fix nil panic.
* in progress.
* in progress.
* in progress.
* consensus check is forked
* update master
* fix leader
* check leader for N blocks
* fix
* fix
* Cleanup and fix update pub keys.
* Rotate leader.
* fix
fix
fix
fix
fix
* Cleaned.
* Cache for `GetLeaderPubKeyFromCoinbase`, removed `NthNextHmyExt`.
* Fixed code review.
* Fix review comments.
* Returned locks in rotateLeader.
* Rebased onto dev.
* staged stream sync v1.0
* refactor errors, rename metrics
* fix p2p discovery test issue
* add watermark low/high options for p2p connection manager
* fix dedent
* in progress.
* consensus check is forked
* fix
* Cleanup and fix update pub keys.
* fix
fix
fix
fix
fix
* activate epoch
* EpochTBD for leader rotation epoch.
* 295 epoch
* Decider no longer requires public keys as a dependency. (#4289)
* Consensus doesn't require anymore `Node` as a circular dependency.
* Proper blockchain initialization.
* Rwlock consensus.
* Removed channels.
* Removed view change locks.
* Removed multiSigMutex locks.
* Removed leader locks.
* Removed additional locks and isViewChange.
* Added locks detected by race.
* Added locks detected by race.
* Locks for start.
* Removed additional locks.
* Removed additional locks.
* Make func private.
* Make VerifyBlock private.
* Make IsLeader private.
* Make ParseFBFTMessage private.
* Fix remove locks.
* Added additional locks.
* Added additional locks.
* Added readSignatureBitmapPayload locks.
* Added HandleMessageUpdate locks.
* Added LastMile locks.
* Locks for IsValidatorInCommittee.
* Fixed locks.
* Fixed tests.
* Fixed lock.
* Rebased over leader rotation.
* in progress.
* consensus check is forked
* update master
* fix leader
* check leader for N blocks
* fix
* fix
* Cleanup and fix update pub keys.
* Rotate leader.
* fix
fix
fix
fix
fix
* Cleaned.
* Cache for `GetLeaderPubKeyFromCoinbase`, removed `NthNextHmyExt`.
* Fix failed tests.
* Fixed code review.
* Fix review comments.
* Merged leader rotation.
* Rebased on dev.
* Rebased on dev.
* Fix usage of private methods.
* Fix usage of private methods.
* Fix usage of private methods.
* Removed deadcode, LockedFBFTPhase.
* Fix review comment.
* Go mod tidy.
* remove default timeouts
* Rotate external leaders on non-beacon chains.
* Fix nil panic.
* Fixes.
* Update singleton.go
* evm: don't return extcode for validators
Due to technical debt, validator information is stored in the code field
of the address. The code field can be accessed in Solidity for an
arbitrary address using `extcodesize`, `extcodehash`, and `extcodecopy`
or helper commands (such as `address.code.Length`). The presence of this
field is used by contract developers to (erroneously) deny smart
contract access to other smart contracts (and therefore, validators).
This PR fixes that oversight by returning the same values as other EOAs
for known validator addresses. Obviously, it needs a hard fork that will
be scheduled separately.
* Fix context passing.
* Clean up code.
* Removed engine dependency.
* Fix possible panic.
* Clean up code.
* Network type.
* Fix tests.
* Revert "Removed engine dependency." (#4392)
* Revert "Fix tests."
This reverts commit 597ba2d6f1ed54ff599b9d9b8940c7285ab1277a.
* Revert "Network type."
This reverts commit 5e1878aedca3989dc0f34161dae1833e43ca6a76.
* Revert "Clean up code."
This reverts commit 15885f4c9b9263746827172b4f4f56d0926d18e2.
* Revert "Fix possible panic."
This reverts commit 1a70d5eb66cdbf8a23791806b71a323eed320085.
* Revert "Removed engine dependency."
This reverts commit 8c2ff803f709f944cfc8b1278f35cf5b2cacf859.
* gitignore the cache folder (#4389)
* stable localnet with external validator (#4388)
* stable localnet with external validator
* ignore deploy config file comments
* reduce node launched in localnet
* update makefile
* localnet configuration - add more fn
* fix validator information command typo
---------
Signed-off-by: dependabot[bot] <support@github.com>
Co-authored-by: MaxMustermann2 <82761650+MaxMustermann2@users.noreply.github.com>
Co-authored-by: frozen <355847+Frozen@users.noreply.github.com>
Co-authored-by: dependabot[bot] <49699333+dependabot[bot]@users.noreply.github.com>
Co-authored-by: “GheisMohammadi” <“Gheis.Mohammadi@gmail.com”>
Co-authored-by: “GheisMohammadi” <36589218+GheisMohammadi@users.noreply.github.com>
Co-authored-by: Sun Hyuk Ahn <sunhyukahn@Suns-MacBook-Pro.local>
Co-authored-by: Soph <35721420+sophoah@users.noreply.github.com>
2 years ago
// Reset resets the state for viewChange.
func ( vc * viewChange ) Reset ( ) {
vc . m1Payload = [ ] byte { }
vc . bhpSigs = map [ uint64 ] map [ string ] * bls_core . Sign { }
vc . nilSigs = map [ uint64 ] map [ string ] * bls_core . Sign { }
vc . viewIDSigs = map [ uint64 ] map [ string ] * bls_core . Sign { }
vc . bhpBitmap = map [ uint64 ] * bls_cosi . Mask { }
vc . nilBitmap = map [ uint64 ] * bls_cosi . Mask { }
vc . viewIDBitmap = map [ uint64 ] * bls_cosi . Mask { }
vc . newViewMsg = map [ uint64 ] map [ string ] uint64 { }
}
// GetPreparedBlock returns the prepared block or nil if not found
func ( vc * viewChange ) GetPreparedBlock ( fbftlog * FBFTLog ) ( [ ] byte , [ ] byte ) {
if vc . isM1PayloadEmpty ( ) {
return nil , nil
}
blockHash := [ 32 ] byte { }
// First 32 bytes of m1 payload is the correct block hash
copy ( blockHash [ : ] , vc . GetM1Payload ( ) )
if ! fbftlog . IsBlockVerified ( blockHash ) {
return nil , nil
}
if block := fbftlog . GetBlockByHash ( blockHash ) ; block != nil {
encodedBlock , err := rlp . EncodeToBytes ( block )
if err != nil || len ( encodedBlock ) == 0 {
return nil , nil
}
return vc . m1Payload , encodedBlock
}
return nil , nil
}
// GetM2Bitmap returns the nilBitmap as M2Bitmap
func ( vc * viewChange ) GetM2Bitmap ( viewID uint64 ) ( [ ] byte , [ ] byte ) {
sig2arr := [ ] * bls_core . Sign { }
for _ , sig := range vc . nilSigs [ viewID ] {
sig2arr = append ( sig2arr , sig )
}
if len ( sig2arr ) > 0 {
m2Sig := bls_cosi . AggregateSig ( sig2arr )
vc . getLogger ( ) . Info ( ) . Int ( "len" , len ( sig2arr ) ) . Msg ( "[GetM2Bitmap] M2 (NIL) type signatures" )
return m2Sig . Serialize ( ) , vc . nilBitmap [ viewID ] . Bitmap
}
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , viewID ) . Msg ( "[GetM2Bitmap] No M2 (NIL) type signatures" )
return nil , nil
}
// GetM3Bitmap returns the viewIDBitmap as M3Bitmap
func ( vc * viewChange ) GetM3Bitmap ( viewID uint64 ) ( [ ] byte , [ ] byte ) {
sig3arr := [ ] * bls_core . Sign { }
for _ , sig := range vc . viewIDSigs [ viewID ] {
sig3arr = append ( sig3arr , sig )
}
// even we check here for safty, m3 type signatures must >= 2f+1
if len ( sig3arr ) > 0 {
m3Sig := bls_cosi . AggregateSig ( sig3arr )
vc . getLogger ( ) . Info ( ) . Int ( "len" , len ( sig3arr ) ) . Msg ( "[GetM3Bitmap] M3 (ViewID) type signatures" )
return m3Sig . Serialize ( ) , vc . viewIDBitmap [ viewID ] . Bitmap
}
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , viewID ) . Msg ( "[GetM3Bitmap] No M3 (ViewID) type signatures" )
return nil , nil
}
// VerifyNewViewMsg returns true if the new view message is valid
func ( vc * viewChange ) VerifyNewViewMsg ( recvMsg * FBFTMessage ) ( * types . Block , error ) {
if recvMsg . M3AggSig == nil || recvMsg . M3Bitmap == nil {
return nil , errors . New ( "[VerifyNewViewMsg] M3AggSig or M3Bitmap is nil" )
}
senderKey := recvMsg . SenderPubkeys [ 0 ]
senderKeyStr := senderKey . Bytes . Hex ( )
// first time received the new view message
_ , ok := vc . newViewMsg [ recvMsg . ViewID ]
if ! ok {
newViewMap := map [ string ] uint64 { }
vc . newViewMsg [ recvMsg . ViewID ] = newViewMap
}
_ , ok = vc . newViewMsg [ recvMsg . ViewID ] [ senderKeyStr ]
if ok {
vc . getLogger ( ) . Warn ( ) .
Uint64 ( "MsgBlockNum" , recvMsg . BlockNum ) .
Uint64 ( "MyBlockNum" , vc . newViewMsg [ recvMsg . ViewID ] [ senderKeyStr ] ) .
Msg ( "[VerifyNewViewMsg] redundant NewView Message" )
}
vc . newViewMsg [ recvMsg . ViewID ] [ senderKeyStr ] = recvMsg . BlockNum
m3Sig := recvMsg . M3AggSig
m3Mask := recvMsg . M3Bitmap
viewIDBytes := make ( [ ] byte , 8 )
binary . LittleEndian . PutUint64 ( viewIDBytes , recvMsg . ViewID )
if ! m3Sig . VerifyHash ( m3Mask . AggregatePublic , viewIDBytes ) {
vc . getLogger ( ) . Warn ( ) .
Bytes ( "viewIDBytes" , viewIDBytes ) .
Interface ( "AggregatePublic" , m3Mask . AggregatePublic ) .
Msg ( "m3Sig.VerifyHash Failed" )
return nil , errors . New ( "[VerifyNewViewMsg] Unable to Verify Aggregated Signature of M3 (ViewID) payload" )
}
m2Mask := recvMsg . M2Bitmap
if recvMsg . M2AggSig != nil {
m2Sig := recvMsg . M2AggSig
if ! m2Sig . VerifyHash ( m2Mask . AggregatePublic , NIL ) {
vc . getLogger ( ) . Warn ( ) .
Bytes ( "NIL" , NIL ) .
Interface ( "AggregatePublic" , m2Mask . AggregatePublic ) .
Msg ( "m2Sig.VerifyHash Failed" )
return nil , errors . New ( "[VerifyNewViewMsg] Unable to Verify Aggregated Signature of M2 (NIL) payload" )
}
}
// check when M3 sigs > M2 sigs, then M1 (recvMsg.Payload) should not be empty
preparedBlock := & types . Block { }
if len ( recvMsg . Payload ) >= ValidPayloadLength && len ( recvMsg . Block ) != 0 {
if err := rlp . DecodeBytes ( recvMsg . Block , preparedBlock ) ; err != nil {
return nil , errors . New ( "[VerifyNewViewMsg] Unparseable prepared block data" )
}
blockHash := recvMsg . Payload [ : 32 ]
preparedBlockHash := preparedBlock . Hash ( )
if ! bytes . Equal ( preparedBlockHash [ : ] , blockHash ) {
return nil , errors . New ( "[VerifyNewViewMsg] Prepared block hash doesn't match msg block hash" )
}
if err := vc . verifyBlock ( preparedBlock ) ; err != nil {
return nil , err
}
return preparedBlock , nil
}
return nil , nil
}
var (
errDupM1 = errors . New ( "received M1 (prepared) message already" )
errDupM2 = errors . New ( "received M2 (NIL) message already" )
errDupM3 = errors . New ( "received M3 (ViewID) message already" )
errVerifyM1 = errors . New ( "failed to verfiy signature for M1 message" )
errVerifyM2 = errors . New ( "failed to verfiy signature for M2 message" )
errM1Payload = errors . New ( "failed to verify multi signature for M1 prepared payload" )
errNoQuorum = errors . New ( "no quorum on M1 (prepared) payload" )
errIncorrectSender = errors . New ( "multiple senders not allowed" )
)
// ProcessViewChangeMsg process the view change message after verification
func ( vc * viewChange ) ProcessViewChangeMsg (
fbftlog * FBFTLog ,
decider quorum . Decider ,
recvMsg * FBFTMessage ,
) error {
preparedBlock := & types . Block { }
if ! recvMsg . HasSingleSender ( ) {
return errIncorrectSender
}
senderKey := recvMsg . SenderPubkeys [ 0 ]
senderKeyStr := senderKey . Bytes . Hex ( )
// check and add viewID (m3 type) message signature
if _ , ok := vc . viewIDSigs [ recvMsg . ViewID ] [ senderKeyStr ] ; ok {
return errDupM3
}
if len ( recvMsg . Payload ) >= ValidPayloadLength && len ( recvMsg . Block ) != 0 {
if err := rlp . DecodeBytes ( recvMsg . Block , preparedBlock ) ; err != nil {
return err
}
if err := vc . verifyBlock ( preparedBlock ) ; err != nil {
return err
}
_ , ok := vc . bhpSigs [ recvMsg . ViewID ] [ senderKeyStr ]
if ok {
return errDupM1
}
if ! recvMsg . ViewchangeSig . VerifyHash ( senderKey . Object , recvMsg . Payload ) {
return errVerifyM1
}
blockHash := recvMsg . Payload [ : 32 ]
aggSig , mask , err := chain . ReadSignatureBitmapByPublicKeys ( recvMsg . Payload [ 32 : ] , decider . Participants ( ) )
if err != nil {
return err
}
if ! decider . IsQuorumAchievedByMask ( mask ) {
return errNoQuorum
}
if ! aggSig . VerifyHash ( mask . AggregatePublic , blockHash [ : ] ) {
return errM1Payload
}
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , recvMsg . ViewID ) .
Str ( "validatorPubKey" , senderKeyStr ) .
Msg ( "[ProcessViewChangeMsg] Add M1 (prepared) type message" )
if _ , ok := vc . bhpSigs [ recvMsg . ViewID ] ; ! ok {
vc . bhpSigs [ recvMsg . ViewID ] = map [ string ] * bls_core . Sign { }
}
vc . bhpSigs [ recvMsg . ViewID ] [ senderKeyStr ] = recvMsg . ViewchangeSig
if _ , ok := vc . bhpBitmap [ recvMsg . ViewID ] ; ! ok {
bhpBitmap , _ := bls_cosi . NewMask ( decider . Participants ( ) , nil )
vc . bhpBitmap [ recvMsg . ViewID ] = bhpBitmap
}
vc . bhpBitmap [ recvMsg . ViewID ] . SetKey ( senderKey . Bytes , true ) // Set the bitmap indicating that this validator signed.
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , recvMsg . ViewID ) .
Str ( "validatorPubKey" , senderKeyStr ) .
Msg ( "[ProcessViewChangeMsg] Add M3 (ViewID) type message" )
if _ , ok := vc . viewIDSigs [ recvMsg . ViewID ] ; ! ok {
vc . viewIDSigs [ recvMsg . ViewID ] = map [ string ] * bls_core . Sign { }
}
vc . viewIDSigs [ recvMsg . ViewID ] [ senderKeyStr ] = recvMsg . ViewidSig
if _ , ok := vc . viewIDBitmap [ recvMsg . ViewID ] ; ! ok {
viewIDBitmap , _ := bls_cosi . NewMask ( decider . Participants ( ) , nil )
vc . viewIDBitmap [ recvMsg . ViewID ] = viewIDBitmap
}
// Set the bitmap indicating that this validator signed.
vc . viewIDBitmap [ recvMsg . ViewID ] . SetKey ( senderKey . Bytes , true )
if vc . isM1PayloadEmpty ( ) {
vc . m1Payload = append ( recvMsg . Payload [ : 0 : 0 ] , recvMsg . Payload ... )
// create prepared message for new leader
preparedMsg := FBFTMessage {
MessageType : msg_pb . MessageType_PREPARED ,
ViewID : recvMsg . ViewID ,
BlockNum : recvMsg . BlockNum ,
}
preparedMsg . BlockHash = common . Hash { }
copy ( preparedMsg . BlockHash [ : ] , recvMsg . Payload [ : 32 ] )
preparedMsg . Payload = make ( [ ] byte , len ( recvMsg . Payload ) - 32 )
copy ( preparedMsg . Payload [ : ] , recvMsg . Payload [ 32 : ] )
preparedMsg . SenderPubkeys = [ ] * bls . PublicKeyWrapper { recvMsg . LeaderPubkey }
vc . getLogger ( ) . Info ( ) . Msg ( "[ProcessViewChangeMsg] New Leader Prepared Message Added" )
fbftlog . AddVerifiedMessage ( & preparedMsg )
fbftlog . AddBlock ( preparedBlock )
}
return nil
}
_ , ok := vc . nilSigs [ recvMsg . ViewID ] [ senderKeyStr ]
if ok {
return errDupM2
}
if ! recvMsg . ViewchangeSig . VerifyHash ( senderKey . Object , NIL ) {
return errVerifyM2
}
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , recvMsg . ViewID ) .
Str ( "validatorPubKey" , senderKeyStr ) .
Msg ( "[ProcessViewChangeMsg] Add M2 (NIL) type message" )
if _ , ok := vc . nilSigs [ recvMsg . ViewID ] ; ! ok {
vc . nilSigs [ recvMsg . ViewID ] = map [ string ] * bls_core . Sign { }
}
vc . nilSigs [ recvMsg . ViewID ] [ senderKeyStr ] = recvMsg . ViewchangeSig
if _ , ok := vc . nilBitmap [ recvMsg . ViewID ] ; ! ok {
nilBitmap , _ := bls_cosi . NewMask ( decider . Participants ( ) , nil )
vc . nilBitmap [ recvMsg . ViewID ] = nilBitmap
}
vc . nilBitmap [ recvMsg . ViewID ] . SetKey ( senderKey . Bytes , true ) // Set the bitmap indicating that this validator signed.
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , recvMsg . ViewID ) .
Str ( "validatorPubKey" , senderKeyStr ) .
Msg ( "[ProcessViewChangeMsg] Add M3 (ViewID) type message" )
if _ , ok := vc . viewIDSigs [ recvMsg . ViewID ] ; ! ok {
vc . viewIDSigs [ recvMsg . ViewID ] = map [ string ] * bls_core . Sign { }
}
vc . viewIDSigs [ recvMsg . ViewID ] [ senderKeyStr ] = recvMsg . ViewidSig
// Set the bitmap indicating that this validator signed.
if _ , ok := vc . viewIDBitmap [ recvMsg . ViewID ] ; ! ok {
viewIDBitmap , _ := bls_cosi . NewMask ( decider . Participants ( ) , nil )
vc . viewIDBitmap [ recvMsg . ViewID ] = viewIDBitmap
}
vc . viewIDBitmap [ recvMsg . ViewID ] . SetKey ( senderKey . Bytes , true )
return nil
}
// InitPayload do it once when validator received view change message
func ( vc * viewChange ) InitPayload (
fbftlog * FBFTLog ,
viewID uint64 ,
blockNum uint64 ,
privKeys multibls . PrivateKeys ,
members multibls . PublicKeys ,
) error {
// m1 or m2 init once per viewID/key.
// m1 and m2 are mutually exclusive.
// If the node has valid prepared block, it will add m1 signature.
// If not, the node will add m2 signature.
// Honest node should have only one kind of m1/m2 signature.
inited := false
for _ , key := range privKeys {
_ , ok1 := vc . bhpSigs [ viewID ] [ key . Pub . Bytes . Hex ( ) ]
_ , ok2 := vc . nilSigs [ viewID ] [ key . Pub . Bytes . Hex ( ) ]
if ok1 || ok2 {
inited = true
break
}
}
// add my own M1/M2 type message signature and bitmap
if ! inited {
preparedMsgs := fbftlog . GetMessagesByTypeSeq ( msg_pb . MessageType_PREPARED , blockNum )
preparedMsg := fbftlog . FindMessageByMaxViewID ( preparedMsgs )
hasBlock := false
if preparedMsg != nil {
if preparedBlock := fbftlog . GetBlockByHash ( preparedMsg . BlockHash ) ; preparedBlock != nil {
if err := vc . verifyBlock ( preparedBlock ) ; err == nil {
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , viewID ) . Uint64 ( "blockNum" , blockNum ) . Int ( "size" , binary . Size ( preparedBlock ) ) . Msg ( "[InitPayload] add my M1 (prepared) type messaage" )
msgToSign := append ( preparedMsg . BlockHash [ : ] , preparedMsg . Payload ... )
for _ , key := range privKeys {
// update the dictionary key if the viewID is first time received
if _ , ok := vc . bhpBitmap [ viewID ] ; ! ok {
bhpBitmap , _ := bls_cosi . NewMask ( members , nil )
vc . bhpBitmap [ viewID ] = bhpBitmap
}
if err := vc . bhpBitmap [ viewID ] . SetKey ( key . Pub . Bytes , true ) ; err != nil {
vc . getLogger ( ) . Warn ( ) . Str ( "key" , key . Pub . Bytes . Hex ( ) ) . Msg ( "[InitPayload] bhpBitmap setkey failed" )
continue
}
if _ , ok := vc . bhpSigs [ viewID ] ; ! ok {
vc . bhpSigs [ viewID ] = map [ string ] * bls_core . Sign { }
}
vc . bhpSigs [ viewID ] [ key . Pub . Bytes . Hex ( ) ] = key . Pri . SignHash ( msgToSign )
}
hasBlock = true
// if m1Payload is empty, we just add one
if vc . isM1PayloadEmpty ( ) {
vc . m1Payload = append ( preparedMsg . BlockHash [ : ] , preparedMsg . Payload ... )
}
}
}
}
if ! hasBlock {
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , viewID ) . Uint64 ( "blockNum" , blockNum ) . Msg ( "[InitPayload] add my M2 (NIL) type messaage" )
for _ , key := range privKeys {
if _ , ok := vc . nilBitmap [ viewID ] ; ! ok {
nilBitmap , _ := bls_cosi . NewMask ( members , nil )
vc . nilBitmap [ viewID ] = nilBitmap
}
if err := vc . nilBitmap [ viewID ] . SetKey ( key . Pub . Bytes , true ) ; err != nil {
vc . getLogger ( ) . Warn ( ) . Err ( err ) .
Str ( "key" , key . Pub . Bytes . Hex ( ) ) . Msg ( "[InitPayload] nilBitmap setkey failed" )
continue
}
if _ , ok := vc . nilSigs [ viewID ] ; ! ok {
vc . nilSigs [ viewID ] = map [ string ] * bls_core . Sign { }
}
vc . nilSigs [ viewID ] [ key . Pub . Bytes . Hex ( ) ] = key . Pri . SignHash ( NIL )
}
}
}
inited = false
for _ , key := range privKeys {
_ , ok3 := vc . viewIDSigs [ viewID ] [ key . Pub . Bytes . Hex ( ) ]
if ok3 {
inited = true
break
}
}
// add my own M3 type message signature and bitmap
if ! inited {
viewIDBytes := make ( [ ] byte , 8 )
binary . LittleEndian . PutUint64 ( viewIDBytes , viewID )
vc . getLogger ( ) . Info ( ) . Uint64 ( "viewID" , viewID ) . Uint64 ( "blockNum" , blockNum ) . Msg ( "[InitPayload] add my M3 (ViewID) type messaage" )
for _ , key := range privKeys {
if _ , ok := vc . viewIDBitmap [ viewID ] ; ! ok {
viewIDBitmap , _ := bls_cosi . NewMask ( members , nil )
vc . viewIDBitmap [ viewID ] = viewIDBitmap
}
if err := vc . viewIDBitmap [ viewID ] . SetKey ( key . Pub . Bytes , true ) ; err != nil {
vc . getLogger ( ) . Warn ( ) . Err ( err ) .
Str ( "key" , key . Pub . Bytes . Hex ( ) ) . Msg ( "[InitPayload] viewIDBitmap setkey failed" )
continue
}
if _ , ok := vc . viewIDSigs [ viewID ] ; ! ok {
vc . viewIDSigs [ viewID ] = map [ string ] * bls_core . Sign { }
}
vc . viewIDSigs [ viewID ] [ key . Pub . Bytes . Hex ( ) ] = key . Pri . SignHash ( viewIDBytes )
}
}
return nil
}
// isM1PayloadEmpty returns true if m1Payload is not set
// this is an unlocked internal function call
func ( vc * viewChange ) isM1PayloadEmpty ( ) bool {
return len ( vc . m1Payload ) == 0
}
// IsM1PayloadEmpty returns true if m1Payload is not set
func ( vc * viewChange ) IsM1PayloadEmpty ( ) bool {
return vc . isM1PayloadEmpty ( )
}
// GetViewIDBitmap returns the viewIDBitmap
func ( vc * viewChange ) GetViewIDBitmap ( viewID uint64 ) * bls_cosi . Mask {
return vc . viewIDBitmap [ viewID ]
}
// GetM1Payload returns the m1Payload.
func ( vc * viewChange ) GetM1Payload ( ) [ ] byte {
return vc . m1Payload
}
// getLogger returns logger for view change contexts added
func ( vc * viewChange ) getLogger ( ) * zerolog . Logger {
logger := utils . Logger ( ) . With ( ) .
Str ( "context" , "ViewChange" ) .
Logger ( )
return & logger
}