Search in sources :

Example 1 with ConstraintMachineException

use of com.radixdlt.constraintmachine.exceptions.ConstraintMachineException in project radixdlt by radixdlt.

the class RadixEngine method executeInternal.

private RadixEngineResult executeInternal(EngineStore.EngineStoreInTransaction<M> engineStoreInTransaction, List<Txn> txns, M meta, PermissionLevel permissionLevel, boolean skipAuthorization) throws RadixEngineException {
    var processedTxns = new ArrayList<REProcessedTxn>();
    // FIXME: This is quite the hack to increase sigsLeft for execution on noncommits (e.g. mempool)
    // FIXME: Should probably just change metering
    // Start with 0
    var sigsLeft = meta != null ? 0 : 1000;
    var storageStopwatch = Stopwatch.createUnstarted();
    var verificationStopwatch = Stopwatch.createUnstarted();
    for (int i = 0; i < txns.size(); i++) {
        var txn = txns.get(i);
        verificationStopwatch.start();
        var context = new ExecutionContext(txn, permissionLevel, skipAuthorization, sigsLeft);
        final REProcessedTxn processedTxn;
        try {
            processedTxn = this.verify(engineStoreInTransaction, txn, context);
        } catch (TxnParseException | AuthorizationException | ConstraintMachineException e) {
            throw new RadixEngineException(i, txns.size(), txn, e);
        }
        verificationStopwatch.stop();
        // Carry sigs left to the next transaction
        sigsLeft = context.sigsLeft();
        storageStopwatch.start();
        try {
            engineStoreInTransaction.storeTxn(processedTxn);
        } catch (Exception e) {
            logger.error("Store of atom failed: " + processedTxn, e);
            throw e;
        }
        storageStopwatch.stop();
        processedTxns.add(processedTxn);
    }
    try {
        batchVerifier.testMetadata(meta, processedTxns);
    } catch (MetadataException e) {
        logger.error("Invalid metadata: " + processedTxns);
        throw e;
    }
    if (meta != null) {
        engineStoreInTransaction.storeMetadata(meta);
    }
    return RadixEngineResult.create(processedTxns, verificationStopwatch.elapsed(TimeUnit.MILLISECONDS), storageStopwatch.elapsed(TimeUnit.MILLISECONDS));
}
Also used : ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) ExecutionContext(com.radixdlt.constraintmachine.ExecutionContext) AuthorizationException(com.radixdlt.constraintmachine.exceptions.AuthorizationException) ArrayList(java.util.ArrayList) TxnParseException(com.radixdlt.engine.parser.exceptions.TxnParseException) REProcessedTxn(com.radixdlt.constraintmachine.REProcessedTxn) AuthorizationException(com.radixdlt.constraintmachine.exceptions.AuthorizationException) TxBuilderException(com.radixdlt.atom.TxBuilderException) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) TxnParseException(com.radixdlt.engine.parser.exceptions.TxnParseException) DeserializeException(com.radixdlt.serialization.DeserializeException) FeeReserveCompleteException(com.radixdlt.application.system.construction.FeeReserveCompleteException)

Example 2 with ConstraintMachineException

use of com.radixdlt.constraintmachine.exceptions.ConstraintMachineException in project radixdlt by radixdlt.

the class RadixEngineStateComputerTest method preparing_system_update_from_vertex_should_fail.

@Test
public void preparing_system_update_from_vertex_should_fail() throws TxBuilderException {
    // Arrange
    var txn = radixEngine.construct(new NextRound(1, false, 0, i -> proposerElection.getProposer(View.of(i)).getKey())).buildWithoutSignature();
    var illegalTxn = TxLowLevelBuilder.newBuilder(currentForkView.currentForkConfig().engineRules().serialization()).down(SubstateId.ofSubstate(txn.getId(), 1)).up(new RoundData(2, 0)).end().build();
    var v = UnverifiedVertex.create(mock(QuorumCertificate.class), View.of(1), List.of(illegalTxn), proposerElection.getProposer(View.of(1)));
    var vertex = new VerifiedVertex(v, mock(HashCode.class));
    // Act
    var result = sut.prepare(ImmutableList.of(), vertex, 0);
    // Assert
    assertThat(result.getSuccessfulCommands()).hasSize(1);
    assertThat(result.getFailedCommands()).hasValueSatisfying(new Condition<>(e -> {
        var ex = (RadixEngineException) e;
        var cmException = (ConstraintMachineException) ex.getCause();
        return cmException.getCause() instanceof InvalidPermissionException;
    }, "Is invalid_execution_permission error"));
}
Also used : VerifiedVertex(com.radixdlt.hotstuff.bft.VerifiedVertex) Module(com.google.inject.Module) SimpleLedgerAccumulatorAndVerifier(com.radixdlt.ledger.SimpleLedgerAccumulatorAndVerifier) TxAction(com.radixdlt.atom.TxAction) NoOpCommittedReader(com.radixdlt.sync.NoOpCommittedReader) ArgumentMatchers.argThat(org.mockito.ArgumentMatchers.argThat) RadixEngineException(com.radixdlt.engine.RadixEngineException) RadixEngineForksLatestOnlyModule(com.radixdlt.statecomputer.forks.RadixEngineForksLatestOnlyModule) Assertions.assertThat(org.assertj.core.api.Assertions.assertThat) Inject(com.google.inject.Inject) TypedMocks(com.radixdlt.utils.TypedMocks) DefaultSerialization(com.radixdlt.DefaultSerialization) Hasher(com.radixdlt.crypto.Hasher) MempoolAdd(com.radixdlt.mempool.MempoolAdd) RoundData(com.radixdlt.application.system.state.RoundData) QuorumCertificate(com.radixdlt.hotstuff.QuorumCertificate) LedgerHeader(com.radixdlt.hotstuff.LedgerHeader) ByzantineQuorumException(com.radixdlt.ledger.ByzantineQuorumException) CurrentForkView(com.radixdlt.statecomputer.forks.CurrentForkView) VerifiedTxnsAndProof(com.radixdlt.ledger.VerifiedTxnsAndProof) PersistentVertexStore(com.radixdlt.hotstuff.bft.PersistentVertexStore) HashUtils(com.radixdlt.crypto.HashUtils) Genesis(com.radixdlt.statecomputer.checkpoint.Genesis) SystemCounters(com.radixdlt.counters.SystemCounters) NoOpForksEpochStore(com.radixdlt.statecomputer.forks.NoOpForksEpochStore) REEvent(com.radixdlt.constraintmachine.REEvent) StateComputerResult(com.radixdlt.ledger.StateComputerLedger.StateComputerResult) VerifiedVertex(com.radixdlt.hotstuff.bft.VerifiedVertex) EngineStore(com.radixdlt.store.EngineStore) TimestampedECDSASignatures(com.radixdlt.hotstuff.TimestampedECDSASignatures) Collectors(java.util.stream.Collectors) ForksEpochStore(com.radixdlt.statecomputer.forks.ForksEpochStore) SystemCountersImpl(com.radixdlt.counters.SystemCountersImpl) List(java.util.List) Stream(java.util.stream.Stream) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) CommittedReader(com.radixdlt.sync.CommittedReader) MainnetForksModule(com.radixdlt.statecomputer.forks.modules.MainnetForksModule) Amount(com.radixdlt.application.tokens.Amount) TypeLiteral(com.google.inject.TypeLiteral) LedgerAccumulator(com.radixdlt.ledger.LedgerAccumulator) Mockito.mock(org.mockito.Mockito.mock) BFTValidatorSet(com.radixdlt.hotstuff.bft.BFTValidatorSet) LedgerProof(com.radixdlt.hotstuff.LedgerProof) Serialization(com.radixdlt.serialization.Serialization) WeightedRotatingLeaders(com.radixdlt.hotstuff.liveness.WeightedRotatingLeaders) Sha256Hasher(com.radixdlt.hotstuff.Sha256Hasher) PermissionLevel(com.radixdlt.constraintmachine.PermissionLevel) com.radixdlt.atom(com.radixdlt.atom) ProposerElection(com.radixdlt.hotstuff.liveness.ProposerElection) MockedGenesisModule(com.radixdlt.statecomputer.checkpoint.MockedGenesisModule) View(com.radixdlt.hotstuff.bft.View) Assertions.assertThatThrownBy(org.assertj.core.api.Assertions.assertThatThrownBy) ImmutableList(com.google.common.collect.ImmutableList) MempoolConfig(com.radixdlt.mempool.MempoolConfig) AccumulatorState(com.radixdlt.ledger.AccumulatorState) RadixEngineCheckpointModule(com.radixdlt.statecomputer.checkpoint.RadixEngineCheckpointModule) UInt256(com.radixdlt.utils.UInt256) Before(org.junit.Before) MempoolAddSuccess(com.radixdlt.mempool.MempoolAddSuccess) BFTHeader(com.radixdlt.hotstuff.BFTHeader) EventDispatcher(com.radixdlt.environment.EventDispatcher) HashCode(com.google.common.hash.HashCode) RadixEngine(com.radixdlt.engine.RadixEngine) Test(org.junit.Test) Mockito.when(org.mockito.Mockito.when) MempoolRelayTrigger(com.radixdlt.mempool.MempoolRelayTrigger) ForksModule(com.radixdlt.statecomputer.forks.ForksModule) Mockito.verify(org.mockito.Mockito.verify) UnverifiedVertex(com.radixdlt.hotstuff.UnverifiedVertex) BFTNode(com.radixdlt.hotstuff.bft.BFTNode) LedgerUpdate(com.radixdlt.ledger.LedgerUpdate) InMemoryEngineStore(com.radixdlt.store.InMemoryEngineStore) ECKeyPair(com.radixdlt.crypto.ECKeyPair) Rule(org.junit.Rule) Ignore(org.junit.Ignore) BFTValidator(com.radixdlt.hotstuff.bft.BFTValidator) Condition(org.assertj.core.api.Condition) Guice(com.google.inject.Guice) InvalidPermissionException(com.radixdlt.constraintmachine.exceptions.InvalidPermissionException) TemporaryFolder(org.junit.rules.TemporaryFolder) AbstractModule(com.google.inject.AbstractModule) InvalidPermissionException(com.radixdlt.constraintmachine.exceptions.InvalidPermissionException) HashCode(com.google.common.hash.HashCode) RoundData(com.radixdlt.application.system.state.RoundData) QuorumCertificate(com.radixdlt.hotstuff.QuorumCertificate) Test(org.junit.Test)

Example 3 with ConstraintMachineException

use of com.radixdlt.constraintmachine.exceptions.ConstraintMachineException in project radixdlt by radixdlt.

the class RadixEngine method executeInternal.

private RadixEngineResult<M> executeInternal(EngineStore.EngineStoreInTransaction<M> engineStoreInTransaction, List<Txn> txns, Optional<M> metaOpt, PermissionLevel permissionLevel, boolean skipAuthorization) throws RadixEngineException {
    var processedTxns = new ArrayList<REProcessedTxn>();
    // FIXME: This is quite the hack to increase sigsLeft for execution on noncommits (e.g. mempool)
    // FIXME: Should probably just change metering
    // Start with 0
    var sigsLeft = metaOpt.isPresent() ? 0 : 1000;
    var storageStopwatch = Stopwatch.createUnstarted();
    var verificationStopwatch = Stopwatch.createUnstarted();
    for (int i = 0; i < txns.size(); i++) {
        var txn = txns.get(i);
        verificationStopwatch.start();
        var context = new ExecutionContext(txn, permissionLevel, skipAuthorization, sigsLeft);
        final REProcessedTxn processedTxn;
        try {
            processedTxn = this.verify(engineStoreInTransaction, txn, context);
        } catch (TxnParseException | AuthorizationException | ConstraintMachineException e) {
            throw new RadixEngineException(i, txns.size(), txn, e);
        }
        verificationStopwatch.stop();
        // Carry sigs left to the next transaction
        sigsLeft = context.sigsLeft();
        storageStopwatch.start();
        try {
            engineStoreInTransaction.storeTxn(processedTxn);
        } catch (Exception e) {
            logger.error("Store of atom failed: " + processedTxn, e);
            throw e;
        }
        storageStopwatch.stop();
        processedTxns.add(processedTxn);
    }
    try {
        final var resultMetadata = metaOpt.map(meta -> {
            final var postProcessedMetadata = postProcessor.process(meta, engineStoreInTransaction, processedTxns);
            engineStoreInTransaction.storeMetadata(postProcessedMetadata);
            return postProcessedMetadata;
        }).orElse(null);
        return RadixEngineResult.create(processedTxns, resultMetadata, verificationStopwatch.elapsed(TimeUnit.MILLISECONDS), storageStopwatch.elapsed(TimeUnit.MILLISECONDS));
    } catch (PostProcessorException e) {
        logger.error("Invalid metadata: " + processedTxns);
        throw e;
    }
}
Also used : SubstateSerialization(com.radixdlt.constraintmachine.SubstateSerialization) TxAction(com.radixdlt.atom.TxAction) BiFunction(java.util.function.BiFunction) TxBuilder(com.radixdlt.atom.TxBuilder) TxnConstructionRequest(com.radixdlt.atom.TxnConstructionRequest) ResourceInBucket(com.radixdlt.application.tokens.ResourceInBucket) VirtualSubstateDeserialization(com.radixdlt.constraintmachine.VirtualSubstateDeserialization) ParsedTxn(com.radixdlt.engine.parser.ParsedTxn) Map(java.util.Map) SystemMapKey(com.radixdlt.constraintmachine.SystemMapKey) AuthorizationException(com.radixdlt.constraintmachine.exceptions.AuthorizationException) Predicate(java.util.function.Predicate) Set(java.util.Set) ExecutionContext(com.radixdlt.constraintmachine.ExecutionContext) REAddr(com.radixdlt.identifiers.REAddr) TxBuilderException(com.radixdlt.atom.TxBuilderException) EngineStore(com.radixdlt.store.EngineStore) Particle(com.radixdlt.constraintmachine.Particle) Objects(java.util.Objects) List(java.util.List) Logger(org.apache.logging.log4j.Logger) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) Optional(java.util.Optional) TxnParseException(com.radixdlt.engine.parser.exceptions.TxnParseException) SubstateId(com.radixdlt.atom.SubstateId) UInt384(com.radixdlt.utils.UInt384) Stopwatch(com.google.common.base.Stopwatch) SubstateStore(com.radixdlt.atom.SubstateStore) HashMap(java.util.HashMap) PermissionLevel(com.radixdlt.constraintmachine.PermissionLevel) ECPublicKey(com.radixdlt.crypto.ECPublicKey) AtomicReference(java.util.concurrent.atomic.AtomicReference) Function(java.util.function.Function) RawSubstateBytes(com.radixdlt.constraintmachine.RawSubstateBytes) ArrayList(java.util.ArrayList) TransientEngineStore(com.radixdlt.store.TransientEngineStore) SubstateDeserialization(com.radixdlt.constraintmachine.SubstateDeserialization) REParser(com.radixdlt.engine.parser.REParser) UInt256(com.radixdlt.utils.UInt256) REProcessedTxn(com.radixdlt.constraintmachine.REProcessedTxn) SubstateIndex(com.radixdlt.constraintmachine.SubstateIndex) ConstraintMachineConfig(com.radixdlt.constraintmachine.ConstraintMachineConfig) Txn(com.radixdlt.atom.Txn) TimeUnit(java.util.concurrent.TimeUnit) CloseableCursor(com.radixdlt.atom.CloseableCursor) ConstraintMachine(com.radixdlt.constraintmachine.ConstraintMachine) DeserializeException(com.radixdlt.serialization.DeserializeException) FeeReserveCompleteException(com.radixdlt.application.system.construction.FeeReserveCompleteException) LogManager(org.apache.logging.log4j.LogManager) REConstructor(com.radixdlt.atom.REConstructor) AuthorizationException(com.radixdlt.constraintmachine.exceptions.AuthorizationException) ArrayList(java.util.ArrayList) TxnParseException(com.radixdlt.engine.parser.exceptions.TxnParseException) REProcessedTxn(com.radixdlt.constraintmachine.REProcessedTxn) AuthorizationException(com.radixdlt.constraintmachine.exceptions.AuthorizationException) TxBuilderException(com.radixdlt.atom.TxBuilderException) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) TxnParseException(com.radixdlt.engine.parser.exceptions.TxnParseException) DeserializeException(com.radixdlt.serialization.DeserializeException) FeeReserveCompleteException(com.radixdlt.application.system.construction.FeeReserveCompleteException) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) ExecutionContext(com.radixdlt.constraintmachine.ExecutionContext)

Example 4 with ConstraintMachineException

use of com.radixdlt.constraintmachine.exceptions.ConstraintMachineException in project radixdlt by radixdlt.

the class ConstraintMachine method statefulVerify.

/**
 * Executes transition procedures and witness validators in a particle group and validates that
 * the particle group is well formed.
 */
List<List<REStateUpdate>> statefulVerify(ExecutionContext context, CMValidationState validationState, List<REInstruction> instructions) throws ConstraintMachineException {
    int instIndex = 0;
    var expectEnd = false;
    ReducerState reducerState = null;
    var readableAddrs = validationState.resources();
    var groupedStateUpdates = new ArrayList<List<REStateUpdate>>();
    var stateUpdates = new ArrayList<REStateUpdate>();
    meter.onStart(context);
    for (REInstruction inst : instructions) {
        try {
            if (expectEnd && inst.getMicroOp() != REInstruction.REMicroOp.END) {
                throw new MissingExpectedEndException();
            }
            if (inst.getMicroOp() == REInstruction.REMicroOp.SYSCALL) {
                CallData callData = inst.getData();
                var opSignature = OpSignature.ofMethod(inst.getMicroOp().getOp(), REAddr.ofSystem());
                var methodProcedure = loadProcedure(reducerState, opSignature);
                reducerState = callProcedure(methodProcedure, callData, reducerState, readableAddrs, context);
            } else if (inst.getMicroOp().getOp() == REOp.READ) {
                final Particle nextParticle;
                if (inst.getMicroOp() == REInstruction.REMicroOp.VREAD) {
                    SubstateId substateId = inst.getData();
                    nextParticle = validationState.virtualRead(substateId);
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.READ) {
                    SubstateId substateId = inst.getData();
                    nextParticle = validationState.read(substateId);
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.LREAD) {
                    SubstateId substateId = inst.getData();
                    nextParticle = validationState.localRead(substateId.getIndex().orElseThrow());
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.LVREAD) {
                    SubstateId substateId = inst.getData();
                    nextParticle = validationState.localVirtualRead(substateId);
                } else {
                    throw new IllegalStateException("Unknown read op " + inst.getMicroOp());
                }
                var eventId = OpSignature.ofSubstateUpdate(inst.getMicroOp().getOp(), nextParticle.getClass());
                var methodProcedure = loadProcedure(reducerState, eventId);
                reducerState = callProcedure(methodProcedure, nextParticle, reducerState, readableAddrs, context);
                expectEnd = reducerState == null;
            } else if (inst.getMicroOp().getOp() == REOp.DOWNINDEX || inst.getMicroOp().getOp() == REOp.READINDEX) {
                byte[] raw = inst.getData();
                var index = SubstateIndex.create(raw, validationState.deserialization.byteToClass(raw[0]));
                var substateCursor = validationState.getIndexedCursor(index);
                var tmp = stateUpdates;
                final int tmpInstIndex = instIndex;
                var iterator = new Iterator<Particle>() {

                    @Override
                    public boolean hasNext() {
                        return substateCursor.hasNext();
                    }

                    @Override
                    public Particle next() {
                        // FIXME: this is a hack
                        // FIXME: do this via shutdownAll state update rather than individually
                        var substate = substateCursor.next();
                        if (inst.getMicroOp().getOp() == REOp.DOWNINDEX) {
                            var typeByte = deserialization.classToByte(substate.getParticle().getClass());
                            tmp.add(REStateUpdate.of(REOp.DOWN, tmpInstIndex, substate.getId(), typeByte, substate.getParticle(), null));
                        }
                        return substate.getParticle();
                    }
                };
                var substateIterator = new IndexedSubstateIterator<>(index, iterator);
                try {
                    var eventId = OpSignature.ofSubstateUpdate(inst.getMicroOp().getOp(), index.getSubstateClass());
                    var methodProcedure = loadProcedure(reducerState, eventId);
                    reducerState = callProcedure(methodProcedure, substateIterator, reducerState, readableAddrs, context);
                } finally {
                    substateCursor.close();
                }
            } else if (inst.isStateUpdate()) {
                final SubstateId substateId;
                final Particle nextParticle;
                final Supplier<ByteBuffer> substateBuffer;
                if (inst.getMicroOp() == REInstruction.REMicroOp.UP) {
                    // TODO: Cleanup indexing of substate class
                    UpSubstate upSubstate = inst.getData();
                    var buf = upSubstate.getSubstateBuffer();
                    nextParticle = validationState.deserialization.deserialize(buf);
                    if (buf.hasRemaining()) {
                        throw new TrailingBytesException("Substate has trailing bytes.");
                    }
                    substateId = upSubstate.getSubstateId();
                    substateBuffer = upSubstate::getSubstateBuffer;
                    validationState.bootUp(Substate.create(nextParticle, substateId), upSubstate::getSubstateBuffer);
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.VDOWN) {
                    substateId = inst.getData();
                    substateBuffer = null;
                    nextParticle = validationState.virtualShutdown(substateId);
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.DOWN) {
                    substateId = inst.getData();
                    substateBuffer = null;
                    nextParticle = validationState.shutdown(substateId);
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.LDOWN) {
                    substateId = inst.getData();
                    substateBuffer = null;
                    nextParticle = validationState.localShutdown(substateId.getIndex().orElseThrow());
                } else if (inst.getMicroOp() == REInstruction.REMicroOp.LVDOWN) {
                    substateId = inst.getData();
                    substateBuffer = null;
                    nextParticle = validationState.localVirtualShutdown(substateId);
                } else {
                    throw new IllegalStateException("Unhandled op: " + inst.getMicroOp());
                }
                var op = inst.getMicroOp().getOp();
                var typeByte = deserialization.classToByte(nextParticle.getClass());
                stateUpdates.add(REStateUpdate.of(op, instIndex, substateId, typeByte, nextParticle, substateBuffer));
                var eventId = OpSignature.ofSubstateUpdate(op, nextParticle.getClass());
                var methodProcedure = loadProcedure(reducerState, eventId);
                reducerState = callProcedure(methodProcedure, nextParticle, reducerState, readableAddrs, context);
                expectEnd = reducerState == null;
            } else if (inst.getMicroOp() == REInstruction.REMicroOp.END) {
                groupedStateUpdates.add(stateUpdates);
                stateUpdates = new ArrayList<>();
                if (reducerState != null) {
                    var eventId = OpSignature.ofSubstateUpdate(inst.getMicroOp().getOp(), null);
                    var methodProcedure = loadProcedure(reducerState, eventId);
                    reducerState = callProcedure(methodProcedure, reducerState, reducerState, readableAddrs, context);
                }
                expectEnd = false;
            } else if (inst.getMicroOp() == REInstruction.REMicroOp.SIG) {
                if (context.permissionLevel() != PermissionLevel.SYSTEM) {
                    meter.onSigInstruction(context);
                }
            } else {
                // Collect no-ops here
                if (inst.getMicroOp() != REInstruction.REMicroOp.MSG && inst.getMicroOp() != REInstruction.REMicroOp.HEADER) {
                    throw new ProcedureException("Unknown op " + inst.getMicroOp());
                }
            }
        } catch (Exception e) {
            throw new ConstraintMachineException(instIndex, instructions, reducerState, e);
        }
        instIndex++;
    }
    try {
        context.destroy();
    } catch (Exception e) {
        throw new ConstraintMachineException(instIndex, instructions, reducerState, e);
    }
    return groupedStateUpdates;
}
Also used : ArrayList(java.util.ArrayList) MeterException(com.radixdlt.constraintmachine.exceptions.MeterException) ProcedureException(com.radixdlt.constraintmachine.exceptions.ProcedureException) MissingProcedureException(com.radixdlt.constraintmachine.exceptions.MissingProcedureException) AuthorizationException(com.radixdlt.constraintmachine.exceptions.AuthorizationException) SignedSystemException(com.radixdlt.constraintmachine.exceptions.SignedSystemException) SubstateNotFoundException(com.radixdlt.constraintmachine.exceptions.SubstateNotFoundException) NotAResourceException(com.radixdlt.constraintmachine.exceptions.NotAResourceException) VirtualSubstateAlreadyDownException(com.radixdlt.constraintmachine.exceptions.VirtualSubstateAlreadyDownException) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) LocalSubstateNotFoundException(com.radixdlt.constraintmachine.exceptions.LocalSubstateNotFoundException) TrailingBytesException(com.radixdlt.engine.parser.exceptions.TrailingBytesException) InvalidPermissionException(com.radixdlt.constraintmachine.exceptions.InvalidPermissionException) TxnParseException(com.radixdlt.engine.parser.exceptions.TxnParseException) DeserializeException(com.radixdlt.serialization.DeserializeException) ConstraintMachineException(com.radixdlt.constraintmachine.exceptions.ConstraintMachineException) TrailingBytesException(com.radixdlt.engine.parser.exceptions.TrailingBytesException) Iterator(java.util.Iterator) SubstateId(com.radixdlt.atom.SubstateId) Supplier(java.util.function.Supplier) ProcedureException(com.radixdlt.constraintmachine.exceptions.ProcedureException) MissingProcedureException(com.radixdlt.constraintmachine.exceptions.MissingProcedureException)

Aggregations

ConstraintMachineException (com.radixdlt.constraintmachine.exceptions.ConstraintMachineException)4 AuthorizationException (com.radixdlt.constraintmachine.exceptions.AuthorizationException)3 TxnParseException (com.radixdlt.engine.parser.exceptions.TxnParseException)3 DeserializeException (com.radixdlt.serialization.DeserializeException)3 ArrayList (java.util.ArrayList)3 FeeReserveCompleteException (com.radixdlt.application.system.construction.FeeReserveCompleteException)2 SubstateId (com.radixdlt.atom.SubstateId)2 TxAction (com.radixdlt.atom.TxAction)2 TxBuilderException (com.radixdlt.atom.TxBuilderException)2 ExecutionContext (com.radixdlt.constraintmachine.ExecutionContext)2 PermissionLevel (com.radixdlt.constraintmachine.PermissionLevel)2 REProcessedTxn (com.radixdlt.constraintmachine.REProcessedTxn)2 InvalidPermissionException (com.radixdlt.constraintmachine.exceptions.InvalidPermissionException)2 EngineStore (com.radixdlt.store.EngineStore)2 UInt256 (com.radixdlt.utils.UInt256)2 List (java.util.List)2 Stopwatch (com.google.common.base.Stopwatch)1 ImmutableList (com.google.common.collect.ImmutableList)1 HashCode (com.google.common.hash.HashCode)1 AbstractModule (com.google.inject.AbstractModule)1