- package state_test
-
- import (
- "testing"
- "time"
-
- "github.com/stretchr/testify/mock"
- "github.com/stretchr/testify/require"
-
- "github.com/tendermint/tendermint/crypto/ed25519"
- "github.com/tendermint/tendermint/crypto/tmhash"
- "github.com/tendermint/tendermint/libs/log"
- memmock "github.com/tendermint/tendermint/mempool/mock"
- tmproto "github.com/tendermint/tendermint/proto/types"
- sm "github.com/tendermint/tendermint/state"
- "github.com/tendermint/tendermint/state/mocks"
- "github.com/tendermint/tendermint/types"
- tmtime "github.com/tendermint/tendermint/types/time"
- )
-
- const validationTestsStopHeight int64 = 10
-
- var defaultTestTime = time.Date(2019, 1, 1, 0, 0, 0, 0, time.UTC)
-
- func TestValidateBlockHeader(t *testing.T) {
- proxyApp := newTestApp()
- require.NoError(t, proxyApp.Start())
- defer proxyApp.Stop()
-
- state, stateDB, privVals := makeState(3, 1)
- blockExec := sm.NewBlockExecutor(
- stateDB,
- log.TestingLogger(),
- proxyApp.Consensus(),
- memmock.Mempool{},
- sm.MockEvidencePool{},
- )
- lastCommit := types.NewCommit(0, 0, types.BlockID{}, nil)
-
- // some bad values
- wrongHash := tmhash.Sum([]byte("this hash is wrong"))
- wrongVersion1 := state.Version.Consensus
- wrongVersion1.Block++
- wrongVersion2 := state.Version.Consensus
- wrongVersion2.App++
-
- // Manipulation of any header field causes failure.
- testCases := []struct {
- name string
- malleateBlock func(block *types.Block)
- }{
- {"Version wrong1", func(block *types.Block) { block.Version = wrongVersion1 }},
- {"Version wrong2", func(block *types.Block) { block.Version = wrongVersion2 }},
- {"ChainID wrong", func(block *types.Block) { block.ChainID = "not-the-real-one" }},
- {"Height wrong", func(block *types.Block) { block.Height += 10 }},
- {"Time wrong", func(block *types.Block) { block.Time = block.Time.Add(-time.Second * 1) }},
-
- {"LastBlockID wrong", func(block *types.Block) { block.LastBlockID.PartsHeader.Total += 10 }},
- {"LastCommitHash wrong", func(block *types.Block) { block.LastCommitHash = wrongHash }},
- {"DataHash wrong", func(block *types.Block) { block.DataHash = wrongHash }},
-
- {"ValidatorsHash wrong", func(block *types.Block) { block.ValidatorsHash = wrongHash }},
- {"NextValidatorsHash wrong", func(block *types.Block) { block.NextValidatorsHash = wrongHash }},
- {"ConsensusHash wrong", func(block *types.Block) { block.ConsensusHash = wrongHash }},
- {"AppHash wrong", func(block *types.Block) { block.AppHash = wrongHash }},
- {"LastResultsHash wrong", func(block *types.Block) { block.LastResultsHash = wrongHash }},
-
- {"EvidenceHash wrong", func(block *types.Block) { block.EvidenceHash = wrongHash }},
- {"Proposer wrong", func(block *types.Block) { block.ProposerAddress = ed25519.GenPrivKey().PubKey().Address() }},
- {"Proposer invalid", func(block *types.Block) { block.ProposerAddress = []byte("wrong size") }},
- }
-
- // Build up state for multiple heights
- for height := int64(1); height < validationTestsStopHeight; height++ {
- proposerAddr := state.Validators.GetProposer().Address
- /*
- Invalid blocks don't pass
- */
- for _, tc := range testCases {
- block, _ := state.MakeBlock(height, makeTxs(height), lastCommit, nil, proposerAddr)
- tc.malleateBlock(block)
- err := blockExec.ValidateBlock(state, block)
- require.Error(t, err, tc.name)
- }
-
- /*
- A good block passes
- */
- var err error
- state, _, lastCommit, err = makeAndCommitGoodBlock(state, height, lastCommit, proposerAddr, blockExec, privVals, nil)
- require.NoError(t, err, "height %d", height)
- }
- }
-
- func TestValidateBlockCommit(t *testing.T) {
- proxyApp := newTestApp()
- require.NoError(t, proxyApp.Start())
- defer proxyApp.Stop()
-
- state, stateDB, privVals := makeState(1, 1)
- blockExec := sm.NewBlockExecutor(
- stateDB,
- log.TestingLogger(),
- proxyApp.Consensus(),
- memmock.Mempool{},
- sm.MockEvidencePool{},
- )
- lastCommit := types.NewCommit(0, 0, types.BlockID{}, nil)
- wrongSigsCommit := types.NewCommit(1, 0, types.BlockID{}, nil)
- badPrivVal := types.NewMockPV()
-
- for height := int64(1); height < validationTestsStopHeight; height++ {
- proposerAddr := state.Validators.GetProposer().Address
- if height > 1 {
- /*
- #2589: ensure state.LastValidators.VerifyCommit fails here
- */
- // should be height-1 instead of height
- wrongHeightVote, err := types.MakeVote(
- height,
- state.LastBlockID,
- state.Validators,
- privVals[proposerAddr.String()],
- chainID,
- time.Now(),
- )
- require.NoError(t, err, "height %d", height)
- wrongHeightCommit := types.NewCommit(
- wrongHeightVote.Height,
- wrongHeightVote.Round,
- state.LastBlockID,
- []types.CommitSig{wrongHeightVote.CommitSig()},
- )
- block, _ := state.MakeBlock(height, makeTxs(height), wrongHeightCommit, nil, proposerAddr)
- err = blockExec.ValidateBlock(state, block)
- _, isErrInvalidCommitHeight := err.(types.ErrInvalidCommitHeight)
- require.True(t, isErrInvalidCommitHeight, "expected ErrInvalidCommitHeight at height %d but got: %v", height, err)
-
- /*
- #2589: test len(block.LastCommit.Signatures) == state.LastValidators.Size()
- */
- block, _ = state.MakeBlock(height, makeTxs(height), wrongSigsCommit, nil, proposerAddr)
- err = blockExec.ValidateBlock(state, block)
- _, isErrInvalidCommitSignatures := err.(types.ErrInvalidCommitSignatures)
- require.True(t, isErrInvalidCommitSignatures,
- "expected ErrInvalidCommitSignatures at height %d, but got: %v",
- height,
- err,
- )
- }
-
- /*
- A good block passes
- */
- var err error
- var blockID types.BlockID
- state, blockID, lastCommit, err = makeAndCommitGoodBlock(
- state,
- height,
- lastCommit,
- proposerAddr,
- blockExec,
- privVals,
- nil,
- )
- require.NoError(t, err, "height %d", height)
-
- /*
- wrongSigsCommit is fine except for the extra bad precommit
- */
- goodVote, err := types.MakeVote(height,
- blockID,
- state.Validators,
- privVals[proposerAddr.String()],
- chainID,
- time.Now(),
- )
- require.NoError(t, err, "height %d", height)
-
- bpvPubKey, err := badPrivVal.GetPubKey()
- require.NoError(t, err)
-
- badVote := &types.Vote{
- ValidatorAddress: bpvPubKey.Address(),
- ValidatorIndex: 0,
- Height: height,
- Round: 0,
- Timestamp: tmtime.Now(),
- Type: tmproto.PrecommitType,
- BlockID: blockID,
- }
- err = badPrivVal.SignVote(chainID, goodVote)
- require.NoError(t, err, "height %d", height)
- err = badPrivVal.SignVote(chainID, badVote)
- require.NoError(t, err, "height %d", height)
-
- wrongSigsCommit = types.NewCommit(goodVote.Height, goodVote.Round,
- blockID, []types.CommitSig{goodVote.CommitSig(), badVote.CommitSig()})
- }
- }
-
- func TestValidateBlockEvidence(t *testing.T) {
- proxyApp := newTestApp()
- require.NoError(t, proxyApp.Start())
- defer proxyApp.Stop()
-
- state, stateDB, privVals := makeState(4, 1)
- state.ConsensusParams.Evidence.MaxNum = 3
- blockExec := sm.NewBlockExecutor(
- stateDB,
- log.TestingLogger(),
- proxyApp.Consensus(),
- memmock.Mempool{},
- sm.MockEvidencePool{},
- )
- lastCommit := types.NewCommit(0, 0, types.BlockID{}, nil)
-
- for height := int64(1); height < validationTestsStopHeight; height++ {
- proposerAddr := state.Validators.GetProposer().Address
- maxNumEvidence := state.ConsensusParams.Evidence.MaxNum
- t.Log(maxNumEvidence)
- if height > 1 {
- /*
- A block with too much evidence fails
- */
- require.True(t, maxNumEvidence > 2)
- evidence := make([]types.Evidence, 0)
- // one more than the maximum allowed evidence
- for i := uint32(0); i <= maxNumEvidence; i++ {
- evidence = append(evidence, types.NewMockEvidence(height, time.Now(), proposerAddr))
- }
- block, _ := state.MakeBlock(height, makeTxs(height), lastCommit, evidence, proposerAddr)
- err := blockExec.ValidateBlock(state, block)
- _, ok := err.(*types.ErrEvidenceOverflow)
- require.True(t, ok, "expected error to be of type ErrEvidenceOverflow at height %d", height)
- }
-
- /*
- A good block with several pieces of good evidence passes
- */
- require.True(t, maxNumEvidence > 2)
- evidence := make([]types.Evidence, 0)
- // precisely the amount of allowed evidence
- for i := int32(0); uint32(i) < maxNumEvidence; i++ {
- // make different evidence for each validator
- addr, _ := state.Validators.GetByIndex(i)
- evidence = append(evidence, types.NewMockEvidence(height, time.Now(), addr))
- }
-
- var err error
- state, _, lastCommit, err = makeAndCommitGoodBlock(
- state,
- height,
- lastCommit,
- proposerAddr,
- blockExec,
- privVals,
- evidence,
- )
- require.NoError(t, err, "height %d", height)
- }
- }
-
- func TestValidateFailBlockOnCommittedEvidence(t *testing.T) {
- var height int64 = 1
- state, stateDB, _ := makeState(2, int(height))
- addr, _ := state.Validators.GetByIndex(0)
- addr2, _ := state.Validators.GetByIndex(1)
- ev := types.NewMockEvidence(height, defaultTestTime, addr)
- ev2 := types.NewMockEvidence(height, defaultTestTime, addr2)
-
- evpool := &mocks.EvidencePool{}
- evpool.On("IsPending", mock.AnythingOfType("types.MockEvidence")).Return(false)
- evpool.On("IsCommitted", ev).Return(false)
- evpool.On("IsCommitted", ev2).Return(true)
-
- blockExec := sm.NewBlockExecutor(
- stateDB, log.TestingLogger(),
- nil,
- nil,
- evpool)
- // A block with a couple pieces of evidence passes.
- block := makeBlock(state, height)
- block.Evidence.Evidence = []types.Evidence{ev, ev2}
- block.EvidenceHash = block.Evidence.Hash()
- err := blockExec.ValidateBlock(state, block)
-
- require.Error(t, err)
- require.IsType(t, err, &types.ErrEvidenceInvalid{})
- }
-
- func TestValidateAlreadyPendingEvidence(t *testing.T) {
- var height int64 = 1
- state, stateDB, _ := makeState(2, int(height))
- addr, _ := state.Validators.GetByIndex(0)
- addr2, _ := state.Validators.GetByIndex(1)
- ev := types.NewMockEvidence(height, defaultTestTime, addr)
- ev2 := types.NewMockEvidence(height, defaultTestTime, addr2)
-
- evpool := &mocks.EvidencePool{}
- evpool.On("IsPending", ev).Return(false)
- evpool.On("IsPending", ev2).Return(true)
- evpool.On("IsCommitted", mock.AnythingOfType("types.MockEvidence")).Return(false)
-
- blockExec := sm.NewBlockExecutor(
- stateDB, log.TestingLogger(),
- nil,
- nil,
- evpool)
- // A block with a couple pieces of evidence passes.
- block := makeBlock(state, height)
- // add one evidence seen before and one evidence that hasn't
- block.Evidence.Evidence = []types.Evidence{ev, ev2}
- block.EvidenceHash = block.Evidence.Hash()
- err := blockExec.ValidateBlock(state, block)
-
- require.NoError(t, err)
- }
-
- func TestValidateDuplicateEvidenceShouldFail(t *testing.T) {
- var height int64 = 1
- state, stateDB, _ := makeState(1, int(height))
- addr, _ := state.Validators.GetByIndex(0)
- addr2, _ := state.Validators.GetByIndex(1)
- ev := types.NewMockEvidence(height, defaultTestTime, addr)
- ev2 := types.NewMockEvidence(height, defaultTestTime, addr2)
-
- blockExec := sm.NewBlockExecutor(
- stateDB, log.TestingLogger(),
- nil,
- nil,
- sm.MockEvidencePool{})
- // A block with a couple pieces of evidence passes.
- block := makeBlock(state, height)
- block.Evidence.Evidence = []types.Evidence{ev, ev2, ev2}
- block.EvidenceHash = block.Evidence.Hash()
- err := blockExec.ValidateBlock(state, block)
-
- require.Error(t, err)
- }
|