vertx
Module Contents
alltypes
Module Contents
object AzureADAuth
object GoogleAuth
object HttpEndpoint
Module Contents
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: JsonObject): HttpClient
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: JsonObject, conf: JsonObject): HttpClient
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>): HttpClient
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>, conf: JsonObject): HttpClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: JsonObject): WebClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: JsonObject, conf: JsonObject): WebClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>): WebClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>, conf: JsonObject): WebClient
object JDBCDataSource
object Json
object KeycloakAuth
object MessageSource
object MongoDataSource
object OpenIDConnectAuth
object RedisDataSource
object SalesforceAuth
object Vertx
io.vertx.amqpbridge.AmqpBridge
io.vertx.cassandra.CassandraClient
io.vertx.cassandra.ResultSet
io.vertx.circuitbreaker.CircuitBreaker
io.vertx.config.ConfigRetriever
io.vertx.core.CompositeFuture
io.vertx.core.Context
io.vertx.core.Future
io.vertx.core.Vertx
io.vertx.core.WorkerExecutor
io.vertx.core.buffer.Buffer
io.vertx.core.datagram.DatagramSocket
Module Contents
suspend fun DatagramSocket.blockMulticastGroupAwait(multicastAddress: String, sourceToBlock: String): DatagramSocket
suspend fun DatagramSocket.blockMulticastGroupAwait(multicastAddress: String, networkInterface: String, sourceToBlock: String): DatagramSocket
suspend fun DatagramSocket.closeAwait(): Unit
suspend fun DatagramSocket.listenAwait(port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.listenMulticastGroupAwait(multicastAddress: String): DatagramSocket
suspend fun DatagramSocket.listenMulticastGroupAwait(multicastAddress: String, networkInterface: String, source: String): DatagramSocket
suspend fun DatagramSocket.sendAwait(packet: Buffer, port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.sendAwait(str: String, port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.sendAwait(str: String, enc: String, port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.unlistenMulticastGroupAwait(multicastAddress: String): DatagramSocket
suspend fun DatagramSocket.unlistenMulticastGroupAwait(multicastAddress: String, networkInterface: String, source: String): DatagramSocket
io.vertx.core.dns.DnsClient
io.vertx.core.eventbus.EventBus
io.vertx.core.eventbus.Message
io.vertx.core.eventbus.MessageConsumer
io.vertx.core.file.AsyncFile
io.vertx.core.file.FileSystem
Module Contents
suspend fun FileSystem.chmodAwait(path: String, perms: String): Unit
suspend fun FileSystem.chmodRecursiveAwait(path: String, perms: String, dirPerms: String): Unit
suspend fun FileSystem.chownAwait(path: String, user: String, group: String): Unit
suspend fun FileSystem.copyAwait(from: String, to: String): Unit
suspend fun FileSystem.copyAwait(from: String, to: String, options: CopyOptions): Unit
suspend fun FileSystem.copyRecursiveAwait(from: String, to: String, recursive: Boolean): Unit
suspend fun FileSystem.createFileAwait(path: String): Unit
suspend fun FileSystem.createFileAwait(path: String, perms: String): Unit
suspend fun FileSystem.createTempDirectoryAwait(prefix: String): String
suspend fun FileSystem.createTempDirectoryAwait(prefix: String, perms: String): String
suspend fun FileSystem.createTempDirectoryAwait(dir: String, prefix: String, perms: String): String
suspend fun FileSystem.createTempFileAwait(prefix: String, suffix: String): String
suspend fun FileSystem.createTempFileAwait(prefix: String, suffix: String, perms: String): String
suspend fun FileSystem.createTempFileAwait(dir: String, prefix: String, suffix: String, perms: String): String
suspend fun FileSystem.deleteAwait(path: String): Unit
suspend fun FileSystem.deleteRecursiveAwait(path: String, recursive: Boolean): Unit
suspend fun FileSystem.existsAwait(path: String): Boolean
suspend fun FileSystem.fsPropsAwait(path: String): FileSystemProps
suspend fun FileSystem.linkAwait(link: String, existing: String): Unit
suspend fun FileSystem.lpropsAwait(path: String): FileProps
suspend fun FileSystem.mkdirAwait(path: String): Unit
suspend fun FileSystem.mkdirAwait(path: String, perms: String): Unit
suspend fun FileSystem.mkdirsAwait(path: String): Unit
suspend fun FileSystem.mkdirsAwait(path: String, perms: String): Unit
suspend fun FileSystem.moveAwait(from: String, to: String): Unit
suspend fun FileSystem.moveAwait(from: String, to: String, options: CopyOptions): Unit
suspend fun FileSystem.openAwait(path: String, options: OpenOptions): AsyncFile
suspend fun FileSystem.propsAwait(path: String): FileProps
suspend fun FileSystem.readDirAwait(path: String): List<String>
suspend fun FileSystem.readDirAwait(path: String, filter: String): List<String>
suspend fun FileSystem.readFileAwait(path: String): Buffer
suspend fun FileSystem.readSymlinkAwait(link: String): String
suspend fun FileSystem.symlinkAwait(link: String, existing: String): Unit
suspend fun FileSystem.truncateAwait(path: String, len: Long): Unit
suspend fun FileSystem.unlinkAwait(link: String): Unit
suspend fun FileSystem.writeFileAwait(path: String, data: Buffer): Unit
io.vertx.core.http.HttpConnection
io.vertx.core.http.HttpServer
io.vertx.core.http.HttpServerResponse
Module Contents
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, host: String, path: String): HttpServerResponse
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, path: String, : MultiMap): HttpServerResponse
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, path: String): HttpServerResponse
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, host: String, path: String, : MultiMap): HttpServerResponse
suspend fun HttpServerResponse.sendFileAwait(filename: String): Unit
suspend fun HttpServerResponse.sendFileAwait(filename: String, offset: Long): Unit
suspend fun HttpServerResponse.sendFileAwait(filename: String, offset: Long, length: Long): Unit
io.vertx.core.json.JsonArray
io.vertx.core.json.JsonObject
io.vertx.core.net.NetClient
io.vertx.core.net.NetServer
io.vertx.core.net.NetSocket
io.vertx.core.shareddata.AsyncMap
Module Contents
suspend fun <K, V> AsyncMap<K, V>.clearAwait(): Unit
suspend fun <K, V> AsyncMap<K, V>.getAwait(k: K): V?
suspend fun <K, V> AsyncMap<K, V>.putAwait(k: K, v: V): Unit
suspend fun <K, V> AsyncMap<K, V>.putAwait(k: K, v: V, ttl: Long): Unit
suspend fun <K, V> AsyncMap<K, V>.putIfAbsentAwait(k: K, v: V): V?
suspend fun <K, V> AsyncMap<K, V>.putIfAbsentAwait(k: K, v: V, ttl: Long): V?
suspend fun <K, V> AsyncMap<K, V>.removeAwait(k: K): V?
suspend fun <K, V> AsyncMap<K, V>.removeIfPresentAwait(k: K, v: V): Boolean
suspend fun <K, V> AsyncMap<K, V>.replaceAwait(k: K, v: V): V?
suspend fun <K, V> AsyncMap<K, V>.replaceIfPresentAwait(k: K, oldValue: V, newValue: V): Boolean
suspend fun <K, V> AsyncMap<K, V>.sizeAwait(): Int
io.vertx.core.shareddata.Counter
io.vertx.core.shareddata.SharedData
io.vertx.ext.asyncsql.AsyncSQLClient
io.vertx.ext.asyncsql.MySQLClient
io.vertx.ext.asyncsql.PostgreSQLClient
io.vertx.ext.auth.AuthProvider
io.vertx.ext.auth.User
io.vertx.ext.auth.mongo.MongoAuth
io.vertx.ext.auth.oauth2.AccessToken
io.vertx.ext.auth.oauth2.OAuth2Auth
io.vertx.ext.auth.oauth2.OAuth2RBAC
io.vertx.ext.bridge.BaseBridgeEvent
io.vertx.ext.consul.ConsulClient
Module Contents
suspend fun ConsulClient.agentInfoAwait(): JsonObject
suspend fun ConsulClient.catalogDatacentersAwait(): List<String>
suspend fun ConsulClient.catalogNodeServicesAwait(node: String): ServiceList
suspend fun ConsulClient.catalogNodeServicesWithOptionsAwait(node: String, options: BlockingQueryOptions): ServiceList
suspend fun ConsulClient.catalogNodesAwait(): NodeList
suspend fun ConsulClient.catalogNodesWithOptionsAwait(options: NodeQueryOptions): NodeList
suspend fun ConsulClient.catalogServiceNodesAwait(service: String): ServiceList
suspend fun ConsulClient.catalogServiceNodesWithOptionsAwait(service: String, options: ServiceQueryOptions): ServiceList
suspend fun ConsulClient.catalogServicesAwait(): ServiceList
suspend fun ConsulClient.catalogServicesWithOptionsAwait(options: BlockingQueryOptions): ServiceList
suspend fun ConsulClient.cloneAclTokenAwait(id: String): String
suspend fun ConsulClient.coordinateDatacentersAwait(): List<DcCoordinates>
suspend fun ConsulClient.coordinateNodesAwait(): CoordinateList
suspend fun ConsulClient.coordinateNodesWithOptionsAwait(options: BlockingQueryOptions): CoordinateList
suspend fun ConsulClient.createAclTokenAwait(token: AclToken): String
suspend fun ConsulClient.createPreparedQueryAwait(definition: PreparedQueryDefinition): String
suspend fun ConsulClient.createSessionAwait(): String
suspend fun ConsulClient.createSessionWithOptionsAwait(options: SessionOptions): String
suspend fun ConsulClient.deletePreparedQueryAwait(id: String): Unit
suspend fun ConsulClient.deleteValueAwait(key: String): Unit
suspend fun ConsulClient.deleteValuesAwait(keyPrefix: String): Unit
suspend fun ConsulClient.deregisterCheckAwait(checkId: String): Unit
suspend fun ConsulClient.deregisterServiceAwait(id: String): Unit
suspend fun ConsulClient.destroyAclTokenAwait(id: String): Unit
suspend fun ConsulClient.destroySessionAwait(id: String): Unit
suspend fun ConsulClient.executePreparedQueryAwait(query: String): PreparedQueryExecuteResponse
suspend fun ConsulClient.executePreparedQueryWithOptionsAwait(query: String, options: PreparedQueryExecuteOptions): PreparedQueryExecuteResponse
suspend fun ConsulClient.failCheckAwait(checkId: String): Unit
suspend fun ConsulClient.failCheckWithNoteAwait(checkId: String, note: String): Unit
suspend fun ConsulClient.fireEventAwait(name: String): Event
suspend fun ConsulClient.fireEventWithOptionsAwait(name: String, options: EventOptions): Event
suspend fun ConsulClient.getAllPreparedQueriesAwait(): List<PreparedQueryDefinition>
suspend fun ConsulClient.getKeysAwait(keyPrefix: String): List<String>
suspend fun ConsulClient.getKeysWithOptionsAwait(keyPrefix: String, options: BlockingQueryOptions): List<String>
suspend fun ConsulClient.getPreparedQueryAwait(id: String): PreparedQueryDefinition
suspend fun ConsulClient.getValueAwait(key: String): KeyValue
suspend fun ConsulClient.getValueWithOptionsAwait(key: String, options: BlockingQueryOptions): KeyValue
suspend fun ConsulClient.getValuesAwait(keyPrefix: String): KeyValueList
suspend fun ConsulClient.getValuesWithOptionsAwait(keyPrefix: String, options: BlockingQueryOptions): KeyValueList
suspend fun ConsulClient.healthChecksAwait(service: String): CheckList
suspend fun ConsulClient.healthChecksWithOptionsAwait(service: String, options: CheckQueryOptions): CheckList
suspend fun ConsulClient.healthServiceNodesAwait(service: String, passing: Boolean): ServiceEntryList
suspend fun ConsulClient.healthServiceNodesWithOptionsAwait(service: String, passing: Boolean, options: ServiceQueryOptions): ServiceEntryList
suspend fun ConsulClient.healthStateAwait(healthState: HealthState): CheckList
suspend fun ConsulClient.healthStateWithOptionsAwait(healthState: HealthState, options: CheckQueryOptions): CheckList
suspend fun ConsulClient.infoAclTokenAwait(id: String): AclToken
suspend fun ConsulClient.infoSessionAwait(id: String): Session
suspend fun ConsulClient.infoSessionWithOptionsAwait(id: String, options: BlockingQueryOptions): Session
suspend fun ConsulClient.leaderStatusAwait(): String
suspend fun ConsulClient.listAclTokensAwait(): List<AclToken>
suspend fun ConsulClient.listEventsAwait(): EventList
suspend fun ConsulClient.listEventsWithOptionsAwait(options: EventListOptions): EventList
suspend fun ConsulClient.listNodeSessionsAwait(nodeId: String): SessionList
suspend fun ConsulClient.listNodeSessionsWithOptionsAwait(nodeId: String, options: BlockingQueryOptions): SessionList
suspend fun ConsulClient.listSessionsAwait(): SessionList
suspend fun ConsulClient.listSessionsWithOptionsAwait(options: BlockingQueryOptions): SessionList
suspend fun ConsulClient.localChecksAwait(): List<Check>
suspend fun ConsulClient.localServicesAwait(): List<Service>
suspend fun ConsulClient.maintenanceServiceAwait(maintenanceOptions: MaintenanceOptions): Unit
suspend fun ConsulClient.passCheckAwait(checkId: String): Unit
suspend fun ConsulClient.passCheckWithNoteAwait(checkId: String, note: String): Unit
suspend fun ConsulClient.peersStatusAwait(): List<String>
suspend fun ConsulClient.putValueAwait(key: String, value: String): Boolean
suspend fun ConsulClient.putValueWithOptionsAwait(key: String, value: String, options: KeyValueOptions): Boolean
suspend fun ConsulClient.registerCheckAwait(checkOptions: CheckOptions): Unit
suspend fun ConsulClient.registerServiceAwait(serviceOptions: ServiceOptions): Unit
suspend fun ConsulClient.renewSessionAwait(id: String): Session
suspend fun ConsulClient.transactionAwait(request: TxnRequest): TxnResponse
suspend fun ConsulClient.updateAclTokenAwait(token: AclToken): String
suspend fun ConsulClient.updateCheckAwait(checkId: String, status: CheckStatus): Unit
suspend fun ConsulClient.updateCheckWithNoteAwait(checkId: String, status: CheckStatus, note: String): Unit
suspend fun ConsulClient.updatePreparedQueryAwait(definition: PreparedQueryDefinition): Unit
suspend fun ConsulClient.warnCheckAwait(checkId: String): Unit
suspend fun ConsulClient.warnCheckWithNoteAwait(checkId: String, note: String): Unit
io.vertx.ext.healthchecks.HealthChecks
io.vertx.ext.jdbc.JDBCClient
io.vertx.ext.mail.MailClient
io.vertx.ext.mongo.MongoClient
Module Contents
suspend fun MongoClient.bulkWriteAwait(collection: String, operations: List<BulkOperation>): MongoClientBulkWriteResult
suspend fun MongoClient.bulkWriteWithOptionsAwait(collection: String, operations: List<BulkOperation>, bulkWriteOptions: BulkWriteOptions): MongoClientBulkWriteResult
suspend fun MongoClient.countAwait(collection: String, query: JsonObject): Long
suspend fun MongoClient.createCollectionAwait(collectionName: String): Unit
suspend fun MongoClient.createIndexAwait(collection: String, key: JsonObject): Unit
suspend fun MongoClient.createIndexWithOptionsAwait(collection: String, key: JsonObject, options: IndexOptions): Unit
suspend fun MongoClient.distinctAwait(collection: String, fieldName: String, resultClassname: String): JsonArray
suspend fun MongoClient.distinctWithQueryAwait(collection: String, fieldName: String, resultClassname: String, query: JsonObject): JsonArray
suspend fun MongoClient.dropCollectionAwait(collection: String): Unit
suspend fun MongoClient.dropIndexAwait(collection: String, indexName: String): Unit
suspend fun MongoClient.findAwait(collection: String, query: JsonObject): List<JsonObject>
suspend fun MongoClient.findOneAndDeleteAwait(collection: String, query: JsonObject): JsonObject
suspend fun MongoClient.findOneAndDeleteWithOptionsAwait(collection: String, query: JsonObject, findOptions: FindOptions): JsonObject
suspend fun MongoClient.findOneAndReplaceAwait(collection: String, query: JsonObject, replace: JsonObject): JsonObject
suspend fun MongoClient.findOneAndReplaceWithOptionsAwait(collection: String, query: JsonObject, replace: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoClient.findOneAndUpdateAwait(collection: String, query: JsonObject, update: JsonObject): JsonObject
suspend fun MongoClient.findOneAndUpdateWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoClient.findOneAwait(collection: String, query: JsonObject, fields: JsonObject): JsonObject
suspend fun MongoClient.findWithOptionsAwait(collection: String, query: JsonObject, options: FindOptions): List<JsonObject>
suspend fun MongoClient.getCollectionsAwait(): List<String>
suspend fun MongoClient.insertAwait(collection: String, document: JsonObject): String
suspend fun MongoClient.insertWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoClient.listIndexesAwait(collection: String): JsonArray
suspend fun MongoClient.removeDocumentAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoClient.removeDocumentWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoClient.removeDocumentsAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoClient.removeDocumentsWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoClient.replaceDocumentsAwait(collection: String, query: JsonObject, replace: JsonObject): MongoClientUpdateResult
suspend fun MongoClient.replaceDocumentsWithOptionsAwait(collection: String, query: JsonObject, replace: JsonObject, options: UpdateOptions): MongoClientUpdateResult
suspend fun MongoClient.runCommandAwait(commandName: String, command: JsonObject): JsonObject
suspend fun MongoClient.saveAwait(collection: String, document: JsonObject): String
suspend fun MongoClient.saveWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoClient.updateCollectionAwait(collection: String, query: JsonObject, update: JsonObject): MongoClientUpdateResult
suspend fun MongoClient.updateCollectionWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, options: UpdateOptions): MongoClientUpdateResult
io.vertx.ext.mongo.MongoService
Module Contents
suspend fun MongoService.bulkWriteAwait(collection: String, operations: List<BulkOperation>): MongoClientBulkWriteResult
suspend fun MongoService.bulkWriteWithOptionsAwait(collection: String, operations: List<BulkOperation>, bulkWriteOptions: BulkWriteOptions): MongoClientBulkWriteResult
suspend fun MongoService.countAwait(collection: String, query: JsonObject): Long
suspend fun MongoService.createCollectionAwait(collectionName: String): Unit
suspend fun MongoService.createIndexAwait(collection: String, key: JsonObject): Unit
suspend fun MongoService.createIndexWithOptionsAwait(collection: String, key: JsonObject, options: IndexOptions): Unit
suspend fun MongoService.distinctAwait(collection: String, fieldName: String, resultClassname: String): JsonArray
suspend fun MongoService.distinctWithQueryAwait(collection: String, fieldName: String, resultClassname: String, query: JsonObject): JsonArray
suspend fun MongoService.dropCollectionAwait(collection: String): Unit
suspend fun MongoService.dropIndexAwait(collection: String, indexName: String): Unit
suspend fun MongoService.findAwait(collection: String, query: JsonObject): List<JsonObject>
suspend fun MongoService.findOneAndDeleteAwait(collection: String, query: JsonObject): JsonObject
suspend fun MongoService.findOneAndDeleteWithOptionsAwait(collection: String, query: JsonObject, findOptions: FindOptions): JsonObject
suspend fun MongoService.findOneAndReplaceAwait(collection: String, query: JsonObject, replace: JsonObject): JsonObject
suspend fun MongoService.findOneAndReplaceWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoService.findOneAndUpdateAwait(collection: String, query: JsonObject, update: JsonObject): JsonObject
suspend fun MongoService.findOneAndUpdateWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoService.findOneAwait(collection: String, query: JsonObject, fields: JsonObject): JsonObject
suspend fun MongoService.findWithOptionsAwait(collection: String, query: JsonObject, options: FindOptions): List<JsonObject>
suspend fun MongoService.getCollectionsAwait(): List<String>
suspend fun MongoService.insertAwait(collection: String, document: JsonObject): String
suspend fun MongoService.insertWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoService.listIndexesAwait(collection: String): JsonArray
suspend fun MongoService.removeDocumentAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoService.removeDocumentWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoService.removeDocumentsAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoService.removeDocumentsWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoService.replaceDocumentsAwait(collection: String, query: JsonObject, replace: JsonObject): MongoClientUpdateResult
suspend fun MongoService.replaceDocumentsWithOptionsAwait(collection: String, query: JsonObject, replace: JsonObject, options: UpdateOptions): MongoClientUpdateResult
suspend fun MongoService.runCommandAwait(commandName: String, command: JsonObject): JsonObject
suspend fun MongoService.saveAwait(collection: String, document: JsonObject): String
suspend fun MongoService.saveWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoService.updateCollectionAwait(collection: String, query: JsonObject, update: JsonObject): MongoClientUpdateResult
suspend fun MongoService.updateCollectionWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, options: UpdateOptions): MongoClientUpdateResult
io.vertx.ext.shell.ShellServer
io.vertx.ext.shell.ShellService
io.vertx.ext.shell.command.CommandRegistry
io.vertx.ext.shell.term.TermServer
io.vertx.ext.sql.SQLClient
io.vertx.ext.sql.SQLConnection
io.vertx.ext.sql.SQLOperations
io.vertx.ext.sql.SQLRowStream
io.vertx.ext.stomp.StompClient
io.vertx.ext.stomp.StompServer
io.vertx.ext.stomp.StompServerHandler
io.vertx.ext.unit.Async
io.vertx.ext.unit.Completion
io.vertx.ext.unit.TestCompletion
io.vertx.ext.web.client.HttpRequest
io.vertx.ext.web.common.template.TemplateEngine
io.vertx.ext.web.handler.AuthHandler
io.vertx.ext.web.handler.BasicAuthHandler
io.vertx.ext.web.handler.ChainAuthHandler
io.vertx.ext.web.handler.DigestAuthHandler
io.vertx.ext.web.handler.JWTAuthHandler
io.vertx.ext.web.handler.OAuth2AuthHandler
io.vertx.ext.web.handler.RedirectAuthHandler
io.vertx.ext.web.handler.sockjs.BridgeEvent
io.vertx.ext.web.sstore.SessionStore
io.vertx.kafka.admin.AdminUtils
io.vertx.kafka.client.consumer.KafkaConsumer
Module Contents
suspend fun <K, V> KafkaConsumer<K, V>.assignAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.assignAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.assignmentAwait(): Set<TopicPartition>
suspend fun <K, V> KafkaConsumer<K, V>.beginningOffsetsAwait(topicPartition: TopicPartition): Long
suspend fun <K, V> KafkaConsumer<K, V>.closeAwait(): Unit
suspend fun <K, V> KafkaConsumer<K, V>.commitAwait(): Unit
suspend fun <K, V> KafkaConsumer<K, V>.committedAwait(topicPartition: TopicPartition): OffsetAndMetadata
suspend fun <K, V> KafkaConsumer<K, V>.endOffsetsAwait(topicPartition: TopicPartition): Long
suspend fun <K, V> KafkaConsumer<K, V>.offsetsForTimesAwait(topicPartition: TopicPartition, timestamp: Long): OffsetAndTimestamp
suspend fun <K, V> KafkaConsumer<K, V>.partitionsForAwait(topic: String): List<PartitionInfo>
suspend fun <K, V> KafkaConsumer<K, V>.pauseAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.pauseAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.pausedAwait(): Set<TopicPartition>
suspend fun <K, V> KafkaConsumer<K, V>.pollAwait(timeout: Long): KafkaConsumerRecords<K, V>
suspend fun <K, V> KafkaConsumer<K, V>.positionAwait(partition: TopicPartition): Long
suspend fun <K, V> KafkaConsumer<K, V>.resumeAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.resumeAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekAwait(topicPartition: TopicPartition, offset: Long): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToBeginningAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToBeginningAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToEndAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToEndAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.subscribeAwait(topic: String): Unit
suspend fun <K, V> KafkaConsumer<K, V>.subscribeAwait(topics: Set<String>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.subscriptionAwait(): Set<String>
suspend fun <K, V> KafkaConsumer<K, V>.unsubscribeAwait(): Unit
io.vertx.kafka.client.producer.KafkaProducer
io.vertx.mqtt.MqttClient
io.vertx.mqtt.MqttEndpoint
io.vertx.mqtt.MqttServer
io.vertx.rabbitmq.RabbitMQClient
Module Contents
suspend fun RabbitMQClient.basicAckAwait(deliveryTag: Long, multiple: Boolean): JsonObject
suspend fun RabbitMQClient.basicConsumerAwait(queue: String): RabbitMQConsumer
suspend fun RabbitMQClient.basicConsumerAwait(queue: String, options: QueueOptions): RabbitMQConsumer
suspend fun RabbitMQClient.basicGetAwait(queue: String, autoAck: Boolean): JsonObject
suspend fun RabbitMQClient.basicNackAwait(deliveryTag: Long, multiple: Boolean, requeue: Boolean): JsonObject
suspend fun RabbitMQClient.basicPublishAwait(exchange: String, routingKey: String, message: JsonObject): Unit
suspend fun RabbitMQClient.basicQosAwait(prefetchCount: Int): Unit
suspend fun RabbitMQClient.basicQosAwait(prefetchCount: Int, global: Boolean): Unit
suspend fun RabbitMQClient.basicQosAwait(prefetchSize: Int, prefetchCount: Int, global: Boolean): Unit
suspend fun RabbitMQClient.confirmSelectAwait(): Unit
suspend fun RabbitMQClient.exchangeBindAwait(destination: String, source: String, routingKey: String): Unit
suspend fun RabbitMQClient.exchangeDeclareAwait(exchange: String, type: String, durable: Boolean, autoDelete: Boolean): Unit
suspend fun RabbitMQClient.exchangeDeclareAwait(exchange: String, type: String, durable: Boolean, autoDelete: Boolean, config: JsonObject): Unit
suspend fun RabbitMQClient.exchangeDeleteAwait(exchange: String): Unit
suspend fun RabbitMQClient.exchangeUnbindAwait(destination: String, source: String, routingKey: String): Unit
suspend fun RabbitMQClient.messageCountAwait(queue: String): Long
suspend fun RabbitMQClient.queueBindAwait(queue: String, exchange: String, routingKey: String): Unit
suspend fun RabbitMQClient.queueDeclareAutoAwait(): JsonObject
suspend fun RabbitMQClient.queueDeclareAwait(queue: String, durable: Boolean, exclusive: Boolean, autoDelete: Boolean): JsonObject
suspend fun RabbitMQClient.queueDeclareAwait(queue: String, durable: Boolean, exclusive: Boolean, autoDelete: Boolean, config: JsonObject): JsonObject
suspend fun RabbitMQClient.queueDeleteAwait(queue: String): JsonObject
suspend fun RabbitMQClient.queueDeleteIfAwait(queue: String, ifUnused: Boolean, ifEmpty: Boolean): JsonObject
suspend fun RabbitMQClient.startAwait(): Unit
suspend fun RabbitMQClient.stopAwait(): Unit
suspend fun RabbitMQClient.waitForConfirmsAwait(): Unit
suspend fun RabbitMQClient.waitForConfirmsAwait(timeout: Long): Unit
io.vertx.rabbitmq.RabbitMQConsumer
io.vertx.redis.RedisClient
Module Contents
suspend fun RedisClient.appendAwait(key: String, value: String): Long
suspend fun RedisClient.authAwait(password: String): String
suspend fun RedisClient.bgrewriteaofAwait(): String
suspend fun RedisClient.bgsaveAwait(): String
suspend fun RedisClient.bitcountAwait(key: String): Long
suspend fun RedisClient.bitcountRangeAwait(key: String, start: Long, end: Long): Long
suspend fun RedisClient.bitfieldAwait(key: String, bitFieldOptions: BitFieldOptions): JsonArray
suspend fun RedisClient.bitfieldWithOverflowAwait(key: String, commands: BitFieldOptions, overflow: BitFieldOverflowOptions): JsonArray
suspend fun RedisClient.bitopAwait(operation: BitOperation, destkey: String, keys: List<String>): Long
suspend fun RedisClient.bitposAwait(key: String, bit: Int): Long
suspend fun RedisClient.bitposFromAwait(key: String, bit: Int, start: Int): Long
suspend fun RedisClient.bitposRangeAwait(key: String, bit: Int, start: Int, stop: Int): Long
suspend fun RedisClient.blpopAwait(key: String, seconds: Int): JsonArray
suspend fun RedisClient.blpopManyAwait(keys: List<String>, seconds: Int): JsonArray
suspend fun RedisClient.brpopAwait(key: String, seconds: Int): JsonArray
suspend fun RedisClient.brpopManyAwait(keys: List<String>, seconds: Int): JsonArray
suspend fun RedisClient.brpoplpushAwait(key: String, destkey: String, seconds: Int): String
suspend fun RedisClient.clientGetnameAwait(): String
suspend fun RedisClient.clientKillAwait(filter: KillFilter): Long
suspend fun RedisClient.clientListAwait(): String
suspend fun RedisClient.clientPauseAwait(millis: Long): String
suspend fun RedisClient.clientReplyAwait(options: ClientReplyOptions): String
suspend fun RedisClient.clientSetnameAwait(name: String): String
suspend fun RedisClient.closeAwait(): Unit
suspend fun RedisClient.clusterAddslotsAwait(slots: List<Long>): Unit
suspend fun RedisClient.clusterCountFailureReportsAwait(nodeId: String): Long
suspend fun RedisClient.clusterCountkeysinslotAwait(slot: Long): Long
suspend fun RedisClient.clusterDelslotsAwait(slot: Long): Unit
suspend fun RedisClient.clusterDelslotsManyAwait(slots: List<Long>): Unit
suspend fun RedisClient.clusterFailOverWithOptionsAwait(options: FailoverOptions): Unit
suspend fun RedisClient.clusterFailoverAwait(): Unit
suspend fun RedisClient.clusterForgetAwait(nodeId: String): Unit
suspend fun RedisClient.clusterGetkeysinslotAwait(slot: Long, count: Long): JsonArray
suspend fun RedisClient.clusterInfoAwait(): JsonArray
suspend fun RedisClient.clusterKeyslotAwait(key: String): Long
suspend fun RedisClient.clusterMeetAwait(ip: String, port: Long): Unit
suspend fun RedisClient.clusterNodesAwait(): JsonArray
suspend fun RedisClient.clusterReplicateAwait(nodeId: String): Unit
suspend fun RedisClient.clusterResetAwait(): Unit
suspend fun RedisClient.clusterResetWithOptionsAwait(options: ResetOptions): Unit
suspend fun RedisClient.clusterSaveconfigAwait(): Unit
suspend fun RedisClient.clusterSetConfigEpochAwait(epoch: Long): Unit
suspend fun RedisClient.clusterSetslotAwait(slot: Long, subcommand: SlotCmd): Unit
suspend fun RedisClient.clusterSetslotWithNodeAwait(slot: Long, subcommand: SlotCmd, nodeId: String): Unit
suspend fun RedisClient.clusterSlavesAwait(nodeId: String): JsonArray
suspend fun RedisClient.clusterSlotsAwait(): JsonArray
suspend fun RedisClient.commandAwait(): JsonArray
suspend fun RedisClient.commandCountAwait(): Long
suspend fun RedisClient.commandGetkeysAwait(): JsonArray
suspend fun RedisClient.commandInfoAwait(commands: List<String>): JsonArray
suspend fun RedisClient.configGetAwait(parameter: String): JsonArray
suspend fun RedisClient.configResetstatAwait(): String
suspend fun RedisClient.configRewriteAwait(): String
suspend fun RedisClient.configSetAwait(parameter: String, value: String): String
suspend fun RedisClient.dbsizeAwait(): Long
suspend fun RedisClient.debugObjectAwait(key: String): String
suspend fun RedisClient.debugSegfaultAwait(): String
suspend fun RedisClient.decrAwait(key: String): Long
suspend fun RedisClient.decrbyAwait(key: String, decrement: Long): Long
suspend fun RedisClient.delAwait(key: String): Long
suspend fun RedisClient.delManyAwait(keys: List<String>): Long
suspend fun RedisClient.dumpAwait(key: String): String
suspend fun RedisClient.echoAwait(message: String): String
suspend fun RedisClient.evalAwait(script: String, keys: List<String>, args: List<String>): JsonArray
suspend fun RedisClient.evalScriptAwait(script: Script, keys: List<String>, args: List<String>): JsonArray
suspend fun RedisClient.evalshaAwait(sha1: String, keys: List<String>, values: List<String>): JsonArray
suspend fun RedisClient.existsAwait(key: String): Long
suspend fun RedisClient.existsManyAwait(keys: List<String>): Long
suspend fun RedisClient.expireAwait(key: String, seconds: Long): Long
suspend fun RedisClient.expireatAwait(key: String, seconds: Long): Long
suspend fun RedisClient.flushallAwait(): String
suspend fun RedisClient.flushdbAwait(): String
suspend fun RedisClient.geoaddAwait(key: String, longitude: Double, latitude: Double, member: String): Long
suspend fun RedisClient.geoaddManyAwait(key: String, members: List<GeoMember>): Long
suspend fun RedisClient.geodistAwait(key: String, member1: String, member2: String): String
suspend fun RedisClient.geodistWithUnitAwait(key: String, member1: String, member2: String, unit: GeoUnit): String
suspend fun RedisClient.geohashAwait(key: String, member: String): JsonArray
suspend fun RedisClient.geohashManyAwait(key: String, members: List<String>): JsonArray
suspend fun RedisClient.geoposAwait(key: String, member: String): JsonArray
suspend fun RedisClient.geoposManyAwait(key: String, members: List<String>): JsonArray
suspend fun RedisClient.georadiusAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit): JsonArray
suspend fun RedisClient.georadiusWithOptionsAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): JsonArray
suspend fun RedisClient.georadiusbymemberAwait(key: String, member: String, radius: Double, unit: GeoUnit): JsonArray
suspend fun RedisClient.georadiusbymemberWithOptionsAwait(key: String, member: String, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): JsonArray
suspend fun RedisClient.getAwait(key: String): String?
suspend fun RedisClient.getBinaryAwait(key: String): Buffer?
suspend fun RedisClient.getbitAwait(key: String, offset: Long): Long
suspend fun RedisClient.getrangeAwait(key: String, start: Long, end: Long): String
suspend fun RedisClient.getsetAwait(key: String, value: String): String?
suspend fun RedisClient.hdelAwait(key: String, field: String): Long
suspend fun RedisClient.hdelManyAwait(key: String, fields: List<String>): Long
suspend fun RedisClient.hexistsAwait(key: String, field: String): Long
suspend fun RedisClient.hgetAwait(key: String, field: String): String?
suspend fun RedisClient.hgetallAwait(key: String): JsonObject
suspend fun RedisClient.hincrbyAwait(key: String, field: String, increment: Long): Long
suspend fun RedisClient.hincrbyfloatAwait(key: String, field: String, increment: Double): String
suspend fun RedisClient.hkeysAwait(key: String): JsonArray
suspend fun RedisClient.hlenAwait(key: String): Long
suspend fun RedisClient.hmgetAwait(key: String, fields: List<String>): JsonArray
suspend fun RedisClient.hmsetAwait(key: String, values: JsonObject): String
suspend fun RedisClient.hscanAwait(key: String, cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.hsetAwait(key: String, field: String, value: String): Long
suspend fun RedisClient.hsetnxAwait(key: String, field: String, value: String): Long
suspend fun RedisClient.hstrlenAwait(key: String, field: String): Long
suspend fun RedisClient.hvalsAwait(key: String): JsonArray
suspend fun RedisClient.incrAwait(key: String): Long
suspend fun RedisClient.incrbyAwait(key: String, increment: Long): Long
suspend fun RedisClient.incrbyfloatAwait(key: String, increment: Double): String
suspend fun RedisClient.infoAwait(): JsonObject
suspend fun RedisClient.infoSectionAwait(section: String): JsonObject
suspend fun RedisClient.keysAwait(pattern: String): JsonArray
suspend fun RedisClient.lastsaveAwait(): Long
suspend fun RedisClient.lindexAwait(key: String, index: Int): String
suspend fun RedisClient.linsertAwait(key: String, option: InsertOptions, pivot: String, value: String): Long
suspend fun RedisClient.llenAwait(key: String): Long
suspend fun RedisClient.lpopAwait(key: String): String?
suspend fun RedisClient.lpushAwait(key: String, value: String): Long
suspend fun RedisClient.lpushManyAwait(key: String, values: List<String>): Long
suspend fun RedisClient.lpushxAwait(key: String, value: String): Long
suspend fun RedisClient.lrangeAwait(key: String, from: Long, to: Long): JsonArray
suspend fun RedisClient.lremAwait(key: String, count: Long, value: String): Long
suspend fun RedisClient.lsetAwait(key: String, index: Long, value: String): String
suspend fun RedisClient.ltrimAwait(key: String, from: Long, to: Long): String
suspend fun RedisClient.mgetAwait(key: String): JsonArray
suspend fun RedisClient.mgetManyAwait(keys: List<String>): JsonArray
suspend fun RedisClient.migrateAwait(host: String, port: Int, key: String, destdb: Int, timeout: Long, options: MigrateOptions): String
suspend fun RedisClient.monitorAwait(): Unit
suspend fun RedisClient.moveAwait(key: String, destdb: Int): Long
suspend fun RedisClient.msetAwait(keyvals: JsonObject): String
suspend fun RedisClient.msetnxAwait(keyvals: JsonObject): Long
suspend fun RedisClient.objectAwait(key: String, cmd: ObjectCmd): Unit
suspend fun RedisClient.persistAwait(key: String): Long
suspend fun RedisClient.pexpireAwait(key: String, millis: Long): Long
suspend fun RedisClient.pexpireatAwait(key: String, millis: Long): Long
suspend fun RedisClient.pfaddAwait(key: String, element: String): Long
suspend fun RedisClient.pfaddManyAwait(key: String, elements: List<String>): Long
suspend fun RedisClient.pfcountAwait(key: String): Long
suspend fun RedisClient.pfcountManyAwait(keys: List<String>): Long
suspend fun RedisClient.pfmergeAwait(destkey: String, keys: List<String>): String
suspend fun RedisClient.pingAwait(): String
suspend fun RedisClient.psetexAwait(key: String, millis: Long, value: String): Unit
suspend fun RedisClient.psubscribeAwait(pattern: String): JsonArray
suspend fun RedisClient.psubscribeManyAwait(patterns: List<String>): JsonArray
suspend fun RedisClient.pttlAwait(key: String): Long
suspend fun RedisClient.publishAwait(channel: String, message: String): Long
suspend fun RedisClient.pubsubChannelsAwait(pattern: String): JsonArray
suspend fun RedisClient.pubsubNumpatAwait(): Long
suspend fun RedisClient.pubsubNumsubAwait(channels: List<String>): JsonArray
suspend fun RedisClient.punsubscribeAwait(patterns: List<String>): Unit
suspend fun RedisClient.randomkeyAwait(): String
suspend fun RedisClient.renameAwait(key: String, newkey: String): String
suspend fun RedisClient.renamenxAwait(key: String, newkey: String): Long
suspend fun RedisClient.restoreAwait(key: String, millis: Long, serialized: String): String
suspend fun RedisClient.roleAwait(): JsonArray
suspend fun RedisClient.rpopAwait(key: String): String
suspend fun RedisClient.rpoplpushAwait(key: String, destkey: String): String
suspend fun RedisClient.rpushAwait(key: String, value: String): Long
suspend fun RedisClient.rpushManyAwait(key: String, values: List<String>): Long
suspend fun RedisClient.rpushxAwait(key: String, value: String): Long
suspend fun RedisClient.saddAwait(key: String, member: String): Long
suspend fun RedisClient.saddManyAwait(key: String, members: List<String>): Long
suspend fun RedisClient.saveAwait(): String
suspend fun RedisClient.scanAwait(cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.scardAwait(key: String): Long
suspend fun RedisClient.scriptDebugAwait(scriptDebugOptions: ScriptDebugOptions): String
suspend fun RedisClient.scriptExistsAwait(script: String): JsonArray
suspend fun RedisClient.scriptExistsManyAwait(scripts: List<String>): JsonArray
suspend fun RedisClient.scriptFlushAwait(): String
suspend fun RedisClient.scriptKillAwait(): String
suspend fun RedisClient.scriptLoadAwait(script: String): String
suspend fun RedisClient.sdiffAwait(key: String, cmpkeys: List<String>): JsonArray
suspend fun RedisClient.sdiffstoreAwait(destkey: String, key: String, cmpkeys: List<String>): Long
suspend fun RedisClient.selectAwait(dbindex: Int): String
suspend fun RedisClient.setAwait(key: String, value: String): Unit
suspend fun RedisClient.setBinaryAwait(key: String, value: Buffer): Unit
suspend fun RedisClient.setBinaryWithOptionsAwait(key: String, value: Buffer, options: SetOptions): Unit
suspend fun RedisClient.setWithOptionsAwait(key: String, value: String, options: SetOptions): String
suspend fun RedisClient.setbitAwait(key: String, offset: Long, bit: Int): Long
suspend fun RedisClient.setexAwait(key: String, seconds: Long, value: String): String
suspend fun RedisClient.setnxAwait(key: String, value: String): Long
suspend fun RedisClient.setrangeAwait(key: String, offset: Int, value: String): Long
suspend fun RedisClient.sinterAwait(keys: List<String>): JsonArray
suspend fun RedisClient.sinterstoreAwait(destkey: String, keys: List<String>): Long
suspend fun RedisClient.sismemberAwait(key: String, member: String): Long
suspend fun RedisClient.slaveofAwait(host: String, port: Int): String
suspend fun RedisClient.slaveofNooneAwait(): String
suspend fun RedisClient.slowlogGetAwait(limit: Int): JsonArray
suspend fun RedisClient.slowlogLenAwait(): Long
suspend fun RedisClient.slowlogResetAwait(): Unit
suspend fun RedisClient.smembersAwait(key: String): JsonArray
suspend fun RedisClient.smoveAwait(key: String, destkey: String, member: String): Long
suspend fun RedisClient.sortAwait(key: String, options: SortOptions): JsonArray
suspend fun RedisClient.spopAwait(key: String): String?
suspend fun RedisClient.spopManyAwait(key: String, count: Int): JsonArray
suspend fun RedisClient.srandmemberAwait(key: String): String
suspend fun RedisClient.srandmemberCountAwait(key: String, count: Int): JsonArray
suspend fun RedisClient.sremAwait(key: String, member: String): Long
suspend fun RedisClient.sremManyAwait(key: String, members: List<String>): Long
suspend fun RedisClient.sscanAwait(key: String, cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.strlenAwait(key: String): Long
suspend fun RedisClient.subscribeAwait(channel: String): JsonArray
suspend fun RedisClient.subscribeManyAwait(channels: List<String>): JsonArray
suspend fun RedisClient.sunionAwait(keys: List<String>): JsonArray
suspend fun RedisClient.sunionstoreAwait(destkey: String, keys: List<String>): Long
suspend fun RedisClient.swapdbAwait(index1: Int, index2: Int): String
suspend fun RedisClient.syncAwait(): Unit
suspend fun RedisClient.timeAwait(): JsonArray
suspend fun RedisClient.touchAwait(key: String): Long
suspend fun RedisClient.touchManyAwait(keys: List<String>): Long
suspend fun RedisClient.ttlAwait(key: String): Long
suspend fun RedisClient.typeAwait(key: String): String
suspend fun RedisClient.unlinkAwait(key: String): Long
suspend fun RedisClient.unlinkManyAwait(keys: List<String>): Long
suspend fun RedisClient.unsubscribeAwait(channels: List<String>): Unit
suspend fun RedisClient.waitAwait(numSlaves: Long, timeout: Long): String
suspend fun RedisClient.zaddAwait(key: String, score: Double, member: String): Long
suspend fun RedisClient.zaddManyAwait(key: String, members: Map<String, Double>): Long
suspend fun RedisClient.zcardAwait(key: String): Long
suspend fun RedisClient.zcountAwait(key: String, min: Double, max: Double): Long
suspend fun RedisClient.zincrbyAwait(key: String, increment: Double, member: String): String
suspend fun RedisClient.zinterstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): Long
suspend fun RedisClient.zinterstoreWeighedAwait(destkey: String, sets: Map<String, Double>, options: AggregateOptions): Long
suspend fun RedisClient.zlexcountAwait(key: String, min: String, max: String): Long
suspend fun RedisClient.zrangeAwait(key: String, start: Long, stop: Long): JsonArray
suspend fun RedisClient.zrangeWithOptionsAwait(key: String, start: Long, stop: Long, options: RangeOptions): JsonArray
suspend fun RedisClient.zrangebylexAwait(key: String, min: String, max: String, options: LimitOptions): JsonArray
suspend fun RedisClient.zrangebyscoreAwait(key: String, min: String, max: String, options: RangeLimitOptions): JsonArray
suspend fun RedisClient.zrankAwait(key: String, member: String): Long
suspend fun RedisClient.zremAwait(key: String, member: String): Long
suspend fun RedisClient.zremManyAwait(key: String, members: List<String>): Long
suspend fun RedisClient.zremrangebylexAwait(key: String, min: String, max: String): Long
suspend fun RedisClient.zremrangebyrankAwait(key: String, start: Long, stop: Long): Long
suspend fun RedisClient.zremrangebyscoreAwait(key: String, min: String, max: String): Long
suspend fun RedisClient.zrevrangeAwait(key: String, start: Long, stop: Long, options: RangeOptions): JsonArray
suspend fun RedisClient.zrevrangebylexAwait(key: String, max: String, min: String, options: LimitOptions): JsonArray
suspend fun RedisClient.zrevrangebyscoreAwait(key: String, max: String, min: String, options: RangeLimitOptions): JsonArray
suspend fun RedisClient.zrevrankAwait(key: String, member: String): Long
suspend fun RedisClient.zscanAwait(key: String, cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.zscoreAwait(key: String, member: String): String
suspend fun RedisClient.zunionstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): Long
suspend fun RedisClient.zunionstoreWeighedAwait(key: String, sets: Map<String, Double>, options: AggregateOptions): Long
io.vertx.redis.RedisTransaction
Module Contents
suspend fun RedisTransaction.appendAwait(key: String, value: String): String
suspend fun RedisTransaction.authAwait(password: String): String
suspend fun RedisTransaction.bgrewriteaofAwait(): String
suspend fun RedisTransaction.bgsaveAwait(): String
suspend fun RedisTransaction.bitcountAwait(key: String): String
suspend fun RedisTransaction.bitcountRangeAwait(key: String, start: Long, end: Long): String
suspend fun RedisTransaction.bitopAwait(operation: BitOperation, destkey: String, keys: List<String>): String
suspend fun RedisTransaction.bitposAwait(key: String, bit: Int): String
suspend fun RedisTransaction.bitposFromAwait(key: String, bit: Int, start: Int): String
suspend fun RedisTransaction.bitposRangeAwait(key: String, bit: Int, start: Int, stop: Int): String
suspend fun RedisTransaction.blpopAwait(key: String, seconds: Int): String
suspend fun RedisTransaction.blpopManyAwait(keys: List<String>, seconds: Int): String
suspend fun RedisTransaction.brpopAwait(key: String, seconds: Int): String
suspend fun RedisTransaction.brpopManyAwait(keys: List<String>, seconds: Int): String
suspend fun RedisTransaction.brpoplpushAwait(key: String, destkey: String, seconds: Int): String
suspend fun RedisTransaction.clientGetnameAwait(): String
suspend fun RedisTransaction.clientKillAwait(filter: KillFilter): String
suspend fun RedisTransaction.clientListAwait(): String
suspend fun RedisTransaction.clientPauseAwait(millis: Long): String
suspend fun RedisTransaction.clientSetnameAwait(name: String): String
suspend fun RedisTransaction.closeAwait(): Unit
suspend fun RedisTransaction.clusterAddslotsAwait(slots: List<String>): String
suspend fun RedisTransaction.clusterCountFailureReportsAwait(nodeId: String): String
suspend fun RedisTransaction.clusterCountkeysinslotAwait(slot: Long): String
suspend fun RedisTransaction.clusterDelslotsAwait(slot: Long): String
suspend fun RedisTransaction.clusterDelslotsManyAwait(slots: List<String>): String
suspend fun RedisTransaction.clusterFailOverWithOptionsAwait(options: FailoverOptions): String
suspend fun RedisTransaction.clusterFailoverAwait(): String
suspend fun RedisTransaction.clusterForgetAwait(nodeId: String): String
suspend fun RedisTransaction.clusterGetkeysinslotAwait(slot: Long, count: Long): String
suspend fun RedisTransaction.clusterInfoAwait(): String
suspend fun RedisTransaction.clusterKeyslotAwait(key: String): String
suspend fun RedisTransaction.clusterMeetAwait(ip: String, port: Long): String
suspend fun RedisTransaction.clusterNodesAwait(): String
suspend fun RedisTransaction.clusterReplicateAwait(nodeId: String): String
suspend fun RedisTransaction.clusterResetAwait(): String
suspend fun RedisTransaction.clusterResetWithOptionsAwait(options: ResetOptions): String
suspend fun RedisTransaction.clusterSaveconfigAwait(): String
suspend fun RedisTransaction.clusterSetConfigEpochAwait(epoch: Long): String
suspend fun RedisTransaction.clusterSetslotAwait(slot: Long, subcommand: SlotCmd): String
suspend fun RedisTransaction.clusterSetslotWithNodeAwait(slot: Long, subcommand: SlotCmd, nodeId: String): String
suspend fun RedisTransaction.clusterSlavesAwait(nodeId: String): String
suspend fun RedisTransaction.clusterSlotsAwait(): String
suspend fun RedisTransaction.commandAwait(): String
suspend fun RedisTransaction.commandCountAwait(): String
suspend fun RedisTransaction.commandGetkeysAwait(): String
suspend fun RedisTransaction.commandInfoAwait(commands: List<String>): String
suspend fun RedisTransaction.configGetAwait(parameter: String): String
suspend fun RedisTransaction.configResetstatAwait(): String
suspend fun RedisTransaction.configRewriteAwait(): String
suspend fun RedisTransaction.configSetAwait(parameter: String, value: String): String
suspend fun RedisTransaction.dbsizeAwait(): String
suspend fun RedisTransaction.debugObjectAwait(key: String): String
suspend fun RedisTransaction.debugSegfaultAwait(): String
suspend fun RedisTransaction.decrAwait(key: String): String
suspend fun RedisTransaction.decrbyAwait(key: String, decrement: Long): String
suspend fun RedisTransaction.delAwait(key: String): String
suspend fun RedisTransaction.delManyAwait(keys: List<String>): String
suspend fun RedisTransaction.discardAwait(): String
suspend fun RedisTransaction.dumpAwait(key: String): String
suspend fun RedisTransaction.echoAwait(message: String): String
suspend fun RedisTransaction.evalAwait(script: String, keys: List<String>, args: List<String>): String
suspend fun RedisTransaction.evalshaAwait(sha1: String, keys: List<String>, values: List<String>): String
suspend fun RedisTransaction.execAwait(): JsonArray
suspend fun RedisTransaction.existsAwait(key: String): String
suspend fun RedisTransaction.existsManyAwait(keys: List<String>): String
suspend fun RedisTransaction.expireAwait(key: String, seconds: Int): String
suspend fun RedisTransaction.expireatAwait(key: String, seconds: Long): String
suspend fun RedisTransaction.flushallAwait(): String
suspend fun RedisTransaction.flushdbAwait(): String
suspend fun RedisTransaction.geoaddAwait(key: String, longitude: Double, latitude: Double, member: String): String
suspend fun RedisTransaction.geoaddManyAwait(key: String, members: List<GeoMember>): String
suspend fun RedisTransaction.geodistAwait(key: String, member1: String, member2: String): String
suspend fun RedisTransaction.geodistWithUnitAwait(key: String, member1: String, member2: String, unit: GeoUnit): String
suspend fun RedisTransaction.geohashAwait(key: String, member: String): String
suspend fun RedisTransaction.geohashManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.geoposAwait(key: String, member: String): String
suspend fun RedisTransaction.geoposManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.georadiusAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit): String
suspend fun RedisTransaction.georadiusWithOptionsAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): String
suspend fun RedisTransaction.georadiusbymemberAwait(key: String, member: String, radius: Double, unit: GeoUnit): String
suspend fun RedisTransaction.georadiusbymemberWithOptionsAwait(key: String, member: String, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): String
suspend fun RedisTransaction.getAwait(key: String): String
suspend fun RedisTransaction.getBinaryAwait(key: String): Buffer
suspend fun RedisTransaction.getbitAwait(key: String, offset: Long): String
suspend fun RedisTransaction.getrangeAwait(key: String, start: Long, end: Long): String
suspend fun RedisTransaction.getsetAwait(key: String, value: String): String
suspend fun RedisTransaction.hdelAwait(key: String, field: String): String
suspend fun RedisTransaction.hdelManyAwait(key: String, fields: List<String>): String
suspend fun RedisTransaction.hexistsAwait(key: String, field: String): String
suspend fun RedisTransaction.hgetAwait(key: String, field: String): String
suspend fun RedisTransaction.hgetallAwait(key: String): String
suspend fun RedisTransaction.hincrbyAwait(key: String, field: String, increment: Long): String
suspend fun RedisTransaction.hincrbyfloatAwait(key: String, field: String, increment: Double): String
suspend fun RedisTransaction.hkeysAwait(key: String): String
suspend fun RedisTransaction.hlenAwait(key: String): String
suspend fun RedisTransaction.hmgetAwait(key: String, fields: List<String>): String
suspend fun RedisTransaction.hmsetAwait(key: String, values: JsonObject): String
suspend fun RedisTransaction.hscanAwait(key: String, cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.hsetAwait(key: String, field: String, value: String): String
suspend fun RedisTransaction.hsetnxAwait(key: String, field: String, value: String): String
suspend fun RedisTransaction.hvalsAwait(key: String): String
suspend fun RedisTransaction.incrAwait(key: String): String
suspend fun RedisTransaction.incrbyAwait(key: String, increment: Long): String
suspend fun RedisTransaction.incrbyfloatAwait(key: String, increment: Double): String
suspend fun RedisTransaction.infoAwait(): String
suspend fun RedisTransaction.infoSectionAwait(section: String): String
suspend fun RedisTransaction.keysAwait(pattern: String): String
suspend fun RedisTransaction.lastsaveAwait(): String
suspend fun RedisTransaction.lindexAwait(key: String, index: Int): String
suspend fun RedisTransaction.linsertAwait(key: String, option: InsertOptions, pivot: String, value: String): String
suspend fun RedisTransaction.llenAwait(key: String): String
suspend fun RedisTransaction.lpopAwait(key: String): String
suspend fun RedisTransaction.lpushAwait(key: String, value: String): String
suspend fun RedisTransaction.lpushManyAwait(key: String, values: List<String>): String
suspend fun RedisTransaction.lpushxAwait(key: String, value: String): String
suspend fun RedisTransaction.lrangeAwait(key: String, from: Long, to: Long): String
suspend fun RedisTransaction.lremAwait(key: String, count: Long, value: String): String
suspend fun RedisTransaction.lsetAwait(key: String, index: Long, value: String): String
suspend fun RedisTransaction.ltrimAwait(key: String, from: Long, to: Long): String
suspend fun RedisTransaction.mgetAwait(key: String): String
suspend fun RedisTransaction.mgetManyAwait(keys: List<String>): String
suspend fun RedisTransaction.migrateAwait(host: String, port: Int, key: String, destdb: Int, timeout: Long, options: MigrateOptions): String
suspend fun RedisTransaction.monitorAwait(): String
suspend fun RedisTransaction.moveAwait(key: String, destdb: Int): String
suspend fun RedisTransaction.msetAwait(keyvals: JsonObject): String
suspend fun RedisTransaction.msetnxAwait(keyvals: JsonObject): String
suspend fun RedisTransaction.multiAwait(): String
suspend fun RedisTransaction.objectAwait(key: String, cmd: ObjectCmd): String
suspend fun RedisTransaction.persistAwait(key: String): String
suspend fun RedisTransaction.pexpireAwait(key: String, millis: Long): String
suspend fun RedisTransaction.pexpireatAwait(key: String, millis: Long): String
suspend fun RedisTransaction.pfaddAwait(key: String, element: String): String
suspend fun RedisTransaction.pfaddManyAwait(key: String, elements: List<String>): String
suspend fun RedisTransaction.pfcountAwait(key: String): String
suspend fun RedisTransaction.pfcountManyAwait(keys: List<String>): String
suspend fun RedisTransaction.pfmergeAwait(destkey: String, keys: List<String>): String
suspend fun RedisTransaction.pingAwait(): String
suspend fun RedisTransaction.psetexAwait(key: String, millis: Long, value: String): String
suspend fun RedisTransaction.psubscribeAwait(pattern: String): String
suspend fun RedisTransaction.psubscribeManyAwait(patterns: List<String>): String
suspend fun RedisTransaction.pttlAwait(key: String): String
suspend fun RedisTransaction.publishAwait(channel: String, message: String): String
suspend fun RedisTransaction.pubsubChannelsAwait(pattern: String): String
suspend fun RedisTransaction.pubsubNumpatAwait(): String
suspend fun RedisTransaction.pubsubNumsubAwait(channels: List<String>): String
suspend fun RedisTransaction.punsubscribeAwait(patterns: List<String>): String
suspend fun RedisTransaction.randomkeyAwait(): String
suspend fun RedisTransaction.renameAwait(key: String, newkey: String): String
suspend fun RedisTransaction.renamenxAwait(key: String, newkey: String): String
suspend fun RedisTransaction.restoreAwait(key: String, millis: Long, serialized: String): String
suspend fun RedisTransaction.roleAwait(): String
suspend fun RedisTransaction.rpopAwait(key: String): String
suspend fun RedisTransaction.rpoplpushAwait(key: String, destkey: String): String
suspend fun RedisTransaction.rpushAwait(key: String, value: String): String
suspend fun RedisTransaction.rpushManyAwait(key: String, values: List<String>): String
suspend fun RedisTransaction.rpushxAwait(key: String, value: String): String
suspend fun RedisTransaction.saddAwait(key: String, member: String): String
suspend fun RedisTransaction.saddManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.saveAwait(): String
suspend fun RedisTransaction.scanAwait(cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.scardAwait(key: String): String
suspend fun RedisTransaction.scriptExistsAwait(script: String): String
suspend fun RedisTransaction.scriptExistsManyAwait(scripts: List<String>): String
suspend fun RedisTransaction.scriptFlushAwait(): String
suspend fun RedisTransaction.scriptKillAwait(): String
suspend fun RedisTransaction.scriptLoadAwait(script: String): String
suspend fun RedisTransaction.sdiffAwait(key: String, cmpkeys: List<String>): String
suspend fun RedisTransaction.sdiffstoreAwait(destkey: String, key: String, cmpkeys: List<String>): String
suspend fun RedisTransaction.selectAwait(dbindex: Int): String
suspend fun RedisTransaction.setAwait(key: String, value: String): String
suspend fun RedisTransaction.setBinaryAwait(key: String, value: Buffer): String
suspend fun RedisTransaction.setBinaryWithOptionsAwait(key: String, value: Buffer, options: SetOptions): String
suspend fun RedisTransaction.setWithOptionsAwait(key: String, value: String, options: SetOptions): String
suspend fun RedisTransaction.setbitAwait(key: String, offset: Long, bit: Int): String
suspend fun RedisTransaction.setexAwait(key: String, seconds: Long, value: String): String
suspend fun RedisTransaction.setnxAwait(key: String, value: String): String
suspend fun RedisTransaction.setrangeAwait(key: String, offset: Int, value: String): String
suspend fun RedisTransaction.sinterAwait(keys: List<String>): String
suspend fun RedisTransaction.sinterstoreAwait(destkey: String, keys: List<String>): String
suspend fun RedisTransaction.sismemberAwait(key: String, member: String): String
suspend fun RedisTransaction.slaveofAwait(host: String, port: Int): String
suspend fun RedisTransaction.slaveofNooneAwait(): String
suspend fun RedisTransaction.slowlogGetAwait(limit: Int): String
suspend fun RedisTransaction.slowlogLenAwait(): String
suspend fun RedisTransaction.slowlogResetAwait(): String
suspend fun RedisTransaction.smembersAwait(key: String): JsonArray
suspend fun RedisTransaction.smoveAwait(key: String, destkey: String, member: String): String
suspend fun RedisTransaction.sortAwait(key: String, options: SortOptions): String
suspend fun RedisTransaction.spopAwait(key: String): String
suspend fun RedisTransaction.spopManyAwait(key: String, count: Int): String
suspend fun RedisTransaction.srandmemberAwait(key: String): String
suspend fun RedisTransaction.srandmemberCountAwait(key: String, count: Int): String
suspend fun RedisTransaction.sremAwait(key: String, member: String): String
suspend fun RedisTransaction.sremManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.sscanAwait(key: String, cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.strlenAwait(key: String): String
suspend fun RedisTransaction.subscribeAwait(channel: String): String
suspend fun RedisTransaction.subscribeManyAwait(channels: List<String>): String
suspend fun RedisTransaction.sunionAwait(keys: List<String>): String
suspend fun RedisTransaction.sunionstoreAwait(destkey: String, keys: List<String>): String
suspend fun RedisTransaction.swapdbAwait(index1: Int, index2: Int): String
suspend fun RedisTransaction.syncAwait(): String
suspend fun RedisTransaction.timeAwait(): String
suspend fun RedisTransaction.ttlAwait(key: String): String
suspend fun RedisTransaction.typeAwait(key: String): String
suspend fun RedisTransaction.unlinkAwait(key: String): String
suspend fun RedisTransaction.unlinkManyAwait(keys: List<String>): String
suspend fun RedisTransaction.unsubscribeAwait(channels: List<String>): String
suspend fun RedisTransaction.unwatchAwait(): String
suspend fun RedisTransaction.waitAwait(numSlaves: Long, timeout: Long): String
suspend fun RedisTransaction.watchAwait(key: String): String
suspend fun RedisTransaction.watchManyAwait(keys: List<String>): String
suspend fun RedisTransaction.zaddAwait(key: String, score: Double, member: String): String
suspend fun RedisTransaction.zaddManyAwait(key: String, members: Map<String, Double>): String
suspend fun RedisTransaction.zcardAwait(key: String): String
suspend fun RedisTransaction.zcountAwait(key: String, min: Double, max: Double): String
suspend fun RedisTransaction.zincrbyAwait(key: String, increment: Double, member: String): String
suspend fun RedisTransaction.zinterstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): String
suspend fun RedisTransaction.zinterstoreWeighedAwait(destkey: String, sets: Map<String, Double>, options: AggregateOptions): String
suspend fun RedisTransaction.zlexcountAwait(key: String, min: String, max: String): String
suspend fun RedisTransaction.zrangeAwait(key: String, start: Long, stop: Long): String
suspend fun RedisTransaction.zrangeWithOptionsAwait(key: String, start: Long, stop: Long, options: RangeOptions): String
suspend fun RedisTransaction.zrangebylexAwait(key: String, min: String, max: String, options: LimitOptions): String
suspend fun RedisTransaction.zrangebyscoreAwait(key: String, min: String, max: String, options: RangeLimitOptions): String
suspend fun RedisTransaction.zrankAwait(key: String, member: String): String
suspend fun RedisTransaction.zremAwait(key: String, member: String): String
suspend fun RedisTransaction.zremManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.zremrangebylexAwait(key: String, min: String, max: String): String
suspend fun RedisTransaction.zremrangebyrankAwait(key: String, start: Long, stop: Long): String
suspend fun RedisTransaction.zremrangebyscoreAwait(key: String, min: String, max: String): String
suspend fun RedisTransaction.zrevrangeAwait(key: String, start: Long, stop: Long, options: RangeOptions): String
suspend fun RedisTransaction.zrevrangebylexAwait(key: String, max: String, min: String, options: LimitOptions): String
suspend fun RedisTransaction.zrevrangebyscoreAwait(key: String, max: String, min: String, options: RangeLimitOptions): String
suspend fun RedisTransaction.zrevrankAwait(key: String, member: String): String
suspend fun RedisTransaction.zscanAwait(key: String, cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.zscoreAwait(key: String, member: String): String
suspend fun RedisTransaction.zunionstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): String
suspend fun RedisTransaction.zunionstoreWeighedAwait(key: String, sets: Map<String, Double>, options: AggregateOptions): String
io.vertx.redis.sentinel.RedisSentinel
io.vertx.servicediscovery.ServiceDiscovery
io.vertx.servicediscovery.spi.ServicePublisher
package io.vertx.kotlin.amqpbridge
Module Contents
fun AmqpBridgeOptions(connectTimeout: Int? = null, containerId: String? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSaslMechanisms: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, heartbeat: Int? = null, hostnameVerificationAlgorithm: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, maxFrameSize: Int? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reconnectAttempts: Int? = null, reconnectInterval: Long? = null, replyHandlingSupport: Boolean? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sniServerName: String? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, vhost: String? = null, virtualHost: String? = null): AmqpBridgeOptions
io.vertx.amqpbridge.AmqpBridge
package io.vertx.kotlin.cassandra
package io.vertx.kotlin.circuitbreaker
package io.vertx.kotlin.config
package io.vertx.kotlin.config.vault.client
package io.vertx.kotlin.core
Module Contents
fun DeploymentOptions(config: JsonObject? = null, : Iterable<String>? = null, ha: Boolean? = null, instances: Int? = null, isolatedClasses: Iterable<String>? = null, isolationGroup: String? = null, maxWorkerExecuteTime: Long? = null, maxWorkerExecuteTimeUnit: TimeUnit? = null, multiThreaded: Boolean? = null, worker: Boolean? = null, workerPoolName: String? = null, workerPoolSize: Int? = null): DeploymentOptions
object Vertx
fun VertxOptions(addressResolverOptions: AddressResolverOptions? = null, blockedThreadCheckInterval: Long? = null, blockedThreadCheckIntervalUnit: TimeUnit? = null, clusterHost: String? = null, clusterPingInterval: Long? = null, clusterPingReplyInterval: Long? = null, clusterPort: Int? = null, clusterPublicHost: String? = null, clusterPublicPort: Int? = null, clustered: Boolean? = null, eventBusOptions: EventBusOptions? = null, eventLoopPoolSize: Int? = null, fileResolverCachingEnabled: Boolean? = null, fileSystemOptions: FileSystemOptions? = null, haEnabled: Boolean? = null, haGroup: String? = null, internalBlockingPoolSize: Int? = null, maxEventLoopExecuteTime: Long? = null, maxEventLoopExecuteTimeUnit: TimeUnit? = null, maxWorkerExecuteTime: Long? = null, maxWorkerExecuteTimeUnit: TimeUnit? = null, metricsOptions: MetricsOptions? = null, preferNativeTransport: Boolean? = null, quorumSize: Int? = null, warningExceptionTime: Long? = null, warningExceptionTimeUnit: TimeUnit? = null, workerPoolSize: Int? = null): VertxOptions
io.vertx.core.CompositeFuture
io.vertx.core.Context
io.vertx.core.Future
io.vertx.core.Vertx
io.vertx.core.WorkerExecutor
package io.vertx.kotlin.core.buffer
package io.vertx.kotlin.core.cli
Module Contents
fun Argument(argName: String? = null, defaultValue: String? = null, description: String? = null, hidden: Boolean? = null, index: Int? = null, multiValued: Boolean? = null, required: Boolean? = null): Argument
fun Option(argName: String? = null, choices: Iterable<String>? = null, defaultValue: String? = null, description: String? = null, flag: Boolean? = null, help: Boolean? = null, hidden: Boolean? = null, longName: String? = null, multiValued: Boolean? = null, required: Boolean? = null, shortName: String? = null, singleValued: Boolean? = null): Option
package io.vertx.kotlin.core.datagram
Module Contents
fun DatagramSocketOptions(broadcast: Boolean? = null, ipV6: Boolean? = null, logActivity: Boolean? = null, loopbackModeDisabled: Boolean? = null, multicastNetworkInterface: String? = null, multicastTimeToLive: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, trafficClass: Int? = null): DatagramSocketOptions
io.vertx.core.datagram.DatagramSocket
Module Contents
suspend fun DatagramSocket.blockMulticastGroupAwait(multicastAddress: String, sourceToBlock: String): DatagramSocket
suspend fun DatagramSocket.blockMulticastGroupAwait(multicastAddress: String, networkInterface: String, sourceToBlock: String): DatagramSocket
suspend fun DatagramSocket.closeAwait(): Unit
suspend fun DatagramSocket.listenAwait(port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.listenMulticastGroupAwait(multicastAddress: String): DatagramSocket
suspend fun DatagramSocket.listenMulticastGroupAwait(multicastAddress: String, networkInterface: String, source: String): DatagramSocket
suspend fun DatagramSocket.sendAwait(packet: Buffer, port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.sendAwait(str: String, port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.sendAwait(str: String, enc: String, port: Int, host: String): DatagramSocket
suspend fun DatagramSocket.unlistenMulticastGroupAwait(multicastAddress: String): DatagramSocket
suspend fun DatagramSocket.unlistenMulticastGroupAwait(multicastAddress: String, networkInterface: String, source: String): DatagramSocket
package io.vertx.kotlin.core.dns
Module Contents
fun AddressResolverOptions(cacheMaxTimeToLive: Int? = null, cacheMinTimeToLive: Int? = null, cacheNegativeTimeToLive: Int? = null, hostsPath: String? = null, hostsValue: Buffer? = null, maxQueries: Int? = null, ndots: Int? = null, optResourceEnabled: Boolean? = null, queryTimeout: Long? = null, rdFlag: Boolean? = null, rotateServers: Boolean? = null, searchDomains: Iterable<String>? = null, servers: Iterable<String>? = null): AddressResolverOptions
fun DnsClientOptions(host: String? = null, logActivity: Boolean? = null, port: Int? = null, queryTimeout: Long? = null, recursionDesired: Boolean? = null): DnsClientOptions
io.vertx.core.dns.DnsClient
package io.vertx.kotlin.core.eventbus
Module Contents
fun DeliveryOptions(codecName: String? = null, : Map<String, String>? = null, localOnly: Boolean? = null, sendTimeout: Long? = null): DeliveryOptions
fun EventBusOptions(acceptBacklog: Int? = null, clientAuth: ClientAuth? = null, clusterPingInterval: Long? = null, clusterPingReplyInterval: Long? = null, clusterPublicHost: String? = null, clusterPublicPort: Int? = null, clustered: Boolean? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, host: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reconnectAttempts: Int? = null, reconnectInterval: Long? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null): EventBusOptions
io.vertx.core.eventbus.EventBus
io.vertx.core.eventbus.Message
io.vertx.core.eventbus.MessageConsumer
package io.vertx.kotlin.core.file
Module Contents
fun CopyOptions(atomicMove: Boolean? = null, copyAttributes: Boolean? = null, nofollowLinks: Boolean? = null, replaceExisting: Boolean? = null): CopyOptions
fun FileSystemOptions(classPathResolvingEnabled: Boolean? = null, fileCachingEnabled: Boolean? = null): FileSystemOptions
fun OpenOptions(append: Boolean? = null, create: Boolean? = null, createNew: Boolean? = null, deleteOnClose: Boolean? = null, dsync: Boolean? = null, perms: String? = null, read: Boolean? = null, sparse: Boolean? = null, sync: Boolean? = null, truncateExisting: Boolean? = null, write: Boolean? = null): OpenOptions
io.vertx.core.file.AsyncFile
io.vertx.core.file.FileSystem
Module Contents
suspend fun FileSystem.chmodAwait(path: String, perms: String): Unit
suspend fun FileSystem.chmodRecursiveAwait(path: String, perms: String, dirPerms: String): Unit
suspend fun FileSystem.chownAwait(path: String, user: String, group: String): Unit
suspend fun FileSystem.copyAwait(from: String, to: String): Unit
suspend fun FileSystem.copyAwait(from: String, to: String, options: CopyOptions): Unit
suspend fun FileSystem.copyRecursiveAwait(from: String, to: String, recursive: Boolean): Unit
suspend fun FileSystem.createFileAwait(path: String): Unit
suspend fun FileSystem.createFileAwait(path: String, perms: String): Unit
suspend fun FileSystem.createTempDirectoryAwait(prefix: String): String
suspend fun FileSystem.createTempDirectoryAwait(prefix: String, perms: String): String
suspend fun FileSystem.createTempDirectoryAwait(dir: String, prefix: String, perms: String): String
suspend fun FileSystem.createTempFileAwait(prefix: String, suffix: String): String
suspend fun FileSystem.createTempFileAwait(prefix: String, suffix: String, perms: String): String
suspend fun FileSystem.createTempFileAwait(dir: String, prefix: String, suffix: String, perms: String): String
suspend fun FileSystem.deleteAwait(path: String): Unit
suspend fun FileSystem.deleteRecursiveAwait(path: String, recursive: Boolean): Unit
suspend fun FileSystem.existsAwait(path: String): Boolean
suspend fun FileSystem.fsPropsAwait(path: String): FileSystemProps
suspend fun FileSystem.linkAwait(link: String, existing: String): Unit
suspend fun FileSystem.lpropsAwait(path: String): FileProps
suspend fun FileSystem.mkdirAwait(path: String): Unit
suspend fun FileSystem.mkdirAwait(path: String, perms: String): Unit
suspend fun FileSystem.mkdirsAwait(path: String): Unit
suspend fun FileSystem.mkdirsAwait(path: String, perms: String): Unit
suspend fun FileSystem.moveAwait(from: String, to: String): Unit
suspend fun FileSystem.moveAwait(from: String, to: String, options: CopyOptions): Unit
suspend fun FileSystem.openAwait(path: String, options: OpenOptions): AsyncFile
suspend fun FileSystem.propsAwait(path: String): FileProps
suspend fun FileSystem.readDirAwait(path: String): List<String>
suspend fun FileSystem.readDirAwait(path: String, filter: String): List<String>
suspend fun FileSystem.readFileAwait(path: String): Buffer
suspend fun FileSystem.readSymlinkAwait(link: String): String
suspend fun FileSystem.symlinkAwait(link: String, existing: String): Unit
suspend fun FileSystem.truncateAwait(path: String, len: Long): Unit
suspend fun FileSystem.unlinkAwait(link: String): Unit
suspend fun FileSystem.writeFileAwait(path: String, data: Buffer): Unit
package io.vertx.kotlin.core.http
Module Contents
fun GoAway(debugData: Buffer? = null, errorCode: Long? = null, lastStreamId: Int? = null): GoAway
fun Http2Settings(: Long? = null, initialWindowSize: Int? = null, maxConcurrentStreams: Long? = null, maxFrameSize: Int? = null, : Long? = null, pushEnabled: Boolean? = null): Http2Settings
fun HttpClientOptions(alpnVersions: Iterable<HttpVersion>? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, decoderInitialBufferSize: Int? = null, defaultHost: String? = null, defaultPort: Int? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, forceSni: Boolean? = null, http2ClearTextUpgrade: Boolean? = null, http2ConnectionWindowSize: Int? = null, http2KeepAliveTimeout: Int? = null, http2MaxPoolSize: Int? = null, http2MultiplexingLimit: Int? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, initialSettings: Http2Settings? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keepAlive: Boolean? = null, keepAliveTimeout: Int? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, maxChunkSize: Int? = null, : Int? = null, maxInitialLineLength: Int? = null, maxPoolSize: Int? = null, maxRedirects: Int? = null, maxWaitQueueSize: Int? = null, maxWebsocketFrameSize: Int? = null, maxWebsocketMessageSize: Int? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, pipelining: Boolean? = null, pipeliningLimit: Int? = null, poolCleanerPeriod: Int? = null, protocolVersion: HttpVersion? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sendUnmaskedFrames: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, tryUseCompression: Boolean? = null, tryUsePerFrameWebsocketCompression: Boolean? = null, tryUsePerMessageWebsocketCompression: Boolean? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, verifyHost: Boolean? = null, websocketCompressionAllowClientNoContext: Boolean? = null, websocketCompressionLevel: Int? = null, websocketCompressionRequestServerNoContext: Boolean? = null): HttpClientOptions
fun HttpServerOptions(acceptBacklog: Int? = null, acceptUnmaskedFrames: Boolean? = null, alpnVersions: Iterable<HttpVersion>? = null, clientAuth: ClientAuth? = null, clientAuthRequired: Boolean? = null, compressionLevel: Int? = null, compressionSupported: Boolean? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, decoderInitialBufferSize: Int? = null, decompressionSupported: Boolean? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, handle100ContinueAutomatically: Boolean? = null, host: String? = null, http2ConnectionWindowSize: Int? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, initialSettings: Http2Settings? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, maxChunkSize: Int? = null, : Int? = null, maxInitialLineLength: Int? = null, maxWebsocketFrameSize: Int? = null, maxWebsocketMessageSize: Int? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, perFrameWebsocketCompressionSupported: Boolean? = null, perMessageWebsocketCompressionSupported: Boolean? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sni: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, websocketAllowServerNoContext: Boolean? = null, websocketCompressionLevel: Int? = null, websocketPreferredClientNoContext: Boolean? = null, websocketSubProtocols: String? = null): HttpServerOptions
fun RequestOptions(host: String? = null, port: Int? = null, ssl: Boolean? = null, uri: String? = null): RequestOptions
fun StreamPriority(dependency: Int? = null, exclusive: Boolean? = null, weight: Short? = null): StreamPriority
io.vertx.core.http.HttpConnection
io.vertx.core.http.HttpServer
io.vertx.core.http.HttpServerResponse
Module Contents
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, host: String, path: String): HttpServerResponse
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, path: String, : MultiMap): HttpServerResponse
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, path: String): HttpServerResponse
suspend fun HttpServerResponse.pushAwait(method: HttpMethod, host: String, path: String, : MultiMap): HttpServerResponse
suspend fun HttpServerResponse.sendFileAwait(filename: String): Unit
suspend fun HttpServerResponse.sendFileAwait(filename: String, offset: Long): Unit
suspend fun HttpServerResponse.sendFileAwait(filename: String, offset: Long, length: Long): Unit
package io.vertx.kotlin.core.json
package io.vertx.kotlin.core.metrics
package io.vertx.kotlin.core.net
Module Contents
fun JdkSSLEngineOptions(): JdkSSLEngineOptions
fun JksOptions(password: String? = null, path: String? = null, value: Buffer? = null): JksOptions
fun NetClientOptions(connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, hostnameVerificationAlgorithm: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reconnectAttempts: Int? = null, reconnectInterval: Long? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null): NetClientOptions
fun NetServerOptions(acceptBacklog: Int? = null, clientAuth: ClientAuth? = null, clientAuthRequired: Boolean? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, host: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sni: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null): NetServerOptions
fun OpenSSLEngineOptions(sessionCacheEnabled: Boolean? = null): OpenSSLEngineOptions
fun PemKeyCertOptions(certPath: String? = null, certPaths: Iterable<String>? = null, certValue: Buffer? = null, certValues: Iterable<Buffer>? = null, keyPath: String? = null, keyPaths: Iterable<String>? = null, keyValue: Buffer? = null, keyValues: Iterable<Buffer>? = null): PemKeyCertOptions
fun PemTrustOptions(certPaths: Iterable<String>? = null, certValues: Iterable<Buffer>? = null): PemTrustOptions
fun PfxOptions(password: String? = null, path: String? = null, value: Buffer? = null): PfxOptions
fun ProxyOptions(host: String? = null, password: String? = null, port: Int? = null, type: ProxyType? = null, username: String? = null): ProxyOptions
io.vertx.core.net.NetClient
io.vertx.core.net.NetServer
io.vertx.core.net.NetSocket
package io.vertx.kotlin.core.shareddata
Module Contents
io.vertx.core.shareddata.AsyncMap
Module Contents
suspend fun <K, V> AsyncMap<K, V>.clearAwait(): Unit
suspend fun <K, V> AsyncMap<K, V>.getAwait(k: K): V?
suspend fun <K, V> AsyncMap<K, V>.putAwait(k: K, v: V): Unit
suspend fun <K, V> AsyncMap<K, V>.putAwait(k: K, v: V, ttl: Long): Unit
suspend fun <K, V> AsyncMap<K, V>.putIfAbsentAwait(k: K, v: V): V?
suspend fun <K, V> AsyncMap<K, V>.putIfAbsentAwait(k: K, v: V, ttl: Long): V?
suspend fun <K, V> AsyncMap<K, V>.removeAwait(k: K): V?
suspend fun <K, V> AsyncMap<K, V>.removeIfPresentAwait(k: K, v: V): Boolean
suspend fun <K, V> AsyncMap<K, V>.replaceAwait(k: K, v: V): V?
suspend fun <K, V> AsyncMap<K, V>.replaceIfPresentAwait(k: K, oldValue: V, newValue: V): Boolean
suspend fun <K, V> AsyncMap<K, V>.sizeAwait(): Int
io.vertx.core.shareddata.Counter
io.vertx.core.shareddata.SharedData
package io.vertx.kotlin.core.streams
package io.vertx.kotlin.ext.asyncsql
package io.vertx.kotlin.ext.auth
package io.vertx.kotlin.ext.auth.htpasswd
package io.vertx.kotlin.ext.auth.jdbc
package io.vertx.kotlin.ext.auth.jwt
Module Contents
fun JWTAuthOptions(jwks: Iterable<JsonObject>? = null, jwtOptions: JWTOptions? = null, keyStore: KeyStoreOptions? = null, permissionsClaimKey: String? = null, pubSecKeys: Iterable<PubSecKeyOptions>? = null, secrets: Iterable<SecretOptions>? = null): JWTAuthOptions
fun JWTKeyStoreOptions(password: String? = null, path: String? = null, type: String? = null): JWTKeyStoreOptions
fun JWTOptions(algorithm: String? = null, audience: Iterable<String>? = null, audiences: Iterable<String>? = null, expiresInMinutes: Int? = null, expiresInSeconds: Int? = null, : JsonObject? = null, ignoreExpiration: Boolean? = null, issuer: String? = null, leeway: Int? = null, noTimestamp: Boolean? = null, permissions: Iterable<String>? = null, subject: String? = null): JWTOptions
package io.vertx.kotlin.ext.auth.mongo
Module Contents
fun MongoAuthOptions(collectionName: String? = null, config: JsonObject? = null, datasourceName: String? = null, passwordField: String? = null, permissionField: String? = null, roleField: String? = null, saltField: String? = null, saltStyle: HashSaltStyle? = null, shared: Boolean? = null, usernameCredentialField: String? = null, usernameField: String? = null): MongoAuthOptions
io.vertx.ext.auth.mongo.MongoAuth
package io.vertx.kotlin.ext.auth.oauth2
Module Contents
fun OAuth2ClientOptions(alpnVersions: Iterable<HttpVersion>? = null, authorizationPath: String? = null, clientID: String? = null, clientSecret: String? = null, clientSecretParameterName: String? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, decoderInitialBufferSize: Int? = null, defaultHost: String? = null, defaultPort: Int? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, : JsonObject? = null, flow: OAuth2FlowType? = null, forceSni: Boolean? = null, : JsonObject? = null, http2ClearTextUpgrade: Boolean? = null, http2ConnectionWindowSize: Int? = null, http2KeepAliveTimeout: Int? = null, http2MaxPoolSize: Int? = null, http2MultiplexingLimit: Int? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, initialSettings: Http2Settings? = null, introspectionPath: String? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, jwkPath: String? = null, jwtOptions: JWTOptions? = null, keepAlive: Boolean? = null, keepAliveTimeout: Int? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, logoutPath: String? = null, maxChunkSize: Int? = null, : Int? = null, maxInitialLineLength: Int? = null, maxPoolSize: Int? = null, maxRedirects: Int? = null, maxWaitQueueSize: Int? = null, maxWebsocketFrameSize: Int? = null, maxWebsocketMessageSize: Int? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, pipelining: Boolean? = null, pipeliningLimit: Int? = null, poolCleanerPeriod: Int? = null, protocolVersion: HttpVersion? = null, proxyOptions: ProxyOptions? = null, pubSecKeys: Iterable<PubSecKeyOptions>? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, revocationPath: String? = null, scopeSeparator: String? = null, sendBufferSize: Int? = null, sendUnmaskedFrames: Boolean? = null, site: String? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, tokenPath: String? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, tryUseCompression: Boolean? = null, tryUsePerFrameWebsocketCompression: Boolean? = null, tryUsePerMessageWebsocketCompression: Boolean? = null, useAlpn: Boolean? = null, : Boolean? = null, usePooledBuffers: Boolean? = null, userAgent: String? = null, userInfoParameters: JsonObject? = null, userInfoPath: String? = null, validateIssuer: Boolean? = null, verifyHost: Boolean? = null, websocketCompressionAllowClientNoContext: Boolean? = null, websocketCompressionLevel: Int? = null, websocketCompressionRequestServerNoContext: Boolean? = null): OAuth2ClientOptions
io.vertx.ext.auth.oauth2.AccessToken
io.vertx.ext.auth.oauth2.OAuth2Auth
io.vertx.ext.auth.oauth2.OAuth2RBAC
package io.vertx.kotlin.ext.auth.oauth2.providers
package io.vertx.kotlin.ext.auth.shiro
package io.vertx.kotlin.ext.bridge
package io.vertx.kotlin.ext.consul
Module Contents
fun AclToken(id: String? = null, name: String? = null, rules: String? = null, type: AclTokenType? = null): AclToken
fun BlockingQueryOptions(index: Long? = null, wait: String? = null): BlockingQueryOptions
fun Check(id: String? = null, name: String? = null, nodeName: String? = null, notes: String? = null, output: String? = null, serviceId: String? = null, serviceName: String? = null, status: CheckStatus? = null): Check
fun CheckList(index: Long? = null, list: Iterable<Check>? = null): CheckList
fun CheckOptions(deregisterAfter: String? = null, grpc: String? = null, grpcTls: Boolean? = null, http: String? = null, id: String? = null, interval: String? = null, name: String? = null, notes: String? = null, scriptArgs: Iterable<String>? = null, serviceId: String? = null, status: CheckStatus? = null, tcp: String? = null, tlsSkipVerify: Boolean? = null, ttl: String? = null): CheckOptions
fun CheckQueryOptions(blockingOptions: BlockingQueryOptions? = null, near: String? = null): CheckQueryOptions
fun ConsulClientOptions(aclToken: String? = null, alpnVersions: Iterable<HttpVersion>? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, dc: String? = null, decoderInitialBufferSize: Int? = null, defaultHost: String? = null, defaultPort: Int? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, followRedirects: Boolean? = null, forceSni: Boolean? = null, http2ClearTextUpgrade: Boolean? = null, http2ConnectionWindowSize: Int? = null, http2KeepAliveTimeout: Int? = null, http2MaxPoolSize: Int? = null, http2MultiplexingLimit: Int? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, initialSettings: Http2Settings? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keepAlive: Boolean? = null, keepAliveTimeout: Int? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, maxChunkSize: Int? = null, : Int? = null, maxInitialLineLength: Int? = null, maxPoolSize: Int? = null, maxRedirects: Int? = null, maxWaitQueueSize: Int? = null, maxWebsocketFrameSize: Int? = null, maxWebsocketMessageSize: Int? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, pipelining: Boolean? = null, pipeliningLimit: Int? = null, poolCleanerPeriod: Int? = null, protocolVersion: HttpVersion? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sendUnmaskedFrames: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, timeout: Long? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, tryUseCompression: Boolean? = null, tryUsePerFrameWebsocketCompression: Boolean? = null, tryUsePerMessageWebsocketCompression: Boolean? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, userAgent: String? = null, userAgentEnabled: Boolean? = null, verifyHost: Boolean? = null, websocketCompressionAllowClientNoContext: Boolean? = null, websocketCompressionLevel: Int? = null, websocketCompressionRequestServerNoContext: Boolean? = null): ConsulClientOptions
fun Coordinate(adj: Float? = null, err: Float? = null, height: Float? = null, node: String? = null, vec: Iterable<Float>? = null): Coordinate
fun CoordinateList(index: Long? = null, list: Iterable<Coordinate>? = null): CoordinateList
fun DcCoordinates(datacenter: String? = null, servers: Iterable<Coordinate>? = null): DcCoordinates
fun Event(id: String? = null, lTime: Int? = null, name: String? = null, node: String? = null, payload: String? = null, service: String? = null, tag: String? = null, version: Int? = null): Event
fun EventList(index: Long? = null, list: Iterable<Event>? = null): EventList
fun EventListOptions(blockingOptions: BlockingQueryOptions? = null, name: String? = null): EventListOptions
fun EventOptions(node: String? = null, payload: String? = null, service: String? = null, tag: String? = null): EventOptions
fun KeyValue(createIndex: Long? = null, flags: Long? = null, key: String? = null, lockIndex: Long? = null, modifyIndex: Long? = null, session: String? = null, value: String? = null): KeyValue
fun KeyValueList(index: Long? = null, list: Iterable<KeyValue>? = null): KeyValueList
fun KeyValueOptions(acquireSession: String? = null, casIndex: Long? = null, flags: Long? = null, releaseSession: String? = null): KeyValueOptions
fun MaintenanceOptions(enable: Boolean? = null, id: String? = null, reason: String? = null): MaintenanceOptions
fun Node(address: String? = null, lanAddress: String? = null, name: String? = null, wanAddress: String? = null): Node
fun NodeList(index: Long? = null, list: Iterable<Node>? = null): NodeList
fun NodeQueryOptions(blockingOptions: BlockingQueryOptions? = null, near: String? = null): NodeQueryOptions
fun PreparedQueryDefinition(dcs: Iterable<String>? = null, dnsTtl: String? = null, id: String? = null, meta: Map<String, String>? = null, name: String? = null, nearestN: Int? = null, passing: Boolean? = null, service: String? = null, session: String? = null, tags: Iterable<String>? = null, templateRegexp: String? = null, templateType: String? = null, token: String? = null): PreparedQueryDefinition
fun PreparedQueryExecuteOptions(limit: Int? = null, near: String? = null): PreparedQueryExecuteOptions
fun PreparedQueryExecuteResponse(dc: String? = null, dnsTtl: String? = null, failovers: Int? = null, nodes: Iterable<ServiceEntry>? = null, service: String? = null): PreparedQueryExecuteResponse
fun Service(address: String? = null, id: String? = null, meta: Map<String, String>? = null, name: String? = null, node: String? = null, nodeAddress: String? = null, port: Int? = null, tags: Iterable<String>? = null): Service
fun ServiceEntry(checks: Iterable<Check>? = null, node: Node? = null, service: Service? = null): ServiceEntry
fun ServiceEntryList(index: Long? = null, list: Iterable<ServiceEntry>? = null): ServiceEntryList
fun ServiceList(index: Long? = null, list: Iterable<Service>? = null): ServiceList
fun ServiceOptions(address: String? = null, checkOptions: CheckOptions? = null, id: String? = null, meta: Map<String, String>? = null, name: String? = null, port: Int? = null, tags: Iterable<String>? = null): ServiceOptions
fun ServiceQueryOptions(blockingOptions: BlockingQueryOptions? = null, near: String? = null, tag: String? = null): ServiceQueryOptions
fun Session(checks: Iterable<String>? = null, createIndex: Long? = null, id: String? = null, index: Long? = null, lockDelay: Long? = null, node: String? = null): Session
fun SessionList(index: Long? = null, list: Iterable<Session>? = null): SessionList
fun SessionOptions(behavior: SessionBehavior? = null, checks: Iterable<String>? = null, lockDelay: Long? = null, name: String? = null, node: String? = null, ttl: Long? = null): SessionOptions
fun TxnError(opIndex: Int? = null, what: String? = null): TxnError
fun TxnKVOperation(flags: Long? = null, index: Long? = null, key: String? = null, session: String? = null, type: TxnKVVerb? = null, value: String? = null): TxnKVOperation
fun TxnRequest(): TxnRequest
fun TxnResponse(errors: Iterable<TxnError>? = null): TxnResponse
io.vertx.ext.consul.ConsulClient
Module Contents
suspend fun ConsulClient.agentInfoAwait(): JsonObject
suspend fun ConsulClient.catalogDatacentersAwait(): List<String>
suspend fun ConsulClient.catalogNodeServicesAwait(node: String): ServiceList
suspend fun ConsulClient.catalogNodeServicesWithOptionsAwait(node: String, options: BlockingQueryOptions): ServiceList
suspend fun ConsulClient.catalogNodesAwait(): NodeList
suspend fun ConsulClient.catalogNodesWithOptionsAwait(options: NodeQueryOptions): NodeList
suspend fun ConsulClient.catalogServiceNodesAwait(service: String): ServiceList
suspend fun ConsulClient.catalogServiceNodesWithOptionsAwait(service: String, options: ServiceQueryOptions): ServiceList
suspend fun ConsulClient.catalogServicesAwait(): ServiceList
suspend fun ConsulClient.catalogServicesWithOptionsAwait(options: BlockingQueryOptions): ServiceList
suspend fun ConsulClient.cloneAclTokenAwait(id: String): String
suspend fun ConsulClient.coordinateDatacentersAwait(): List<DcCoordinates>
suspend fun ConsulClient.coordinateNodesAwait(): CoordinateList
suspend fun ConsulClient.coordinateNodesWithOptionsAwait(options: BlockingQueryOptions): CoordinateList
suspend fun ConsulClient.createAclTokenAwait(token: AclToken): String
suspend fun ConsulClient.createPreparedQueryAwait(definition: PreparedQueryDefinition): String
suspend fun ConsulClient.createSessionAwait(): String
suspend fun ConsulClient.createSessionWithOptionsAwait(options: SessionOptions): String
suspend fun ConsulClient.deletePreparedQueryAwait(id: String): Unit
suspend fun ConsulClient.deleteValueAwait(key: String): Unit
suspend fun ConsulClient.deleteValuesAwait(keyPrefix: String): Unit
suspend fun ConsulClient.deregisterCheckAwait(checkId: String): Unit
suspend fun ConsulClient.deregisterServiceAwait(id: String): Unit
suspend fun ConsulClient.destroyAclTokenAwait(id: String): Unit
suspend fun ConsulClient.destroySessionAwait(id: String): Unit
suspend fun ConsulClient.executePreparedQueryAwait(query: String): PreparedQueryExecuteResponse
suspend fun ConsulClient.executePreparedQueryWithOptionsAwait(query: String, options: PreparedQueryExecuteOptions): PreparedQueryExecuteResponse
suspend fun ConsulClient.failCheckAwait(checkId: String): Unit
suspend fun ConsulClient.failCheckWithNoteAwait(checkId: String, note: String): Unit
suspend fun ConsulClient.fireEventAwait(name: String): Event
suspend fun ConsulClient.fireEventWithOptionsAwait(name: String, options: EventOptions): Event
suspend fun ConsulClient.getAllPreparedQueriesAwait(): List<PreparedQueryDefinition>
suspend fun ConsulClient.getKeysAwait(keyPrefix: String): List<String>
suspend fun ConsulClient.getKeysWithOptionsAwait(keyPrefix: String, options: BlockingQueryOptions): List<String>
suspend fun ConsulClient.getPreparedQueryAwait(id: String): PreparedQueryDefinition
suspend fun ConsulClient.getValueAwait(key: String): KeyValue
suspend fun ConsulClient.getValueWithOptionsAwait(key: String, options: BlockingQueryOptions): KeyValue
suspend fun ConsulClient.getValuesAwait(keyPrefix: String): KeyValueList
suspend fun ConsulClient.getValuesWithOptionsAwait(keyPrefix: String, options: BlockingQueryOptions): KeyValueList
suspend fun ConsulClient.healthChecksAwait(service: String): CheckList
suspend fun ConsulClient.healthChecksWithOptionsAwait(service: String, options: CheckQueryOptions): CheckList
suspend fun ConsulClient.healthServiceNodesAwait(service: String, passing: Boolean): ServiceEntryList
suspend fun ConsulClient.healthServiceNodesWithOptionsAwait(service: String, passing: Boolean, options: ServiceQueryOptions): ServiceEntryList
suspend fun ConsulClient.healthStateAwait(healthState: HealthState): CheckList
suspend fun ConsulClient.healthStateWithOptionsAwait(healthState: HealthState, options: CheckQueryOptions): CheckList
suspend fun ConsulClient.infoAclTokenAwait(id: String): AclToken
suspend fun ConsulClient.infoSessionAwait(id: String): Session
suspend fun ConsulClient.infoSessionWithOptionsAwait(id: String, options: BlockingQueryOptions): Session
suspend fun ConsulClient.leaderStatusAwait(): String
suspend fun ConsulClient.listAclTokensAwait(): List<AclToken>
suspend fun ConsulClient.listEventsAwait(): EventList
suspend fun ConsulClient.listEventsWithOptionsAwait(options: EventListOptions): EventList
suspend fun ConsulClient.listNodeSessionsAwait(nodeId: String): SessionList
suspend fun ConsulClient.listNodeSessionsWithOptionsAwait(nodeId: String, options: BlockingQueryOptions): SessionList
suspend fun ConsulClient.listSessionsAwait(): SessionList
suspend fun ConsulClient.listSessionsWithOptionsAwait(options: BlockingQueryOptions): SessionList
suspend fun ConsulClient.localChecksAwait(): List<Check>
suspend fun ConsulClient.localServicesAwait(): List<Service>
suspend fun ConsulClient.maintenanceServiceAwait(maintenanceOptions: MaintenanceOptions): Unit
suspend fun ConsulClient.passCheckAwait(checkId: String): Unit
suspend fun ConsulClient.passCheckWithNoteAwait(checkId: String, note: String): Unit
suspend fun ConsulClient.peersStatusAwait(): List<String>
suspend fun ConsulClient.putValueAwait(key: String, value: String): Boolean
suspend fun ConsulClient.putValueWithOptionsAwait(key: String, value: String, options: KeyValueOptions): Boolean
suspend fun ConsulClient.registerCheckAwait(checkOptions: CheckOptions): Unit
suspend fun ConsulClient.registerServiceAwait(serviceOptions: ServiceOptions): Unit
suspend fun ConsulClient.renewSessionAwait(id: String): Session
suspend fun ConsulClient.transactionAwait(request: TxnRequest): TxnResponse
suspend fun ConsulClient.updateAclTokenAwait(token: AclToken): String
suspend fun ConsulClient.updateCheckAwait(checkId: String, status: CheckStatus): Unit
suspend fun ConsulClient.updateCheckWithNoteAwait(checkId: String, status: CheckStatus, note: String): Unit
suspend fun ConsulClient.updatePreparedQueryAwait(definition: PreparedQueryDefinition): Unit
suspend fun ConsulClient.warnCheckAwait(checkId: String): Unit
suspend fun ConsulClient.warnCheckWithNoteAwait(checkId: String, note: String): Unit
package io.vertx.kotlin.ext.dropwizard
Module Contents
fun DropwizardMetricsOptions(baseName: String? = null, configPath: String? = null, enabled: Boolean? = null, jmxDomain: String? = null, jmxEnabled: Boolean? = null, monitoredEventBusHandlers: Iterable<Match>? = null, monitoredHttpClientEndpoints: Iterable<Match>? = null, monitoredHttpClientUris: Iterable<Match>? = null, monitoredHttpServerUris: Iterable<Match>? = null, registryName: String? = null): DropwizardMetricsOptions
fun Match(alias: String? = null, type: MatchType? = null, value: String? = null): Match
package io.vertx.kotlin.ext.healthchecks
package io.vertx.kotlin.ext.jdbc
package io.vertx.kotlin.ext.jwt
Module Contents
fun JWTOptions(algorithm: String? = null, audience: Iterable<String>? = null, audiences: Iterable<String>? = null, expiresInMinutes: Int? = null, expiresInSeconds: Int? = null, : JsonObject? = null, ignoreExpiration: Boolean? = null, issuer: String? = null, leeway: Int? = null, noTimestamp: Boolean? = null, permissions: Iterable<String>? = null, subject: String? = null): JWTOptions
package io.vertx.kotlin.ext.mail
Module Contents
fun MailAttachment(contentId: String? = null, contentType: String? = null, data: Buffer? = null, description: String? = null, disposition: String? = null, : Map<String, String>? = null, name: String? = null): MailAttachment
fun MailConfig(allowRcptErrors: Boolean? = null, authMethods: String? = null, disableEsmtp: Boolean? = null, hostname: String? = null, keepAlive: Boolean? = null, keyStore: String? = null, keyStorePassword: String? = null, login: LoginOption? = null, maxPoolSize: Int? = null, ownHostname: String? = null, password: String? = null, port: Int? = null, ssl: Boolean? = null, starttls: StartTLSOptions? = null, trustAll: Boolean? = null, username: String? = null): MailConfig
fun MailMessage(attachment: Iterable<MailAttachment>? = null, bcc: Iterable<String>? = null, bounceAddress: String? = null, cc: Iterable<String>? = null, : Boolean? = null, from: String? = null, : Map<String, String>? = null, html: String? = null, inlineAttachment: Iterable<MailAttachment>? = null, subject: String? = null, text: String? = null, to: Iterable<String>? = null): MailMessage
fun MailResult(messageID: String? = null, recipients: Iterable<String>? = null): MailResult
io.vertx.ext.mail.MailClient
package io.vertx.kotlin.ext.mongo
Module Contents
fun AggregateOptions(allowDiskUse: Boolean? = null, batchSize: Int? = null, maxAwaitTime: Long? = null, maxTime: Long? = null): AggregateOptions
fun BulkOperation(document: JsonObject? = null, filter: JsonObject? = null, multi: Boolean? = null, type: BulkOperationType? = null, upsert: Boolean? = null): BulkOperation
fun BulkWriteOptions(ordered: Boolean? = null, writeOption: WriteOption? = null): BulkWriteOptions
fun FindOptions(batchSize: Int? = null, fields: JsonObject? = null, limit: Int? = null, skip: Int? = null, sort: JsonObject? = null): FindOptions
fun IndexOptions(): IndexOptions
fun MongoClientBulkWriteResult(): MongoClientBulkWriteResult
fun MongoClientDeleteResult(): MongoClientDeleteResult
fun MongoClientUpdateResult(): MongoClientUpdateResult
fun UpdateOptions(multi: Boolean? = null, returningNewDocument: Boolean? = null, upsert: Boolean? = null, writeOption: WriteOption? = null): UpdateOptions
io.vertx.ext.mongo.MongoClient
Module Contents
suspend fun MongoClient.bulkWriteAwait(collection: String, operations: List<BulkOperation>): MongoClientBulkWriteResult
suspend fun MongoClient.bulkWriteWithOptionsAwait(collection: String, operations: List<BulkOperation>, bulkWriteOptions: BulkWriteOptions): MongoClientBulkWriteResult
suspend fun MongoClient.countAwait(collection: String, query: JsonObject): Long
suspend fun MongoClient.createCollectionAwait(collectionName: String): Unit
suspend fun MongoClient.createIndexAwait(collection: String, key: JsonObject): Unit
suspend fun MongoClient.createIndexWithOptionsAwait(collection: String, key: JsonObject, options: IndexOptions): Unit
suspend fun MongoClient.distinctAwait(collection: String, fieldName: String, resultClassname: String): JsonArray
suspend fun MongoClient.distinctWithQueryAwait(collection: String, fieldName: String, resultClassname: String, query: JsonObject): JsonArray
suspend fun MongoClient.dropCollectionAwait(collection: String): Unit
suspend fun MongoClient.dropIndexAwait(collection: String, indexName: String): Unit
suspend fun MongoClient.findAwait(collection: String, query: JsonObject): List<JsonObject>
suspend fun MongoClient.findOneAndDeleteAwait(collection: String, query: JsonObject): JsonObject
suspend fun MongoClient.findOneAndDeleteWithOptionsAwait(collection: String, query: JsonObject, findOptions: FindOptions): JsonObject
suspend fun MongoClient.findOneAndReplaceAwait(collection: String, query: JsonObject, replace: JsonObject): JsonObject
suspend fun MongoClient.findOneAndReplaceWithOptionsAwait(collection: String, query: JsonObject, replace: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoClient.findOneAndUpdateAwait(collection: String, query: JsonObject, update: JsonObject): JsonObject
suspend fun MongoClient.findOneAndUpdateWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoClient.findOneAwait(collection: String, query: JsonObject, fields: JsonObject): JsonObject
suspend fun MongoClient.findWithOptionsAwait(collection: String, query: JsonObject, options: FindOptions): List<JsonObject>
suspend fun MongoClient.getCollectionsAwait(): List<String>
suspend fun MongoClient.insertAwait(collection: String, document: JsonObject): String
suspend fun MongoClient.insertWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoClient.listIndexesAwait(collection: String): JsonArray
suspend fun MongoClient.removeDocumentAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoClient.removeDocumentWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoClient.removeDocumentsAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoClient.removeDocumentsWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoClient.replaceDocumentsAwait(collection: String, query: JsonObject, replace: JsonObject): MongoClientUpdateResult
suspend fun MongoClient.replaceDocumentsWithOptionsAwait(collection: String, query: JsonObject, replace: JsonObject, options: UpdateOptions): MongoClientUpdateResult
suspend fun MongoClient.runCommandAwait(commandName: String, command: JsonObject): JsonObject
suspend fun MongoClient.saveAwait(collection: String, document: JsonObject): String
suspend fun MongoClient.saveWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoClient.updateCollectionAwait(collection: String, query: JsonObject, update: JsonObject): MongoClientUpdateResult
suspend fun MongoClient.updateCollectionWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, options: UpdateOptions): MongoClientUpdateResult
io.vertx.ext.mongo.MongoService
Module Contents
suspend fun MongoService.bulkWriteAwait(collection: String, operations: List<BulkOperation>): MongoClientBulkWriteResult
suspend fun MongoService.bulkWriteWithOptionsAwait(collection: String, operations: List<BulkOperation>, bulkWriteOptions: BulkWriteOptions): MongoClientBulkWriteResult
suspend fun MongoService.countAwait(collection: String, query: JsonObject): Long
suspend fun MongoService.createCollectionAwait(collectionName: String): Unit
suspend fun MongoService.createIndexAwait(collection: String, key: JsonObject): Unit
suspend fun MongoService.createIndexWithOptionsAwait(collection: String, key: JsonObject, options: IndexOptions): Unit
suspend fun MongoService.distinctAwait(collection: String, fieldName: String, resultClassname: String): JsonArray
suspend fun MongoService.distinctWithQueryAwait(collection: String, fieldName: String, resultClassname: String, query: JsonObject): JsonArray
suspend fun MongoService.dropCollectionAwait(collection: String): Unit
suspend fun MongoService.dropIndexAwait(collection: String, indexName: String): Unit
suspend fun MongoService.findAwait(collection: String, query: JsonObject): List<JsonObject>
suspend fun MongoService.findOneAndDeleteAwait(collection: String, query: JsonObject): JsonObject
suspend fun MongoService.findOneAndDeleteWithOptionsAwait(collection: String, query: JsonObject, findOptions: FindOptions): JsonObject
suspend fun MongoService.findOneAndReplaceAwait(collection: String, query: JsonObject, replace: JsonObject): JsonObject
suspend fun MongoService.findOneAndReplaceWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoService.findOneAndUpdateAwait(collection: String, query: JsonObject, update: JsonObject): JsonObject
suspend fun MongoService.findOneAndUpdateWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, findOptions: FindOptions, updateOptions: UpdateOptions): JsonObject
suspend fun MongoService.findOneAwait(collection: String, query: JsonObject, fields: JsonObject): JsonObject
suspend fun MongoService.findWithOptionsAwait(collection: String, query: JsonObject, options: FindOptions): List<JsonObject>
suspend fun MongoService.getCollectionsAwait(): List<String>
suspend fun MongoService.insertAwait(collection: String, document: JsonObject): String
suspend fun MongoService.insertWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoService.listIndexesAwait(collection: String): JsonArray
suspend fun MongoService.removeDocumentAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoService.removeDocumentWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoService.removeDocumentsAwait(collection: String, query: JsonObject): MongoClientDeleteResult
suspend fun MongoService.removeDocumentsWithOptionsAwait(collection: String, query: JsonObject, writeOption: WriteOption): MongoClientDeleteResult
suspend fun MongoService.replaceDocumentsAwait(collection: String, query: JsonObject, replace: JsonObject): MongoClientUpdateResult
suspend fun MongoService.replaceDocumentsWithOptionsAwait(collection: String, query: JsonObject, replace: JsonObject, options: UpdateOptions): MongoClientUpdateResult
suspend fun MongoService.runCommandAwait(commandName: String, command: JsonObject): JsonObject
suspend fun MongoService.saveAwait(collection: String, document: JsonObject): String
suspend fun MongoService.saveWithOptionsAwait(collection: String, document: JsonObject, writeOption: WriteOption): String
suspend fun MongoService.updateCollectionAwait(collection: String, query: JsonObject, update: JsonObject): MongoClientUpdateResult
suspend fun MongoService.updateCollectionWithOptionsAwait(collection: String, query: JsonObject, update: JsonObject, options: UpdateOptions): MongoClientUpdateResult
package io.vertx.kotlin.ext.shell
package io.vertx.kotlin.ext.shell.command
package io.vertx.kotlin.ext.shell.term
Module Contents
fun HttpTermOptions(acceptBacklog: Int? = null, acceptUnmaskedFrames: Boolean? = null, alpnVersions: Iterable<HttpVersion>? = null, charset: String? = null, clientAuth: ClientAuth? = null, clientAuthRequired: Boolean? = null, compressionLevel: Int? = null, compressionSupported: Boolean? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, decoderInitialBufferSize: Int? = null, decompressionSupported: Boolean? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, handle100ContinueAutomatically: Boolean? = null, host: String? = null, http2ConnectionWindowSize: Int? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, initialSettings: Http2Settings? = null, intputrc: String? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, maxChunkSize: Int? = null, maxHeaderSize: Int? = null, maxInitialLineLength: Int? = null, maxWebsocketFrameSize: Int? = null, maxWebsocketMessageSize: Int? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, perFrameWebsocketCompressionSupported: Boolean? = null, perMessageWebsocketCompressionSupported: Boolean? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, shellHtmlResource: Buffer? = null, sni: Boolean? = null, soLinger: Int? = null, sockJSHandlerOptions: SockJSHandlerOptions? = null, sockJSPath: String? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, termJsResource: Buffer? = null, trafficClass: Int? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, vertsShellJsResource: Buffer? = null, websocketAllowServerNoContext: Boolean? = null, websocketCompressionLevel: Int? = null, websocketPreferredClientNoContext: Boolean? = null, websocketSubProtocols: String? = null): HttpTermOptions
fun SSHTermOptions(defaultCharset: String? = null, host: String? = null, intputrc: String? = null, keyPairOptions: JksOptions? = null, pemKeyPairOptions: PemKeyCertOptions? = null, pfxKeyPairOptions: PfxOptions? = null, port: Int? = null): SSHTermOptions
fun TelnetTermOptions(acceptBacklog: Int? = null, charset: String? = null, clientAuth: ClientAuth? = null, clientAuthRequired: Boolean? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, host: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, inBinary: Boolean? = null, intputrc: String? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, outBinary: Boolean? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sni: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null): TelnetTermOptions
io.vertx.ext.shell.term.TermServer
package io.vertx.kotlin.ext.sql
Module Contents
fun ResultSet(columnNames: Iterable<String>? = null, next: ResultSet? = null, output: JsonArray? = null, results: Iterable<JsonArray>? = null): ResultSet
fun SQLOptions(autoGeneratedKeys: Boolean? = null, autoGeneratedKeysIndexes: JsonArray? = null, catalog: String? = null, fetchDirection: FetchDirection? = null, fetchSize: Int? = null, queryTimeout: Int? = null, readOnly: Boolean? = null, resultSetConcurrency: ResultSetConcurrency? = null, resultSetType: ResultSetType? = null, schema: String? = null, transactionIsolation: TransactionIsolation? = null): SQLOptions
fun UpdateResult(keys: JsonArray? = null, updated: Int? = null): UpdateResult
io.vertx.ext.sql.SQLClient
io.vertx.ext.sql.SQLConnection
io.vertx.ext.sql.SQLOperations
io.vertx.ext.sql.SQLRowStream
package io.vertx.kotlin.ext.stomp
Module Contents
fun BridgeOptions(inboundPermitteds: Iterable<PermittedOptions>? = null, outboundPermitteds: Iterable<PermittedOptions>? = null, pointToPoint: Boolean? = null): BridgeOptions
fun Frame(body: Buffer? = null, command: Command? = null, destination: String? = null, headers: Map<String, String>? = null, id: String? = null, transaction: String? = null): Frame
fun StompClientOptions(acceptedVersions: Iterable<String>? = null, autoComputeContentLength: Boolean? = null, : Boolean? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, heartbeat: JsonObject? = null, host: String? = null, hostnameVerificationAlgorithm: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, login: String? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, passcode: String? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reconnectAttempts: Int? = null, reconnectInterval: Long? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trailingLine: Boolean? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, useStompFrame: Boolean? = null, virtualHost: String? = null): StompClientOptions
fun StompServerOptions(acceptBacklog: Int? = null, clientAuth: ClientAuth? = null, clientAuthRequired: Boolean? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, heartbeat: JsonObject? = null, host: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, maxBodyLength: Int? = null, maxFrameInTransaction: Int? = null, : Int? = null, : Int? = null, maxSubscriptionsByClient: Int? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, secured: Boolean? = null, sendBufferSize: Int? = null, sendErrorOnNoSubscriptions: Boolean? = null, sni: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, supportedVersions: Iterable<String>? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, timeFactor: Int? = null, trafficClass: Int? = null, trailingLine: Boolean? = null, transactionChunkSize: Int? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, websocketBridge: Boolean? = null, websocketPath: String? = null): StompServerOptions
io.vertx.ext.stomp.StompClient
io.vertx.ext.stomp.StompServer
io.vertx.ext.stomp.StompServerHandler
package io.vertx.kotlin.ext.unit
package io.vertx.kotlin.ext.unit.report
package io.vertx.kotlin.ext.web
package io.vertx.kotlin.ext.web.client
Module Contents
fun WebClientOptions(alpnVersions: Iterable<HttpVersion>? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, decoderInitialBufferSize: Int? = null, defaultHost: String? = null, defaultPort: Int? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, followRedirects: Boolean? = null, forceSni: Boolean? = null, http2ClearTextUpgrade: Boolean? = null, http2ConnectionWindowSize: Int? = null, http2KeepAliveTimeout: Int? = null, http2MaxPoolSize: Int? = null, http2MultiplexingLimit: Int? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, initialSettings: Http2Settings? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keepAlive: Boolean? = null, keepAliveTimeout: Int? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, maxChunkSize: Int? = null, : Int? = null, maxInitialLineLength: Int? = null, maxPoolSize: Int? = null, maxRedirects: Int? = null, maxWaitQueueSize: Int? = null, maxWebsocketFrameSize: Int? = null, maxWebsocketMessageSize: Int? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, pipelining: Boolean? = null, pipeliningLimit: Int? = null, poolCleanerPeriod: Int? = null, protocolVersion: HttpVersion? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sendUnmaskedFrames: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, tryUseCompression: Boolean? = null, tryUsePerFrameWebsocketCompression: Boolean? = null, tryUsePerMessageWebsocketCompression: Boolean? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, userAgent: String? = null, userAgentEnabled: Boolean? = null, verifyHost: Boolean? = null, websocketCompressionAllowClientNoContext: Boolean? = null, websocketCompressionLevel: Int? = null, websocketCompressionRequestServerNoContext: Boolean? = null): WebClientOptions
io.vertx.ext.web.client.HttpRequest
package io.vertx.kotlin.ext.web.common.template
package io.vertx.kotlin.ext.web.handler
package io.vertx.kotlin.ext.web.handler.sockjs
Module Contents
fun BridgeOptions(inboundPermitted: Iterable<PermittedOptions>? = null, inboundPermitteds: Iterable<PermittedOptions>? = null, maxAddressLength: Int? = null, maxHandlersPerSocket: Int? = null, outboundPermitted: Iterable<PermittedOptions>? = null, outboundPermitteds: Iterable<PermittedOptions>? = null, pingTimeout: Long? = null, replyTimeout: Long? = null): BridgeOptions
fun PermittedOptions(address: String? = null, addressRegex: String? = null, match: JsonObject? = null, requiredAuthority: String? = null): PermittedOptions
fun SockJSHandlerOptions(disabledTransports: Iterable<String>? = null, heartbeatInterval: Long? = null, insertJSESSIONID: Boolean? = null, libraryURL: String? = null, maxBytesStreaming: Int? = null, sessionTimeout: Long? = null): SockJSHandlerOptions
io.vertx.ext.web.handler.sockjs.BridgeEvent
package io.vertx.kotlin.ext.web.sstore
package io.vertx.kotlin.kafka.admin
package io.vertx.kotlin.kafka.client.common
Module Contents
fun Node(hasRack: Boolean? = null, host: String? = null, id: Int? = null, idString: String? = null, isEmpty: Boolean? = null, port: Int? = null, rack: String? = null): Node
fun PartitionInfo(inSyncReplicas: Iterable<Node>? = null, leader: Node? = null, partition: Int? = null, replicas: Iterable<Node>? = null, topic: String? = null): PartitionInfo
fun TopicPartition(partition: Int? = null, topic: String? = null): TopicPartition
package io.vertx.kotlin.kafka.client.consumer
Module Contents
fun OffsetAndMetadata(metadata: String? = null, offset: Long? = null): OffsetAndMetadata
fun OffsetAndTimestamp(offset: Long? = null, timestamp: Long? = null): OffsetAndTimestamp
io.vertx.kafka.client.consumer.KafkaConsumer
Module Contents
suspend fun <K, V> KafkaConsumer<K, V>.assignAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.assignAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.assignmentAwait(): Set<TopicPartition>
suspend fun <K, V> KafkaConsumer<K, V>.beginningOffsetsAwait(topicPartition: TopicPartition): Long
suspend fun <K, V> KafkaConsumer<K, V>.closeAwait(): Unit
suspend fun <K, V> KafkaConsumer<K, V>.commitAwait(): Unit
suspend fun <K, V> KafkaConsumer<K, V>.committedAwait(topicPartition: TopicPartition): OffsetAndMetadata
suspend fun <K, V> KafkaConsumer<K, V>.endOffsetsAwait(topicPartition: TopicPartition): Long
suspend fun <K, V> KafkaConsumer<K, V>.offsetsForTimesAwait(topicPartition: TopicPartition, timestamp: Long): OffsetAndTimestamp
suspend fun <K, V> KafkaConsumer<K, V>.partitionsForAwait(topic: String): List<PartitionInfo>
suspend fun <K, V> KafkaConsumer<K, V>.pauseAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.pauseAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.pausedAwait(): Set<TopicPartition>
suspend fun <K, V> KafkaConsumer<K, V>.pollAwait(timeout: Long): KafkaConsumerRecords<K, V>
suspend fun <K, V> KafkaConsumer<K, V>.positionAwait(partition: TopicPartition): Long
suspend fun <K, V> KafkaConsumer<K, V>.resumeAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.resumeAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekAwait(topicPartition: TopicPartition, offset: Long): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToBeginningAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToBeginningAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToEndAwait(topicPartition: TopicPartition): Unit
suspend fun <K, V> KafkaConsumer<K, V>.seekToEndAwait(topicPartitions: Set<TopicPartition>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.subscribeAwait(topic: String): Unit
suspend fun <K, V> KafkaConsumer<K, V>.subscribeAwait(topics: Set<String>): Unit
suspend fun <K, V> KafkaConsumer<K, V>.subscriptionAwait(): Set<String>
suspend fun <K, V> KafkaConsumer<K, V>.unsubscribeAwait(): Unit
package io.vertx.kotlin.kafka.client.producer
package io.vertx.kotlin.micrometer
Module Contents
fun Match(alias: String? = null, domain: MetricsDomain? = null, label: String? = null, type: MatchType? = null, value: String? = null): Match
fun MicrometerMetricsOptions(disabledMetricsCategories: Iterable<MetricsDomain>? = null, enabled: Boolean? = null, influxDbOptions: VertxInfluxDbOptions? = null, jmxMetricsOptions: VertxJmxMetricsOptions? = null, jvmMetricsEnabled: Boolean? = null, labelMatches: Iterable<Match>? = null, labelMatchs: Iterable<Match>? = null, labels: Iterable<Label>? = null, prometheusOptions: VertxPrometheusOptions? = null, registryName: String? = null): MicrometerMetricsOptions
fun VertxInfluxDbOptions(batchSize: Int? = null, compressed: Boolean? = null, connectTimeout: Int? = null, db: String? = null, enabled: Boolean? = null, numThreads: Int? = null, password: String? = null, readTimeout: Int? = null, retentionPolicy: String? = null, step: Int? = null, uri: String? = null, userName: String? = null): VertxInfluxDbOptions
fun VertxJmxMetricsOptions(domain: String? = null, enabled: Boolean? = null, step: Int? = null): VertxJmxMetricsOptions
fun VertxPrometheusOptions(embeddedServerEndpoint: String? = null, embeddedServerOptions: HttpServerOptions? = null, enabled: Boolean? = null, publishQuantiles: Boolean? = null, startEmbeddedServer: Boolean? = null): VertxPrometheusOptions
package io.vertx.kotlin.mqtt
Module Contents
fun MqttAuth(): MqttAuth
fun MqttClientOptions(autoGeneratedClientId: Boolean? = null, autoKeepAlive: Boolean? = null, cleanSession: Boolean? = null, clientId: String? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, hostnameVerificationAlgorithm: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keepAliveTimeSeconds: Int? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, maxInflightQueue: Int? = null, maxMessageSize: Int? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, password: String? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reconnectAttempts: Int? = null, reconnectInterval: Long? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null, username: String? = null, willFlag: Boolean? = null, willMessage: String? = null, willQoS: Int? = null, willRetain: Boolean? = null, willTopic: String? = null): MqttClientOptions
fun MqttServerOptions(acceptBacklog: Int? = null, autoClientId: Boolean? = null, clientAuth: ClientAuth? = null, clientAuthRequired: Boolean? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, host: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, logActivity: Boolean? = null, maxMessageSize: Int? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, receiveBufferSize: Int? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, sendBufferSize: Int? = null, sni: Boolean? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, timeoutOnConnect: Int? = null, trafficClass: Int? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null): MqttServerOptions
fun MqttWill(): MqttWill
io.vertx.mqtt.MqttClient
io.vertx.mqtt.MqttEndpoint
io.vertx.mqtt.MqttServer
package io.vertx.kotlin.rabbitmq
Module Contents
fun QueueOptions(autoAck: Boolean? = null, keepMostRecent: Boolean? = null, maxInternalQueueSize: Int? = null): QueueOptions
fun RabbitMQOptions(automaticRecoveryEnabled: Boolean? = null, connectionRetries: Int? = null, connectionRetryDelay: Long? = null, connectionTimeout: Int? = null, handshakeTimeout: Int? = null, host: String? = null, includeProperties: Boolean? = null, networkRecoveryInterval: Long? = null, password: String? = null, port: Int? = null, requestedChannelMax: Int? = null, requestedHeartbeat: Int? = null, uri: String? = null, user: String? = null, virtualHost: String? = null): RabbitMQOptions
io.vertx.rabbitmq.RabbitMQClient
Module Contents
suspend fun RabbitMQClient.basicAckAwait(deliveryTag: Long, multiple: Boolean): JsonObject
suspend fun RabbitMQClient.basicConsumerAwait(queue: String): RabbitMQConsumer
suspend fun RabbitMQClient.basicConsumerAwait(queue: String, options: QueueOptions): RabbitMQConsumer
suspend fun RabbitMQClient.basicGetAwait(queue: String, autoAck: Boolean): JsonObject
suspend fun RabbitMQClient.basicNackAwait(deliveryTag: Long, multiple: Boolean, requeue: Boolean): JsonObject
suspend fun RabbitMQClient.basicPublishAwait(exchange: String, routingKey: String, message: JsonObject): Unit
suspend fun RabbitMQClient.basicQosAwait(prefetchCount: Int): Unit
suspend fun RabbitMQClient.basicQosAwait(prefetchCount: Int, global: Boolean): Unit
suspend fun RabbitMQClient.basicQosAwait(prefetchSize: Int, prefetchCount: Int, global: Boolean): Unit
suspend fun RabbitMQClient.confirmSelectAwait(): Unit
suspend fun RabbitMQClient.exchangeBindAwait(destination: String, source: String, routingKey: String): Unit
suspend fun RabbitMQClient.exchangeDeclareAwait(exchange: String, type: String, durable: Boolean, autoDelete: Boolean): Unit
suspend fun RabbitMQClient.exchangeDeclareAwait(exchange: String, type: String, durable: Boolean, autoDelete: Boolean, config: JsonObject): Unit
suspend fun RabbitMQClient.exchangeDeleteAwait(exchange: String): Unit
suspend fun RabbitMQClient.exchangeUnbindAwait(destination: String, source: String, routingKey: String): Unit
suspend fun RabbitMQClient.messageCountAwait(queue: String): Long
suspend fun RabbitMQClient.queueBindAwait(queue: String, exchange: String, routingKey: String): Unit
suspend fun RabbitMQClient.queueDeclareAutoAwait(): JsonObject
suspend fun RabbitMQClient.queueDeclareAwait(queue: String, durable: Boolean, exclusive: Boolean, autoDelete: Boolean): JsonObject
suspend fun RabbitMQClient.queueDeclareAwait(queue: String, durable: Boolean, exclusive: Boolean, autoDelete: Boolean, config: JsonObject): JsonObject
suspend fun RabbitMQClient.queueDeleteAwait(queue: String): JsonObject
suspend fun RabbitMQClient.queueDeleteIfAwait(queue: String, ifUnused: Boolean, ifEmpty: Boolean): JsonObject
suspend fun RabbitMQClient.startAwait(): Unit
suspend fun RabbitMQClient.stopAwait(): Unit
suspend fun RabbitMQClient.waitForConfirmsAwait(): Unit
suspend fun RabbitMQClient.waitForConfirmsAwait(timeout: Long): Unit
io.vertx.rabbitmq.RabbitMQConsumer
package io.vertx.kotlin.redis
Module Contents
fun RedisOptions(address: String? = null, auth: String? = null, binary: Boolean? = null, connectTimeout: Int? = null, crlPaths: Iterable<String>? = null, crlValues: Iterable<Buffer>? = null, domainSocket: Boolean? = null, domainSocketAddress: String? = null, enabledCipherSuites: Iterable<String>? = null, enabledSecureTransportProtocols: Iterable<String>? = null, encoding: String? = null, host: String? = null, hostnameVerificationAlgorithm: String? = null, idleTimeout: Int? = null, idleTimeoutUnit: TimeUnit? = null, jdkSslEngineOptions: JdkSSLEngineOptions? = null, keyStoreOptions: JksOptions? = null, localAddress: String? = null, logActivity: Boolean? = null, masterName: String? = null, metricsName: String? = null, openSslEngineOptions: OpenSSLEngineOptions? = null, pemKeyCertOptions: PemKeyCertOptions? = null, pemTrustOptions: PemTrustOptions? = null, pfxKeyCertOptions: PfxOptions? = null, pfxTrustOptions: PfxOptions? = null, port: Int? = null, proxyOptions: ProxyOptions? = null, receiveBufferSize: Int? = null, reconnectAttempts: Int? = null, reconnectInterval: Long? = null, reuseAddress: Boolean? = null, reusePort: Boolean? = null, select: Int? = null, sendBufferSize: Int? = null, sentinels: Iterable<String>? = null, soLinger: Int? = null, ssl: Boolean? = null, tcpCork: Boolean? = null, tcpFastOpen: Boolean? = null, tcpKeepAlive: Boolean? = null, tcpNoDelay: Boolean? = null, tcpQuickAck: Boolean? = null, trafficClass: Int? = null, trustAll: Boolean? = null, trustStoreOptions: JksOptions? = null, useAlpn: Boolean? = null, usePooledBuffers: Boolean? = null): RedisOptions
io.vertx.redis.RedisClient
Module Contents
suspend fun RedisClient.appendAwait(key: String, value: String): Long
suspend fun RedisClient.authAwait(password: String): String
suspend fun RedisClient.bgrewriteaofAwait(): String
suspend fun RedisClient.bgsaveAwait(): String
suspend fun RedisClient.bitcountAwait(key: String): Long
suspend fun RedisClient.bitcountRangeAwait(key: String, start: Long, end: Long): Long
suspend fun RedisClient.bitfieldAwait(key: String, bitFieldOptions: BitFieldOptions): JsonArray
suspend fun RedisClient.bitfieldWithOverflowAwait(key: String, commands: BitFieldOptions, overflow: BitFieldOverflowOptions): JsonArray
suspend fun RedisClient.bitopAwait(operation: BitOperation, destkey: String, keys: List<String>): Long
suspend fun RedisClient.bitposAwait(key: String, bit: Int): Long
suspend fun RedisClient.bitposFromAwait(key: String, bit: Int, start: Int): Long
suspend fun RedisClient.bitposRangeAwait(key: String, bit: Int, start: Int, stop: Int): Long
suspend fun RedisClient.blpopAwait(key: String, seconds: Int): JsonArray
suspend fun RedisClient.blpopManyAwait(keys: List<String>, seconds: Int): JsonArray
suspend fun RedisClient.brpopAwait(key: String, seconds: Int): JsonArray
suspend fun RedisClient.brpopManyAwait(keys: List<String>, seconds: Int): JsonArray
suspend fun RedisClient.brpoplpushAwait(key: String, destkey: String, seconds: Int): String
suspend fun RedisClient.clientGetnameAwait(): String
suspend fun RedisClient.clientKillAwait(filter: KillFilter): Long
suspend fun RedisClient.clientListAwait(): String
suspend fun RedisClient.clientPauseAwait(millis: Long): String
suspend fun RedisClient.clientReplyAwait(options: ClientReplyOptions): String
suspend fun RedisClient.clientSetnameAwait(name: String): String
suspend fun RedisClient.closeAwait(): Unit
suspend fun RedisClient.clusterAddslotsAwait(slots: List<Long>): Unit
suspend fun RedisClient.clusterCountFailureReportsAwait(nodeId: String): Long
suspend fun RedisClient.clusterCountkeysinslotAwait(slot: Long): Long
suspend fun RedisClient.clusterDelslotsAwait(slot: Long): Unit
suspend fun RedisClient.clusterDelslotsManyAwait(slots: List<Long>): Unit
suspend fun RedisClient.clusterFailOverWithOptionsAwait(options: FailoverOptions): Unit
suspend fun RedisClient.clusterFailoverAwait(): Unit
suspend fun RedisClient.clusterForgetAwait(nodeId: String): Unit
suspend fun RedisClient.clusterGetkeysinslotAwait(slot: Long, count: Long): JsonArray
suspend fun RedisClient.clusterInfoAwait(): JsonArray
suspend fun RedisClient.clusterKeyslotAwait(key: String): Long
suspend fun RedisClient.clusterMeetAwait(ip: String, port: Long): Unit
suspend fun RedisClient.clusterNodesAwait(): JsonArray
suspend fun RedisClient.clusterReplicateAwait(nodeId: String): Unit
suspend fun RedisClient.clusterResetAwait(): Unit
suspend fun RedisClient.clusterResetWithOptionsAwait(options: ResetOptions): Unit
suspend fun RedisClient.clusterSaveconfigAwait(): Unit
suspend fun RedisClient.clusterSetConfigEpochAwait(epoch: Long): Unit
suspend fun RedisClient.clusterSetslotAwait(slot: Long, subcommand: SlotCmd): Unit
suspend fun RedisClient.clusterSetslotWithNodeAwait(slot: Long, subcommand: SlotCmd, nodeId: String): Unit
suspend fun RedisClient.clusterSlavesAwait(nodeId: String): JsonArray
suspend fun RedisClient.clusterSlotsAwait(): JsonArray
suspend fun RedisClient.commandAwait(): JsonArray
suspend fun RedisClient.commandCountAwait(): Long
suspend fun RedisClient.commandGetkeysAwait(): JsonArray
suspend fun RedisClient.commandInfoAwait(commands: List<String>): JsonArray
suspend fun RedisClient.configGetAwait(parameter: String): JsonArray
suspend fun RedisClient.configResetstatAwait(): String
suspend fun RedisClient.configRewriteAwait(): String
suspend fun RedisClient.configSetAwait(parameter: String, value: String): String
suspend fun RedisClient.dbsizeAwait(): Long
suspend fun RedisClient.debugObjectAwait(key: String): String
suspend fun RedisClient.debugSegfaultAwait(): String
suspend fun RedisClient.decrAwait(key: String): Long
suspend fun RedisClient.decrbyAwait(key: String, decrement: Long): Long
suspend fun RedisClient.delAwait(key: String): Long
suspend fun RedisClient.delManyAwait(keys: List<String>): Long
suspend fun RedisClient.dumpAwait(key: String): String
suspend fun RedisClient.echoAwait(message: String): String
suspend fun RedisClient.evalAwait(script: String, keys: List<String>, args: List<String>): JsonArray
suspend fun RedisClient.evalScriptAwait(script: Script, keys: List<String>, args: List<String>): JsonArray
suspend fun RedisClient.evalshaAwait(sha1: String, keys: List<String>, values: List<String>): JsonArray
suspend fun RedisClient.existsAwait(key: String): Long
suspend fun RedisClient.existsManyAwait(keys: List<String>): Long
suspend fun RedisClient.expireAwait(key: String, seconds: Long): Long
suspend fun RedisClient.expireatAwait(key: String, seconds: Long): Long
suspend fun RedisClient.flushallAwait(): String
suspend fun RedisClient.flushdbAwait(): String
suspend fun RedisClient.geoaddAwait(key: String, longitude: Double, latitude: Double, member: String): Long
suspend fun RedisClient.geoaddManyAwait(key: String, members: List<GeoMember>): Long
suspend fun RedisClient.geodistAwait(key: String, member1: String, member2: String): String
suspend fun RedisClient.geodistWithUnitAwait(key: String, member1: String, member2: String, unit: GeoUnit): String
suspend fun RedisClient.geohashAwait(key: String, member: String): JsonArray
suspend fun RedisClient.geohashManyAwait(key: String, members: List<String>): JsonArray
suspend fun RedisClient.geoposAwait(key: String, member: String): JsonArray
suspend fun RedisClient.geoposManyAwait(key: String, members: List<String>): JsonArray
suspend fun RedisClient.georadiusAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit): JsonArray
suspend fun RedisClient.georadiusWithOptionsAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): JsonArray
suspend fun RedisClient.georadiusbymemberAwait(key: String, member: String, radius: Double, unit: GeoUnit): JsonArray
suspend fun RedisClient.georadiusbymemberWithOptionsAwait(key: String, member: String, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): JsonArray
suspend fun RedisClient.getAwait(key: String): String?
suspend fun RedisClient.getBinaryAwait(key: String): Buffer?
suspend fun RedisClient.getbitAwait(key: String, offset: Long): Long
suspend fun RedisClient.getrangeAwait(key: String, start: Long, end: Long): String
suspend fun RedisClient.getsetAwait(key: String, value: String): String?
suspend fun RedisClient.hdelAwait(key: String, field: String): Long
suspend fun RedisClient.hdelManyAwait(key: String, fields: List<String>): Long
suspend fun RedisClient.hexistsAwait(key: String, field: String): Long
suspend fun RedisClient.hgetAwait(key: String, field: String): String?
suspend fun RedisClient.hgetallAwait(key: String): JsonObject
suspend fun RedisClient.hincrbyAwait(key: String, field: String, increment: Long): Long
suspend fun RedisClient.hincrbyfloatAwait(key: String, field: String, increment: Double): String
suspend fun RedisClient.hkeysAwait(key: String): JsonArray
suspend fun RedisClient.hlenAwait(key: String): Long
suspend fun RedisClient.hmgetAwait(key: String, fields: List<String>): JsonArray
suspend fun RedisClient.hmsetAwait(key: String, values: JsonObject): String
suspend fun RedisClient.hscanAwait(key: String, cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.hsetAwait(key: String, field: String, value: String): Long
suspend fun RedisClient.hsetnxAwait(key: String, field: String, value: String): Long
suspend fun RedisClient.hstrlenAwait(key: String, field: String): Long
suspend fun RedisClient.hvalsAwait(key: String): JsonArray
suspend fun RedisClient.incrAwait(key: String): Long
suspend fun RedisClient.incrbyAwait(key: String, increment: Long): Long
suspend fun RedisClient.incrbyfloatAwait(key: String, increment: Double): String
suspend fun RedisClient.infoAwait(): JsonObject
suspend fun RedisClient.infoSectionAwait(section: String): JsonObject
suspend fun RedisClient.keysAwait(pattern: String): JsonArray
suspend fun RedisClient.lastsaveAwait(): Long
suspend fun RedisClient.lindexAwait(key: String, index: Int): String
suspend fun RedisClient.linsertAwait(key: String, option: InsertOptions, pivot: String, value: String): Long
suspend fun RedisClient.llenAwait(key: String): Long
suspend fun RedisClient.lpopAwait(key: String): String?
suspend fun RedisClient.lpushAwait(key: String, value: String): Long
suspend fun RedisClient.lpushManyAwait(key: String, values: List<String>): Long
suspend fun RedisClient.lpushxAwait(key: String, value: String): Long
suspend fun RedisClient.lrangeAwait(key: String, from: Long, to: Long): JsonArray
suspend fun RedisClient.lremAwait(key: String, count: Long, value: String): Long
suspend fun RedisClient.lsetAwait(key: String, index: Long, value: String): String
suspend fun RedisClient.ltrimAwait(key: String, from: Long, to: Long): String
suspend fun RedisClient.mgetAwait(key: String): JsonArray
suspend fun RedisClient.mgetManyAwait(keys: List<String>): JsonArray
suspend fun RedisClient.migrateAwait(host: String, port: Int, key: String, destdb: Int, timeout: Long, options: MigrateOptions): String
suspend fun RedisClient.monitorAwait(): Unit
suspend fun RedisClient.moveAwait(key: String, destdb: Int): Long
suspend fun RedisClient.msetAwait(keyvals: JsonObject): String
suspend fun RedisClient.msetnxAwait(keyvals: JsonObject): Long
suspend fun RedisClient.objectAwait(key: String, cmd: ObjectCmd): Unit
suspend fun RedisClient.persistAwait(key: String): Long
suspend fun RedisClient.pexpireAwait(key: String, millis: Long): Long
suspend fun RedisClient.pexpireatAwait(key: String, millis: Long): Long
suspend fun RedisClient.pfaddAwait(key: String, element: String): Long
suspend fun RedisClient.pfaddManyAwait(key: String, elements: List<String>): Long
suspend fun RedisClient.pfcountAwait(key: String): Long
suspend fun RedisClient.pfcountManyAwait(keys: List<String>): Long
suspend fun RedisClient.pfmergeAwait(destkey: String, keys: List<String>): String
suspend fun RedisClient.pingAwait(): String
suspend fun RedisClient.psetexAwait(key: String, millis: Long, value: String): Unit
suspend fun RedisClient.psubscribeAwait(pattern: String): JsonArray
suspend fun RedisClient.psubscribeManyAwait(patterns: List<String>): JsonArray
suspend fun RedisClient.pttlAwait(key: String): Long
suspend fun RedisClient.publishAwait(channel: String, message: String): Long
suspend fun RedisClient.pubsubChannelsAwait(pattern: String): JsonArray
suspend fun RedisClient.pubsubNumpatAwait(): Long
suspend fun RedisClient.pubsubNumsubAwait(channels: List<String>): JsonArray
suspend fun RedisClient.punsubscribeAwait(patterns: List<String>): Unit
suspend fun RedisClient.randomkeyAwait(): String
suspend fun RedisClient.renameAwait(key: String, newkey: String): String
suspend fun RedisClient.renamenxAwait(key: String, newkey: String): Long
suspend fun RedisClient.restoreAwait(key: String, millis: Long, serialized: String): String
suspend fun RedisClient.roleAwait(): JsonArray
suspend fun RedisClient.rpopAwait(key: String): String
suspend fun RedisClient.rpoplpushAwait(key: String, destkey: String): String
suspend fun RedisClient.rpushAwait(key: String, value: String): Long
suspend fun RedisClient.rpushManyAwait(key: String, values: List<String>): Long
suspend fun RedisClient.rpushxAwait(key: String, value: String): Long
suspend fun RedisClient.saddAwait(key: String, member: String): Long
suspend fun RedisClient.saddManyAwait(key: String, members: List<String>): Long
suspend fun RedisClient.saveAwait(): String
suspend fun RedisClient.scanAwait(cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.scardAwait(key: String): Long
suspend fun RedisClient.scriptDebugAwait(scriptDebugOptions: ScriptDebugOptions): String
suspend fun RedisClient.scriptExistsAwait(script: String): JsonArray
suspend fun RedisClient.scriptExistsManyAwait(scripts: List<String>): JsonArray
suspend fun RedisClient.scriptFlushAwait(): String
suspend fun RedisClient.scriptKillAwait(): String
suspend fun RedisClient.scriptLoadAwait(script: String): String
suspend fun RedisClient.sdiffAwait(key: String, cmpkeys: List<String>): JsonArray
suspend fun RedisClient.sdiffstoreAwait(destkey: String, key: String, cmpkeys: List<String>): Long
suspend fun RedisClient.selectAwait(dbindex: Int): String
suspend fun RedisClient.setAwait(key: String, value: String): Unit
suspend fun RedisClient.setBinaryAwait(key: String, value: Buffer): Unit
suspend fun RedisClient.setBinaryWithOptionsAwait(key: String, value: Buffer, options: SetOptions): Unit
suspend fun RedisClient.setWithOptionsAwait(key: String, value: String, options: SetOptions): String
suspend fun RedisClient.setbitAwait(key: String, offset: Long, bit: Int): Long
suspend fun RedisClient.setexAwait(key: String, seconds: Long, value: String): String
suspend fun RedisClient.setnxAwait(key: String, value: String): Long
suspend fun RedisClient.setrangeAwait(key: String, offset: Int, value: String): Long
suspend fun RedisClient.sinterAwait(keys: List<String>): JsonArray
suspend fun RedisClient.sinterstoreAwait(destkey: String, keys: List<String>): Long
suspend fun RedisClient.sismemberAwait(key: String, member: String): Long
suspend fun RedisClient.slaveofAwait(host: String, port: Int): String
suspend fun RedisClient.slaveofNooneAwait(): String
suspend fun RedisClient.slowlogGetAwait(limit: Int): JsonArray
suspend fun RedisClient.slowlogLenAwait(): Long
suspend fun RedisClient.slowlogResetAwait(): Unit
suspend fun RedisClient.smembersAwait(key: String): JsonArray
suspend fun RedisClient.smoveAwait(key: String, destkey: String, member: String): Long
suspend fun RedisClient.sortAwait(key: String, options: SortOptions): JsonArray
suspend fun RedisClient.spopAwait(key: String): String?
suspend fun RedisClient.spopManyAwait(key: String, count: Int): JsonArray
suspend fun RedisClient.srandmemberAwait(key: String): String
suspend fun RedisClient.srandmemberCountAwait(key: String, count: Int): JsonArray
suspend fun RedisClient.sremAwait(key: String, member: String): Long
suspend fun RedisClient.sremManyAwait(key: String, members: List<String>): Long
suspend fun RedisClient.sscanAwait(key: String, cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.strlenAwait(key: String): Long
suspend fun RedisClient.subscribeAwait(channel: String): JsonArray
suspend fun RedisClient.subscribeManyAwait(channels: List<String>): JsonArray
suspend fun RedisClient.sunionAwait(keys: List<String>): JsonArray
suspend fun RedisClient.sunionstoreAwait(destkey: String, keys: List<String>): Long
suspend fun RedisClient.swapdbAwait(index1: Int, index2: Int): String
suspend fun RedisClient.syncAwait(): Unit
suspend fun RedisClient.timeAwait(): JsonArray
suspend fun RedisClient.touchAwait(key: String): Long
suspend fun RedisClient.touchManyAwait(keys: List<String>): Long
suspend fun RedisClient.ttlAwait(key: String): Long
suspend fun RedisClient.typeAwait(key: String): String
suspend fun RedisClient.unlinkAwait(key: String): Long
suspend fun RedisClient.unlinkManyAwait(keys: List<String>): Long
suspend fun RedisClient.unsubscribeAwait(channels: List<String>): Unit
suspend fun RedisClient.waitAwait(numSlaves: Long, timeout: Long): String
suspend fun RedisClient.zaddAwait(key: String, score: Double, member: String): Long
suspend fun RedisClient.zaddManyAwait(key: String, members: Map<String, Double>): Long
suspend fun RedisClient.zcardAwait(key: String): Long
suspend fun RedisClient.zcountAwait(key: String, min: Double, max: Double): Long
suspend fun RedisClient.zincrbyAwait(key: String, increment: Double, member: String): String
suspend fun RedisClient.zinterstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): Long
suspend fun RedisClient.zinterstoreWeighedAwait(destkey: String, sets: Map<String, Double>, options: AggregateOptions): Long
suspend fun RedisClient.zlexcountAwait(key: String, min: String, max: String): Long
suspend fun RedisClient.zrangeAwait(key: String, start: Long, stop: Long): JsonArray
suspend fun RedisClient.zrangeWithOptionsAwait(key: String, start: Long, stop: Long, options: RangeOptions): JsonArray
suspend fun RedisClient.zrangebylexAwait(key: String, min: String, max: String, options: LimitOptions): JsonArray
suspend fun RedisClient.zrangebyscoreAwait(key: String, min: String, max: String, options: RangeLimitOptions): JsonArray
suspend fun RedisClient.zrankAwait(key: String, member: String): Long
suspend fun RedisClient.zremAwait(key: String, member: String): Long
suspend fun RedisClient.zremManyAwait(key: String, members: List<String>): Long
suspend fun RedisClient.zremrangebylexAwait(key: String, min: String, max: String): Long
suspend fun RedisClient.zremrangebyrankAwait(key: String, start: Long, stop: Long): Long
suspend fun RedisClient.zremrangebyscoreAwait(key: String, min: String, max: String): Long
suspend fun RedisClient.zrevrangeAwait(key: String, start: Long, stop: Long, options: RangeOptions): JsonArray
suspend fun RedisClient.zrevrangebylexAwait(key: String, max: String, min: String, options: LimitOptions): JsonArray
suspend fun RedisClient.zrevrangebyscoreAwait(key: String, max: String, min: String, options: RangeLimitOptions): JsonArray
suspend fun RedisClient.zrevrankAwait(key: String, member: String): Long
suspend fun RedisClient.zscanAwait(key: String, cursor: String, options: ScanOptions): JsonArray
suspend fun RedisClient.zscoreAwait(key: String, member: String): String
suspend fun RedisClient.zunionstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): Long
suspend fun RedisClient.zunionstoreWeighedAwait(key: String, sets: Map<String, Double>, options: AggregateOptions): Long
io.vertx.redis.RedisTransaction
Module Contents
suspend fun RedisTransaction.appendAwait(key: String, value: String): String
suspend fun RedisTransaction.authAwait(password: String): String
suspend fun RedisTransaction.bgrewriteaofAwait(): String
suspend fun RedisTransaction.bgsaveAwait(): String
suspend fun RedisTransaction.bitcountAwait(key: String): String
suspend fun RedisTransaction.bitcountRangeAwait(key: String, start: Long, end: Long): String
suspend fun RedisTransaction.bitopAwait(operation: BitOperation, destkey: String, keys: List<String>): String
suspend fun RedisTransaction.bitposAwait(key: String, bit: Int): String
suspend fun RedisTransaction.bitposFromAwait(key: String, bit: Int, start: Int): String
suspend fun RedisTransaction.bitposRangeAwait(key: String, bit: Int, start: Int, stop: Int): String
suspend fun RedisTransaction.blpopAwait(key: String, seconds: Int): String
suspend fun RedisTransaction.blpopManyAwait(keys: List<String>, seconds: Int): String
suspend fun RedisTransaction.brpopAwait(key: String, seconds: Int): String
suspend fun RedisTransaction.brpopManyAwait(keys: List<String>, seconds: Int): String
suspend fun RedisTransaction.brpoplpushAwait(key: String, destkey: String, seconds: Int): String
suspend fun RedisTransaction.clientGetnameAwait(): String
suspend fun RedisTransaction.clientKillAwait(filter: KillFilter): String
suspend fun RedisTransaction.clientListAwait(): String
suspend fun RedisTransaction.clientPauseAwait(millis: Long): String
suspend fun RedisTransaction.clientSetnameAwait(name: String): String
suspend fun RedisTransaction.closeAwait(): Unit
suspend fun RedisTransaction.clusterAddslotsAwait(slots: List<String>): String
suspend fun RedisTransaction.clusterCountFailureReportsAwait(nodeId: String): String
suspend fun RedisTransaction.clusterCountkeysinslotAwait(slot: Long): String
suspend fun RedisTransaction.clusterDelslotsAwait(slot: Long): String
suspend fun RedisTransaction.clusterDelslotsManyAwait(slots: List<String>): String
suspend fun RedisTransaction.clusterFailOverWithOptionsAwait(options: FailoverOptions): String
suspend fun RedisTransaction.clusterFailoverAwait(): String
suspend fun RedisTransaction.clusterForgetAwait(nodeId: String): String
suspend fun RedisTransaction.clusterGetkeysinslotAwait(slot: Long, count: Long): String
suspend fun RedisTransaction.clusterInfoAwait(): String
suspend fun RedisTransaction.clusterKeyslotAwait(key: String): String
suspend fun RedisTransaction.clusterMeetAwait(ip: String, port: Long): String
suspend fun RedisTransaction.clusterNodesAwait(): String
suspend fun RedisTransaction.clusterReplicateAwait(nodeId: String): String
suspend fun RedisTransaction.clusterResetAwait(): String
suspend fun RedisTransaction.clusterResetWithOptionsAwait(options: ResetOptions): String
suspend fun RedisTransaction.clusterSaveconfigAwait(): String
suspend fun RedisTransaction.clusterSetConfigEpochAwait(epoch: Long): String
suspend fun RedisTransaction.clusterSetslotAwait(slot: Long, subcommand: SlotCmd): String
suspend fun RedisTransaction.clusterSetslotWithNodeAwait(slot: Long, subcommand: SlotCmd, nodeId: String): String
suspend fun RedisTransaction.clusterSlavesAwait(nodeId: String): String
suspend fun RedisTransaction.clusterSlotsAwait(): String
suspend fun RedisTransaction.commandAwait(): String
suspend fun RedisTransaction.commandCountAwait(): String
suspend fun RedisTransaction.commandGetkeysAwait(): String
suspend fun RedisTransaction.commandInfoAwait(commands: List<String>): String
suspend fun RedisTransaction.configGetAwait(parameter: String): String
suspend fun RedisTransaction.configResetstatAwait(): String
suspend fun RedisTransaction.configRewriteAwait(): String
suspend fun RedisTransaction.configSetAwait(parameter: String, value: String): String
suspend fun RedisTransaction.dbsizeAwait(): String
suspend fun RedisTransaction.debugObjectAwait(key: String): String
suspend fun RedisTransaction.debugSegfaultAwait(): String
suspend fun RedisTransaction.decrAwait(key: String): String
suspend fun RedisTransaction.decrbyAwait(key: String, decrement: Long): String
suspend fun RedisTransaction.delAwait(key: String): String
suspend fun RedisTransaction.delManyAwait(keys: List<String>): String
suspend fun RedisTransaction.discardAwait(): String
suspend fun RedisTransaction.dumpAwait(key: String): String
suspend fun RedisTransaction.echoAwait(message: String): String
suspend fun RedisTransaction.evalAwait(script: String, keys: List<String>, args: List<String>): String
suspend fun RedisTransaction.evalshaAwait(sha1: String, keys: List<String>, values: List<String>): String
suspend fun RedisTransaction.execAwait(): JsonArray
suspend fun RedisTransaction.existsAwait(key: String): String
suspend fun RedisTransaction.existsManyAwait(keys: List<String>): String
suspend fun RedisTransaction.expireAwait(key: String, seconds: Int): String
suspend fun RedisTransaction.expireatAwait(key: String, seconds: Long): String
suspend fun RedisTransaction.flushallAwait(): String
suspend fun RedisTransaction.flushdbAwait(): String
suspend fun RedisTransaction.geoaddAwait(key: String, longitude: Double, latitude: Double, member: String): String
suspend fun RedisTransaction.geoaddManyAwait(key: String, members: List<GeoMember>): String
suspend fun RedisTransaction.geodistAwait(key: String, member1: String, member2: String): String
suspend fun RedisTransaction.geodistWithUnitAwait(key: String, member1: String, member2: String, unit: GeoUnit): String
suspend fun RedisTransaction.geohashAwait(key: String, member: String): String
suspend fun RedisTransaction.geohashManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.geoposAwait(key: String, member: String): String
suspend fun RedisTransaction.geoposManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.georadiusAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit): String
suspend fun RedisTransaction.georadiusWithOptionsAwait(key: String, longitude: Double, latitude: Double, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): String
suspend fun RedisTransaction.georadiusbymemberAwait(key: String, member: String, radius: Double, unit: GeoUnit): String
suspend fun RedisTransaction.georadiusbymemberWithOptionsAwait(key: String, member: String, radius: Double, unit: GeoUnit, options: GeoRadiusOptions): String
suspend fun RedisTransaction.getAwait(key: String): String
suspend fun RedisTransaction.getBinaryAwait(key: String): Buffer
suspend fun RedisTransaction.getbitAwait(key: String, offset: Long): String
suspend fun RedisTransaction.getrangeAwait(key: String, start: Long, end: Long): String
suspend fun RedisTransaction.getsetAwait(key: String, value: String): String
suspend fun RedisTransaction.hdelAwait(key: String, field: String): String
suspend fun RedisTransaction.hdelManyAwait(key: String, fields: List<String>): String
suspend fun RedisTransaction.hexistsAwait(key: String, field: String): String
suspend fun RedisTransaction.hgetAwait(key: String, field: String): String
suspend fun RedisTransaction.hgetallAwait(key: String): String
suspend fun RedisTransaction.hincrbyAwait(key: String, field: String, increment: Long): String
suspend fun RedisTransaction.hincrbyfloatAwait(key: String, field: String, increment: Double): String
suspend fun RedisTransaction.hkeysAwait(key: String): String
suspend fun RedisTransaction.hlenAwait(key: String): String
suspend fun RedisTransaction.hmgetAwait(key: String, fields: List<String>): String
suspend fun RedisTransaction.hmsetAwait(key: String, values: JsonObject): String
suspend fun RedisTransaction.hscanAwait(key: String, cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.hsetAwait(key: String, field: String, value: String): String
suspend fun RedisTransaction.hsetnxAwait(key: String, field: String, value: String): String
suspend fun RedisTransaction.hvalsAwait(key: String): String
suspend fun RedisTransaction.incrAwait(key: String): String
suspend fun RedisTransaction.incrbyAwait(key: String, increment: Long): String
suspend fun RedisTransaction.incrbyfloatAwait(key: String, increment: Double): String
suspend fun RedisTransaction.infoAwait(): String
suspend fun RedisTransaction.infoSectionAwait(section: String): String
suspend fun RedisTransaction.keysAwait(pattern: String): String
suspend fun RedisTransaction.lastsaveAwait(): String
suspend fun RedisTransaction.lindexAwait(key: String, index: Int): String
suspend fun RedisTransaction.linsertAwait(key: String, option: InsertOptions, pivot: String, value: String): String
suspend fun RedisTransaction.llenAwait(key: String): String
suspend fun RedisTransaction.lpopAwait(key: String): String
suspend fun RedisTransaction.lpushAwait(key: String, value: String): String
suspend fun RedisTransaction.lpushManyAwait(key: String, values: List<String>): String
suspend fun RedisTransaction.lpushxAwait(key: String, value: String): String
suspend fun RedisTransaction.lrangeAwait(key: String, from: Long, to: Long): String
suspend fun RedisTransaction.lremAwait(key: String, count: Long, value: String): String
suspend fun RedisTransaction.lsetAwait(key: String, index: Long, value: String): String
suspend fun RedisTransaction.ltrimAwait(key: String, from: Long, to: Long): String
suspend fun RedisTransaction.mgetAwait(key: String): String
suspend fun RedisTransaction.mgetManyAwait(keys: List<String>): String
suspend fun RedisTransaction.migrateAwait(host: String, port: Int, key: String, destdb: Int, timeout: Long, options: MigrateOptions): String
suspend fun RedisTransaction.monitorAwait(): String
suspend fun RedisTransaction.moveAwait(key: String, destdb: Int): String
suspend fun RedisTransaction.msetAwait(keyvals: JsonObject): String
suspend fun RedisTransaction.msetnxAwait(keyvals: JsonObject): String
suspend fun RedisTransaction.multiAwait(): String
suspend fun RedisTransaction.objectAwait(key: String, cmd: ObjectCmd): String
suspend fun RedisTransaction.persistAwait(key: String): String
suspend fun RedisTransaction.pexpireAwait(key: String, millis: Long): String
suspend fun RedisTransaction.pexpireatAwait(key: String, millis: Long): String
suspend fun RedisTransaction.pfaddAwait(key: String, element: String): String
suspend fun RedisTransaction.pfaddManyAwait(key: String, elements: List<String>): String
suspend fun RedisTransaction.pfcountAwait(key: String): String
suspend fun RedisTransaction.pfcountManyAwait(keys: List<String>): String
suspend fun RedisTransaction.pfmergeAwait(destkey: String, keys: List<String>): String
suspend fun RedisTransaction.pingAwait(): String
suspend fun RedisTransaction.psetexAwait(key: String, millis: Long, value: String): String
suspend fun RedisTransaction.psubscribeAwait(pattern: String): String
suspend fun RedisTransaction.psubscribeManyAwait(patterns: List<String>): String
suspend fun RedisTransaction.pttlAwait(key: String): String
suspend fun RedisTransaction.publishAwait(channel: String, message: String): String
suspend fun RedisTransaction.pubsubChannelsAwait(pattern: String): String
suspend fun RedisTransaction.pubsubNumpatAwait(): String
suspend fun RedisTransaction.pubsubNumsubAwait(channels: List<String>): String
suspend fun RedisTransaction.punsubscribeAwait(patterns: List<String>): String
suspend fun RedisTransaction.randomkeyAwait(): String
suspend fun RedisTransaction.renameAwait(key: String, newkey: String): String
suspend fun RedisTransaction.renamenxAwait(key: String, newkey: String): String
suspend fun RedisTransaction.restoreAwait(key: String, millis: Long, serialized: String): String
suspend fun RedisTransaction.roleAwait(): String
suspend fun RedisTransaction.rpopAwait(key: String): String
suspend fun RedisTransaction.rpoplpushAwait(key: String, destkey: String): String
suspend fun RedisTransaction.rpushAwait(key: String, value: String): String
suspend fun RedisTransaction.rpushManyAwait(key: String, values: List<String>): String
suspend fun RedisTransaction.rpushxAwait(key: String, value: String): String
suspend fun RedisTransaction.saddAwait(key: String, member: String): String
suspend fun RedisTransaction.saddManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.saveAwait(): String
suspend fun RedisTransaction.scanAwait(cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.scardAwait(key: String): String
suspend fun RedisTransaction.scriptExistsAwait(script: String): String
suspend fun RedisTransaction.scriptExistsManyAwait(scripts: List<String>): String
suspend fun RedisTransaction.scriptFlushAwait(): String
suspend fun RedisTransaction.scriptKillAwait(): String
suspend fun RedisTransaction.scriptLoadAwait(script: String): String
suspend fun RedisTransaction.sdiffAwait(key: String, cmpkeys: List<String>): String
suspend fun RedisTransaction.sdiffstoreAwait(destkey: String, key: String, cmpkeys: List<String>): String
suspend fun RedisTransaction.selectAwait(dbindex: Int): String
suspend fun RedisTransaction.setAwait(key: String, value: String): String
suspend fun RedisTransaction.setBinaryAwait(key: String, value: Buffer): String
suspend fun RedisTransaction.setBinaryWithOptionsAwait(key: String, value: Buffer, options: SetOptions): String
suspend fun RedisTransaction.setWithOptionsAwait(key: String, value: String, options: SetOptions): String
suspend fun RedisTransaction.setbitAwait(key: String, offset: Long, bit: Int): String
suspend fun RedisTransaction.setexAwait(key: String, seconds: Long, value: String): String
suspend fun RedisTransaction.setnxAwait(key: String, value: String): String
suspend fun RedisTransaction.setrangeAwait(key: String, offset: Int, value: String): String
suspend fun RedisTransaction.sinterAwait(keys: List<String>): String
suspend fun RedisTransaction.sinterstoreAwait(destkey: String, keys: List<String>): String
suspend fun RedisTransaction.sismemberAwait(key: String, member: String): String
suspend fun RedisTransaction.slaveofAwait(host: String, port: Int): String
suspend fun RedisTransaction.slaveofNooneAwait(): String
suspend fun RedisTransaction.slowlogGetAwait(limit: Int): String
suspend fun RedisTransaction.slowlogLenAwait(): String
suspend fun RedisTransaction.slowlogResetAwait(): String
suspend fun RedisTransaction.smembersAwait(key: String): JsonArray
suspend fun RedisTransaction.smoveAwait(key: String, destkey: String, member: String): String
suspend fun RedisTransaction.sortAwait(key: String, options: SortOptions): String
suspend fun RedisTransaction.spopAwait(key: String): String
suspend fun RedisTransaction.spopManyAwait(key: String, count: Int): String
suspend fun RedisTransaction.srandmemberAwait(key: String): String
suspend fun RedisTransaction.srandmemberCountAwait(key: String, count: Int): String
suspend fun RedisTransaction.sremAwait(key: String, member: String): String
suspend fun RedisTransaction.sremManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.sscanAwait(key: String, cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.strlenAwait(key: String): String
suspend fun RedisTransaction.subscribeAwait(channel: String): String
suspend fun RedisTransaction.subscribeManyAwait(channels: List<String>): String
suspend fun RedisTransaction.sunionAwait(keys: List<String>): String
suspend fun RedisTransaction.sunionstoreAwait(destkey: String, keys: List<String>): String
suspend fun RedisTransaction.swapdbAwait(index1: Int, index2: Int): String
suspend fun RedisTransaction.syncAwait(): String
suspend fun RedisTransaction.timeAwait(): String
suspend fun RedisTransaction.ttlAwait(key: String): String
suspend fun RedisTransaction.typeAwait(key: String): String
suspend fun RedisTransaction.unlinkAwait(key: String): String
suspend fun RedisTransaction.unlinkManyAwait(keys: List<String>): String
suspend fun RedisTransaction.unsubscribeAwait(channels: List<String>): String
suspend fun RedisTransaction.unwatchAwait(): String
suspend fun RedisTransaction.waitAwait(numSlaves: Long, timeout: Long): String
suspend fun RedisTransaction.watchAwait(key: String): String
suspend fun RedisTransaction.watchManyAwait(keys: List<String>): String
suspend fun RedisTransaction.zaddAwait(key: String, score: Double, member: String): String
suspend fun RedisTransaction.zaddManyAwait(key: String, members: Map<String, Double>): String
suspend fun RedisTransaction.zcardAwait(key: String): String
suspend fun RedisTransaction.zcountAwait(key: String, min: Double, max: Double): String
suspend fun RedisTransaction.zincrbyAwait(key: String, increment: Double, member: String): String
suspend fun RedisTransaction.zinterstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): String
suspend fun RedisTransaction.zinterstoreWeighedAwait(destkey: String, sets: Map<String, Double>, options: AggregateOptions): String
suspend fun RedisTransaction.zlexcountAwait(key: String, min: String, max: String): String
suspend fun RedisTransaction.zrangeAwait(key: String, start: Long, stop: Long): String
suspend fun RedisTransaction.zrangeWithOptionsAwait(key: String, start: Long, stop: Long, options: RangeOptions): String
suspend fun RedisTransaction.zrangebylexAwait(key: String, min: String, max: String, options: LimitOptions): String
suspend fun RedisTransaction.zrangebyscoreAwait(key: String, min: String, max: String, options: RangeLimitOptions): String
suspend fun RedisTransaction.zrankAwait(key: String, member: String): String
suspend fun RedisTransaction.zremAwait(key: String, member: String): String
suspend fun RedisTransaction.zremManyAwait(key: String, members: List<String>): String
suspend fun RedisTransaction.zremrangebylexAwait(key: String, min: String, max: String): String
suspend fun RedisTransaction.zremrangebyrankAwait(key: String, start: Long, stop: Long): String
suspend fun RedisTransaction.zremrangebyscoreAwait(key: String, min: String, max: String): String
suspend fun RedisTransaction.zrevrangeAwait(key: String, start: Long, stop: Long, options: RangeOptions): String
suspend fun RedisTransaction.zrevrangebylexAwait(key: String, max: String, min: String, options: LimitOptions): String
suspend fun RedisTransaction.zrevrangebyscoreAwait(key: String, max: String, min: String, options: RangeLimitOptions): String
suspend fun RedisTransaction.zrevrankAwait(key: String, member: String): String
suspend fun RedisTransaction.zscanAwait(key: String, cursor: String, options: ScanOptions): String
suspend fun RedisTransaction.zscoreAwait(key: String, member: String): String
suspend fun RedisTransaction.zunionstoreAwait(destkey: String, sets: List<String>, options: AggregateOptions): String
suspend fun RedisTransaction.zunionstoreWeighedAwait(key: String, sets: Map<String, Double>, options: AggregateOptions): String
package io.vertx.kotlin.redis.op
Module Contents
fun BitFieldGetCommand(offset: Long? = null, type: String? = null): BitFieldGetCommand
fun BitFieldIncrbyCommand(increment: Long? = null, offset: Long? = null, type: String? = null): BitFieldIncrbyCommand
fun BitFieldOptions(get: BitFieldGetCommand? = null, incrby: BitFieldIncrbyCommand? = null, set: BitFieldSetCommand? = null): BitFieldOptions
fun BitFieldSetCommand(offset: Long? = null, type: String? = null, value: Long? = null): BitFieldSetCommand
fun GeoMember(latitude: Double? = null, longitude: Double? = null, member: String? = null): GeoMember
fun GeoRadiusOptions(count: Long? = null, withCoord: Boolean? = null, withDist: Boolean? = null, withHash: Boolean? = null): GeoRadiusOptions
fun KillFilter(addr: String? = null, id: String? = null, skipme: Boolean? = null, type: Type? = null): KillFilter
fun LimitOptions(count: Long? = null, offset: Long? = null): LimitOptions
fun MigrateOptions(copy: Boolean? = null, replace: Boolean? = null): MigrateOptions
fun RangeLimitOptions(count: Long? = null, offset: Long? = null, withscores: Boolean? = null): RangeLimitOptions
fun ScanOptions(count: Int? = null, match: String? = null): ScanOptions
fun SetOptions(ex: Long? = null, nx: Boolean? = null, px: Long? = null, xx: Boolean? = null): SetOptions
fun SortOptions(alpha: Boolean? = null, by: String? = null, descending: Boolean? = null, gets: Iterable<String>? = null, store: String? = null): SortOptions
package io.vertx.kotlin.redis.sentinel
package io.vertx.kotlin.servicediscovery
package io.vertx.kotlin.servicediscovery.spi
package io.vertx.kotlin.servicediscovery.types
Module Contents
object HttpEndpoint
Module Contents
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: JsonObject): HttpClient
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: JsonObject, conf: JsonObject): HttpClient
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>): HttpClient
suspend fun getClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>, conf: JsonObject): HttpClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: JsonObject): WebClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: JsonObject, conf: JsonObject): WebClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>): WebClient
suspend fun getWebClientAwait(discovery: ServiceDiscovery, filter: Function<Record, Boolean>, conf: JsonObject): WebClient
fun HttpLocation(endpoint: String? = null, host: String? = null, port: Int? = null, root: String? = null, ssl: Boolean? = null): HttpLocation
object JDBCDataSource
object MessageSource
object MongoDataSource
object RedisDataSource