Skip to content

Commit

Permalink
Merge refs/heads/develop into use-sa-from-11143
Browse files Browse the repository at this point in the history
  • Loading branch information
prylabs-bulldozer[bot] authored Aug 3, 2022
2 parents 2a5fd0f + d4ab080 commit 65a9e5c
Show file tree
Hide file tree
Showing 36 changed files with 82 additions and 82 deletions.
4 changes: 2 additions & 2 deletions beacon-chain/blockchain/process_block_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -2249,7 +2249,7 @@ func TestStore_NoViableHead_NewPayload_DoublyLinkedTree(t *testing.T) {
err = service.onBlock(ctx, wsb, root)
require.ErrorContains(t, "received an INVALID payload from execution engine", err)
// Check that forkchoice's head and store's headroot are the previous head (since the invalid block did
// not finish importing and it was never imported to forkchoice). Cehck
// not finish importing and it was never imported to forkchoice). Check
// also that the node is optimistic
require.Equal(t, firstInvalidRoot, service.ForkChoicer().CachedHeadRoot())
headRoot, err := service.HeadRoot(ctx)
Expand Down Expand Up @@ -2409,7 +2409,7 @@ func TestStore_NoViableHead_NewPayload_Protoarray(t *testing.T) {
err = service.onBlock(ctx, wsb, root)
require.ErrorContains(t, "received an INVALID payload from execution engine", err)
// Check that forkchoice's head and store's headroot are the previous head (since the invalid block did
// not finish importing and it was never imported to forkchoice). Cehck
// not finish importing and it was never imported to forkchoice). Check
// also that the node is optimistic
require.Equal(t, firstInvalidRoot, service.ForkChoicer().CachedHeadRoot())
headRoot, err := service.HeadRoot(ctx)
Expand Down
4 changes: 2 additions & 2 deletions beacon-chain/core/altair/block_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -309,13 +309,13 @@ func Test_SyncRewards(t *testing.T) {
}
for _, tt := range tests {
t.Run(tt.name, func(t *testing.T) {
proposerReward, participarntReward, err := altair.SyncRewards(tt.activeBalance)
proposerReward, participantReward, err := altair.SyncRewards(tt.activeBalance)
if (err != nil) && (tt.errString != "") {
require.ErrorContains(t, tt.errString, err)
return
}
require.Equal(t, tt.wantProposerReward, proposerReward)
require.Equal(t, tt.wantParticipantReward, participarntReward)
require.Equal(t, tt.wantParticipantReward, participantReward)
})
}
}
4 changes: 2 additions & 2 deletions beacon-chain/core/altair/transition.go
Original file line number Diff line number Diff line change
Expand Up @@ -68,11 +68,11 @@ func ProcessEpoch(ctx context.Context, state state.BeaconState) (state.BeaconSta
}

// Modified in Altair and Bellatrix.
proportionalSlashingMultipler, err := state.ProportionalSlashingMultiplier()
proportionalSlashingMultiplier, err := state.ProportionalSlashingMultiplier()
if err != nil {
return nil, err
}
state, err = e.ProcessSlashings(state, proportionalSlashingMultipler)
state, err = e.ProcessSlashings(state, proportionalSlashingMultiplier)
if err != nil {
return nil, err
}
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/core/blocks/randao.go
Original file line number Diff line number Diff line change
Expand Up @@ -73,7 +73,7 @@ func ProcessRandaoNoVerify(
}
blockRandaoReveal := hash.Hash(randaoReveal)
if len(blockRandaoReveal) != len(latestMixSlice) {
return nil, errors.New("blockRandaoReveal length doesnt match latestMixSlice length")
return nil, errors.New("blockRandaoReveal length doesn't match latestMixSlice length")
}
for i, x := range blockRandaoReveal {
latestMixSlice[i] ^= x
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/core/epoch/precompute/attestation_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -39,7 +39,7 @@ func TestUpdateValidator_InclusionOnlyCountsPrevEpoch(t *testing.T) {
record := &precompute.Validator{IsCurrentEpochAttester: true, IsCurrentEpochTargetAttester: true}
a := &ethpb.PendingAttestation{InclusionDelay: 1, ProposerIndex: 2}

// Verify inclusion info doesnt get updated.
// Verify inclusion info doesn't get updated.
vp = precompute.UpdateValidator(vp, record, []uint64{0}, a, 100)
wanted := &precompute.Validator{IsCurrentEpochAttester: true, IsCurrentEpochTargetAttester: true, InclusionSlot: e}
wantedVp := []*precompute.Validator{wanted}
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/execution/engine_client_fuzz_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -310,7 +310,7 @@ func validateBlockConsistency(execBlock *pb.ExecutionBlock, jsonMap map[string]i
continue
}
if !reflect.DeepEqual(jsonVal, bVal) {
return errors.Errorf("fields dont match, %v and %v are not equal for field %s", jsonVal, bVal, field.Name)
return errors.Errorf("fields don't match, %v and %v are not equal for field %s", jsonVal, bVal, field.Name)
}
}
return nil
Expand Down
4 changes: 2 additions & 2 deletions beacon-chain/forkchoice/doubly-linked-tree/store.go
Original file line number Diff line number Diff line change
Expand Up @@ -158,8 +158,8 @@ func (s *Store) insert(ctx context.Context,
}
secondsIntoSlot := (timeNow - s.genesisTime) % params.BeaconConfig().SecondsPerSlot
currentSlot := slots.CurrentSlot(s.genesisTime)
boostTreshold := params.BeaconConfig().SecondsPerSlot / params.BeaconConfig().IntervalsPerSlot
if currentSlot == slot && secondsIntoSlot < boostTreshold {
boostThreshold := params.BeaconConfig().SecondsPerSlot / params.BeaconConfig().IntervalsPerSlot
if currentSlot == slot && secondsIntoSlot < boostThreshold {
s.proposerBoostLock.Lock()
s.proposerBoostRoot = root
s.proposerBoostLock.Unlock()
Expand Down
4 changes: 2 additions & 2 deletions beacon-chain/forkchoice/protoarray/store.go
Original file line number Diff line number Diff line change
Expand Up @@ -515,8 +515,8 @@ func (s *Store) insert(ctx context.Context,
}
secondsIntoSlot := (timeNow - s.genesisTime) % params.BeaconConfig().SecondsPerSlot
currentSlot := slots.CurrentSlot(s.genesisTime)
boostTreshold := params.BeaconConfig().SecondsPerSlot / params.BeaconConfig().IntervalsPerSlot
if currentSlot == slot && secondsIntoSlot < boostTreshold {
boostThreshold := params.BeaconConfig().SecondsPerSlot / params.BeaconConfig().IntervalsPerSlot
if currentSlot == slot && secondsIntoSlot < boostThreshold {
s.proposerBoostLock.Lock()
s.proposerBoostRoot = root
s.proposerBoostLock.Unlock()
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/monitor/process_attestation.go
Original file line number Diff line number Diff line change
Expand Up @@ -184,7 +184,7 @@ func (s *Service) processUnaggregatedAttestation(ctx context.Context, att *ethpb
}
}

// processUnaggregatedAttestation logs when the beacon node observes an anngregated attestation from tracked validator.
// processUnaggregatedAttestation logs when the beacon node observes an aggregated attestation from tracked validator.
func (s *Service) processAggregatedAttestation(ctx context.Context, att *ethpb.AggregateAttestationAndProof) {
s.Lock()
defer s.Unlock()
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/monitor/process_block.go
Original file line number Diff line number Diff line change
Expand Up @@ -171,7 +171,7 @@ func (s *Service) logAggregatedPerformance() {
"AverageInclusionDistance": fmt.Sprintf("%.1f", percentDistance),
"TotalProposedBlocks": p.totalProposedCount,
"TotalAggregations": p.totalAggregations,
"TotalSyncContributions": p.totalSyncComitteeContributions,
"TotalSyncContributions": p.totalSyncCommitteeContributions,
}).Info("Aggregated performance since launch")
}
}
4 changes: 2 additions & 2 deletions beacon-chain/monitor/process_sync_committee.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ func (s *Service) processSyncCommitteeContribution(contribution *ethpb.SignedCon
defer s.Unlock()
if s.trackedIndex(idx) {
aggPerf := s.aggregatedPerformance[idx]
aggPerf.totalSyncComitteeAggregations++
aggPerf.totalSyncCommitteeAggregations++
s.aggregatedPerformance[idx] = aggPerf

log.WithField("ValidatorIndex", contribution.Message.AggregatorIndex).Info("Sync committee aggregation processed")
Expand Down Expand Up @@ -58,7 +58,7 @@ func (s *Service) processSyncAggregate(state state.BeaconState, blk interfaces.B
s.latestPerformance[validatorIdx] = latestPerf

aggPerf := s.aggregatedPerformance[validatorIdx]
aggPerf.totalSyncComitteeContributions += uint64(contrib)
aggPerf.totalSyncCommitteeContributions += uint64(contrib)
s.aggregatedPerformance[validatorIdx] = aggPerf

syncCommitteeContributionCounter.WithLabelValues(
Expand Down
24 changes: 12 additions & 12 deletions beacon-chain/monitor/service.go
Original file line number Diff line number Diff line change
Expand Up @@ -41,18 +41,18 @@ type ValidatorLatestPerformance struct {
// ValidatorAggregatedPerformance keeps track of the accumulated performance of
// the tracked validator since start of monitor service.
type ValidatorAggregatedPerformance struct {
startEpoch types.Epoch
startBalance uint64
totalAttestedCount uint64
totalRequestedCount uint64
totalDistance uint64
totalCorrectSource uint64
totalCorrectTarget uint64
totalCorrectHead uint64
totalProposedCount uint64
totalAggregations uint64
totalSyncComitteeContributions uint64
totalSyncComitteeAggregations uint64
startEpoch types.Epoch
startBalance uint64
totalAttestedCount uint64
totalRequestedCount uint64
totalDistance uint64
totalCorrectSource uint64
totalCorrectTarget uint64
totalCorrectHead uint64
totalProposedCount uint64
totalAggregations uint64
totalSyncCommitteeContributions uint64
totalSyncCommitteeAggregations uint64
}

// ValidatorMonitorConfig contains the list of validator indices that the
Expand Down
22 changes: 11 additions & 11 deletions beacon-chain/monitor/service_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -66,17 +66,17 @@ func setupService(t *testing.T) *Service {
}
aggregatedPerformance := map[types.ValidatorIndex]ValidatorAggregatedPerformance{
1: {
startEpoch: 0,
startBalance: 31700000000,
totalAttestedCount: 12,
totalRequestedCount: 15,
totalDistance: 14,
totalCorrectHead: 8,
totalCorrectSource: 11,
totalCorrectTarget: 12,
totalProposedCount: 1,
totalSyncComitteeContributions: 0,
totalSyncComitteeAggregations: 0,
startEpoch: 0,
startBalance: 31700000000,
totalAttestedCount: 12,
totalRequestedCount: 15,
totalDistance: 14,
totalCorrectHead: 8,
totalCorrectSource: 11,
totalCorrectTarget: 12,
totalProposedCount: 1,
totalSyncCommitteeContributions: 0,
totalSyncCommitteeAggregations: 0,
},
2: {},
12: {},
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/p2p/broadcaster_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -332,7 +332,7 @@ func TestService_BroadcastAttestationWithDiscoveryAttempts(t *testing.T) {

// External peer subscribes to the topic.
topic += p.Encoding().ProtocolSuffix()
// We dont use our internal subscribe method
// We don't use our internal subscribe method
// due to using floodsub over here.
tpHandle, err := p2.JoinTopic(topic)
require.NoError(t, err)
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/p2p/peers/status.go
Original file line number Diff line number Diff line change
Expand Up @@ -740,7 +740,7 @@ func (p *Status) BestNonFinalized(minPeers int, ourHeadEpoch types.Epoch) (types
return targetEpoch, potentialPIDs
}

// PeersToPrune selects the most sutiable inbound peers
// PeersToPrune selects the most suitable inbound peers
// to disconnect the host peer from. As of this moment
// the pruning relies on simple heuristics such as
// bad response count. In the future scoring will be used
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/p2p/peers/status_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -666,7 +666,7 @@ func TestConcurrentPeerLimitHolds(t *testing.T) {
},
},
})
assert.Equal(t, true, uint64(p.MaxPeerLimit()) > p.ConnectedPeerLimit(), "max peer limit doesnt exceed connected peer limit")
assert.Equal(t, true, uint64(p.MaxPeerLimit()) > p.ConnectedPeerLimit(), "max peer limit doesn't exceed connected peer limit")
}

func TestAtInboundPeerLimit(t *testing.T) {
Expand Down
10 changes: 5 additions & 5 deletions beacon-chain/p2p/testing/p2p.go
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ import (
"google.golang.org/protobuf/proto"
)

// We have to declare this again here to prevent a circular dependancy
// We have to declare this again here to prevent a circular dependency
// with the main p2p package.
const metatadataV1Topic = "/eth2/beacon_chain/req/metadata/1"
const metatadataV2Topic = "/eth2/beacon_chain/req/metadata/2"
Expand Down Expand Up @@ -107,7 +107,7 @@ func (p *TestP2P) ReceiveRPC(topic string, msg proto.Message) {

castedMsg, ok := msg.(ssz.Marshaler)
if !ok {
p.t.Fatalf("%T doesnt support ssz marshaler", msg)
p.t.Fatalf("%T doesn't support ssz marshaler", msg)
}
n, err := p.Encoding().EncodeWithMaxLength(s, castedMsg)
if err != nil {
Expand Down Expand Up @@ -139,7 +139,7 @@ func (p *TestP2P) ReceivePubSub(topic string, msg proto.Message) {

castedMsg, ok := msg.(ssz.Marshaler)
if !ok {
p.t.Fatalf("%T doesnt support ssz marshaler", msg)
p.t.Fatalf("%T doesn't support ssz marshaler", msg)
}
buf := new(bytes.Buffer)
if _, err := p.Encoding().EncodeGossip(buf, castedMsg); err != nil {
Expand Down Expand Up @@ -305,7 +305,7 @@ func (p *TestP2P) AddDisconnectionHandler(f func(ctx context.Context, id peer.ID
func (p *TestP2P) Send(ctx context.Context, msg interface{}, topic string, pid peer.ID) (network.Stream, error) {
t := topic
if t == "" {
return nil, fmt.Errorf("protocol doesnt exist for proto message: %v", msg)
return nil, fmt.Errorf("protocol doesn't exist for proto message: %v", msg)
}
stream, err := p.BHost.NewStream(ctx, pid, core.ProtocolID(t+p.Encoding().ProtocolSuffix()))
if err != nil {
Expand All @@ -315,7 +315,7 @@ func (p *TestP2P) Send(ctx context.Context, msg interface{}, topic string, pid p
if topic != metatadataV1Topic && topic != metatadataV2Topic {
castedMsg, ok := msg.(ssz.Marshaler)
if !ok {
p.t.Fatalf("%T doesnt support ssz marshaler", msg)
p.t.Fatalf("%T doesn't support ssz marshaler", msg)
}
if _, err := p.Encoding().EncodeWithMaxLength(stream, castedMsg); err != nil {
_err := stream.Reset()
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/rpc/prysm/v1alpha1/validator/attester_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -209,7 +209,7 @@ func TestAttestationDataAtSlot_HandlesFarAwayJustifiedEpoch(t *testing.T) {
// HistoricalRootsLimit = 8192
//
// More background: https://github.com/prysmaticlabs/prysm/issues/2153
// This test breaks if it doesnt use mainnet config
// This test breaks if it doesn't use mainnet config

// Ensure HistoricalRootsLimit matches scenario
params.SetupTestConfigCleanup(t)
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/rpc/prysm/v1alpha1/validator/server_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -91,7 +91,7 @@ func TestWaitForActivation_ContextClosed(t *testing.T) {
}

func TestWaitForActivation_ValidatorOriginallyExists(t *testing.T) {
// This test breaks if it doesnt use mainnet config
// This test breaks if it doesn't use mainnet config
params.SetupTestConfigCleanup(t)
params.OverrideBeaconConfig(params.MainnetConfig().Copy())
ctx := context.Background()
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/rpc/prysm/v1alpha1/validator/status_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -234,7 +234,7 @@ func TestValidatorStatus_Pending(t *testing.T) {
}

func TestValidatorStatus_Active(t *testing.T) {
// This test breaks if it doesnt use mainnet config
// This test breaks if it doesn't use mainnet config
params.SetupTestConfigCleanup(t)
params.OverrideBeaconConfig(params.MainnetConfig().Copy())
ctx := context.Background()
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/slasher/params_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -455,7 +455,7 @@ func TestParams_validatorIndicesInChunk(t *testing.T) {
want: []types.ValidatorIndex{6, 7, 8},
},
{
name: "0 validator chunk size returs empty",
name: "0 validator chunk size returns empty",
fields: &Parameters{
validatorChunkSize: 0,
},
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/slasher/service.go
Original file line number Diff line number Diff line change
Expand Up @@ -96,7 +96,7 @@ func (s *Service) run() {

log.Info("Completed chain sync, starting slashing detection")

// Get the latest eopch written for each validator from disk on startup.
// Get the latest epoch written for each validator from disk on startup.
headState, err := s.serviceCfg.HeadStateFetcher.HeadState(s.ctx)
if err != nil {
log.WithError(err).Error("Failed to fetch head state")
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/state/stateutil/sync_committee.root.go
Original file line number Diff line number Diff line change
Expand Up @@ -8,7 +8,7 @@ import (
ethpb "github.com/prysmaticlabs/prysm/proto/prysm/v1alpha1"
)

// SyncCommitteeRoot computes the HashTreeRoot Merkleization of a commitee root.
// SyncCommitteeRoot computes the HashTreeRoot Merkleization of a committee root.
// a SyncCommitteeRoot struct according to the eth2
// Simple Serialize specification.
func SyncCommitteeRoot(committee *ethpb.SyncCommittee) ([32]byte, error) {
Expand Down
2 changes: 1 addition & 1 deletion beacon-chain/sync/validate_beacon_blocks_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -1065,7 +1065,7 @@ func TestService_isBlockQueueable(t *testing.T) {
genesisTime := uint64(currentTime.Unix() - int64(params.BeaconConfig().SecondsPerSlot))
blockSlot := types.Slot(1)

// slot time within MAXIMUM_GOSSIP_CLOCK_DISPARITY, so dont queue the block.
// slot time within MAXIMUM_GOSSIP_CLOCK_DISPARITY, so don't queue the block.
receivedTime := currentTime.Add(-400 * time.Millisecond)
result := isBlockQueueable(genesisTime, blockSlot, receivedTime)
assert.Equal(t, false, result)
Expand Down
2 changes: 1 addition & 1 deletion container/queue/priority_queue.go
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,7 @@ import (
// ErrEmpty is returned for queues with no items
var ErrEmpty = errors.New("queue is empty")

// ErrDuplicateItem is returned when the queue attmepts to push an item to a key that
// ErrDuplicateItem is returned when the queue attempts to push an item to a key that
// already exists. The queue does not attempt to update, instead returns this
// error. If an Item needs to be updated or replaced, pop the item first.
var ErrDuplicateItem = errors.New("duplicate item")
Expand Down
2 changes: 1 addition & 1 deletion proto/eth/v1/beacon_block.proto
Original file line number Diff line number Diff line change
Expand Up @@ -95,7 +95,7 @@ message ProposerSlashing {
}

// Attestor slashings are proofs that a slashable offense has been committed by
// attestating to two conflicting pieces of information by the same validator.
// attesting to two conflicting pieces of information by the same validator.
message AttesterSlashing {
// First conflicting attestation.
IndexedAttestation attestation_1 = 1;
Expand Down
30 changes: 15 additions & 15 deletions proto/migration/v1alpha1_to_v2.go
Original file line number Diff line number Diff line change
Expand Up @@ -418,7 +418,7 @@ func BeaconStateBellatrixToProto(st state.BeaconState) (*ethpbv2.BeaconStateBell
if err != nil {
return nil, errors.Wrap(err, "could not get next sync committee")
}
sourceLatestExecutionPaylodHeader, err := st.LatestExecutionPayloadHeader()
sourceLatestExecutionPayloadHeader, err := st.LatestExecutionPayloadHeader()
if err != nil {
return nil, errors.Wrap(err, "could not get latest execution payload header")
}
Expand Down Expand Up @@ -478,20 +478,20 @@ func BeaconStateBellatrixToProto(st state.BeaconState) (*ethpbv2.BeaconStateBell
AggregatePubkey: bytesutil.SafeCopyBytes(sourceNextSyncCommittee.AggregatePubkey),
},
LatestExecutionPayloadHeader: &enginev1.ExecutionPayloadHeader{
ParentHash: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.ParentHash),
FeeRecipient: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.FeeRecipient),
StateRoot: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.StateRoot),
ReceiptsRoot: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.ReceiptsRoot),
LogsBloom: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.LogsBloom),
PrevRandao: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.PrevRandao),
BlockNumber: sourceLatestExecutionPaylodHeader.BlockNumber,
GasLimit: sourceLatestExecutionPaylodHeader.GasLimit,
GasUsed: sourceLatestExecutionPaylodHeader.GasUsed,
Timestamp: sourceLatestExecutionPaylodHeader.Timestamp,
ExtraData: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.ExtraData),
BaseFeePerGas: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.BaseFeePerGas),
BlockHash: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.BlockHash),
TransactionsRoot: bytesutil.SafeCopyBytes(sourceLatestExecutionPaylodHeader.TransactionsRoot),
ParentHash: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.ParentHash),
FeeRecipient: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.FeeRecipient),
StateRoot: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.StateRoot),
ReceiptsRoot: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.ReceiptsRoot),
LogsBloom: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.LogsBloom),
PrevRandao: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.PrevRandao),
BlockNumber: sourceLatestExecutionPayloadHeader.BlockNumber,
GasLimit: sourceLatestExecutionPayloadHeader.GasLimit,
GasUsed: sourceLatestExecutionPayloadHeader.GasUsed,
Timestamp: sourceLatestExecutionPayloadHeader.Timestamp,
ExtraData: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.ExtraData),
BaseFeePerGas: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.BaseFeePerGas),
BlockHash: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.BlockHash),
TransactionsRoot: bytesutil.SafeCopyBytes(sourceLatestExecutionPayloadHeader.TransactionsRoot),
},
}

Expand Down
2 changes: 1 addition & 1 deletion proto/prysm/v1alpha1/beacon_block.proto
Original file line number Diff line number Diff line change
Expand Up @@ -203,7 +203,7 @@ message ProposerSlashing {
}

// Attestor slashings are proofs that a slashable offense has been committed by
// attestating to two conflicting pieces of information by the same validator.
// attesting to two conflicting pieces of information by the same validator.
message AttesterSlashing {
// First conflicting attestation.
IndexedAttestation attestation_1 = 1;
Expand Down
Loading

0 comments on commit 65a9e5c

Please sign in to comment.