Search in sources :

Example 1 with ForkChoiceStrategy

use of tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy in project teku by ConsenSys.

the class Store method create.

public static UpdatableStore create(final AsyncRunner asyncRunner, final MetricsSystem metricsSystem, final Spec spec, final BlockProvider blockProvider, final StateAndBlockSummaryProvider stateAndBlockProvider, final Optional<Checkpoint> initialCheckpoint, final UInt64 time, final UInt64 genesisTime, final AnchorPoint finalizedAnchor, final Optional<SlotAndExecutionPayload> finalizedOptimisticTransitionPayload, final Checkpoint justifiedCheckpoint, final Checkpoint bestJustifiedCheckpoint, final Map<Bytes32, StoredBlockMetadata> blockInfoByRoot, final Map<UInt64, VoteTracker> votes, final StoreConfig config) {
    // Create limited collections for non-final data
    final Map<Bytes32, SignedBeaconBlock> blocks = LimitedMap.create(config.getBlockCacheSize());
    final CachingTaskQueue<SlotAndBlockRoot, BeaconState> checkpointStateTaskQueue = CachingTaskQueue.create(asyncRunner, metricsSystem, "memory_checkpoint_states", config.getCheckpointStateCacheSize());
    final CachingTaskQueue<Bytes32, StateAndBlockSummary> stateTaskQueue = CachingTaskQueue.create(asyncRunner, metricsSystem, "memory_states", config.getStateCacheSize());
    final ForkChoiceStrategy forkChoiceStrategy = ForkChoiceStrategy.initialize(spec, buildProtoArray(spec, blockInfoByRoot, initialCheckpoint, justifiedCheckpoint, finalizedAnchor));
    return new Store(metricsSystem, spec, config.getHotStatePersistenceFrequencyInEpochs(), blockProvider, stateAndBlockProvider, stateTaskQueue, initialCheckpoint, time, genesisTime, finalizedAnchor, finalizedOptimisticTransitionPayload, justifiedCheckpoint, bestJustifiedCheckpoint, forkChoiceStrategy, votes, blocks, checkpointStateTaskQueue);
}
Also used : SlotAndBlockRoot(tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot) StateAndBlockSummary(tech.pegasys.teku.spec.datastructures.blocks.StateAndBlockSummary) ForkChoiceStrategy(tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy) SignedBeaconBlock(tech.pegasys.teku.spec.datastructures.blocks.SignedBeaconBlock) Bytes32(org.apache.tuweni.bytes.Bytes32) BeaconState(tech.pegasys.teku.spec.datastructures.state.beaconstate.BeaconState)

Example 2 with ForkChoiceStrategy

use of tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy in project teku by ConsenSys.

the class RecentChainData method computeReorgContext.

private Optional<ReorgContext> computeReorgContext(final ReadOnlyForkChoiceStrategy forkChoiceStrategy, final Optional<ChainHead> originalChainHead, final ChainHead newChainHead) {
    final Optional<ReorgContext> optionalReorgContext;
    if (originalChainHead.map(head -> hasReorgedFrom(head.getRoot(), head.getSlot())).orElse(false)) {
        final ChainHead previousChainHead = originalChainHead.get();
        final SlotAndBlockRoot commonAncestorSlotAndBlockRoot = forkChoiceStrategy.findCommonAncestor(previousChainHead.getRoot(), newChainHead.getRoot()).orElseGet(() -> store.getFinalizedCheckpoint().toSlotAndBlockRoot(spec));
        reorgCounter.inc();
        optionalReorgContext = ReorgContext.of(previousChainHead.getRoot(), previousChainHead.getSlot(), previousChainHead.getStateRoot(), commonAncestorSlotAndBlockRoot.getSlot(), commonAncestorSlotAndBlockRoot.getBlockRoot());
    } else {
        optionalReorgContext = ReorgContext.empty();
    }
    return optionalReorgContext;
}
Also used : SpecConfigBellatrix(tech.pegasys.teku.spec.config.SpecConfigBellatrix) ProtoNodeData(tech.pegasys.teku.spec.datastructures.forkchoice.ProtoNodeData) StoreConfig(tech.pegasys.teku.storage.store.StoreConfig) BlockProvider(tech.pegasys.teku.dataproviders.lookup.BlockProvider) BeaconBlock(tech.pegasys.teku.spec.datastructures.blocks.BeaconBlock) StateAndBlockSummary(tech.pegasys.teku.spec.datastructures.blocks.StateAndBlockSummary) ReadOnlyStore(tech.pegasys.teku.spec.datastructures.forkchoice.ReadOnlyStore) Map(java.util.Map) ForkInfo(tech.pegasys.teku.spec.datastructures.state.ForkInfo) Bytes32(org.apache.tuweni.bytes.Bytes32) GenesisData(tech.pegasys.teku.spec.datastructures.genesis.GenesisData) AsyncRunner(tech.pegasys.teku.infrastructure.async.AsyncRunner) ConcurrentHashMap(java.util.concurrent.ConcurrentHashMap) Set(java.util.Set) NavigableMap(java.util.NavigableMap) Logger(org.apache.logging.log4j.Logger) Optional(java.util.Optional) VoteUpdateChannel(tech.pegasys.teku.storage.api.VoteUpdateChannel) MetricsSystem(org.hyperledger.besu.plugin.services.MetricsSystem) Checkpoint(tech.pegasys.teku.spec.datastructures.state.Checkpoint) Counter(org.hyperledger.besu.plugin.services.metrics.Counter) ChainHeadChannel(tech.pegasys.teku.storage.api.ChainHeadChannel) StoreUpdateHandler(tech.pegasys.teku.storage.store.UpdatableStore.StoreUpdateHandler) ReadOnlyForkChoiceStrategy(tech.pegasys.teku.spec.datastructures.forkchoice.ReadOnlyForkChoiceStrategy) UpdatableStore(tech.pegasys.teku.storage.store.UpdatableStore) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) SafeFuture(tech.pegasys.teku.infrastructure.async.SafeFuture) MinimalBeaconBlockSummary(tech.pegasys.teku.spec.datastructures.blocks.MinimalBeaconBlockSummary) Fork(tech.pegasys.teku.spec.datastructures.state.Fork) StoreBuilder(tech.pegasys.teku.storage.store.StoreBuilder) SpecVersion(tech.pegasys.teku.spec.SpecVersion) VoteUpdater(tech.pegasys.teku.spec.datastructures.forkchoice.VoteUpdater) UInt64(tech.pegasys.teku.infrastructure.unsigned.UInt64) Spec(tech.pegasys.teku.spec.Spec) SignedBeaconBlock(tech.pegasys.teku.spec.datastructures.blocks.SignedBeaconBlock) SlotAndBlockRoot(tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot) BeaconStateUtil(tech.pegasys.teku.spec.logic.common.util.BeaconStateUtil) FinalizedCheckpointChannel(tech.pegasys.teku.storage.api.FinalizedCheckpointChannel) EmptyStoreResults(tech.pegasys.teku.storage.store.EmptyStoreResults) ReorgContext(tech.pegasys.teku.storage.api.ReorgContext) StorageUpdateChannel(tech.pegasys.teku.storage.api.StorageUpdateChannel) StateAndBlockSummaryProvider(tech.pegasys.teku.dataproviders.lookup.StateAndBlockSummaryProvider) StoreTransaction(tech.pegasys.teku.storage.store.UpdatableStore.StoreTransaction) ForkChoiceStrategy(tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy) TekuMetricCategory(tech.pegasys.teku.infrastructure.metrics.TekuMetricCategory) TreeMap(java.util.TreeMap) AnchorPoint(tech.pegasys.teku.spec.datastructures.state.AnchorPoint) Bytes4(tech.pegasys.teku.infrastructure.bytes.Bytes4) Collections(java.util.Collections) LogManager(org.apache.logging.log4j.LogManager) SpecMilestone(tech.pegasys.teku.spec.SpecMilestone) BeaconState(tech.pegasys.teku.spec.datastructures.state.beaconstate.BeaconState) SlotAndBlockRoot(tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot) ReorgContext(tech.pegasys.teku.storage.api.ReorgContext)

Example 3 with ForkChoiceStrategy

use of tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy in project teku by ConsenSys.

the class ForkChoice method applyVotesFromBlock.

private void applyVotesFromBlock(final ForkChoiceStrategy forkChoiceStrategy, final UInt64 currentEpoch, final CapturingIndexedAttestationCache indexedAttestationProvider) {
    final VoteUpdater voteUpdater = recentChainData.startVoteUpdate();
    indexedAttestationProvider.getIndexedAttestations().stream().filter(attestation -> validateBlockAttestation(forkChoiceStrategy, currentEpoch, attestation)).forEach(attestation -> forkChoiceStrategy.onAttestation(voteUpdater, attestation));
    voteUpdater.commit();
}
Also used : StateRootCollector.addParentStateRoots(tech.pegasys.teku.statetransition.forkchoice.StateRootCollector.addParentStateRoots) AttestationProcessingResult(tech.pegasys.teku.spec.datastructures.util.AttestationProcessingResult) FailureReason(tech.pegasys.teku.spec.logic.common.statetransition.results.BlockImportResult.FailureReason) ExceptionThrowingRunnable(tech.pegasys.teku.infrastructure.async.ExceptionThrowingRunnable) ReadOnlyForkChoiceStrategy(tech.pegasys.teku.spec.datastructures.forkchoice.ReadOnlyForkChoiceStrategy) UpdatableStore(tech.pegasys.teku.storage.store.UpdatableStore) IndexedAttestation(tech.pegasys.teku.spec.datastructures.operations.IndexedAttestation) SafeFuture(tech.pegasys.teku.infrastructure.async.SafeFuture) CapturingIndexedAttestationCache(tech.pegasys.teku.spec.cache.CapturingIndexedAttestationCache) ForkChoiceUtil(tech.pegasys.teku.spec.logic.common.util.ForkChoiceUtil) Subscribers(tech.pegasys.teku.infrastructure.subscribers.Subscribers) VoteUpdater(tech.pegasys.teku.spec.datastructures.forkchoice.VoteUpdater) InvalidCheckpointException(tech.pegasys.teku.spec.datastructures.forkchoice.InvalidCheckpointException) Preconditions.checkArgument(com.google.common.base.Preconditions.checkArgument) ExecutionPayloadStatus(tech.pegasys.teku.spec.executionengine.ExecutionPayloadStatus) UInt64(tech.pegasys.teku.infrastructure.unsigned.UInt64) Spec(tech.pegasys.teku.spec.Spec) SignedBeaconBlock(tech.pegasys.teku.spec.datastructures.blocks.SignedBeaconBlock) SlotAndBlockRoot(tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot) Bytes32(org.apache.tuweni.bytes.Bytes32) FatalServiceFailureException(tech.pegasys.teku.infrastructure.exceptions.FatalServiceFailureException) ForkChoiceState(tech.pegasys.teku.spec.executionengine.ForkChoiceState) EventThread(tech.pegasys.teku.infrastructure.async.eventthread.EventThread) Throwables(com.google.common.base.Throwables) ExecutionEngineChannel(tech.pegasys.teku.spec.executionengine.ExecutionEngineChannel) INTERVALS_PER_SLOT(tech.pegasys.teku.spec.constants.NetworkConstants.INTERVALS_PER_SLOT) P2P_LOG(tech.pegasys.teku.infrastructure.logging.P2PLogger.P2P_LOG) StoreTransaction(tech.pegasys.teku.storage.store.UpdatableStore.StoreTransaction) StateTransitionException(tech.pegasys.teku.spec.logic.common.statetransition.exceptions.StateTransitionException) List(java.util.List) ForkChoiceStrategy(tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy) ExceptionUtil(tech.pegasys.teku.infrastructure.exceptions.ExceptionUtil) Logger(org.apache.logging.log4j.Logger) IndexedAttestationCache(tech.pegasys.teku.spec.cache.IndexedAttestationCache) RecentChainData(tech.pegasys.teku.storage.client.RecentChainData) ValidateableAttestation(tech.pegasys.teku.spec.datastructures.attestation.ValidateableAttestation) Optional(java.util.Optional) ExceptionThrowingSupplier(tech.pegasys.teku.infrastructure.async.ExceptionThrowingSupplier) LogManager(org.apache.logging.log4j.LogManager) Checkpoint(tech.pegasys.teku.spec.datastructures.state.Checkpoint) PayloadStatus(tech.pegasys.teku.spec.executionengine.PayloadStatus) BlockImportResult(tech.pegasys.teku.spec.logic.common.statetransition.results.BlockImportResult) BeaconState(tech.pegasys.teku.spec.datastructures.state.beaconstate.BeaconState) VoteUpdater(tech.pegasys.teku.spec.datastructures.forkchoice.VoteUpdater)

Example 4 with ForkChoiceStrategy

use of tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy in project teku by ConsenSys.

the class ForkChoice method importBlockAndState.

private BlockImportResult importBlockAndState(final SignedBeaconBlock block, final BeaconState blockSlotState, final ForkChoiceUtil forkChoiceUtil, final CapturingIndexedAttestationCache indexedAttestationCache, final BeaconState postState, final PayloadValidationResult payloadValidationResult) {
    final PayloadStatus payloadResult = payloadValidationResult.getStatus();
    if (payloadResult.hasInvalidStatus()) {
        final BlockImportResult result = BlockImportResult.failedStateTransition(new IllegalStateException("Invalid ExecutionPayload: " + payloadResult.getValidationError().orElse("No reason provided")));
        reportInvalidBlock(block, result);
        payloadValidationResult.getInvalidTransitionBlockRoot().ifPresent(invalidTransitionBlockRoot -> getForkChoiceStrategy().onExecutionPayloadResult(invalidTransitionBlockRoot, payloadResult));
        return result;
    }
    if (payloadResult.hasNotValidatedStatus() && !recentChainData.isOptimisticSyncPossible(block.getSlot())) {
        return BlockImportResult.FAILED_EXECUTION_PAYLOAD_EXECUTION_SYNCING;
    }
    if (payloadResult.hasFailedExecution()) {
        return BlockImportResult.failedExecutionPayloadExecution(payloadResult.getFailureCause().orElseThrow());
    }
    final ForkChoiceStrategy forkChoiceStrategy = getForkChoiceStrategy();
    // (which may have changed while we were processing the block)
    if (!forkChoiceUtil.blockDescendsFromLatestFinalizedBlock(block, recentChainData.getStore(), forkChoiceStrategy)) {
        return BlockImportResult.FAILED_INVALID_ANCESTRY;
    }
    final StoreTransaction transaction = recentChainData.startStoreTransaction();
    addParentStateRoots(spec, blockSlotState, transaction);
    forkChoiceUtil.applyBlockToStore(transaction, block, postState);
    if (proposerBoostEnabled && spec.getCurrentSlot(transaction).equals(block.getSlot())) {
        final int secondsPerSlot = spec.getSecondsPerSlot(block.getSlot());
        final UInt64 timeIntoSlot = transaction.getTime().minus(transaction.getGenesisTime()).mod(secondsPerSlot);
        final boolean isBeforeAttestingInterval = timeIntoSlot.isLessThan(secondsPerSlot / INTERVALS_PER_SLOT);
        if (isBeforeAttestingInterval) {
            transaction.setProposerBoostRoot(block.getRoot());
        }
    }
    if (payloadResult.hasValidStatus()) {
        UInt64 latestValidFinalizedSlot = transaction.getLatestFinalized().getSlot();
        if (latestValidFinalizedSlot.isGreaterThan(transaction.getLatestValidFinalizedSlot())) {
            transaction.setLatestValidFinalizedSlot(latestValidFinalizedSlot);
        }
    }
    // Note: not using thenRun here because we want to ensure each step is on the event thread
    transaction.commit().join();
    forkChoiceStrategy.onExecutionPayloadResult(block.getRoot(), payloadResult);
    final UInt64 currentEpoch = spec.computeEpochAtSlot(spec.getCurrentSlot(transaction));
    // before that, none of the attestations will be applicable so just skip the whole step.
    if (spec.computeEpochAtSlot(block.getSlot()).isGreaterThanOrEqualTo(currentEpoch.minusMinZero(1))) {
        applyVotesFromBlock(forkChoiceStrategy, currentEpoch, indexedAttestationCache);
    }
    final BlockImportResult result;
    if (payloadResult.hasValidStatus()) {
        result = BlockImportResult.successful(block);
    } else {
        result = BlockImportResult.optimisticallySuccessful(block);
    }
    updateForkChoiceForImportedBlock(block, result, forkChoiceStrategy);
    notifyForkChoiceUpdatedAndOptimisticSyncingChanged();
    return result;
}
Also used : ExecutionPayloadStatus(tech.pegasys.teku.spec.executionengine.ExecutionPayloadStatus) PayloadStatus(tech.pegasys.teku.spec.executionengine.PayloadStatus) ReadOnlyForkChoiceStrategy(tech.pegasys.teku.spec.datastructures.forkchoice.ReadOnlyForkChoiceStrategy) ForkChoiceStrategy(tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy) StoreTransaction(tech.pegasys.teku.storage.store.UpdatableStore.StoreTransaction) UInt64(tech.pegasys.teku.infrastructure.unsigned.UInt64) BlockImportResult(tech.pegasys.teku.spec.logic.common.statetransition.results.BlockImportResult) Checkpoint(tech.pegasys.teku.spec.datastructures.state.Checkpoint)

Example 5 with ForkChoiceStrategy

use of tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy in project teku by ConsenSys.

the class ForkChoice method findNewChainHead.

private SlotAndBlockRoot findNewChainHead(final SignedBeaconBlock block, final ForkChoiceStrategy forkChoiceStrategy) {
    // child of the current chain head we'd have already selected it as head.
    if (recentChainData.getBestBlockRoot().map(chainHeadRoot -> chainHeadRoot.equals(block.getParentRoot())).orElse(false)) {
        return new SlotAndBlockRoot(block.getSlot(), block.getRoot());
    }
    // Otherwise, use fork choice to find the new chain head as if this block is on time the
    // proposer weighting may cause us to reorg.
    // During sync, this may be noticeably slower than just comparing the chain head due to the way
    // ProtoArray skips updating all ancestors when adding a new block but it's cheap when in sync.
    final Checkpoint justifiedCheckpoint = recentChainData.getJustifiedCheckpoint().orElseThrow();
    final Checkpoint finalizedCheckpoint = recentChainData.getFinalizedCheckpoint().orElseThrow();
    return forkChoiceStrategy.findHead(justifiedCheckpoint, finalizedCheckpoint);
}
Also used : StateRootCollector.addParentStateRoots(tech.pegasys.teku.statetransition.forkchoice.StateRootCollector.addParentStateRoots) AttestationProcessingResult(tech.pegasys.teku.spec.datastructures.util.AttestationProcessingResult) FailureReason(tech.pegasys.teku.spec.logic.common.statetransition.results.BlockImportResult.FailureReason) ExceptionThrowingRunnable(tech.pegasys.teku.infrastructure.async.ExceptionThrowingRunnable) ReadOnlyForkChoiceStrategy(tech.pegasys.teku.spec.datastructures.forkchoice.ReadOnlyForkChoiceStrategy) UpdatableStore(tech.pegasys.teku.storage.store.UpdatableStore) IndexedAttestation(tech.pegasys.teku.spec.datastructures.operations.IndexedAttestation) SafeFuture(tech.pegasys.teku.infrastructure.async.SafeFuture) CapturingIndexedAttestationCache(tech.pegasys.teku.spec.cache.CapturingIndexedAttestationCache) ForkChoiceUtil(tech.pegasys.teku.spec.logic.common.util.ForkChoiceUtil) Subscribers(tech.pegasys.teku.infrastructure.subscribers.Subscribers) VoteUpdater(tech.pegasys.teku.spec.datastructures.forkchoice.VoteUpdater) InvalidCheckpointException(tech.pegasys.teku.spec.datastructures.forkchoice.InvalidCheckpointException) Preconditions.checkArgument(com.google.common.base.Preconditions.checkArgument) ExecutionPayloadStatus(tech.pegasys.teku.spec.executionengine.ExecutionPayloadStatus) UInt64(tech.pegasys.teku.infrastructure.unsigned.UInt64) Spec(tech.pegasys.teku.spec.Spec) SignedBeaconBlock(tech.pegasys.teku.spec.datastructures.blocks.SignedBeaconBlock) SlotAndBlockRoot(tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot) Bytes32(org.apache.tuweni.bytes.Bytes32) FatalServiceFailureException(tech.pegasys.teku.infrastructure.exceptions.FatalServiceFailureException) ForkChoiceState(tech.pegasys.teku.spec.executionengine.ForkChoiceState) EventThread(tech.pegasys.teku.infrastructure.async.eventthread.EventThread) Throwables(com.google.common.base.Throwables) ExecutionEngineChannel(tech.pegasys.teku.spec.executionengine.ExecutionEngineChannel) INTERVALS_PER_SLOT(tech.pegasys.teku.spec.constants.NetworkConstants.INTERVALS_PER_SLOT) P2P_LOG(tech.pegasys.teku.infrastructure.logging.P2PLogger.P2P_LOG) StoreTransaction(tech.pegasys.teku.storage.store.UpdatableStore.StoreTransaction) StateTransitionException(tech.pegasys.teku.spec.logic.common.statetransition.exceptions.StateTransitionException) List(java.util.List) ForkChoiceStrategy(tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy) ExceptionUtil(tech.pegasys.teku.infrastructure.exceptions.ExceptionUtil) Logger(org.apache.logging.log4j.Logger) IndexedAttestationCache(tech.pegasys.teku.spec.cache.IndexedAttestationCache) RecentChainData(tech.pegasys.teku.storage.client.RecentChainData) ValidateableAttestation(tech.pegasys.teku.spec.datastructures.attestation.ValidateableAttestation) Optional(java.util.Optional) ExceptionThrowingSupplier(tech.pegasys.teku.infrastructure.async.ExceptionThrowingSupplier) LogManager(org.apache.logging.log4j.LogManager) Checkpoint(tech.pegasys.teku.spec.datastructures.state.Checkpoint) PayloadStatus(tech.pegasys.teku.spec.executionengine.PayloadStatus) BlockImportResult(tech.pegasys.teku.spec.logic.common.statetransition.results.BlockImportResult) BeaconState(tech.pegasys.teku.spec.datastructures.state.beaconstate.BeaconState) SlotAndBlockRoot(tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot) Checkpoint(tech.pegasys.teku.spec.datastructures.state.Checkpoint)

Aggregations

ForkChoiceStrategy (tech.pegasys.teku.ethereum.forkchoice.ForkChoiceStrategy)6 Bytes32 (org.apache.tuweni.bytes.Bytes32)5 UInt64 (tech.pegasys.teku.infrastructure.unsigned.UInt64)5 SignedBeaconBlock (tech.pegasys.teku.spec.datastructures.blocks.SignedBeaconBlock)5 SlotAndBlockRoot (tech.pegasys.teku.spec.datastructures.blocks.SlotAndBlockRoot)5 ReadOnlyForkChoiceStrategy (tech.pegasys.teku.spec.datastructures.forkchoice.ReadOnlyForkChoiceStrategy)5 Checkpoint (tech.pegasys.teku.spec.datastructures.state.Checkpoint)5 BeaconState (tech.pegasys.teku.spec.datastructures.state.beaconstate.BeaconState)5 Optional (java.util.Optional)4 LogManager (org.apache.logging.log4j.LogManager)4 Logger (org.apache.logging.log4j.Logger)4 SafeFuture (tech.pegasys.teku.infrastructure.async.SafeFuture)4 Spec (tech.pegasys.teku.spec.Spec)4 VoteUpdater (tech.pegasys.teku.spec.datastructures.forkchoice.VoteUpdater)4 StoreTransaction (tech.pegasys.teku.storage.store.UpdatableStore.StoreTransaction)4 ExecutionPayloadStatus (tech.pegasys.teku.spec.executionengine.ExecutionPayloadStatus)3 PayloadStatus (tech.pegasys.teku.spec.executionengine.PayloadStatus)3 BlockImportResult (tech.pegasys.teku.spec.logic.common.statetransition.results.BlockImportResult)3 UpdatableStore (tech.pegasys.teku.storage.store.UpdatableStore)3 Preconditions.checkArgument (com.google.common.base.Preconditions.checkArgument)2