Unused parameter should be replaced by underscore (#9632)

Co-authored-by: deepsource-autofix[bot] <62050782+deepsource-autofix[bot]@users.noreply.github.com>
Co-authored-by: prylabs-bulldozer[bot] <58059840+prylabs-bulldozer[bot]@users.noreply.github.com>
Co-authored-by: terence tsao <terence@prysmaticlabs.com>
This commit is contained in:
deepsource-autofix[bot] 2021-09-20 20:51:59 +00:00 committed by GitHub
parent 728c77cc0c
commit 531f05d30d
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
31 changed files with 245 additions and 245 deletions

View File

@ -50,7 +50,7 @@ func TestGetChan(t *testing.T) {
assert.Equal(ch1, ch3) assert.Equal(ch1, ch3)
} }
func TestLockUnlock(t *testing.T) { func TestLockUnlock(_ *testing.T) {
var wg sync.WaitGroup var wg sync.WaitGroup
wg.Add(5) wg.Add(5)

View File

@ -298,7 +298,7 @@ func (s *Service) HeadPublicKeyToValidatorIndex(ctx context.Context, pubKey [48]
} }
// HeadValidatorIndexToPublicKey returns the pubkey of the validator `index` in current head state. // HeadValidatorIndexToPublicKey returns the pubkey of the validator `index` in current head state.
func (s *Service) HeadValidatorIndexToPublicKey(ctx context.Context, index types.ValidatorIndex) ([48]byte, error) { func (s *Service) HeadValidatorIndexToPublicKey(_ context.Context, index types.ValidatorIndex) ([48]byte, error) {
s.headLock.RLock() s.headLock.RLock()
defer s.headLock.RUnlock() defer s.headLock.RUnlock()

View File

@ -400,36 +400,36 @@ func (s *ChainService) ChainHeads() ([][32]byte, []types.Slot) {
} }
// HeadPublicKeyToValidatorIndex mocks HeadPublicKeyToValidatorIndex and always return 0 and true. // HeadPublicKeyToValidatorIndex mocks HeadPublicKeyToValidatorIndex and always return 0 and true.
func (s *ChainService) HeadPublicKeyToValidatorIndex(ctx context.Context, pubKey [48]byte) (types.ValidatorIndex, bool) { func (s *ChainService) HeadPublicKeyToValidatorIndex(_ context.Context, _ [48]byte) (types.ValidatorIndex, bool) {
return 0, true return 0, true
} }
// HeadValidatorIndexToPublicKey mocks HeadValidatorIndexToPublicKey and always return empty and nil. // HeadValidatorIndexToPublicKey mocks HeadValidatorIndexToPublicKey and always return empty and nil.
func (s *ChainService) HeadValidatorIndexToPublicKey(ctx context.Context, index types.ValidatorIndex) ([48]byte, error) { func (s *ChainService) HeadValidatorIndexToPublicKey(_ context.Context, _ types.ValidatorIndex) ([48]byte, error) {
return s.PublicKey, nil return s.PublicKey, nil
} }
// HeadSyncCommitteeIndices mocks HeadSyncCommitteeIndices and always return `HeadNextSyncCommitteeIndices`. // HeadSyncCommitteeIndices mocks HeadSyncCommitteeIndices and always return `HeadNextSyncCommitteeIndices`.
func (s *ChainService) HeadSyncCommitteeIndices(ctx context.Context, index types.ValidatorIndex, slot types.Slot) ([]types.CommitteeIndex, error) { func (s *ChainService) HeadSyncCommitteeIndices(_ context.Context, index types.ValidatorIndex, slot types.Slot) ([]types.CommitteeIndex, error) {
return s.SyncCommitteeIndices, nil return s.SyncCommitteeIndices, nil
} }
// HeadSyncCommitteePubKeys mocks HeadSyncCommitteePubKeys and always return empty nil. // HeadSyncCommitteePubKeys mocks HeadSyncCommitteePubKeys and always return empty nil.
func (s *ChainService) HeadSyncCommitteePubKeys(ctx context.Context, slot types.Slot, committeeIndex types.CommitteeIndex) ([][]byte, error) { func (s *ChainService) HeadSyncCommitteePubKeys(_ context.Context, _ types.Slot, _ types.CommitteeIndex) ([][]byte, error) {
return s.SyncCommitteePubkeys, nil return s.SyncCommitteePubkeys, nil
} }
// HeadSyncCommitteeDomain mocks HeadSyncCommitteeDomain and always return empty nil. // HeadSyncCommitteeDomain mocks HeadSyncCommitteeDomain and always return empty nil.
func (s *ChainService) HeadSyncCommitteeDomain(ctx context.Context, slot types.Slot) ([]byte, error) { func (s *ChainService) HeadSyncCommitteeDomain(_ context.Context, _ types.Slot) ([]byte, error) {
return s.SyncCommitteeDomain, nil return s.SyncCommitteeDomain, nil
} }
// HeadSyncSelectionProofDomain mocks HeadSyncSelectionProofDomain and always return empty nil. // HeadSyncSelectionProofDomain mocks HeadSyncSelectionProofDomain and always return empty nil.
func (s *ChainService) HeadSyncSelectionProofDomain(ctx context.Context, slot types.Slot) ([]byte, error) { func (s *ChainService) HeadSyncSelectionProofDomain(_ context.Context, _ types.Slot) ([]byte, error) {
return s.SyncSelectionProofDomain, nil return s.SyncSelectionProofDomain, nil
} }
// HeadSyncContributionProofDomain mocks HeadSyncContributionProofDomain and always return empty nil. // HeadSyncContributionProofDomain mocks HeadSyncContributionProofDomain and always return empty nil.
func (s *ChainService) HeadSyncContributionProofDomain(ctx context.Context, slot types.Slot) ([]byte, error) { func (s *ChainService) HeadSyncContributionProofDomain(_ context.Context, _ types.Slot) ([]byte, error) {
return s.SyncContributionProofDomain, nil return s.SyncContributionProofDomain, nil
} }

View File

@ -108,7 +108,7 @@ func TestSigningRoot_ComputeForkDigest(t *testing.T) {
} }
} }
func TestFuzzverifySigningRoot_10000(t *testing.T) { func TestFuzzverifySigningRoot_10000(_ *testing.T) {
fuzzer := fuzz.NewWithSeed(0) fuzzer := fuzz.NewWithSeed(0)
state := &ethpb.BeaconState{} state := &ethpb.BeaconState{}
pubkey := [48]byte{} pubkey := [48]byte{}

View File

@ -19,7 +19,7 @@ var SkipSlotCache = cache.NewSkipSlotCache()
// The key for skip slot cache is mixed between state root and state slot. // The key for skip slot cache is mixed between state root and state slot.
// state root is in the mix to defend against different forks with same skip slots // state root is in the mix to defend against different forks with same skip slots
// to hit the same cache. We don't want beacon states mixed up between different chains. // to hit the same cache. We don't want beacon states mixed up between different chains.
func cacheKey(ctx context.Context, state state.ReadOnlyBeaconState) ([32]byte, error) { func cacheKey(_ context.Context, state state.ReadOnlyBeaconState) ([32]byte, error) {
bh := state.LatestBlockHeader() bh := state.LatestBlockHeader()
if bh == nil { if bh == nil {
return [32]byte{}, errors.New("block head in state can't be nil") return [32]byte{}, errors.New("block head in state can't be nil")

View File

@ -53,7 +53,7 @@ func TestOptimizedGenesisBeaconState_1000(t *testing.T) {
} }
} }
func TestIsValidGenesisState_100000(t *testing.T) { func TestIsValidGenesisState_100000(_ *testing.T) {
SkipSlotCache.Disable() SkipSlotCache.Disable()
defer SkipSlotCache.Enable() defer SkipSlotCache.Enable()
fuzzer := fuzz.NewWithSeed(0) fuzzer := fuzz.NewWithSeed(0)

View File

@ -32,7 +32,7 @@ var (
// NextSlotState returns the saved state if the input root matches the root in `nextSlotCache`. Returns nil otherwise. // NextSlotState returns the saved state if the input root matches the root in `nextSlotCache`. Returns nil otherwise.
// This is useful to check before processing slots. With a cache hit, it will return last processed state with slot plus // This is useful to check before processing slots. With a cache hit, it will return last processed state with slot plus
// one advancement. // one advancement.
func NextSlotState(ctx context.Context, root []byte) (state.BeaconState, error) { func NextSlotState(_ context.Context, root []byte) (state.BeaconState, error) {
nsc.RLock() nsc.RLock()
defer nsc.RUnlock() defer nsc.RUnlock()
if !bytes.Equal(root, nsc.root) { if !bytes.Equal(root, nsc.root) {

View File

@ -99,7 +99,7 @@ func TestFuzzprocessOperationsNoVerify_1000(t *testing.T) {
} }
} }
func TestFuzzverifyOperationLengths_10000(t *testing.T) { func TestFuzzverifyOperationLengths_10000(_ *testing.T) {
SkipSlotCache.Disable() SkipSlotCache.Disable()
defer SkipSlotCache.Enable() defer SkipSlotCache.Enable()
state := &v1.BeaconState{} state := &v1.BeaconState{}
@ -114,7 +114,7 @@ func TestFuzzverifyOperationLengths_10000(t *testing.T) {
} }
} }
func TestFuzzCanProcessEpoch_10000(t *testing.T) { func TestFuzzCanProcessEpoch_10000(_ *testing.T) {
SkipSlotCache.Disable() SkipSlotCache.Disable()
defer SkipSlotCache.Enable() defer SkipSlotCache.Enable()
state := &v1.BeaconState{} state := &v1.BeaconState{}

View File

@ -594,7 +594,7 @@ func createBlockIndicesFromFilters(ctx context.Context, f *filters.QueryFilter)
} }
// unmarshal block from marshaled proto beacon block bytes to versioned beacon block struct type. // unmarshal block from marshaled proto beacon block bytes to versioned beacon block struct type.
func unmarshalBlock(ctx context.Context, enc []byte) (block.SignedBeaconBlock, error) { func unmarshalBlock(_ context.Context, enc []byte) (block.SignedBeaconBlock, error) {
var err error var err error
enc, err = snappy.Decode(nil, enc) enc, err = snappy.Decode(nil, enc)
if err != nil { if err != nil {
@ -621,7 +621,7 @@ func unmarshalBlock(ctx context.Context, enc []byte) (block.SignedBeaconBlock, e
} }
// marshal versioned beacon block from struct type down to bytes. // marshal versioned beacon block from struct type down to bytes.
func marshalBlock(ctx context.Context, blk block.SignedBeaconBlock) ([]byte, error) { func marshalBlock(_ context.Context, blk block.SignedBeaconBlock) ([]byte, error) {
obj, err := blk.MarshalSSZ() obj, err := blk.MarshalSSZ()
if err != nil { if err != nil {
return nil, err return nil, err

View File

@ -377,7 +377,7 @@ func (s *Store) DeleteStates(ctx context.Context, blockRoots [][32]byte) error {
} }
// unmarshal state from marshaled proto state bytes to versioned state struct type. // unmarshal state from marshaled proto state bytes to versioned state struct type.
func (s *Store) unmarshalState(ctx context.Context, enc []byte, validatorEntries []*ethpb.Validator) (state.BeaconState, error) { func (s *Store) unmarshalState(_ context.Context, enc []byte, validatorEntries []*ethpb.Validator) (state.BeaconState, error) {
var err error var err error
enc, err = snappy.Decode(nil, enc) enc, err = snappy.Decode(nil, enc)
if err != nil { if err != nil {

View File

@ -14,7 +14,7 @@ import (
// PruneAttestationsAtEpoch deletes all attestations from the slasher DB with target epoch // PruneAttestationsAtEpoch deletes all attestations from the slasher DB with target epoch
// less than or equal to the specified epoch. // less than or equal to the specified epoch.
func (s *Store) PruneAttestationsAtEpoch( func (s *Store) PruneAttestationsAtEpoch(
ctx context.Context, maxEpoch types.Epoch, _ context.Context, maxEpoch types.Epoch,
) (numPruned uint, err error) { ) (numPruned uint, err error) {
// We can prune everything less than the current epoch - history length. // We can prune everything less than the current epoch - history length.
encodedEndPruneEpoch := fssz.MarshalUint64([]byte{}, uint64(maxEpoch)) encodedEndPruneEpoch := fssz.MarshalUint64([]byte{}, uint64(maxEpoch))
@ -85,7 +85,7 @@ func (s *Store) PruneAttestationsAtEpoch(
// PruneProposalsAtEpoch deletes all proposals from the slasher DB with epoch // PruneProposalsAtEpoch deletes all proposals from the slasher DB with epoch
// less than or equal to the specified epoch. // less than or equal to the specified epoch.
func (s *Store) PruneProposalsAtEpoch( func (s *Store) PruneProposalsAtEpoch(
ctx context.Context, maxEpoch types.Epoch, _ context.Context, maxEpoch types.Epoch,
) (numPruned uint, err error) { ) (numPruned uint, err error) {
var endPruneSlot types.Slot var endPruneSlot types.Slot
endPruneSlot, err = core.EndSlot(maxEpoch) endPruneSlot, err = core.EndSlot(maxEpoch)

View File

@ -148,6 +148,6 @@ func NewPowchainCollector(ctx context.Context) (*PowchainCollector, error) {
type NopBeaconNodeStatsUpdater struct{} type NopBeaconNodeStatsUpdater struct{}
func (nop *NopBeaconNodeStatsUpdater) Update(stats clientstats.BeaconNodeStats) {} func (nop *NopBeaconNodeStatsUpdater) Update(_ clientstats.BeaconNodeStats) {}
var _ BeaconNodeStatsUpdater = &NopBeaconNodeStatsUpdater{} var _ BeaconNodeStatsUpdater = &NopBeaconNodeStatsUpdater{}

View File

@ -383,7 +383,7 @@ func (s *Service) AreAllDepositsProcessed() (bool, error) {
// refers to the latest eth1 block which follows the condition: eth1_timestamp + // refers to the latest eth1 block which follows the condition: eth1_timestamp +
// SECONDS_PER_ETH1_BLOCK * ETH1_FOLLOW_DISTANCE <= current_unix_time // SECONDS_PER_ETH1_BLOCK * ETH1_FOLLOW_DISTANCE <= current_unix_time
func (s *Service) followBlockHeight(ctx context.Context) (uint64, error) { func (s *Service) followBlockHeight(_ context.Context) (uint64, error) {
latestValidBlock := uint64(0) latestValidBlock := uint64(0)
if s.latestEth1Data.BlockHeight > params.BeaconConfig().Eth1FollowDistance { if s.latestEth1Data.BlockHeight > params.BeaconConfig().Eth1FollowDistance {
latestValidBlock = s.latestEth1Data.BlockHeight - params.BeaconConfig().Eth1FollowDistance latestValidBlock = s.latestEth1Data.BlockHeight - params.BeaconConfig().Eth1FollowDistance

View File

@ -134,7 +134,7 @@ func (bs *Server) SubmitAttestations(ctx context.Context, req *ethpbv1.SubmitAtt
// ListPoolAttesterSlashings retrieves attester slashings known by the node but // ListPoolAttesterSlashings retrieves attester slashings known by the node but
// not necessarily incorporated into any block. // not necessarily incorporated into any block.
func (bs *Server) ListPoolAttesterSlashings(ctx context.Context, req *emptypb.Empty) (*ethpbv1.AttesterSlashingsPoolResponse, error) { func (bs *Server) ListPoolAttesterSlashings(ctx context.Context, _ *emptypb.Empty) (*ethpbv1.AttesterSlashingsPoolResponse, error) {
ctx, span := trace.StartSpan(ctx, "beacon.ListPoolAttesterSlashings") ctx, span := trace.StartSpan(ctx, "beacon.ListPoolAttesterSlashings")
defer span.End() defer span.End()
@ -186,7 +186,7 @@ func (bs *Server) SubmitAttesterSlashing(ctx context.Context, req *ethpbv1.Attes
// ListPoolProposerSlashings retrieves proposer slashings known by the node // ListPoolProposerSlashings retrieves proposer slashings known by the node
// but not necessarily incorporated into any block. // but not necessarily incorporated into any block.
func (bs *Server) ListPoolProposerSlashings(ctx context.Context, req *emptypb.Empty) (*ethpbv1.ProposerSlashingPoolResponse, error) { func (bs *Server) ListPoolProposerSlashings(ctx context.Context, _ *emptypb.Empty) (*ethpbv1.ProposerSlashingPoolResponse, error) {
ctx, span := trace.StartSpan(ctx, "beacon.ListPoolProposerSlashings") ctx, span := trace.StartSpan(ctx, "beacon.ListPoolProposerSlashings")
defer span.End() defer span.End()
@ -238,7 +238,7 @@ func (bs *Server) SubmitProposerSlashing(ctx context.Context, req *ethpbv1.Propo
// ListPoolVoluntaryExits retrieves voluntary exits known by the node but // ListPoolVoluntaryExits retrieves voluntary exits known by the node but
// not necessarily incorporated into any block. // not necessarily incorporated into any block.
func (bs *Server) ListPoolVoluntaryExits(ctx context.Context, req *emptypb.Empty) (*ethpbv1.VoluntaryExitsPoolResponse, error) { func (bs *Server) ListPoolVoluntaryExits(ctx context.Context, _ *emptypb.Empty) (*ethpbv1.VoluntaryExitsPoolResponse, error) {
ctx, span := trace.StartSpan(ctx, "beacon.ListPoolVoluntaryExits") ctx, span := trace.StartSpan(ctx, "beacon.ListPoolVoluntaryExits")
defer span.End() defer span.End()

View File

@ -263,7 +263,7 @@ func (bs *Server) ListBlocksForEpoch(ctx context.Context, req *ethpb.ListBlocksR
} }
// ListBlocksForRoot retrieves the block for the provided root. // ListBlocksForRoot retrieves the block for the provided root.
func (bs *Server) ListBlocksForRoot(ctx context.Context, req *ethpb.ListBlocksRequest, q *ethpb.ListBlocksRequest_Root) ([]blockContainer, int, string, error) { func (bs *Server) ListBlocksForRoot(ctx context.Context, _ *ethpb.ListBlocksRequest, q *ethpb.ListBlocksRequest_Root) ([]blockContainer, int, string, error) {
blk, err := bs.BeaconDB.Block(ctx, bytesutil.ToBytes32(q.Root)) blk, err := bs.BeaconDB.Block(ctx, bytesutil.ToBytes32(q.Root))
if err != nil { if err != nil {
return nil, 0, strconv.Itoa(0), status.Errorf(codes.Internal, "Could not retrieve block: %v", err) return nil, 0, strconv.Itoa(0), status.Errorf(codes.Internal, "Could not retrieve block: %v", err)
@ -325,7 +325,7 @@ func (bs *Server) ListBlocksForSlot(ctx context.Context, req *ethpb.ListBlocksRe
} }
// ListBlocksForGenesis retrieves the genesis block. // ListBlocksForGenesis retrieves the genesis block.
func (bs *Server) ListBlocksForGenesis(ctx context.Context, req *ethpb.ListBlocksRequest, q *ethpb.ListBlocksRequest_Genesis) ([]blockContainer, int, string, error) { func (bs *Server) ListBlocksForGenesis(ctx context.Context, _ *ethpb.ListBlocksRequest, _ *ethpb.ListBlocksRequest_Genesis) ([]blockContainer, int, string, error) {
genBlk, err := bs.BeaconDB.GenesisBlock(ctx) genBlk, err := bs.BeaconDB.GenesisBlock(ctx)
if err != nil { if err != nil {
return nil, 0, strconv.Itoa(0), status.Errorf(codes.Internal, "Could not retrieve blocks for genesis slot: %v", err) return nil, 0, strconv.Itoa(0), status.Errorf(codes.Internal, "Could not retrieve blocks for genesis slot: %v", err)

View File

@ -24,79 +24,79 @@ func NewMockService() *MockStateManager {
} }
// Resume -- // Resume --
func (m *MockStateManager) Resume(ctx context.Context) (state.BeaconState, error) { func (m *MockStateManager) Resume(_ context.Context) (state.BeaconState, error) {
panic("implement me") panic("implement me")
} }
// SaveFinalizedState -- // SaveFinalizedState --
func (m *MockStateManager) SaveFinalizedState(fSlot types.Slot, fRoot [32]byte, fState state.BeaconState) { func (m *MockStateManager) SaveFinalizedState(_ types.Slot, _ [32]byte, _ state.BeaconState) {
panic("implement me") panic("implement me")
} }
// MigrateToCold -- // MigrateToCold --
func (m *MockStateManager) MigrateToCold(ctx context.Context, fRoot [32]byte) error { func (m *MockStateManager) MigrateToCold(_ context.Context, _ [32]byte) error {
panic("implement me") panic("implement me")
} }
// ReplayBlocks -- // ReplayBlocks --
func (m *MockStateManager) ReplayBlocks( func (m *MockStateManager) ReplayBlocks(
ctx context.Context, _ context.Context,
state state.BeaconState, _ state.BeaconState,
signed []block.SignedBeaconBlock, _ []block.SignedBeaconBlock,
targetSlot types.Slot, _ types.Slot,
) (state.BeaconState, error) { ) (state.BeaconState, error) {
panic("implement me") panic("implement me")
} }
// LoadBlocks -- // LoadBlocks --
func (m *MockStateManager) LoadBlocks( func (m *MockStateManager) LoadBlocks(
ctx context.Context, _ context.Context,
startSlot, endSlot types.Slot, _, _ types.Slot,
endBlockRoot [32]byte, _ [32]byte,
) ([]block.SignedBeaconBlock, error) { ) ([]block.SignedBeaconBlock, error) {
panic("implement me") panic("implement me")
} }
// HasState -- // HasState --
func (m *MockStateManager) HasState(ctx context.Context, blockRoot [32]byte) (bool, error) { func (m *MockStateManager) HasState(_ context.Context, _ [32]byte) (bool, error) {
panic("implement me") panic("implement me")
} }
// HasStateInCache -- // HasStateInCache --
func (m *MockStateManager) HasStateInCache(ctx context.Context, blockRoot [32]byte) (bool, error) { func (m *MockStateManager) HasStateInCache(_ context.Context, _ [32]byte) (bool, error) {
panic("implement me") panic("implement me")
} }
// StateByRoot -- // StateByRoot --
func (m *MockStateManager) StateByRoot(ctx context.Context, blockRoot [32]byte) (state.BeaconState, error) { func (m *MockStateManager) StateByRoot(_ context.Context, blockRoot [32]byte) (state.BeaconState, error) {
return m.StatesByRoot[blockRoot], nil return m.StatesByRoot[blockRoot], nil
} }
// StateByRootInitialSync -- // StateByRootInitialSync --
func (m *MockStateManager) StateByRootInitialSync(ctx context.Context, blockRoot [32]byte) (state.BeaconState, error) { func (m *MockStateManager) StateByRootInitialSync(_ context.Context, _ [32]byte) (state.BeaconState, error) {
panic("implement me") panic("implement me")
} }
// StateBySlot -- // StateBySlot --
func (m *MockStateManager) StateBySlot(ctx context.Context, slot types.Slot) (state.BeaconState, error) { func (m *MockStateManager) StateBySlot(_ context.Context, slot types.Slot) (state.BeaconState, error) {
return m.StatesBySlot[slot], nil return m.StatesBySlot[slot], nil
} }
// RecoverStateSummary -- // RecoverStateSummary --
func (m *MockStateManager) RecoverStateSummary( func (m *MockStateManager) RecoverStateSummary(
ctx context.Context, _ context.Context,
blockRoot [32]byte, _ [32]byte,
) (*ethpb.StateSummary, error) { ) (*ethpb.StateSummary, error) {
panic("implement me") panic("implement me")
} }
// SaveState -- // SaveState --
func (m *MockStateManager) SaveState(ctx context.Context, root [32]byte, st state.BeaconState) error { func (m *MockStateManager) SaveState(_ context.Context, _ [32]byte, _ state.BeaconState) error {
panic("implement me") panic("implement me")
} }
// ForceCheckpoint -- // ForceCheckpoint --
func (m *MockStateManager) ForceCheckpoint(ctx context.Context, root []byte) error { func (m *MockStateManager) ForceCheckpoint(_ context.Context, _ []byte) error {
panic("implement me") panic("implement me")
} }
@ -106,7 +106,7 @@ func (m *MockStateManager) EnableSaveHotStateToDB(_ context.Context) {
} }
// DisableSaveHotStateToDB -- // DisableSaveHotStateToDB --
func (m *MockStateManager) DisableSaveHotStateToDB(ctx context.Context) error { func (m *MockStateManager) DisableSaveHotStateToDB(_ context.Context) error {
panic("implement me") panic("implement me")
} }

View File

@ -336,7 +336,7 @@ func (s *Service) deleteBlockFromPendingQueue(slot types.Slot, b block.SignedBea
// Insert block to the list in the pending queue using the slot as key. // Insert block to the list in the pending queue using the slot as key.
// Note: this helper is not thread safe. // Note: this helper is not thread safe.
func (s *Service) insertBlockToPendingQueue(slot types.Slot, b block.SignedBeaconBlock, r [32]byte) error { func (s *Service) insertBlockToPendingQueue(_ types.Slot, b block.SignedBeaconBlock, r [32]byte) error {
mutexasserts.AssertRWMutexLocked(&s.pendingQueueLock) mutexasserts.AssertRWMutexLocked(&s.pendingQueueLock)
if s.seenPendingBlocks[r] { if s.seenPendingBlocks[r] {

View File

@ -5,7 +5,7 @@ import (
"testing" "testing"
) )
func TestNewGenerator(t *testing.T) { func TestNewGenerator(_ *testing.T) {
// Make sure that generation works, no panics. // Make sure that generation works, no panics.
randGen := NewGenerator() randGen := NewGenerator()
_ = randGen.Int63() _ = randGen.Int63()
@ -14,7 +14,7 @@ func TestNewGenerator(t *testing.T) {
var _ = rand.Source64(randGen) var _ = rand.Source64(randGen)
} }
func TestNewDeterministicGenerator(t *testing.T) { func TestNewDeterministicGenerator(_ *testing.T) {
// Make sure that generation works, no panics. // Make sure that generation works, no panics.
randGen := NewDeterministicGenerator() randGen := NewDeterministicGenerator()
_ = randGen.Int63() _ = randGen.Int63()

View File

@ -24,7 +24,7 @@ type mockRT struct {
statusCode int statusCode int
} }
func (rt *mockRT) RoundTrip(req *http.Request) (*http.Response, error) { func (rt *mockRT) RoundTrip(_ *http.Request) (*http.Response, error) {
return &http.Response{ return &http.Response{
Status: http.StatusText(http.StatusOK), Status: http.StatusText(http.StatusOK),
StatusCode: http.StatusOK, StatusCode: http.StatusOK,

View File

@ -39,7 +39,7 @@ var _ = github_com_prysmaticlabs_eth2_types.Epoch(0)
var _ = emptypb.Empty{} var _ = emptypb.Empty{}
var _ = empty.Empty{} var _ = empty.Empty{}
func request_BeaconChain_GetGenesis_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetGenesis_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -48,7 +48,7 @@ func request_BeaconChain_GetGenesis_0(ctx context.Context, marshaler runtime.Mar
} }
func local_request_BeaconChain_GetGenesis_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetGenesis_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -57,7 +57,7 @@ func local_request_BeaconChain_GetGenesis_0(ctx context.Context, marshaler runti
} }
func request_BeaconChain_GetStateRoot_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetStateRoot_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateRequest var protoReq v1.StateRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -84,7 +84,7 @@ func request_BeaconChain_GetStateRoot_0(ctx context.Context, marshaler runtime.M
} }
func local_request_BeaconChain_GetStateRoot_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetStateRoot_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateRequest var protoReq v1.StateRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -111,7 +111,7 @@ func local_request_BeaconChain_GetStateRoot_0(ctx context.Context, marshaler run
} }
func request_BeaconChain_GetStateFork_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetStateFork_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateRequest var protoReq v1.StateRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -138,7 +138,7 @@ func request_BeaconChain_GetStateFork_0(ctx context.Context, marshaler runtime.M
} }
func local_request_BeaconChain_GetStateFork_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetStateFork_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateRequest var protoReq v1.StateRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -165,7 +165,7 @@ func local_request_BeaconChain_GetStateFork_0(ctx context.Context, marshaler run
} }
func request_BeaconChain_GetFinalityCheckpoints_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetFinalityCheckpoints_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateRequest var protoReq v1.StateRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -192,7 +192,7 @@ func request_BeaconChain_GetFinalityCheckpoints_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_GetFinalityCheckpoints_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetFinalityCheckpoints_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateRequest var protoReq v1.StateRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -223,7 +223,7 @@ var (
filter_BeaconChain_ListValidators_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}} filter_BeaconChain_ListValidators_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}}
) )
func request_BeaconChain_ListValidators_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListValidators_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateValidatorsRequest var protoReq v1.StateValidatorsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -257,7 +257,7 @@ func request_BeaconChain_ListValidators_0(ctx context.Context, marshaler runtime
} }
func local_request_BeaconChain_ListValidators_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListValidators_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateValidatorsRequest var protoReq v1.StateValidatorsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -291,7 +291,7 @@ func local_request_BeaconChain_ListValidators_0(ctx context.Context, marshaler r
} }
func request_BeaconChain_GetValidator_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetValidator_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateValidatorRequest var protoReq v1.StateValidatorRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -329,7 +329,7 @@ func request_BeaconChain_GetValidator_0(ctx context.Context, marshaler runtime.M
} }
func local_request_BeaconChain_GetValidator_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetValidator_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateValidatorRequest var protoReq v1.StateValidatorRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -371,7 +371,7 @@ var (
filter_BeaconChain_ListValidatorBalances_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}} filter_BeaconChain_ListValidatorBalances_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}}
) )
func request_BeaconChain_ListValidatorBalances_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListValidatorBalances_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ValidatorBalancesRequest var protoReq v1.ValidatorBalancesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -405,7 +405,7 @@ func request_BeaconChain_ListValidatorBalances_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_ListValidatorBalances_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListValidatorBalances_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ValidatorBalancesRequest var protoReq v1.ValidatorBalancesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -443,7 +443,7 @@ var (
filter_BeaconChain_ListCommittees_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}} filter_BeaconChain_ListCommittees_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}}
) )
func request_BeaconChain_ListCommittees_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListCommittees_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateCommitteesRequest var protoReq v1.StateCommitteesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -477,7 +477,7 @@ func request_BeaconChain_ListCommittees_0(ctx context.Context, marshaler runtime
} }
func local_request_BeaconChain_ListCommittees_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListCommittees_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.StateCommitteesRequest var protoReq v1.StateCommitteesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -515,7 +515,7 @@ var (
filter_BeaconChain_ListSyncCommittees_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}} filter_BeaconChain_ListSyncCommittees_0 = &utilities.DoubleArray{Encoding: map[string]int{"state_id": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}}
) )
func request_BeaconChain_ListSyncCommittees_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListSyncCommittees_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.StateSyncCommitteesRequest var protoReq eth.StateSyncCommitteesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -549,7 +549,7 @@ func request_BeaconChain_ListSyncCommittees_0(ctx context.Context, marshaler run
} }
func local_request_BeaconChain_ListSyncCommittees_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListSyncCommittees_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.StateSyncCommitteesRequest var protoReq eth.StateSyncCommitteesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -587,7 +587,7 @@ var (
filter_BeaconChain_ListBlockHeaders_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListBlockHeaders_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListBlockHeaders_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListBlockHeaders_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockHeadersRequest var protoReq v1.BlockHeadersRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -603,7 +603,7 @@ func request_BeaconChain_ListBlockHeaders_0(ctx context.Context, marshaler runti
} }
func local_request_BeaconChain_ListBlockHeaders_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListBlockHeaders_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockHeadersRequest var protoReq v1.BlockHeadersRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -619,7 +619,7 @@ func local_request_BeaconChain_ListBlockHeaders_0(ctx context.Context, marshaler
} }
func request_BeaconChain_GetBlockHeader_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBlockHeader_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -646,7 +646,7 @@ func request_BeaconChain_GetBlockHeader_0(ctx context.Context, marshaler runtime
} }
func local_request_BeaconChain_GetBlockHeader_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBlockHeader_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -673,7 +673,7 @@ func local_request_BeaconChain_GetBlockHeader_0(ctx context.Context, marshaler r
} }
func request_BeaconChain_SubmitBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BeaconBlockContainer var protoReq v1.BeaconBlockContainer
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -690,7 +690,7 @@ func request_BeaconChain_SubmitBlock_0(ctx context.Context, marshaler runtime.Ma
} }
func local_request_BeaconChain_SubmitBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BeaconBlockContainer var protoReq v1.BeaconBlockContainer
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -707,7 +707,7 @@ func local_request_BeaconChain_SubmitBlock_0(ctx context.Context, marshaler runt
} }
func request_BeaconChain_GetBlockRoot_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBlockRoot_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -734,7 +734,7 @@ func request_BeaconChain_GetBlockRoot_0(ctx context.Context, marshaler runtime.M
} }
func local_request_BeaconChain_GetBlockRoot_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBlockRoot_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -761,7 +761,7 @@ func local_request_BeaconChain_GetBlockRoot_0(ctx context.Context, marshaler run
} }
func request_BeaconChain_GetBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBlock_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -788,7 +788,7 @@ func request_BeaconChain_GetBlock_0(ctx context.Context, marshaler runtime.Marsh
} }
func local_request_BeaconChain_GetBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBlock_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -815,7 +815,7 @@ func local_request_BeaconChain_GetBlock_0(ctx context.Context, marshaler runtime
} }
func request_BeaconChain_GetBlockSSZ_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBlockSSZ_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -842,7 +842,7 @@ func request_BeaconChain_GetBlockSSZ_0(ctx context.Context, marshaler runtime.Ma
} }
func local_request_BeaconChain_GetBlockSSZ_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBlockSSZ_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -869,7 +869,7 @@ func local_request_BeaconChain_GetBlockSSZ_0(ctx context.Context, marshaler runt
} }
func request_BeaconChain_GetBlockV2_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBlockV2_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.BlockRequestV2 var protoReq eth.BlockRequestV2
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -896,7 +896,7 @@ func request_BeaconChain_GetBlockV2_0(ctx context.Context, marshaler runtime.Mar
} }
func local_request_BeaconChain_GetBlockV2_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBlockV2_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.BlockRequestV2 var protoReq eth.BlockRequestV2
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -923,7 +923,7 @@ func local_request_BeaconChain_GetBlockV2_0(ctx context.Context, marshaler runti
} }
func request_BeaconChain_GetBlockSSZV2_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBlockSSZV2_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.BlockRequestV2 var protoReq eth.BlockRequestV2
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -950,7 +950,7 @@ func request_BeaconChain_GetBlockSSZV2_0(ctx context.Context, marshaler runtime.
} }
func local_request_BeaconChain_GetBlockSSZV2_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBlockSSZV2_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.BlockRequestV2 var protoReq eth.BlockRequestV2
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -977,7 +977,7 @@ func local_request_BeaconChain_GetBlockSSZV2_0(ctx context.Context, marshaler ru
} }
func request_BeaconChain_ListBlockAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListBlockAttestations_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1004,7 +1004,7 @@ func request_BeaconChain_ListBlockAttestations_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_ListBlockAttestations_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListBlockAttestations_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.BlockRequest var protoReq v1.BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1035,7 +1035,7 @@ var (
filter_BeaconChain_ListPoolAttestations_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListPoolAttestations_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListPoolAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListPoolAttestations_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.AttestationsPoolRequest var protoReq v1.AttestationsPoolRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1051,7 +1051,7 @@ func request_BeaconChain_ListPoolAttestations_0(ctx context.Context, marshaler r
} }
func local_request_BeaconChain_ListPoolAttestations_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListPoolAttestations_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.AttestationsPoolRequest var protoReq v1.AttestationsPoolRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1067,7 +1067,7 @@ func local_request_BeaconChain_ListPoolAttestations_0(ctx context.Context, marsh
} }
func request_BeaconChain_SubmitAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SubmitAttestationsRequest var protoReq v1.SubmitAttestationsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1084,7 +1084,7 @@ func request_BeaconChain_SubmitAttestations_0(ctx context.Context, marshaler run
} }
func local_request_BeaconChain_SubmitAttestations_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitAttestations_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SubmitAttestationsRequest var protoReq v1.SubmitAttestationsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1101,7 +1101,7 @@ func local_request_BeaconChain_SubmitAttestations_0(ctx context.Context, marshal
} }
func request_BeaconChain_ListPoolAttesterSlashings_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListPoolAttesterSlashings_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1110,7 +1110,7 @@ func request_BeaconChain_ListPoolAttesterSlashings_0(ctx context.Context, marsha
} }
func local_request_BeaconChain_ListPoolAttesterSlashings_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListPoolAttesterSlashings_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1119,7 +1119,7 @@ func local_request_BeaconChain_ListPoolAttesterSlashings_0(ctx context.Context,
} }
func request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.AttesterSlashing var protoReq v1.AttesterSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1136,7 +1136,7 @@ func request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.AttesterSlashing var protoReq v1.AttesterSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1153,7 +1153,7 @@ func local_request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, mar
} }
func request_BeaconChain_ListPoolProposerSlashings_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListPoolProposerSlashings_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1162,7 +1162,7 @@ func request_BeaconChain_ListPoolProposerSlashings_0(ctx context.Context, marsha
} }
func local_request_BeaconChain_ListPoolProposerSlashings_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListPoolProposerSlashings_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1171,7 +1171,7 @@ func local_request_BeaconChain_ListPoolProposerSlashings_0(ctx context.Context,
} }
func request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProposerSlashing var protoReq v1.ProposerSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1188,7 +1188,7 @@ func request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProposerSlashing var protoReq v1.ProposerSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1205,7 +1205,7 @@ func local_request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, mar
} }
func request_BeaconChain_ListPoolVoluntaryExits_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListPoolVoluntaryExits_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1214,7 +1214,7 @@ func request_BeaconChain_ListPoolVoluntaryExits_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_ListPoolVoluntaryExits_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListPoolVoluntaryExits_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1223,7 +1223,7 @@ func local_request_BeaconChain_ListPoolVoluntaryExits_0(ctx context.Context, mar
} }
func request_BeaconChain_SubmitVoluntaryExit_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitVoluntaryExit_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SignedVoluntaryExit var protoReq v1.SignedVoluntaryExit
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1240,7 +1240,7 @@ func request_BeaconChain_SubmitVoluntaryExit_0(ctx context.Context, marshaler ru
} }
func local_request_BeaconChain_SubmitVoluntaryExit_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitVoluntaryExit_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SignedVoluntaryExit var protoReq v1.SignedVoluntaryExit
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1257,7 +1257,7 @@ func local_request_BeaconChain_SubmitVoluntaryExit_0(ctx context.Context, marsha
} }
func request_BeaconChain_SubmitPoolSyncCommitteeSignatures_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitPoolSyncCommitteeSignatures_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.SubmitPoolSyncCommitteeSignatures var protoReq eth.SubmitPoolSyncCommitteeSignatures
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1274,7 +1274,7 @@ func request_BeaconChain_SubmitPoolSyncCommitteeSignatures_0(ctx context.Context
} }
func local_request_BeaconChain_SubmitPoolSyncCommitteeSignatures_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitPoolSyncCommitteeSignatures_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.SubmitPoolSyncCommitteeSignatures var protoReq eth.SubmitPoolSyncCommitteeSignatures
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1291,7 +1291,7 @@ func local_request_BeaconChain_SubmitPoolSyncCommitteeSignatures_0(ctx context.C
} }
func request_BeaconChain_GetForkSchedule_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetForkSchedule_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1300,7 +1300,7 @@ func request_BeaconChain_GetForkSchedule_0(ctx context.Context, marshaler runtim
} }
func local_request_BeaconChain_GetForkSchedule_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetForkSchedule_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1309,7 +1309,7 @@ func local_request_BeaconChain_GetForkSchedule_0(ctx context.Context, marshaler
} }
func request_BeaconChain_GetSpec_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetSpec_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1318,7 +1318,7 @@ func request_BeaconChain_GetSpec_0(ctx context.Context, marshaler runtime.Marsha
} }
func local_request_BeaconChain_GetSpec_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetSpec_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1327,7 +1327,7 @@ func local_request_BeaconChain_GetSpec_0(ctx context.Context, marshaler runtime.
} }
func request_BeaconChain_GetDepositContract_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetDepositContract_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1336,7 +1336,7 @@ func request_BeaconChain_GetDepositContract_0(ctx context.Context, marshaler run
} }
func local_request_BeaconChain_GetDepositContract_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetDepositContract_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1349,7 +1349,7 @@ func local_request_BeaconChain_GetDepositContract_0(ctx context.Context, marshal
// UnaryRPC :call BeaconChainServer directly. // UnaryRPC :call BeaconChainServer directly.
// StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. // StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906.
// Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterBeaconChainHandlerFromEndpoint instead. // Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterBeaconChainHandlerFromEndpoint instead.
func RegisterBeaconChainHandlerServer(ctx context.Context, mux *runtime.ServeMux, server BeaconChainServer) error { func RegisterBeaconChainHandlerServer(_ context.Context, mux *runtime.ServeMux, server BeaconChainServer) error {
mux.Handle("GET", pattern_BeaconChain_GetGenesis_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { mux.Handle("GET", pattern_BeaconChain_GetGenesis_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) {
ctx, cancel := context.WithCancel(req.Context()) ctx, cancel := context.WithCancel(req.Context())
@ -2080,7 +2080,7 @@ func RegisterBeaconChainHandler(ctx context.Context, mux *runtime.ServeMux, conn
// Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconChainClient" // Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconChainClient"
// doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in // doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in
// "BeaconChainClient" to call the correct interceptors. // "BeaconChainClient" to call the correct interceptors.
func RegisterBeaconChainHandlerClient(ctx context.Context, mux *runtime.ServeMux, client BeaconChainClient) error { func RegisterBeaconChainHandlerClient(_ context.Context, mux *runtime.ServeMux, client BeaconChainClient) error {
mux.Handle("GET", pattern_BeaconChain_GetGenesis_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { mux.Handle("GET", pattern_BeaconChain_GetGenesis_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) {
ctx, cancel := context.WithCancel(req.Context()) ctx, cancel := context.WithCancel(req.Context())

View File

@ -109,7 +109,7 @@ func local_request_BeaconValidator_GetAttesterDuties_0(ctx context.Context, mars
} }
func request_BeaconValidator_GetProposerDuties_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_GetProposerDuties_0(ctx context.Context, _ runtime.Marshaler, client BeaconValidatorClient, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProposerDutiesRequest var protoReq v1.ProposerDutiesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -136,7 +136,7 @@ func request_BeaconValidator_GetProposerDuties_0(ctx context.Context, marshaler
} }
func local_request_BeaconValidator_GetProposerDuties_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_GetProposerDuties_0(ctx context.Context, _ runtime.Marshaler, server BeaconValidatorServer, _ *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProposerDutiesRequest var protoReq v1.ProposerDutiesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -237,7 +237,7 @@ var (
filter_BeaconValidator_ProduceBlock_0 = &utilities.DoubleArray{Encoding: map[string]int{"slot": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}} filter_BeaconValidator_ProduceBlock_0 = &utilities.DoubleArray{Encoding: map[string]int{"slot": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}}
) )
func request_BeaconValidator_ProduceBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_ProduceBlock_0(ctx context.Context, _ runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProduceBlockRequest var protoReq v1.ProduceBlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -271,7 +271,7 @@ func request_BeaconValidator_ProduceBlock_0(ctx context.Context, marshaler runti
} }
func local_request_BeaconValidator_ProduceBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_ProduceBlock_0(ctx context.Context, _ runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProduceBlockRequest var protoReq v1.ProduceBlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -309,7 +309,7 @@ var (
filter_BeaconValidator_ProduceBlockV2_0 = &utilities.DoubleArray{Encoding: map[string]int{"slot": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}} filter_BeaconValidator_ProduceBlockV2_0 = &utilities.DoubleArray{Encoding: map[string]int{"slot": 0}, Base: []int{1, 1, 0}, Check: []int{0, 1, 2}}
) )
func request_BeaconValidator_ProduceBlockV2_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_ProduceBlockV2_0(ctx context.Context, _ runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProduceBlockRequest var protoReq v1.ProduceBlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -343,7 +343,7 @@ func request_BeaconValidator_ProduceBlockV2_0(ctx context.Context, marshaler run
} }
func local_request_BeaconValidator_ProduceBlockV2_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_ProduceBlockV2_0(ctx context.Context, _ runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProduceBlockRequest var protoReq v1.ProduceBlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -381,7 +381,7 @@ var (
filter_BeaconValidator_ProduceAttestationData_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconValidator_ProduceAttestationData_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconValidator_ProduceAttestationData_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_ProduceAttestationData_0(ctx context.Context, _ runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProduceAttestationDataRequest var protoReq v1.ProduceAttestationDataRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -397,7 +397,7 @@ func request_BeaconValidator_ProduceAttestationData_0(ctx context.Context, marsh
} }
func local_request_BeaconValidator_ProduceAttestationData_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_ProduceAttestationData_0(ctx context.Context, _ runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.ProduceAttestationDataRequest var protoReq v1.ProduceAttestationDataRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -417,7 +417,7 @@ var (
filter_BeaconValidator_GetAggregateAttestation_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconValidator_GetAggregateAttestation_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconValidator_GetAggregateAttestation_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_GetAggregateAttestation_0(ctx context.Context, _ runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.AggregateAttestationRequest var protoReq v1.AggregateAttestationRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -433,7 +433,7 @@ func request_BeaconValidator_GetAggregateAttestation_0(ctx context.Context, mars
} }
func local_request_BeaconValidator_GetAggregateAttestation_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_GetAggregateAttestation_0(ctx context.Context, _ runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.AggregateAttestationRequest var protoReq v1.AggregateAttestationRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -449,7 +449,7 @@ func local_request_BeaconValidator_GetAggregateAttestation_0(ctx context.Context
} }
func request_BeaconValidator_SubmitAggregateAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_SubmitAggregateAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SubmitAggregateAndProofsRequest var protoReq v1.SubmitAggregateAndProofsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -466,7 +466,7 @@ func request_BeaconValidator_SubmitAggregateAndProofs_0(ctx context.Context, mar
} }
func local_request_BeaconValidator_SubmitAggregateAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_SubmitAggregateAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SubmitAggregateAndProofsRequest var protoReq v1.SubmitAggregateAndProofsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -483,7 +483,7 @@ func local_request_BeaconValidator_SubmitAggregateAndProofs_0(ctx context.Contex
} }
func request_BeaconValidator_SubmitBeaconCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_SubmitBeaconCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SubmitBeaconCommitteeSubscriptionsRequest var protoReq v1.SubmitBeaconCommitteeSubscriptionsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -500,7 +500,7 @@ func request_BeaconValidator_SubmitBeaconCommitteeSubscription_0(ctx context.Con
} }
func local_request_BeaconValidator_SubmitBeaconCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_SubmitBeaconCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq v1.SubmitBeaconCommitteeSubscriptionsRequest var protoReq v1.SubmitBeaconCommitteeSubscriptionsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -517,7 +517,7 @@ func local_request_BeaconValidator_SubmitBeaconCommitteeSubscription_0(ctx conte
} }
func request_BeaconValidator_SubmitSyncCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_SubmitSyncCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.SubmitSyncCommitteeSubscriptionsRequest var protoReq eth.SubmitSyncCommitteeSubscriptionsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -534,7 +534,7 @@ func request_BeaconValidator_SubmitSyncCommitteeSubscription_0(ctx context.Conte
} }
func local_request_BeaconValidator_SubmitSyncCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_SubmitSyncCommitteeSubscription_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.SubmitSyncCommitteeSubscriptionsRequest var protoReq eth.SubmitSyncCommitteeSubscriptionsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -555,7 +555,7 @@ var (
filter_BeaconValidator_ProduceSyncCommitteeContribution_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconValidator_ProduceSyncCommitteeContribution_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconValidator_ProduceSyncCommitteeContribution_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_ProduceSyncCommitteeContribution_0(ctx context.Context, _ runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.ProduceSyncCommitteeContributionRequest var protoReq eth.ProduceSyncCommitteeContributionRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -571,7 +571,7 @@ func request_BeaconValidator_ProduceSyncCommitteeContribution_0(ctx context.Cont
} }
func local_request_BeaconValidator_ProduceSyncCommitteeContribution_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_ProduceSyncCommitteeContribution_0(ctx context.Context, _ runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.ProduceSyncCommitteeContributionRequest var protoReq eth.ProduceSyncCommitteeContributionRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -587,7 +587,7 @@ func local_request_BeaconValidator_ProduceSyncCommitteeContribution_0(ctx contex
} }
func request_BeaconValidator_SubmitContributionAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconValidator_SubmitContributionAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.SubmitContributionAndProofsRequest var protoReq eth.SubmitContributionAndProofsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -604,7 +604,7 @@ func request_BeaconValidator_SubmitContributionAndProofs_0(ctx context.Context,
} }
func local_request_BeaconValidator_SubmitContributionAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconValidator_SubmitContributionAndProofs_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq eth.SubmitContributionAndProofsRequest var protoReq eth.SubmitContributionAndProofsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -625,7 +625,7 @@ func local_request_BeaconValidator_SubmitContributionAndProofs_0(ctx context.Con
// UnaryRPC :call BeaconValidatorServer directly. // UnaryRPC :call BeaconValidatorServer directly.
// StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906. // StreamingRPC :currently unsupported pending https://github.com/grpc/grpc-go/issues/906.
// Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterBeaconValidatorHandlerFromEndpoint instead. // Note that using this registration option will cause many gRPC library features to stop working. Consider using RegisterBeaconValidatorHandlerFromEndpoint instead.
func RegisterBeaconValidatorHandlerServer(ctx context.Context, mux *runtime.ServeMux, server BeaconValidatorServer) error { func RegisterBeaconValidatorHandlerServer(_ context.Context, mux *runtime.ServeMux, server BeaconValidatorServer) error {
mux.Handle("POST", pattern_BeaconValidator_GetAttesterDuties_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { mux.Handle("POST", pattern_BeaconValidator_GetAttesterDuties_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) {
ctx, cancel := context.WithCancel(req.Context()) ctx, cancel := context.WithCancel(req.Context())
@ -942,7 +942,7 @@ func RegisterBeaconValidatorHandler(ctx context.Context, mux *runtime.ServeMux,
// Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconValidatorClient" // Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconValidatorClient"
// doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in // doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in
// "BeaconValidatorClient" to call the correct interceptors. // "BeaconValidatorClient" to call the correct interceptors.
func RegisterBeaconValidatorHandlerClient(ctx context.Context, mux *runtime.ServeMux, client BeaconValidatorClient) error { func RegisterBeaconValidatorHandlerClient(_ context.Context, mux *runtime.ServeMux, client BeaconValidatorClient) error {
mux.Handle("POST", pattern_BeaconValidator_GetAttesterDuties_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { mux.Handle("POST", pattern_BeaconValidator_GetAttesterDuties_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) {
ctx, cancel := context.WithCancel(req.Context()) ctx, cancel := context.WithCancel(req.Context())

View File

@ -41,7 +41,7 @@ var (
filter_BeaconChain_ListAttestations_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListAttestations_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListAttestations_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListAttestationsRequest var protoReq ListAttestationsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -57,7 +57,7 @@ func request_BeaconChain_ListAttestations_0(ctx context.Context, marshaler runti
} }
func local_request_BeaconChain_ListAttestations_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListAttestations_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListAttestationsRequest var protoReq ListAttestationsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -77,7 +77,7 @@ var (
filter_BeaconChain_ListIndexedAttestations_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListIndexedAttestations_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListIndexedAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListIndexedAttestations_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListIndexedAttestationsRequest var protoReq ListIndexedAttestationsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -93,7 +93,7 @@ func request_BeaconChain_ListIndexedAttestations_0(ctx context.Context, marshale
} }
func local_request_BeaconChain_ListIndexedAttestations_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListIndexedAttestations_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListIndexedAttestationsRequest var protoReq ListIndexedAttestationsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -109,7 +109,7 @@ func local_request_BeaconChain_ListIndexedAttestations_0(ctx context.Context, ma
} }
func request_BeaconChain_StreamAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (BeaconChain_StreamAttestationsClient, runtime.ServerMetadata, error) { func request_BeaconChain_StreamAttestations_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (BeaconChain_StreamAttestationsClient, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -126,7 +126,7 @@ func request_BeaconChain_StreamAttestations_0(ctx context.Context, marshaler run
} }
func request_BeaconChain_StreamIndexedAttestations_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (BeaconChain_StreamIndexedAttestationsClient, runtime.ServerMetadata, error) { func request_BeaconChain_StreamIndexedAttestations_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (BeaconChain_StreamIndexedAttestationsClient, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -147,7 +147,7 @@ var (
filter_BeaconChain_AttestationPool_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_AttestationPool_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_AttestationPool_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_AttestationPool_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AttestationPoolRequest var protoReq AttestationPoolRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -163,7 +163,7 @@ func request_BeaconChain_AttestationPool_0(ctx context.Context, marshaler runtim
} }
func local_request_BeaconChain_AttestationPool_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_AttestationPool_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AttestationPoolRequest var protoReq AttestationPoolRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -183,7 +183,7 @@ var (
filter_BeaconChain_ListBlocks_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListBlocks_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListBlocks_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListBlocks_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListBlocksRequest var protoReq ListBlocksRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -199,7 +199,7 @@ func request_BeaconChain_ListBlocks_0(ctx context.Context, marshaler runtime.Mar
} }
func local_request_BeaconChain_ListBlocks_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListBlocks_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListBlocksRequest var protoReq ListBlocksRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -219,7 +219,7 @@ var (
filter_BeaconChain_ListBeaconBlocks_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListBeaconBlocks_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListBeaconBlocks_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListBeaconBlocks_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListBlocksRequest var protoReq ListBlocksRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -235,7 +235,7 @@ func request_BeaconChain_ListBeaconBlocks_0(ctx context.Context, marshaler runti
} }
func local_request_BeaconChain_ListBeaconBlocks_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListBeaconBlocks_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListBlocksRequest var protoReq ListBlocksRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -255,7 +255,7 @@ var (
filter_BeaconChain_StreamBlocks_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_StreamBlocks_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_StreamBlocks_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (BeaconChain_StreamBlocksClient, runtime.ServerMetadata, error) { func request_BeaconChain_StreamBlocks_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (BeaconChain_StreamBlocksClient, runtime.ServerMetadata, error) {
var protoReq StreamBlocksRequest var protoReq StreamBlocksRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -279,7 +279,7 @@ func request_BeaconChain_StreamBlocks_0(ctx context.Context, marshaler runtime.M
} }
func request_BeaconChain_StreamChainHead_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (BeaconChain_StreamChainHeadClient, runtime.ServerMetadata, error) { func request_BeaconChain_StreamChainHead_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (BeaconChain_StreamChainHeadClient, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -296,7 +296,7 @@ func request_BeaconChain_StreamChainHead_0(ctx context.Context, marshaler runtim
} }
func request_BeaconChain_GetChainHead_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetChainHead_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -305,7 +305,7 @@ func request_BeaconChain_GetChainHead_0(ctx context.Context, marshaler runtime.M
} }
func local_request_BeaconChain_GetChainHead_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetChainHead_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -314,7 +314,7 @@ func local_request_BeaconChain_GetChainHead_0(ctx context.Context, marshaler run
} }
func request_BeaconChain_GetWeakSubjectivityCheckpoint_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetWeakSubjectivityCheckpoint_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -323,7 +323,7 @@ func request_BeaconChain_GetWeakSubjectivityCheckpoint_0(ctx context.Context, ma
} }
func local_request_BeaconChain_GetWeakSubjectivityCheckpoint_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetWeakSubjectivityCheckpoint_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -336,7 +336,7 @@ var (
filter_BeaconChain_ListBeaconCommittees_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListBeaconCommittees_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListBeaconCommittees_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListBeaconCommittees_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListCommitteesRequest var protoReq ListCommitteesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -352,7 +352,7 @@ func request_BeaconChain_ListBeaconCommittees_0(ctx context.Context, marshaler r
} }
func local_request_BeaconChain_ListBeaconCommittees_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListBeaconCommittees_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListCommitteesRequest var protoReq ListCommitteesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -372,7 +372,7 @@ var (
filter_BeaconChain_ListValidatorBalances_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListValidatorBalances_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListValidatorBalances_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListValidatorBalances_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListValidatorBalancesRequest var protoReq ListValidatorBalancesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -388,7 +388,7 @@ func request_BeaconChain_ListValidatorBalances_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_ListValidatorBalances_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListValidatorBalances_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListValidatorBalancesRequest var protoReq ListValidatorBalancesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -408,7 +408,7 @@ var (
filter_BeaconChain_ListValidators_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListValidators_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListValidators_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListValidators_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListValidatorsRequest var protoReq ListValidatorsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -424,7 +424,7 @@ func request_BeaconChain_ListValidators_0(ctx context.Context, marshaler runtime
} }
func local_request_BeaconChain_ListValidators_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListValidators_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListValidatorsRequest var protoReq ListValidatorsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -444,7 +444,7 @@ var (
filter_BeaconChain_GetValidator_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_GetValidator_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_GetValidator_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetValidator_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GetValidatorRequest var protoReq GetValidatorRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -460,7 +460,7 @@ func request_BeaconChain_GetValidator_0(ctx context.Context, marshaler runtime.M
} }
func local_request_BeaconChain_GetValidator_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetValidator_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GetValidatorRequest var protoReq GetValidatorRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -480,7 +480,7 @@ var (
filter_BeaconChain_GetValidatorActiveSetChanges_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_GetValidatorActiveSetChanges_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_GetValidatorActiveSetChanges_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetValidatorActiveSetChanges_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GetValidatorActiveSetChangesRequest var protoReq GetValidatorActiveSetChangesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -496,7 +496,7 @@ func request_BeaconChain_GetValidatorActiveSetChanges_0(ctx context.Context, mar
} }
func local_request_BeaconChain_GetValidatorActiveSetChanges_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetValidatorActiveSetChanges_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GetValidatorActiveSetChangesRequest var protoReq GetValidatorActiveSetChangesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -512,7 +512,7 @@ func local_request_BeaconChain_GetValidatorActiveSetChanges_0(ctx context.Contex
} }
func request_BeaconChain_GetValidatorQueue_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetValidatorQueue_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -521,7 +521,7 @@ func request_BeaconChain_GetValidatorQueue_0(ctx context.Context, marshaler runt
} }
func local_request_BeaconChain_GetValidatorQueue_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetValidatorQueue_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -534,7 +534,7 @@ var (
filter_BeaconChain_GetValidatorPerformance_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_GetValidatorPerformance_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_GetValidatorPerformance_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetValidatorPerformance_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ValidatorPerformanceRequest var protoReq ValidatorPerformanceRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -550,7 +550,7 @@ func request_BeaconChain_GetValidatorPerformance_0(ctx context.Context, marshale
} }
func local_request_BeaconChain_GetValidatorPerformance_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetValidatorPerformance_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ValidatorPerformanceRequest var protoReq ValidatorPerformanceRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -570,7 +570,7 @@ var (
filter_BeaconChain_ListValidatorAssignments_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_ListValidatorAssignments_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_ListValidatorAssignments_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_ListValidatorAssignments_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListValidatorAssignmentsRequest var protoReq ListValidatorAssignmentsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -586,7 +586,7 @@ func request_BeaconChain_ListValidatorAssignments_0(ctx context.Context, marshal
} }
func local_request_BeaconChain_ListValidatorAssignments_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_ListValidatorAssignments_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ListValidatorAssignmentsRequest var protoReq ListValidatorAssignmentsRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -606,7 +606,7 @@ var (
filter_BeaconChain_GetValidatorParticipation_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_GetValidatorParticipation_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_GetValidatorParticipation_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetValidatorParticipation_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GetValidatorParticipationRequest var protoReq GetValidatorParticipationRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -622,7 +622,7 @@ func request_BeaconChain_GetValidatorParticipation_0(ctx context.Context, marsha
} }
func local_request_BeaconChain_GetValidatorParticipation_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetValidatorParticipation_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GetValidatorParticipationRequest var protoReq GetValidatorParticipationRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -638,7 +638,7 @@ func local_request_BeaconChain_GetValidatorParticipation_0(ctx context.Context,
} }
func request_BeaconChain_GetBeaconConfig_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetBeaconConfig_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -647,7 +647,7 @@ func request_BeaconChain_GetBeaconConfig_0(ctx context.Context, marshaler runtim
} }
func local_request_BeaconChain_GetBeaconConfig_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetBeaconConfig_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -656,7 +656,7 @@ func local_request_BeaconChain_GetBeaconConfig_0(ctx context.Context, marshaler
} }
func request_BeaconChain_StreamValidatorsInfo_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (BeaconChain_StreamValidatorsInfoClient, runtime.ServerMetadata, error) { func request_BeaconChain_StreamValidatorsInfo_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (BeaconChain_StreamValidatorsInfoClient, runtime.ServerMetadata, error) {
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
stream, err := client.StreamValidatorsInfo(ctx) stream, err := client.StreamValidatorsInfo(ctx)
if err != nil { if err != nil {
@ -712,7 +712,7 @@ var (
filter_BeaconChain_SubmitAttesterSlashing_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_SubmitAttesterSlashing_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AttesterSlashing var protoReq AttesterSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -728,7 +728,7 @@ func request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitAttesterSlashing_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AttesterSlashing var protoReq AttesterSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -748,7 +748,7 @@ var (
filter_BeaconChain_SubmitProposerSlashing_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_SubmitProposerSlashing_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ProposerSlashing var protoReq ProposerSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -764,7 +764,7 @@ func request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler
} }
func local_request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_SubmitProposerSlashing_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ProposerSlashing var protoReq ProposerSlashing
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -784,7 +784,7 @@ var (
filter_BeaconChain_GetIndividualVotes_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconChain_GetIndividualVotes_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconChain_GetIndividualVotes_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconChainClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconChain_GetIndividualVotes_0(ctx context.Context, _ runtime.Marshaler, client BeaconChainClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq IndividualVotesRequest var protoReq IndividualVotesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -800,7 +800,7 @@ func request_BeaconChain_GetIndividualVotes_0(ctx context.Context, marshaler run
} }
func local_request_BeaconChain_GetIndividualVotes_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconChainServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconChain_GetIndividualVotes_0(ctx context.Context, _ runtime.Marshaler, server BeaconChainServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq IndividualVotesRequest var protoReq IndividualVotesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1356,7 +1356,7 @@ func RegisterBeaconChainHandler(ctx context.Context, mux *runtime.ServeMux, conn
// Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconChainClient" // Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconChainClient"
// doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in // doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in
// "BeaconChainClient" to call the correct interceptors. // "BeaconChainClient" to call the correct interceptors.
func RegisterBeaconChainHandlerClient(ctx context.Context, mux *runtime.ServeMux, client BeaconChainClient) error { func RegisterBeaconChainHandlerClient(_ context.Context, mux *runtime.ServeMux, client BeaconChainClient) error {
mux.Handle("GET", pattern_BeaconChain_ListAttestations_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { mux.Handle("GET", pattern_BeaconChain_ListAttestations_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) {
ctx, cancel := context.WithCancel(req.Context()) ctx, cancel := context.WithCancel(req.Context())

View File

@ -41,7 +41,7 @@ var (
filter_BeaconNodeValidator_GetDuties_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_GetDuties_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_GetDuties_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetDuties_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq DutiesRequest var protoReq DutiesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -57,7 +57,7 @@ func request_BeaconNodeValidator_GetDuties_0(ctx context.Context, marshaler runt
} }
func local_request_BeaconNodeValidator_GetDuties_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetDuties_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq DutiesRequest var protoReq DutiesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -77,7 +77,7 @@ var (
filter_BeaconNodeValidator_StreamDuties_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_StreamDuties_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_StreamDuties_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (BeaconNodeValidator_StreamDutiesClient, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_StreamDuties_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (BeaconNodeValidator_StreamDutiesClient, runtime.ServerMetadata, error) {
var protoReq DutiesRequest var protoReq DutiesRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -105,7 +105,7 @@ var (
filter_BeaconNodeValidator_DomainData_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_DomainData_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_DomainData_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_DomainData_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq DomainRequest var protoReq DomainRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -121,7 +121,7 @@ func request_BeaconNodeValidator_DomainData_0(ctx context.Context, marshaler run
} }
func local_request_BeaconNodeValidator_DomainData_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_DomainData_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq DomainRequest var protoReq DomainRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -137,7 +137,7 @@ func local_request_BeaconNodeValidator_DomainData_0(ctx context.Context, marshal
} }
func request_BeaconNodeValidator_WaitForChainStart_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (BeaconNodeValidator_WaitForChainStartClient, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_WaitForChainStart_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, _ *http.Request, _ map[string]string) (BeaconNodeValidator_WaitForChainStartClient, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -158,7 +158,7 @@ var (
filter_BeaconNodeValidator_WaitForActivation_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_WaitForActivation_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_WaitForActivation_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (BeaconNodeValidator_WaitForActivationClient, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_WaitForActivation_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (BeaconNodeValidator_WaitForActivationClient, runtime.ServerMetadata, error) {
var protoReq ValidatorActivationRequest var protoReq ValidatorActivationRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -186,7 +186,7 @@ var (
filter_BeaconNodeValidator_ValidatorIndex_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_ValidatorIndex_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_ValidatorIndex_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_ValidatorIndex_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ValidatorIndexRequest var protoReq ValidatorIndexRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -202,7 +202,7 @@ func request_BeaconNodeValidator_ValidatorIndex_0(ctx context.Context, marshaler
} }
func local_request_BeaconNodeValidator_ValidatorIndex_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_ValidatorIndex_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ValidatorIndexRequest var protoReq ValidatorIndexRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -222,7 +222,7 @@ var (
filter_BeaconNodeValidator_ValidatorStatus_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_ValidatorStatus_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_ValidatorStatus_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_ValidatorStatus_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ValidatorStatusRequest var protoReq ValidatorStatusRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -238,7 +238,7 @@ func request_BeaconNodeValidator_ValidatorStatus_0(ctx context.Context, marshale
} }
func local_request_BeaconNodeValidator_ValidatorStatus_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_ValidatorStatus_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq ValidatorStatusRequest var protoReq ValidatorStatusRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -258,7 +258,7 @@ var (
filter_BeaconNodeValidator_MultipleValidatorStatus_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_MultipleValidatorStatus_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_MultipleValidatorStatus_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_MultipleValidatorStatus_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq MultipleValidatorStatusRequest var protoReq MultipleValidatorStatusRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -274,7 +274,7 @@ func request_BeaconNodeValidator_MultipleValidatorStatus_0(ctx context.Context,
} }
func local_request_BeaconNodeValidator_MultipleValidatorStatus_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_MultipleValidatorStatus_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq MultipleValidatorStatusRequest var protoReq MultipleValidatorStatusRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -294,7 +294,7 @@ var (
filter_BeaconNodeValidator_GetBlock_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_GetBlock_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_GetBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetBlock_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq BlockRequest var protoReq BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -310,7 +310,7 @@ func request_BeaconNodeValidator_GetBlock_0(ctx context.Context, marshaler runti
} }
func local_request_BeaconNodeValidator_GetBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetBlock_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq BlockRequest var protoReq BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -326,7 +326,7 @@ func local_request_BeaconNodeValidator_GetBlock_0(ctx context.Context, marshaler
} }
func request_BeaconNodeValidator_ProposeBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_ProposeBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedBeaconBlock var protoReq SignedBeaconBlock
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -343,7 +343,7 @@ func request_BeaconNodeValidator_ProposeBlock_0(ctx context.Context, marshaler r
} }
func local_request_BeaconNodeValidator_ProposeBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_ProposeBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedBeaconBlock var protoReq SignedBeaconBlock
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -364,7 +364,7 @@ var (
filter_BeaconNodeValidator_GetBeaconBlock_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_GetBeaconBlock_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_GetBeaconBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetBeaconBlock_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq BlockRequest var protoReq BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -380,7 +380,7 @@ func request_BeaconNodeValidator_GetBeaconBlock_0(ctx context.Context, marshaler
} }
func local_request_BeaconNodeValidator_GetBeaconBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetBeaconBlock_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq BlockRequest var protoReq BlockRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -396,7 +396,7 @@ func local_request_BeaconNodeValidator_GetBeaconBlock_0(ctx context.Context, mar
} }
func request_BeaconNodeValidator_ProposeBeaconBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_ProposeBeaconBlock_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GenericSignedBeaconBlock var protoReq GenericSignedBeaconBlock
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -413,7 +413,7 @@ func request_BeaconNodeValidator_ProposeBeaconBlock_0(ctx context.Context, marsh
} }
func local_request_BeaconNodeValidator_ProposeBeaconBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_ProposeBeaconBlock_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq GenericSignedBeaconBlock var protoReq GenericSignedBeaconBlock
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -434,7 +434,7 @@ var (
filter_BeaconNodeValidator_GetAttestationData_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_GetAttestationData_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_GetAttestationData_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetAttestationData_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AttestationDataRequest var protoReq AttestationDataRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -450,7 +450,7 @@ func request_BeaconNodeValidator_GetAttestationData_0(ctx context.Context, marsh
} }
func local_request_BeaconNodeValidator_GetAttestationData_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetAttestationData_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AttestationDataRequest var protoReq AttestationDataRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -466,7 +466,7 @@ func local_request_BeaconNodeValidator_GetAttestationData_0(ctx context.Context,
} }
func request_BeaconNodeValidator_ProposeAttestation_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_ProposeAttestation_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq Attestation var protoReq Attestation
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -483,7 +483,7 @@ func request_BeaconNodeValidator_ProposeAttestation_0(ctx context.Context, marsh
} }
func local_request_BeaconNodeValidator_ProposeAttestation_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_ProposeAttestation_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq Attestation var protoReq Attestation
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -500,7 +500,7 @@ func local_request_BeaconNodeValidator_ProposeAttestation_0(ctx context.Context,
} }
func request_BeaconNodeValidator_SubmitAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_SubmitAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AggregateSelectionRequest var protoReq AggregateSelectionRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -517,7 +517,7 @@ func request_BeaconNodeValidator_SubmitAggregateSelectionProof_0(ctx context.Con
} }
func local_request_BeaconNodeValidator_SubmitAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_SubmitAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq AggregateSelectionRequest var protoReq AggregateSelectionRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -534,7 +534,7 @@ func local_request_BeaconNodeValidator_SubmitAggregateSelectionProof_0(ctx conte
} }
func request_BeaconNodeValidator_SubmitSignedAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_SubmitSignedAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedAggregateSubmitRequest var protoReq SignedAggregateSubmitRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -551,7 +551,7 @@ func request_BeaconNodeValidator_SubmitSignedAggregateSelectionProof_0(ctx conte
} }
func local_request_BeaconNodeValidator_SubmitSignedAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_SubmitSignedAggregateSelectionProof_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedAggregateSubmitRequest var protoReq SignedAggregateSubmitRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -568,7 +568,7 @@ func local_request_BeaconNodeValidator_SubmitSignedAggregateSelectionProof_0(ctx
} }
func request_BeaconNodeValidator_ProposeExit_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_ProposeExit_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedVoluntaryExit var protoReq SignedVoluntaryExit
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -585,7 +585,7 @@ func request_BeaconNodeValidator_ProposeExit_0(ctx context.Context, marshaler ru
} }
func local_request_BeaconNodeValidator_ProposeExit_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_ProposeExit_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedVoluntaryExit var protoReq SignedVoluntaryExit
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -602,7 +602,7 @@ func local_request_BeaconNodeValidator_ProposeExit_0(ctx context.Context, marsha
} }
func request_BeaconNodeValidator_SubscribeCommitteeSubnets_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_SubscribeCommitteeSubnets_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq CommitteeSubnetsSubscribeRequest var protoReq CommitteeSubnetsSubscribeRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -619,7 +619,7 @@ func request_BeaconNodeValidator_SubscribeCommitteeSubnets_0(ctx context.Context
} }
func local_request_BeaconNodeValidator_SubscribeCommitteeSubnets_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_SubscribeCommitteeSubnets_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq CommitteeSubnetsSubscribeRequest var protoReq CommitteeSubnetsSubscribeRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -640,7 +640,7 @@ var (
filter_BeaconNodeValidator_CheckDoppelGanger_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_CheckDoppelGanger_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_CheckDoppelGanger_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_CheckDoppelGanger_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq DoppelGangerRequest var protoReq DoppelGangerRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -656,7 +656,7 @@ func request_BeaconNodeValidator_CheckDoppelGanger_0(ctx context.Context, marsha
} }
func local_request_BeaconNodeValidator_CheckDoppelGanger_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_CheckDoppelGanger_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq DoppelGangerRequest var protoReq DoppelGangerRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -672,7 +672,7 @@ func local_request_BeaconNodeValidator_CheckDoppelGanger_0(ctx context.Context,
} }
func request_BeaconNodeValidator_GetSyncMessageBlockRoot_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetSyncMessageBlockRoot_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -681,7 +681,7 @@ func request_BeaconNodeValidator_GetSyncMessageBlockRoot_0(ctx context.Context,
} }
func local_request_BeaconNodeValidator_GetSyncMessageBlockRoot_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetSyncMessageBlockRoot_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, _ *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq emptypb.Empty var protoReq emptypb.Empty
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -690,7 +690,7 @@ func local_request_BeaconNodeValidator_GetSyncMessageBlockRoot_0(ctx context.Con
} }
func request_BeaconNodeValidator_SubmitSyncMessage_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_SubmitSyncMessage_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SyncCommitteeMessage var protoReq SyncCommitteeMessage
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -707,7 +707,7 @@ func request_BeaconNodeValidator_SubmitSyncMessage_0(ctx context.Context, marsha
} }
func local_request_BeaconNodeValidator_SubmitSyncMessage_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_SubmitSyncMessage_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SyncCommitteeMessage var protoReq SyncCommitteeMessage
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -728,7 +728,7 @@ var (
filter_BeaconNodeValidator_GetSyncSubcommitteeIndex_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_GetSyncSubcommitteeIndex_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_GetSyncSubcommitteeIndex_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetSyncSubcommitteeIndex_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SyncSubcommitteeIndexRequest var protoReq SyncSubcommitteeIndexRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -744,7 +744,7 @@ func request_BeaconNodeValidator_GetSyncSubcommitteeIndex_0(ctx context.Context,
} }
func local_request_BeaconNodeValidator_GetSyncSubcommitteeIndex_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetSyncSubcommitteeIndex_0(ctx context.Context, _ runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SyncSubcommitteeIndexRequest var protoReq SyncSubcommitteeIndexRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -760,7 +760,7 @@ func local_request_BeaconNodeValidator_GetSyncSubcommitteeIndex_0(ctx context.Co
} }
func request_BeaconNodeValidator_GetSyncCommitteeContribution_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_GetSyncCommitteeContribution_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SyncCommitteeContributionRequest var protoReq SyncCommitteeContributionRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -777,7 +777,7 @@ func request_BeaconNodeValidator_GetSyncCommitteeContribution_0(ctx context.Cont
} }
func local_request_BeaconNodeValidator_GetSyncCommitteeContribution_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_GetSyncCommitteeContribution_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SyncCommitteeContributionRequest var protoReq SyncCommitteeContributionRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -794,7 +794,7 @@ func local_request_BeaconNodeValidator_GetSyncCommitteeContribution_0(ctx contex
} }
func request_BeaconNodeValidator_SubmitSignedContributionAndProof_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_SubmitSignedContributionAndProof_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedContributionAndProof var protoReq SignedContributionAndProof
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -811,7 +811,7 @@ func request_BeaconNodeValidator_SubmitSignedContributionAndProof_0(ctx context.
} }
func local_request_BeaconNodeValidator_SubmitSignedContributionAndProof_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, pathParams map[string]string) (proto.Message, runtime.ServerMetadata, error) { func local_request_BeaconNodeValidator_SubmitSignedContributionAndProof_0(ctx context.Context, marshaler runtime.Marshaler, server BeaconNodeValidatorServer, req *http.Request, _ map[string]string) (proto.Message, runtime.ServerMetadata, error) {
var protoReq SignedContributionAndProof var protoReq SignedContributionAndProof
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -832,7 +832,7 @@ var (
filter_BeaconNodeValidator_StreamBlocksAltair_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)} filter_BeaconNodeValidator_StreamBlocksAltair_0 = &utilities.DoubleArray{Encoding: map[string]int{}, Base: []int(nil), Check: []int(nil)}
) )
func request_BeaconNodeValidator_StreamBlocksAltair_0(ctx context.Context, marshaler runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, pathParams map[string]string) (BeaconNodeValidator_StreamBlocksAltairClient, runtime.ServerMetadata, error) { func request_BeaconNodeValidator_StreamBlocksAltair_0(ctx context.Context, _ runtime.Marshaler, client BeaconNodeValidatorClient, req *http.Request, _ map[string]string) (BeaconNodeValidator_StreamBlocksAltairClient, runtime.ServerMetadata, error) {
var protoReq StreamBlocksRequest var protoReq StreamBlocksRequest
var metadata runtime.ServerMetadata var metadata runtime.ServerMetadata
@ -1412,7 +1412,7 @@ func RegisterBeaconNodeValidatorHandler(ctx context.Context, mux *runtime.ServeM
// Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconNodeValidatorClient" // Note: the gRPC framework executes interceptors within the gRPC handler. If the passed in "BeaconNodeValidatorClient"
// doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in // doesn't go through the normal gRPC flow (creating a gRPC client etc.) then it will be up to the passed in
// "BeaconNodeValidatorClient" to call the correct interceptors. // "BeaconNodeValidatorClient" to call the correct interceptors.
func RegisterBeaconNodeValidatorHandlerClient(ctx context.Context, mux *runtime.ServeMux, client BeaconNodeValidatorClient) error { func RegisterBeaconNodeValidatorHandlerClient(_ context.Context, mux *runtime.ServeMux, client BeaconNodeValidatorClient) error {
mux.Handle("GET", pattern_BeaconNodeValidator_GetDuties_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) { mux.Handle("GET", pattern_BeaconNodeValidator_GetDuties_0, func(w http.ResponseWriter, req *http.Request, pathParams map[string]string) {
ctx, cancel := context.WithCancel(req.Context()) ctx, cancel := context.WithCancel(req.Context())

View File

@ -39,7 +39,7 @@ func NewTracingSink(endpoint string) *TracingSink {
} }
// Start the tracing sink. // Start the tracing sink.
func (ts *TracingSink) Start(ctx context.Context) error { func (ts *TracingSink) Start(_ context.Context) error {
go ts.initializeSink() go ts.initializeSink()
close(ts.started) close(ts.started)
return nil return nil

View File

@ -196,7 +196,7 @@ func extractWalletCreationConfigFromCli(cliCtx *cli.Context, keymanagerKind keym
return createWalletConfig, nil return createWalletConfig, nil
} }
func createImportedKeymanagerWallet(ctx context.Context, wallet *wallet.Wallet) error { func createImportedKeymanagerWallet(_ context.Context, wallet *wallet.Wallet) error {
if wallet == nil { if wallet == nil {
return errors.New("nil wallet") return errors.New("nil wallet")
} }

View File

@ -176,7 +176,7 @@ func (fv *FakeValidator) SubmitSyncCommitteeMessage(_ context.Context, _ types.S
func (fv *FakeValidator) LogAttestationsSubmitted() {} func (fv *FakeValidator) LogAttestationsSubmitted() {}
// LogNextDutyTimeLeft for mocking. // LogNextDutyTimeLeft for mocking.
func (fv *FakeValidator) LogNextDutyTimeLeft(slot types.Slot) error { func (fv *FakeValidator) LogNextDutyTimeLeft(_ types.Slot) error {
return nil return nil
} }
@ -217,12 +217,12 @@ func (fv *FakeValidator) GetKeymanager() keymanager.IKeymanager {
} }
// CheckDoppelGanger for mocking // CheckDoppelGanger for mocking
func (fv *FakeValidator) CheckDoppelGanger(ctx context.Context) error { func (fv *FakeValidator) CheckDoppelGanger(_ context.Context) error {
return nil return nil
} }
// ReceiveBlocks for mocking // ReceiveBlocks for mocking
func (fv *FakeValidator) ReceiveBlocks(ctx context.Context, connectionErrorChannel chan<- error) { func (fv *FakeValidator) ReceiveBlocks(_ context.Context, connectionErrorChannel chan<- error) {
fv.ReceiveBlocksCalled++ fv.ReceiveBlocksCalled++
if fv.RetryTillSuccess > fv.ReceiveBlocksCalled { if fv.RetryTillSuccess > fv.ReceiveBlocksCalled {
connectionErrorChannel <- iface.ErrConnectionIssue connectionErrorChannel <- iface.ErrConnectionIssue
@ -241,5 +241,5 @@ func (fv *FakeValidator) HandleKeyReload(_ context.Context, newKeys [][48]byte)
} }
// SubmitSignedContributionAndProof for mocking // SubmitSignedContributionAndProof for mocking
func (fv *FakeValidator) SubmitSignedContributionAndProof(ctx context.Context, slot types.Slot, pubKey [48]byte) { func (fv *FakeValidator) SubmitSignedContributionAndProof(_ context.Context, _ types.Slot, _ [48]byte) {
} }

View File

@ -60,7 +60,7 @@ type mockKeymanager struct {
accountsChangedFeed *event.Feed accountsChangedFeed *event.Feed
} }
func (m *mockKeymanager) FetchValidatingPublicKeys(ctx context.Context) ([][48]byte, error) { func (m *mockKeymanager) FetchValidatingPublicKeys(_ context.Context) ([][48]byte, error) {
m.lock.RLock() m.lock.RLock()
defer m.lock.RUnlock() defer m.lock.RUnlock()
keys := make([][48]byte, 0) keys := make([][48]byte, 0)
@ -74,7 +74,7 @@ func (m *mockKeymanager) FetchValidatingPublicKeys(ctx context.Context) ([][48]b
return keys, nil return keys, nil
} }
func (m *mockKeymanager) Sign(ctx context.Context, req *validatorpb.SignRequest) (bls.Signature, error) { func (m *mockKeymanager) Sign(_ context.Context, req *validatorpb.SignRequest) (bls.Signature, error) {
pubKey := [48]byte{} pubKey := [48]byte{}
copy(pubKey[:], req.PublicKey) copy(pubKey[:], req.PublicKey)
privKey, ok := m.keysMap[pubKey] privKey, ok := m.keysMap[pubKey]

View File

@ -16,7 +16,7 @@ const (
publicKeyMigrationBatchSize = 100 // Batch update 100 public keys at a time. publicKeyMigrationBatchSize = 100 // Batch update 100 public keys at a time.
) )
func (s *Store) migrateSourceTargetEpochsBucketUp(ctx context.Context) error { func (s *Store) migrateSourceTargetEpochsBucketUp(_ context.Context) error {
// First, we extract the public keys we need to migrate data for. // First, we extract the public keys we need to migrate data for.
publicKeyBytes := make([][]byte, 0) publicKeyBytes := make([][]byte, 0)
err := s.db.View(func(tx *bolt.Tx) error { err := s.db.View(func(tx *bolt.Tx) error {
@ -95,7 +95,7 @@ func (s *Store) migrateSourceTargetEpochsBucketUp(ctx context.Context) error {
}) })
} }
func (s *Store) migrateSourceTargetEpochsBucketDown(ctx context.Context) error { func (s *Store) migrateSourceTargetEpochsBucketDown(_ context.Context) error {
return s.db.Update(func(tx *bolt.Tx) error { return s.db.Update(func(tx *bolt.Tx) error {
bkt := tx.Bucket(pubKeysBucket) bkt := tx.Bucket(pubKeysBucket)
err := bkt.ForEach(func(k, _ []byte) error { err := bkt.ForEach(func(k, _ []byte) error {

View File

@ -63,7 +63,7 @@ func (s *Server) Signup(ctx context.Context, req *pb.AuthRequest) (*pb.AuthRespo
} }
// Login to authenticate with the validator RPC API using a password. // Login to authenticate with the validator RPC API using a password.
func (s *Server) Login(ctx context.Context, req *pb.AuthRequest) (*pb.AuthResponse, error) { func (s *Server) Login(_ context.Context, req *pb.AuthRequest) (*pb.AuthResponse, error) {
walletDir := s.walletDir walletDir := s.walletDir
// We check the strength of the password to ensure it is high-entropy, // We check the strength of the password to ensure it is high-entropy,
// has the required character count, and contains only unicode characters. // has the required character count, and contains only unicode characters.
@ -86,7 +86,7 @@ func (s *Server) Login(ctx context.Context, req *pb.AuthRequest) (*pb.AuthRespon
} }
// HasUsedWeb checks if the user has authenticated via the web interface. // HasUsedWeb checks if the user has authenticated via the web interface.
func (s *Server) HasUsedWeb(ctx context.Context, _ *empty.Empty) (*pb.HasUsedWebResponse, error) { func (s *Server) HasUsedWeb(_ context.Context, _ *empty.Empty) (*pb.HasUsedWebResponse, error) {
walletExists, err := wallet.Exists(s.walletDir) walletExists, err := wallet.Exists(s.walletDir)
if err != nil { if err != nil {
return nil, status.Error(codes.Internal, "Could not check if wallet exists") return nil, status.Error(codes.Internal, "Could not check if wallet exists")
@ -99,7 +99,7 @@ func (s *Server) HasUsedWeb(ctx context.Context, _ *empty.Empty) (*pb.HasUsedWeb
} }
// Logout a user by invalidating their JWT key. // Logout a user by invalidating their JWT key.
func (s *Server) Logout(ctx context.Context, _ *empty.Empty) (*empty.Empty, error) { func (s *Server) Logout(_ context.Context, _ *empty.Empty) (*empty.Empty, error) {
// Invalidate the old JWT key, making all requests done with its token fail. // Invalidate the old JWT key, making all requests done with its token fail.
jwtKey, err := createRandomJWTKey() jwtKey, err := createRandomJWTKey()
if err != nil { if err != nil {
@ -123,7 +123,7 @@ func (s *Server) sendAuthResponse() (*pb.AuthResponse, error) {
} }
// ChangePassword allows changing the RPC password via the API as an authenticated method. // ChangePassword allows changing the RPC password via the API as an authenticated method.
func (s *Server) ChangePassword(ctx context.Context, req *pb.ChangePasswordRequest) (*empty.Empty, error) { func (s *Server) ChangePassword(_ context.Context, req *pb.ChangePasswordRequest) (*empty.Empty, error) {
if req.CurrentPassword == "" { if req.CurrentPassword == "" {
return nil, status.Error(codes.InvalidArgument, "Current password cannot be empty") return nil, status.Error(codes.InvalidArgument, "Current password cannot be empty")
} }
@ -164,7 +164,7 @@ func (s *Server) SaveHashedPassword(password string) error {
// Interval in which we should check if a user has not yet used the RPC Signup endpoint // Interval in which we should check if a user has not yet used the RPC Signup endpoint
// which means they are using the --web flag and someone could come in and signup for them // which means they are using the --web flag and someone could come in and signup for them
// if they have their web host:port exposed to the Internet. // if they have their web host:port exposed to the Internet.
func (s *Server) checkUserSignup(ctx context.Context) { func (s *Server) checkUserSignup(_ context.Context) {
ticker := time.NewTicker(checkUserSignupInterval) ticker := time.NewTicker(checkUserSignupInterval)
defer ticker.Stop() defer ticker.Stop()
for { for {

View File

@ -39,7 +39,7 @@ func (s *Server) GetBeaconNodeConnection(ctx context.Context, _ *emptypb.Empty)
} }
// GetLogsEndpoints for the beacon and validator client. // GetLogsEndpoints for the beacon and validator client.
func (s *Server) GetLogsEndpoints(ctx context.Context, _ *emptypb.Empty) (*validatorpb.LogsEndpointResponse, error) { func (s *Server) GetLogsEndpoints(_ context.Context, _ *emptypb.Empty) (*validatorpb.LogsEndpointResponse, error) {
return nil, status.Error(codes.Unimplemented, "unimplemented") return nil, status.Error(codes.Unimplemented, "unimplemented")
} }

View File

@ -94,7 +94,7 @@ func (s *Server) CreateWallet(ctx context.Context, req *pb.CreateWalletRequest)
} }
// WalletConfig returns the wallet's configuration. If no wallet exists, we return an empty response. // WalletConfig returns the wallet's configuration. If no wallet exists, we return an empty response.
func (s *Server) WalletConfig(ctx context.Context, _ *empty.Empty) (*pb.WalletResponse, error) { func (s *Server) WalletConfig(_ context.Context, _ *empty.Empty) (*pb.WalletResponse, error) {
exists, err := wallet.Exists(s.walletDir) exists, err := wallet.Exists(s.walletDir)
if err != nil { if err != nil {
return nil, status.Errorf(codes.Internal, checkExistsErrMsg) return nil, status.Errorf(codes.Internal, checkExistsErrMsg)