tuweni
Module Contents
alltypes
Module Contents
class AES256GCM : AutoCloseable
Module Contents
class Key : Destroyable
class Nonce
fun close(): Unit
@Nullable fun decrypt(cipherText: Bytes, nonce: Nonce): Bytes?
@Nullable fun decrypt(cipherText: ByteArray, nonce: Nonce): ByteArray?
@Nullable fun decrypt(cipherText: Bytes, data: Bytes, nonce: Nonce): Bytes?
@Nullable fun decrypt(cipherText: ByteArray, data: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable fun decryptDetached(cipherText: Bytes, mac: Bytes, nonce: Nonce): Bytes?
@Nullable fun decryptDetached(cipherText: ByteArray, mac: ByteArray, nonce: Nonce): ByteArray?
@Nullable fun decryptDetached(cipherText: Bytes, mac: Bytes, data: Bytes, nonce: Nonce): Bytes?
@Nullable fun decryptDetached(cipherText: ByteArray, mac: ByteArray, data: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
fun encrypt(message: Bytes, nonce: Nonce): Bytes
fun encrypt(message: ByteArray, nonce: Nonce): ByteArray
fun encrypt(message: Bytes, data: Bytes, nonce: Nonce): Bytes
fun encrypt(message: ByteArray, data: ByteArray, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray
fun encryptDetached(message: Bytes, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: ByteArray, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: Bytes, data: Bytes, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: ByteArray, data: ByteArray, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, data: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun forKey(key: Key): AES256GCM
static fun isAvailable(): Boolean
abstract class AbstractBytes : Bytes
class Address
class Allocated : Destroyable
interface AsyncCompletion
Module Contents
static val COMPLETED: AsyncCompletion
abstract fun accept(consumer: Consumer<in Throwable>): AsyncCompletion
open static fun allOf(vararg cs: AsyncCompletion): AsyncCompletion
open static fun allOf(cs: MutableCollection<AsyncCompletion>): AsyncCompletion
open static fun allOf(cs: Stream<AsyncCompletion>): AsyncCompletion
abstract fun cancel(): Boolean
open static fun completed(): AsyncCompletion
open static fun exceptional(ex: Throwable): AsyncCompletion
abstract fun exceptionally(consumer: Consumer<in Throwable>): AsyncCompletion
open static fun executeBlocking(action: Runnable): AsyncCompletion
open static fun executeBlocking(executor: Executor, action: Runnable): AsyncCompletion
open static fun executeBlocking(vertx: Vertx, action: Runnable): AsyncCompletion
open static fun executeBlocking(executor: WorkerExecutor, action: Runnable): AsyncCompletion
abstract fun <U : Any> handle(fn: Function<in Throwable, out U>): AsyncResult<U>
open static fun incomplete(): CompletableAsyncCompletion
abstract fun isCancelled(): Boolean
abstract fun isCompletedExceptionally(): Boolean
abstract fun isDone(): Boolean
abstract fun join(): Unit
abstract fun join(timeout: Long, unit: TimeUnit): Unit
open static fun runOnContext(vertx: Vertx, fn: Supplier<out AsyncCompletion>): AsyncCompletion
open static fun runOnContext(vertx: Vertx, action: Runnable): AsyncCompletion
abstract fun <U : Any> then(fn: Supplier<out AsyncResult<U>>): AsyncResult<U>
abstract fun <U : Any, V : Any> thenApply(other: AsyncResult<out U>, fn: Function<in U, out V>): AsyncResult<V>
abstract fun thenCombine(other: AsyncCompletion): AsyncCompletion
abstract fun thenCompose(fn: Supplier<out AsyncCompletion>): AsyncCompletion
abstract fun <U : Any> thenConsume(other: AsyncResult<out U>, consumer: Consumer<in U>): AsyncCompletion
abstract fun thenRun(runnable: Runnable): AsyncCompletion
abstract fun <U : Any> thenSchedule(vertx: Vertx, fn: Supplier<out AsyncResult<U>>): AsyncResult<U>
abstract fun thenScheduleBlockingRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleBlockingRun(executor: WorkerExecutor, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun <U : Any> thenSupply(supplier: Supplier<out U>): AsyncResult<U>
abstract fun <U : Any> thenSupply(vertx: Vertx, supplier: Supplier<out U>): AsyncResult<U>
abstract fun whenComplete(consumer: Consumer<in Throwable>): AsyncCompletion
abstract class AsyncMerkleStorage : MerkleStorage
interface AsyncResult<T : Any>
Module Contents
abstract fun accept(consumer: BiConsumer<in T, Throwable>): AsyncCompletion
open static fun allOf(vararg rs: AsyncResult<*>): AsyncCompletion
open static fun allOf(rs: MutableCollection<out AsyncResult<*>>): AsyncCompletion
open static fun allOf(rs: Stream<out AsyncResult<*>>): AsyncCompletion
abstract fun cancel(): Boolean
open static fun <T : Any> combine(rs: MutableCollection<out AsyncResult<out T>>): AsyncResult<MutableList<T>>
open static fun <T : Any> combine(rs: Stream<out AsyncResult<out T>>): AsyncResult<MutableList<T>>
open static fun <T : Any> completed(@Nullable value: T?): AsyncResult<T>
open static fun <T : Any> exceptional(ex: Throwable): AsyncResult<T>
abstract fun exceptionally(fn: Function<Throwable, out T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(fn: Supplier<T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(executor: Executor, fn: Supplier<T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(vertx: Vertx, fn: Supplier<T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(executor: WorkerExecutor, fn: Supplier<T>): AsyncResult<T>
@Nullable abstract fun get(): T?
@Nullable abstract fun get(timeout: Long, unit: TimeUnit): T?
abstract fun <U : Any> handle(fn: BiFunction<in T, Throwable, out U>): AsyncResult<U>
open static fun <T : Any> incomplete(): CompletableAsyncResult<T>
abstract fun isCancelled(): Boolean
abstract fun isCompletedExceptionally(): Boolean
abstract fun isDone(): Boolean
open static fun <T : Any> runOnContext(vertx: Vertx, fn: Supplier<out AsyncResult<T>>): AsyncResult<T>
abstract fun <U : Any> then(fn: Function<in T, out AsyncResult<U>>): AsyncResult<U>
abstract fun thenAccept(consumer: Consumer<in T>): AsyncCompletion
abstract fun <U : Any> thenAcceptBoth(other: AsyncResult<out U>, consumer: BiConsumer<in T, in U>): AsyncCompletion
abstract fun <U : Any> thenApply(fn: Function<in T, out U>): AsyncResult<U>
abstract fun <U : Any, V : Any> thenCombine(other: AsyncResult<out U>, fn: BiFunction<in T, in U, out V>): AsyncResult<V>
abstract fun thenCompose(fn: Function<in T, out AsyncCompletion>): AsyncCompletion
abstract fun thenRun(runnable: Runnable): AsyncCompletion
abstract fun <U : Any> thenSchedule(vertx: Vertx, fn: Function<in T, out AsyncResult<U>>): AsyncResult<U>
abstract fun <U : Any> thenScheduleApply(vertx: Vertx, fn: Function<in T, out U>): AsyncResult<U>
abstract fun <U : Any> thenScheduleBlockingApply(vertx: Vertx, fn: Function<in T, out U>): AsyncResult<U>
abstract fun <U : Any> thenScheduleBlockingApply(executor: WorkerExecutor, fn: Function<in T, out U>): AsyncResult<U>
abstract fun thenScheduleBlockingRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleBlockingRun(executor: WorkerExecutor, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun whenComplete(action: BiConsumer<in T, in Throwable>): AsyncResult<T>
class AtomicSlotMap<K : Comparable<Any?>, V : Any>
class Auth
class BLS12381
Module Contents
static fun sign(keyPair: KeyPair, message: ByteArray, domain: Int): SignatureAndPublicKey
static fun sign(keyPair: KeyPair, message: Bytes, domain: Int): SignatureAndPublicKey
static fun verify(publicKey: PublicKey, signature: Signature, message: ByteArray, domain: Int): Boolean
static fun verify(publicKey: PublicKey, signature: Signature, message: Bytes, domain: Int): Boolean
static fun verify(sigAndPubKey: SignatureAndPublicKey, message: ByteArray, domain: Int): Boolean
static fun verify(sigAndPubKey: SignatureAndPublicKey, message: Bytes, domain: Int): Boolean
class Base32
class Base64
class Base64URLSafe
abstract class BaseUInt256Value<T : UInt256Value<T>> : UInt256Value<T>
abstract class BaseUInt32Value<T : UInt32Value<T>> : UInt32Value<T>
abstract class BaseUInt384Value<T : UInt384Value<T>> : UInt384Value<T>
abstract class BaseUInt64Value<T : UInt64Value<T>> : UInt64Value<T>
class Block
class BlockBody
class BlockHeader
Module Contents
BlockHeader(@Nullable : Hash?, : Hash, : Address, : Hash, : Hash, : Hash, : Bytes, : UInt256, : UInt256, : Gas, : Gas, : Instant, : Bytes, : Hash, : Bytes)
fun coinbase(): Address
fun difficulty(): UInt256
fun equals(: Any?): Boolean
fun extraData(): Bytes
static fun fromBytes(: Bytes): BlockHeader
fun gasLimit(): Gas
fun gasUsed(): Gas
fun hash(): Hash
fun hashCode(): Int
fun logsBloom(): Bytes
fun mixHash(): Hash
fun nonce(): Bytes
fun number(): UInt256
fun ommersHash(): Hash
@Nullable fun parentHash(): Hash?
static fun readFrom(: RLPReader): BlockHeader
fun receiptsRoot(): Hash
fun stateRoot(): Hash
fun timestamp(): Instant
fun toBytes(): Bytes
fun toString(): String
fun transactionsRoot(): Hash
enum class BlockHeaderFields
class BlockchainIndex : BlockchainIndexWriter, BlockchainIndexReader
Module Contents
BlockchainIndex(indexWriter: IndexWriter)
fun findBy(: BlockHeaderFields, : Bytes): List<Hash>
fun findBy(: BlockHeaderFields, : Long): List<Hash>
fun findBy(: BlockHeaderFields, : Gas): List<Hash>
fun findBy(: BlockHeaderFields, : UInt256): List<Hash>
fun findBy(: BlockHeaderFields, : Address): List<Hash>
fun findBy(: BlockHeaderFields, : Hash): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Bytes): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Int): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Long): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Gas): List<Hash>
fun findBy(field: TransactionReceiptFields, value: UInt256): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Address): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Hash): List<Hash>
fun findByBlockHashAndIndex(blockHash: Hash, index: Int): Hash?
fun findByHashOrNumber(hashOrNumber: Bytes32): List<Hash>
fun findByLargest(: BlockHeaderFields): Hash?
fun findByLargest(field: TransactionReceiptFields): Hash?
fun findInRange(: BlockHeaderFields, : UInt256, : UInt256): List<Hash>
fun findInRange(field: TransactionReceiptFields, minValue: UInt256, maxValue: UInt256): List<Hash>
fun index(indexer: (BlockchainIndexWriter) -> Unit): Unit
fun indexBlockHeader(: BlockHeader): Unit
fun indexTransactionReceipt(: TransactionReceipt, : Int, : Hash, : Hash): Unit
fun totalDifficulty(hash: Hash): UInt256?
interface BlockchainIndexReader
Module Contents
abstract fun findBy(: BlockHeaderFields, : Bytes): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Long): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Gas): List<Hash>
abstract fun findBy(: BlockHeaderFields, : UInt256): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Address): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Hash): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Bytes): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Int): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Long): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Gas): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: UInt256): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Address): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Hash): List<Hash>
abstract fun findByBlockHashAndIndex(blockHash: Hash, index: Int): Hash?
abstract fun findByHashOrNumber(hashOrNumber: Bytes32): List<Hash>
abstract fun findByLargest(: BlockHeaderFields): Hash?
abstract fun findByLargest(field: TransactionReceiptFields): Hash?
abstract fun findInRange(: BlockHeaderFields, : UInt256, : UInt256): List<Hash>
abstract fun findInRange(field: TransactionReceiptFields, minValue: UInt256, maxValue: UInt256): List<Hash>
abstract fun totalDifficulty(hash: Hash): UInt256?
interface BlockchainIndexWriter
class BlockchainRepository
Module Contents
BlockchainRepository(chainMetadata: KeyValueStore, blockBodyStore: KeyValueStore, : KeyValueStore, transactionReceiptsStore: KeyValueStore, blockchainIndex: BlockchainIndex)
val GENESIS_BLOCK: Bytes
fun findBlockByHashOrNumber(blockNumberOrBlockHash: Bytes32): List<Hash>
fun findBlocksByParentHash(parentHash: Hash): List<Hash>
suspend fun init(blockBodyStore: KeyValueStore, : KeyValueStore, chainMetadata: KeyValueStore, transactionReceiptsStore: KeyValueStore, blockchainIndex: BlockchainIndex, genesisBlock: Block): BlockchainRepository
suspend fun retrieveBlock(blockHash: Hash): Block?
suspend fun retrieveBlock(blockHash: Bytes): Block?
suspend fun retrieveBlockBody(blockHash: Hash): BlockBody?
suspend fun retrieveBlockBody(blockHash: Bytes): BlockBody?
suspend fun retrieveBlockBodyBytes(blockHash: Hash): Bytes?
suspend fun retrieveBlockBodyBytes(blockHash: Bytes): Bytes?
suspend fun retrieveBlockHeader(: Hash): BlockHeader?
suspend fun retrieveBlockHeader(: Bytes): BlockHeader?
suspend fun retrieveBlockHeaderBytes(: Hash): Bytes?
suspend fun retrieveBlockHeaderBytes(: Bytes): Bytes?
suspend fun retrieveChainHead(): Block?
suspend fun retrieveChainHeadHeader(): BlockHeader?
suspend fun retrieveGenesisBlock(): Block?
suspend fun retrieveTransactionReceipt(blockHash: Hash, index: Int): TransactionReceipt?
suspend fun retrieveTransactionReceipt(txHash: Hash): TransactionReceipt?
suspend fun retrieveTransactionReceipts(blockHash: Hash): List<TransactionReceipt?>
suspend fun storeBlock(block: Block): Unit
suspend fun storeBlockBody(blockHash: Hash, blockBody: BlockBody): Unit
suspend fun storeBlockHeader(: BlockHeader): Unit
suspend fun storeTransactionReceipt(transactionReceipt: TransactionReceipt, txIndex: Int, txHash: Hash, blockHash: Hash): Unit
suspend fun storeTransactionReceipts(vararg transactionReceipts: TransactionReceipt, txHash: Hash, blockHash: Hash): Unit
open class BouncyCastleExtension : BeforeAllCallback
class Box : AutoCloseable
Module Contents
class KeyPair
class Nonce
class PublicKey
class SecretKey : Destroyable
class Seed
fun close(): Unit
@Nullable fun decrypt(cipherText: Bytes, nonce: Nonce): Bytes?
@Nullable fun decrypt(cipherText: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, sender: PublicKey, receiver: SecretKey, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, sender: PublicKey, receiver: SecretKey, nonce: Nonce): ByteArray?
@Nullable fun decryptDetached(cipherText: Bytes, mac: Bytes, nonce: Nonce): Bytes?
@Nullable fun decryptDetached(cipherText: ByteArray, mac: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, sender: PublicKey, receiver: SecretKey, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, sender: PublicKey, receiver: SecretKey, nonce: Nonce): ByteArray?
@Nullable static fun decryptSealed(cipherText: Bytes, sender: PublicKey, receiver: SecretKey): Bytes?
@Nullable static fun decryptSealed(cipherText: ByteArray, sender: PublicKey, receiver: SecretKey): ByteArray?
fun encrypt(message: Bytes, nonce: Nonce): Bytes
fun encrypt(message: ByteArray, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, receiver: PublicKey, sender: SecretKey, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, receiver: PublicKey, sender: SecretKey, nonce: Nonce): ByteArray
fun encryptDetached(message: Bytes, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: ByteArray, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, receiver: PublicKey, sender: SecretKey, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, receiver: PublicKey, sender: SecretKey, nonce: Nonce): DetachedEncryptionResult
static fun encryptSealed(message: Bytes, receiver: PublicKey): Bytes
static fun encryptSealed(message: ByteArray, receiver: PublicKey): ByteArray
static fun forKeys(receiver: PublicKey, sender: SecretKey): Box
interface Bytes
Module Contents
static val EMPTY: Bytes
open fun and(other: Bytes): Bytes
open fun <T : MutableBytes> and(other: Bytes, result: T): T
open fun <T : Appendable> appendHexTo(appendable: T): T
open fun appendTo(byteBuffer: ByteBuffer): Unit
open fun appendTo(buffer: Buffer): Unit
open fun bitLength(): Int
open fun commonPrefix(other: Bytes): Bytes
open fun commonPrefixLength(other: Bytes): Int
open static fun concatenate(vararg values: Bytes): Bytes
abstract fun copy(): Bytes
open fun copyTo(destination: MutableBytes): Unit
open fun copyTo(destination: MutableBytes, destinationOffset: Int): Unit
open static fun fromBase64String(str: CharSequence): Bytes
open static fun fromHexString(str: CharSequence): Bytes
open static fun fromHexString(str: CharSequence, destinationSize: Int): Bytes
open static fun fromHexStringLenient(str: CharSequence): Bytes
open static fun fromHexStringLenient(str: CharSequence, destinationSize: Int): Bytes
abstract fun get(i: Int): Byte
open fun getInt(i: Int): Int
open fun getInt(i: Int, order: ByteOrder): Int
open fun getLong(i: Int): Long
open fun getLong(i: Int, order: ByteOrder): Long
open fun hasLeadingZero(): Boolean
open fun hasLeadingZeroByte(): Boolean
open fun isEmpty(): Boolean
open fun isZero(): Boolean
open static fun minimalBytes(value: Long): Bytes
abstract fun mutableCopy(): MutableBytes
open fun not(): Bytes
open fun <T : MutableBytes> not(result: T): T
open fun numberOfLeadingZeroBytes(): Int
open fun numberOfLeadingZeros(): Int
open fun numberOfTrailingZeroBytes(): Int
open static fun of(vararg bytes: Byte): Bytes
open static fun of(vararg bytes: Int): Bytes
open static fun ofUnsignedInt(value: Long): Bytes
open static fun ofUnsignedInt(value: Long, order: ByteOrder): Bytes
open static fun ofUnsignedLong(value: Long): Bytes
open static fun ofUnsignedLong(value: Long, order: ByteOrder): Bytes
open static fun ofUnsignedShort(value: Int): Bytes
open static fun ofUnsignedShort(value: Int, order: ByteOrder): Bytes
open fun or(other: Bytes): Bytes
open fun <T : MutableBytes> or(other: Bytes, result: T): T
open static fun random(size: Int): Bytes
open static fun random(size: Int, generator: Random): Bytes
open fun reverse(): Bytes
open fun shiftLeft(distance: Int): Bytes
open fun <T : MutableBytes> shiftLeft(distance: Int, result: T): T
open fun shiftRight(distance: Int): Bytes
open fun <T : MutableBytes> shiftRight(distance: Int, result: T): T
abstract fun size(): Int
open fun slice(i: Int): Bytes
abstract fun slice(i: Int, length: Int): Bytes
open fun toArray(): ByteArray
open fun toArrayUnsafe(): ByteArray
open fun toBase64String(): String
open fun toBigInteger(): BigInteger
open fun toBigInteger(order: ByteOrder): BigInteger
open fun toHexString(): String
open fun toInt(): Int
open fun toInt(order: ByteOrder): Int
open fun toLong(): Long
open fun toLong(order: ByteOrder): Long
open fun toShortHexString(): String
open fun toUnsignedBigInteger(): BigInteger
open fun toUnsignedBigInteger(order: ByteOrder): BigInteger
open fun trimLeadingZeros(): Bytes
open fun update(digest: MessageDigest): Unit
open static fun wrap(value: ByteArray): Bytes
open static fun wrap(value: ByteArray, offset: Int, length: Int): Bytes
open static fun wrap(vararg values: Bytes): Bytes
open static fun wrapBuffer(buffer: Buffer): Bytes
open static fun wrapBuffer(buffer: Buffer, offset: Int, size: Int): Bytes
open static fun wrapByteBuf(byteBuf: ByteBuf): Bytes
open static fun wrapByteBuf(byteBuf: ByteBuf, offset: Int, size: Int): Bytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer): Bytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer, offset: Int, size: Int): Bytes
open fun xor(other: Bytes): Bytes
open fun <T : MutableBytes> xor(other: Bytes, result: T): T
interface Bytes32 : Bytes
interface Bytes48 : Bytes
interface ClientHandler
interface ClientHandlerFactory<T : ClientHandler>
class CompactEncoding
interface CompletableAsyncCompletion : AsyncCompletion
interface CompletableAsyncResult<T : Any> : AsyncResult<T>
class Concatenate
interface Configuration
class ConfigurationError : RuntimeException
class ConfigurationErrors
interface ConfigurationValidator
open class ConnectionClosedException : Exception
interface CoroutineByteChannel : ReadableCoroutineByteChannel, WritableCoroutineByteChannel
sealed class CoroutineChannelGroup
class CoroutineDatagramChannel : CoroutineByteChannel, ScatteringCoroutineByteChannel, GatheringCoroutineByteChannel, CoroutineNetworkChannel
class CoroutineLatch
interface CoroutineNetworkChannel : NetworkChannel
sealed class CoroutineSelector
class CoroutineServerSocketChannel : CoroutineNetworkChannel
class CoroutineSocketChannel : CoroutineByteChannel, ScatteringCoroutineByteChannel, GatheringCoroutineByteChannel, CoroutineNetworkChannel
class DefaultWireConnection : WireConnection
Module Contents
DefaultWireConnection(id: String, nodeId: Bytes, peerNodeId: Bytes, logger: Logger, writer: Consumer<RLPxMessage>, afterHandshakeListener: Consumer<HelloMessage>, disconnectHandler: Runnable, subprotocols: LinkedHashMap<SubProtocol, SubProtocolHandler>, p2pVersion: Int, clientId: String, advertisedPort: Int)
fun disconnect(reason: DisconnectReason): Unit
fun handleConnectionStart(): Unit
fun id(): String
fun messageReceived(message: RLPxMessage): Unit
fun sendMessage(subProtocolIdentifier: SubProtocolIdentifier, messageType: Int, message: Bytes): Unit
fun sendPing(): AsyncCompletion
fun toString(): String
interface DetachedEncryptionResult
class DevP2PPeerRoutingTable : PeerRoutingTable
class DiffieHelman
class DisconnectReason
interface DiscoveryService
Module Contents
abstract suspend fun awaitBootstrap(): Int
abstract suspend fun awaitTermination(): Unit
abstract fun awaitTerminationAsync(): AsyncCompletion
abstract val expiredPackets: Long
abstract val filteredPackets: Long
abstract val invalidPackets: Long
abstract val isShutdown: Boolean
abstract val isTerminated: Boolean
abstract val localPort: Int
abstract suspend fun lookup(target: PublicKey): List<Peer>
abstract fun lookupAsync(target: PublicKey): AsyncResult<List<Peer>>
abstract val nodeId: PublicKey
@JvmOverloads fun open(keyPair: KeyPair, port: Int = 0, host: String? = null, seq: Long = Instant.now().toEpochMilli(), enrData: Map<String, Bytes> = emptyMap(), bootstrapURIs: List<URI> = emptyList(), peerRepository: PeerRepository = EphemeralPeerRepository(), advertiseAddress: InetAddress? = null, advertiseUdpPort: Int? = null, advertiseTcpPort: Int? = null, routingTable: PeerRoutingTable = DevP2PPeerRoutingTable(keyPair.publicKey()), packetFilter: (PublicKey, InetSocketAddress) -> Boolean = null, loggerProvider: LoggerProvider = LoggerProvider.nullProvider(), channelGroup: CoroutineChannelGroup = CommonCoroutineGroup, bufferAllocator: () -> ByteBuffer = DEFAULT_BUFFER_ALLOCATOR, timeSupplier: () -> Long = CURRENT_TIME_SUPPLIER): DiscoveryService
@JvmOverloads fun open(keyPair: KeyPair, bindAddress: InetSocketAddress, seq: Long = Instant.now().toEpochMilli(), enrData: Map<String, Bytes> = emptyMap(), bootstrapURIs: List<URI> = emptyList(), peerRepository: PeerRepository = EphemeralPeerRepository(), advertiseAddress: InetAddress? = null, advertiseUdpPort: Int? = null, advertiseTcpPort: Int? = null, routingTable: PeerRoutingTable = DevP2PPeerRoutingTable(keyPair.publicKey()), packetFilter: (PublicKey, InetSocketAddress) -> Boolean = null, loggerProvider: LoggerProvider = LoggerProvider.nullProvider(), channelGroup: CoroutineChannelGroup = CommonCoroutineGroup, bufferAllocator: () -> ByteBuffer = DEFAULT_BUFFER_ALLOCATOR, timeSupplier: () -> Long = CURRENT_TIME_SUPPLIER): DiscoveryService
abstract val selfPackets: Long
abstract fun shutdown(): Unit
abstract fun shutdownNow(): Unit
abstract val unexpectedENRResponses: Long
abstract val unexpectedNeighbors: Long
abstract val unexpectedPongs: Long
abstract val unvalidatedPeerPackets: Long
class DocumentPosition
class ENRNode : DNSEntry
class ENRTree : DNSEntry
class ENRTreeLink : DNSEntry
class ENRTreeRoot : DNSEntry
open class EndOfRLPException : RLPException
open class EndOfSSZException : SSZException
data class Endpoint
data class EnodeUriComponents
class EphemeralPeerRepository : PeerRepository
class EphemeralPeerRepository : PeerRepository
open class EthHash
open class EthereumIESEncryptionEngine
Module Contents
EthereumIESEncryptionEngine(agree: BasicAgreement, kdf: DerivationFunction, mac: Mac, commonMac: ByteArray)
EthereumIESEncryptionEngine(agree: BasicAgreement, kdf: DerivationFunction, mac: Mac, commonMac: ByteArray, cipher: BufferedBlockCipher)
open fun getCipher(): BufferedBlockCipher
open fun getMac(): Mac
open fun init(forEncryption: Boolean, privParam: CipherParameters, pubParam: CipherParameters, params: CipherParameters): Unit
open fun init(publicKey: AsymmetricKeyParameter, params: CipherParameters, ephemeralKeyPairGenerator: EphemeralKeyPairGenerator): Unit
open fun init(privateKey: AsymmetricKeyParameter, params: CipherParameters, publicKeyParser: KeyParser): Unit
open fun processBlock(in: ByteArray, inOff: Int, inLen: Int): ByteArray
class EthereumNodeRecord
Module Contents
EthereumNodeRecord(signature: Bytes, seq: Long, data: Map<String, Bytes>)
val data: Map<String, Bytes>
@JvmStatic fun fromRLP(rlp: Bytes): EthereumNodeRecord
fun ip(): InetAddress
fun publicKey(): PublicKey
val seq: Long
val signature: Bytes
fun tcp(): Int
@JvmOverloads @JvmStatic fun toRLP(signatureKeyPair: KeyPair, seq: Long = Instant.now().toEpochMilli(), data: Map<String, Bytes>? = null, ip: InetAddress, tcp: Int? = null, udp: Int? = null): Bytes
fun udp(): Int
fun validate(): Unit
class ExpiringMap<K : Any, V : Any> : MutableMap<K, V>
Module Contents
ExpiringMap()
fun clear(): Unit
fun compute(key: K, remappingFunction: BiFunction<in K, in V?, out V?>): V?
fun computeIfAbsent(key: K, mappingFunction: Function<in K, out V>): V
fun computeIfPresent(key: K, remappingFunction: BiFunction<in K, in V, out V?>): V?
fun containsKey(key: K): Boolean
fun containsValue(value: V): Boolean
val entries: MutableSet<MutableEntry<K, V>>
fun equals(other: Any?): Boolean
fun forEach(action: BiConsumer<in K, in V>): Unit
@Nullable fun get(key: K): V?
fun getOrDefault(key: K, defaultValue: V): V
fun hashCode(): Int
fun isEmpty(): Boolean
val keys: MutableSet<K>
fun merge(key: K, value: V, remappingFunction: BiFunction<in V, in V, out V?>): V?
fun purgeExpired(): Long
@Nullable fun put(key: K, value: V): V?
@Nullable fun put(key: K, value: V, expiry: Long): V?
@Nullable fun put(key: K, value: V, expiry: Long, @Nullable expiryListener: BiConsumer<K, V>?): V?
fun putAll(from: Map<out K, V>): Unit
@Nullable fun putIfAbsent(key: K, value: V): V?
@Nullable fun putIfAbsent(key: K, value: V, expiry: Long): V?
@Nullable fun putIfAbsent(key: K, value: V, expiry: Long, @Nullable expiryListener: BiConsumer<K, V>?): V?
fun remove(key: K): V?
fun remove(key: K, value: V): Boolean
fun replace(key: K, value: V): V?
fun replace(key: K, oldValue: V, newValue: V): Boolean
fun replaceAll(function: BiFunction<in K, in V, out V>): Unit
val size: Int
val values: MutableCollection<V>
class ExpiringSet<E : Any> : MutableSet<E>
class Files
Module Contents
static fun atomicReplace(path: Path, bytes: ByteArray): Unit
static fun atomicReplace(path: Path, fn: IOConsumer<Writer>): Unit
static fun atomicReplace(path: Path, charset: Charset, fn: IOConsumer<Writer>): Unit
static fun copyResource(resourceName: String, destination: Path, vararg options: OpenOption): Path
static fun copyResource(classloader: ClassLoader, resourceName: String, destination: Path, vararg options: OpenOption): Path
static fun copyResource(resourceName: String, out: OutputStream): Long
static fun copyResource(classloader: ClassLoader, resourceName: String, out: OutputStream): Long
static fun createFileIfMissing(path: Path, vararg attrs: FileAttribute<*>): Boolean
static fun deleteRecursively(directory: Path): Unit
interface FingerprintRepository
class Gas
interface GatheringCoroutineByteChannel : WritableCoroutineByteChannel
class GenericHash
class GossipApp
class HMACSHA256
class HMACSHA512
class HMACSHA512256
class HandshakeException : RuntimeException
interface HandshakeMessage
class Hash
class Hash
class HelloMessage : WireProtocolMessage
class HobbitsTransport : CoroutineScope
Module Contents
HobbitsTransport(vertx: Vertx, coroutineContext: CoroutineContext = Dispatchers.Default)
val coroutineContext: CoroutineContext
fun createHTTPEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9337, requestURI: String? = null, tls: Boolean = false, handler: (Message) -> Unit): Unit
fun createTCPEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9237, tls: Boolean = false, handler: (Message) -> Unit): Unit
fun createUDPEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9137, handler: (Message) -> Unit): Unit
fun createWSEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9037, requestURI: String? = null, tls: Boolean = false, handler: (Message) -> Unit): Unit
fun exceptionHandler(handler: (Throwable) -> Unit): Unit
suspend fun sendMessage(message: Message, transport: Transport, host: String, port: Int, requestURI: String = ""): Unit
suspend fun start(): Unit
fun stop(): Unit
@FunctionalInterface interface IOConsumer<T : Any>
interface Identity
class InfinispanKeyValueStore : KeyValueStore
class InvalidConfigurationPropertyTypeException : RuntimeException
class InvalidEntryException : RuntimeException
open class InvalidMACException : RuntimeException
open class InvalidRLPEncodingException : RLPException
open class InvalidRLPTypeException : RLPException
class InvalidSEC256K1SecretKeyStoreException : RuntimeException
open class InvalidSSZTypeException : SSZException
class Invite
class KademliaRoutingTable<T> : Set<T>
Module Contents
KademliaRoutingTable(selfId: ByteArray, k: Int, maxReplacements: Int = k, nodeId: (T) -> ByteArray)
fun add(node: T): T?
fun clear(): Unit
fun contains(element: T): Boolean
fun containsAll(elements: Collection<T>): Boolean
@JvmStatic fun <T> create(selfId: ByteArray, k: Int, nodeId: Function<T, ByteArray>): KademliaRoutingTable<T>
@JvmStatic fun <T> create(selfId: ByteArray, k: Int, maxReplacements: Int, nodeId: Function<T, ByteArray>): KademliaRoutingTable<T>
fun evict(node: T): Boolean
fun isEmpty(): Boolean
fun iterator(): Iterator<T>
fun nearest(targetId: ByteArray, limit: Int): List<T>
val size: Int
class KeyDerivation
class KeyExchange
class KeyPair
interface KeyValueStore : Closeable
class LESSubprotocol : SubProtocol
class LevelDBKeyValueStore : KeyValueStore
interface LibSodium
Module Contents
abstract fun buf(buf: ByteArray, size: Long): Unit
abstract fun close(): Int
abstract fun crypto_aead_aes256gcm_abytes(): Long
abstract fun crypto_aead_aes256gcm_beforenm(ctx_: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: Pointer, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt_afternm(m: ByteArray, mlen_p: LongLongByReference, nsec: Pointer, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt_detached(m: ByteArray, nsec: Pointer, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt_detached_afternm(m: ByteArray, nsec: Pointer, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt_afternm(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt_detached_afternm(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_is_available(): Int
abstract fun crypto_aead_aes256gcm_keybytes(): Long
abstract fun crypto_aead_aes256gcm_keygen(k: Pointer): Unit
abstract fun crypto_aead_aes256gcm_messagebytes_max(): Long
abstract fun crypto_aead_aes256gcm_npubbytes(): Long
abstract fun crypto_aead_aes256gcm_nsecbytes(): Long
abstract fun crypto_aead_aes256gcm_statebytes(): Long
abstract fun crypto_aead_chacha20poly1305_abytes(): Long
abstract fun crypto_aead_chacha20poly1305_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: ByteArray, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_decrypt_detached(m: ByteArray, nsec: ByteArray, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_abytes(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: ByteArray, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_decrypt_detached(m: ByteArray, nsec: ByteArray, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_keybytes(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_keygen(k: ByteArray): Unit
abstract fun crypto_aead_chacha20poly1305_ietf_messagebytes_max(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_npubbytes(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_nsecbytes(): Long
abstract fun crypto_aead_chacha20poly1305_keybytes(): Long
abstract fun crypto_aead_chacha20poly1305_keygen(k: ByteArray): Unit
abstract fun crypto_aead_chacha20poly1305_messagebytes_max(): Long
abstract fun crypto_aead_chacha20poly1305_npubbytes(): Long
abstract fun crypto_aead_chacha20poly1305_nsecbytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_abytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: ByteArray, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_decrypt_detached(m: ByteArray, nsec: ByteArray, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_keybytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_keygen(k: Pointer): Unit
abstract fun crypto_aead_xchacha20poly1305_ietf_messagebytes_max(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_npubbytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_nsecbytes(): Long
abstract fun crypto_auth(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_bytes(): Long
abstract fun crypto_auth_hmacsha256(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha256_bytes(): Long
abstract fun crypto_auth_hmacsha256_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_auth_hmacsha256_init(state: Pointer, key: ByteArray, keylen: Long): Int
abstract fun crypto_auth_hmacsha256_keybytes(): Long
abstract fun crypto_auth_hmacsha256_keygen(k: ByteArray): Unit
abstract fun crypto_auth_hmacsha256_statebytes(): Long
abstract fun crypto_auth_hmacsha256_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_auth_hmacsha256_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512256(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512256_bytes(): Long
abstract fun crypto_auth_hmacsha512256_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_auth_hmacsha512256_init(state: Pointer, key: ByteArray, keylen: Long): Int
abstract fun crypto_auth_hmacsha512256_keybytes(): Long
abstract fun crypto_auth_hmacsha512256_keygen(k: ByteArray): Unit
abstract fun crypto_auth_hmacsha512256_statebytes(): Long
abstract fun crypto_auth_hmacsha512256_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_auth_hmacsha512256_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512_bytes(): Long
abstract fun crypto_auth_hmacsha512_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_auth_hmacsha512_init(state: Pointer, key: ByteArray, keylen: Long): Int
abstract fun crypto_auth_hmacsha512_keybytes(): Long
abstract fun crypto_auth_hmacsha512_keygen(k: ByteArray): Unit
abstract fun crypto_auth_hmacsha512_statebytes(): Long
abstract fun crypto_auth_hmacsha512_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_auth_hmacsha512_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_keybytes(): Long
abstract fun crypto_auth_keygen(k: Pointer): Unit
abstract fun crypto_auth_primitive(): String
abstract fun crypto_auth_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_box(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_beforenm(k: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_beforenmbytes(): Long
abstract fun crypto_box_boxzerobytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_beforenm(k: Pointer, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_beforenmbytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_detached_afternm(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_easy(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_easy_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_keypair(pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_macbytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_messagebytes_max(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_noncebytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_open_detached_afternm(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_open_easy_afternm(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_publickeybytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_seal(c: ByteArray, m: ByteArray, mlen: Long, pk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_seal_open(m: ByteArray, c: ByteArray, clen: Long, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_sealbytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_secretkeybytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_seed_keypair(pk: ByteArray, sk: ByteArray, seed: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_seedbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_beforenm(k: Pointer, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_beforenmbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_boxzerobytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_keypair(pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_macbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_messagebytes_max(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_noncebytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_open_afternm(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_publickeybytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_secretkeybytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_seed_keypair(pk: ByteArray, sk: ByteArray, seed: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_seedbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_zerobytes(): Long
abstract fun crypto_box_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_detached_afternm(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_easy(c: ByteArray, m: ByteArray, mlen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_easy_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_keypair(pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_macbytes(): Long
abstract fun crypto_box_messagebytes_max(): Long
abstract fun crypto_box_noncebytes(): Long
abstract fun crypto_box_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_open_afternm(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_open_detached_afternm(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_open_easy_afternm(m: ByteArray, c: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_primitive(): String
abstract fun crypto_box_publickeybytes(): Long
abstract fun crypto_box_seal(c: ByteArray, m: ByteArray, mlen: Long, pk: Pointer): Int
abstract fun crypto_box_seal_open(m: ByteArray, c: ByteArray, clen: Long, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_sealbytes(): Long
abstract fun crypto_box_secretkeybytes(): Long
abstract fun crypto_box_seed_keypair(pk: Pointer, sk: Pointer, seed: Pointer): Int
abstract fun crypto_box_seedbytes(): Long
abstract fun crypto_box_zerobytes(): Long
abstract fun crypto_core_ed25519_add(r: ByteArray, p: ByteArray, q: ByteArray): Int
abstract fun crypto_core_ed25519_bytes(): Long
abstract fun crypto_core_ed25519_from_uniform(p: ByteArray, r: ByteArray): Int
abstract fun crypto_core_ed25519_is_valid_point(p: ByteArray): Int
abstract fun crypto_core_ed25519_sub(r: ByteArray, p: ByteArray, q: ByteArray): Int
abstract fun crypto_core_ed25519_uniformbytes(): Long
abstract fun crypto_core_hchacha20(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_hchacha20_constbytes(): Long
abstract fun crypto_core_hchacha20_inputbytes(): Long
abstract fun crypto_core_hchacha20_keybytes(): Long
abstract fun crypto_core_hchacha20_outputbytes(): Long
abstract fun crypto_core_hsalsa20(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_hsalsa20_constbytes(): Long
abstract fun crypto_core_hsalsa20_inputbytes(): Long
abstract fun crypto_core_hsalsa20_keybytes(): Long
abstract fun crypto_core_hsalsa20_outputbytes(): Long
abstract fun crypto_core_salsa20(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_salsa2012(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_salsa2012_constbytes(): Long
abstract fun crypto_core_salsa2012_inputbytes(): Long
abstract fun crypto_core_salsa2012_keybytes(): Long
abstract fun crypto_core_salsa2012_outputbytes(): Long
abstract fun crypto_core_salsa208(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_salsa208_constbytes(): Long
abstract fun crypto_core_salsa208_inputbytes(): Long
abstract fun crypto_core_salsa208_keybytes(): Long
abstract fun crypto_core_salsa208_outputbytes(): Long
abstract fun crypto_core_salsa20_constbytes(): Long
abstract fun crypto_core_salsa20_inputbytes(): Long
abstract fun crypto_core_salsa20_keybytes(): Long
abstract fun crypto_core_salsa20_outputbytes(): Long
abstract fun crypto_generichash(out: Pointer, outlen: Long, in: Pointer, inlen: Long, key: Pointer, keylen: Long): Int
abstract fun crypto_generichash_blake2b(out: ByteArray, outlen: Long, in: ByteArray, inlen: Long, key: ByteArray, keylen: Long): Int
abstract fun crypto_generichash_blake2b_bytes(): Long
abstract fun crypto_generichash_blake2b_bytes_max(): Long
abstract fun crypto_generichash_blake2b_bytes_min(): Long
abstract fun crypto_generichash_blake2b_final(state: Pointer, out: ByteArray, outlen: Long): Int
abstract fun crypto_generichash_blake2b_init(state: Pointer, key: ByteArray, keylen: Long, outlen: Long): Int
abstract fun crypto_generichash_blake2b_init_salt_personal(state: Pointer, key: ByteArray, keylen: Long, outlen: Long, salt: ByteArray, personal: ByteArray): Int
abstract fun crypto_generichash_blake2b_keybytes(): Long
abstract fun crypto_generichash_blake2b_keybytes_max(): Long
abstract fun crypto_generichash_blake2b_keybytes_min(): Long
abstract fun crypto_generichash_blake2b_keygen(k: ByteArray): Unit
abstract fun crypto_generichash_blake2b_personalbytes(): Long
abstract fun crypto_generichash_blake2b_salt_personal(out: ByteArray, outlen: Long, in: ByteArray, inlen: Long, key: ByteArray, keylen: Long, salt: ByteArray, personal: ByteArray): Int
abstract fun crypto_generichash_blake2b_saltbytes(): Long
abstract fun crypto_generichash_blake2b_statebytes(): Long
abstract fun crypto_generichash_blake2b_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_generichash_bytes(): Long
abstract fun crypto_generichash_bytes_max(): Long
abstract fun crypto_generichash_bytes_min(): Long
abstract fun crypto_generichash_final(state: Pointer, out: ByteArray, outlen: Long): Int
abstract fun crypto_generichash_init(state: Pointer, key: ByteArray, keylen: Long, outlen: Long): Int
abstract fun crypto_generichash_keybytes(): Long
abstract fun crypto_generichash_keybytes_max(): Long
abstract fun crypto_generichash_keybytes_min(): Long
abstract fun crypto_generichash_keygen(k: ByteArray): Unit
abstract fun crypto_generichash_primitive(): String
abstract fun crypto_generichash_statebytes(): Long
abstract fun crypto_generichash_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash(out: ByteArray, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_bytes(): Long
abstract fun crypto_hash_primitive(): String
abstract fun crypto_hash_sha256(out: ByteArray, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_sha256(out: Pointer, in: Pointer, inlen: Long): Int
abstract fun crypto_hash_sha256_bytes(): Long
abstract fun crypto_hash_sha256_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_hash_sha256_init(state: Pointer): Int
abstract fun crypto_hash_sha256_statebytes(): Long
abstract fun crypto_hash_sha256_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_sha512(out: ByteArray, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_sha512_bytes(): Long
abstract fun crypto_hash_sha512_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_hash_sha512_init(state: Pointer): Int
abstract fun crypto_hash_sha512_statebytes(): Long
abstract fun crypto_hash_sha512_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_kdf_blake2b_bytes_max(): Long
abstract fun crypto_kdf_blake2b_bytes_min(): Long
abstract fun crypto_kdf_blake2b_contextbytes(): Long
abstract fun crypto_kdf_blake2b_derive_from_key(subkey: ByteArray, subkey_len: Long, subkey_id: Long, ctx: ByteArray, key: Pointer): Int
abstract fun crypto_kdf_blake2b_keybytes(): Long
abstract fun crypto_kdf_bytes_max(): Long
abstract fun crypto_kdf_bytes_min(): Long
abstract fun crypto_kdf_contextbytes(): Long
abstract fun crypto_kdf_derive_from_key(subkey: ByteArray, subkey_len: Long, subkey_id: Long, ctx: ByteArray, key: Pointer): Int
abstract fun crypto_kdf_keybytes(): Long
abstract fun crypto_kdf_keygen(k: Pointer): Unit
abstract fun crypto_kdf_primitive(): String
abstract fun crypto_kx_client_session_keys(rx: Pointer, tx: Pointer, client_pk: Pointer, client_sk: Pointer, server_pk: Pointer): Int
abstract fun crypto_kx_keypair(pk: Pointer, sk: Pointer): Int
abstract fun crypto_kx_primitive(): String
abstract fun crypto_kx_publickeybytes(): Long
abstract fun crypto_kx_secretkeybytes(): Long
abstract fun crypto_kx_seed_keypair(pk: Pointer, sk: Pointer, seed: Pointer): Int
abstract fun crypto_kx_seedbytes(): Long
abstract fun crypto_kx_server_session_keys(rx: Pointer, tx: Pointer, server_pk: Pointer, server_sk: Pointer, client_pk: Pointer): Int
abstract fun crypto_kx_sessionkeybytes(): Long
abstract fun crypto_onetimeauth(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_onetimeauth_bytes(): Long
abstract fun crypto_onetimeauth_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_onetimeauth_init(state: Pointer, key: ByteArray): Int
abstract fun crypto_onetimeauth_keybytes(): Long
abstract fun crypto_onetimeauth_keygen(k: ByteArray): Unit
abstract fun crypto_onetimeauth_poly1305(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_onetimeauth_poly1305_bytes(): Long
abstract fun crypto_onetimeauth_poly1305_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_onetimeauth_poly1305_init(state: Pointer, key: ByteArray): Int
abstract fun crypto_onetimeauth_poly1305_keybytes(): Long
abstract fun crypto_onetimeauth_poly1305_keygen(k: ByteArray): Unit
abstract fun crypto_onetimeauth_poly1305_statebytes(): Long
abstract fun crypto_onetimeauth_poly1305_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_onetimeauth_poly1305_verify(h: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_onetimeauth_primitive(): String
abstract fun crypto_onetimeauth_statebytes(): Long
abstract fun crypto_onetimeauth_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_onetimeauth_verify(h: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_pwhash(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: Pointer, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_alg_argon2i13(): Int
abstract fun crypto_pwhash_alg_argon2id13(): Int
abstract fun crypto_pwhash_alg_default(): Int
abstract fun crypto_pwhash_argon2i(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: ByteArray, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_argon2i_alg_argon2i13(): Int
abstract fun crypto_pwhash_argon2i_bytes_max(): Long
abstract fun crypto_pwhash_argon2i_bytes_min(): Long
abstract fun crypto_pwhash_argon2i_memlimit_interactive(): Long
abstract fun crypto_pwhash_argon2i_memlimit_max(): Long
abstract fun crypto_pwhash_argon2i_memlimit_min(): Long
abstract fun crypto_pwhash_argon2i_memlimit_moderate(): Long
abstract fun crypto_pwhash_argon2i_memlimit_sensitive(): Long
abstract fun crypto_pwhash_argon2i_opslimit_interactive(): Long
abstract fun crypto_pwhash_argon2i_opslimit_max(): Long
abstract fun crypto_pwhash_argon2i_opslimit_min(): Long
abstract fun crypto_pwhash_argon2i_opslimit_moderate(): Long
abstract fun crypto_pwhash_argon2i_opslimit_sensitive(): Long
abstract fun crypto_pwhash_argon2i_passwd_max(): Long
abstract fun crypto_pwhash_argon2i_passwd_min(): Long
abstract fun crypto_pwhash_argon2i_saltbytes(): Long
abstract fun crypto_pwhash_argon2i_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2i_str_needs_rehash(str: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2i_str_verify(str: ByteArray, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_argon2i_strbytes(): Long
abstract fun crypto_pwhash_argon2i_strprefix(): String
abstract fun crypto_pwhash_argon2id(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: ByteArray, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_argon2id_alg_argon2id13(): Int
abstract fun crypto_pwhash_argon2id_bytes_max(): Long
abstract fun crypto_pwhash_argon2id_bytes_min(): Long
abstract fun crypto_pwhash_argon2id_memlimit_interactive(): Long
abstract fun crypto_pwhash_argon2id_memlimit_max(): Long
abstract fun crypto_pwhash_argon2id_memlimit_min(): Long
abstract fun crypto_pwhash_argon2id_memlimit_moderate(): Long
abstract fun crypto_pwhash_argon2id_memlimit_sensitive(): Long
abstract fun crypto_pwhash_argon2id_opslimit_interactive(): Long
abstract fun crypto_pwhash_argon2id_opslimit_max(): Long
abstract fun crypto_pwhash_argon2id_opslimit_min(): Long
abstract fun crypto_pwhash_argon2id_opslimit_moderate(): Long
abstract fun crypto_pwhash_argon2id_opslimit_sensitive(): Long
abstract fun crypto_pwhash_argon2id_passwd_max(): Long
abstract fun crypto_pwhash_argon2id_passwd_min(): Long
abstract fun crypto_pwhash_argon2id_saltbytes(): Long
abstract fun crypto_pwhash_argon2id_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2id_str_needs_rehash(str: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2id_str_verify(str: ByteArray, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_argon2id_strbytes(): Long
abstract fun crypto_pwhash_argon2id_strprefix(): String
abstract fun crypto_pwhash_bytes_max(): Long
abstract fun crypto_pwhash_bytes_min(): Long
abstract fun crypto_pwhash_memlimit_interactive(): Long
abstract fun crypto_pwhash_memlimit_max(): Long
abstract fun crypto_pwhash_memlimit_min(): Long
abstract fun crypto_pwhash_memlimit_moderate(): Long
abstract fun crypto_pwhash_memlimit_sensitive(): Long
abstract fun crypto_pwhash_opslimit_interactive(): Long
abstract fun crypto_pwhash_opslimit_max(): Long
abstract fun crypto_pwhash_opslimit_min(): Long
abstract fun crypto_pwhash_opslimit_moderate(): Long
abstract fun crypto_pwhash_opslimit_sensitive(): Long
abstract fun crypto_pwhash_passwd_max(): Long
abstract fun crypto_pwhash_passwd_min(): Long
abstract fun crypto_pwhash_primitive(): String
abstract fun crypto_pwhash_saltbytes(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_bytes_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_bytes_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_ll(passwd: ByteArray, passwdlen: Long, salt: ByteArray, saltlen: Long, N: Long, r: Int, p: Int, buf: ByteArray, buflen: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_interactive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_sensitive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_interactive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_sensitive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_passwd_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_passwd_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_saltbytes(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_str_needs_rehash(str: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_str_verify(str: ByteArray, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_strbytes(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_strprefix(): String
abstract fun crypto_pwhash_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_str_alg(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_str_needs_rehash(str: Pointer, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_str_verify(str: Pointer, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_strbytes(): Long
abstract fun crypto_pwhash_strprefix(): String
abstract fun crypto_scalarmult(q: Pointer, n: Pointer, p: Pointer): Int
abstract fun crypto_scalarmult_base(q: Pointer, n: Pointer): Int
abstract fun crypto_scalarmult_bytes(): Long
abstract fun crypto_scalarmult_curve25519(q: ByteArray, n: ByteArray, p: ByteArray): Int
abstract fun crypto_scalarmult_curve25519_base(q: ByteArray, n: ByteArray): Int
abstract fun crypto_scalarmult_curve25519_bytes(): Long
abstract fun crypto_scalarmult_curve25519_scalarbytes(): Long
abstract fun crypto_scalarmult_ed25519(q: ByteArray, n: ByteArray, p: ByteArray): Int
abstract fun crypto_scalarmult_ed25519_base(q: ByteArray, n: ByteArray): Int
abstract fun crypto_scalarmult_ed25519_bytes(): Long
abstract fun crypto_scalarmult_ed25519_scalarbytes(): Long
abstract fun crypto_scalarmult_primitive(): String
abstract fun crypto_scalarmult_scalarbytes(): Long
abstract fun crypto_secretbox(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_boxzerobytes(): Long
abstract fun crypto_secretbox_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_easy(c: Pointer, m: Pointer, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_easy(c: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_keybytes(): Long
abstract fun crypto_secretbox_keygen(k: Pointer): Unit
abstract fun crypto_secretbox_macbytes(): Long
abstract fun crypto_secretbox_messagebytes_max(): Long
abstract fun crypto_secretbox_noncebytes(): Long
abstract fun crypto_secretbox_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_open_easy(m: Pointer, c: Pointer, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_primitive(): String
abstract fun crypto_secretbox_xchacha20poly1305_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xchacha20poly1305_easy(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xchacha20poly1305_keybytes(): Long
abstract fun crypto_secretbox_xchacha20poly1305_macbytes(): Long
abstract fun crypto_secretbox_xchacha20poly1305_messagebytes_max(): Long
abstract fun crypto_secretbox_xchacha20poly1305_noncebytes(): Long
abstract fun crypto_secretbox_xchacha20poly1305_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xchacha20poly1305_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xsalsa20poly1305(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xsalsa20poly1305_boxzerobytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_keybytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_keygen(k: ByteArray): Unit
abstract fun crypto_secretbox_xsalsa20poly1305_macbytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_messagebytes_max(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_noncebytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xsalsa20poly1305_zerobytes(): Long
abstract fun crypto_secretbox_zerobytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_abytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_headerbytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_init_pull(state: Pointer, : ByteArray, k: Pointer): Int
abstract fun crypto_secretstream_xchacha20poly1305_init_push(state: Pointer, : ByteArray, k: Pointer): Int
abstract fun crypto_secretstream_xchacha20poly1305_keybytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_keygen(k: Pointer): Unit
abstract fun crypto_secretstream_xchacha20poly1305_messagebytes_max(): Long
abstract fun crypto_secretstream_xchacha20poly1305_pull(state: Pointer, m: ByteArray, mlen_p: LongLongByReference, tag_p: ByteByReference, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long): Int
abstract fun crypto_secretstream_xchacha20poly1305_push(state: Pointer, c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, tag: Byte): Int
abstract fun crypto_secretstream_xchacha20poly1305_rekey(state: Pointer): Unit
abstract fun crypto_secretstream_xchacha20poly1305_statebytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_tag_final(): Char
abstract fun crypto_secretstream_xchacha20poly1305_tag_message(): Char
abstract fun crypto_secretstream_xchacha20poly1305_tag_push(): Char
abstract fun crypto_secretstream_xchacha20poly1305_tag_rekey(): Char
abstract fun crypto_shorthash(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_shorthash_bytes(): Long
abstract fun crypto_shorthash_keybytes(): Long
abstract fun crypto_shorthash_keygen(k: ByteArray): Unit
abstract fun crypto_shorthash_primitive(): String
abstract fun crypto_shorthash_siphash24(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_shorthash_siphash24_bytes(): Long
abstract fun crypto_shorthash_siphash24_keybytes(): Long
abstract fun crypto_shorthash_siphashx24(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_shorthash_siphashx24_bytes(): Long
abstract fun crypto_shorthash_siphashx24_keybytes(): Long
abstract fun crypto_sign(sm: ByteArray, @Nullable smlen_p: LongLongByReference?, m: ByteArray, mlen: Long, sk: Pointer): Int
abstract fun crypto_sign_bytes(): Long
abstract fun crypto_sign_detached(sig: ByteArray, @Nullable siglen_p: LongLongByReference?, m: ByteArray, mlen: Long, sk: Pointer): Int
abstract fun crypto_sign_detached(sig: Pointer, @Nullable siglen_p: LongLongByReference?, m: Pointer, mlen: Long, sk: Pointer): Int
abstract fun crypto_sign_ed25519(sm: ByteArray, smlen_p: LongLongByReference, m: ByteArray, mlen: Long, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_bytes(): Long
abstract fun crypto_sign_ed25519_detached(sig: ByteArray, siglen_p: LongLongByReference, m: ByteArray, mlen: Long, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_keypair(pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_messagebytes_max(): Long
abstract fun crypto_sign_ed25519_open(m: ByteArray, mlen_p: LongLongByReference, sm: ByteArray, smlen: Long, pk: ByteArray): Int
abstract fun crypto_sign_ed25519_pk_to_curve25519(curve25519_pk: Pointer, ed25519_pk: Pointer): Int
abstract fun crypto_sign_ed25519_publickeybytes(): Long
abstract fun crypto_sign_ed25519_secretkeybytes(): Long
abstract fun crypto_sign_ed25519_seed_keypair(pk: ByteArray, sk: ByteArray, seed: ByteArray): Int
abstract fun crypto_sign_ed25519_seedbytes(): Long
abstract fun crypto_sign_ed25519_sk_to_curve25519(curve25519_sk: Pointer, ed25519_sk: Pointer): Int
abstract fun crypto_sign_ed25519_sk_to_pk(pk: Pointer, sk: Pointer): Int
abstract fun crypto_sign_ed25519_sk_to_seed(seed: ByteArray, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_verify_detached(sig: ByteArray, m: ByteArray, mlen: Long, pk: ByteArray): Int
abstract fun crypto_sign_ed25519ph_final_create(state: Pointer, sig: ByteArray, siglen_p: LongLongByReference, sk: ByteArray): Int
abstract fun crypto_sign_ed25519ph_final_verify(state: Pointer, sig: ByteArray, pk: ByteArray): Int
abstract fun crypto_sign_ed25519ph_init(state: Pointer): Int
abstract fun crypto_sign_ed25519ph_statebytes(): Long
abstract fun crypto_sign_ed25519ph_update(state: Pointer, m: ByteArray, mlen: Long): Int
abstract fun crypto_sign_final_create(state: Pointer, sig: ByteArray, siglen_p: LongLongByReference, sk: ByteArray): Int
abstract fun crypto_sign_final_verify(state: Pointer, sig: ByteArray, pk: ByteArray): Int
abstract fun crypto_sign_init(state: Pointer): Int
abstract fun crypto_sign_keypair(pk: Pointer, sk: Pointer): Int
abstract fun crypto_sign_messagebytes_max(): Long
abstract fun crypto_sign_open(m: ByteArray, mlen_p: LongLongByReference, sm: ByteArray, smlen: Long, pk: Pointer): Int
abstract fun crypto_sign_primitive(): String
abstract fun crypto_sign_publickeybytes(): Long
abstract fun crypto_sign_secretkeybytes(): Long
abstract fun crypto_sign_seed_keypair(pk: Pointer, sk: Pointer, seed: Pointer): Int
abstract fun crypto_sign_seedbytes(): Long
abstract fun crypto_sign_statebytes(): Long
abstract fun crypto_sign_update(state: Pointer, m: ByteArray, mlen: Long): Int
abstract fun crypto_sign_verify_detached(sig: Pointer, m: Pointer, mlen: Long, pk: Pointer): Int
abstract fun crypto_sign_verify_detached(sig: ByteArray, m: ByteArray, mlen: Long, pk: Pointer): Int
abstract fun crypto_stream(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_ietf(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_ietf_keybytes(): Long
abstract fun crypto_stream_chacha20_ietf_keygen(k: ByteArray): Unit
abstract fun crypto_stream_chacha20_ietf_messagebytes_max(): Long
abstract fun crypto_stream_chacha20_ietf_noncebytes(): Long
abstract fun crypto_stream_chacha20_ietf_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_ietf_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Int, k: ByteArray): Int
abstract fun crypto_stream_chacha20_keybytes(): Long
abstract fun crypto_stream_chacha20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_chacha20_messagebytes_max(): Long
abstract fun crypto_stream_chacha20_noncebytes(): Long
abstract fun crypto_stream_chacha20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_stream_keybytes(): Long
abstract fun crypto_stream_keygen(k: ByteArray): Unit
abstract fun crypto_stream_messagebytes_max(): Long
abstract fun crypto_stream_noncebytes(): Long
abstract fun crypto_stream_primitive(): String
abstract fun crypto_stream_salsa20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa2012(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa2012_keybytes(): Long
abstract fun crypto_stream_salsa2012_keygen(k: ByteArray): Unit
abstract fun crypto_stream_salsa2012_messagebytes_max(): Long
abstract fun crypto_stream_salsa2012_noncebytes(): Long
abstract fun crypto_stream_salsa2012_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa208(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa208_keybytes(): Long
abstract fun crypto_stream_salsa208_keygen(k: ByteArray): Unit
abstract fun crypto_stream_salsa208_messagebytes_max(): Long
abstract fun crypto_stream_salsa208_noncebytes(): Long
abstract fun crypto_stream_salsa208_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa20_keybytes(): Long
abstract fun crypto_stream_salsa20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_salsa20_messagebytes_max(): Long
abstract fun crypto_stream_salsa20_noncebytes(): Long
abstract fun crypto_stream_salsa20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_stream_xchacha20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xchacha20_keybytes(): Long
abstract fun crypto_stream_xchacha20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_xchacha20_messagebytes_max(): Long
abstract fun crypto_stream_xchacha20_noncebytes(): Long
abstract fun crypto_stream_xchacha20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xchacha20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_stream_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xsalsa20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xsalsa20_keybytes(): Long
abstract fun crypto_stream_xsalsa20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_xsalsa20_messagebytes_max(): Long
abstract fun crypto_stream_xsalsa20_noncebytes(): Long
abstract fun crypto_stream_xsalsa20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xsalsa20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_verify_16(x: ByteArray, y: ByteArray): Int
abstract fun crypto_verify_16_bytes(): Long
abstract fun crypto_verify_32(x: ByteArray, y: ByteArray): Int
abstract fun crypto_verify_32_bytes(): Long
abstract fun crypto_verify_64(x: ByteArray, y: ByteArray): Int
abstract fun crypto_verify_64_bytes(): Long
abstract fun implementation_name(): String
abstract fun random(): Int
abstract fun randombytes(buf: ByteArray, buf_len: Long): Unit
abstract fun randombytes_buf(buf: Pointer, size: Long): Unit
abstract fun randombytes_buf_deterministic(buf: ByteArray, size: Long, seed: ByteArray): Unit
abstract fun randombytes_close(): Int
abstract fun randombytes_implementation_name(): String
abstract fun randombytes_random(): Int
abstract fun randombytes_seedbytes(): Long
abstract fun randombytes_set_implementation(impl: Pointer): Int
abstract fun randombytes_stir(): Unit
abstract fun randombytes_uniform(upper_bound: Int): Int
abstract fun sodium_add(a: Pointer, b: Pointer, len: Long): Unit
abstract fun sodium_allocarray(count: Long, size: Long): Pointer
abstract fun sodium_base642bin(bin: ByteArray, bin_maxlen: Long, b64: ByteArray, b64_len: Long, ignore: ByteArray, bin_len: LongLongByReference, b64_end: Pointer, variant: Int): Int
abstract fun sodium_base64_encoded_len(bin_len: Long, variant: Int): Long
abstract fun sodium_compare(b1_: Pointer, b2_: Pointer, len: Long): Int
abstract fun sodium_free(ptr: Pointer): Unit
abstract fun sodium_hex2bin(bin: ByteArray, bin_maxlen: Long, hex: ByteArray, hex_len: Long, ignore: ByteArray, bin_len: LongLongByReference, hex_end: Pointer): Int
abstract fun sodium_increment(n: Pointer, nlen: Long): Unit
abstract fun sodium_init(): Int
abstract fun sodium_is_zero(n: Pointer, nlen: Long): Int
abstract fun sodium_library_minimal(): Int
abstract fun sodium_library_version_major(): Int
abstract fun sodium_library_version_minor(): Int
abstract fun sodium_malloc(size: Long): Pointer
abstract fun sodium_memcmp(b1_: Pointer, b2_: Pointer, len: Long): Int
abstract fun sodium_memzero(pnt: Pointer, len: Long): Unit
abstract fun sodium_misuse(): Unit
abstract fun sodium_mlock(addr: Pointer, len: Long): Int
abstract fun sodium_mprotect_noaccess(ptr: Pointer): Int
abstract fun sodium_mprotect_readonly(ptr: Pointer): Int
abstract fun sodium_mprotect_readwrite(ptr: Pointer): Int
abstract fun sodium_munlock(addr: Pointer, len: Long): Int
abstract fun sodium_pad(padded_buflen_p: LongLongByReference, buf: ByteArray, unpadded_buflen: Long, blocksize: Long, max_buflen: Long): Int
abstract fun sodium_runtime_has_aesni(): Int
abstract fun sodium_runtime_has_avx(): Int
abstract fun sodium_runtime_has_avx2(): Int
abstract fun sodium_runtime_has_avx512f(): Int
abstract fun sodium_runtime_has_neon(): Int
abstract fun sodium_runtime_has_pclmul(): Int
abstract fun sodium_runtime_has_rdrand(): Int
abstract fun sodium_runtime_has_sse2(): Int
abstract fun sodium_runtime_has_sse3(): Int
abstract fun sodium_runtime_has_sse41(): Int
abstract fun sodium_runtime_has_ssse3(): Int
abstract fun sodium_set_misuse_handler(handler: Pointer): Int
abstract fun sodium_stackzero(len: Long): Unit
abstract fun sodium_unpad(unpadded_buflen_p: LongLongByReference, buf: ByteArray, padded_buflen: Long, blocksize: Long): Int
abstract fun sodium_version_string(): String
abstract fun stir(): Unit
abstract fun uniform(upper_bound: Int): Int
interface LightClient
class LocalIdentity
class Log
class LogsBloomFilter
@Target([AnnotationTarget.VALUE_PARAMETER]) class LuceneIndex
@Target([AnnotationTarget.VALUE_PARAMETER]) class LuceneIndexWriter
open class LuceneIndexWriterExtension : ParameterResolver, AfterAllCallback
class MapDBKeyValueStore : KeyValueStore
class MapKeyValueStore : KeyValueStore
open class MemoryWireConnectionsRepository : WireConnectionRepository
class MerklePatriciaTrie<V> : MerkleTrie<Bytes, V>
interface MerkleStorage
class MerkleStorageException : RuntimeException
interface MerkleTrie<in K, V>
class Message
interface MessageHashing
interface MessageListener
interface MessageSender
interface MessageValidator
interface Multiplexer
open class MutableByteBufferWrappingBytes : ByteBufferWrappingBytes, MutableBytes
interface MutableBytes : Bytes
Module Contents
static val EMPTY: MutableBytes
open fun clear(): Unit
open static fun create(size: Int): MutableBytes
open fun decrement(): MutableBytes
open fun fill(b: Byte): Unit
open fun increment(): MutableBytes
abstract fun mutableSlice(i: Int, length: Int): MutableBytes
open static fun of(vararg bytes: Byte): MutableBytes
open static fun of(vararg bytes: Int): MutableBytes
abstract fun set(i: Int, b: Byte): Unit
open fun setInt(i: Int, value: Int): Unit
open fun setLong(i: Int, value: Long): Unit
open static fun wrap(value: ByteArray): MutableBytes
open static fun wrap(value: ByteArray, offset: Int, length: Int): MutableBytes
open static fun wrapBuffer(buffer: Buffer): MutableBytes
open static fun wrapBuffer(buffer: Buffer, offset: Int, size: Int): MutableBytes
open static fun wrapByteBuf(byteBuf: ByteBuf): MutableBytes
open static fun wrapByteBuf(byteBuf: ByteBuf, offset: Int, size: Int): MutableBytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer): MutableBytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer, offset: Int, size: Int): MutableBytes
interface MutableBytes32 : MutableBytes, Bytes32
interface MutableBytes48 : MutableBytes, Bytes48
class NoConfigurationPropertyException : RuntimeException
class PasswordHash
Module Contents
PasswordHash()
class Algorithm
class Salt
class VerificationResult
static fun checkHash(hash: String, password: String): VerificationResult
static fun checkHash(hash: String, password: String, opsLimit: Long, memLimit: Long): VerificationResult
static fun checkHashForInteractive(hash: String, password: String): VerificationResult
static fun checkHashForSensitive(hash: String, password: String): VerificationResult
static fun hash(password: String, length: Int, salt: Salt): Bytes
static fun hash(password: Bytes, length: Int, salt: Salt): Bytes
static fun hash(password: ByteArray, length: Int, salt: Salt): ByteArray
static fun hash(password: String, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hash(password: Bytes, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hash(password: ByteArray, length: Int, salt: Salt, algorithm: Algorithm): ByteArray
static fun hash(password: String, length: Int, salt: Salt, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes
static fun hash(password: Bytes, length: Int, salt: Salt, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes
static fun hash(password: ByteArray, length: Int, salt: Salt, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray
static fun hash(password: String): String
static fun hash(password: String, opsLimit: Long, memLimit: Long): String
static fun hashInteractive(password: String, length: Int, salt: Salt): Bytes
static fun hashInteractive(password: Bytes, length: Int, salt: Salt): Bytes
static fun hashInteractive(password: ByteArray, length: Int, salt: Salt): ByteArray
static fun hashInteractive(password: String, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashInteractive(password: Bytes, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashInteractive(password: ByteArray, length: Int, salt: Salt, algorithm: Algorithm): ByteArray
static fun hashInteractive(password: String): String
static fun hashSensitive(password: String, length: Int, salt: Salt): Bytes
static fun hashSensitive(password: Bytes, length: Int, salt: Salt): Bytes
static fun hashSensitive(password: ByteArray, length: Int, salt: Salt): ByteArray
static fun hashSensitive(password: String, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashSensitive(password: Bytes, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashSensitive(password: ByteArray, length: Int, salt: Salt, algorithm: Algorithm): ByteArray
static fun hashSensitive(password: String): String
static fun interactiveMemLimit(): Long
static fun interactiveOpsLimit(): Long
static fun maxHashLength(): Int
static fun maxMemLimit(): Long
static fun maxOpsLimit(): Long
static fun minHashLength(): Int
static fun minMemLimit(): Long
static fun minOpsLimit(): Long
static fun moderateMemLimit(): Long
static fun moderateOpsLimit(): Long
static fun needsRehash(hash: String): Boolean
static fun needsRehash(hash: String, opsLimit: Long, memLimit: Long): Boolean
static fun needsRehashForInteractive(hash: String): Boolean
static fun needsRehashForSensitive(hash: String): Boolean
static fun sensitiveMemLimit(): Long
static fun sensitiveOpsLimit(): Long
static fun verify(hash: String, password: String): Boolean
interface Peer
interface Peer
interface PeerPruning
interface PeerRepository
interface PeerRepository
interface PeerRoutingTable : Set<Peer>
class ProgPoW
interface PropertyValidator<T : Any>
class PublicKey
class RLP
Module Contents
static fun <T : Any> decode(source: Bytes, fn: Function<RLPReader, T>): T
static fun <T : Any> decode(source: Bytes, lenient: Boolean, fn: Function<RLPReader, T>): T
static fun decodeBigInteger(source: Bytes): BigInteger
static fun decodeBigInteger(source: Bytes, lenient: Boolean): BigInteger
static fun decodeInt(source: Bytes): Int
static fun decodeInt(source: Bytes, lenient: Boolean): Int
static fun <T : Any> decodeList(source: Bytes, fn: Function<RLPReader, T>): T
static fun <T : Any> decodeList(source: Bytes, lenient: Boolean, fn: Function<RLPReader, T>): T
static fun decodeLong(source: Bytes): Long
static fun decodeLong(source: Bytes, lenient: Boolean): Long
static fun decodeString(source: Bytes): String
static fun decodeString(source: Bytes, lenient: Boolean): String
static fun decodeToList(source: Bytes, fn: BiConsumer<RLPReader, MutableList<Any>>): MutableList<Any>
static fun decodeToList(source: Bytes, lenient: Boolean, fn: BiConsumer<RLPReader, MutableList<Any>>): MutableList<Any>
static fun <T : Any> decodeToList(source: Bytes, fn: Function<RLPReader, T>): MutableList<T>
static fun <T : Any> decodeToList(source: Bytes, lenient: Boolean, fn: Function<RLPReader, T>): MutableList<T>
static fun decodeValue(source: Bytes): Bytes
static fun decodeValue(source: Bytes, lenient: Boolean): Bytes
static fun encode(fn: Consumer<RLPWriter>): Bytes
static fun encodeBigInteger(value: BigInteger): Bytes
static fun encodeByteArray(value: ByteArray): Bytes
static fun encodeInt(value: Int): Bytes
static fun encodeList(fn: Consumer<RLPWriter>): Bytes
static fun <T : Any> encodeList(elements: MutableList<T>, fn: BiConsumer<RLPWriter, T>): Bytes
static fun <T : ByteBuffer> encodeListTo(buffer: T, fn: Consumer<RLPWriter>): T
static fun encodeLong(value: Long): Bytes
static fun encodeString(str: String): Bytes
static fun <T : ByteBuffer> encodeTo(buffer: T, fn: Consumer<RLPWriter>): T
static fun encodeValue(value: Bytes): Bytes
static fun isList(value: Bytes): Boolean
open class RLPException : RuntimeException
interface RLPReader
interface RLPWriter
class RLPxConnection
class RLPxConnectionFactory
Module Contents
RLPxConnectionFactory()
static fun createConnection(initiator: Boolean, initiatorMessage: Bytes, responderMessage: Bytes, ourEphemeralPrivateKey: SecretKey, peerEphemeralPublicKey: PublicKey, initiatorNonce: Bytes32, responderNonce: Bytes32, ourPublicKey: PublicKey, peerPublicKey: PublicKey): RLPxConnection
static fun createHandshake(keyPair: KeyPair, remotePublicKey: PublicKey, initAndResponse: Function<Bytes, AsyncResult<Bytes>>): AsyncResult<RLPxConnection>
static fun generateRandomBytes32(): Bytes32
static fun init(keyPair: KeyPair, remotePublicKey: PublicKey, ephemeralKeyPair: KeyPair, initiatorNonce: Bytes32): Bytes
static fun messageSize(msgBytes: Bytes): Int
static fun readResponse(response: Bytes, privateKey: SecretKey): HandshakeMessage
static fun respondToHandshake(initiatorMessageBytes: Bytes, keyPair: KeyPair, responseHandler: Consumer<Bytes>): RLPxConnection
class RLPxMessage
interface RLPxService
open class RPCAsyncRequest
class RPCCodec
Module Contents
RPCCodec()
static fun encodeRequest(body: String, vararg flags: RPCFlag): Bytes
static fun encodeRequest(body: Bytes, vararg flags: RPCFlag): Bytes
static fun encodeRequest(body: Bytes, requestNumber: Int, vararg flags: RPCFlag): Bytes
static fun encodeRequest(body: Bytes, requestNumber: Int, flags: Byte): Bytes
static fun encodeResponse(body: Bytes, requestNumber: Int, flagByte: Byte): Bytes
static fun encodeResponse(body: Bytes, requestNumber: Int, flagByte: Byte, vararg flags: RPCFlag): Bytes
static fun encodeResponse(body: Bytes, requestNumber: Int, vararg flags: RPCFlag): Bytes
static fun encodeStreamEndRequest(requestNumber: Int): Bytes
open class RPCErrorBody
interface RPCFlag
open class RPCFunction
open class RPCHandler : Multiplexer, ClientHandler
class RPCMessage
open class RPCRequestBody
class RPCRequestFailedException : RuntimeException
class RPCRequestType
open class RPCResponse
open class RPCStreamRequest
interface ReadableCoroutineByteChannel
class RedisKeyValueStore : KeyValueStore
@Target([AnnotationTarget.VALUE_PARAMETER]) class RedisPort
class RedisServerExtension : ParameterResolver, AfterAllCallback
class Relayer : CoroutineScope
class Resources
class RocksDBKeyValueStore : KeyValueStore
class SECP256K1
Module Contents
class KeyPair
class Parameters
class PublicKey
class SecretKey : Destroyable
class Signature
static fun calculateKeyAgreement(privKey: SecretKey, theirPubKey: PublicKey): Bytes32
static fun sign(data: ByteArray, keyPair: KeyPair): Signature
static fun sign(data: Bytes, keyPair: KeyPair): Signature
static fun signHashed(hash: ByteArray, keyPair: KeyPair): Signature
static fun signHashed(hash: Bytes32, keyPair: KeyPair): Signature
static fun verify(data: ByteArray, signature: Signature, publicKey: PublicKey): Boolean
static fun verify(data: Bytes, signature: Signature, publicKey: PublicKey): Boolean
static fun verifyHashed(hash: Bytes32, signature: Signature, publicKey: PublicKey): Boolean
static fun verifyHashed(hash: ByteArray, signature: Signature, publicKey: PublicKey): Boolean
open class SHA256Hash
class SQLKeyValueStore : KeyValueStore
class SSZ
Module Contents
static fun <T : Any> decode(source: Bytes, fn: Function<SSZReader, T>): T
static fun decodeAddress(source: Bytes): Bytes
static fun decodeAddressList(source: Bytes): MutableList<Bytes>
static fun decodeBigInteger(source: Bytes, bitLength: Int): BigInteger
static fun decodeBigIntegerList(source: Bytes, bitLength: Int): MutableList<BigInteger>
static fun decodeBoolean(source: Bytes): Boolean
static fun decodeBooleanList(source: Bytes): MutableList<Boolean>
static fun decodeByteArrayList(source: Bytes): MutableList<ByteArray>
static fun decodeByteArrayList(source: Bytes, limit: Int): MutableList<ByteArray>
static fun decodeBytes(source: Bytes): Bytes
static fun decodeBytes(source: Bytes, limit: Int): Bytes
static fun decodeBytesList(source: Bytes): MutableList<Bytes>
static fun decodeBytesList(source: Bytes, limit: Int): MutableList<Bytes>
static fun decodeHash(source: Bytes, hashLength: Int): Bytes
static fun decodeHashList(source: Bytes, hashLength: Int): MutableList<Bytes>
static fun decodeInt(source: Bytes, bitLength: Int): Int
static fun decodeInt16(source: Bytes): Int
static fun decodeInt16List(source: Bytes): MutableList<Int>
static fun decodeInt32(source: Bytes): Int
static fun decodeInt32List(source: Bytes): MutableList<Int>
static fun decodeInt64(source: Bytes): Long
static fun decodeInt64List(source: Bytes): MutableList<Long>
static fun decodeInt8(source: Bytes): Int
static fun decodeInt8List(source: Bytes): MutableList<Int>
static fun decodeIntList(source: Bytes, bitLength: Int): MutableList<Int>
static fun decodeLong(source: Bytes, bitLength: Int): Long
static fun decodeLongIntList(source: Bytes, bitLength: Int): MutableList<Long>
static fun decodeString(source: Bytes): String
static fun decodeString(source: Bytes, limit: Int): String
static fun decodeStringList(source: Bytes): MutableList<String>
static fun decodeStringList(source: Bytes, limit: Int): MutableList<String>
static fun decodeUInt(source: Bytes, bitLength: Int): Int
static fun decodeUInt16(source: Bytes): Int
static fun decodeUInt16List(source: Bytes): MutableList<Int>
static fun decodeUInt256(source: Bytes): UInt256
static fun decodeUInt256List(source: Bytes): MutableList<UInt256>
static fun decodeUInt32(source: Bytes): Long
static fun decodeUInt32List(source: Bytes): MutableList<Long>
static fun decodeUInt384(source: Bytes): UInt384
static fun decodeUInt384List(source: Bytes): MutableList<UInt384>
static fun decodeUInt64(source: Bytes): Long
static fun decodeUInt64List(source: Bytes): MutableList<Long>
static fun decodeUInt8(source: Bytes): Int
static fun decodeUInt8List(source: Bytes): MutableList<Int>
static fun decodeUIntList(source: Bytes, bitLength: Int): MutableList<Int>
static fun decodeULong(source: Bytes, bitLength: Int): Long
static fun decodeULongIntList(source: Bytes, bitLength: Int): MutableList<Long>
static fun decodeUnsignedBigInteger(source: Bytes, bitLength: Int): BigInteger
static fun decodeUnsignedBigIntegerList(source: Bytes, bitLength: Int): MutableList<BigInteger>
static fun encode(fn: Consumer<SSZWriter>): Bytes
static fun encodeAddress(address: Bytes): Bytes
static fun encodeAddressList(vararg elements: Bytes): Bytes
static fun encodeAddressList(elements: MutableList<out Bytes>): Bytes
static fun encodeBigInteger(value: BigInteger, bitLength: Int): Bytes
static fun encodeBigIntegerList(bitLength: Int, vararg elements: BigInteger): Bytes
static fun encodeBigIntegerList(bitLength: Int, elements: MutableList<BigInteger>): Bytes
static fun encodeBigIntegerToByteArray(value: BigInteger, bitLength: Int): ByteArray
static fun encodeBoolean(value: Boolean): Bytes
static fun encodeBooleanList(vararg elements: Boolean): Bytes
static fun encodeBooleanList(elements: MutableList<Boolean>): Bytes
static fun encodeByteArray(value: ByteArray): Bytes
static fun encodeBytes(value: Bytes): Bytes
static fun encodeBytesList(vararg elements: Bytes): Bytes
static fun encodeBytesList(elements: MutableList<out Bytes>): Bytes
static fun encodeHash(hash: Bytes): Bytes
static fun encodeHashList(vararg elements: Bytes): Bytes
static fun encodeHashList(elements: MutableList<out Bytes>): Bytes
static fun encodeInt(value: Int, bitLength: Int): Bytes
static fun encodeInt16(value: Int): Bytes
static fun encodeInt16List(vararg elements: Int): Bytes
static fun encodeInt16List(elements: MutableList<Int>): Bytes
static fun encodeInt32(value: Int): Bytes
static fun encodeInt32List(vararg elements: Int): Bytes
static fun encodeInt32List(elements: MutableList<Int>): Bytes
static fun encodeInt64(value: Long): Bytes
static fun encodeInt64List(vararg elements: Long): Bytes
static fun encodeInt64List(elements: MutableList<Long>): Bytes
static fun encodeInt8(value: Int): Bytes
static fun encodeInt8List(vararg elements: Int): Bytes
static fun encodeInt8List(elements: MutableList<Int>): Bytes
static fun encodeIntList(bitLength: Int, vararg elements: Int): Bytes
static fun encodeIntList(bitLength: Int, elements: MutableList<Int>): Bytes
static fun encodeLong(value: Long, bitLength: Int): Bytes
static fun encodeLongIntList(bitLength: Int, vararg elements: Long): Bytes
static fun encodeLongIntList(bitLength: Int, elements: MutableList<Long>): Bytes
static fun encodeString(str: String): Bytes
static fun encodeStringList(vararg elements: String): Bytes
static fun encodeStringList(elements: MutableList<String>): Bytes
static fun <T : ByteBuffer> encodeTo(buffer: T, fn: Consumer<SSZWriter>): T
static fun encodeUBigInteger(value: BigInteger, bitLength: Int): Bytes
static fun encodeUBigIntegerToByteArray(value: BigInteger, bitLength: Int): ByteArray
static fun encodeUInt(value: Int, bitLength: Int): Bytes
static fun encodeUInt16(value: Int): Bytes
static fun encodeUInt16List(vararg elements: Int): Bytes
static fun encodeUInt16List(elements: MutableList<Int>): Bytes
static fun encodeUInt256(value: UInt256): Bytes
static fun encodeUInt256List(vararg elements: UInt256): Bytes
static fun encodeUInt256List(elements: MutableList<UInt256>): Bytes
static fun encodeUInt32(value: Long): Bytes
static fun encodeUInt32List(vararg elements: Long): Bytes
static fun encodeUInt32List(elements: MutableList<Long>): Bytes
static fun encodeUInt384(value: UInt384): Bytes
static fun encodeUInt384List(vararg elements: UInt384): Bytes
static fun encodeUInt384List(elements: MutableList<UInt384>): Bytes
static fun encodeUInt64(value: Long): Bytes
static fun encodeUInt64List(vararg elements: Long): Bytes
static fun encodeUInt64List(elements: MutableList<Long>): Bytes
static fun encodeUInt8(value: Int): Bytes
static fun encodeUInt8List(vararg elements: Int): Bytes
static fun encodeUInt8List(elements: MutableList<Int>): Bytes
static fun encodeUIntList(bitLength: Int, vararg elements: Int): Bytes
static fun encodeUIntList(bitLength: Int, elements: MutableList<Int>): Bytes
static fun encodeULong(value: Long, bitLength: Int): Bytes
static fun encodeULongIntList(bitLength: Int, vararg elements: Long): Bytes
static fun encodeULongIntList(bitLength: Int, elements: MutableList<Long>): Bytes
static fun hashTreeRoot(vararg bytes: Bytes): Bytes32
open class SSZException : RuntimeException
interface SSZReader
interface SSZWriter
Module Contents
open fun writeAddress(address: Bytes): Unit
open fun writeAddressList(vararg elements: Bytes): Unit
open fun writeAddressList(elements: MutableList<out Bytes>): Unit
open fun writeBigInteger(value: BigInteger, bitLength: Int): Unit
open fun writeBigIntegerList(bitLength: Int, vararg elements: BigInteger): Unit
open fun writeBigIntegerList(bitLength: Int, elements: MutableList<BigInteger>): Unit
open fun writeBoolean(value: Boolean): Unit
open fun writeBooleanList(vararg elements: Boolean): Unit
open fun writeBooleanList(elements: MutableList<Boolean>): Unit
open fun writeBytes(value: Bytes): Unit
open fun writeBytes(value: ByteArray): Unit
open fun writeBytesList(vararg elements: Bytes): Unit
open fun writeBytesList(elements: MutableList<out Bytes>): Unit
open fun writeFixedBytes(byteLength: Int, value: Bytes): Unit
open fun writeFixedBytesList(byteLength: Int, elements: MutableList<out Bytes>): Unit
open fun writeFixedBytesVector(elements: MutableList<out Bytes>): Unit
open fun writeHash(hash: Bytes): Unit
open fun writeHashList(vararg elements: Bytes): Unit
open fun writeHashList(elements: MutableList<out Bytes>): Unit
open fun writeInt(value: Int, bitLength: Int): Unit
open fun writeInt16(value: Int): Unit
open fun writeInt16List(vararg elements: Int): Unit
open fun writeInt16List(elements: MutableList<Int>): Unit
open fun writeInt32(value: Int): Unit
open fun writeInt32List(vararg elements: Int): Unit
open fun writeInt32List(elements: MutableList<Int>): Unit
open fun writeInt64(value: Long): Unit
open fun writeInt64List(vararg elements: Long): Unit
open fun writeInt64List(elements: MutableList<Long>): Unit
open fun writeInt8(value: Int): Unit
open fun writeInt8List(vararg elements: Int): Unit
open fun writeInt8List(elements: MutableList<Int>): Unit
open fun writeIntList(bitLength: Int, vararg elements: Int): Unit
open fun writeIntList(bitLength: Int, elements: MutableList<Int>): Unit
open fun writeLong(value: Long, bitLength: Int): Unit
open fun writeLongIntList(bitLength: Int, vararg elements: Long): Unit
open fun writeLongIntList(bitLength: Int, elements: MutableList<Long>): Unit
abstract fun writeSSZ(value: Bytes): Unit
open fun writeSSZ(value: ByteArray): Unit
open fun writeString(str: String): Unit
open fun writeStringList(vararg elements: String): Unit
open fun writeStringList(elements: MutableList<String>): Unit
open fun writeUBigInteger(value: BigInteger, bitLength: Int): Unit
open fun writeUInt(value: Int, bitLength: Int): Unit
open fun writeUInt16(value: Int): Unit
open fun writeUInt16List(vararg elements: Int): Unit
open fun writeUInt16List(elements: MutableList<Int>): Unit
open fun writeUInt256(value: UInt256): Unit
open fun writeUInt256List(vararg elements: UInt256): Unit
open fun writeUInt256List(elements: MutableList<UInt256>): Unit
open fun writeUInt32(value: Long): Unit
open fun writeUInt32List(vararg elements: Long): Unit
open fun writeUInt32List(elements: MutableList<Long>): Unit
open fun writeUInt384(value: UInt384): Unit
open fun writeUInt384List(elements: MutableList<UInt384>): Unit
open fun writeUInt384List(vararg elements: UInt384): Unit
open fun writeUInt64(value: Long): Unit
open fun writeUInt64List(vararg elements: Long): Unit
open fun writeUInt64List(elements: MutableList<Long>): Unit
open fun writeUInt8(value: Int): Unit
open fun writeUInt8List(vararg elements: Int): Unit
open fun writeUInt8List(elements: MutableList<Int>): Unit
open fun writeUIntList(bitLength: Int, vararg elements: Int): Unit
open fun writeUIntList(bitLength: Int, elements: MutableList<Int>): Unit
open fun writeULong(value: Long, bitLength: Int): Unit
open fun writeULongIntList(bitLength: Int, vararg elements: Long): Unit
open fun writeULongIntList(bitLength: Int, elements: MutableList<Long>): Unit
open fun writeVector(elements: MutableList<out Bytes>): Unit
interface ScatteringCoroutineByteChannel : ReadableCoroutineByteChannel
class Schema
class SchemaBuilder
Module Contents
fun addBoolean(key: String, @Nullable defaultValue: Boolean?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Boolean>?): SchemaBuilder
fun addDefault(key: String, value: Any): SchemaBuilder
fun addDouble(key: String, @Nullable defaultValue: Double?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Double>?): SchemaBuilder
fun addInteger(key: String, @Nullable defaultValue: Int?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Int>?): SchemaBuilder
fun addListOfBoolean(key: String, @Nullable defaultValue: MutableList<Boolean>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Boolean>>?): SchemaBuilder
fun addListOfDouble(key: String, @Nullable defaultValue: MutableList<Double>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Double>>?): SchemaBuilder
fun addListOfInteger(key: String, @Nullable defaultValue: MutableList<Int>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Int>>?): SchemaBuilder
fun addListOfLong(key: String, @Nullable defaultValue: MutableList<Long>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Long>>?): SchemaBuilder
fun addListOfMap(key: String, @Nullable defaultValue: MutableList<MutableMap<String, Any>>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<MutableMap<String, Any>>>?): SchemaBuilder
fun addListOfString(key: String, @Nullable defaultValue: MutableList<String>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<String>>?): SchemaBuilder
fun addLong(key: String, @Nullable defaultValue: Long?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Long>?): SchemaBuilder
fun addString(key: String, @Nullable defaultValue: String?, @Nullable description: String?, @Nullable validator: PropertyValidator<in String>?): SchemaBuilder
static fun create(): SchemaBuilder
fun documentProperty(key: String, description: String): SchemaBuilder
fun toSchema(): Schema
fun validateConfiguration(validator: ConfigurationValidator): SchemaBuilder
fun validateProperty(key: String, validator: PropertyValidator<Any>): SchemaBuilder
open class ScuttlebuttLocalDiscoveryService
interface ScuttlebuttStreamHandler
class SecretBox
Module Contents
class Key : Destroyable
class Nonce : Destroyable
@Nullable static fun decrypt(cipherText: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: Allocated, key: Key, nonce: Nonce): Allocated?
@Nullable static fun decrypt(cipherText: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, password: String): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, password: String): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, password: String): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, password: String): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptInteractive(cipherText: Bytes, password: String): Bytes?
@Nullable static fun decryptInteractive(cipherText: ByteArray, password: String): ByteArray?
@Nullable static fun decryptInteractive(cipherText: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptInteractive(cipherText: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptInteractiveDetached(cipherText: Bytes, mac: Bytes, password: String): Bytes?
@Nullable static fun decryptInteractiveDetached(cipherText: ByteArray, mac: ByteArray, password: String): ByteArray?
@Nullable static fun decryptInteractiveDetached(cipherText: Bytes, mac: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptInteractiveDetached(cipherText: ByteArray, mac: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptSensitive(cipherText: Bytes, password: String): Bytes?
@Nullable static fun decryptSensitive(cipherText: ByteArray, password: String): ByteArray?
@Nullable static fun decryptSensitive(cipherText: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptSensitive(cipherText: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptSensitiveDetached(cipherText: Bytes, mac: Bytes, password: String): Bytes?
@Nullable static fun decryptSensitiveDetached(cipherText: ByteArray, mac: ByteArray, password: String): ByteArray?
@Nullable static fun decryptSensitiveDetached(cipherText: Bytes, mac: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptSensitiveDetached(cipherText: ByteArray, mac: ByteArray, password: String, algorithm: Algorithm): ByteArray?
static fun encrypt(message: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: Allocated, key: Key, nonce: Nonce): Allocated
static fun encrypt(message: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, password: String): Bytes
static fun encrypt(message: ByteArray, password: String): ByteArray
static fun encrypt(message: Bytes, password: String, algorithm: Algorithm): Bytes
static fun encrypt(message: ByteArray, password: String, algorithm: Algorithm): ByteArray
static fun encrypt(message: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes
static fun encrypt(message: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray
static fun encryptDetached(message: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, password: String): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, password: String): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptInteractive(message: Bytes, password: String): Bytes
static fun encryptInteractive(message: ByteArray, password: String): ByteArray
static fun encryptInteractive(message: Bytes, password: String, algorithm: Algorithm): Bytes
static fun encryptInteractive(message: ByteArray, password: String, algorithm: Algorithm): ByteArray
static fun encryptInteractiveDetached(message: Bytes, password: String): DetachedEncryptionResult
static fun encryptInteractiveDetached(message: ByteArray, password: String): DetachedEncryptionResult
static fun encryptInteractiveDetached(message: Bytes, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptInteractiveDetached(message: ByteArray, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptSensitive(message: Bytes, password: String): Bytes
static fun encryptSensitive(message: ByteArray, password: String): ByteArray
static fun encryptSensitive(message: Bytes, password: String, algorithm: Algorithm): Bytes
static fun encryptSensitive(message: ByteArray, password: String, algorithm: Algorithm): ByteArray
static fun encryptSensitiveDetached(message: Bytes, password: String): DetachedEncryptionResult
static fun encryptSensitiveDetached(message: ByteArray, password: String): DetachedEncryptionResult
static fun encryptSensitiveDetached(message: Bytes, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptSensitiveDetached(message: ByteArray, password: String, algorithm: Algorithm): DetachedEncryptionResult
interface SecretDecryptionStream : Destroyable
interface SecretEncryptionStream : Destroyable
class SecretKey
class SecureScuttlebuttHandshakeClient
class SecureScuttlebuttHandshakeServer
interface SecureScuttlebuttStreamClient
interface SecureScuttlebuttStreamServer
class SecureScuttlebuttVertxClient
class SecureScuttlebuttVertxServer
interface ServerHandler
interface ServerHandlerFactory
class Signature
class Signature
Module Contents
class KeyPair
class PublicKey
class SecretKey : Destroyable
class Seed
static fun sign(message: Bytes, secretKey: SecretKey): Bytes
static fun sign(message: ByteArray, secretKey: SecretKey): ByteArray
static fun signDetached(message: Bytes, secretKey: SecretKey): Bytes
static fun signDetached(message: Allocated, secretKey: SecretKey): Allocated
static fun signDetached(message: ByteArray, secretKey: SecretKey): ByteArray
static fun verify(signed: Bytes, publicKey: PublicKey): Bytes
static fun verify(signed: ByteArray, publicKey: PublicKey): ByteArray
static fun verifyDetached(message: Bytes, signature: Bytes, publicKey: PublicKey): Boolean
static fun verifyDetached(message: Allocated, signature: Allocated, publicKey: PublicKey): Boolean
static fun verifyDetached(message: ByteArray, signature: ByteArray, publicKey: PublicKey): Boolean
class SignatureAndPublicKey
class Sodium
class SodiumException : RuntimeException
class SodiumVersion : Comparable<SodiumVersion>
class State
Module Contents
State(peerRepository: PeerRepository, messageHashingFunction: MessageHashing, messageSender: MessageSender, messageListener: MessageListener, messageValidator: MessageValidator, peerPruningFunction: PeerPruning)
State(peerRepository: PeerRepository, messageHashingFunction: MessageHashing, messageSender: MessageSender, messageListener: MessageListener, messageValidator: MessageValidator, peerPruningFunction: PeerPruning, graftDelay: Long, lazyQueueInterval: Long)
fun addPeer(peer: Peer): Unit
fun receiveGossipMessage(peer: Peer, attributes: String, message: Bytes, messageHash: Bytes): Unit
fun receiveGraftMessage(peer: Peer, messageHash: Bytes): Unit
fun receiveIHaveMessage(peer: Peer, messageHash: Bytes): Unit
fun receivePruneMessage(peer: Peer): Unit
fun removePeer(peer: Peer): Unit
fun sendGossipMessage(attributes: String, message: Bytes): Bytes
fun stop(): Unit
class StoredMerklePatriciaTrie<V> : MerkleTrie<Bytes, V>
Module Contents
StoredMerklePatriciaTrie(storage: MerkleStorage, valueSerializer: (V) -> Bytes, valueDeserializer: (Bytes) -> V)
StoredMerklePatriciaTrie(storage: MerkleStorage, rootHash: Bytes32, valueSerializer: (V) -> Bytes, valueDeserializer: (Bytes) -> V)
fun clearCache(): Unit
@JvmStatic fun <V> create(storage: MerkleStorage, valueSerializer: Function<V, Bytes>, valueDeserializer: Function<Bytes, V>): StoredMerklePatriciaTrie<V>
@JvmStatic fun <V> create(storage: MerkleStorage, rootHash: Bytes32, valueSerializer: Function<V, Bytes>, valueDeserializer: Function<Bytes, V>): StoredMerklePatriciaTrie<V>
suspend fun get(key: Bytes): V?
suspend fun put(key: Bytes, value: V?): Unit
suspend fun remove(key: Bytes): Unit
fun rootHash(): Bytes32
@JvmStatic fun storingBytes(storage: MerkleStorage): StoredMerklePatriciaTrie<Bytes>
@JvmStatic fun storingBytes(storage: MerkleStorage, rootHash: Bytes32): StoredMerklePatriciaTrie<Bytes>
@JvmStatic fun storingStrings(storage: MerkleStorage): StoredMerklePatriciaTrie<String>
@JvmStatic fun storingStrings(storage: MerkleStorage, rootHash: Bytes32): StoredMerklePatriciaTrie<String>
fun toString(): String
class StreamException : RuntimeException
class Streams
interface SubProtocol
interface SubProtocolHandler
interface SubProtocolIdentifier
class TLS
@Target([AnnotationTarget.VALUE_PARAMETER]) class TempDirectory
class TempDirectoryExtension : ParameterResolver, AfterAllCallback
class Toml
interface TomlArray
open class TomlInvalidTypeException : RuntimeException
class TomlParseError : RuntimeException
interface TomlParseResult : TomlTable
class TomlPosition
interface TomlTable
Module Contents
open fun contains(dottedKey: String): Boolean
open fun contains(path: MutableList<String>): Boolean
open fun dottedKeySet(): MutableSet<String>
open fun dottedKeySet(includeTables: Boolean): MutableSet<String>
@Nullable open fun get(dottedKey: String): Any?
@Nullable abstract fun get(path: MutableList<String>): Any?
@Nullable open fun getArray(dottedKey: String): TomlArray?
@Nullable open fun getArray(path: MutableList<String>): TomlArray?
open fun getArrayOrEmpty(dottedKey: String): TomlArray
open fun getArrayOrEmpty(path: MutableList<String>): TomlArray
@Nullable open fun getBoolean(dottedKey: String): Boolean?
@Nullable open fun getBoolean(path: MutableList<String>): Boolean?
open fun getBoolean(dottedKey: String, defaultValue: BooleanSupplier): Boolean
open fun getBoolean(path: MutableList<String>, defaultValue: BooleanSupplier): Boolean
@Nullable open fun getDouble(dottedKey: String): Double?
@Nullable open fun getDouble(path: MutableList<String>): Double?
open fun getDouble(dottedKey: String, defaultValue: DoubleSupplier): Double
open fun getDouble(path: MutableList<String>, defaultValue: DoubleSupplier): Double
@Nullable open fun getLocalDate(dottedKey: String): LocalDate?
@Nullable open fun getLocalDate(path: MutableList<String>): LocalDate?
open fun getLocalDate(dottedKey: String, defaultValue: Supplier<LocalDate>): LocalDate
open fun getLocalDate(path: MutableList<String>, defaultValue: Supplier<LocalDate>): LocalDate
@Nullable open fun getLocalDateTime(dottedKey: String): LocalDateTime?
@Nullable open fun getLocalDateTime(path: MutableList<String>): LocalDateTime?
open fun getLocalDateTime(dottedKey: String, defaultValue: Supplier<LocalDateTime>): LocalDateTime
open fun getLocalDateTime(path: MutableList<String>, defaultValue: Supplier<LocalDateTime>): LocalDateTime
@Nullable open fun getLocalTime(dottedKey: String): LocalTime?
@Nullable open fun getLocalTime(path: MutableList<String>): LocalTime?
open fun getLocalTime(dottedKey: String, defaultValue: Supplier<LocalTime>): LocalTime
open fun getLocalTime(path: MutableList<String>, defaultValue: Supplier<LocalTime>): LocalTime
@Nullable open fun getLong(dottedKey: String): Long?
@Nullable open fun getLong(path: MutableList<String>): Long?
open fun getLong(dottedKey: String, defaultValue: LongSupplier): Long
open fun getLong(path: MutableList<String>, defaultValue: LongSupplier): Long
@Nullable open fun getOffsetDateTime(dottedKey: String): OffsetDateTime?
@Nullable open fun getOffsetDateTime(path: MutableList<String>): OffsetDateTime?
open fun getOffsetDateTime(dottedKey: String, defaultValue: Supplier<OffsetDateTime>): OffsetDateTime
open fun getOffsetDateTime(path: MutableList<String>, defaultValue: Supplier<OffsetDateTime>): OffsetDateTime
@Nullable open fun getString(dottedKey: String): String?
@Nullable open fun getString(path: MutableList<String>): String?
open fun getString(dottedKey: String, defaultValue: Supplier<String>): String
open fun getString(path: MutableList<String>, defaultValue: Supplier<String>): String
@Nullable open fun getTable(dottedKey: String): TomlTable?
@Nullable open fun getTable(path: MutableList<String>): TomlTable?
open fun getTableOrEmpty(dottedKey: String): TomlTable
open fun getTableOrEmpty(path: MutableList<String>): TomlTable
@Nullable open fun inputPositionOf(dottedKey: String): TomlPosition?
@Nullable abstract fun inputPositionOf(path: MutableList<String>): TomlPosition?
open fun isArray(dottedKey: String): Boolean
open fun isArray(path: MutableList<String>): Boolean
open fun isBoolean(dottedKey: String): Boolean
open fun isBoolean(path: MutableList<String>): Boolean
open fun isDouble(dottedKey: String): Boolean
open fun isDouble(path: MutableList<String>): Boolean
abstract fun isEmpty(): Boolean
open fun isLocalDate(dottedKey: String): Boolean
open fun isLocalDate(path: MutableList<String>): Boolean
open fun isLocalDateTime(dottedKey: String): Boolean
open fun isLocalDateTime(path: MutableList<String>): Boolean
open fun isLocalTime(dottedKey: String): Boolean
open fun isLocalTime(path: MutableList<String>): Boolean
open fun isLong(dottedKey: String): Boolean
open fun isLong(path: MutableList<String>): Boolean
open fun isOffsetDateTime(dottedKey: String): Boolean
open fun isOffsetDateTime(path: MutableList<String>): Boolean
open fun isString(dottedKey: String): Boolean
open fun isString(path: MutableList<String>): Boolean
open fun isTable(dottedKey: String): Boolean
open fun isTable(path: MutableList<String>): Boolean
open fun keyPathSet(): MutableSet<MutableList<String>>
abstract fun keyPathSet(includeTables: Boolean): MutableSet<MutableList<String>>
abstract fun keySet(): MutableSet<String>
abstract fun size(): Int
open fun toJson(): String
open fun toJson(appendable: Appendable): Unit
abstract fun toMap(): MutableMap<String, Any>
class TomlVersion
class Transaction
Module Contents
Transaction(nonce: UInt256, gasPrice: Wei, gasLimit: Gas, @Nullable to: Address?, value: Wei, payload: Bytes, keyPair: KeyPair)
Transaction(nonce: UInt256, gasPrice: Wei, gasLimit: Gas, @Nullable to: Address?, value: Wei, payload: Bytes, keyPair: KeyPair, @Nullable chainId: Int?)
Transaction(nonce: UInt256, gasPrice: Wei, gasLimit: Gas, @Nullable to: Address?, value: Wei, payload: Bytes, @Nullable chainId: Int?, signature: Signature)
fun chainId(): Int
fun equals(other: Any?): Boolean
static fun fromBytes(encoded: Bytes): Transaction
static fun fromBytes(encoded: Bytes, lenient: Boolean): Transaction
fun gasLimit(): Gas
fun gasPrice(): Wei
fun hash(): Hash
fun hashCode(): Int
fun isContractCreation(): Boolean
fun nonce(): UInt256
fun payload(): Bytes
static fun readFrom(reader: RLPReader): Transaction
@Nullable fun sender(): Address?
fun signature(): Signature
@Nullable fun to(): Address?
fun toBytes(): Bytes
fun toString(): String
fun value(): Wei
fun writeTo(writer: RLPWriter): Unit
class TransactionReceipt
enum class TransactionReceiptFields
enum class Transport
class TrustManagerFactories
Module Contents
static fun recordClientFingerprints(knownClientsFile: Path): TrustManagerFactory
static fun recordClientFingerprints(repository: FingerprintRepository): TrustManagerFactory
static fun recordClientFingerprints(knownClientsFile: Path, skipCASigned: Boolean): TrustManagerFactory
static fun recordClientFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustManagerFactory
static fun recordClientFingerprints(knownClientsFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun recordClientFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun recordServerFingerprints(knownServersFile: Path): TrustManagerFactory
static fun recordServerFingerprints(repository: FingerprintRepository): TrustManagerFactory
static fun recordServerFingerprints(knownServersFile: Path, skipCASigned: Boolean): TrustManagerFactory
static fun recordServerFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustManagerFactory
static fun recordServerFingerprints(knownServersFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun recordServerFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustClientOnFirstAccess(knownClientsFile: Path): TrustManagerFactory
static fun trustClientOnFirstAccess(repository: FingerprintRepository): TrustManagerFactory
static fun trustClientOnFirstAccess(knownClientsFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun trustClientOnFirstAccess(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun trustClientOnFirstAccess(knownClientsFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustClientOnFirstAccess(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustServerOnFirstUse(knownServersFile: Path): TrustManagerFactory
static fun trustServerOnFirstUse(repository: FingerprintRepository): TrustManagerFactory
static fun trustServerOnFirstUse(knownServersFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun trustServerOnFirstUse(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun trustServerOnFirstUse(knownServersFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustServerOnFirstUse(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistClients(knownClientsFile: Path): TrustManagerFactory
static fun whitelistClients(repository: FingerprintRepository): TrustManagerFactory
static fun whitelistClients(knownClientsFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistClients(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistClients(knownClientsFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistClients(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistServers(knownServersFile: Path): TrustManagerFactory
static fun whitelistServers(repository: FingerprintRepository): TrustManagerFactory
static fun whitelistServers(knownServersFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistServers(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistServers(knownServersFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistServers(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
class UInt256 : UInt256Value<UInt256>
class UInt256Domain : DiscreteDomain<UInt256>
interface UInt256Value<T : UInt256Value<T>> : Comparable<T>
class UInt256ValueDomain<T : UInt256Value<T>> : DiscreteDomain<T>
class UInt256s
class UInt32 : UInt32Value<UInt32>
class UInt32Domain : DiscreteDomain<UInt32>
interface UInt32Value<T : UInt32Value<T>> : Comparable<T>
class UInt32ValueDomain<T : UInt32Value<T>> : DiscreteDomain<T>
class UInt32s
class UInt384 : UInt384Value<UInt384>
class UInt384Domain : DiscreteDomain<UInt384>
interface UInt384Value<T : UInt384Value<T>> : Comparable<T>
class UInt384ValueDomain<T : UInt384Value<T>> : DiscreteDomain<T>
class UInt384s
class UInt64 : UInt64Value<UInt64>
class UInt64Domain : DiscreteDomain<UInt64>
interface UInt64Value<T : UInt64Value<T>> : Comparable<T>
class UInt64ValueDomain<T : UInt64Value<T>> : DiscreteDomain<T>
class UInt64s
open class VertxExtension : ParameterResolver, AfterAllCallback
class VertxGossipServer
Module Contents
VertxGossipServer(vertx: Vertx, networkInterface: String, port: Int, messageHashing: MessageHashing, peerRepository: PeerRepository, payloadListener: MessageListener, @Nullable payloadValidator: MessageValidator?, @Nullable peerPruningFunction: PeerPruning?, graftDelay: Int, lazyQueueInterval: Int)
fun connectTo(host: String, port: Int): AsyncCompletion
fun gossip(attributes: String, message: Bytes): Unit
fun start(): AsyncCompletion
fun stop(): AsyncCompletion
@Target([AnnotationTarget.VALUE_PARAMETER]) class VertxInstance
class VertxRLPxService : RLPxService
Module Contents
VertxRLPxService(vertx: Vertx, loggerProvider: LoggerProvider, listenPort: Int, networkInterface: String, advertisedPort: Int, identityKeyPair: KeyPair, subProtocols: MutableList<SubProtocol>, clientId: String)
VertxRLPxService(vertx: Vertx, loggerProvider: LoggerProvider, listenPort: Int, networkInterface: String, advertisedPort: Int, identityKeyPair: KeyPair, subProtocols: MutableList<SubProtocol>, clientId: String, repository: WireConnectionRepository)
fun actualPort(): Int
fun advertisedPort(): Int
fun broadcast(subProtocolIdentifier: SubProtocolIdentifier, messageType: Int, message: Bytes): Unit
fun connectTo(peerPublicKey: PublicKey, peerAddress: InetSocketAddress): AsyncCompletion
fun disconnect(connectionId: String, disconnectReason: DisconnectReason): Unit
fun repository(): WireConnectionRepository
fun send(subProtocolIdentifier: SubProtocolIdentifier, messageType: Int, connectionId: String, message: Bytes): Unit
fun start(): AsyncCompletion
fun stop(): AsyncCompletion
class VertxTrustOptions
Module Contents
static fun recordClientFingerprints(knownClientsFile: Path): TrustOptions
static fun recordClientFingerprints(repository: FingerprintRepository): TrustOptions
static fun recordClientFingerprints(knownClientsFile: Path, skipCASigned: Boolean): TrustOptions
static fun recordClientFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustOptions
static fun recordClientFingerprints(knownClientsFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun recordClientFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun recordServerFingerprints(knownServersFile: Path): TrustOptions
static fun recordServerFingerprints(repository: FingerprintRepository): TrustOptions
static fun recordServerFingerprints(knownServersFile: Path, skipCASigned: Boolean): TrustOptions
static fun recordServerFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustOptions
static fun recordServerFingerprints(knownServersFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun recordServerFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun trustClientOnFirstAccess(knownClientsFile: Path): TrustOptions
static fun trustClientOnFirstAccess(repository: FingerprintRepository): TrustOptions
static fun trustClientOnFirstAccess(knownClientsFile: Path, acceptCASigned: Boolean): TrustOptions
static fun trustClientOnFirstAccess(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun trustClientOnFirstAccess(knownClientsFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun trustClientOnFirstAccess(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun trustServerOnFirstUse(knownServersFile: Path): TrustOptions
static fun trustServerOnFirstUse(repository: FingerprintRepository): TrustOptions
static fun trustServerOnFirstUse(knownServersFile: Path, acceptCASigned: Boolean): TrustOptions
static fun trustServerOnFirstUse(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun trustServerOnFirstUse(knownServersFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun trustServerOnFirstUse(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun whitelistClients(knownClientsFile: Path): TrustOptions
static fun whitelistClients(repository: FingerprintRepository): TrustOptions
static fun whitelistClients(knownClientsFile: Path, acceptCASigned: Boolean): TrustOptions
static fun whitelistClients(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun whitelistClients(knownClientsFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun whitelistClients(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun whitelistServers(knownServersFile: Path): TrustOptions
static fun whitelistServers(repository: FingerprintRepository): TrustOptions
static fun whitelistServers(knownServersFile: Path, acceptCASigned: Boolean): TrustOptions
static fun whitelistServers(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun whitelistServers(knownServersFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun whitelistServers(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
class Wei : BaseUInt256Value<Wei>
interface WireConnection
interface WireConnectionRepository
interface WritableCoroutineByteChannel
class XChaCha20Poly1305
Module Contents
class Key : Destroyable
class Nonce
@Nullable static fun decrypt(cipherText: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
static fun decryptDetached(cipherText: Bytes, mac: Bytes, key: Key, nonce: Nonce): Bytes
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
static fun encrypt(message: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encryptDetached(message: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, data: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun isAvailable(): Boolean
static fun isSecretStreamAvailable(): Boolean
static fun openDecryptionStream(key: Key, : ByteArray): SecretDecryptionStream
static fun openEncryptionStream(key: Key): SecretEncryptionStream
kotlin.ByteArray
kotlin.collections.MutableList
kotlinx.coroutines.CoroutineScope
kotlinx.coroutines.Deferred
kotlinx.coroutines.Job
org.apache.tuweni.concurrent.AsyncCompletion
org.apache.tuweni.concurrent.AsyncResult
package org.apache.tuweni.bytes
Module Contents
abstract class AbstractBytes : Bytes
interface Bytes
Module Contents
static val EMPTY: Bytes
open fun and(other: Bytes): Bytes
open fun <T : MutableBytes> and(other: Bytes, result: T): T
open fun <T : Appendable> appendHexTo(appendable: T): T
open fun appendTo(byteBuffer: ByteBuffer): Unit
open fun appendTo(buffer: Buffer): Unit
open fun bitLength(): Int
open fun commonPrefix(other: Bytes): Bytes
open fun commonPrefixLength(other: Bytes): Int
open static fun concatenate(vararg values: Bytes): Bytes
abstract fun copy(): Bytes
open fun copyTo(destination: MutableBytes): Unit
open fun copyTo(destination: MutableBytes, destinationOffset: Int): Unit
open static fun fromBase64String(str: CharSequence): Bytes
open static fun fromHexString(str: CharSequence): Bytes
open static fun fromHexString(str: CharSequence, destinationSize: Int): Bytes
open static fun fromHexStringLenient(str: CharSequence): Bytes
open static fun fromHexStringLenient(str: CharSequence, destinationSize: Int): Bytes
abstract fun get(i: Int): Byte
open fun getInt(i: Int): Int
open fun getInt(i: Int, order: ByteOrder): Int
open fun getLong(i: Int): Long
open fun getLong(i: Int, order: ByteOrder): Long
open fun hasLeadingZero(): Boolean
open fun hasLeadingZeroByte(): Boolean
open fun isEmpty(): Boolean
open fun isZero(): Boolean
open static fun minimalBytes(value: Long): Bytes
abstract fun mutableCopy(): MutableBytes
open fun not(): Bytes
open fun <T : MutableBytes> not(result: T): T
open fun numberOfLeadingZeroBytes(): Int
open fun numberOfLeadingZeros(): Int
open fun numberOfTrailingZeroBytes(): Int
open static fun of(vararg bytes: Byte): Bytes
open static fun of(vararg bytes: Int): Bytes
open static fun ofUnsignedInt(value: Long): Bytes
open static fun ofUnsignedInt(value: Long, order: ByteOrder): Bytes
open static fun ofUnsignedLong(value: Long): Bytes
open static fun ofUnsignedLong(value: Long, order: ByteOrder): Bytes
open static fun ofUnsignedShort(value: Int): Bytes
open static fun ofUnsignedShort(value: Int, order: ByteOrder): Bytes
open fun or(other: Bytes): Bytes
open fun <T : MutableBytes> or(other: Bytes, result: T): T
open static fun random(size: Int): Bytes
open static fun random(size: Int, generator: Random): Bytes
open fun reverse(): Bytes
open fun shiftLeft(distance: Int): Bytes
open fun <T : MutableBytes> shiftLeft(distance: Int, result: T): T
open fun shiftRight(distance: Int): Bytes
open fun <T : MutableBytes> shiftRight(distance: Int, result: T): T
abstract fun size(): Int
open fun slice(i: Int): Bytes
abstract fun slice(i: Int, length: Int): Bytes
open fun toArray(): ByteArray
open fun toArrayUnsafe(): ByteArray
open fun toBase64String(): String
open fun toBigInteger(): BigInteger
open fun toBigInteger(order: ByteOrder): BigInteger
open fun toHexString(): String
open fun toInt(): Int
open fun toInt(order: ByteOrder): Int
open fun toLong(): Long
open fun toLong(order: ByteOrder): Long
open fun toShortHexString(): String
open fun toUnsignedBigInteger(): BigInteger
open fun toUnsignedBigInteger(order: ByteOrder): BigInteger
open fun trimLeadingZeros(): Bytes
open fun update(digest: MessageDigest): Unit
open static fun wrap(value: ByteArray): Bytes
open static fun wrap(value: ByteArray, offset: Int, length: Int): Bytes
open static fun wrap(vararg values: Bytes): Bytes
open static fun wrapBuffer(buffer: Buffer): Bytes
open static fun wrapBuffer(buffer: Buffer, offset: Int, size: Int): Bytes
open static fun wrapByteBuf(byteBuf: ByteBuf): Bytes
open static fun wrapByteBuf(byteBuf: ByteBuf, offset: Int, size: Int): Bytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer): Bytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer, offset: Int, size: Int): Bytes
open fun xor(other: Bytes): Bytes
open fun <T : MutableBytes> xor(other: Bytes, result: T): T
interface Bytes32 : Bytes
interface Bytes48 : Bytes
open class MutableByteBufferWrappingBytes : ByteBufferWrappingBytes, MutableBytes
interface MutableBytes : Bytes
Module Contents
static val EMPTY: MutableBytes
open fun clear(): Unit
open static fun create(size: Int): MutableBytes
open fun decrement(): MutableBytes
open fun fill(b: Byte): Unit
open fun increment(): MutableBytes
abstract fun mutableSlice(i: Int, length: Int): MutableBytes
open static fun of(vararg bytes: Byte): MutableBytes
open static fun of(vararg bytes: Int): MutableBytes
abstract fun set(i: Int, b: Byte): Unit
open fun setInt(i: Int, value: Int): Unit
open fun setLong(i: Int, value: Long): Unit
open static fun wrap(value: ByteArray): MutableBytes
open static fun wrap(value: ByteArray, offset: Int, length: Int): MutableBytes
open static fun wrapBuffer(buffer: Buffer): MutableBytes
open static fun wrapBuffer(buffer: Buffer, offset: Int, size: Int): MutableBytes
open static fun wrapByteBuf(byteBuf: ByteBuf): MutableBytes
open static fun wrapByteBuf(byteBuf: ByteBuf, offset: Int, size: Int): MutableBytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer): MutableBytes
open static fun wrapByteBuffer(byteBuffer: ByteBuffer, offset: Int, size: Int): MutableBytes
interface MutableBytes32 : MutableBytes, Bytes32
interface MutableBytes48 : MutableBytes, Bytes48
package org.apache.tuweni.concurrent
Module Contents
interface AsyncCompletion
Module Contents
static val COMPLETED: AsyncCompletion
abstract fun accept(consumer: Consumer<in Throwable>): AsyncCompletion
open static fun allOf(vararg cs: AsyncCompletion): AsyncCompletion
open static fun allOf(cs: MutableCollection<AsyncCompletion>): AsyncCompletion
open static fun allOf(cs: Stream<AsyncCompletion>): AsyncCompletion
abstract fun cancel(): Boolean
open static fun completed(): AsyncCompletion
open static fun exceptional(ex: Throwable): AsyncCompletion
abstract fun exceptionally(consumer: Consumer<in Throwable>): AsyncCompletion
open static fun executeBlocking(action: Runnable): AsyncCompletion
open static fun executeBlocking(executor: Executor, action: Runnable): AsyncCompletion
open static fun executeBlocking(vertx: Vertx, action: Runnable): AsyncCompletion
open static fun executeBlocking(executor: WorkerExecutor, action: Runnable): AsyncCompletion
abstract fun <U : Any> handle(fn: Function<in Throwable, out U>): AsyncResult<U>
open static fun incomplete(): CompletableAsyncCompletion
abstract fun isCancelled(): Boolean
abstract fun isCompletedExceptionally(): Boolean
abstract fun isDone(): Boolean
abstract fun join(): Unit
abstract fun join(timeout: Long, unit: TimeUnit): Unit
open static fun runOnContext(vertx: Vertx, fn: Supplier<out AsyncCompletion>): AsyncCompletion
open static fun runOnContext(vertx: Vertx, action: Runnable): AsyncCompletion
abstract fun <U : Any> then(fn: Supplier<out AsyncResult<U>>): AsyncResult<U>
abstract fun <U : Any, V : Any> thenApply(other: AsyncResult<out U>, fn: Function<in U, out V>): AsyncResult<V>
abstract fun thenCombine(other: AsyncCompletion): AsyncCompletion
abstract fun thenCompose(fn: Supplier<out AsyncCompletion>): AsyncCompletion
abstract fun <U : Any> thenConsume(other: AsyncResult<out U>, consumer: Consumer<in U>): AsyncCompletion
abstract fun thenRun(runnable: Runnable): AsyncCompletion
abstract fun <U : Any> thenSchedule(vertx: Vertx, fn: Supplier<out AsyncResult<U>>): AsyncResult<U>
abstract fun thenScheduleBlockingRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleBlockingRun(executor: WorkerExecutor, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun <U : Any> thenSupply(supplier: Supplier<out U>): AsyncResult<U>
abstract fun <U : Any> thenSupply(vertx: Vertx, supplier: Supplier<out U>): AsyncResult<U>
abstract fun whenComplete(consumer: Consumer<in Throwable>): AsyncCompletion
interface AsyncResult<T : Any>
Module Contents
abstract fun accept(consumer: BiConsumer<in T, Throwable>): AsyncCompletion
open static fun allOf(vararg rs: AsyncResult<*>): AsyncCompletion
open static fun allOf(rs: MutableCollection<out AsyncResult<*>>): AsyncCompletion
open static fun allOf(rs: Stream<out AsyncResult<*>>): AsyncCompletion
abstract fun cancel(): Boolean
open static fun <T : Any> combine(rs: MutableCollection<out AsyncResult<out T>>): AsyncResult<MutableList<T>>
open static fun <T : Any> combine(rs: Stream<out AsyncResult<out T>>): AsyncResult<MutableList<T>>
open static fun <T : Any> completed(@Nullable value: T?): AsyncResult<T>
open static fun <T : Any> exceptional(ex: Throwable): AsyncResult<T>
abstract fun exceptionally(fn: Function<Throwable, out T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(fn: Supplier<T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(executor: Executor, fn: Supplier<T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(vertx: Vertx, fn: Supplier<T>): AsyncResult<T>
open static fun <T : Any> executeBlocking(executor: WorkerExecutor, fn: Supplier<T>): AsyncResult<T>
@Nullable abstract fun get(): T?
@Nullable abstract fun get(timeout: Long, unit: TimeUnit): T?
abstract fun <U : Any> handle(fn: BiFunction<in T, Throwable, out U>): AsyncResult<U>
open static fun <T : Any> incomplete(): CompletableAsyncResult<T>
abstract fun isCancelled(): Boolean
abstract fun isCompletedExceptionally(): Boolean
abstract fun isDone(): Boolean
open static fun <T : Any> runOnContext(vertx: Vertx, fn: Supplier<out AsyncResult<T>>): AsyncResult<T>
abstract fun <U : Any> then(fn: Function<in T, out AsyncResult<U>>): AsyncResult<U>
abstract fun thenAccept(consumer: Consumer<in T>): AsyncCompletion
abstract fun <U : Any> thenAcceptBoth(other: AsyncResult<out U>, consumer: BiConsumer<in T, in U>): AsyncCompletion
abstract fun <U : Any> thenApply(fn: Function<in T, out U>): AsyncResult<U>
abstract fun <U : Any, V : Any> thenCombine(other: AsyncResult<out U>, fn: BiFunction<in T, in U, out V>): AsyncResult<V>
abstract fun thenCompose(fn: Function<in T, out AsyncCompletion>): AsyncCompletion
abstract fun thenRun(runnable: Runnable): AsyncCompletion
abstract fun <U : Any> thenSchedule(vertx: Vertx, fn: Function<in T, out AsyncResult<U>>): AsyncResult<U>
abstract fun <U : Any> thenScheduleApply(vertx: Vertx, fn: Function<in T, out U>): AsyncResult<U>
abstract fun <U : Any> thenScheduleBlockingApply(vertx: Vertx, fn: Function<in T, out U>): AsyncResult<U>
abstract fun <U : Any> thenScheduleBlockingApply(executor: WorkerExecutor, fn: Function<in T, out U>): AsyncResult<U>
abstract fun thenScheduleBlockingRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleBlockingRun(executor: WorkerExecutor, runnable: Runnable): AsyncCompletion
abstract fun thenScheduleRun(vertx: Vertx, runnable: Runnable): AsyncCompletion
abstract fun whenComplete(action: BiConsumer<in T, in Throwable>): AsyncResult<T>
class AtomicSlotMap<K : Comparable<Any?>, V : Any>
interface CompletableAsyncCompletion : AsyncCompletion
interface CompletableAsyncResult<T : Any> : AsyncResult<T>
class ExpiringMap<K : Any, V : Any> : MutableMap<K, V>
Module Contents
ExpiringMap()
fun clear(): Unit
fun compute(key: K, remappingFunction: BiFunction<in K, in V?, out V?>): V?
fun computeIfAbsent(key: K, mappingFunction: Function<in K, out V>): V
fun computeIfPresent(key: K, remappingFunction: BiFunction<in K, in V, out V?>): V?
fun containsKey(key: K): Boolean
fun containsValue(value: V): Boolean
val entries: MutableSet<MutableEntry<K, V>>
fun equals(other: Any?): Boolean
fun forEach(action: BiConsumer<in K, in V>): Unit
@Nullable fun get(key: K): V?
fun getOrDefault(key: K, defaultValue: V): V
fun hashCode(): Int
fun isEmpty(): Boolean
val keys: MutableSet<K>
fun merge(key: K, value: V, remappingFunction: BiFunction<in V, in V, out V?>): V?
fun purgeExpired(): Long
@Nullable fun put(key: K, value: V): V?
@Nullable fun put(key: K, value: V, expiry: Long): V?
@Nullable fun put(key: K, value: V, expiry: Long, @Nullable expiryListener: BiConsumer<K, V>?): V?
fun putAll(from: Map<out K, V>): Unit
@Nullable fun putIfAbsent(key: K, value: V): V?
@Nullable fun putIfAbsent(key: K, value: V, expiry: Long): V?
@Nullable fun putIfAbsent(key: K, value: V, expiry: Long, @Nullable expiryListener: BiConsumer<K, V>?): V?
fun remove(key: K): V?
fun remove(key: K, value: V): Boolean
fun replace(key: K, value: V): V?
fun replace(key: K, oldValue: V, newValue: V): Boolean
fun replaceAll(function: BiFunction<in K, in V, out V>): Unit
val size: Int
val values: MutableCollection<V>
class ExpiringSet<E : Any> : MutableSet<E>
package org.apache.tuweni.concurrent.coroutines
package org.apache.tuweni.config
Module Contents
interface Configuration
class ConfigurationError : RuntimeException
class ConfigurationErrors
interface ConfigurationValidator
class DocumentPosition
class InvalidConfigurationPropertyTypeException : RuntimeException
class NoConfigurationPropertyException : RuntimeException
interface PropertyValidator<T : Any>
class Schema
class SchemaBuilder
Module Contents
fun addBoolean(key: String, @Nullable defaultValue: Boolean?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Boolean>?): SchemaBuilder
fun addDefault(key: String, value: Any): SchemaBuilder
fun addDouble(key: String, @Nullable defaultValue: Double?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Double>?): SchemaBuilder
fun addInteger(key: String, @Nullable defaultValue: Int?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Int>?): SchemaBuilder
fun addListOfBoolean(key: String, @Nullable defaultValue: MutableList<Boolean>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Boolean>>?): SchemaBuilder
fun addListOfDouble(key: String, @Nullable defaultValue: MutableList<Double>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Double>>?): SchemaBuilder
fun addListOfInteger(key: String, @Nullable defaultValue: MutableList<Int>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Int>>?): SchemaBuilder
fun addListOfLong(key: String, @Nullable defaultValue: MutableList<Long>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<Long>>?): SchemaBuilder
fun addListOfMap(key: String, @Nullable defaultValue: MutableList<MutableMap<String, Any>>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<MutableMap<String, Any>>>?): SchemaBuilder
fun addListOfString(key: String, @Nullable defaultValue: MutableList<String>?, @Nullable description: String?, @Nullable validator: PropertyValidator<in MutableList<String>>?): SchemaBuilder
fun addLong(key: String, @Nullable defaultValue: Long?, @Nullable description: String?, @Nullable validator: PropertyValidator<in Long>?): SchemaBuilder
fun addString(key: String, @Nullable defaultValue: String?, @Nullable description: String?, @Nullable validator: PropertyValidator<in String>?): SchemaBuilder
static fun create(): SchemaBuilder
fun documentProperty(key: String, description: String): SchemaBuilder
fun toSchema(): Schema
fun validateConfiguration(validator: ConfigurationValidator): SchemaBuilder
fun validateProperty(key: String, validator: PropertyValidator<Any>): SchemaBuilder
package org.apache.tuweni.crypto
Module Contents
class Hash
class InvalidSEC256K1SecretKeyStoreException : RuntimeException
class SECP256K1
Module Contents
class KeyPair
class Parameters
class PublicKey
class SecretKey : Destroyable
class Signature
static fun calculateKeyAgreement(privKey: SecretKey, theirPubKey: PublicKey): Bytes32
static fun sign(data: ByteArray, keyPair: KeyPair): Signature
static fun sign(data: Bytes, keyPair: KeyPair): Signature
static fun signHashed(hash: ByteArray, keyPair: KeyPair): Signature
static fun signHashed(hash: Bytes32, keyPair: KeyPair): Signature
static fun verify(data: ByteArray, signature: Signature, publicKey: PublicKey): Boolean
static fun verify(data: Bytes, signature: Signature, publicKey: PublicKey): Boolean
static fun verifyHashed(hash: Bytes32, signature: Signature, publicKey: PublicKey): Boolean
static fun verifyHashed(hash: ByteArray, signature: Signature, publicKey: PublicKey): Boolean
package org.apache.tuweni.crypto.mikuli
Module Contents
class BLS12381
Module Contents
static fun sign(keyPair: KeyPair, message: ByteArray, domain: Int): SignatureAndPublicKey
static fun sign(keyPair: KeyPair, message: Bytes, domain: Int): SignatureAndPublicKey
static fun verify(publicKey: PublicKey, signature: Signature, message: ByteArray, domain: Int): Boolean
static fun verify(publicKey: PublicKey, signature: Signature, message: Bytes, domain: Int): Boolean
static fun verify(sigAndPubKey: SignatureAndPublicKey, message: ByteArray, domain: Int): Boolean
static fun verify(sigAndPubKey: SignatureAndPublicKey, message: Bytes, domain: Int): Boolean
class KeyPair
class PublicKey
class SecretKey
class Signature
class SignatureAndPublicKey
package org.apache.tuweni.crypto.sodium
Module Contents
class AES256GCM : AutoCloseable
Module Contents
class Key : Destroyable
class Nonce
fun close(): Unit
@Nullable fun decrypt(cipherText: Bytes, nonce: Nonce): Bytes?
@Nullable fun decrypt(cipherText: ByteArray, nonce: Nonce): ByteArray?
@Nullable fun decrypt(cipherText: Bytes, data: Bytes, nonce: Nonce): Bytes?
@Nullable fun decrypt(cipherText: ByteArray, data: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable fun decryptDetached(cipherText: Bytes, mac: Bytes, nonce: Nonce): Bytes?
@Nullable fun decryptDetached(cipherText: ByteArray, mac: ByteArray, nonce: Nonce): ByteArray?
@Nullable fun decryptDetached(cipherText: Bytes, mac: Bytes, data: Bytes, nonce: Nonce): Bytes?
@Nullable fun decryptDetached(cipherText: ByteArray, mac: ByteArray, data: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
fun encrypt(message: Bytes, nonce: Nonce): Bytes
fun encrypt(message: ByteArray, nonce: Nonce): ByteArray
fun encrypt(message: Bytes, data: Bytes, nonce: Nonce): Bytes
fun encrypt(message: ByteArray, data: ByteArray, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray
fun encryptDetached(message: Bytes, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: ByteArray, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: Bytes, data: Bytes, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: ByteArray, data: ByteArray, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, data: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun forKey(key: Key): AES256GCM
static fun isAvailable(): Boolean
class Allocated : Destroyable
class Auth
class Box : AutoCloseable
Module Contents
class KeyPair
class Nonce
class PublicKey
class SecretKey : Destroyable
class Seed
fun close(): Unit
@Nullable fun decrypt(cipherText: Bytes, nonce: Nonce): Bytes?
@Nullable fun decrypt(cipherText: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, sender: PublicKey, receiver: SecretKey, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, sender: PublicKey, receiver: SecretKey, nonce: Nonce): ByteArray?
@Nullable fun decryptDetached(cipherText: Bytes, mac: Bytes, nonce: Nonce): Bytes?
@Nullable fun decryptDetached(cipherText: ByteArray, mac: ByteArray, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, sender: PublicKey, receiver: SecretKey, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, sender: PublicKey, receiver: SecretKey, nonce: Nonce): ByteArray?
@Nullable static fun decryptSealed(cipherText: Bytes, sender: PublicKey, receiver: SecretKey): Bytes?
@Nullable static fun decryptSealed(cipherText: ByteArray, sender: PublicKey, receiver: SecretKey): ByteArray?
fun encrypt(message: Bytes, nonce: Nonce): Bytes
fun encrypt(message: ByteArray, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, receiver: PublicKey, sender: SecretKey, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, receiver: PublicKey, sender: SecretKey, nonce: Nonce): ByteArray
fun encryptDetached(message: Bytes, nonce: Nonce): DetachedEncryptionResult
fun encryptDetached(message: ByteArray, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, receiver: PublicKey, sender: SecretKey, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, receiver: PublicKey, sender: SecretKey, nonce: Nonce): DetachedEncryptionResult
static fun encryptSealed(message: Bytes, receiver: PublicKey): Bytes
static fun encryptSealed(message: ByteArray, receiver: PublicKey): ByteArray
static fun forKeys(receiver: PublicKey, sender: SecretKey): Box
class Concatenate
interface DetachedEncryptionResult
class DiffieHelman
class GenericHash
class HMACSHA256
class HMACSHA512
class HMACSHA512256
class KeyDerivation
class KeyExchange
interface LibSodium
Module Contents
abstract fun buf(buf: ByteArray, size: Long): Unit
abstract fun close(): Int
abstract fun crypto_aead_aes256gcm_abytes(): Long
abstract fun crypto_aead_aes256gcm_beforenm(ctx_: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: Pointer, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt_afternm(m: ByteArray, mlen_p: LongLongByReference, nsec: Pointer, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt_detached(m: ByteArray, nsec: Pointer, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_decrypt_detached_afternm(m: ByteArray, nsec: Pointer, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt_afternm(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_aes256gcm_encrypt_detached_afternm(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: Pointer, npub: Pointer, ctx_: Pointer): Int
abstract fun crypto_aead_aes256gcm_is_available(): Int
abstract fun crypto_aead_aes256gcm_keybytes(): Long
abstract fun crypto_aead_aes256gcm_keygen(k: Pointer): Unit
abstract fun crypto_aead_aes256gcm_messagebytes_max(): Long
abstract fun crypto_aead_aes256gcm_npubbytes(): Long
abstract fun crypto_aead_aes256gcm_nsecbytes(): Long
abstract fun crypto_aead_aes256gcm_statebytes(): Long
abstract fun crypto_aead_chacha20poly1305_abytes(): Long
abstract fun crypto_aead_chacha20poly1305_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: ByteArray, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_decrypt_detached(m: ByteArray, nsec: ByteArray, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_abytes(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: ByteArray, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_decrypt_detached(m: ByteArray, nsec: ByteArray, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: ByteArray, k: ByteArray): Int
abstract fun crypto_aead_chacha20poly1305_ietf_keybytes(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_keygen(k: ByteArray): Unit
abstract fun crypto_aead_chacha20poly1305_ietf_messagebytes_max(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_npubbytes(): Long
abstract fun crypto_aead_chacha20poly1305_ietf_nsecbytes(): Long
abstract fun crypto_aead_chacha20poly1305_keybytes(): Long
abstract fun crypto_aead_chacha20poly1305_keygen(k: ByteArray): Unit
abstract fun crypto_aead_chacha20poly1305_messagebytes_max(): Long
abstract fun crypto_aead_chacha20poly1305_npubbytes(): Long
abstract fun crypto_aead_chacha20poly1305_nsecbytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_abytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_decrypt(m: ByteArray, mlen_p: LongLongByReference, nsec: ByteArray, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_decrypt_detached(m: ByteArray, nsec: ByteArray, c: ByteArray, clen: Long, mac: ByteArray, ad: ByteArray, adlen: Long, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_encrypt(c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_encrypt_detached(c: ByteArray, mac: ByteArray, maclen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, nsec: ByteArray, npub: Pointer, k: Pointer): Int
abstract fun crypto_aead_xchacha20poly1305_ietf_keybytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_keygen(k: Pointer): Unit
abstract fun crypto_aead_xchacha20poly1305_ietf_messagebytes_max(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_npubbytes(): Long
abstract fun crypto_aead_xchacha20poly1305_ietf_nsecbytes(): Long
abstract fun crypto_auth(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_bytes(): Long
abstract fun crypto_auth_hmacsha256(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha256_bytes(): Long
abstract fun crypto_auth_hmacsha256_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_auth_hmacsha256_init(state: Pointer, key: ByteArray, keylen: Long): Int
abstract fun crypto_auth_hmacsha256_keybytes(): Long
abstract fun crypto_auth_hmacsha256_keygen(k: ByteArray): Unit
abstract fun crypto_auth_hmacsha256_statebytes(): Long
abstract fun crypto_auth_hmacsha256_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_auth_hmacsha256_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512256(out: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512256_bytes(): Long
abstract fun crypto_auth_hmacsha512256_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_auth_hmacsha512256_init(state: Pointer, key: ByteArray, keylen: Long): Int
abstract fun crypto_auth_hmacsha512256_keybytes(): Long
abstract fun crypto_auth_hmacsha512256_keygen(k: ByteArray): Unit
abstract fun crypto_auth_hmacsha512256_statebytes(): Long
abstract fun crypto_auth_hmacsha512256_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_auth_hmacsha512256_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_hmacsha512_bytes(): Long
abstract fun crypto_auth_hmacsha512_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_auth_hmacsha512_init(state: Pointer, key: ByteArray, keylen: Long): Int
abstract fun crypto_auth_hmacsha512_keybytes(): Long
abstract fun crypto_auth_hmacsha512_keygen(k: ByteArray): Unit
abstract fun crypto_auth_hmacsha512_statebytes(): Long
abstract fun crypto_auth_hmacsha512_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_auth_hmacsha512_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_auth_keybytes(): Long
abstract fun crypto_auth_keygen(k: Pointer): Unit
abstract fun crypto_auth_primitive(): String
abstract fun crypto_auth_verify(h: ByteArray, in: ByteArray, inlen: Long, k: Pointer): Int
abstract fun crypto_box(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_beforenm(k: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_beforenmbytes(): Long
abstract fun crypto_box_boxzerobytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_beforenm(k: Pointer, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_beforenmbytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_detached_afternm(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_easy(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_easy_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_keypair(pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_macbytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_messagebytes_max(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_noncebytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_open_detached_afternm(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_open_easy_afternm(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xchacha20poly1305_publickeybytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_seal(c: ByteArray, m: ByteArray, mlen: Long, pk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_seal_open(m: ByteArray, c: ByteArray, clen: Long, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_sealbytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_secretkeybytes(): Long
abstract fun crypto_box_curve25519xchacha20poly1305_seed_keypair(pk: ByteArray, sk: ByteArray, seed: ByteArray): Int
abstract fun crypto_box_curve25519xchacha20poly1305_seedbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_beforenm(k: Pointer, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_beforenmbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_boxzerobytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_keypair(pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_macbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_messagebytes_max(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_noncebytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_open_afternm(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_publickeybytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_secretkeybytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_seed_keypair(pk: ByteArray, sk: ByteArray, seed: ByteArray): Int
abstract fun crypto_box_curve25519xsalsa20poly1305_seedbytes(): Long
abstract fun crypto_box_curve25519xsalsa20poly1305_zerobytes(): Long
abstract fun crypto_box_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_detached_afternm(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_easy(c: ByteArray, m: ByteArray, mlen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_easy_afternm(c: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_keypair(pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_macbytes(): Long
abstract fun crypto_box_messagebytes_max(): Long
abstract fun crypto_box_noncebytes(): Long
abstract fun crypto_box_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_box_open_afternm(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: Pointer): Int
abstract fun crypto_box_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_open_detached_afternm(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: Pointer, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_open_easy_afternm(m: ByteArray, c: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_box_primitive(): String
abstract fun crypto_box_publickeybytes(): Long
abstract fun crypto_box_seal(c: ByteArray, m: ByteArray, mlen: Long, pk: Pointer): Int
abstract fun crypto_box_seal_open(m: ByteArray, c: ByteArray, clen: Long, pk: Pointer, sk: Pointer): Int
abstract fun crypto_box_sealbytes(): Long
abstract fun crypto_box_secretkeybytes(): Long
abstract fun crypto_box_seed_keypair(pk: Pointer, sk: Pointer, seed: Pointer): Int
abstract fun crypto_box_seedbytes(): Long
abstract fun crypto_box_zerobytes(): Long
abstract fun crypto_core_ed25519_add(r: ByteArray, p: ByteArray, q: ByteArray): Int
abstract fun crypto_core_ed25519_bytes(): Long
abstract fun crypto_core_ed25519_from_uniform(p: ByteArray, r: ByteArray): Int
abstract fun crypto_core_ed25519_is_valid_point(p: ByteArray): Int
abstract fun crypto_core_ed25519_sub(r: ByteArray, p: ByteArray, q: ByteArray): Int
abstract fun crypto_core_ed25519_uniformbytes(): Long
abstract fun crypto_core_hchacha20(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_hchacha20_constbytes(): Long
abstract fun crypto_core_hchacha20_inputbytes(): Long
abstract fun crypto_core_hchacha20_keybytes(): Long
abstract fun crypto_core_hchacha20_outputbytes(): Long
abstract fun crypto_core_hsalsa20(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_hsalsa20_constbytes(): Long
abstract fun crypto_core_hsalsa20_inputbytes(): Long
abstract fun crypto_core_hsalsa20_keybytes(): Long
abstract fun crypto_core_hsalsa20_outputbytes(): Long
abstract fun crypto_core_salsa20(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_salsa2012(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_salsa2012_constbytes(): Long
abstract fun crypto_core_salsa2012_inputbytes(): Long
abstract fun crypto_core_salsa2012_keybytes(): Long
abstract fun crypto_core_salsa2012_outputbytes(): Long
abstract fun crypto_core_salsa208(out: ByteArray, in: ByteArray, k: ByteArray, c: ByteArray): Int
abstract fun crypto_core_salsa208_constbytes(): Long
abstract fun crypto_core_salsa208_inputbytes(): Long
abstract fun crypto_core_salsa208_keybytes(): Long
abstract fun crypto_core_salsa208_outputbytes(): Long
abstract fun crypto_core_salsa20_constbytes(): Long
abstract fun crypto_core_salsa20_inputbytes(): Long
abstract fun crypto_core_salsa20_keybytes(): Long
abstract fun crypto_core_salsa20_outputbytes(): Long
abstract fun crypto_generichash(out: Pointer, outlen: Long, in: Pointer, inlen: Long, key: Pointer, keylen: Long): Int
abstract fun crypto_generichash_blake2b(out: ByteArray, outlen: Long, in: ByteArray, inlen: Long, key: ByteArray, keylen: Long): Int
abstract fun crypto_generichash_blake2b_bytes(): Long
abstract fun crypto_generichash_blake2b_bytes_max(): Long
abstract fun crypto_generichash_blake2b_bytes_min(): Long
abstract fun crypto_generichash_blake2b_final(state: Pointer, out: ByteArray, outlen: Long): Int
abstract fun crypto_generichash_blake2b_init(state: Pointer, key: ByteArray, keylen: Long, outlen: Long): Int
abstract fun crypto_generichash_blake2b_init_salt_personal(state: Pointer, key: ByteArray, keylen: Long, outlen: Long, salt: ByteArray, personal: ByteArray): Int
abstract fun crypto_generichash_blake2b_keybytes(): Long
abstract fun crypto_generichash_blake2b_keybytes_max(): Long
abstract fun crypto_generichash_blake2b_keybytes_min(): Long
abstract fun crypto_generichash_blake2b_keygen(k: ByteArray): Unit
abstract fun crypto_generichash_blake2b_personalbytes(): Long
abstract fun crypto_generichash_blake2b_salt_personal(out: ByteArray, outlen: Long, in: ByteArray, inlen: Long, key: ByteArray, keylen: Long, salt: ByteArray, personal: ByteArray): Int
abstract fun crypto_generichash_blake2b_saltbytes(): Long
abstract fun crypto_generichash_blake2b_statebytes(): Long
abstract fun crypto_generichash_blake2b_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_generichash_bytes(): Long
abstract fun crypto_generichash_bytes_max(): Long
abstract fun crypto_generichash_bytes_min(): Long
abstract fun crypto_generichash_final(state: Pointer, out: ByteArray, outlen: Long): Int
abstract fun crypto_generichash_init(state: Pointer, key: ByteArray, keylen: Long, outlen: Long): Int
abstract fun crypto_generichash_keybytes(): Long
abstract fun crypto_generichash_keybytes_max(): Long
abstract fun crypto_generichash_keybytes_min(): Long
abstract fun crypto_generichash_keygen(k: ByteArray): Unit
abstract fun crypto_generichash_primitive(): String
abstract fun crypto_generichash_statebytes(): Long
abstract fun crypto_generichash_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash(out: ByteArray, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_bytes(): Long
abstract fun crypto_hash_primitive(): String
abstract fun crypto_hash_sha256(out: ByteArray, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_sha256(out: Pointer, in: Pointer, inlen: Long): Int
abstract fun crypto_hash_sha256_bytes(): Long
abstract fun crypto_hash_sha256_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_hash_sha256_init(state: Pointer): Int
abstract fun crypto_hash_sha256_statebytes(): Long
abstract fun crypto_hash_sha256_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_sha512(out: ByteArray, in: ByteArray, inlen: Long): Int
abstract fun crypto_hash_sha512_bytes(): Long
abstract fun crypto_hash_sha512_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_hash_sha512_init(state: Pointer): Int
abstract fun crypto_hash_sha512_statebytes(): Long
abstract fun crypto_hash_sha512_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_kdf_blake2b_bytes_max(): Long
abstract fun crypto_kdf_blake2b_bytes_min(): Long
abstract fun crypto_kdf_blake2b_contextbytes(): Long
abstract fun crypto_kdf_blake2b_derive_from_key(subkey: ByteArray, subkey_len: Long, subkey_id: Long, ctx: ByteArray, key: Pointer): Int
abstract fun crypto_kdf_blake2b_keybytes(): Long
abstract fun crypto_kdf_bytes_max(): Long
abstract fun crypto_kdf_bytes_min(): Long
abstract fun crypto_kdf_contextbytes(): Long
abstract fun crypto_kdf_derive_from_key(subkey: ByteArray, subkey_len: Long, subkey_id: Long, ctx: ByteArray, key: Pointer): Int
abstract fun crypto_kdf_keybytes(): Long
abstract fun crypto_kdf_keygen(k: Pointer): Unit
abstract fun crypto_kdf_primitive(): String
abstract fun crypto_kx_client_session_keys(rx: Pointer, tx: Pointer, client_pk: Pointer, client_sk: Pointer, server_pk: Pointer): Int
abstract fun crypto_kx_keypair(pk: Pointer, sk: Pointer): Int
abstract fun crypto_kx_primitive(): String
abstract fun crypto_kx_publickeybytes(): Long
abstract fun crypto_kx_secretkeybytes(): Long
abstract fun crypto_kx_seed_keypair(pk: Pointer, sk: Pointer, seed: Pointer): Int
abstract fun crypto_kx_seedbytes(): Long
abstract fun crypto_kx_server_session_keys(rx: Pointer, tx: Pointer, server_pk: Pointer, server_sk: Pointer, client_pk: Pointer): Int
abstract fun crypto_kx_sessionkeybytes(): Long
abstract fun crypto_onetimeauth(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_onetimeauth_bytes(): Long
abstract fun crypto_onetimeauth_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_onetimeauth_init(state: Pointer, key: ByteArray): Int
abstract fun crypto_onetimeauth_keybytes(): Long
abstract fun crypto_onetimeauth_keygen(k: ByteArray): Unit
abstract fun crypto_onetimeauth_poly1305(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_onetimeauth_poly1305_bytes(): Long
abstract fun crypto_onetimeauth_poly1305_final(state: Pointer, out: ByteArray): Int
abstract fun crypto_onetimeauth_poly1305_init(state: Pointer, key: ByteArray): Int
abstract fun crypto_onetimeauth_poly1305_keybytes(): Long
abstract fun crypto_onetimeauth_poly1305_keygen(k: ByteArray): Unit
abstract fun crypto_onetimeauth_poly1305_statebytes(): Long
abstract fun crypto_onetimeauth_poly1305_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_onetimeauth_poly1305_verify(h: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_onetimeauth_primitive(): String
abstract fun crypto_onetimeauth_statebytes(): Long
abstract fun crypto_onetimeauth_update(state: Pointer, in: ByteArray, inlen: Long): Int
abstract fun crypto_onetimeauth_verify(h: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_pwhash(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: Pointer, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_alg_argon2i13(): Int
abstract fun crypto_pwhash_alg_argon2id13(): Int
abstract fun crypto_pwhash_alg_default(): Int
abstract fun crypto_pwhash_argon2i(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: ByteArray, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_argon2i_alg_argon2i13(): Int
abstract fun crypto_pwhash_argon2i_bytes_max(): Long
abstract fun crypto_pwhash_argon2i_bytes_min(): Long
abstract fun crypto_pwhash_argon2i_memlimit_interactive(): Long
abstract fun crypto_pwhash_argon2i_memlimit_max(): Long
abstract fun crypto_pwhash_argon2i_memlimit_min(): Long
abstract fun crypto_pwhash_argon2i_memlimit_moderate(): Long
abstract fun crypto_pwhash_argon2i_memlimit_sensitive(): Long
abstract fun crypto_pwhash_argon2i_opslimit_interactive(): Long
abstract fun crypto_pwhash_argon2i_opslimit_max(): Long
abstract fun crypto_pwhash_argon2i_opslimit_min(): Long
abstract fun crypto_pwhash_argon2i_opslimit_moderate(): Long
abstract fun crypto_pwhash_argon2i_opslimit_sensitive(): Long
abstract fun crypto_pwhash_argon2i_passwd_max(): Long
abstract fun crypto_pwhash_argon2i_passwd_min(): Long
abstract fun crypto_pwhash_argon2i_saltbytes(): Long
abstract fun crypto_pwhash_argon2i_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2i_str_needs_rehash(str: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2i_str_verify(str: ByteArray, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_argon2i_strbytes(): Long
abstract fun crypto_pwhash_argon2i_strprefix(): String
abstract fun crypto_pwhash_argon2id(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: ByteArray, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_argon2id_alg_argon2id13(): Int
abstract fun crypto_pwhash_argon2id_bytes_max(): Long
abstract fun crypto_pwhash_argon2id_bytes_min(): Long
abstract fun crypto_pwhash_argon2id_memlimit_interactive(): Long
abstract fun crypto_pwhash_argon2id_memlimit_max(): Long
abstract fun crypto_pwhash_argon2id_memlimit_min(): Long
abstract fun crypto_pwhash_argon2id_memlimit_moderate(): Long
abstract fun crypto_pwhash_argon2id_memlimit_sensitive(): Long
abstract fun crypto_pwhash_argon2id_opslimit_interactive(): Long
abstract fun crypto_pwhash_argon2id_opslimit_max(): Long
abstract fun crypto_pwhash_argon2id_opslimit_min(): Long
abstract fun crypto_pwhash_argon2id_opslimit_moderate(): Long
abstract fun crypto_pwhash_argon2id_opslimit_sensitive(): Long
abstract fun crypto_pwhash_argon2id_passwd_max(): Long
abstract fun crypto_pwhash_argon2id_passwd_min(): Long
abstract fun crypto_pwhash_argon2id_saltbytes(): Long
abstract fun crypto_pwhash_argon2id_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2id_str_needs_rehash(str: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_argon2id_str_verify(str: ByteArray, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_argon2id_strbytes(): Long
abstract fun crypto_pwhash_argon2id_strprefix(): String
abstract fun crypto_pwhash_bytes_max(): Long
abstract fun crypto_pwhash_bytes_min(): Long
abstract fun crypto_pwhash_memlimit_interactive(): Long
abstract fun crypto_pwhash_memlimit_max(): Long
abstract fun crypto_pwhash_memlimit_min(): Long
abstract fun crypto_pwhash_memlimit_moderate(): Long
abstract fun crypto_pwhash_memlimit_sensitive(): Long
abstract fun crypto_pwhash_opslimit_interactive(): Long
abstract fun crypto_pwhash_opslimit_max(): Long
abstract fun crypto_pwhash_opslimit_min(): Long
abstract fun crypto_pwhash_opslimit_moderate(): Long
abstract fun crypto_pwhash_opslimit_sensitive(): Long
abstract fun crypto_pwhash_passwd_max(): Long
abstract fun crypto_pwhash_passwd_min(): Long
abstract fun crypto_pwhash_primitive(): String
abstract fun crypto_pwhash_saltbytes(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256(out: ByteArray, outlen: Long, passwd: ByteArray, passwdlen: Long, salt: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_bytes_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_bytes_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_ll(passwd: ByteArray, passwdlen: Long, salt: ByteArray, saltlen: Long, N: Long, r: Int, p: Int, buf: ByteArray, buflen: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_interactive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_memlimit_sensitive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_interactive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_opslimit_sensitive(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_passwd_max(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_passwd_min(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_saltbytes(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_str_needs_rehash(str: ByteArray, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_str_verify(str: ByteArray, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_scryptsalsa208sha256_strbytes(): Long
abstract fun crypto_pwhash_scryptsalsa208sha256_strprefix(): String
abstract fun crypto_pwhash_str(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_str_alg(out: ByteArray, passwd: ByteArray, passwdlen: Long, opslimit: Long, memlimit: Long, alg: Int): Int
abstract fun crypto_pwhash_str_needs_rehash(str: Pointer, opslimit: Long, memlimit: Long): Int
abstract fun crypto_pwhash_str_verify(str: Pointer, passwd: ByteArray, passwdlen: Long): Int
abstract fun crypto_pwhash_strbytes(): Long
abstract fun crypto_pwhash_strprefix(): String
abstract fun crypto_scalarmult(q: Pointer, n: Pointer, p: Pointer): Int
abstract fun crypto_scalarmult_base(q: Pointer, n: Pointer): Int
abstract fun crypto_scalarmult_bytes(): Long
abstract fun crypto_scalarmult_curve25519(q: ByteArray, n: ByteArray, p: ByteArray): Int
abstract fun crypto_scalarmult_curve25519_base(q: ByteArray, n: ByteArray): Int
abstract fun crypto_scalarmult_curve25519_bytes(): Long
abstract fun crypto_scalarmult_curve25519_scalarbytes(): Long
abstract fun crypto_scalarmult_ed25519(q: ByteArray, n: ByteArray, p: ByteArray): Int
abstract fun crypto_scalarmult_ed25519_base(q: ByteArray, n: ByteArray): Int
abstract fun crypto_scalarmult_ed25519_bytes(): Long
abstract fun crypto_scalarmult_ed25519_scalarbytes(): Long
abstract fun crypto_scalarmult_primitive(): String
abstract fun crypto_scalarmult_scalarbytes(): Long
abstract fun crypto_secretbox(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_boxzerobytes(): Long
abstract fun crypto_secretbox_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_easy(c: Pointer, m: Pointer, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_easy(c: ByteArray, m: ByteArray, mlen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_keybytes(): Long
abstract fun crypto_secretbox_keygen(k: Pointer): Unit
abstract fun crypto_secretbox_macbytes(): Long
abstract fun crypto_secretbox_messagebytes_max(): Long
abstract fun crypto_secretbox_noncebytes(): Long
abstract fun crypto_secretbox_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_open_easy(m: Pointer, c: Pointer, clen: Long, n: Pointer, k: Pointer): Int
abstract fun crypto_secretbox_primitive(): String
abstract fun crypto_secretbox_xchacha20poly1305_detached(c: ByteArray, mac: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xchacha20poly1305_easy(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xchacha20poly1305_keybytes(): Long
abstract fun crypto_secretbox_xchacha20poly1305_macbytes(): Long
abstract fun crypto_secretbox_xchacha20poly1305_messagebytes_max(): Long
abstract fun crypto_secretbox_xchacha20poly1305_noncebytes(): Long
abstract fun crypto_secretbox_xchacha20poly1305_open_detached(m: ByteArray, c: ByteArray, mac: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xchacha20poly1305_open_easy(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xsalsa20poly1305(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xsalsa20poly1305_boxzerobytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_keybytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_keygen(k: ByteArray): Unit
abstract fun crypto_secretbox_xsalsa20poly1305_macbytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_messagebytes_max(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_noncebytes(): Long
abstract fun crypto_secretbox_xsalsa20poly1305_open(m: ByteArray, c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_secretbox_xsalsa20poly1305_zerobytes(): Long
abstract fun crypto_secretbox_zerobytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_abytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_headerbytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_init_pull(state: Pointer, : ByteArray, k: Pointer): Int
abstract fun crypto_secretstream_xchacha20poly1305_init_push(state: Pointer, : ByteArray, k: Pointer): Int
abstract fun crypto_secretstream_xchacha20poly1305_keybytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_keygen(k: Pointer): Unit
abstract fun crypto_secretstream_xchacha20poly1305_messagebytes_max(): Long
abstract fun crypto_secretstream_xchacha20poly1305_pull(state: Pointer, m: ByteArray, mlen_p: LongLongByReference, tag_p: ByteByReference, c: ByteArray, clen: Long, ad: ByteArray, adlen: Long): Int
abstract fun crypto_secretstream_xchacha20poly1305_push(state: Pointer, c: ByteArray, clen_p: LongLongByReference, m: ByteArray, mlen: Long, ad: ByteArray, adlen: Long, tag: Byte): Int
abstract fun crypto_secretstream_xchacha20poly1305_rekey(state: Pointer): Unit
abstract fun crypto_secretstream_xchacha20poly1305_statebytes(): Long
abstract fun crypto_secretstream_xchacha20poly1305_tag_final(): Char
abstract fun crypto_secretstream_xchacha20poly1305_tag_message(): Char
abstract fun crypto_secretstream_xchacha20poly1305_tag_push(): Char
abstract fun crypto_secretstream_xchacha20poly1305_tag_rekey(): Char
abstract fun crypto_shorthash(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_shorthash_bytes(): Long
abstract fun crypto_shorthash_keybytes(): Long
abstract fun crypto_shorthash_keygen(k: ByteArray): Unit
abstract fun crypto_shorthash_primitive(): String
abstract fun crypto_shorthash_siphash24(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_shorthash_siphash24_bytes(): Long
abstract fun crypto_shorthash_siphash24_keybytes(): Long
abstract fun crypto_shorthash_siphashx24(out: ByteArray, in: ByteArray, inlen: Long, k: ByteArray): Int
abstract fun crypto_shorthash_siphashx24_bytes(): Long
abstract fun crypto_shorthash_siphashx24_keybytes(): Long
abstract fun crypto_sign(sm: ByteArray, @Nullable smlen_p: LongLongByReference?, m: ByteArray, mlen: Long, sk: Pointer): Int
abstract fun crypto_sign_bytes(): Long
abstract fun crypto_sign_detached(sig: ByteArray, @Nullable siglen_p: LongLongByReference?, m: ByteArray, mlen: Long, sk: Pointer): Int
abstract fun crypto_sign_detached(sig: Pointer, @Nullable siglen_p: LongLongByReference?, m: Pointer, mlen: Long, sk: Pointer): Int
abstract fun crypto_sign_ed25519(sm: ByteArray, smlen_p: LongLongByReference, m: ByteArray, mlen: Long, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_bytes(): Long
abstract fun crypto_sign_ed25519_detached(sig: ByteArray, siglen_p: LongLongByReference, m: ByteArray, mlen: Long, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_keypair(pk: ByteArray, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_messagebytes_max(): Long
abstract fun crypto_sign_ed25519_open(m: ByteArray, mlen_p: LongLongByReference, sm: ByteArray, smlen: Long, pk: ByteArray): Int
abstract fun crypto_sign_ed25519_pk_to_curve25519(curve25519_pk: Pointer, ed25519_pk: Pointer): Int
abstract fun crypto_sign_ed25519_publickeybytes(): Long
abstract fun crypto_sign_ed25519_secretkeybytes(): Long
abstract fun crypto_sign_ed25519_seed_keypair(pk: ByteArray, sk: ByteArray, seed: ByteArray): Int
abstract fun crypto_sign_ed25519_seedbytes(): Long
abstract fun crypto_sign_ed25519_sk_to_curve25519(curve25519_sk: Pointer, ed25519_sk: Pointer): Int
abstract fun crypto_sign_ed25519_sk_to_pk(pk: Pointer, sk: Pointer): Int
abstract fun crypto_sign_ed25519_sk_to_seed(seed: ByteArray, sk: ByteArray): Int
abstract fun crypto_sign_ed25519_verify_detached(sig: ByteArray, m: ByteArray, mlen: Long, pk: ByteArray): Int
abstract fun crypto_sign_ed25519ph_final_create(state: Pointer, sig: ByteArray, siglen_p: LongLongByReference, sk: ByteArray): Int
abstract fun crypto_sign_ed25519ph_final_verify(state: Pointer, sig: ByteArray, pk: ByteArray): Int
abstract fun crypto_sign_ed25519ph_init(state: Pointer): Int
abstract fun crypto_sign_ed25519ph_statebytes(): Long
abstract fun crypto_sign_ed25519ph_update(state: Pointer, m: ByteArray, mlen: Long): Int
abstract fun crypto_sign_final_create(state: Pointer, sig: ByteArray, siglen_p: LongLongByReference, sk: ByteArray): Int
abstract fun crypto_sign_final_verify(state: Pointer, sig: ByteArray, pk: ByteArray): Int
abstract fun crypto_sign_init(state: Pointer): Int
abstract fun crypto_sign_keypair(pk: Pointer, sk: Pointer): Int
abstract fun crypto_sign_messagebytes_max(): Long
abstract fun crypto_sign_open(m: ByteArray, mlen_p: LongLongByReference, sm: ByteArray, smlen: Long, pk: Pointer): Int
abstract fun crypto_sign_primitive(): String
abstract fun crypto_sign_publickeybytes(): Long
abstract fun crypto_sign_secretkeybytes(): Long
abstract fun crypto_sign_seed_keypair(pk: Pointer, sk: Pointer, seed: Pointer): Int
abstract fun crypto_sign_seedbytes(): Long
abstract fun crypto_sign_statebytes(): Long
abstract fun crypto_sign_update(state: Pointer, m: ByteArray, mlen: Long): Int
abstract fun crypto_sign_verify_detached(sig: Pointer, m: Pointer, mlen: Long, pk: Pointer): Int
abstract fun crypto_sign_verify_detached(sig: ByteArray, m: ByteArray, mlen: Long, pk: Pointer): Int
abstract fun crypto_stream(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_ietf(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_ietf_keybytes(): Long
abstract fun crypto_stream_chacha20_ietf_keygen(k: ByteArray): Unit
abstract fun crypto_stream_chacha20_ietf_messagebytes_max(): Long
abstract fun crypto_stream_chacha20_ietf_noncebytes(): Long
abstract fun crypto_stream_chacha20_ietf_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_ietf_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Int, k: ByteArray): Int
abstract fun crypto_stream_chacha20_keybytes(): Long
abstract fun crypto_stream_chacha20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_chacha20_messagebytes_max(): Long
abstract fun crypto_stream_chacha20_noncebytes(): Long
abstract fun crypto_stream_chacha20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_chacha20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_stream_keybytes(): Long
abstract fun crypto_stream_keygen(k: ByteArray): Unit
abstract fun crypto_stream_messagebytes_max(): Long
abstract fun crypto_stream_noncebytes(): Long
abstract fun crypto_stream_primitive(): String
abstract fun crypto_stream_salsa20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa2012(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa2012_keybytes(): Long
abstract fun crypto_stream_salsa2012_keygen(k: ByteArray): Unit
abstract fun crypto_stream_salsa2012_messagebytes_max(): Long
abstract fun crypto_stream_salsa2012_noncebytes(): Long
abstract fun crypto_stream_salsa2012_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa208(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa208_keybytes(): Long
abstract fun crypto_stream_salsa208_keygen(k: ByteArray): Unit
abstract fun crypto_stream_salsa208_messagebytes_max(): Long
abstract fun crypto_stream_salsa208_noncebytes(): Long
abstract fun crypto_stream_salsa208_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa20_keybytes(): Long
abstract fun crypto_stream_salsa20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_salsa20_messagebytes_max(): Long
abstract fun crypto_stream_salsa20_noncebytes(): Long
abstract fun crypto_stream_salsa20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_salsa20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_stream_xchacha20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xchacha20_keybytes(): Long
abstract fun crypto_stream_xchacha20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_xchacha20_messagebytes_max(): Long
abstract fun crypto_stream_xchacha20_noncebytes(): Long
abstract fun crypto_stream_xchacha20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xchacha20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_stream_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xsalsa20(c: ByteArray, clen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xsalsa20_keybytes(): Long
abstract fun crypto_stream_xsalsa20_keygen(k: ByteArray): Unit
abstract fun crypto_stream_xsalsa20_messagebytes_max(): Long
abstract fun crypto_stream_xsalsa20_noncebytes(): Long
abstract fun crypto_stream_xsalsa20_xor(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, k: ByteArray): Int
abstract fun crypto_stream_xsalsa20_xor_ic(c: ByteArray, m: ByteArray, mlen: Long, n: ByteArray, ic: Long, k: ByteArray): Int
abstract fun crypto_verify_16(x: ByteArray, y: ByteArray): Int
abstract fun crypto_verify_16_bytes(): Long
abstract fun crypto_verify_32(x: ByteArray, y: ByteArray): Int
abstract fun crypto_verify_32_bytes(): Long
abstract fun crypto_verify_64(x: ByteArray, y: ByteArray): Int
abstract fun crypto_verify_64_bytes(): Long
abstract fun implementation_name(): String
abstract fun random(): Int
abstract fun randombytes(buf: ByteArray, buf_len: Long): Unit
abstract fun randombytes_buf(buf: Pointer, size: Long): Unit
abstract fun randombytes_buf_deterministic(buf: ByteArray, size: Long, seed: ByteArray): Unit
abstract fun randombytes_close(): Int
abstract fun randombytes_implementation_name(): String
abstract fun randombytes_random(): Int
abstract fun randombytes_seedbytes(): Long
abstract fun randombytes_set_implementation(impl: Pointer): Int
abstract fun randombytes_stir(): Unit
abstract fun randombytes_uniform(upper_bound: Int): Int
abstract fun sodium_add(a: Pointer, b: Pointer, len: Long): Unit
abstract fun sodium_allocarray(count: Long, size: Long): Pointer
abstract fun sodium_base642bin(bin: ByteArray, bin_maxlen: Long, b64: ByteArray, b64_len: Long, ignore: ByteArray, bin_len: LongLongByReference, b64_end: Pointer, variant: Int): Int
abstract fun sodium_base64_encoded_len(bin_len: Long, variant: Int): Long
abstract fun sodium_compare(b1_: Pointer, b2_: Pointer, len: Long): Int
abstract fun sodium_free(ptr: Pointer): Unit
abstract fun sodium_hex2bin(bin: ByteArray, bin_maxlen: Long, hex: ByteArray, hex_len: Long, ignore: ByteArray, bin_len: LongLongByReference, hex_end: Pointer): Int
abstract fun sodium_increment(n: Pointer, nlen: Long): Unit
abstract fun sodium_init(): Int
abstract fun sodium_is_zero(n: Pointer, nlen: Long): Int
abstract fun sodium_library_minimal(): Int
abstract fun sodium_library_version_major(): Int
abstract fun sodium_library_version_minor(): Int
abstract fun sodium_malloc(size: Long): Pointer
abstract fun sodium_memcmp(b1_: Pointer, b2_: Pointer, len: Long): Int
abstract fun sodium_memzero(pnt: Pointer, len: Long): Unit
abstract fun sodium_misuse(): Unit
abstract fun sodium_mlock(addr: Pointer, len: Long): Int
abstract fun sodium_mprotect_noaccess(ptr: Pointer): Int
abstract fun sodium_mprotect_readonly(ptr: Pointer): Int
abstract fun sodium_mprotect_readwrite(ptr: Pointer): Int
abstract fun sodium_munlock(addr: Pointer, len: Long): Int
abstract fun sodium_pad(padded_buflen_p: LongLongByReference, buf: ByteArray, unpadded_buflen: Long, blocksize: Long, max_buflen: Long): Int
abstract fun sodium_runtime_has_aesni(): Int
abstract fun sodium_runtime_has_avx(): Int
abstract fun sodium_runtime_has_avx2(): Int
abstract fun sodium_runtime_has_avx512f(): Int
abstract fun sodium_runtime_has_neon(): Int
abstract fun sodium_runtime_has_pclmul(): Int
abstract fun sodium_runtime_has_rdrand(): Int
abstract fun sodium_runtime_has_sse2(): Int
abstract fun sodium_runtime_has_sse3(): Int
abstract fun sodium_runtime_has_sse41(): Int
abstract fun sodium_runtime_has_ssse3(): Int
abstract fun sodium_set_misuse_handler(handler: Pointer): Int
abstract fun sodium_stackzero(len: Long): Unit
abstract fun sodium_unpad(unpadded_buflen_p: LongLongByReference, buf: ByteArray, padded_buflen: Long, blocksize: Long): Int
abstract fun sodium_version_string(): String
abstract fun stir(): Unit
abstract fun uniform(upper_bound: Int): Int
class PasswordHash
Module Contents
PasswordHash()
class Algorithm
class Salt
class VerificationResult
static fun checkHash(hash: String, password: String): VerificationResult
static fun checkHash(hash: String, password: String, opsLimit: Long, memLimit: Long): VerificationResult
static fun checkHashForInteractive(hash: String, password: String): VerificationResult
static fun checkHashForSensitive(hash: String, password: String): VerificationResult
static fun hash(password: String, length: Int, salt: Salt): Bytes
static fun hash(password: Bytes, length: Int, salt: Salt): Bytes
static fun hash(password: ByteArray, length: Int, salt: Salt): ByteArray
static fun hash(password: String, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hash(password: Bytes, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hash(password: ByteArray, length: Int, salt: Salt, algorithm: Algorithm): ByteArray
static fun hash(password: String, length: Int, salt: Salt, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes
static fun hash(password: Bytes, length: Int, salt: Salt, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes
static fun hash(password: ByteArray, length: Int, salt: Salt, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray
static fun hash(password: String): String
static fun hash(password: String, opsLimit: Long, memLimit: Long): String
static fun hashInteractive(password: String, length: Int, salt: Salt): Bytes
static fun hashInteractive(password: Bytes, length: Int, salt: Salt): Bytes
static fun hashInteractive(password: ByteArray, length: Int, salt: Salt): ByteArray
static fun hashInteractive(password: String, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashInteractive(password: Bytes, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashInteractive(password: ByteArray, length: Int, salt: Salt, algorithm: Algorithm): ByteArray
static fun hashInteractive(password: String): String
static fun hashSensitive(password: String, length: Int, salt: Salt): Bytes
static fun hashSensitive(password: Bytes, length: Int, salt: Salt): Bytes
static fun hashSensitive(password: ByteArray, length: Int, salt: Salt): ByteArray
static fun hashSensitive(password: String, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashSensitive(password: Bytes, length: Int, salt: Salt, algorithm: Algorithm): Bytes
static fun hashSensitive(password: ByteArray, length: Int, salt: Salt, algorithm: Algorithm): ByteArray
static fun hashSensitive(password: String): String
static fun interactiveMemLimit(): Long
static fun interactiveOpsLimit(): Long
static fun maxHashLength(): Int
static fun maxMemLimit(): Long
static fun maxOpsLimit(): Long
static fun minHashLength(): Int
static fun minMemLimit(): Long
static fun minOpsLimit(): Long
static fun moderateMemLimit(): Long
static fun moderateOpsLimit(): Long
static fun needsRehash(hash: String): Boolean
static fun needsRehash(hash: String, opsLimit: Long, memLimit: Long): Boolean
static fun needsRehashForInteractive(hash: String): Boolean
static fun needsRehashForSensitive(hash: String): Boolean
static fun sensitiveMemLimit(): Long
static fun sensitiveOpsLimit(): Long
static fun verify(hash: String, password: String): Boolean
open class SHA256Hash
class SecretBox
Module Contents
class Key : Destroyable
class Nonce : Destroyable
@Nullable static fun decrypt(cipherText: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: Allocated, key: Key, nonce: Nonce): Allocated?
@Nullable static fun decrypt(cipherText: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, password: String): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, password: String): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, password: String): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, password: String): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptInteractive(cipherText: Bytes, password: String): Bytes?
@Nullable static fun decryptInteractive(cipherText: ByteArray, password: String): ByteArray?
@Nullable static fun decryptInteractive(cipherText: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptInteractive(cipherText: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptInteractiveDetached(cipherText: Bytes, mac: Bytes, password: String): Bytes?
@Nullable static fun decryptInteractiveDetached(cipherText: ByteArray, mac: ByteArray, password: String): ByteArray?
@Nullable static fun decryptInteractiveDetached(cipherText: Bytes, mac: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptInteractiveDetached(cipherText: ByteArray, mac: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptSensitive(cipherText: Bytes, password: String): Bytes?
@Nullable static fun decryptSensitive(cipherText: ByteArray, password: String): ByteArray?
@Nullable static fun decryptSensitive(cipherText: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptSensitive(cipherText: ByteArray, password: String, algorithm: Algorithm): ByteArray?
@Nullable static fun decryptSensitiveDetached(cipherText: Bytes, mac: Bytes, password: String): Bytes?
@Nullable static fun decryptSensitiveDetached(cipherText: ByteArray, mac: ByteArray, password: String): ByteArray?
@Nullable static fun decryptSensitiveDetached(cipherText: Bytes, mac: Bytes, password: String, algorithm: Algorithm): Bytes?
@Nullable static fun decryptSensitiveDetached(cipherText: ByteArray, mac: ByteArray, password: String, algorithm: Algorithm): ByteArray?
static fun encrypt(message: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: Allocated, key: Key, nonce: Nonce): Allocated
static fun encrypt(message: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, password: String): Bytes
static fun encrypt(message: ByteArray, password: String): ByteArray
static fun encrypt(message: Bytes, password: String, algorithm: Algorithm): Bytes
static fun encrypt(message: ByteArray, password: String, algorithm: Algorithm): ByteArray
static fun encrypt(message: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): Bytes
static fun encrypt(message: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): ByteArray
static fun encryptDetached(message: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, password: String): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, password: String): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, password: String, opsLimit: Long, memLimit: Long, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptInteractive(message: Bytes, password: String): Bytes
static fun encryptInteractive(message: ByteArray, password: String): ByteArray
static fun encryptInteractive(message: Bytes, password: String, algorithm: Algorithm): Bytes
static fun encryptInteractive(message: ByteArray, password: String, algorithm: Algorithm): ByteArray
static fun encryptInteractiveDetached(message: Bytes, password: String): DetachedEncryptionResult
static fun encryptInteractiveDetached(message: ByteArray, password: String): DetachedEncryptionResult
static fun encryptInteractiveDetached(message: Bytes, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptInteractiveDetached(message: ByteArray, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptSensitive(message: Bytes, password: String): Bytes
static fun encryptSensitive(message: ByteArray, password: String): ByteArray
static fun encryptSensitive(message: Bytes, password: String, algorithm: Algorithm): Bytes
static fun encryptSensitive(message: ByteArray, password: String, algorithm: Algorithm): ByteArray
static fun encryptSensitiveDetached(message: Bytes, password: String): DetachedEncryptionResult
static fun encryptSensitiveDetached(message: ByteArray, password: String): DetachedEncryptionResult
static fun encryptSensitiveDetached(message: Bytes, password: String, algorithm: Algorithm): DetachedEncryptionResult
static fun encryptSensitiveDetached(message: ByteArray, password: String, algorithm: Algorithm): DetachedEncryptionResult
interface SecretDecryptionStream : Destroyable
interface SecretEncryptionStream : Destroyable
class Signature
Module Contents
class KeyPair
class PublicKey
class SecretKey : Destroyable
class Seed
static fun sign(message: Bytes, secretKey: SecretKey): Bytes
static fun sign(message: ByteArray, secretKey: SecretKey): ByteArray
static fun signDetached(message: Bytes, secretKey: SecretKey): Bytes
static fun signDetached(message: Allocated, secretKey: SecretKey): Allocated
static fun signDetached(message: ByteArray, secretKey: SecretKey): ByteArray
static fun verify(signed: Bytes, publicKey: PublicKey): Bytes
static fun verify(signed: ByteArray, publicKey: PublicKey): ByteArray
static fun verifyDetached(message: Bytes, signature: Bytes, publicKey: PublicKey): Boolean
static fun verifyDetached(message: Allocated, signature: Allocated, publicKey: PublicKey): Boolean
static fun verifyDetached(message: ByteArray, signature: ByteArray, publicKey: PublicKey): Boolean
class Sodium
class SodiumException : RuntimeException
class SodiumVersion : Comparable<SodiumVersion>
class XChaCha20Poly1305
Module Contents
class Key : Destroyable
class Nonce
@Nullable static fun decrypt(cipherText: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decrypt(cipherText: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decrypt(cipherText: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
static fun decryptDetached(cipherText: Bytes, mac: Bytes, key: Key, nonce: Nonce): Bytes
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, key: Key, nonce: Nonce): ByteArray?
@Nullable static fun decryptDetached(cipherText: Bytes, mac: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes?
@Nullable static fun decryptDetached(cipherText: ByteArray, mac: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray?
static fun encrypt(message: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encrypt(message: Bytes, data: Bytes, key: Key, nonce: Nonce): Bytes
static fun encrypt(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): ByteArray
static fun encryptDetached(message: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: Bytes, data: Bytes, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun encryptDetached(message: ByteArray, data: ByteArray, key: Key, nonce: Nonce): DetachedEncryptionResult
static fun isAvailable(): Boolean
static fun isSecretStreamAvailable(): Boolean
static fun openDecryptionStream(key: Key, : ByteArray): SecretDecryptionStream
static fun openEncryptionStream(key: Key): SecretEncryptionStream
package org.apache.tuweni.devp2p
Module Contents
const val DEVP2P_BUCKET_SIZE: Int
class DevP2PPeerRoutingTable : PeerRoutingTable
interface DiscoveryService
Module Contents
abstract suspend fun awaitBootstrap(): Int
abstract suspend fun awaitTermination(): Unit
abstract fun awaitTerminationAsync(): AsyncCompletion
abstract val expiredPackets: Long
abstract val filteredPackets: Long
abstract val invalidPackets: Long
abstract val isShutdown: Boolean
abstract val isTerminated: Boolean
abstract val localPort: Int
abstract suspend fun lookup(target: PublicKey): List<Peer>
abstract fun lookupAsync(target: PublicKey): AsyncResult<List<Peer>>
abstract val nodeId: PublicKey
@JvmOverloads fun open(keyPair: KeyPair, port: Int = 0, host: String? = null, seq: Long = Instant.now().toEpochMilli(), enrData: Map<String, Bytes> = emptyMap(), bootstrapURIs: List<URI> = emptyList(), peerRepository: PeerRepository = EphemeralPeerRepository(), advertiseAddress: InetAddress? = null, advertiseUdpPort: Int? = null, advertiseTcpPort: Int? = null, routingTable: PeerRoutingTable = DevP2PPeerRoutingTable(keyPair.publicKey()), packetFilter: (PublicKey, InetSocketAddress) -> Boolean = null, loggerProvider: LoggerProvider = LoggerProvider.nullProvider(), channelGroup: CoroutineChannelGroup = CommonCoroutineGroup, bufferAllocator: () -> ByteBuffer = DEFAULT_BUFFER_ALLOCATOR, timeSupplier: () -> Long = CURRENT_TIME_SUPPLIER): DiscoveryService
@JvmOverloads fun open(keyPair: KeyPair, bindAddress: InetSocketAddress, seq: Long = Instant.now().toEpochMilli(), enrData: Map<String, Bytes> = emptyMap(), bootstrapURIs: List<URI> = emptyList(), peerRepository: PeerRepository = EphemeralPeerRepository(), advertiseAddress: InetAddress? = null, advertiseUdpPort: Int? = null, advertiseTcpPort: Int? = null, routingTable: PeerRoutingTable = DevP2PPeerRoutingTable(keyPair.publicKey()), packetFilter: (PublicKey, InetSocketAddress) -> Boolean = null, loggerProvider: LoggerProvider = LoggerProvider.nullProvider(), channelGroup: CoroutineChannelGroup = CommonCoroutineGroup, bufferAllocator: () -> ByteBuffer = DEFAULT_BUFFER_ALLOCATOR, timeSupplier: () -> Long = CURRENT_TIME_SUPPLIER): DiscoveryService
abstract val selfPackets: Long
abstract fun shutdown(): Unit
abstract fun shutdownNow(): Unit
abstract val unexpectedENRResponses: Long
abstract val unexpectedNeighbors: Long
abstract val unexpectedPongs: Long
abstract val unvalidatedPeerPackets: Long
data class Endpoint
data class EnodeUriComponents
class EphemeralPeerRepository : PeerRepository
class EthereumNodeRecord
Module Contents
EthereumNodeRecord(signature: Bytes, seq: Long, data: Map<String, Bytes>)
val data: Map<String, Bytes>
@JvmStatic fun fromRLP(rlp: Bytes): EthereumNodeRecord
fun ip(): InetAddress
fun publicKey(): PublicKey
val seq: Long
val signature: Bytes
fun tcp(): Int
@JvmOverloads @JvmStatic fun toRLP(signatureKeyPair: KeyPair, seq: Long = Instant.now().toEpochMilli(), data: Map<String, Bytes>? = null, ip: InetAddress, tcp: Int? = null, udp: Int? = null): Bytes
fun udp(): Int
fun validate(): Unit
interface Peer
interface PeerRepository
interface PeerRoutingTable : Set<Peer>
fun parseEnodeUri(uri: URI): EnodeUriComponents
package org.apache.tuweni.discovery
package org.apache.tuweni.eth
Module Contents
class Address
class Block
class BlockBody
class BlockHeader
Module Contents
BlockHeader(@Nullable : Hash?, : Hash, : Address, : Hash, : Hash, : Hash, : Bytes, : UInt256, : UInt256, : Gas, : Gas, : Instant, : Bytes, : Hash, : Bytes)
fun coinbase(): Address
fun difficulty(): UInt256
fun equals(: Any?): Boolean
fun extraData(): Bytes
static fun fromBytes(: Bytes): BlockHeader
fun gasLimit(): Gas
fun gasUsed(): Gas
fun hash(): Hash
fun hashCode(): Int
fun logsBloom(): Bytes
fun mixHash(): Hash
fun nonce(): Bytes
fun number(): UInt256
fun ommersHash(): Hash
@Nullable fun parentHash(): Hash?
static fun readFrom(: RLPReader): BlockHeader
fun receiptsRoot(): Hash
fun stateRoot(): Hash
fun timestamp(): Instant
fun toBytes(): Bytes
fun toString(): String
fun transactionsRoot(): Hash
class Hash
class Log
class LogsBloomFilter
class Transaction
Module Contents
Transaction(nonce: UInt256, gasPrice: Wei, gasLimit: Gas, @Nullable to: Address?, value: Wei, payload: Bytes, keyPair: KeyPair)
Transaction(nonce: UInt256, gasPrice: Wei, gasLimit: Gas, @Nullable to: Address?, value: Wei, payload: Bytes, keyPair: KeyPair, @Nullable chainId: Int?)
Transaction(nonce: UInt256, gasPrice: Wei, gasLimit: Gas, @Nullable to: Address?, value: Wei, payload: Bytes, @Nullable chainId: Int?, signature: Signature)
fun chainId(): Int
fun equals(other: Any?): Boolean
static fun fromBytes(encoded: Bytes): Transaction
static fun fromBytes(encoded: Bytes, lenient: Boolean): Transaction
fun gasLimit(): Gas
fun gasPrice(): Wei
fun hash(): Hash
fun hashCode(): Int
fun isContractCreation(): Boolean
fun nonce(): UInt256
fun payload(): Bytes
static fun readFrom(reader: RLPReader): Transaction
@Nullable fun sender(): Address?
fun signature(): Signature
@Nullable fun to(): Address?
fun toBytes(): Bytes
fun toString(): String
fun value(): Wei
fun writeTo(writer: RLPWriter): Unit
class TransactionReceipt
package org.apache.tuweni.eth.repository
Module Contents
enum class BlockHeaderFields
class BlockchainIndex : BlockchainIndexWriter, BlockchainIndexReader
Module Contents
BlockchainIndex(indexWriter: IndexWriter)
fun findBy(: BlockHeaderFields, : Bytes): List<Hash>
fun findBy(: BlockHeaderFields, : Long): List<Hash>
fun findBy(: BlockHeaderFields, : Gas): List<Hash>
fun findBy(: BlockHeaderFields, : UInt256): List<Hash>
fun findBy(: BlockHeaderFields, : Address): List<Hash>
fun findBy(: BlockHeaderFields, : Hash): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Bytes): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Int): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Long): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Gas): List<Hash>
fun findBy(field: TransactionReceiptFields, value: UInt256): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Address): List<Hash>
fun findBy(field: TransactionReceiptFields, value: Hash): List<Hash>
fun findByBlockHashAndIndex(blockHash: Hash, index: Int): Hash?
fun findByHashOrNumber(hashOrNumber: Bytes32): List<Hash>
fun findByLargest(: BlockHeaderFields): Hash?
fun findByLargest(field: TransactionReceiptFields): Hash?
fun findInRange(: BlockHeaderFields, : UInt256, : UInt256): List<Hash>
fun findInRange(field: TransactionReceiptFields, minValue: UInt256, maxValue: UInt256): List<Hash>
fun index(indexer: (BlockchainIndexWriter) -> Unit): Unit
fun indexBlockHeader(: BlockHeader): Unit
fun indexTransactionReceipt(: TransactionReceipt, : Int, : Hash, : Hash): Unit
fun totalDifficulty(hash: Hash): UInt256?
interface BlockchainIndexReader
Module Contents
abstract fun findBy(: BlockHeaderFields, : Bytes): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Long): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Gas): List<Hash>
abstract fun findBy(: BlockHeaderFields, : UInt256): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Address): List<Hash>
abstract fun findBy(: BlockHeaderFields, : Hash): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Bytes): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Int): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Long): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Gas): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: UInt256): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Address): List<Hash>
abstract fun findBy(field: TransactionReceiptFields, value: Hash): List<Hash>
abstract fun findByBlockHashAndIndex(blockHash: Hash, index: Int): Hash?
abstract fun findByHashOrNumber(hashOrNumber: Bytes32): List<Hash>
abstract fun findByLargest(: BlockHeaderFields): Hash?
abstract fun findByLargest(field: TransactionReceiptFields): Hash?
abstract fun findInRange(: BlockHeaderFields, : UInt256, : UInt256): List<Hash>
abstract fun findInRange(field: TransactionReceiptFields, minValue: UInt256, maxValue: UInt256): List<Hash>
abstract fun totalDifficulty(hash: Hash): UInt256?
interface BlockchainIndexWriter
class BlockchainRepository
Module Contents
BlockchainRepository(chainMetadata: KeyValueStore, blockBodyStore: KeyValueStore, : KeyValueStore, transactionReceiptsStore: KeyValueStore, blockchainIndex: BlockchainIndex)
val GENESIS_BLOCK: Bytes
fun findBlockByHashOrNumber(blockNumberOrBlockHash: Bytes32): List<Hash>
fun findBlocksByParentHash(parentHash: Hash): List<Hash>
suspend fun init(blockBodyStore: KeyValueStore, : KeyValueStore, chainMetadata: KeyValueStore, transactionReceiptsStore: KeyValueStore, blockchainIndex: BlockchainIndex, genesisBlock: Block): BlockchainRepository
suspend fun retrieveBlock(blockHash: Hash): Block?
suspend fun retrieveBlock(blockHash: Bytes): Block?
suspend fun retrieveBlockBody(blockHash: Hash): BlockBody?
suspend fun retrieveBlockBody(blockHash: Bytes): BlockBody?
suspend fun retrieveBlockBodyBytes(blockHash: Hash): Bytes?
suspend fun retrieveBlockBodyBytes(blockHash: Bytes): Bytes?
suspend fun retrieveBlockHeader(: Hash): BlockHeader?
suspend fun retrieveBlockHeader(: Bytes): BlockHeader?
suspend fun retrieveBlockHeaderBytes(: Hash): Bytes?
suspend fun retrieveBlockHeaderBytes(: Bytes): Bytes?
suspend fun retrieveChainHead(): Block?
suspend fun retrieveChainHeadHeader(): BlockHeader?
suspend fun retrieveGenesisBlock(): Block?
suspend fun retrieveTransactionReceipt(blockHash: Hash, index: Int): TransactionReceipt?
suspend fun retrieveTransactionReceipt(txHash: Hash): TransactionReceipt?
suspend fun retrieveTransactionReceipts(blockHash: Hash): List<TransactionReceipt?>
suspend fun storeBlock(block: Block): Unit
suspend fun storeBlockBody(blockHash: Hash, blockBody: BlockBody): Unit
suspend fun storeBlockHeader(: BlockHeader): Unit
suspend fun storeTransactionReceipt(transactionReceipt: TransactionReceipt, txIndex: Int, txHash: Hash, blockHash: Hash): Unit
suspend fun storeTransactionReceipts(vararg transactionReceipts: TransactionReceipt, txHash: Hash, blockHash: Hash): Unit
enum class TransactionReceiptFields
package org.apache.tuweni.ethash
package org.apache.tuweni.gossip
package org.apache.tuweni.hobbits
Module Contents
class HobbitsTransport : CoroutineScope
Module Contents
HobbitsTransport(vertx: Vertx, coroutineContext: CoroutineContext = Dispatchers.Default)
val coroutineContext: CoroutineContext
fun createHTTPEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9337, requestURI: String? = null, tls: Boolean = false, handler: (Message) -> Unit): Unit
fun createTCPEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9237, tls: Boolean = false, handler: (Message) -> Unit): Unit
fun createUDPEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9137, handler: (Message) -> Unit): Unit
fun createWSEndpoint(id: String = "default", networkInterface: String = "0.0.0.0", port: Int = 9037, requestURI: String? = null, tls: Boolean = false, handler: (Message) -> Unit): Unit
fun exceptionHandler(handler: (Throwable) -> Unit): Unit
suspend fun sendMessage(message: Message, transport: Transport, host: String, port: Int, requestURI: String = ""): Unit
suspend fun start(): Unit
fun stop(): Unit
class Message
class Relayer : CoroutineScope
enum class Transport
package org.apache.tuweni.io
package org.apache.tuweni.io.file
Module Contents
class Files
Module Contents
static fun atomicReplace(path: Path, bytes: ByteArray): Unit
static fun atomicReplace(path: Path, fn: IOConsumer<Writer>): Unit
static fun atomicReplace(path: Path, charset: Charset, fn: IOConsumer<Writer>): Unit
static fun copyResource(resourceName: String, destination: Path, vararg options: OpenOption): Path
static fun copyResource(classloader: ClassLoader, resourceName: String, destination: Path, vararg options: OpenOption): Path
static fun copyResource(resourceName: String, out: OutputStream): Long
static fun copyResource(classloader: ClassLoader, resourceName: String, out: OutputStream): Long
static fun createFileIfMissing(path: Path, vararg attrs: FileAttribute<*>): Boolean
static fun deleteRecursively(directory: Path): Unit
package org.apache.tuweni.junit
package org.apache.tuweni.kademlia
Module Contents
class KademliaRoutingTable<T> : Set<T>
Module Contents
KademliaRoutingTable(selfId: ByteArray, k: Int, maxReplacements: Int = k, nodeId: (T) -> ByteArray)
fun add(node: T): T?
fun clear(): Unit
fun contains(element: T): Boolean
fun containsAll(elements: Collection<T>): Boolean
@JvmStatic fun <T> create(selfId: ByteArray, k: Int, nodeId: Function<T, ByteArray>): KademliaRoutingTable<T>
@JvmStatic fun <T> create(selfId: ByteArray, k: Int, maxReplacements: Int, nodeId: Function<T, ByteArray>): KademliaRoutingTable<T>
fun evict(node: T): Boolean
fun isEmpty(): Boolean
fun iterator(): Iterator<T>
fun nearest(targetId: ByteArray, limit: Int): List<T>
val size: Int
kotlin.ByteArray
kotlin.collections.MutableList
package org.apache.tuweni.kv
package org.apache.tuweni.les
package org.apache.tuweni.net.coroutines
package org.apache.tuweni.net.tls
Module Contents
interface FingerprintRepository
class TLS
class TrustManagerFactories
Module Contents
static fun recordClientFingerprints(knownClientsFile: Path): TrustManagerFactory
static fun recordClientFingerprints(repository: FingerprintRepository): TrustManagerFactory
static fun recordClientFingerprints(knownClientsFile: Path, skipCASigned: Boolean): TrustManagerFactory
static fun recordClientFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustManagerFactory
static fun recordClientFingerprints(knownClientsFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun recordClientFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun recordServerFingerprints(knownServersFile: Path): TrustManagerFactory
static fun recordServerFingerprints(repository: FingerprintRepository): TrustManagerFactory
static fun recordServerFingerprints(knownServersFile: Path, skipCASigned: Boolean): TrustManagerFactory
static fun recordServerFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustManagerFactory
static fun recordServerFingerprints(knownServersFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun recordServerFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustClientOnFirstAccess(knownClientsFile: Path): TrustManagerFactory
static fun trustClientOnFirstAccess(repository: FingerprintRepository): TrustManagerFactory
static fun trustClientOnFirstAccess(knownClientsFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun trustClientOnFirstAccess(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun trustClientOnFirstAccess(knownClientsFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustClientOnFirstAccess(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustServerOnFirstUse(knownServersFile: Path): TrustManagerFactory
static fun trustServerOnFirstUse(repository: FingerprintRepository): TrustManagerFactory
static fun trustServerOnFirstUse(knownServersFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun trustServerOnFirstUse(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun trustServerOnFirstUse(knownServersFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun trustServerOnFirstUse(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistClients(knownClientsFile: Path): TrustManagerFactory
static fun whitelistClients(repository: FingerprintRepository): TrustManagerFactory
static fun whitelistClients(knownClientsFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistClients(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistClients(knownClientsFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistClients(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistServers(knownServersFile: Path): TrustManagerFactory
static fun whitelistServers(repository: FingerprintRepository): TrustManagerFactory
static fun whitelistServers(knownServersFile: Path, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistServers(repository: FingerprintRepository, acceptCASigned: Boolean): TrustManagerFactory
static fun whitelistServers(knownServersFile: Path, tmf: TrustManagerFactory): TrustManagerFactory
static fun whitelistServers(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustManagerFactory
class VertxTrustOptions
Module Contents
static fun recordClientFingerprints(knownClientsFile: Path): TrustOptions
static fun recordClientFingerprints(repository: FingerprintRepository): TrustOptions
static fun recordClientFingerprints(knownClientsFile: Path, skipCASigned: Boolean): TrustOptions
static fun recordClientFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustOptions
static fun recordClientFingerprints(knownClientsFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun recordClientFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun recordServerFingerprints(knownServersFile: Path): TrustOptions
static fun recordServerFingerprints(repository: FingerprintRepository): TrustOptions
static fun recordServerFingerprints(knownServersFile: Path, skipCASigned: Boolean): TrustOptions
static fun recordServerFingerprints(repository: FingerprintRepository, skipCASigned: Boolean): TrustOptions
static fun recordServerFingerprints(knownServersFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun recordServerFingerprints(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun trustClientOnFirstAccess(knownClientsFile: Path): TrustOptions
static fun trustClientOnFirstAccess(repository: FingerprintRepository): TrustOptions
static fun trustClientOnFirstAccess(knownClientsFile: Path, acceptCASigned: Boolean): TrustOptions
static fun trustClientOnFirstAccess(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun trustClientOnFirstAccess(knownClientsFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun trustClientOnFirstAccess(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun trustServerOnFirstUse(knownServersFile: Path): TrustOptions
static fun trustServerOnFirstUse(repository: FingerprintRepository): TrustOptions
static fun trustServerOnFirstUse(knownServersFile: Path, acceptCASigned: Boolean): TrustOptions
static fun trustServerOnFirstUse(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun trustServerOnFirstUse(knownServersFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun trustServerOnFirstUse(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun whitelistClients(knownClientsFile: Path): TrustOptions
static fun whitelistClients(repository: FingerprintRepository): TrustOptions
static fun whitelistClients(knownClientsFile: Path, acceptCASigned: Boolean): TrustOptions
static fun whitelistClients(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun whitelistClients(knownClientsFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun whitelistClients(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
static fun whitelistServers(knownServersFile: Path): TrustOptions
static fun whitelistServers(repository: FingerprintRepository): TrustOptions
static fun whitelistServers(knownServersFile: Path, acceptCASigned: Boolean): TrustOptions
static fun whitelistServers(repository: FingerprintRepository, acceptCASigned: Boolean): TrustOptions
static fun whitelistServers(knownServersFile: Path, tmf: TrustManagerFactory): TrustOptions
static fun whitelistServers(repository: FingerprintRepository, tmf: TrustManagerFactory): TrustOptions
package org.apache.tuweni.plumtree
Module Contents
class EphemeralPeerRepository : PeerRepository
interface MessageHashing
interface MessageListener
interface MessageSender
interface MessageValidator
interface Peer
interface PeerPruning
interface PeerRepository
class State
Module Contents
State(peerRepository: PeerRepository, messageHashingFunction: MessageHashing, messageSender: MessageSender, messageListener: MessageListener, messageValidator: MessageValidator, peerPruningFunction: PeerPruning)
State(peerRepository: PeerRepository, messageHashingFunction: MessageHashing, messageSender: MessageSender, messageListener: MessageListener, messageValidator: MessageValidator, peerPruningFunction: PeerPruning, graftDelay: Long, lazyQueueInterval: Long)
fun addPeer(peer: Peer): Unit
fun receiveGossipMessage(peer: Peer, attributes: String, message: Bytes, messageHash: Bytes): Unit
fun receiveGraftMessage(peer: Peer, messageHash: Bytes): Unit
fun receiveIHaveMessage(peer: Peer, messageHash: Bytes): Unit
fun receivePruneMessage(peer: Peer): Unit
fun removePeer(peer: Peer): Unit
fun sendGossipMessage(attributes: String, message: Bytes): Bytes
fun stop(): Unit
package org.apache.tuweni.plumtree.vertx
Module Contents
class VertxGossipServer
Module Contents
VertxGossipServer(vertx: Vertx, networkInterface: String, port: Int, messageHashing: MessageHashing, peerRepository: PeerRepository, payloadListener: MessageListener, @Nullable payloadValidator: MessageValidator?, @Nullable peerPruningFunction: PeerPruning?, graftDelay: Int, lazyQueueInterval: Int)
fun connectTo(host: String, port: Int): AsyncCompletion
fun gossip(attributes: String, message: Bytes): Unit
fun start(): AsyncCompletion
fun stop(): AsyncCompletion
package org.apache.tuweni.progpow
package org.apache.tuweni.relayer
package org.apache.tuweni.rlp
Module Contents
open class EndOfRLPException : RLPException
open class InvalidRLPEncodingException : RLPException
open class InvalidRLPTypeException : RLPException
class RLP
Module Contents
static fun <T : Any> decode(source: Bytes, fn: Function<RLPReader, T>): T
static fun <T : Any> decode(source: Bytes, lenient: Boolean, fn: Function<RLPReader, T>): T
static fun decodeBigInteger(source: Bytes): BigInteger
static fun decodeBigInteger(source: Bytes, lenient: Boolean): BigInteger
static fun decodeInt(source: Bytes): Int
static fun decodeInt(source: Bytes, lenient: Boolean): Int
static fun <T : Any> decodeList(source: Bytes, fn: Function<RLPReader, T>): T
static fun <T : Any> decodeList(source: Bytes, lenient: Boolean, fn: Function<RLPReader, T>): T
static fun decodeLong(source: Bytes): Long
static fun decodeLong(source: Bytes, lenient: Boolean): Long
static fun decodeString(source: Bytes): String
static fun decodeString(source: Bytes, lenient: Boolean): String
static fun decodeToList(source: Bytes, fn: BiConsumer<RLPReader, MutableList<Any>>): MutableList<Any>
static fun decodeToList(source: Bytes, lenient: Boolean, fn: BiConsumer<RLPReader, MutableList<Any>>): MutableList<Any>
static fun <T : Any> decodeToList(source: Bytes, fn: Function<RLPReader, T>): MutableList<T>
static fun <T : Any> decodeToList(source: Bytes, lenient: Boolean, fn: Function<RLPReader, T>): MutableList<T>
static fun decodeValue(source: Bytes): Bytes
static fun decodeValue(source: Bytes, lenient: Boolean): Bytes
static fun encode(fn: Consumer<RLPWriter>): Bytes
static fun encodeBigInteger(value: BigInteger): Bytes
static fun encodeByteArray(value: ByteArray): Bytes
static fun encodeInt(value: Int): Bytes
static fun encodeList(fn: Consumer<RLPWriter>): Bytes
static fun <T : Any> encodeList(elements: MutableList<T>, fn: BiConsumer<RLPWriter, T>): Bytes
static fun <T : ByteBuffer> encodeListTo(buffer: T, fn: Consumer<RLPWriter>): T
static fun encodeLong(value: Long): Bytes
static fun encodeString(str: String): Bytes
static fun <T : ByteBuffer> encodeTo(buffer: T, fn: Consumer<RLPWriter>): T
static fun encodeValue(value: Bytes): Bytes
static fun isList(value: Bytes): Boolean
open class RLPException : RuntimeException
interface RLPReader
interface RLPWriter
package org.apache.tuweni.rlpx
Module Contents
open class EthereumIESEncryptionEngine
Module Contents
EthereumIESEncryptionEngine(agree: BasicAgreement, kdf: DerivationFunction, mac: Mac, commonMac: ByteArray)
EthereumIESEncryptionEngine(agree: BasicAgreement, kdf: DerivationFunction, mac: Mac, commonMac: ByteArray, cipher: BufferedBlockCipher)
open fun getCipher(): BufferedBlockCipher
open fun getMac(): Mac
open fun init(forEncryption: Boolean, privParam: CipherParameters, pubParam: CipherParameters, params: CipherParameters): Unit
open fun init(publicKey: AsymmetricKeyParameter, params: CipherParameters, ephemeralKeyPairGenerator: EphemeralKeyPairGenerator): Unit
open fun init(privateKey: AsymmetricKeyParameter, params: CipherParameters, publicKeyParser: KeyParser): Unit
open fun processBlock(in: ByteArray, inOff: Int, inLen: Int): ByteArray
interface HandshakeMessage
open class InvalidMACException : RuntimeException
open class MemoryWireConnectionsRepository : WireConnectionRepository
class RLPxConnection
class RLPxConnectionFactory
Module Contents
RLPxConnectionFactory()
static fun createConnection(initiator: Boolean, initiatorMessage: Bytes, responderMessage: Bytes, ourEphemeralPrivateKey: SecretKey, peerEphemeralPublicKey: PublicKey, initiatorNonce: Bytes32, responderNonce: Bytes32, ourPublicKey: PublicKey, peerPublicKey: PublicKey): RLPxConnection
static fun createHandshake(keyPair: KeyPair, remotePublicKey: PublicKey, initAndResponse: Function<Bytes, AsyncResult<Bytes>>): AsyncResult<RLPxConnection>
static fun generateRandomBytes32(): Bytes32
static fun init(keyPair: KeyPair, remotePublicKey: PublicKey, ephemeralKeyPair: KeyPair, initiatorNonce: Bytes32): Bytes
static fun messageSize(msgBytes: Bytes): Int
static fun readResponse(response: Bytes, privateKey: SecretKey): HandshakeMessage
static fun respondToHandshake(initiatorMessageBytes: Bytes, keyPair: KeyPair, responseHandler: Consumer<Bytes>): RLPxConnection
class RLPxMessage
interface RLPxService
interface WireConnectionRepository
package org.apache.tuweni.rlpx.vertx
Module Contents
class VertxRLPxService : RLPxService
Module Contents
VertxRLPxService(vertx: Vertx, loggerProvider: LoggerProvider, listenPort: Int, networkInterface: String, advertisedPort: Int, identityKeyPair: KeyPair, subProtocols: MutableList<SubProtocol>, clientId: String)
VertxRLPxService(vertx: Vertx, loggerProvider: LoggerProvider, listenPort: Int, networkInterface: String, advertisedPort: Int, identityKeyPair: KeyPair, subProtocols: MutableList<SubProtocol>, clientId: String, repository: WireConnectionRepository)
fun actualPort(): Int
fun advertisedPort(): Int
fun broadcast(subProtocolIdentifier: SubProtocolIdentifier, messageType: Int, message: Bytes): Unit
fun connectTo(peerPublicKey: PublicKey, peerAddress: InetSocketAddress): AsyncCompletion
fun disconnect(connectionId: String, disconnectReason: DisconnectReason): Unit
fun repository(): WireConnectionRepository
fun send(subProtocolIdentifier: SubProtocolIdentifier, messageType: Int, connectionId: String, message: Bytes): Unit
fun start(): AsyncCompletion
fun stop(): AsyncCompletion
package org.apache.tuweni.rlpx.wire
Module Contents
class DefaultWireConnection : WireConnection
Module Contents
DefaultWireConnection(id: String, nodeId: Bytes, peerNodeId: Bytes, logger: Logger, writer: Consumer<RLPxMessage>, afterHandshakeListener: Consumer<HelloMessage>, disconnectHandler: Runnable, subprotocols: LinkedHashMap<SubProtocol, SubProtocolHandler>, p2pVersion: Int, clientId: String, advertisedPort: Int)
fun disconnect(reason: DisconnectReason): Unit
fun handleConnectionStart(): Unit
fun id(): String
fun messageReceived(message: RLPxMessage): Unit
fun sendMessage(subProtocolIdentifier: SubProtocolIdentifier, messageType: Int, message: Bytes): Unit
fun sendPing(): AsyncCompletion
fun toString(): String
class DisconnectReason
class HelloMessage : WireProtocolMessage
interface SubProtocol
interface SubProtocolHandler
interface SubProtocolIdentifier
interface WireConnection
package org.apache.tuweni.scuttlebutt
package org.apache.tuweni.scuttlebutt.discovery
package org.apache.tuweni.scuttlebutt.handshake
package org.apache.tuweni.scuttlebutt.handshake.vertx
package org.apache.tuweni.scuttlebutt.rpc
Module Contents
open class RPCAsyncRequest
class RPCCodec
Module Contents
RPCCodec()
static fun encodeRequest(body: String, vararg flags: RPCFlag): Bytes
static fun encodeRequest(body: Bytes, vararg flags: RPCFlag): Bytes
static fun encodeRequest(body: Bytes, requestNumber: Int, vararg flags: RPCFlag): Bytes
static fun encodeRequest(body: Bytes, requestNumber: Int, flags: Byte): Bytes
static fun encodeResponse(body: Bytes, requestNumber: Int, flagByte: Byte): Bytes
static fun encodeResponse(body: Bytes, requestNumber: Int, flagByte: Byte, vararg flags: RPCFlag): Bytes
static fun encodeResponse(body: Bytes, requestNumber: Int, vararg flags: RPCFlag): Bytes
static fun encodeStreamEndRequest(requestNumber: Int): Bytes
open class RPCErrorBody
interface RPCFlag
open class RPCFunction
class RPCMessage
open class RPCRequestBody
class RPCRequestType
open class RPCResponse
open class RPCStreamRequest
package org.apache.tuweni.scuttlebutt.rpc.mux
package org.apache.tuweni.scuttlebutt.rpc.mux.exceptions
package org.apache.tuweni.ssz
Module Contents
open class EndOfSSZException : SSZException
open class InvalidSSZTypeException : SSZException
class SSZ
Module Contents
static fun <T : Any> decode(source: Bytes, fn: Function<SSZReader, T>): T
static fun decodeAddress(source: Bytes): Bytes
static fun decodeAddressList(source: Bytes): MutableList<Bytes>
static fun decodeBigInteger(source: Bytes, bitLength: Int): BigInteger
static fun decodeBigIntegerList(source: Bytes, bitLength: Int): MutableList<BigInteger>
static fun decodeBoolean(source: Bytes): Boolean
static fun decodeBooleanList(source: Bytes): MutableList<Boolean>
static fun decodeByteArrayList(source: Bytes): MutableList<ByteArray>
static fun decodeByteArrayList(source: Bytes, limit: Int): MutableList<ByteArray>
static fun decodeBytes(source: Bytes): Bytes
static fun decodeBytes(source: Bytes, limit: Int): Bytes
static fun decodeBytesList(source: Bytes): MutableList<Bytes>
static fun decodeBytesList(source: Bytes, limit: Int): MutableList<Bytes>
static fun decodeHash(source: Bytes, hashLength: Int): Bytes
static fun decodeHashList(source: Bytes, hashLength: Int): MutableList<Bytes>
static fun decodeInt(source: Bytes, bitLength: Int): Int
static fun decodeInt16(source: Bytes): Int
static fun decodeInt16List(source: Bytes): MutableList<Int>
static fun decodeInt32(source: Bytes): Int
static fun decodeInt32List(source: Bytes): MutableList<Int>
static fun decodeInt64(source: Bytes): Long
static fun decodeInt64List(source: Bytes): MutableList<Long>
static fun decodeInt8(source: Bytes): Int
static fun decodeInt8List(source: Bytes): MutableList<Int>
static fun decodeIntList(source: Bytes, bitLength: Int): MutableList<Int>
static fun decodeLong(source: Bytes, bitLength: Int): Long
static fun decodeLongIntList(source: Bytes, bitLength: Int): MutableList<Long>
static fun decodeString(source: Bytes): String
static fun decodeString(source: Bytes, limit: Int): String
static fun decodeStringList(source: Bytes): MutableList<String>
static fun decodeStringList(source: Bytes, limit: Int): MutableList<String>
static fun decodeUInt(source: Bytes, bitLength: Int): Int
static fun decodeUInt16(source: Bytes): Int
static fun decodeUInt16List(source: Bytes): MutableList<Int>
static fun decodeUInt256(source: Bytes): UInt256
static fun decodeUInt256List(source: Bytes): MutableList<UInt256>
static fun decodeUInt32(source: Bytes): Long
static fun decodeUInt32List(source: Bytes): MutableList<Long>
static fun decodeUInt384(source: Bytes): UInt384
static fun decodeUInt384List(source: Bytes): MutableList<UInt384>
static fun decodeUInt64(source: Bytes): Long
static fun decodeUInt64List(source: Bytes): MutableList<Long>
static fun decodeUInt8(source: Bytes): Int
static fun decodeUInt8List(source: Bytes): MutableList<Int>
static fun decodeUIntList(source: Bytes, bitLength: Int): MutableList<Int>
static fun decodeULong(source: Bytes, bitLength: Int): Long
static fun decodeULongIntList(source: Bytes, bitLength: Int): MutableList<Long>
static fun decodeUnsignedBigInteger(source: Bytes, bitLength: Int): BigInteger
static fun decodeUnsignedBigIntegerList(source: Bytes, bitLength: Int): MutableList<BigInteger>
static fun encode(fn: Consumer<SSZWriter>): Bytes
static fun encodeAddress(address: Bytes): Bytes
static fun encodeAddressList(vararg elements: Bytes): Bytes
static fun encodeAddressList(elements: MutableList<out Bytes>): Bytes
static fun encodeBigInteger(value: BigInteger, bitLength: Int): Bytes
static fun encodeBigIntegerList(bitLength: Int, vararg elements: BigInteger): Bytes
static fun encodeBigIntegerList(bitLength: Int, elements: MutableList<BigInteger>): Bytes
static fun encodeBigIntegerToByteArray(value: BigInteger, bitLength: Int): ByteArray
static fun encodeBoolean(value: Boolean): Bytes
static fun encodeBooleanList(vararg elements: Boolean): Bytes
static fun encodeBooleanList(elements: MutableList<Boolean>): Bytes
static fun encodeByteArray(value: ByteArray): Bytes
static fun encodeBytes(value: Bytes): Bytes
static fun encodeBytesList(vararg elements: Bytes): Bytes
static fun encodeBytesList(elements: MutableList<out Bytes>): Bytes
static fun encodeHash(hash: Bytes): Bytes
static fun encodeHashList(vararg elements: Bytes): Bytes
static fun encodeHashList(elements: MutableList<out Bytes>): Bytes
static fun encodeInt(value: Int, bitLength: Int): Bytes
static fun encodeInt16(value: Int): Bytes
static fun encodeInt16List(vararg elements: Int): Bytes
static fun encodeInt16List(elements: MutableList<Int>): Bytes
static fun encodeInt32(value: Int): Bytes
static fun encodeInt32List(vararg elements: Int): Bytes
static fun encodeInt32List(elements: MutableList<Int>): Bytes
static fun encodeInt64(value: Long): Bytes
static fun encodeInt64List(vararg elements: Long): Bytes
static fun encodeInt64List(elements: MutableList<Long>): Bytes
static fun encodeInt8(value: Int): Bytes
static fun encodeInt8List(vararg elements: Int): Bytes
static fun encodeInt8List(elements: MutableList<Int>): Bytes
static fun encodeIntList(bitLength: Int, vararg elements: Int): Bytes
static fun encodeIntList(bitLength: Int, elements: MutableList<Int>): Bytes
static fun encodeLong(value: Long, bitLength: Int): Bytes
static fun encodeLongIntList(bitLength: Int, vararg elements: Long): Bytes
static fun encodeLongIntList(bitLength: Int, elements: MutableList<Long>): Bytes
static fun encodeString(str: String): Bytes
static fun encodeStringList(vararg elements: String): Bytes
static fun encodeStringList(elements: MutableList<String>): Bytes
static fun <T : ByteBuffer> encodeTo(buffer: T, fn: Consumer<SSZWriter>): T
static fun encodeUBigInteger(value: BigInteger, bitLength: Int): Bytes
static fun encodeUBigIntegerToByteArray(value: BigInteger, bitLength: Int): ByteArray
static fun encodeUInt(value: Int, bitLength: Int): Bytes
static fun encodeUInt16(value: Int): Bytes
static fun encodeUInt16List(vararg elements: Int): Bytes
static fun encodeUInt16List(elements: MutableList<Int>): Bytes
static fun encodeUInt256(value: UInt256): Bytes
static fun encodeUInt256List(vararg elements: UInt256): Bytes
static fun encodeUInt256List(elements: MutableList<UInt256>): Bytes
static fun encodeUInt32(value: Long): Bytes
static fun encodeUInt32List(vararg elements: Long): Bytes
static fun encodeUInt32List(elements: MutableList<Long>): Bytes
static fun encodeUInt384(value: UInt384): Bytes
static fun encodeUInt384List(vararg elements: UInt384): Bytes
static fun encodeUInt384List(elements: MutableList<UInt384>): Bytes
static fun encodeUInt64(value: Long): Bytes
static fun encodeUInt64List(vararg elements: Long): Bytes
static fun encodeUInt64List(elements: MutableList<Long>): Bytes
static fun encodeUInt8(value: Int): Bytes
static fun encodeUInt8List(vararg elements: Int): Bytes
static fun encodeUInt8List(elements: MutableList<Int>): Bytes
static fun encodeUIntList(bitLength: Int, vararg elements: Int): Bytes
static fun encodeUIntList(bitLength: Int, elements: MutableList<Int>): Bytes
static fun encodeULong(value: Long, bitLength: Int): Bytes
static fun encodeULongIntList(bitLength: Int, vararg elements: Long): Bytes
static fun encodeULongIntList(bitLength: Int, elements: MutableList<Long>): Bytes
static fun hashTreeRoot(vararg bytes: Bytes): Bytes32
open class SSZException : RuntimeException
interface SSZReader
interface SSZWriter
Module Contents
open fun writeAddress(address: Bytes): Unit
open fun writeAddressList(vararg elements: Bytes): Unit
open fun writeAddressList(elements: MutableList<out Bytes>): Unit
open fun writeBigInteger(value: BigInteger, bitLength: Int): Unit
open fun writeBigIntegerList(bitLength: Int, vararg elements: BigInteger): Unit
open fun writeBigIntegerList(bitLength: Int, elements: MutableList<BigInteger>): Unit
open fun writeBoolean(value: Boolean): Unit
open fun writeBooleanList(vararg elements: Boolean): Unit
open fun writeBooleanList(elements: MutableList<Boolean>): Unit
open fun writeBytes(value: Bytes): Unit
open fun writeBytes(value: ByteArray): Unit
open fun writeBytesList(vararg elements: Bytes): Unit
open fun writeBytesList(elements: MutableList<out Bytes>): Unit
open fun writeFixedBytes(byteLength: Int, value: Bytes): Unit
open fun writeFixedBytesList(byteLength: Int, elements: MutableList<out Bytes>): Unit
open fun writeFixedBytesVector(elements: MutableList<out Bytes>): Unit
open fun writeHash(hash: Bytes): Unit
open fun writeHashList(vararg elements: Bytes): Unit
open fun writeHashList(elements: MutableList<out Bytes>): Unit
open fun writeInt(value: Int, bitLength: Int): Unit
open fun writeInt16(value: Int): Unit
open fun writeInt16List(vararg elements: Int): Unit
open fun writeInt16List(elements: MutableList<Int>): Unit
open fun writeInt32(value: Int): Unit
open fun writeInt32List(vararg elements: Int): Unit
open fun writeInt32List(elements: MutableList<Int>): Unit
open fun writeInt64(value: Long): Unit
open fun writeInt64List(vararg elements: Long): Unit
open fun writeInt64List(elements: MutableList<Long>): Unit
open fun writeInt8(value: Int): Unit
open fun writeInt8List(vararg elements: Int): Unit
open fun writeInt8List(elements: MutableList<Int>): Unit
open fun writeIntList(bitLength: Int, vararg elements: Int): Unit
open fun writeIntList(bitLength: Int, elements: MutableList<Int>): Unit
open fun writeLong(value: Long, bitLength: Int): Unit
open fun writeLongIntList(bitLength: Int, vararg elements: Long): Unit
open fun writeLongIntList(bitLength: Int, elements: MutableList<Long>): Unit
abstract fun writeSSZ(value: Bytes): Unit
open fun writeSSZ(value: ByteArray): Unit
open fun writeString(str: String): Unit
open fun writeStringList(vararg elements: String): Unit
open fun writeStringList(elements: MutableList<String>): Unit
open fun writeUBigInteger(value: BigInteger, bitLength: Int): Unit
open fun writeUInt(value: Int, bitLength: Int): Unit
open fun writeUInt16(value: Int): Unit
open fun writeUInt16List(vararg elements: Int): Unit
open fun writeUInt16List(elements: MutableList<Int>): Unit
open fun writeUInt256(value: UInt256): Unit
open fun writeUInt256List(vararg elements: UInt256): Unit
open fun writeUInt256List(elements: MutableList<UInt256>): Unit
open fun writeUInt32(value: Long): Unit
open fun writeUInt32List(vararg elements: Long): Unit
open fun writeUInt32List(elements: MutableList<Long>): Unit
open fun writeUInt384(value: UInt384): Unit
open fun writeUInt384List(elements: MutableList<UInt384>): Unit
open fun writeUInt384List(vararg elements: UInt384): Unit
open fun writeUInt64(value: Long): Unit
open fun writeUInt64List(vararg elements: Long): Unit
open fun writeUInt64List(elements: MutableList<Long>): Unit
open fun writeUInt8(value: Int): Unit
open fun writeUInt8List(vararg elements: Int): Unit
open fun writeUInt8List(elements: MutableList<Int>): Unit
open fun writeUIntList(bitLength: Int, vararg elements: Int): Unit
open fun writeUIntList(bitLength: Int, elements: MutableList<Int>): Unit
open fun writeULong(value: Long, bitLength: Int): Unit
open fun writeULongIntList(bitLength: Int, vararg elements: Long): Unit
open fun writeULongIntList(bitLength: Int, elements: MutableList<Long>): Unit
open fun writeVector(elements: MutableList<out Bytes>): Unit
package org.apache.tuweni.toml
Module Contents
class Toml
interface TomlArray
open class TomlInvalidTypeException : RuntimeException
class TomlParseError : RuntimeException
interface TomlParseResult : TomlTable
class TomlPosition
interface TomlTable
Module Contents
open fun contains(dottedKey: String): Boolean
open fun contains(path: MutableList<String>): Boolean
open fun dottedKeySet(): MutableSet<String>
open fun dottedKeySet(includeTables: Boolean): MutableSet<String>
@Nullable open fun get(dottedKey: String): Any?
@Nullable abstract fun get(path: MutableList<String>): Any?
@Nullable open fun getArray(dottedKey: String): TomlArray?
@Nullable open fun getArray(path: MutableList<String>): TomlArray?
open fun getArrayOrEmpty(dottedKey: String): TomlArray
open fun getArrayOrEmpty(path: MutableList<String>): TomlArray
@Nullable open fun getBoolean(dottedKey: String): Boolean?
@Nullable open fun getBoolean(path: MutableList<String>): Boolean?
open fun getBoolean(dottedKey: String, defaultValue: BooleanSupplier): Boolean
open fun getBoolean(path: MutableList<String>, defaultValue: BooleanSupplier): Boolean
@Nullable open fun getDouble(dottedKey: String): Double?
@Nullable open fun getDouble(path: MutableList<String>): Double?
open fun getDouble(dottedKey: String, defaultValue: DoubleSupplier): Double
open fun getDouble(path: MutableList<String>, defaultValue: DoubleSupplier): Double
@Nullable open fun getLocalDate(dottedKey: String): LocalDate?
@Nullable open fun getLocalDate(path: MutableList<String>): LocalDate?
open fun getLocalDate(dottedKey: String, defaultValue: Supplier<LocalDate>): LocalDate
open fun getLocalDate(path: MutableList<String>, defaultValue: Supplier<LocalDate>): LocalDate
@Nullable open fun getLocalDateTime(dottedKey: String): LocalDateTime?
@Nullable open fun getLocalDateTime(path: MutableList<String>): LocalDateTime?
open fun getLocalDateTime(dottedKey: String, defaultValue: Supplier<LocalDateTime>): LocalDateTime
open fun getLocalDateTime(path: MutableList<String>, defaultValue: Supplier<LocalDateTime>): LocalDateTime
@Nullable open fun getLocalTime(dottedKey: String): LocalTime?
@Nullable open fun getLocalTime(path: MutableList<String>): LocalTime?
open fun getLocalTime(dottedKey: String, defaultValue: Supplier<LocalTime>): LocalTime
open fun getLocalTime(path: MutableList<String>, defaultValue: Supplier<LocalTime>): LocalTime
@Nullable open fun getLong(dottedKey: String): Long?
@Nullable open fun getLong(path: MutableList<String>): Long?
open fun getLong(dottedKey: String, defaultValue: LongSupplier): Long
open fun getLong(path: MutableList<String>, defaultValue: LongSupplier): Long
@Nullable open fun getOffsetDateTime(dottedKey: String): OffsetDateTime?
@Nullable open fun getOffsetDateTime(path: MutableList<String>): OffsetDateTime?
open fun getOffsetDateTime(dottedKey: String, defaultValue: Supplier<OffsetDateTime>): OffsetDateTime
open fun getOffsetDateTime(path: MutableList<String>, defaultValue: Supplier<OffsetDateTime>): OffsetDateTime
@Nullable open fun getString(dottedKey: String): String?
@Nullable open fun getString(path: MutableList<String>): String?
open fun getString(dottedKey: String, defaultValue: Supplier<String>): String
open fun getString(path: MutableList<String>, defaultValue: Supplier<String>): String
@Nullable open fun getTable(dottedKey: String): TomlTable?
@Nullable open fun getTable(path: MutableList<String>): TomlTable?
open fun getTableOrEmpty(dottedKey: String): TomlTable
open fun getTableOrEmpty(path: MutableList<String>): TomlTable
@Nullable open fun inputPositionOf(dottedKey: String): TomlPosition?
@Nullable abstract fun inputPositionOf(path: MutableList<String>): TomlPosition?
open fun isArray(dottedKey: String): Boolean
open fun isArray(path: MutableList<String>): Boolean
open fun isBoolean(dottedKey: String): Boolean
open fun isBoolean(path: MutableList<String>): Boolean
open fun isDouble(dottedKey: String): Boolean
open fun isDouble(path: MutableList<String>): Boolean
abstract fun isEmpty(): Boolean
open fun isLocalDate(dottedKey: String): Boolean
open fun isLocalDate(path: MutableList<String>): Boolean
open fun isLocalDateTime(dottedKey: String): Boolean
open fun isLocalDateTime(path: MutableList<String>): Boolean
open fun isLocalTime(dottedKey: String): Boolean
open fun isLocalTime(path: MutableList<String>): Boolean
open fun isLong(dottedKey: String): Boolean
open fun isLong(path: MutableList<String>): Boolean
open fun isOffsetDateTime(dottedKey: String): Boolean
open fun isOffsetDateTime(path: MutableList<String>): Boolean
open fun isString(dottedKey: String): Boolean
open fun isString(path: MutableList<String>): Boolean
open fun isTable(dottedKey: String): Boolean
open fun isTable(path: MutableList<String>): Boolean
open fun keyPathSet(): MutableSet<MutableList<String>>
abstract fun keyPathSet(includeTables: Boolean): MutableSet<MutableList<String>>
abstract fun keySet(): MutableSet<String>
abstract fun size(): Int
open fun toJson(): String
open fun toJson(appendable: Appendable): Unit
abstract fun toMap(): MutableMap<String, Any>
class TomlVersion
package org.apache.tuweni.trie
Module Contents
abstract class AsyncMerkleStorage : MerkleStorage
class CompactEncoding
class MerklePatriciaTrie<V> : MerkleTrie<Bytes, V>
interface MerkleStorage
class MerkleStorageException : RuntimeException
interface MerkleTrie<in K, V>
class StoredMerklePatriciaTrie<V> : MerkleTrie<Bytes, V>
Module Contents
StoredMerklePatriciaTrie(storage: MerkleStorage, valueSerializer: (V) -> Bytes, valueDeserializer: (Bytes) -> V)
StoredMerklePatriciaTrie(storage: MerkleStorage, rootHash: Bytes32, valueSerializer: (V) -> Bytes, valueDeserializer: (Bytes) -> V)
fun clearCache(): Unit
@JvmStatic fun <V> create(storage: MerkleStorage, valueSerializer: Function<V, Bytes>, valueDeserializer: Function<Bytes, V>): StoredMerklePatriciaTrie<V>
@JvmStatic fun <V> create(storage: MerkleStorage, rootHash: Bytes32, valueSerializer: Function<V, Bytes>, valueDeserializer: Function<Bytes, V>): StoredMerklePatriciaTrie<V>
suspend fun get(key: Bytes): V?
suspend fun put(key: Bytes, value: V?): Unit
suspend fun remove(key: Bytes): Unit
fun rootHash(): Bytes32
@JvmStatic fun storingBytes(storage: MerkleStorage): StoredMerklePatriciaTrie<Bytes>
@JvmStatic fun storingBytes(storage: MerkleStorage, rootHash: Bytes32): StoredMerklePatriciaTrie<Bytes>
@JvmStatic fun storingStrings(storage: MerkleStorage): StoredMerklePatriciaTrie<String>
@JvmStatic fun storingStrings(storage: MerkleStorage, rootHash: Bytes32): StoredMerklePatriciaTrie<String>
fun toString(): String
package org.apache.tuweni.units.bigints
package org.apache.tuweni.units.ethereum