prysm-pulse/beacon-chain/core/helpers/committee.go
terence tsao 761f3352a0 Fix current epoch committee count (#2099)
* fix current epoch committee count

* prev epoch
2019-03-27 22:10:10 -05:00

611 lines
22 KiB
Go

// Package helpers contains helper functions outlined in ETH2.0 spec:
// https://github.com/ethereum/eth2.0-specs/blob/master/specs/core/0_beacon-chain.md#helper-functions
package helpers
import (
"encoding/binary"
"errors"
"fmt"
"github.com/prysmaticlabs/prysm/beacon-chain/utils"
pb "github.com/prysmaticlabs/prysm/proto/beacon/p2p/v1"
"github.com/prysmaticlabs/prysm/shared/bitutil"
"github.com/prysmaticlabs/prysm/shared/bytesutil"
"github.com/prysmaticlabs/prysm/shared/mathutil"
"github.com/prysmaticlabs/prysm/shared/params"
"google.golang.org/grpc/codes"
"google.golang.org/grpc/status"
)
// CrosslinkCommittee defines the validator committee of slot and shard combinations.
type CrosslinkCommittee struct {
Committee []uint64
Shard uint64
}
type shufflingInput struct {
seed []byte
shufflingEpoch uint64
slot uint64
startShard uint64
committeesPerEpoch uint64
}
// EpochCommitteeCount returns the number of crosslink committees of an epoch.
//
// Spec pseudocode definition:
// def get_epoch_committee_count(active_validator_count: int) -> int:
// """
// Return the number of committees in one epoch.
// """
// return max(
// 1,
// min(
// SHARD_COUNT // SLOTS_PER_EPOCH,
// active_validator_count // SLOTS_PER_EPOCH // TARGET_COMMITTEE_SIZE,
// )
// ) * SLOTS_PER_EPOCH
func EpochCommitteeCount(activeValidatorCount uint64) uint64 {
var minCommitteePerSlot = uint64(1)
// Max committee count per slot will be 0 when shard count is less than epoch length, this
// covers the special case to ensure there's always 1 max committee count per slot.
var maxCommitteePerSlot = minCommitteePerSlot
if params.BeaconConfig().ShardCount/params.BeaconConfig().SlotsPerEpoch > minCommitteePerSlot {
maxCommitteePerSlot = params.BeaconConfig().ShardCount / params.BeaconConfig().SlotsPerEpoch
}
var currCommitteePerSlot = activeValidatorCount / params.BeaconConfig().SlotsPerEpoch / params.BeaconConfig().TargetCommitteeSize
if currCommitteePerSlot > maxCommitteePerSlot {
return maxCommitteePerSlot * params.BeaconConfig().SlotsPerEpoch
}
if currCommitteePerSlot < 1 {
return minCommitteePerSlot * params.BeaconConfig().SlotsPerEpoch
}
return currCommitteePerSlot * params.BeaconConfig().SlotsPerEpoch
}
// CurrentEpochCommitteeCount returns the number of crosslink committees per epoch
// of the current epoch.
// Ex: Returns 100 means there's 8 committees assigned to current epoch.
//
// Spec pseudocode definition:
// def get_current_epoch_committee_count(state: BeaconState) -> int:
// """
// Return the number of committees in the current epoch of the given ``state``.
// """
// current_active_validators = get_active_validator_indices(
// state.validator_registry,
// get_current_epoch(state),
// )
// return get_epoch_committee_count(len(current_active_validators)
func CurrentEpochCommitteeCount(state *pb.BeaconState) uint64 {
currActiveValidatorIndices := ActiveValidatorIndices(
state.ValidatorRegistry, CurrentEpoch(state))
return EpochCommitteeCount(uint64(len(currActiveValidatorIndices)))
}
// PrevEpochCommitteeCount returns the number of committees per slot
// of the previous epoch.
//
// Spec pseudocode definition:
// def get_previous_epoch_committee_count(state: BeaconState) -> int:
// """
// Return the number of committees in the previous epoch of the given ``state``.
// """
// previous_active_validators = get_active_validator_indices(
// state.validator_registry,
// state.previous_epoch,
// )
// return get_epoch_committee_count(len(previous_active_validators))
func PrevEpochCommitteeCount(state *pb.BeaconState) uint64 {
prevActiveValidatorIndices := ActiveValidatorIndices(
state.ValidatorRegistry, PrevEpoch(state))
return EpochCommitteeCount(uint64(len(prevActiveValidatorIndices)))
}
// NextEpochCommitteeCount returns the number of committees per slot
// of the next epoch.
//
// Spec pseudocode definition:
// def get_next_epoch_committee_count(state: BeaconState) -> int:
// """
// Return the number of committees in the next epoch of the given ``state``.
// """
// next_active_validators = get_active_validator_indices(
// state.validator_registry,
// get_current_epoch(state) + 1,
// )
// return get_epoch_committee_count(len(next_active_validators))
func NextEpochCommitteeCount(state *pb.BeaconState) uint64 {
prevActiveValidatorIndices := ActiveValidatorIndices(
state.ValidatorRegistry, CurrentEpoch(state)+1)
return EpochCommitteeCount(uint64(len(prevActiveValidatorIndices)))
}
// CrosslinkCommitteesAtSlot returns the list of crosslink committees, it
// contains the shard associated with the committee and the validator indices
// in that committee.
//
// Spec pseudocode definition:
// def get_crosslink_committees_at_slot(state: BeaconState,
// slot: Slot,
// registry_change: bool=False) -> List[Tuple[List[ValidatorIndex], Shard]]:
// """
// Return the list of ``(committee, shard)`` tuples for the ``slot``.
//
// Note: There are two possible shufflings for crosslink committees for a
// ``slot`` in the next epoch -- with and without a `registry_change`
// """
// epoch = slot_to_epoch(slot)
// current_epoch = get_current_epoch(state)
// previous_epoch = get_previous_epoch(state)
// next_epoch = current_epoch + 1
//
// assert previous_epoch <= epoch <= next_epoch
//
// if epoch == current_epoch:
// return get_current_epoch_committees_at_slot(state, slot)
// elif epoch == previous_epoch:
// return get_previous_epoch_committees_at_slot(state, slot)
// elif epoch == next_epoch:
// return get_next_epoch_committee_count(state, slot, registry_change)
func CrosslinkCommitteesAtSlot(
state *pb.BeaconState,
slot uint64,
registryChange bool) ([]*CrosslinkCommittee, error) {
wantedEpoch := SlotToEpoch(slot)
currentEpoch := CurrentEpoch(state)
prevEpoch := PrevEpoch(state)
nextEpoch := NextEpoch(state)
switch wantedEpoch {
case currentEpoch:
return currEpochCommitteesAtSlot(state, slot)
case prevEpoch:
return prevEpochCommitteesAtSlot(state, slot)
case nextEpoch:
return nextEpochCommitteesAtSlot(state, slot, registryChange)
default:
return nil, fmt.Errorf(
"input committee epoch %d out of bounds: %d <= epoch <= %d",
wantedEpoch-params.BeaconConfig().GenesisEpoch,
prevEpoch-params.BeaconConfig().GenesisEpoch,
currentEpoch-params.BeaconConfig().GenesisEpoch,
)
}
}
// Shuffling shuffles input validator indices and splits them by slot and shard.
//
// Spec pseudocode definition:
// def get_shuffling(seed: Bytes32,
// validators: List[Validator],
// epoch: Epoch) -> List[List[ValidatorIndex]]
// """
// Shuffle ``validators`` into crosslink committees seeded by ``seed`` and ``epoch``.
// Return a list of ``committees_per_epoch`` committees where each
// committee is itself a list of validator indices.
// """
//
// active_validator_indices = get_active_validator_indices(validators, epoch)
//
// committees_per_epoch = get_epoch_committee_count(len(active_validator_indices))
//
// # Shuffle
// seed = xor(seed, int_to_bytes32(epoch))
// shuffled_active_validator_indices = shuffle(active_validator_indices, seed)
//
// # Split the shuffled list into committees_per_epoch pieces
// return split(shuffled_active_validator_indices, committees_per_epoch)
func Shuffling(
seed [32]byte,
validators []*pb.Validator,
slot uint64) ([][]uint64, error) {
// Normalize slot to start of epoch boundary.
slot -= slot % params.BeaconConfig().SlotsPerEpoch
// Figure out how many committees can be in a single slot.
activeIndices := ActiveValidatorIndices(validators, slot)
activeCount := uint64(len(activeIndices))
committeesPerEpoch := EpochCommitteeCount(activeCount)
// Convert slot to bytes and xor it with seed.
slotInBytes := make([]byte, 32)
binary.LittleEndian.PutUint64(slotInBytes, slot)
seed = bytesutil.ToBytes32(bytesutil.Xor(seed[:], slotInBytes))
shuffledIndices, err := utils.ShuffleIndices(seed, activeIndices)
if err != nil {
return nil, err
}
// Split the shuffled list into epoch_length * committees_per_slot pieces.
return utils.SplitIndices(shuffledIndices, committeesPerEpoch), nil
}
// AttestationParticipants returns the attesting participants indices.
//
// Spec pseudocode definition:
// def get_attestation_participants(state: BeaconState,
// attestation_data: AttestationData,
// bitfield: bytes) -> List[ValidatorIndex]:
// """
// Returns the participant indices at for the ``attestation_data`` and ``bitfield``.
// """
// # Find the committee in the list with the desired shard
// crosslink_committees = get_crosslink_committees_at_slot(state, attestation_data.slot)
//
// assert attestation_data.shard in [shard for _, shard in crosslink_committees]
// crosslink_committee = [committee for committee,
// shard in crosslink_committees if shard == attestation_data.shard][0]
//
// assert verify_bitfield(bitfield, len(crosslink_committee))
//
// # Find the participating attesters in the committee
// participants = []
// for i, validator_index in enumerate(crosslink_committee):
// aggregation_bit = get_bitfield_bit(bitfield, i)
// if aggregation_bit == 0b1:
// participants.append(validator_index)
// return participants
func AttestationParticipants(
state *pb.BeaconState,
attestationData *pb.AttestationData,
bitfield []byte) ([]uint64, error) {
// Find the relevant committee.
// RegistryChange is a no-op when requesting slot in current and previous epoch.
// AttestationParticipants is used to calculate justification and finality hence won't be used
// to request crosslink commitees of future epoch.
crosslinkCommittees, err := CrosslinkCommitteesAtSlot(state, attestationData.Slot, false /* registryChange */)
if err != nil {
return nil, err
}
var committee []uint64
for _, crosslinkCommittee := range crosslinkCommittees {
if crosslinkCommittee.Shard == attestationData.Shard {
committee = crosslinkCommittee.Committee
break
}
}
if isValidated, err := VerifyBitfield(bitfield, len(committee)); !isValidated || err != nil {
if err != nil {
return nil, err
}
return nil, errors.New("bitfield is unable to be verified")
}
// Find the participating validators in the committee.
var participants []uint64
for i, validatorIndex := range committee {
bitSet, err := bitutil.CheckBit(bitfield, i)
if err != nil {
return nil, fmt.Errorf("could not get participant bitfield: %v", err)
}
if bitSet {
participants = append(participants, validatorIndex)
}
}
return participants, nil
}
// VerifyBitfield validates a bitfield with a given committee size.
//
// Spec pseudocode:
//
// def verify_bitfield(bitfield: bytes, committee_size: int) -> bool:
// """
// Verify ``bitfield`` against the ``committee_size``.
// """
// if len(bitfield) != (committee_size + 7) // 8:
// return False
//
// # Check `bitfield` is padded with zero bits only
// for i in range(committee_size, len(bitfield) * 8):
// if get_bitfield_bit(bitfield, i) == 0b1:
// return False
//
// return True
func VerifyBitfield(bitfield []byte, committeeSize int) (bool, error) {
if len(bitfield) != mathutil.CeilDiv8(committeeSize) {
return false, fmt.Errorf(
"wanted participants bitfield length %d, got: %d",
mathutil.CeilDiv8(committeeSize),
len(bitfield))
}
for i := committeeSize; i < len(bitfield)*8; i++ {
bitSet, err := bitutil.CheckBit(bitfield, i)
if err != nil {
return false, fmt.Errorf("unable to check bit in bitfield %v", err)
}
if bitSet {
return false, nil
}
}
return true, nil
}
// CommitteeAssignment is used to query committee assignment from
// current and previous epoch.
//
// Spec pseudocode definition:
// def get_committee_assignment(
// state: BeaconState,
// epoch: Epoch,
// validator_index: ValidatorIndex,
// registry_change: bool=False) -> Tuple[List[ValidatorIndex], Shard, Slot, bool]:
// """
// Return the committee assignment in the ``epoch`` for ``validator_index`` and ``registry_change``.
// ``assignment`` returned is a tuple of the following form:
// * ``assignment[0]`` is the list of validators in the committee
// * ``assignment[1]`` is the shard to which the committee is assigned
// * ``assignment[2]`` is the slot at which the committee is assigned
// * ``assignment[3]`` is a bool signalling if the validator is expected to propose
// a beacon block at the assigned slot.
// """
// previous_epoch = get_previous_epoch(state)
// next_epoch = get_current_epoch(state)
// assert previous_epoch <= epoch <= next_epoch
//
// epoch_start_slot = get_epoch_start_slot(epoch)
// for slot in range(epoch_start_slot, epoch_start_slot + SLOTS_PER_EPOCH):
// crosslink_committees = get_crosslink_committees_at_slot(
// state,
// slot,
// registry_change=registry_change,
// )
// selected_committees = [
// committee # Tuple[List[ValidatorIndex], Shard]
// for committee in crosslink_committees
// if validator_index in committee[0]
// ]
// if len(selected_committees) > 0:
// validators = selected_committees[0][0]
// shard = selected_committees[0][1]
// first_committee_at_slot = crosslink_committees[0][0] # List[ValidatorIndex]
// is_proposer = first_committee_at_slot[slot % len(first_committee_at_slot)] == validator_index
//
// assignment = (validators, shard, slot, is_proposer)
// return assignment
func CommitteeAssignment(
state *pb.BeaconState,
slot uint64,
validatorIndex uint64,
registryChange bool) ([]uint64, uint64, uint64, bool, error) {
var selectedCommittees []*CrosslinkCommittee
wantedEpoch := slot / params.BeaconConfig().SlotsPerEpoch
prevEpoch := PrevEpoch(state)
nextEpoch := NextEpoch(state)
if wantedEpoch < prevEpoch || wantedEpoch > nextEpoch {
return nil, 0, 0, false, fmt.Errorf(
"epoch %d out of bounds: %d <= epoch <= %d",
wantedEpoch-params.BeaconConfig().GenesisEpoch,
prevEpoch-params.BeaconConfig().GenesisEpoch,
nextEpoch-params.BeaconConfig().GenesisEpoch,
)
}
startSlot := StartSlot(wantedEpoch)
for slot := startSlot; slot < startSlot+params.BeaconConfig().SlotsPerEpoch; slot++ {
crosslinkCommittees, err := CrosslinkCommitteesAtSlot(
state, slot, registryChange)
if err != nil {
return []uint64{}, 0, 0, false, fmt.Errorf("could not get crosslink committee: %v", err)
}
for _, committee := range crosslinkCommittees {
for _, idx := range committee.Committee {
if idx == validatorIndex {
selectedCommittees = append(selectedCommittees, committee)
}
if len(selectedCommittees) > 0 {
validators := selectedCommittees[0].Committee
shard := selectedCommittees[0].Shard
firstCommitteeAtSlot := crosslinkCommittees[0].Committee
isProposer := firstCommitteeAtSlot[slot%
uint64(len(firstCommitteeAtSlot))] == validatorIndex
return validators, shard, slot, isProposer, nil
}
}
}
}
return []uint64{}, 0, 0, false, status.Error(codes.NotFound, "validator not found found in assignments")
}
// prevEpochCommitteesAtSlot returns a list of crosslink committees of the previous epoch.
//
// Spec pseudocode definition:
// def get_previous_epoch_committees_at_slot(state: BeaconState,
// slot: Slot) -> List[Tuple[List[ValidatorIndex], Shard]]:
// committees_per_epoch = get_previous_epoch_committee_count(state)
// seed = state.previous_shuffling_seed
// shuffling_epoch = state.previous_shuffling_epoch
// shuffling_start_shard = state.previous_shuffling_start_shard
// return get_crosslink_committees(
// state,
// seed,
// shuffling_epoch,
// slot,
// start_shard,
// committees_per_epoch,
// )
func prevEpochCommitteesAtSlot(state *pb.BeaconState, slot uint64) ([]*CrosslinkCommittee, error) {
committeesPerEpoch := PrevEpochCommitteeCount(state)
return crosslinkCommittees(
state, &shufflingInput{
seed: state.PreviousShufflingSeedHash32,
shufflingEpoch: state.PreviousShufflingEpoch,
slot: slot,
startShard: state.PreviousShufflingStartShard,
committeesPerEpoch: committeesPerEpoch,
})
}
// currEpochCommitteesAtSlot returns a list of crosslink committees of the current epoch.
//
// Spec pseudocode definition:
// def get_current_epoch_committees_at_slot(state: BeaconState,
// slot: Slot) -> List[Tuple[List[ValidatorIndex], Shard]]:
// committees_per_epoch = get_current_epoch_committee_count(state)
// seed = state.current_shuffling_seed
// shuffling_epoch = state.current_shuffling_epoch
// shuffling_start_shard = state.current_shuffling_start_shard
// return get_crosslink_committees(
// state,
// seed,
// shuffling_epoch,
// slot,
// start_shard,
// committees_per_epoch,
// )
func currEpochCommitteesAtSlot(state *pb.BeaconState, slot uint64) ([]*CrosslinkCommittee, error) {
committeesPerEpoch := CurrentEpochCommitteeCount(state)
return crosslinkCommittees(
state, &shufflingInput{
seed: state.CurrentShufflingSeedHash32,
shufflingEpoch: state.CurrentShufflingEpoch,
slot: slot,
startShard: state.CurrentShufflingStartShard,
committeesPerEpoch: committeesPerEpoch,
})
}
// nextEpochCommitteesAtSlot returns a list of crosslink committees of the next epoch.
//
// Spec pseudocode definition:
// def get_next_epoch_committees_at_slot(state: BeaconState,
// slot: Slot,
// registry_change: bool) -> List[Tuple[List[ValidatorIndex], Shard]]:
// epochs_since_last_registry_update = current_epoch - state.validator_registry_update_epoch
// if registry_change:
// committees_per_epoch = get_next_epoch_committee_count(state)
// seed = generate_seed(state, next_epoch)
// shuffling_epoch = next_epoch
// current_committees_per_epoch = get_current_epoch_committee_count(state)
// shuffling_start_shard = (state.current_shuffling_start_shard + current_committees_per_epoch) % SHARD_COUNT
// elif epochs_since_last_registry_update > 1 and is_power_of_two(epochs_since_last_registry_update):
// committees_per_epoch = get_next_epoch_committee_count(state)
// seed = generate_seed(state, next_epoch)
// shuffling_epoch = next_epoch
// shuffling_start_shard = state.current_shuffling_start_shard
// else:
// committees_per_epoch = get_current_epoch_committee_count(state)
// seed = state.current_shuffling_seed
// shuffling_epoch = state.current_shuffling_epoch
// shuffling_start_shard = state.current_shuffling_start_shard
//
// return get_crosslink_committees(
// state,
// seed,
// shuffling_epoch,
// slot,
// start_shard,
// committees_per_epoch,
// )
func nextEpochCommitteesAtSlot(state *pb.BeaconState, slot uint64, registryChange bool) ([]*CrosslinkCommittee, error) {
var committeesPerEpoch uint64
var shufflingEpoch uint64
var shufflingStartShard uint64
var seed [32]byte
var err error
epochsSinceLastUpdate := CurrentEpoch(state) - state.ValidatorRegistryUpdateEpoch
if registryChange {
committeesPerEpoch = NextEpochCommitteeCount(state)
shufflingEpoch = NextEpoch(state)
seed, err = GenerateSeed(state, shufflingEpoch)
if err != nil {
return nil, fmt.Errorf("could not generate seed: %v", err)
}
shufflingStartShard = (state.CurrentShufflingStartShard + CurrentEpochCommitteeCount(state)) %
params.BeaconConfig().ShardCount
} else if epochsSinceLastUpdate > 1 &&
mathutil.IsPowerOf2(epochsSinceLastUpdate) {
committeesPerEpoch = NextEpochCommitteeCount(state)
shufflingEpoch = NextEpoch(state)
seed, err = GenerateSeed(state, shufflingEpoch)
if err != nil {
return nil, fmt.Errorf("could not generate seed: %v", err)
}
shufflingStartShard = state.CurrentShufflingStartShard
} else {
committeesPerEpoch = CurrentEpochCommitteeCount(state)
seed = bytesutil.ToBytes32(state.CurrentShufflingSeedHash32)
shufflingEpoch = state.CurrentShufflingEpoch
shufflingStartShard = state.CurrentShufflingStartShard
}
return crosslinkCommittees(
state, &shufflingInput{
seed: seed[:],
shufflingEpoch: shufflingEpoch,
slot: slot,
startShard: shufflingStartShard,
committeesPerEpoch: committeesPerEpoch,
})
}
// crosslinkCommittees breaks down the shuffled indices into list of crosslink committee structs
// which contains of validator indices and the shard they are assigned to.
//
// Spec pseudocode definition:
// def get_crosslink_committees(state: BeaconState,
// seed: Bytes32,
// shuffling_epoch: Epoch,
// slot: Slot,
// start_shard: Shard,
// committees_per_epoch: int) -> List[Tuple[List[ValidatorIndex], Shard]]:
// offset = slot % SLOTS_PER_EPOCH
// committees_per_slot = committees_per_epoch // SLOTS_PER_EPOCH
// slot_start_shard = (shuffling_start_shard + committees_per_slot * offset) % SHARD_COUNT
//
// shuffling = get_shuffling(
// seed,
// state.validator_registry,
// shuffling_epoch,
// )
//
// return [
// (
// shuffling[committees_per_slot * offset + i],
// (slot_start_shard + i) % SHARD_COUNT,
// )
// for i in range(committees_per_slot)
// ]
func crosslinkCommittees(state *pb.BeaconState, input *shufflingInput) ([]*CrosslinkCommittee, error) {
slotsPerEpoch := params.BeaconConfig().SlotsPerEpoch
offSet := input.slot % slotsPerEpoch
committeesPerSlot := input.committeesPerEpoch / slotsPerEpoch
slotStartShard := (input.startShard + committeesPerSlot*offSet) %
params.BeaconConfig().ShardCount
shuffledIndices, err := Shuffling(
bytesutil.ToBytes32(input.seed),
state.ValidatorRegistry,
input.shufflingEpoch)
if err != nil {
return nil, err
}
var crosslinkCommittees []*CrosslinkCommittee
for i := uint64(0); i < committeesPerSlot; i++ {
crosslinkCommittees = append(crosslinkCommittees, &CrosslinkCommittee{
Committee: shuffledIndices[committeesPerSlot*offSet+i],
Shard: (slotStartShard + i) % params.BeaconConfig().ShardCount,
})
}
return crosslinkCommittees, nil
}