Module Contents
alltypes
Module Contents
class ANSIProgressObserver
object ANSIProgressRenderer
interface APIServer
Module Contents
abstract fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
abstract fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
abstract fun fetchProtocolsRequiringAttention(query: StatesQuery): Map<StateRef, ProtocolRequiringAttention>
abstract fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
abstract fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
abstract fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
abstract fun invokeProtocolSync(type: ProtocolRef, args: Map<String, Any?>): Any?
abstract fun provideProtocolResponse(protocol: ProtocolInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
abstract fun queryStates(query: StatesQuery): List<StateRef>
abstract fun serverTime(): LocalDateTime
abstract fun status(): <ERROR CLASS>
class APIServerImpl : APIServer
Module Contents
APIServerImpl(node: AbstractNode)
fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
fun fetchProtocolsRequiringAttention(query: StatesQuery): Map<StateRef, ProtocolRequiringAttention>
fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
fun invokeProtocolSync(type: ProtocolRef, args: Map<String, Any?>): Any?
val node: AbstractNode
fun provideProtocolResponse(protocol: ProtocolInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
fun queryStates(query: StatesQuery): List<StateRef>
fun serverTime(): LocalDateTime
fun status(): <ERROR CLASS>
abstract class AbstractConserveAmount<S : FungibleAsset<T>, T : Any> : GroupClause<S, Issued<T>>
abstract class AbstractIssue<S : ContractState, T : Any> : GroupClause<S, Issued<T>>
abstract class AbstractNode
abstract class AbstractNodeService : SingletonSerializeAsToken
abstract class AbstractStateReplacementProtocol<T>
interface AcceptsFileUpload
enum class AccrualAdjustment
object Ack : DeserializeAsKotlinObjectDef
enum class AddOrRemove
interface AffinityExecutor : Executor
interface AllPossibleRecipients : MessageRecipients
class AlwaysSucceedContract : Contract
data class Amount<T> : Comparable<Amount<T>>
data class AppContext
class ArtemisMessagingService : SingletonSerializeAsToken, MessagingService
interface Attachment : NamedByHash
class AttachmentDownloadServlet
class AttachmentResolutionException : Exception
interface AttachmentStorage
class AttachmentsClassLoader : SecureClassLoader
data class AuthenticatedObject<out T : Any>
object AutoOfferProtocol
data class BilateralNetState<P> : NetState<P>
interface BilateralNettableState<N : BilateralNettableState<N>>
class BriefLogFormatter : Formatter
open class BusinessCalendar
Module Contents
val TEST_CALENDAR_DATA: <ERROR CLASS>
class UnknownCalendar : Exception
open fun applyRollConvention(testDate: LocalDate, dateRollConvention: DateRollConvention): LocalDate
val calendars: Array<out String>
val calendars: <ERROR CLASS>
fun createGenericSchedule(startDate: LocalDate, period: Frequency, calendar: BusinessCalendar = getInstance(), dateRollConvention: DateRollConvention = DateRollConvention.Following, noOfAdditionalPeriods: Int = Integer.MAX_VALUE, endDate: LocalDate? = null, periodOffset: Int? = null): List<LocalDate>
open fun equals(other: Any?): Boolean
fun getInstance(vararg calname: String): BusinessCalendar
fun getOffsetDate(startDate: LocalDate, period: Frequency, steps: Int = 1): LocalDate
open fun hashCode(): Int
val holidayDates: List<LocalDate>
open fun isWorkingDay(date: LocalDate): Boolean
fun moveBusinessDays(date: LocalDate, direction: DateRollDirection, i: Int): LocalDate
fun parseDateFromString(it: String): LocalDate
class Cash : ClauseVerifier
Module Contents
Cash()
interface Clauses
interface Commands : Commands
data class State : FungibleAsset<Currency>
val clauses: List<SingleClause>
fun extractCommands(tx: TransactionForContract): List<AuthenticatedObject<Commands>>
fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<Currency>>, changeKey: PublicKey, cashStates: List<StateAndRef<State>>): PublicKey
fun generateIssue(tx: TransactionBuilder, tokenDef: Issued<Currency>, pennies: Long, owner: PublicKey, notary: Party): Unit
fun generateIssue(tx: TransactionBuilder, amount: Amount<Issued<Currency>>, owner: PublicKey, notary: Party): Unit
fun generateSpend(tx: TransactionBuilder, amount: Amount<Issued<Currency>>, to: PublicKey, cashStates: List<StateAndRef<State>>): List<PublicKey>
fun generateSpend(tx: TransactionBuilder, amount: Amount<Currency>, to: PublicKey, cashStates: List<StateAndRef<State>>, onlyFromParties: Set<Party>? = null): List<PublicKey>
val legalContractReference: SecureHash
class CashBalanceAsMetricsObserver
data class Checkpoint
interface CheckpointStorage
object CityDatabase
interface Clause
abstract class ClauseVerifier : Contract
sealed class CliParams
object CliParamsSpec
data class Command
interface CommandData
class CommercialPaper : ClauseVerifier
class CommercialPaperLegacy : Contract
class Config
class ConfigurationException : Exception
interface Contract
data class ContractClassRef : ContractDefRef
interface ContractDefRef
data class ContractLedgerRef : ContractDefRef
interface ContractState
interface CordaPluginRegistry
class CubicSplineInterpolator : Interpolator
class DataUploadServlet
class DataVendingService : AbstractNodeService
enum class DateRollConvention
enum class DateRollDirection
enum class DayCountBasisDay
enum class DayCountBasisYear
interface DealState : LinearState
class DemoClock : MutableClock, SerializeAsToken
interface DeserializeAsKotlinObjectDef
open class DigitalSignature : OpaqueBytes
class DummyContract : Contract
class DummyLinearState : LinearState
class DummyPublicKey : PublicKey, Comparable<PublicKey>
data class DummyState : ContractState
class DuplicateOutputLabel : Exception
class E2ETestKeyManagementService : SingletonSerializeAsToken, KeyManagementService
object Ed25519PrivateKeySerializer
object Ed25519PublicKeySerializer
object Emoji
sealed class EnforceVerifyOrFail
open class Event
object ExitServerProtocol
data class Expression
object ExpressionDeserializer
object ExpressionSerializer
class FetchAttachmentsProtocol : FetchDataProtocol<Attachment, ByteArray>
abstract class FetchDataProtocol<T : NamedByHash, in W : Any> : ProtocolLogic<Result<T>>
class FetchTransactionsProtocol : FetchDataProtocol<SignedTransaction, SignedTransaction>
class FiberBox<T>
sealed class FiberRequest
data class Fix : CommandData
data class FixOf
interface FixableDealState : DealState
class FixedRate : Rate
class FixedRatePaymentEvent : RatePaymentEvent
object FixingSessionInitiationHandler
open class FloatingRate : Rate
class FloatingRatePaymentEvent : RatePaymentEvent
Module Contents
FloatingRatePaymentEvent(date: LocalDate, accrualStartDate: LocalDate, accrualEndDate: LocalDate, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, fixingDate: LocalDate, notional: Amount<Currency>, rate: Rate)
val CSVHeader: String
fun asCSV(): String
fun copy(date: LocalDate = this.date, accrualStartDate: LocalDate = this.accrualStartDate, accrualEndDate: LocalDate = this.accrualEndDate, dayCountBasisDay: DayCountBasisDay = this.dayCountBasisDay, dayCountBasisYear: DayCountBasisYear = this.dayCountBasisYear, fixingDate: LocalDate = this.fixingDate, notional: Amount<Currency> = this.notional, rate: Rate = this.rate): FloatingRatePaymentEvent
fun equals(other: Any?): Boolean
val fixingDate: LocalDate
val flow: Amount<Currency>
fun hashCode(): Int
fun toString(): String
fun withNewRate(newRate: Rate): FloatingRatePaymentEvent
enum class Frequency
interface FungibleAsset<T> : OwnableState
interface GroupClause<S : ContractState, T : Any> : Clause, GroupVerify<S, T>
abstract class GroupClauseVerifier<S : ContractState, T : Any> : SingleClause
interface GroupVerify<in S, in T : Any>
enum class IRSDemoNode
class IRSDemoPluginRegistry : CordaPluginRegistry
enum class IRSDemoRole
class IRSSimulation : Simulation
interface IdentityService
class IllegalProtocolLogicException : IllegalArgumentException
class ImmutableClassSerializer<T : Any>
class InMemoryIdentityService : SingletonSerializeAsToken, IdentityService
class InMemoryMessagingNetwork : SingletonSerializeAsToken
open class InMemoryNetworkMapCache : SingletonSerializeAsToken, NetworkMapCache
class InMemoryNetworkMapService : NetworkMapService, AbstractNodeService
class InMemoryUniquenessProvider : UniquenessProvider
open class InMemoryWalletService : SingletonSerializeAsToken, WalletService
class InsufficientBalanceException : Exception
data class InterceptorClause : SingleClause
class InterestRateSwap : ClauseVerifier
Module Contents
InterestRateSwap()
data class Calculation
interface Clause
interface Commands : CommandData
data class Common
Module Contents
Common(baseCurrency: Currency, eligibleCurrency: Currency, eligibleCreditSupport: String, independentAmounts: Amount<Currency>, threshold: Amount<Currency>, minimumTransferAmount: Amount<Currency>, rounding: Amount<Currency>, valuationDate: String, notificationTime: String, resolutionTime: String, interestRate: ReferenceRate, addressForTransfers: String, exposure: UnknownType, localBusinessDay: BusinessCalendar, dailyInterestAmount: Expression, tradeID: String, hashLegalDocs: String)
val addressForTransfers: String
val baseCurrency: Currency
val dailyInterestAmount: Expression
val eligibleCreditSupport: String
val eligibleCurrency: Currency
val exposure: UnknownType
val hashLegalDocs: String
val independentAmounts: Amount<Currency>
val interestRate: ReferenceRate
val localBusinessDay: BusinessCalendar
val minimumTransferAmount: Amount<Currency>
val notificationTime: String
val resolutionTime: String
val rounding: Amount<Currency>
val threshold: Amount<Currency>
val tradeID: String
val valuationDate: String
abstract class CommonLeg
Module Contents
CommonLeg(notional: Amount<Currency>, paymentFrequency: Frequency, effectiveDate: LocalDate, effectiveDateAdjustment: DateRollConvention?, terminationDate: LocalDate, terminationDateAdjustment: DateRollConvention?, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, dayInMonth: Int, paymentRule: PaymentRule, paymentDelay: Int, paymentCalendar: BusinessCalendar, interestPeriodAdjustment: AccrualAdjustment)
val dayCountBasisDay: DayCountBasisDay
val dayCountBasisYear: DayCountBasisYear
val dayInMonth: Int
val effectiveDate: LocalDate
val effectiveDateAdjustment: DateRollConvention?
open fun equals(other: Any?): Boolean
open fun hashCode(): Int
val interestPeriodAdjustment: AccrualAdjustment
val notional: Amount<Currency>
val paymentCalendar: BusinessCalendar
val paymentDelay: Int
val paymentFrequency: Frequency
val paymentRule: PaymentRule
val terminationDate: LocalDate
val terminationDateAdjustment: DateRollConvention?
open fun toString(): String
class FixedLeg : CommonLeg
Module Contents
FixedLeg(fixedRatePayer: Party, notional: Amount<Currency>, paymentFrequency: Frequency, effectiveDate: LocalDate, effectiveDateAdjustment: DateRollConvention?, terminationDate: LocalDate, terminationDateAdjustment: DateRollConvention?, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, dayInMonth: Int, paymentRule: PaymentRule, paymentDelay: Int, paymentCalendar: BusinessCalendar, interestPeriodAdjustment: AccrualAdjustment, fixedRate: FixedRate, rollConvention: DateRollConvention)
fun copy(fixedRatePayer: Party = this.fixedRatePayer, notional: Amount<Currency> = this.notional, paymentFrequency: Frequency = this.paymentFrequency, effectiveDate: LocalDate = this.effectiveDate, effectiveDateAdjustment: DateRollConvention? = this.effectiveDateAdjustment, terminationDate: LocalDate = this.terminationDate, terminationDateAdjustment: DateRollConvention? = this.terminationDateAdjustment, dayCountBasisDay: DayCountBasisDay = this.dayCountBasisDay, dayCountBasisYear: DayCountBasisYear = this.dayCountBasisYear, dayInMonth: Int = this.dayInMonth, paymentRule: PaymentRule = this.paymentRule, paymentDelay: Int = this.paymentDelay, paymentCalendar: BusinessCalendar = this.paymentCalendar, interestPeriodAdjustment: AccrualAdjustment = this.interestPeriodAdjustment, fixedRate: FixedRate = this.fixedRate): FixedLeg
open fun equals(other: Any?): Boolean
var fixedRate: FixedRate
var fixedRatePayer: Party
open fun hashCode(): Int
var rollConvention: DateRollConvention
open fun toString(): String
class FloatingLeg : CommonLeg
Module Contents
FloatingLeg(floatingRatePayer: Party, notional: Amount<Currency>, paymentFrequency: Frequency, effectiveDate: LocalDate, effectiveDateAdjustment: DateRollConvention?, terminationDate: LocalDate, terminationDateAdjustment: DateRollConvention?, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, dayInMonth: Int, paymentRule: PaymentRule, paymentDelay: Int, paymentCalendar: BusinessCalendar, interestPeriodAdjustment: AccrualAdjustment, rollConvention: DateRollConvention, fixingRollConvention: DateRollConvention, resetDayInMonth: Int, fixingPeriodOffset: Int, resetRule: PaymentRule, fixingsPerPayment: Frequency, fixingCalendar: BusinessCalendar, index: String, indexSource: String, indexTenor: Tenor)
fun copy(floatingRatePayer: Party = this.floatingRatePayer, notional: Amount<Currency> = this.notional, paymentFrequency: Frequency = this.paymentFrequency, effectiveDate: LocalDate = this.effectiveDate, effectiveDateAdjustment: DateRollConvention? = this.effectiveDateAdjustment, terminationDate: LocalDate = this.terminationDate, terminationDateAdjustment: DateRollConvention? = this.terminationDateAdjustment, dayCountBasisDay: DayCountBasisDay = this.dayCountBasisDay, dayCountBasisYear: DayCountBasisYear = this.dayCountBasisYear, dayInMonth: Int = this.dayInMonth, paymentRule: PaymentRule = this.paymentRule, paymentDelay: Int = this.paymentDelay, paymentCalendar: BusinessCalendar = this.paymentCalendar, interestPeriodAdjustment: AccrualAdjustment = this.interestPeriodAdjustment, rollConvention: DateRollConvention = this.rollConvention, fixingRollConvention: DateRollConvention = this.fixingRollConvention, resetDayInMonth: Int = this.resetDayInMonth, fixingPeriod: Int = this.fixingPeriodOffset, resetRule: PaymentRule = this.resetRule, fixingsPerPayment: Frequency = this.fixingsPerPayment, fixingCalendar: BusinessCalendar = this.fixingCalendar, index: String = this.index, indexSource: String = this.indexSource, indexTenor: Tenor = this.indexTenor): FloatingLeg
open fun equals(other: Any?): Boolean
var fixingCalendar: BusinessCalendar
var fixingPeriodOffset: Int
var fixingRollConvention: DateRollConvention
var fixingsPerPayment: Frequency
var floatingRatePayer: Party
open fun hashCode(): Int
var index: String
var indexSource: String
var indexTenor: Tenor
var resetDayInMonth: Int
var resetRule: PaymentRule
var rollConvention: DateRollConvention
open fun toString(): String
data class State : FixableDealState, SchedulableState
val clauses: List<SingleClause>
fun extractCommands(tx: TransactionForContract): Collection<AuthenticatedObject<CommandData>>
fun generateAgreement(floatingLeg: FloatingLeg, fixedLeg: FixedLeg, calculation: Calculation, common: Common, notary: Party): TransactionBuilder
fun generateFix(tx: TransactionBuilder, irs: StateAndRef<State>, fixing: Fix): Unit
val legalContractReference: SecureHash
class InterestRateSwapAPI
interface Interpolator
interface InterpolatorFactory
interface IssuanceDefinition
interface IssueCommand : CommandData
data class Issued<out P>
object JsonSupport
interface KeyManagementService
object KotlinObjectSerializer
class LedgerDSL<out T : TransactionDSLInterpreter, out L : LedgerDSLInterpreter<T>> : LedgerDSLInterpreter<TransactionDSLInterpreter>
interface LedgerDSLInterpreter<out T : TransactionDSLInterpreter> : Verifies, OutputStateLookup
data class LedgerTransaction : NamedByHash
class LinearInterpolator : Interpolator
interface LinearState : ContractState
enum class MatchBehaviour
interface Message
interface MessageHandlerRegistration
interface MessageRecipientGroup : MessageRecipients
interface MessageRecipients
interface MessagingService
interface MessagingServiceBuilder<out T : MessagingService>
class MissingAttachmentsException : Exception
class MockAttachmentStorage : AttachmentStorage
class MockIdentityService : IdentityService, SingletonSerializeAsToken
class MockKeyManagementService : SingletonSerializeAsToken, KeyManagementService
class MockNetwork
Module Contents
MockNetwork(networkSendManuallyPumped: Boolean = false, threadPerNode: Boolean = false, defaultFactory: Factory = MockNetwork.DefaultFactory)
object DefaultFactory : Factory
interface Factory
class MockNode : AbstractNode
fun addressToNode(address: SingleMessageRecipient): MockNode
fun createNode(networkMapAddress: NodeInfo? = null, forcedID: Int = -1, nodeFactory: Factory = defaultFactory, start: Boolean = true, legalName: String? = null, keyPair: KeyPair? = null, vararg advertisedServices: ServiceType): MockNode
fun createNotaryNode(legalName: String? = null, keyPair: KeyPair? = null): MockNode
fun createPartyNode(networkMapAddr: NodeInfo, legalName: String? = null, keyPair: KeyPair? = null): MockNode
fun createTwoNodes(nodeFactory: Factory = defaultFactory, notaryKeyPair: KeyPair? = null): <ERROR CLASS><MockNode, MockNode>
val filesystem: <ERROR CLASS>
val identities: ArrayList<Party>
val messagingNetwork: InMemoryMessagingNetwork
val nodes: List<MockNode>
fun runNetwork(rounds: Int = -1): Unit
fun startNodes(): Unit
fun stopNodes(): Unit
class MockNetworkMapCache : InMemoryNetworkMapCache
class MockStorageService : SingletonSerializeAsToken, TxWritableStorageService
open class MockTransactionStorage : TransactionStorage
class MonitoringService : SingletonSerializeAsToken
interface MoveCommand : CommandData
data class MultilateralNetState<P> : NetState<P>
interface MultilateralNettableState<T : Any>
abstract class MutableClock : Clock
interface NamedByHash
open class NetClause<P> : SingleClause
interface NetState<P>
enum class NetType
interface NettableState<N : BilateralNettableState<N>, T : Any> : BilateralNettableState<N>, MultilateralNettableState<T>
sealed class NetworkCacheError : Exception
interface NetworkMapCache
interface NetworkMapService
class NoReferencesSerializer<T>
open class NoZeroSizedOutputs<S : FungibleAsset<T>, T : Any> : GroupClause<S, Issued<T>>
class Node : AbstractNode
class NodeAttachmentService : AttachmentStorage, AcceptsFileUpload
class NodeClock : Clock, SerializeAsToken
interface NodeConfiguration
class NodeConfigurationFromConfig : NodeConfiguration
data class NodeInfo
object NodeInterestRates
sealed class NodeMapError : Exception
class NodeRegistration
class NodeSchedulerService : SchedulerService, SingletonSerializeAsToken
class NodeWalletService : InMemoryWalletService
class NonEmptySet<T> : MutableSet<T>
object NonEmptySetSerializer
object NotaryChangeProtocol : AbstractStateReplacementProtocol<Party>
class NotaryChangeService : AbstractNodeService
sealed class NotaryError
class NotaryException : Exception
object NotaryProtocol
abstract class NotaryService : AbstractNodeService
object NullPublicKey : PublicKey, Comparable<PublicKey>
class Obligation<P> : ClauseVerifier
Module Contents
Obligation()
interface Clauses
interface Commands : Commands
enum class Lifecycle
data class State<P> : FungibleAsset<Terms<P>>, NettableState<State<P>, MultilateralNetState<P>>
data class Terms<P>
val clauses: List<SingleClause>
fun extractCommands(tx: TransactionForContract): List<AuthenticatedObject<Commands>>
fun generateCloseOutNetting(tx: TransactionBuilder, signer: PublicKey, vararg states: State<P>): Unit
fun generateIssue(tx: TransactionBuilder, obligor: Party, issuanceDef: Terms<P>, pennies: Long, beneficiary: PublicKey, notary: Party): Unit
fun generatePaymentNetting(tx: TransactionBuilder, issued: Issued<Terms<P>>, notary: Party, vararg states: State<P>): Unit
fun generateSetLifecycle(tx: TransactionBuilder, statesAndRefs: List<StateAndRef<State<P>>>, lifecycle: Lifecycle, notary: Party): Unit
fun generateSettle(tx: TransactionBuilder, statesAndRefs: Iterable<StateAndRef<State<P>>>, assetStatesAndRefs: Iterable<StateAndRef<FungibleAsset<P>>>, moveCommand: MoveCommand, notary: Party): Unit
val legalContractReference: SecureHash
protected fun verifySetLifecycleCommand(inputs: List<FungibleAsset<Terms<P>>>, outputs: List<FungibleAsset<Terms<P>>>, tx: TransactionForContract, setLifecycleCommand: AuthenticatedObject<SetLifecycle>): Unit
open class OpaqueBytes
interface OutputStateLookup
interface OwnableState : ContractState
data class Party
data class PartyAndReference
interface PartyRequestMessage : ServiceRequestMessage
abstract class PaymentEvent : Event
enum class PaymentRule
class PerFileCheckpointStorage : CheckpointStorage
class PerFileTransactionStorage : TransactionStorage
open class PercentageRatioUnit : RatioUnit
data class PhysicalLocation
class Polynomial
class ProgressTracker
data class ProtocolClassRef : ProtocolRef
data class ProtocolInstanceRef
abstract class ProtocolLogic<out T>
data class ProtocolLogicRef
class ProtocolLogicRefFactory : SingletonSerializeAsToken
interface ProtocolRef
data class ProtocolRequiringAttention
interface ProtocolStateMachine<R>
Module Contents
abstract val logger: <ERROR CLASS>
abstract fun <T : Any> receive(topic: String, sessionIDForReceive: Long, recvType: Class<T>): UntrustworthyData<T>
abstract fun send(topic: String, destination: Party, sessionID: Long, payload: Any): Unit
abstract fun <T : Any> sendAndReceive(topic: String, destination: Party, sessionIDForSend: Long, sessionIDForReceive: Long, payload: Any, recvType: Class<T>): UntrustworthyData<T>
abstract val serviceHub: ServiceHub
class ProtocolStateMachineImpl<R> : ProtocolStateMachine<R>
Module Contents
ProtocolStateMachineImpl(logic: ProtocolLogic<R>, scheduler: <ERROR CLASS>, loggerName: String)
val logger: <ERROR CLASS>
val logic: ProtocolLogic<R>
fun <T : Any> receive(topic: String, sessionIDForReceive: Long, recvType: Class<T>): UntrustworthyData<T>
val resultFuture: <ERROR CLASS><R>
fun run(): R
fun send(topic: String, destination: Party, sessionID: Long, payload: Any): Unit
fun <T : Any> sendAndReceive(topic: String, destination: Party, sessionIDForSend: Long, sessionIDForReceive: Long, payload: Any, recvType: Class<T>): UntrustworthyData<T>
lateinit var serviceHub: ServiceHubInternal
open class Rate
abstract class RatePaymentEvent : PaymentEvent
open class RatesFixProtocol : ProtocolLogic<Unit>
open class RatioUnit
interface ReadOnlyTransactionStorage
class RecordingMap<K, V> : MutableMap<K, V>
class ReferenceRate : FloatingRate
object ReferencesAwareJavaSerializer
interface RegulatorService
class Requirements
class ResolveTransactionsProtocol : ProtocolLogic<Unit>
class ResponseFilter
abstract class RetryableException : Exception
enum class Role
interface SchedulableState : ContractState
interface Scheduled
data class ScheduledActivity : Scheduled
class ScheduledActivityObserver
data class ScheduledStateRef : Scheduled
interface SchedulerService
sealed class SecureHash : OpaqueBytes
interface SerializationToken
interface SerializeAsToken
class SerializeAsTokenContext
class SerializeAsTokenSerializer<T : SerializeAsToken>
class SerializedBytes<T : Any> : OpaqueBytes
object SerializedBytesSerializer
interface ServiceHub
abstract class ServiceHubInternal : ServiceHub
interface ServiceRequestMessage
abstract class ServiceType
open class SignedData<T : Any>
data class SignedTransaction : NamedByHash
class SimpleNotaryService : NotaryService
abstract class Simulation
interface SingleClause : Clause, SingleVerify
interface SingleMessageRecipient : MessageRecipients
interface SingleVerify
data class SingletonSerializationToken : SerializationToken
abstract class SingletonSerializeAsToken : SerializeAsToken
class SplineFunction
class StackSnapshot : Throwable
data class StateAndRef<out T : ContractState>
class StateMachineManager
data class StateRef
class StateReplacementException : Exception
class StateReplacementRefused
interface StatesQuery
interface StorageService
open class StorageServiceImpl : SingletonSerializeAsToken, TxWritableStorageService
data class Tenor
class TestClock : MutableClock, SerializeAsToken
data class TestLedgerDSLInterpreter : LedgerDSLInterpreter<TestTransactionDSLInterpreter>
data class TestTransactionDSLInterpreter : TransactionDSLInterpreter, OutputStateLookup
class ThreadBox<out T>
data class TimeWindow
class TimestampChecker
data class TimestampCommand : CommandData
object TopicStringValidator
class TradeSimulation : Simulation
data class TransactionBuildStep
open class TransactionBuilder
Module Contents
TransactionBuilder(type: TransactionType = TransactionType.General(), notary: Party? = null, inputs: MutableList<StateRef> = arrayListOf(), attachments: MutableList<SecureHash> = arrayListOf(), outputs: MutableList<TransactionState<ContractState>> = arrayListOf(), commands: MutableList<Command> = arrayListOf(), signers: MutableSet<PublicKey> = mutableSetOf())
fun addAttachment(attachmentId: SecureHash): Unit
fun addCommand(arg: Command): Unit
fun addCommand(data: CommandData, vararg keys: PublicKey): <ERROR CLASS>
fun addCommand(data: CommandData, keys: List<PublicKey>): Unit
open fun addInputState(stateAndRef: StateAndRef<*>): Unit
fun addInputState(stateRef: StateRef, notary: Party): Unit
fun addOutputState(state: TransactionState<*>): Int
fun addOutputState(state: ContractState, notary: Party): Int
fun addOutputState(state: ContractState): Int
fun addSignatureUnchecked(sig: WithKey): Unit
fun attachments(): List<SecureHash>
protected val attachments: MutableList<SecureHash>
fun checkAndAddSignature(sig: WithKey): Unit
fun checkSignature(sig: WithKey): Unit
fun commands(): List<Command>
protected val commands: MutableList<Command>
fun copy(): TransactionBuilder
protected val currentSigs: <ERROR CLASS>
fun inputStates(): List<StateRef>
protected val inputs: MutableList<StateRef>
protected val notary: Party?
fun outputStates(): List<TransactionState<*>>
protected val outputs: MutableList<TransactionState<ContractState>>
fun setTime(time: Instant, authority: Party, timeTolerance: Duration): Unit
fun signWith(key: KeyPair): Unit
protected val signers: MutableSet<PublicKey>
val time: TimestampCommand?
fun toSignedTransaction(checkSufficientSignatures: Boolean = true): SignedTransaction
fun toWireTransaction(): WireTransaction
protected val type: TransactionType
fun withItems(vararg items: Any): TransactionBuilder
class TransactionConflictException : Exception
class TransactionDSL<out T : TransactionDSLInterpreter> : TransactionDSLInterpreter
interface TransactionDSLInterpreter : Verifies, OutputStateLookup
data class TransactionForContract
Module Contents
TransactionForContract(inputs: List<ContractState>, outputs: List<ContractState>, attachments: List<Attachment>, commands: List<AuthenticatedObject<CommandData>>, origHash: SecureHash, inputNotary: Party? = null)
data class InOutGroup<out T : ContractState, out K : Any>
val attachments: List<Attachment>
val commands: List<AuthenticatedObject<CommandData>>
fun equals(other: Any?): Boolean
fun getTimestampBy(timestampingAuthority: Party): TimestampCommand?
fun getTimestampByName(vararg authorityName: String): TimestampCommand?
fun <T : ContractState, K : Any> groupStates(ofType: Class<T>, selector: (T) -> K): List<InOutGroup<T, K>>
inline fun <reified T : ContractState, K : Any> groupStates(selector: (T) -> K): List<InOutGroup<T, K>>
fun <T : ContractState, K : Any> groupStatesInternal(inGroups: Map<K, List<T>>, outGroups: Map<K, List<T>>): List<InOutGroup<T, K>>
fun hashCode(): Int
val inStates: List<ContractState>
val inputNotary: Party?
val inputs: List<ContractState>
val origHash: SecureHash
val outStates: List<ContractState>
val outputs: List<ContractState>
val timestamp: TimestampCommand?
data class TransactionForVerification
class TransactionGraphSearch : Callable<List<WireTransaction>>
class TransactionGroup
class TransactionResolutionException : Exception
data class TransactionState<out T : ContractState>
interface TransactionStorage : ReadOnlyTransactionStorage
sealed class TransactionType
sealed class TransactionVerificationException : Exception
class TransientProperty<out T>
object TwoPartyDealProtocol
object TwoPartyTradeProtocol
interface TxWritableStorageService : StorageService
abstract class TypeOnlyCommandData : CommandData
class UniquenessException : Exception
interface UniquenessProvider
open class UnknownType
class UntrustworthyData<out T>
object UpdateBusinessDayProtocol
class ValidatingNotaryProtocol : Service
class ValidatingNotaryService : NotaryService
interface Verifies
class Wallet
interface WalletService
class WhitelistTrustManager : X509ExtendedTrustManager
Module Contents
WhitelistTrustManager(originalProvider: X509ExtendedTrustManager)
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String): Unit
val checker: HostnameChecker
fun getAcceptedIssuers(): Array<out X509Certificate>
val originalProvider: X509ExtendedTrustManager
object WhitelistTrustManagerProvider : Provider
class WhitelistTrustManagerSpi : TrustManagerFactorySpi
class WireNodeRegistration : SignedData<NodeRegistration>
data class WireTransaction : NamedByHash
object WireTransactionSerializer
data class WorldCoordinate
object X509Utilities
Module Contents
data class CACertAndKey
val CA_CERT_ALIAS: String
val CERT_PRIVATE_KEY_ALIAS: String
val ECDSA_CURVE: String
val INTERMEDIATE_CA_PRIVATE_KEY_ALIAS: String
val KEYSTORE_TYPE: String
val KEY_GENERATION_ALGORITHM: String
val ROOT_CA_CERT_PRIVATE_KEY_ALIAS: String
val SIGNATURE_ALGORITHM: String
fun createCAKeyStoreAndTrustStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, trustStoreFilePath: Path, trustStorePassword: String): KeyStore
fun createIntermediateCert(domain: String, certificateAuthority: CACertAndKey): CACertAndKey
fun createKeystoreForSSL(: Path, : String, : String, : KeyStore, : String): KeyStore
fun createSelfSignedCACert(domain: String): CACertAndKey
fun createServerCert(subject: <ERROR CLASS>, publicKey: PublicKey, certificateAuthority: CACertAndKey, subjectAlternativeNameDomains: List<String>, subjectAlternativeNameIps: List<String>): X509Certificate
fun generateECDSAKeyPairForSSL(): KeyPair
fun getDevX509Name(domain: String): <ERROR CLASS>
fun loadCertificateAndKey(keyStore: KeyStore, keyPassword: String, alias: String): CACertAndKey
fun loadCertificateFromKeyStore(keyStoreFilePath: Path, storePassword: String, alias: String): X509Certificate
fun loadCertificateFromPEMFile(filename: Path): X509Certificate
fun loadKeyPairFromKeyStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, alias: String): KeyPair
fun loadKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun loadKeyStore(input: InputStream, storePassword: String): KeyStore
fun loadOrCreateKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun saveCertificateAsPEMFile(x509Certificate: X509Certificate, filename: Path): Unit
fun saveKeyStore(keyStore: KeyStore, keyStoreFilePath: Path, storePassword: String): Unit
java.nio.file.Path
java.security.KeyPair
java.security.PrivateKey
java.security.PublicKey
java.time.Clock
Module Contents
fun Clock.awaitWithDeadline(deadline: Instant, future: Future<*> = SettableFuture<Any>()): Boolean
java.time.LocalDate
java.time.temporal.Temporal
java.util.Currency
kotlin.ByteArray
kotlin.ByteArray
kotlin.Double
kotlin.Double
kotlin.Int
kotlin.Int
kotlin.Int
kotlin.Long
kotlin.String
kotlin.String
kotlin.collections.Collection
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.Iterable
kotlin.collections.List
kotlin.collections.List
package com.r3corda.contracts
Module Contents
val CP_LEGACY_PROGRAM_ID: CommercialPaperLegacy
val CP_PROGRAM_ID: CommercialPaper
class CommercialPaper : ClauseVerifier
class CommercialPaperLegacy : Contract
open class Event
class FixedRate : Rate
class FixedRatePaymentEvent : RatePaymentEvent
open class FloatingRate : Rate
class FloatingRatePaymentEvent : RatePaymentEvent
Module Contents
FloatingRatePaymentEvent(date: LocalDate, accrualStartDate: LocalDate, accrualEndDate: LocalDate, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, fixingDate: LocalDate, notional: Amount<Currency>, rate: Rate)
val CSVHeader: String
fun asCSV(): String
fun copy(date: LocalDate = this.date, accrualStartDate: LocalDate = this.accrualStartDate, accrualEndDate: LocalDate = this.accrualEndDate, dayCountBasisDay: DayCountBasisDay = this.dayCountBasisDay, dayCountBasisYear: DayCountBasisYear = this.dayCountBasisYear, fixingDate: LocalDate = this.fixingDate, notional: Amount<Currency> = this.notional, rate: Rate = this.rate): FloatingRatePaymentEvent
fun equals(other: Any?): Boolean
val fixingDate: LocalDate
val flow: Amount<Currency>
fun hashCode(): Int
fun toString(): String
fun withNewRate(newRate: Rate): FloatingRatePaymentEvent
val IRS_PROGRAM_ID: InterestRateSwap
class InterestRateSwap : ClauseVerifier
Module Contents
InterestRateSwap()
data class Calculation
interface Clause
interface Commands : CommandData
data class Common
Module Contents
Common(baseCurrency: Currency, eligibleCurrency: Currency, eligibleCreditSupport: String, independentAmounts: Amount<Currency>, threshold: Amount<Currency>, minimumTransferAmount: Amount<Currency>, rounding: Amount<Currency>, valuationDate: String, notificationTime: String, resolutionTime: String, interestRate: ReferenceRate, addressForTransfers: String, exposure: UnknownType, localBusinessDay: BusinessCalendar, dailyInterestAmount: Expression, tradeID: String, hashLegalDocs: String)
val addressForTransfers: String
val baseCurrency: Currency
val dailyInterestAmount: Expression
val eligibleCreditSupport: String
val eligibleCurrency: Currency
val exposure: UnknownType
val hashLegalDocs: String
val independentAmounts: Amount<Currency>
val interestRate: ReferenceRate
val localBusinessDay: BusinessCalendar
val minimumTransferAmount: Amount<Currency>
val notificationTime: String
val resolutionTime: String
val rounding: Amount<Currency>
val threshold: Amount<Currency>
val tradeID: String
val valuationDate: String
abstract class CommonLeg
Module Contents
CommonLeg(notional: Amount<Currency>, paymentFrequency: Frequency, effectiveDate: LocalDate, effectiveDateAdjustment: DateRollConvention?, terminationDate: LocalDate, terminationDateAdjustment: DateRollConvention?, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, dayInMonth: Int, paymentRule: PaymentRule, paymentDelay: Int, paymentCalendar: BusinessCalendar, interestPeriodAdjustment: AccrualAdjustment)
val dayCountBasisDay: DayCountBasisDay
val dayCountBasisYear: DayCountBasisYear
val dayInMonth: Int
val effectiveDate: LocalDate
val effectiveDateAdjustment: DateRollConvention?
open fun equals(other: Any?): Boolean
open fun hashCode(): Int
val interestPeriodAdjustment: AccrualAdjustment
val notional: Amount<Currency>
val paymentCalendar: BusinessCalendar
val paymentDelay: Int
val paymentFrequency: Frequency
val paymentRule: PaymentRule
val terminationDate: LocalDate
val terminationDateAdjustment: DateRollConvention?
open fun toString(): String
class FixedLeg : CommonLeg
Module Contents
FixedLeg(fixedRatePayer: Party, notional: Amount<Currency>, paymentFrequency: Frequency, effectiveDate: LocalDate, effectiveDateAdjustment: DateRollConvention?, terminationDate: LocalDate, terminationDateAdjustment: DateRollConvention?, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, dayInMonth: Int, paymentRule: PaymentRule, paymentDelay: Int, paymentCalendar: BusinessCalendar, interestPeriodAdjustment: AccrualAdjustment, fixedRate: FixedRate, rollConvention: DateRollConvention)
fun copy(fixedRatePayer: Party = this.fixedRatePayer, notional: Amount<Currency> = this.notional, paymentFrequency: Frequency = this.paymentFrequency, effectiveDate: LocalDate = this.effectiveDate, effectiveDateAdjustment: DateRollConvention? = this.effectiveDateAdjustment, terminationDate: LocalDate = this.terminationDate, terminationDateAdjustment: DateRollConvention? = this.terminationDateAdjustment, dayCountBasisDay: DayCountBasisDay = this.dayCountBasisDay, dayCountBasisYear: DayCountBasisYear = this.dayCountBasisYear, dayInMonth: Int = this.dayInMonth, paymentRule: PaymentRule = this.paymentRule, paymentDelay: Int = this.paymentDelay, paymentCalendar: BusinessCalendar = this.paymentCalendar, interestPeriodAdjustment: AccrualAdjustment = this.interestPeriodAdjustment, fixedRate: FixedRate = this.fixedRate): FixedLeg
open fun equals(other: Any?): Boolean
var fixedRate: FixedRate
var fixedRatePayer: Party
open fun hashCode(): Int
var rollConvention: DateRollConvention
open fun toString(): String
class FloatingLeg : CommonLeg
Module Contents
FloatingLeg(floatingRatePayer: Party, notional: Amount<Currency>, paymentFrequency: Frequency, effectiveDate: LocalDate, effectiveDateAdjustment: DateRollConvention?, terminationDate: LocalDate, terminationDateAdjustment: DateRollConvention?, dayCountBasisDay: DayCountBasisDay, dayCountBasisYear: DayCountBasisYear, dayInMonth: Int, paymentRule: PaymentRule, paymentDelay: Int, paymentCalendar: BusinessCalendar, interestPeriodAdjustment: AccrualAdjustment, rollConvention: DateRollConvention, fixingRollConvention: DateRollConvention, resetDayInMonth: Int, fixingPeriodOffset: Int, resetRule: PaymentRule, fixingsPerPayment: Frequency, fixingCalendar: BusinessCalendar, index: String, indexSource: String, indexTenor: Tenor)
fun copy(floatingRatePayer: Party = this.floatingRatePayer, notional: Amount<Currency> = this.notional, paymentFrequency: Frequency = this.paymentFrequency, effectiveDate: LocalDate = this.effectiveDate, effectiveDateAdjustment: DateRollConvention? = this.effectiveDateAdjustment, terminationDate: LocalDate = this.terminationDate, terminationDateAdjustment: DateRollConvention? = this.terminationDateAdjustment, dayCountBasisDay: DayCountBasisDay = this.dayCountBasisDay, dayCountBasisYear: DayCountBasisYear = this.dayCountBasisYear, dayInMonth: Int = this.dayInMonth, paymentRule: PaymentRule = this.paymentRule, paymentDelay: Int = this.paymentDelay, paymentCalendar: BusinessCalendar = this.paymentCalendar, interestPeriodAdjustment: AccrualAdjustment = this.interestPeriodAdjustment, rollConvention: DateRollConvention = this.rollConvention, fixingRollConvention: DateRollConvention = this.fixingRollConvention, resetDayInMonth: Int = this.resetDayInMonth, fixingPeriod: Int = this.fixingPeriodOffset, resetRule: PaymentRule = this.resetRule, fixingsPerPayment: Frequency = this.fixingsPerPayment, fixingCalendar: BusinessCalendar = this.fixingCalendar, index: String = this.index, indexSource: String = this.indexSource, indexTenor: Tenor = this.indexTenor): FloatingLeg
open fun equals(other: Any?): Boolean
var fixingCalendar: BusinessCalendar
var fixingPeriodOffset: Int
var fixingRollConvention: DateRollConvention
var fixingsPerPayment: Frequency
var floatingRatePayer: Party
open fun hashCode(): Int
var index: String
var indexSource: String
var indexTenor: Tenor
var resetDayInMonth: Int
var resetRule: PaymentRule
var rollConvention: DateRollConvention
open fun toString(): String
data class State : FixableDealState, SchedulableState
val clauses: List<SingleClause>
fun extractCommands(tx: TransactionForContract): Collection<AuthenticatedObject<CommandData>>
fun generateAgreement(floatingLeg: FloatingLeg, fixedLeg: FixedLeg, calculation: Calculation, common: Common, notary: Party): TransactionBuilder
fun generateFix(tx: TransactionBuilder, irs: StateAndRef<State>, fixing: Fix): Unit
val legalContractReference: SecureHash
abstract class PaymentEvent : Event
open class PercentageRatioUnit : RatioUnit
open class Rate
abstract class RatePaymentEvent : PaymentEvent
open class RatioUnit
class ReferenceRate : FloatingRate
open class UnknownType
fun State.exportIRSToCSV(): String
kotlin.Int
kotlin.String
infix fun State.owned by(owner: PublicKey): State
infix fun <ERROR CLASS>.owned by(newOwner: PublicKey): <ERROR CLASS>
operator fun Amount<Currency>.times(other: RatioUnit): Amount<Currency>
infix fun State.with notary(notary: Party): TransactionState<State>
package com.r3corda.contracts.asset
Module Contents
val Amount<Currency>.CASH: State
val CASH_PROGRAM_ID: Cash
class Cash : ClauseVerifier
Module Contents
Cash()
interface Clauses
interface Commands : Commands
data class State : FungibleAsset<Currency>
val clauses: List<SingleClause>
fun extractCommands(tx: TransactionForContract): List<AuthenticatedObject<Commands>>
fun generateExit(tx: TransactionBuilder, amountIssued: Amount<Issued<Currency>>, changeKey: PublicKey, cashStates: List<StateAndRef<State>>): PublicKey
fun generateIssue(tx: TransactionBuilder, tokenDef: Issued<Currency>, pennies: Long, owner: PublicKey, notary: Party): Unit
fun generateIssue(tx: TransactionBuilder, amount: Amount<Issued<Currency>>, owner: PublicKey, notary: Party): Unit
fun generateSpend(tx: TransactionBuilder, amount: Amount<Issued<Currency>>, to: PublicKey, cashStates: List<StateAndRef<State>>): List<PublicKey>
fun generateSpend(tx: TransactionBuilder, amount: Amount<Currency>, to: PublicKey, cashStates: List<StateAndRef<State>>, onlyFromParties: Set<Party>? = null): List<PublicKey>
val legalContractReference: SecureHash
val DUMMY_CASH_ISSUER: <ERROR CLASS>
val DUMMY_CASH_ISSUER_KEY: <ERROR CLASS>
interface FungibleAsset<T> : OwnableState
class InsufficientBalanceException : Exception
val Amount<Issued<Currency>>.OBLIGATION: State<Currency>
val Issued<Currency>.OBLIGATION_DEF: Terms<Currency>
val OBLIGATION_PROGRAM_ID: Obligation<Currency>
class Obligation<P> : ClauseVerifier
Module Contents
Obligation()
interface Clauses
interface Commands : Commands
enum class Lifecycle
data class State<P> : FungibleAsset<Terms<P>>, NettableState<State<P>, MultilateralNetState<P>>
data class Terms<P>
val clauses: List<SingleClause>
fun extractCommands(tx: TransactionForContract): List<AuthenticatedObject<Commands>>
fun generateCloseOutNetting(tx: TransactionBuilder, signer: PublicKey, vararg states: State<P>): Unit
fun generateIssue(tx: TransactionBuilder, obligor: Party, issuanceDef: Terms<P>, pennies: Long, beneficiary: PublicKey, notary: Party): Unit
fun generatePaymentNetting(tx: TransactionBuilder, issued: Issued<Terms<P>>, notary: Party, vararg states: State<P>): Unit
fun generateSetLifecycle(tx: TransactionBuilder, statesAndRefs: List<StateAndRef<State<P>>>, lifecycle: Lifecycle, notary: Party): Unit
fun generateSettle(tx: TransactionBuilder, statesAndRefs: Iterable<StateAndRef<State<P>>>, assetStatesAndRefs: Iterable<StateAndRef<FungibleAsset<P>>>, moveCommand: MoveCommand, notary: Party): Unit
val legalContractReference: SecureHash
protected fun verifySetLifecycleCommand(inputs: List<FungibleAsset<Terms<P>>>, outputs: List<FungibleAsset<Terms<P>>>, tx: TransactionForContract, setLifecycleCommand: AuthenticatedObject<SetLifecycle>): Unit
val Amount<Issued<Currency>>.STATE: State
infix fun <T> State<T>.at(dueBefore: Instant): State<T>
infix fun <T> State<T>.between(parties: <ERROR CLASS><Party, PublicKey>): State<T>
val Wallet.cashBalances: Map<Currency, Amount<Currency>>
fun <P> extractAmountsDue(: Terms<P>, : Iterable<State<P>>): Map<<ERROR CLASS><PublicKey, PublicKey>, Amount<Terms<P>>>
infix fun State.issued by(party: Party): State
infix fun State.issued by(deposit: PartyAndReference): State
infix fun <T> State<T>.issued by(party: Party): State<T>
fun State.issuedBy(party: Party): State
fun State.issuedBy(deposit: PartyAndReference): State
fun <T> State<T>.issuedBy(party: Party): State<T>
kotlin.collections.Iterable
fun <P> netAmountsDue(balances: Map<<ERROR CLASS><PublicKey, PublicKey>, Amount<P>>): Map<<ERROR CLASS><PublicKey, PublicKey>, Amount<P>>
infix fun State.owned by(owner: PublicKey): State
infix fun <T> State<T>.owned by(owner: PublicKey): State<T>
fun State.ownedBy(owner: PublicKey): State
fun <T> State<T>.ownedBy(owner: PublicKey): State<T>
fun <P> sumAmountsDue(balances: Map<<ERROR CLASS><PublicKey, PublicKey>, Amount<P>>): Map<PublicKey, Long>
infix fun State.with deposit(deposit: PartyAndReference): State
fun State.withDeposit(deposit: PartyAndReference): State
package com.r3corda.contracts.clause
package com.r3corda.contracts.testing
package com.r3corda.core
package com.r3corda.core.contracts
Module Contents
enum class AccrualAdjustment
data class Amount<T> : Comparable<Amount<T>>
interface Attachment : NamedByHash
data class AuthenticatedObject<out T : Any>
interface BilateralNettableState<N : BilateralNettableState<N>>
open class BusinessCalendar
Module Contents
val TEST_CALENDAR_DATA: <ERROR CLASS>
class UnknownCalendar : Exception
open fun applyRollConvention(testDate: LocalDate, dateRollConvention: DateRollConvention): LocalDate
val calendars: Array<out String>
val calendars: <ERROR CLASS>
fun createGenericSchedule(startDate: LocalDate, period: Frequency, calendar: BusinessCalendar = getInstance(), dateRollConvention: DateRollConvention = DateRollConvention.Following, noOfAdditionalPeriods: Int = Integer.MAX_VALUE, endDate: LocalDate? = null, periodOffset: Int? = null): List<LocalDate>
open fun equals(other: Any?): Boolean
fun getInstance(vararg calname: String): BusinessCalendar
fun getOffsetDate(startDate: LocalDate, period: Frequency, steps: Int = 1): LocalDate
open fun hashCode(): Int
val holidayDates: List<LocalDate>
open fun isWorkingDay(date: LocalDate): Boolean
fun moveBusinessDays(date: LocalDate, direction: DateRollDirection, i: Int): LocalDate
fun parseDateFromString(it: String): LocalDate
val CHF: Currency
data class Command
interface CommandData
interface Contract
interface ContractState
fun DOLLARS(amount: Int): Amount<Currency>
fun DOLLARS(amount: Double): Amount<Currency>
val DUMMY_PROGRAM_ID: DummyContract
enum class DateRollConvention
enum class DateRollDirection
enum class DayCountBasisDay
enum class DayCountBasisYear
interface DealState : LinearState
class DummyContract : Contract
data class DummyState : ContractState
data class Expression
object ExpressionDeserializer
object ExpressionSerializer
data class Fix : CommandData
data class FixOf
interface FixableDealState : DealState
enum class Frequency
val GBP: Currency
interface IssuanceDefinition
interface IssueCommand : CommandData
data class Issued<out P>
data class LedgerTransaction : NamedByHash
interface LinearState : ContractState
interface MoveCommand : CommandData
interface MultilateralNettableState<T : Any>
interface NamedByHash
enum class NetType
interface NettableState<N : BilateralNettableState<N>, T : Any> : BilateralNettableState<N>, MultilateralNettableState<T>
interface OwnableState : ContractState
fun POUNDS(amount: Int): Amount<Currency>
data class PartyAndReference
enum class PaymentRule
val R: Requirements
class Requirements
fun SWISS_FRANCS(amount: Int): Amount<Currency>
interface SchedulableState : ContractState
interface Scheduled
data class ScheduledActivity : Scheduled
data class ScheduledStateRef : Scheduled
data class SignedTransaction : NamedByHash
data class StateAndRef<out T : ContractState>
data class StateRef
data class Tenor
data class TimestampCommand : CommandData
open class TransactionBuilder
Module Contents
TransactionBuilder(type: TransactionType = TransactionType.General(), notary: Party? = null, inputs: MutableList<StateRef> = arrayListOf(), attachments: MutableList<SecureHash> = arrayListOf(), outputs: MutableList<TransactionState<ContractState>> = arrayListOf(), commands: MutableList<Command> = arrayListOf(), signers: MutableSet<PublicKey> = mutableSetOf())
fun addAttachment(attachmentId: SecureHash): Unit
fun addCommand(arg: Command): Unit
fun addCommand(data: CommandData, vararg keys: PublicKey): <ERROR CLASS>
fun addCommand(data: CommandData, keys: List<PublicKey>): Unit
open fun addInputState(stateAndRef: StateAndRef<*>): Unit
fun addInputState(stateRef: StateRef, notary: Party): Unit
fun addOutputState(state: TransactionState<*>): Int
fun addOutputState(state: ContractState, notary: Party): Int
fun addOutputState(state: ContractState): Int
fun addSignatureUnchecked(sig: WithKey): Unit
fun attachments(): List<SecureHash>
protected val attachments: MutableList<SecureHash>
fun checkAndAddSignature(sig: WithKey): Unit
fun checkSignature(sig: WithKey): Unit
fun commands(): List<Command>
protected val commands: MutableList<Command>
fun copy(): TransactionBuilder
protected val currentSigs: <ERROR CLASS>
fun inputStates(): List<StateRef>
protected val inputs: MutableList<StateRef>
protected val notary: Party?
fun outputStates(): List<TransactionState<*>>
protected val outputs: MutableList<TransactionState<ContractState>>
fun setTime(time: Instant, authority: Party, timeTolerance: Duration): Unit
fun signWith(key: KeyPair): Unit
protected val signers: MutableSet<PublicKey>
val time: TimestampCommand?
fun toSignedTransaction(checkSufficientSignatures: Boolean = true): SignedTransaction
fun toWireTransaction(): WireTransaction
protected val type: TransactionType
fun withItems(vararg items: Any): TransactionBuilder
class TransactionConflictException : Exception
data class TransactionForContract
Module Contents
TransactionForContract(inputs: List<ContractState>, outputs: List<ContractState>, attachments: List<Attachment>, commands: List<AuthenticatedObject<CommandData>>, origHash: SecureHash, inputNotary: Party? = null)
data class InOutGroup<out T : ContractState, out K : Any>
val attachments: List<Attachment>
val commands: List<AuthenticatedObject<CommandData>>
fun equals(other: Any?): Boolean
fun getTimestampBy(timestampingAuthority: Party): TimestampCommand?
fun getTimestampByName(vararg authorityName: String): TimestampCommand?
fun <T : ContractState, K : Any> groupStates(ofType: Class<T>, selector: (T) -> K): List<InOutGroup<T, K>>
inline fun <reified T : ContractState, K : Any> groupStates(selector: (T) -> K): List<InOutGroup<T, K>>
fun <T : ContractState, K : Any> groupStatesInternal(inGroups: Map<K, List<T>>, outGroups: Map<K, List<T>>): List<InOutGroup<T, K>>
fun hashCode(): Int
val inStates: List<ContractState>
val inputNotary: Party?
val inputs: List<ContractState>
val origHash: SecureHash
val outStates: List<ContractState>
val outputs: List<ContractState>
val timestamp: TimestampCommand?
data class TransactionForVerification
class TransactionGraphSearch : Callable<List<WireTransaction>>
class TransactionGroup
class TransactionResolutionException : Exception
data class TransactionState<out T : ContractState>
sealed class TransactionType
sealed class TransactionVerificationException : Exception
abstract class TypeOnlyCommandData : CommandData
val USD: Currency
data class WireTransaction : NamedByHash
fun calculateDaysBetween(startDate: LocalDate, endDate: LocalDate, dcbYear: DayCountBasisYear, dcbDay: DayCountBasisDay): Int
fun currency(code: String): Currency
fun ContractState.hash(): SecureHash
infix fun Amount<Currency>.issued by(deposit: PartyAndReference): Amount<Issued<Currency>>
infix fun Amount<Currency>.issuedBy(deposit: PartyAndReference): Amount<Issued<Currency>>
java.time.LocalDate
java.util.Currency
kotlin.Double
kotlin.Int
kotlin.collections.Collection
kotlin.collections.Iterable
kotlin.collections.List
inline fun <R> requireThat(body: Requirements.() -> R): R
fun WireTransaction.toLedgerTransaction(identityService: IdentityService, attachmentStorage: AttachmentStorage): LedgerTransaction
inline fun <reified T : MoveCommand> verifyMoveCommand(inputs: List<OwnableState>, tx: TransactionForContract): MoveCommand
inline fun <reified T : MoveCommand> verifyMoveCommand(inputs: List<OwnableState>, commands: List<AuthenticatedObject<CommandData>>): MoveCommand
fun SignedTransaction.verifyToLedgerTransaction(identityService: IdentityService, attachmentStorage: AttachmentStorage): LedgerTransaction
infix fun <T : ContractState> T.with notary(newNotary: Party): TransactionState<T>
infix fun <T : ContractState> T.withNotary(newNotary: Party): TransactionState<T>
package com.r3corda.core.contracts.clauses
package com.r3corda.core.crypto
Module Contents
open class DigitalSignature : OpaqueBytes
class DummyPublicKey : PublicKey, Comparable<PublicKey>
object NullPublicKey : PublicKey, Comparable<PublicKey>
data class Party
sealed class SecureHash : OpaqueBytes
open class SignedData<T : Any>
class WhitelistTrustManager : X509ExtendedTrustManager
Module Contents
WhitelistTrustManager(originalProvider: X509ExtendedTrustManager)
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkClientTrusted(chain: Array<out X509Certificate>, authType: String): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, socket: Socket?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String, engine: SSLEngine?): Unit
fun checkServerTrusted(chain: Array<out X509Certificate>, authType: String): Unit
val checker: HostnameChecker
fun getAcceptedIssuers(): Array<out X509Certificate>
val originalProvider: X509ExtendedTrustManager
object WhitelistTrustManagerProvider : Provider
class WhitelistTrustManagerSpi : TrustManagerFactorySpi
object X509Utilities
Module Contents
data class CACertAndKey
val CA_CERT_ALIAS: String
val CERT_PRIVATE_KEY_ALIAS: String
val ECDSA_CURVE: String
val INTERMEDIATE_CA_PRIVATE_KEY_ALIAS: String
val KEYSTORE_TYPE: String
val KEY_GENERATION_ALGORITHM: String
val ROOT_CA_CERT_PRIVATE_KEY_ALIAS: String
val SIGNATURE_ALGORITHM: String
fun createCAKeyStoreAndTrustStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, trustStoreFilePath: Path, trustStorePassword: String): KeyStore
fun createIntermediateCert(domain: String, certificateAuthority: CACertAndKey): CACertAndKey
fun createKeystoreForSSL(: Path, : String, : String, : KeyStore, : String): KeyStore
fun createSelfSignedCACert(domain: String): CACertAndKey
fun createServerCert(subject: <ERROR CLASS>, publicKey: PublicKey, certificateAuthority: CACertAndKey, subjectAlternativeNameDomains: List<String>, subjectAlternativeNameIps: List<String>): X509Certificate
fun generateECDSAKeyPairForSSL(): KeyPair
fun getDevX509Name(domain: String): <ERROR CLASS>
fun loadCertificateAndKey(keyStore: KeyStore, keyPassword: String, alias: String): CACertAndKey
fun loadCertificateFromKeyStore(keyStoreFilePath: Path, storePassword: String, alias: String): X509Certificate
fun loadCertificateFromPEMFile(filename: Path): X509Certificate
fun loadKeyPairFromKeyStore(keyStoreFilePath: Path, storePassword: String, keyPassword: String, alias: String): KeyPair
fun loadKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun loadKeyStore(input: InputStream, storePassword: String): KeyStore
fun loadOrCreateKeyStore(keyStoreFilePath: Path, storePassword: String): KeyStore
fun saveCertificateAsPEMFile(x509Certificate: X509Certificate, filename: Path): Unit
fun saveKeyStore(keyStore: KeyStore, keyStoreFilePath: Path, storePassword: String): Unit
fun generateKeyPair(): KeyPair
java.security.KeyPair
java.security.PrivateKey
java.security.PublicKey
kotlin.ByteArray
fun newSecureRandom(): SecureRandom
fun registerWhitelistTrustManager(): Unit
fun OpaqueBytes.sha256(): SHA256
package com.r3corda.core.math
package com.r3corda.core.messaging
package com.r3corda.core.node
package com.r3corda.core.node.services
package com.r3corda.core.node.services.testing
package com.r3corda.core.protocols
Module Contents
data class AppContext
class IllegalProtocolLogicException : IllegalArgumentException
abstract class ProtocolLogic<out T>
data class ProtocolLogicRef
class ProtocolLogicRefFactory : SingletonSerializeAsToken
interface ProtocolStateMachine<R>
Module Contents
abstract val logger: <ERROR CLASS>
abstract fun <T : Any> receive(topic: String, sessionIDForReceive: Long, recvType: Class<T>): UntrustworthyData<T>
abstract fun send(topic: String, destination: Party, sessionID: Long, payload: Any): Unit
abstract fun <T : Any> sendAndReceive(topic: String, destination: Party, sessionIDForSend: Long, sessionIDForReceive: Long, payload: Any, recvType: Class<T>): UntrustworthyData<T>
abstract val serviceHub: ServiceHub
package com.r3corda.core.serialization
package com.r3corda.core.testing
Module Contents
val ALICE: Party
val ALICE_KEY: KeyPair
val ALICE_PUBKEY: PublicKey
val ALL_TEST_KEYS: List<KeyPair>
class AlwaysSucceedContract : Contract
class AttachmentResolutionException : Exception
val BOB: Party
val BOB_KEY: KeyPair
val BOB_PUBKEY: PublicKey
val DUMMY_KEY_1: KeyPair
val DUMMY_KEY_2: KeyPair
val DUMMY_KEY_3: KeyPair
val DUMMY_NOTARY: Party
val DUMMY_NOTARY_KEY: KeyPair
val DUMMY_PUBKEY_1: PublicKey
val DUMMY_PUBKEY_2: PublicKey
class DummyLinearState : LinearState
class DuplicateOutputLabel : Exception
sealed class EnforceVerifyOrFail
open class InMemoryWalletService : SingletonSerializeAsToken, WalletService
class LedgerDSL<out T : TransactionDSLInterpreter, out L : LedgerDSLInterpreter<T>> : LedgerDSLInterpreter<TransactionDSLInterpreter>
interface LedgerDSLInterpreter<out T : TransactionDSLInterpreter> : Verifies, OutputStateLookup
val MEGA_CORP: Party
val MEGA_CORP_KEY: KeyPair
val MEGA_CORP_PUBKEY: PublicKey
val MINI_CORP: Party
val MINI_CORP_KEY: KeyPair
val MINI_CORP_PUBKEY: PublicKey
val MOCK_IDENTITY_SERVICE: MockIdentityService
val ORACLE_KEY: KeyPair
val ORACLE_PUBKEY: PublicKey
interface OutputStateLookup
val TEST_TX_TIME: Instant
data class TestLedgerDSLInterpreter : LedgerDSLInterpreter<TestTransactionDSLInterpreter>
data class TestTransactionDSLInterpreter : TransactionDSLInterpreter, OutputStateLookup
class TransactionDSL<out T : TransactionDSLInterpreter> : TransactionDSLInterpreter
interface TransactionDSLInterpreter : Verifies, OutputStateLookup
interface Verifies
fun freeLocalHostAndPort(): <ERROR CLASS>
fun generateStateRef(): StateRef
fun ledger(identityService: IdentityService = MOCK_IDENTITY_SERVICE, storageService: StorageService = MockStorageService(), dsl: LedgerDSL<TestTransactionDSLInterpreter, TestLedgerDSLInterpreter>.() -> Unit): LedgerDSL<TestTransactionDSLInterpreter, TestLedgerDSLInterpreter>
fun TransactionDSLInterpreter.ledger(dsl: LedgerDSL<TestTransactionDSLInterpreter, TestLedgerDSLInterpreter>.() -> Unit): Unit
fun LedgerDSLInterpreter<TransactionDSLInterpreter>.ledger(dsl: LedgerDSL<TestTransactionDSLInterpreter, TestLedgerDSLInterpreter>.() -> Unit): Unit
inline fun <R> rootCauseExceptions(body: () -> R): R
fun signAll(transactionsToSign: List<WireTransaction>, : Array<out KeyPair>): <ERROR CLASS>
fun LedgerDSL<TestTransactionDSLInterpreter, TestLedgerDSLInterpreter>.signAll(vararg : KeyPair): <ERROR CLASS>
fun transaction(transactionLabel: String? = null, transactionBuilder: TransactionBuilder = TransactionBuilder(), dsl: TransactionDSL<TransactionDSLInterpreter>.() -> EnforceVerifyOrFail): LedgerDSL<TestTransactionDSLInterpreter, TestLedgerDSLInterpreter>
fun TransactionDSLInterpreter.transaction(dsl: TransactionDSL<TransactionDSLInterpreter>.() -> EnforceVerifyOrFail): Unit
package com.r3corda.core.utilities
package com.r3corda.demos
package com.r3corda.demos.api
package com.r3corda.demos.protocols
package com.r3corda.demos.utilities
package com.r3corda.node.api
Module Contents
interface APIServer
Module Contents
abstract fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
abstract fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
abstract fun fetchProtocolsRequiringAttention(query: StatesQuery): Map<StateRef, ProtocolRequiringAttention>
abstract fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
abstract fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
abstract fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
abstract fun invokeProtocolSync(type: ProtocolRef, args: Map<String, Any?>): Any?
abstract fun provideProtocolResponse(protocol: ProtocolInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
abstract fun queryStates(query: StatesQuery): List<StateRef>
abstract fun serverTime(): LocalDateTime
abstract fun status(): <ERROR CLASS>
data class ContractClassRef : ContractDefRef
interface ContractDefRef
data class ContractLedgerRef : ContractDefRef
data class ProtocolClassRef : ProtocolRef
data class ProtocolInstanceRef
interface ProtocolRef
data class ProtocolRequiringAttention
interface StatesQuery
data class TransactionBuildStep
package com.r3corda.node.internal
Module Contents
class APIServerImpl : APIServer
Module Contents
APIServerImpl(node: AbstractNode)
fun buildTransaction(type: ContractDefRef, steps: List<TransactionBuildStep>): SerializedBytes<WireTransaction>
fun commitTransaction(tx: SerializedBytes<WireTransaction>, signatures: List<WithKey>): SecureHash
fun fetchProtocolsRequiringAttention(query: StatesQuery): Map<StateRef, ProtocolRequiringAttention>
fun fetchStates(states: List<StateRef>): Map<StateRef, TransactionState<ContractState>?>
fun fetchTransactions(txs: List<SecureHash>): Map<SecureHash, SignedTransaction?>
fun generateTransactionSignature(tx: SerializedBytes<WireTransaction>): WithKey
fun invokeProtocolSync(type: ProtocolRef, args: Map<String, Any?>): Any?
val node: AbstractNode
fun provideProtocolResponse(protocol: ProtocolInstanceRef, choice: SecureHash, args: Map<String, Any?>): Unit
fun queryStates(query: StatesQuery): List<StateRef>
fun serverTime(): LocalDateTime
fun status(): <ERROR CLASS>
abstract class AbstractNode
class ConfigurationException : Exception
class Node : AbstractNode
package com.r3corda.node.internal.testing
Module Contents
class IRSSimulation : Simulation
class MockNetwork
Module Contents
MockNetwork(networkSendManuallyPumped: Boolean = false, threadPerNode: Boolean = false, defaultFactory: Factory = MockNetwork.DefaultFactory)
object DefaultFactory : Factory
interface Factory
class MockNode : AbstractNode
fun addressToNode(address: SingleMessageRecipient): MockNode
fun createNode(networkMapAddress: NodeInfo? = null, forcedID: Int = -1, nodeFactory: Factory = defaultFactory, start: Boolean = true, legalName: String? = null, keyPair: KeyPair? = null, vararg advertisedServices: ServiceType): MockNode
fun createNotaryNode(legalName: String? = null, keyPair: KeyPair? = null): MockNode
fun createPartyNode(networkMapAddr: NodeInfo, legalName: String? = null, keyPair: KeyPair? = null): MockNode
fun createTwoNodes(nodeFactory: Factory = defaultFactory, notaryKeyPair: KeyPair? = null): <ERROR CLASS><MockNode, MockNode>
val filesystem: <ERROR CLASS>
val identities: ArrayList<Party>
val messagingNetwork: InMemoryMessagingNetwork
val nodes: List<MockNode>
fun runNetwork(rounds: Int = -1): Unit
fun startNodes(): Unit
fun stopNodes(): Unit
abstract class Simulation
class TestClock : MutableClock, SerializeAsToken
class TradeSimulation : Simulation
kotlin.collections.Iterable
package com.r3corda.node.serialization
package com.r3corda.node.services
package com.r3corda.node.services.api
package com.r3corda.node.services.clientapi
package com.r3corda.node.services.config
package com.r3corda.node.services.events
package com.r3corda.node.services.identity
package com.r3corda.node.services.keys
package com.r3corda.node.services.messaging
package com.r3corda.node.services.network
package com.r3corda.node.services.persistence
package com.r3corda.node.services.statemachine
Module Contents
sealed class FiberRequest
class ProtocolStateMachineImpl<R> : ProtocolStateMachine<R>
Module Contents
ProtocolStateMachineImpl(logic: ProtocolLogic<R>, scheduler: <ERROR CLASS>, loggerName: String)
val logger: <ERROR CLASS>
val logic: ProtocolLogic<R>
fun <T : Any> receive(topic: String, sessionIDForReceive: Long, recvType: Class<T>): UntrustworthyData<T>
val resultFuture: <ERROR CLASS><R>
fun run(): R
fun send(topic: String, destination: Party, sessionID: Long, payload: Any): Unit
fun <T : Any> sendAndReceive(topic: String, destination: Party, sessionIDForSend: Long, sessionIDForReceive: Long, payload: Any, recvType: Class<T>): UntrustworthyData<T>
lateinit var serviceHub: ServiceHubInternal
class StackSnapshot : Throwable
class StateMachineManager
package com.r3corda.node.services.transactions
package com.r3corda.node.services.wallet
package com.r3corda.node.servlets
package com.r3corda.node.utilities
package com.r3corda.protocols