A B C D E F G H I J L M N O P Q R S T U V W 
All Classes All Packages

A

acceptsOptions(SqlConnectOptions) - Method in interface io.vertx.sqlclient.spi.Driver
 
addArrayOfBigDecimal(BigDecimal[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of BigDecimal value at the end of the tuple.
addArrayOfBoolean(Boolean[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Boolean value at the end of the tuple.
addArrayOfBuffer(Buffer[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Buffer value at the end of the tuple.
addArrayOfDouble(Double[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Double value at the end of the tuple.
addArrayOfFloat(Float[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Float value at the end of the tuple.
addArrayOfInteger(Integer[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Integer value at the end of the tuple.
addArrayOfJsonArray(JsonArray[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of JsonArray value at the end of the tuple.
addArrayOfJsonObject(JsonObject[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of JsonObject value at the end of the tuple.
addArrayOfLocalDate(LocalDate[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of LocalDate value at the end of the tuple.
addArrayOfLocalDateTime(LocalDateTime[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of LocalDateTime value at the end of the tuple.
addArrayOfLocalTime(LocalTime[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of LocalTime value at the end of the tuple.
addArrayOfLong(Long[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Long value at the end of the tuple.
addArrayOfOffsetDateTime(OffsetDateTime[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of OffsetDateTime value at the end of the tuple.
addArrayOfOffsetTime(OffsetTime[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of OffsetTime value at the end of the tuple.
addArrayOfShort(Short[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Short value at the end of the tuple.
addArrayOfString(String[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of String value at the end of the tuple.
addArrayOfTemporal(Temporal[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of Temporal value at the end of the tuple.
addArrayOfUUID(UUID[]) - Method in interface io.vertx.sqlclient.Tuple
Add an array of UUID value at the end of the tuple.
addBigDecimal(BigDecimal) - Method in interface io.vertx.sqlclient.Tuple
Add a BigDecimal value at the end of the tuple.
addBoolean(Boolean) - Method in interface io.vertx.sqlclient.Tuple
Add a boolean value at the end of the tuple.
addBuffer(Buffer) - Method in interface io.vertx.sqlclient.Tuple
Add a buffer value at the end of the tuple.
addDouble(Double) - Method in interface io.vertx.sqlclient.Tuple
Add a double value at the end of the tuple.
addFloat(Float) - Method in interface io.vertx.sqlclient.Tuple
Add a float value at the end of the tuple.
addInteger(Integer) - Method in interface io.vertx.sqlclient.Tuple
Add an integer value at the end of the tuple.
addJsonArray(JsonArray) - Method in interface io.vertx.sqlclient.Tuple
Add a JsonArray value at the end of the tuple.
addJsonObject(JsonObject) - Method in interface io.vertx.sqlclient.Tuple
Add a JsonObject value at the end of the tuple.
addLocalDate(LocalDate) - Method in interface io.vertx.sqlclient.Tuple
Add a LocalDate value at the end of the tuple.
addLocalDateTime(LocalDateTime) - Method in interface io.vertx.sqlclient.Tuple
Add a LocalDateTime value at the end of the tuple.
addLocalTime(LocalTime) - Method in interface io.vertx.sqlclient.Tuple
Add a LocalTime value at the end of the tuple.
addLong(Long) - Method in interface io.vertx.sqlclient.Tuple
Add a long value at the end of the tuple.
addOffsetDateTime(OffsetDateTime) - Method in interface io.vertx.sqlclient.Tuple
Add a OffsetDateTime value at the end of the tuple.
addOffsetTime(OffsetTime) - Method in interface io.vertx.sqlclient.Tuple
Add a OffsetTime value at the end of the tuple.
addProperty(String, String) - Method in class io.vertx.sqlclient.SqlConnectOptions
Add a property for this client, which will be sent to server at the connection start.
addShort(Short) - Method in interface io.vertx.sqlclient.Tuple
Add a short value at the end of the tuple.
addString(String) - Method in interface io.vertx.sqlclient.Tuple
Add a string value at the end of the tuple.
addTemporal(Temporal) - Method in interface io.vertx.sqlclient.Tuple
Add a Temporal value at the end of the tuple.
addUUID(UUID) - Method in interface io.vertx.sqlclient.Tuple
Add a UUID value at the end of the tuple.
addValue(Object) - Method in interface io.vertx.sqlclient.Tuple
Add an object value at the end of the tuple.
appendQueryPlaceholder(StringBuilder, int, int) - Method in interface io.vertx.sqlclient.spi.Driver
Append a parameter placeholder in the query.
ArrayOfBigDecimal - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfBoolean - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfBuffer - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfDouble - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfFloat - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfInteger - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfJsonArray - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfJsonObject - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfLocalDate - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfLocalDateTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfLocalTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfLong - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfOffsetDateTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfOffsetTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfShort - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfString - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfTemporal - Static variable in class io.vertx.sqlclient.data.NullValue
 
ArrayOfUUID - Static variable in class io.vertx.sqlclient.data.NullValue
 

B

begin() - Method in interface io.vertx.sqlclient.SqlConnection
Begin a transaction and returns a Transaction for controlling and tracking this transaction.
BigDecimal - Static variable in class io.vertx.sqlclient.data.NullValue
 
bigDecimalValue() - Method in class io.vertx.sqlclient.data.Numeric
 
bigIntegerValue() - Method in class io.vertx.sqlclient.data.Numeric
 
Boolean - Static variable in class io.vertx.sqlclient.data.NullValue
 
Buffer - Static variable in class io.vertx.sqlclient.data.NullValue
 
build() - Method in interface io.vertx.sqlclient.ClientBuilder
Build and return the client.

C

clear() - Method in interface io.vertx.sqlclient.Tuple
 
ClientBuilder<C> - Interface in io.vertx.sqlclient
Builder for SqlClient instances.
close() - Method in interface io.vertx.sqlclient.Cursor
Release the cursor.
close() - Method in interface io.vertx.sqlclient.PreparedStatement
Close the prepared query and release its resources.
close() - Method in interface io.vertx.sqlclient.RowStream
Close the stream and release the resources.
close() - Method in interface io.vertx.sqlclient.SqlClient
Close the client and release the associated resources.
ClosedConnectionException - Exception in io.vertx.sqlclient
When a client operation fails with this exception, the underlying connection may have been lost unexpectedly.
closeHandler(Handler<Void>) - Method in interface io.vertx.sqlclient.SqlConnection
Set an handler called when the connection is closed.
collecting(Collector<Row, ?, R>) - Method in interface io.vertx.sqlclient.PreparedQuery
Use the specified collector for collecting the query result to <R>.
collecting(Collector<Row, ?, R>) - Method in interface io.vertx.sqlclient.Query
Use the specified collector for collecting the query result to <R>.
ColumnDescriptor - Interface in io.vertx.sqlclient.desc
 
columnDescriptors() - Method in interface io.vertx.sqlclient.SqlResult
Get the column descriptors in the SqlResult.
columnsNames() - Method in interface io.vertx.sqlclient.SqlResult
Get the names of columns in the SqlResult.
commit() - Method in interface io.vertx.sqlclient.Transaction
Commit the current transaction.
completion() - Method in interface io.vertx.sqlclient.Transaction
Return the transaction completion Future that succeeds when the transaction commits and fails with TransactionRollbackException when the transaction rolls back.
connect(Context, C) - Method in interface io.vertx.sqlclient.spi.ConnectionFactory
Create a connection using the given context.
connect(Context, Future<C>) - Method in interface io.vertx.sqlclient.spi.ConnectionFactory
 
connectingTo(SqlConnectOptions) - Method in interface io.vertx.sqlclient.ClientBuilder
Configure the database the client should connect to.
connectingTo(String) - Method in interface io.vertx.sqlclient.ClientBuilder
Configure the database the client should connect to.
connectingTo(Supplier<Future<SqlConnectOptions>>) - Method in interface io.vertx.sqlclient.ClientBuilder
Configure the database the client should connect to.
connectingTo(List<SqlConnectOptions>) - Method in interface io.vertx.sqlclient.ClientBuilder
Configure the database the client should connect to.
ConnectionFactory<C extends SqlConnectOptions> - Interface in io.vertx.sqlclient.spi
CONTEXT - io.vertx.sqlclient.TransactionPropagation
Keeps the acquired connection stored in the local context for as long as the given function executes.
create(Number) - Static method in class io.vertx.sqlclient.data.Numeric
Return a Numeric instance for the given number.
create(String, Class<T>) - Static method in interface io.vertx.sqlclient.PropertyKind
 
createConnectionFactory(Vertx, NetClientOptions) - Method in interface io.vertx.sqlclient.spi.Driver
Create a connection factory to the given database.
createPool(Vertx, Supplier<Future<C>>, PoolOptions, NetClientOptions, Handler<SqlConnection>) - Method in interface io.vertx.sqlclient.spi.Driver
Create a connection pool to the database configured with the given connectOptions and poolOptions.
createStream(int) - Method in interface io.vertx.sqlclient.PreparedStatement
Like PreparedStatement.createStream(int, Tuple) but with empty arguments.
createStream(int, Tuple) - Method in interface io.vertx.sqlclient.PreparedStatement
Execute the prepared query with a cursor and createStream the result.
cursor() - Method in interface io.vertx.sqlclient.PreparedStatement
Like PreparedStatement.cursor(Tuple) but with empty arguments.
cursor(Tuple) - Method in interface io.vertx.sqlclient.PreparedStatement
Create a cursor with the provided arguments.
Cursor - Interface in io.vertx.sqlclient
A cursor that reads progressively rows from the database, it is useful for reading very large result sets.

D

DatabaseException - Exception in io.vertx.sqlclient
Base class for database failures.
DatabaseException(String, int, String) - Constructor for exception io.vertx.sqlclient.DatabaseException
 
DatabaseException(String, int, String, SQLException) - Constructor for exception io.vertx.sqlclient.DatabaseException
 
databaseMetadata() - Method in interface io.vertx.sqlclient.SqlConnection
 
DatabaseMetadata - Interface in io.vertx.sqlclient.spi
Contains static metadata about the backend database server
deepToString() - Method in interface io.vertx.sqlclient.Tuple
 
DEFAULT_CACHE_PREPARED_STATEMENTS - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_CONNECTION_TIMEOUT - Static variable in class io.vertx.sqlclient.PoolOptions
Default connection timeout in the pool = 30 seconds
DEFAULT_CONNECTION_TIMEOUT_TIME_UNIT - Static variable in class io.vertx.sqlclient.PoolOptions
Default connection idle time unit in the pool = seconds
DEFAULT_EVENT_LOOP_SIZE - Static variable in class io.vertx.sqlclient.PoolOptions
Default pool event loop size = 0 (reuse current event-loop)
DEFAULT_IDLE_TIMEOUT - Static variable in class io.vertx.sqlclient.PoolOptions
Default connection timeout in the pool = 0 (no timeout)
DEFAULT_IDLE_TIMEOUT_TIME_UNIT - Static variable in class io.vertx.sqlclient.PoolOptions
Default connection idle time unit in the pool = seconds
DEFAULT_MAX_SIZE - Static variable in class io.vertx.sqlclient.PoolOptions
The default maximum number of connections a client will pool = 4
DEFAULT_MAX_WAIT_QUEUE_SIZE - Static variable in class io.vertx.sqlclient.PoolOptions
Default max wait queue size = -1 (unbounded)
DEFAULT_MAXIMUM_LIFETIME - Static variable in class io.vertx.sqlclient.PoolOptions
Default maximum pooled connection lifetime = 0 (no maximum)
DEFAULT_MAXIMUM_LIFETIME_TIME_UNIT - Static variable in class io.vertx.sqlclient.PoolOptions
Default maximum pooled connection lifetime unit = seconds
DEFAULT_METRICS_NAME - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_NAME - Static variable in class io.vertx.sqlclient.PoolOptions
Actual name of anonymous shared pool = __vertx.DEFAULT
DEFAULT_POOL_CLEANER_PERIOD - Static variable in class io.vertx.sqlclient.PoolOptions
Default pool cleaner period = 1000 ms (1 second)
DEFAULT_PREPARED_STATEMENT_CACHE_FILTER - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_PREPARED_STATEMENT_CACHE_MAX_SIZE - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_PREPARED_STATEMENT_CACHE_SQL_LIMIT - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_RECONNECT_ATTEMPTS - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_RECONNECT_INTERVAL - Static variable in class io.vertx.sqlclient.SqlConnectOptions
 
DEFAULT_SHARED_POOL - Static variable in class io.vertx.sqlclient.PoolOptions
Default shared pool config = false
Double - Static variable in class io.vertx.sqlclient.data.NullValue
 
doubleValue() - Method in class io.vertx.sqlclient.data.Numeric
 
downcast(SqlConnectOptions) - Method in interface io.vertx.sqlclient.spi.Driver
Downcast the connect options to the specific driver options.
Driver<C extends SqlConnectOptions> - Interface in io.vertx.sqlclient.spi
An entry point to the Vertx Reactive SQL Client Every driver must implement this interface.

E

endHandler(Handler<Void>) - Method in interface io.vertx.sqlclient.RowStream
 
equals(Object) - Method in class io.vertx.sqlclient.data.Numeric
 
equals(Object) - Method in class io.vertx.sqlclient.PoolOptions
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.sqlclient.RowStream
 
exceptionHandler(Handler<Throwable>) - Method in interface io.vertx.sqlclient.SqlConnection
Set an handler called with connection errors.
execute() - Method in interface io.vertx.sqlclient.Query
Execute the query.
execute(Tuple) - Method in interface io.vertx.sqlclient.PreparedQuery
Execute the query.
executeBatch(List<Tuple>) - Method in interface io.vertx.sqlclient.PreparedQuery
Execute the query with a batch of tuples.

F

fetch(long) - Method in interface io.vertx.sqlclient.RowStream
 
Float - Static variable in class io.vertx.sqlclient.data.NullValue
 
floatValue() - Method in class io.vertx.sqlclient.data.Numeric
 
from(Object[]) - Static method in interface io.vertx.sqlclient.Tuple
Wrap the provided array with a tuple.
from(List<T>) - Static method in interface io.vertx.sqlclient.Tuple
Wrap the provided list with a tuple.
fromUri(String) - Static method in class io.vertx.sqlclient.SqlConnectOptions
Provide a SqlConnectOptions subclass configured from connectionUri.
fullVersion() - Method in interface io.vertx.sqlclient.spi.DatabaseMetadata
 

G

get(Class<T>, int) - Method in interface io.vertx.sqlclient.Tuple
Get the the at the specified position and the specified type.
get(Class<T>, String) - Method in interface io.vertx.sqlclient.Row
Like Tuple.get(Class, int) but specifying the column instead of the position.
getArrayOfBigDecimals(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of BigDecimal value at pos.
getArrayOfBigDecimals(String) - Method in interface io.vertx.sqlclient.Row
Get an array of BigDecimal value for the given column.
getArrayOfBooleans(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Boolean value at pos.
getArrayOfBooleans(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Boolean value for the given column.
getArrayOfBuffers(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Buffer value at pos.
getArrayOfBuffers(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Buffer value for the given column.
getArrayOfDoubles(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Double value at pos.
getArrayOfDoubles(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Double value for the given column.
getArrayOfFloats(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Float value at pos.
getArrayOfFloats(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Float value for the given column.
getArrayOfIntegers(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Integer value at pos.
getArrayOfIntegers(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Integer value for the given column.
getArrayOfJsonArrays(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of JsonArray value at pos.
getArrayOfJsonArrays(String) - Method in interface io.vertx.sqlclient.Row
Get an array of JsonArray value for the given column.
getArrayOfJsonObjects(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of JsonObject value at pos.
getArrayOfJsonObjects(String) - Method in interface io.vertx.sqlclient.Row
Get an array of JsonObject value for the given column.
getArrayOfJsons(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of JSON elements at pos, the element might be null or one of the following types: String Number JsonObject JsonArray Boolean
getArrayOfJsons(String) - Method in interface io.vertx.sqlclient.Row
Get an array of JSON elements for the given column, the element might be null or one of the following types: String Number JsonObject JsonArray Boolean
getArrayOfLocalDates(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of LocalDate value at pos.
getArrayOfLocalDates(String) - Method in interface io.vertx.sqlclient.Row
Get an array of LocalDate value for the given column.
getArrayOfLocalDateTimes(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of LocalDateTime value at pos.
getArrayOfLocalDateTimes(String) - Method in interface io.vertx.sqlclient.Row
Get an array of LocalDateTime value for the given column.
getArrayOfLocalTimes(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of LocalTime value at pos.
getArrayOfLocalTimes(String) - Method in interface io.vertx.sqlclient.Row
Get an array of LocalTime value for the given column.
getArrayOfLongs(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Long value at pos.
getArrayOfLongs(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Long value for the given column.
getArrayOfNumerics(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Numeric value at pos.
getArrayOfNumerics(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Numeric value for the given column.
getArrayOfOffsetDateTimes(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of OffsetDateTime value at pos.
getArrayOfOffsetDateTimes(String) - Method in interface io.vertx.sqlclient.Row
Get an array of OffsetDateTime value for the given column.
getArrayOfOffsetTimes(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of OffsetTime value at pos.
getArrayOfOffsetTimes(String) - Method in interface io.vertx.sqlclient.Row
Get an array of OffsetTime value for the given column.
getArrayOfShorts(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Short value at pos.
getArrayOfShorts(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Short value for the given column.
getArrayOfStrings(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of String value at pos.
getArrayOfStrings(String) - Method in interface io.vertx.sqlclient.Row
Get an array of String value for the given column.
getArrayOfTemporals(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of Temporal value at pos.
getArrayOfTemporals(String) - Method in interface io.vertx.sqlclient.Row
Get an array of Temporal value for the given column.
getArrayOfUUIDs(int) - Method in interface io.vertx.sqlclient.Tuple
Get an array of UUID value at pos.
getArrayOfUUIDs(String) - Method in interface io.vertx.sqlclient.Row
Get an array of UUID value for the given column.
getBigDecimal(int) - Method in interface io.vertx.sqlclient.Tuple
Get BigDecimal value at pos.
getBigDecimal(String) - Method in interface io.vertx.sqlclient.Row
Get BigDecimal value for the given column.
getBoolean(int) - Method in interface io.vertx.sqlclient.Tuple
Get a boolean value at pos.
getBoolean(String) - Method in interface io.vertx.sqlclient.Row
Get a boolean value for the given column.
getBuffer(int) - Method in interface io.vertx.sqlclient.Tuple
Get a buffer value at pos.
getBuffer(String) - Method in interface io.vertx.sqlclient.Row
Get a buffer value for the given column.
getCachePreparedStatements() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get whether prepared statements cache is enabled.
getColumnIndex(String) - Method in interface io.vertx.sqlclient.Row
Get a column position for the given @code column}.
getColumnName(int) - Method in interface io.vertx.sqlclient.Row
Get a column name at pos.
getConnection() - Method in interface io.vertx.sqlclient.Pool
Get a connection from the pool.
getConnectionTimeout() - Method in class io.vertx.sqlclient.PoolOptions
 
getConnectionTimeoutUnit() - Method in class io.vertx.sqlclient.PoolOptions
 
getDatabase() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the default database name for the connection.
getDouble(int) - Method in interface io.vertx.sqlclient.Tuple
Get a double value at pos.
getDouble(String) - Method in interface io.vertx.sqlclient.Row
Get a double value for the given column.
getErrorCode() - Method in exception io.vertx.sqlclient.DatabaseException
Database specific error code.
getEventLoopSize() - Method in class io.vertx.sqlclient.PoolOptions
 
getFloat(int) - Method in interface io.vertx.sqlclient.Tuple
Get a float value at pos.
getFloat(String) - Method in interface io.vertx.sqlclient.Row
Get a float value for the given column.
getHost() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the host for connecting to the server.
getIdleTimeout() - Method in class io.vertx.sqlclient.PoolOptions
 
getIdleTimeoutUnit() - Method in class io.vertx.sqlclient.PoolOptions
 
getInteger(int) - Method in interface io.vertx.sqlclient.Tuple
Get an integer value at pos.
getInteger(String) - Method in interface io.vertx.sqlclient.Row
Get an integer value for the given column.
getJson(int) - Method in interface io.vertx.sqlclient.Tuple
Get a JSON element at pos, the element might be null or one of the following types: String Number JsonObject JsonArray Boolean
getJson(String) - Method in interface io.vertx.sqlclient.Row
Get a JSON element for the given column, the element might be null or one of the following types: String Number JsonObject JsonArray Boolean
getJsonArray(int) - Method in interface io.vertx.sqlclient.Tuple
Get a JsonArray value at pos.
getJsonArray(String) - Method in interface io.vertx.sqlclient.Row
Get a JsonArray value for the given column.
getJsonObject(int) - Method in interface io.vertx.sqlclient.Tuple
Get a JsonObject value at pos.
getJsonObject(String) - Method in interface io.vertx.sqlclient.Row
Get a JsonObject value for the given column.
getLocalDate(int) - Method in interface io.vertx.sqlclient.Tuple
Get LocalDate value at pos.
getLocalDate(String) - Method in interface io.vertx.sqlclient.Row
Get LocalDate value for the given column.
getLocalDateTime(int) - Method in interface io.vertx.sqlclient.Tuple
Get LocalDateTime value at pos.
getLocalDateTime(String) - Method in interface io.vertx.sqlclient.Row
Get LocalDateTime value for the given column.
getLocalTime(int) - Method in interface io.vertx.sqlclient.Tuple
Get LocalTime value at pos.
getLocalTime(String) - Method in interface io.vertx.sqlclient.Row
Get LocalTime value for the given column.
getLong(int) - Method in interface io.vertx.sqlclient.Tuple
Get a long value at pos.
getLong(String) - Method in interface io.vertx.sqlclient.Row
Get a long value for the given column.
getMaxLifetime() - Method in class io.vertx.sqlclient.PoolOptions
 
getMaxLifetimeUnit() - Method in class io.vertx.sqlclient.PoolOptions
 
getMaxSize() - Method in class io.vertx.sqlclient.PoolOptions
 
getMaxWaitQueueSize() - Method in class io.vertx.sqlclient.PoolOptions
 
getMetricsName() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getName() - Method in class io.vertx.sqlclient.PoolOptions
 
getNumeric(int) - Method in interface io.vertx.sqlclient.Tuple
Get Numeric value at pos.
getNumeric(String) - Method in interface io.vertx.sqlclient.Row
Get Numeric value for the given column.
getOffsetDateTime(int) - Method in interface io.vertx.sqlclient.Tuple
Get OffsetDateTime value at pos.
getOffsetDateTime(String) - Method in interface io.vertx.sqlclient.Row
Get OffsetDateTime value for the given column.
getOffsetTime(int) - Method in interface io.vertx.sqlclient.Tuple
Get OffsetTime value at pos.
getOffsetTime(String) - Method in interface io.vertx.sqlclient.Row
Get OffsetTime value for the given column.
getPassword() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the user password to be used for the authentication.
getPoolCleanerPeriod() - Method in class io.vertx.sqlclient.PoolOptions
 
getPort() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the port for connecting to the server.
getPreparedStatementCacheMaxSize() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the maximum number of prepared statements that the connection will cache.
getPreparedStatementCacheSqlFilter() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the predicate filtering prepared statements that the connection will cache.
getProperties() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getReconnectAttempts() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getReconnectInterval() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getShort(int) - Method in interface io.vertx.sqlclient.Tuple
Get a short value at pos.
getShort(String) - Method in interface io.vertx.sqlclient.Row
Get a short value for the given column.
getSocketAddress() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getSqlState() - Method in exception io.vertx.sqlclient.DatabaseException
SQL State (XOPEN or SQL:2003 conventions).
getSslOptions() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getString(int) - Method in interface io.vertx.sqlclient.Tuple
Get a string value at pos.
getString(String) - Method in interface io.vertx.sqlclient.Row
Get a string value for the given column.
getTemporal(int) - Method in interface io.vertx.sqlclient.Tuple
Get a Temporal value at pos.
getTemporal(String) - Method in interface io.vertx.sqlclient.Row
Get a temporal value for the given column.
getTracingPolicy() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
getUser() - Method in class io.vertx.sqlclient.SqlConnectOptions
Get the user account to be used for the authentication.
getUUID(int) - Method in interface io.vertx.sqlclient.Tuple
Get UUID value at pos.
getUUID(String) - Method in interface io.vertx.sqlclient.Row
Get UUID value for the given column.
getValue(int) - Method in interface io.vertx.sqlclient.Tuple
Get an object value at pos.
getValue(String) - Method in interface io.vertx.sqlclient.Row
Get a value for the given column.

H

handler(Handler<T>) - Method in interface io.vertx.sqlclient.RowStream
 
hashCode() - Method in class io.vertx.sqlclient.data.Numeric
 
hashCode() - Method in class io.vertx.sqlclient.PoolOptions
 
hasMore() - Method in interface io.vertx.sqlclient.Cursor
Returns true when the cursor has results in progress and the Cursor.read(int) should be called to retrieve them.
hasNext() - Method in interface io.vertx.sqlclient.RowIterator
 

I

init() - Method in class io.vertx.sqlclient.SqlConnectOptions
Initialize with the default options.
INSTANCE - Static variable in exception io.vertx.sqlclient.ClosedConnectionException
 
INSTANCE - Static variable in exception io.vertx.sqlclient.TransactionRollbackException
 
Integer - Static variable in class io.vertx.sqlclient.data.NullValue
 
intValue() - Method in class io.vertx.sqlclient.data.Numeric
 
io.vertx.sql.client - module io.vertx.sql.client
 
io.vertx.sqlclient - package io.vertx.sqlclient
 
io.vertx.sqlclient.data - package io.vertx.sqlclient.data
 
io.vertx.sqlclient.desc - package io.vertx.sqlclient.desc
 
io.vertx.sqlclient.spi - package io.vertx.sqlclient.spi
 
isArray() - Method in interface io.vertx.sqlclient.desc.ColumnDescriptor
 
isClosed() - Method in interface io.vertx.sqlclient.Cursor
 
isNaN() - Method in class io.vertx.sqlclient.data.Numeric
 
isShared() - Method in class io.vertx.sqlclient.PoolOptions
 
isSSL() - Method in interface io.vertx.sqlclient.SqlConnection
 
isUsingDomainSocket() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
iterator() - Method in interface io.vertx.sqlclient.RowSet
 

J

jdbcType() - Method in interface io.vertx.sqlclient.desc.ColumnDescriptor
 
JSON_NULL - Static variable in interface io.vertx.sqlclient.Tuple
The JSON null literal value.
JsonArray - Static variable in class io.vertx.sqlclient.data.NullValue
 
JsonObject - Static variable in class io.vertx.sqlclient.data.NullValue
 

L

LocalDate - Static variable in class io.vertx.sqlclient.data.NullValue
 
LocalDateTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
LocalTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
Long - Static variable in class io.vertx.sqlclient.data.NullValue
 
longValue() - Method in class io.vertx.sqlclient.data.Numeric
 

M

majorVersion() - Method in interface io.vertx.sqlclient.spi.DatabaseMetadata
 
mapping(Function<Row, U>) - Method in interface io.vertx.sqlclient.PreparedQuery
Use the specified mapper for mapping Row to <U>.
mapping(Function<Row, U>) - Method in interface io.vertx.sqlclient.Query
Use the specified mapper for mapping Row to <U>.
merge(JsonObject) - Method in class io.vertx.sqlclient.SqlConnectOptions
Returns new options created after this object and merged with the other json config.
minorVersion() - Method in interface io.vertx.sqlclient.spi.DatabaseMetadata
 

N

name() - Method in interface io.vertx.sqlclient.desc.ColumnDescriptor
 
name() - Method in interface io.vertx.sqlclient.PropertyKind
 
NaN - Static variable in class io.vertx.sqlclient.data.Numeric
Constant for the NaN value.
newPool(Vertx, Supplier<Future<C>>, PoolOptions, NetClientOptions, Handler<SqlConnection>, CloseFuture) - Method in interface io.vertx.sqlclient.spi.Driver
Create a connection pool to the database configured with the given connectOptions and poolOptions.
next() - Method in interface io.vertx.sqlclient.RowIterator
 
next() - Method in interface io.vertx.sqlclient.RowSet
 
next() - Method in interface io.vertx.sqlclient.SqlResult
Return the next available result or null, e.g for a simple query that executed multiple queries or for a batch result.
NONE - io.vertx.sqlclient.TransactionPropagation
The acquired connection is not stored anywhere, making it local to the provided function execution and to wherever it is passed.
NullValue - Class in io.vertx.sqlclient.data
Instances of this class indicate the type associated with a NULL column value.
Numeric - Class in io.vertx.sqlclient.data
An arbitrary number that supports NaN.

O

of(Class<?>) - Static method in class io.vertx.sqlclient.data.NullValue
 
of(Object) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of one element.
of(Object, Object) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of two elements.
of(Object, Object...) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of an arbitrary number of elements.
of(Object, Object, Object) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of three elements.
of(Object, Object, Object, Object) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of four elements.
of(Object, Object, Object, Object, Object) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of five elements.
of(Object, Object, Object, Object, Object, Object) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple of six elements.
OffsetDateTime - Static variable in class io.vertx.sqlclient.data.NullValue
 
OffsetTime - Static variable in class io.vertx.sqlclient.data.NullValue
 

P

parse(String) - Static method in class io.vertx.sqlclient.data.Numeric
Parse and return a Numeric instance for the given s.
parseConnectionUri(String) - Method in interface io.vertx.sqlclient.spi.Driver
 
pause() - Method in interface io.vertx.sqlclient.RowStream
 
pool(Vertx, SqlConnectOptions, PoolOptions) - Static method in interface io.vertx.sqlclient.Pool
Create a connection pool to the database with the given options.
pool(Driver<?>) - Static method in interface io.vertx.sqlclient.ClientBuilder
Provide a builder for a pool of connections for the specified Driver
pool(Driver<?>, Handler<ClientBuilder<Pool>>) - Static method in interface io.vertx.sqlclient.ClientBuilder
Build a pool with the specified block argument and Driver The block argument is usually a lambda that configures the provided builder
pool(SqlConnectOptions) - Static method in interface io.vertx.sqlclient.Pool
pool(SqlConnectOptions, PoolOptions) - Static method in interface io.vertx.sqlclient.Pool
Like Pool.pool(Vertx, SqlConnectOptions, PoolOptions) with a Vert.x instance created automatically.
Pool - Interface in io.vertx.sqlclient
A connection pool which reuses a number of SQL connections.
PoolOptions - Class in io.vertx.sqlclient
The options for configuring a connection pool.
PoolOptions() - Constructor for class io.vertx.sqlclient.PoolOptions
 
PoolOptions(JsonObject) - Constructor for class io.vertx.sqlclient.PoolOptions
 
PoolOptions(PoolOptions) - Constructor for class io.vertx.sqlclient.PoolOptions
 
PoolOptionsConverter - Class in io.vertx.sqlclient
Converter and mapper for PoolOptions.
PoolOptionsConverter() - Constructor for class io.vertx.sqlclient.PoolOptionsConverter
 
prepare(String) - Method in interface io.vertx.sqlclient.SqlConnection
Create a prepared statement using the given sql string.
prepare(String, PrepareOptions) - Method in interface io.vertx.sqlclient.SqlConnection
Create a prepared statement using the given sql string.
preparedQuery(String) - Method in interface io.vertx.sqlclient.Pool
Create a prepared query, one of the PreparedQuery.execute(io.vertx.sqlclient.Tuple) or PreparedQuery.executeBatch(java.util.List<io.vertx.sqlclient.Tuple>) methods must be called to execute the query.
preparedQuery(String) - Method in interface io.vertx.sqlclient.SqlClient
Create a prepared query, one of the PreparedQuery.execute(io.vertx.sqlclient.Tuple) or PreparedQuery.executeBatch(java.util.List<io.vertx.sqlclient.Tuple>) methods must be called to execute the query.
preparedQuery(String, PrepareOptions) - Method in interface io.vertx.sqlclient.SqlClient
Create a prepared query, one of the PreparedQuery.execute(io.vertx.sqlclient.Tuple) or PreparedQuery.executeBatch(java.util.List<io.vertx.sqlclient.Tuple>) methods must be called to execute the query.
PreparedQuery<T> - Interface in io.vertx.sqlclient
A query for a prepared statement allowing parameterized execution of the query, this query will use a prepared statement.
PreparedStatement - Interface in io.vertx.sqlclient
A prepared statement, the statement is pre-compiled and it's more efficient to execute the statement for multiple times.
PrepareOptions - Class in io.vertx.sqlclient
Options for preparing a statement.
PrepareOptions() - Constructor for class io.vertx.sqlclient.PrepareOptions
 
PrepareOptions(JsonObject) - Constructor for class io.vertx.sqlclient.PrepareOptions
 
PrepareOptions(PrepareOptions) - Constructor for class io.vertx.sqlclient.PrepareOptions
 
productName() - Method in interface io.vertx.sqlclient.spi.DatabaseMetadata
 
property(PropertyKind<V>) - Method in interface io.vertx.sqlclient.SqlResult
Get the specific property with the specified PropertyKind.
PropertyKind<T> - Interface in io.vertx.sqlclient
The kind of the property, this can be used to fetch some specific property of the execution result.

Q

query() - Method in interface io.vertx.sqlclient.PreparedStatement
Create a prepared query for this statement.
query(String) - Method in interface io.vertx.sqlclient.Pool
Create a query, the Query.execute() method must be called to execute the query.
query(String) - Method in interface io.vertx.sqlclient.SqlClient
Create a query, the Query.execute() method must be called to execute the query.
Query<T> - Interface in io.vertx.sqlclient
A query.

R

read(int) - Method in interface io.vertx.sqlclient.Cursor
Read rows from the cursor, the result is provided asynchronously to the handler.
release() - Method in interface io.vertx.sqlclient.Row
Signal the row can be recycled, this is only effective when dealing with a row in a collector query and the row has already been processed and transformed.
resume() - Method in interface io.vertx.sqlclient.RowStream
 
rollback() - Method in interface io.vertx.sqlclient.Transaction
Rollback the transaction and release the associated resources.
Row - Interface in io.vertx.sqlclient
A single row of the execution result rowset.
rowCount() - Method in interface io.vertx.sqlclient.SqlResult
Get the number of the affected rows in the operation to this SqlResult.
RowIterator<R> - Interface in io.vertx.sqlclient
An iterator for processing rows.
RowSet<R> - Interface in io.vertx.sqlclient
The execution result of the row set of a query provided as <R>, commonly used as a RowSet<Row>.
RowStream<T> - Interface in io.vertx.sqlclient
A row oriented stream.

S

setCachePreparedStatements(boolean) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set whether prepared statements cache should be enabled.
setConnectionTimeout(int) - Method in class io.vertx.sqlclient.PoolOptions
Set the amount of time a client will wait for a connection from the pool.
setConnectionTimeoutUnit(TimeUnit) - Method in class io.vertx.sqlclient.PoolOptions
setDatabase(String) - Method in class io.vertx.sqlclient.SqlConnectOptions
Specify the default database for the connection.
setEventLoopSize(int) - Method in class io.vertx.sqlclient.PoolOptions
Set the number of event-loop the pool use.
setHost(String) - Method in class io.vertx.sqlclient.SqlConnectOptions
Specify the host for connecting to the server.
setIdleTimeout(int) - Method in class io.vertx.sqlclient.PoolOptions
Establish an idle timeout for pooled connections, a value of zero disables the idle timeout.
setIdleTimeoutUnit(TimeUnit) - Method in class io.vertx.sqlclient.PoolOptions
Establish an idle timeout unit for pooled connections.
setMaxLifetime(int) - Method in class io.vertx.sqlclient.PoolOptions
Establish a max lifetime for pooled connections, a value of zero disables the maximum lifetime.
setMaxLifetimeUnit(TimeUnit) - Method in class io.vertx.sqlclient.PoolOptions
Establish a max lifetime unit for pooled connections.
setMaxSize(int) - Method in class io.vertx.sqlclient.PoolOptions
Set the maximum pool size
setMaxWaitQueueSize(int) - Method in class io.vertx.sqlclient.PoolOptions
Set the maximum connection request allowed in the wait queue, any requests beyond the max size will result in an failure.
setMetricsName(String) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set the metrics name identifying the reported metrics, useful for grouping metrics with the same name.
setName(String) - Method in class io.vertx.sqlclient.PoolOptions
Set the pool name, used when the pool shared, otherwise ignored.
setPassword(String) - Method in class io.vertx.sqlclient.SqlConnectOptions
Specify the user password to be used for the authentication.
setPoolCleanerPeriod(int) - Method in class io.vertx.sqlclient.PoolOptions
Set the connection pool cleaner period in milli seconds, a non positive value disables expiration checks and connections will remain in the pool until they are closed.
setPort(int) - Method in class io.vertx.sqlclient.SqlConnectOptions
Specify the port for connecting to the server.
setPreparedStatementCacheMaxSize(int) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set the maximum number of prepared statements that the connection will cache.
setPreparedStatementCacheSqlFilter(Predicate<String>) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set a predicate filtering prepared statements that the connection will cache.
setPreparedStatementCacheSqlLimit(int) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set the maximum length of prepared statement SQL string that the connection will cache.
setProperties(Map<String, String>) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set properties for this client, which will be sent to server at the connection start.
setReconnectAttempts(int) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set the value of reconnect attempts
setReconnectInterval(long) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set the reconnect interval
setShared(boolean) - Method in class io.vertx.sqlclient.PoolOptions
Set to true to share the pool.
setSslOptions(ClientSSLOptions) - Method in class io.vertx.sqlclient.SqlConnectOptions
 
setTracingPolicy(TracingPolicy) - Method in class io.vertx.sqlclient.SqlConnectOptions
Set the tracing policy for the client behavior when Vert.x has tracing enabled.
setUser(String) - Method in class io.vertx.sqlclient.SqlConnectOptions
Specify the user account to be used for the authentication.
Short - Static variable in class io.vertx.sqlclient.data.NullValue
 
shortValue() - Method in class io.vertx.sqlclient.data.Numeric
 
size() - Method in interface io.vertx.sqlclient.Pool
 
size() - Method in interface io.vertx.sqlclient.SqlResult
Get the number of rows retrieved in the SqlResult.
size() - Method in interface io.vertx.sqlclient.Tuple
 
SqlClient - Interface in io.vertx.sqlclient
Defines common SQL client operations with a database server.
SqlConnection - Interface in io.vertx.sqlclient
A connection to the database server.
SqlConnectOptions - Class in io.vertx.sqlclient
Connect options for configuring SqlConnection or Pool.
SqlConnectOptions() - Constructor for class io.vertx.sqlclient.SqlConnectOptions
 
SqlConnectOptions(JsonObject) - Constructor for class io.vertx.sqlclient.SqlConnectOptions
 
SqlConnectOptions(SqlConnectOptions) - Constructor for class io.vertx.sqlclient.SqlConnectOptions
 
SqlConnectOptionsConverter - Class in io.vertx.sqlclient
Converter and mapper for SqlConnectOptions.
SqlConnectOptionsConverter() - Constructor for class io.vertx.sqlclient.SqlConnectOptionsConverter
 
SqlResult<T> - Interface in io.vertx.sqlclient
An interface that represents the execution result of an operation on the database server.
stream() - Method in interface io.vertx.sqlclient.RowSet
 
String - Static variable in class io.vertx.sqlclient.data.NullValue
 

T

Temporal - Static variable in class io.vertx.sqlclient.data.NullValue
 
toJson() - Method in class io.vertx.sqlclient.PoolOptions
 
toJson() - Method in class io.vertx.sqlclient.PrepareOptions
 
toJson() - Method in interface io.vertx.sqlclient.Row
Return a JSON object representation of the row.
toJson() - Method in class io.vertx.sqlclient.SqlConnectOptions
 
toString() - Method in class io.vertx.sqlclient.data.Numeric
 
toString() - Method in class io.vertx.sqlclient.PrepareOptions
 
transaction() - Method in interface io.vertx.sqlclient.SqlConnection
 
Transaction - Interface in io.vertx.sqlclient
A transaction.
TransactionPropagation - Enum in io.vertx.sqlclient
Defines how the acquired connection will be managed during the execution of the function provided in Pool.withTransaction(TransactionPropagation, Function).
TransactionRollbackException - Exception in io.vertx.sqlclient
Failure reported to the Transaction.completion() future when the database server reports the current transaction is failed.
tuple() - Static method in interface io.vertx.sqlclient.Tuple
 
tuple(List<Object>) - Static method in interface io.vertx.sqlclient.Tuple
Create a tuple with the provided elements list.
Tuple - Interface in io.vertx.sqlclient
A general purpose tuple.
type() - Method in class io.vertx.sqlclient.data.NullValue
 
type() - Method in interface io.vertx.sqlclient.PropertyKind
 
typeName() - Method in interface io.vertx.sqlclient.desc.ColumnDescriptor
 
types() - Method in interface io.vertx.sqlclient.Tuple
 

U

using(Vertx) - Method in interface io.vertx.sqlclient.ClientBuilder
Sets the vertx instance to use.
UUID - Static variable in class io.vertx.sqlclient.data.NullValue
 

V

value() - Method in interface io.vertx.sqlclient.SqlResult
Get the execution result value, the execution result type may vary such as a rowSet or even a string.
valueOf(String) - Static method in enum io.vertx.sqlclient.TransactionPropagation
Returns the enum constant of this type with the specified name.
values() - Static method in enum io.vertx.sqlclient.TransactionPropagation
Returns an array containing the constants of this enum type, in the order they are declared.

W

with(NetClientOptions) - Method in interface io.vertx.sqlclient.ClientBuilder
Configure the client pool with the given transport options.
with(PoolOptions) - Method in interface io.vertx.sqlclient.ClientBuilder
Configure the client with the given pool options
withConnectHandler(Handler<SqlConnection>) - Method in interface io.vertx.sqlclient.ClientBuilder
Set a handler called when the pool has established a connection to the database.
withConnection(Function<SqlConnection, Future<T>>) - Method in interface io.vertx.sqlclient.Pool
Get a connection from the pool and execute the given function.
withTransaction(TransactionPropagation, Function<SqlConnection, Future<T>>) - Method in interface io.vertx.sqlclient.Pool
Like Pool.withTransaction(Function) but allows for setting the mode, defining how the acquired connection is managed during the execution of the function.
withTransaction(Function<SqlConnection, Future<T>>) - Method in interface io.vertx.sqlclient.Pool
Execute the given function within a transaction.
wrap(Object[]) - Static method in interface io.vertx.sqlclient.Tuple
Wrap the provided array with a tuple.
wrap(List<T>) - Static method in interface io.vertx.sqlclient.Tuple
Wrap the provided list with a tuple.
wrapConnection(ContextInternal, ConnectionFactory<C>, Connection) - Method in interface io.vertx.sqlclient.spi.Driver
 
A B C D E F G H I J L M N O P Q R S T U V W 
All Classes All Packages