All Classes

Class Description
AbandonedConnectionCleanupThread
This class implements a thread that is responsible for closing abandoned MySQL connections, i.e., connections that are not explicitly closed.
AbstractBufferRow
A ResultSetRow implementation that holds one row packet (which is re-used by the driver, and thus saves memory allocations), and tries when possible to avoid allocations to break out the results as individual byte[]s.
AbstractDataResult<T>
Base class for data set results.
AbstractDateTimeValueFactory<T>  
AbstractFilterParams
Abstract implementation of FilterParams.
AbstractNumericValueFactory<T>  
AbstractPreparedQuery<T extends QueryBindings<?>>  
AbstractPropertyDefinition<T>  
AbstractProtocol<M extends Message>  
AbstractQuery  
AbstractQueryBindings<T extends BindValue>  
AbstractResultsetRow  
AbstractResultsetRows  
AbstractRowFactory  
AbstractRuntimeProperty<T>  
AbstractSocketConnection  
AddMethods  
AddResult
A result from the collection.add() statement.
AddResultBuilder
Result builder producing an AddResult instance.
AddResultImpl
A result from the collection.add() statement.
AddStatement
A statement adding documents to a collection.
AddStatementImpl  
AppendingBatchVisitor  
AssertionFailedException
Assertions for empty code paths that should never be executed.
AuroraTopologyService
An implementation of topology service for Aurora RDS.
AuthenticationLdapSaslClientPlugin
MySQL 'authentication_ldap_sasl_client' authentication plugin.
AuthenticationPlugin<M extends Message>
Implementors of this interface can be installed via the "authenticationPlugins" configuration property.
AuthenticationProvider<M extends Message>  
AwsSingleConnectionUrl  
BalanceStrategy
Implement this interface to provide a new load balancing strategy for URLs of the form "jdbc:mysql:loadbalance://..", and provide the implementation class name as the configuration parameter "loadBalanceStrategy".
Base64Decoder
This decoder implements standard Base64 decoding except it allows and silently ignores non-base64 input characters (spaces, line breaks etc) Note: Java 6+ provide standard decoders
Base64Decoder.IntWrapper  
BaseBugReport
Base class to help file bug reports for Connector/J.
BaseMetricsHolder  
BasicConnectionProvider
This class is a basic implementation of ConnectionProvider interface.
BatchVisitor  
BestResponseTimeBalanceStrategy  
BigDecimalValueFactory
A value factory for creating BigDecimal values.
BinaryBufferRow
A BufferRow implementation that holds one row packet from a server-side prepared statement (which is re-used by the driver, and thus saves memory allocations), and tries when possible to avoid allocations to break out the results as individual byte[]s.
BinaryResultsetReader  
BinaryRowFactory
Handle binary-encoded data for server-side PreparedStatements
BinaryStreamValueFactory
A value factory for a raw stream of bytes from the value.
BindValue  
Blob
The representation (mapping) in the JavaTM programming language of an SQL BLOB value.
BlobFromLocator
The representation (mapping) in the JavaTM programming language of an SQL BLOB value.
BooleanProperty  
BooleanPropertyDefinition  
BooleanPropertyDefinition.AllowableValues  
BooleanValueFactory
A value factory for creating Boolean values.
BufferedRowList  
ByteArrayRow
A RowHolder implementation that is for cached results (a-la mysql_store_result()).
ByteValueFactory
A value factory for creating byte values.
CacheAdapter<K,​V>  
CacheAdapterFactory<K,​V>  
CachedResultSetMetaData  
CachedResultSetMetaDataImpl  
CachingSha2PasswordPlugin  
CachingSha2PasswordPlugin.AuthStage  
CallableStatement
Representation of stored procedures for JDBC
CallableStatement.CallableStatementParam  
CallableStatementWrapper
Wraps callable statements created by pooled connections.
CancelQueryTask  
CancelQueryTaskImpl
Thread used to implement query timeouts...Eventually we could be more efficient and have one thread with timers, but this is a straightforward and simple way to implement a feature that isn't used all that often.
CanCollectPerformanceMetrics
This is a generic interface for performance metrics.
CharsetMapping
Mapping between MySQL charset names and Java charset names.
CJCommunicationsException  
CJConnectionFeatureNotAvailableException  
CJException
The base unchecked exception thrown internally in connector.
CJOperationNotSupportedException  
CJPacketTooBigException
Thrown when a packet that is too big for the server is created.
CJTimeoutException  
Client
X DevAPI class encapsulating a Session pooling functionality.
Client.ClientProperty  
ClientFactory
ClientFactory is used for creation of Client instances.
ClientImpl  
ClientInfoProvider
Classes that implement this interface and provide a no-args constructor can be used by the driver to store and retrieve client information and/or labels.
ClientInfoProviderSP  
ClientPreparedQuery  
ClientPreparedQueryBindings  
ClientPreparedQueryBindValue  
ClientPreparedStatement
A SQL Statement is pre-compiled and stored in a PreparedStatement object.
Clob
Simplistic implementation of java.sql.Clob for MySQL Connector/J
ClosedOnExpiredPasswordException
Equivalent to SQLSTATE ER_MUST_CHANGE_PASSWORD_LOGIN = 1862 "Your password has expired.
ClusterAwareConnectionLifecycleInterceptor
This basic implementation of ConnectionLifecycleInterceptor allows the ClusterAwareConnectionProxy class to be aware of certain events occurring against the database connection.
ClusterAwareConnectionProxy
A proxy for a dynamic com.mysql.cj.jdbc.JdbcConnection implementation that provides cluster-aware failover features.
ClusterAwareHitMissMetricsHolder
A simple implementation of hit-miss metric.
ClusterAwareMetrics
Collect certain performance metrics for ClusterAwareConnectionProxy.
ClusterAwareReaderFailoverHandler
An implementation of ReaderFailoverHandler.
ClusterAwareReaderFailoverHandler.HostTuple
HostTuple class.
ClusterAwareTimeMetricsHolder
A simple implementation of timing metric.
ClusterAwareUtils  
ClusterAwareWriterFailoverHandler
An implementation of WriterFailoverHandler.
Collection
Representation of a document collection.
CollectionImpl  
Column
Represents individual column of RowResult
ColumnDefinition
Represents protocol specific result set metadata, eg., for native protocol, Protocol::ColumnDefinition41 protocol entity.
ColumnDefinitionFactory  
ColumnDefinitionReader  
ColumnImpl  
CommentClientInfoProvider
An implementation of ClientInfoProvider that exposes the client info as a comment prepended to all statements issued by the driver.
CommonChecks  
CommunicationsException
An exception to represent communications errors with the database.
CompressedInputStream
Used to de-compress packets from the MySQL server when protocol-level compression is turned on.
CompressedPacketSender
A MessageSender for the compressed protocol.
CompressionAlgorithm
Contains all information about a compression algorithm, its name, compression mode and classes that implement the inflating and deflating streams of data.
CompressionMode
The modes by which compression can be made.
CompressionSplittedInputStream
An InputStream wrapper that analyzes X Protocol frames and, if compressed, routes them to a secondary compressor-able InputStream that also knows how to rebuild uncompressed X Protocol frames from compressed ones.
CompressionSplittedOutputStream
An OutputStream wrapper that analyzes X Protocol frames and routes them directly to the original underlying OutputStream or passes them through to a compressor-able OutputStream to compresses the frame, rebuilds it and then sends a newly compressed X Protocol frame, depending on defined data size threshold.
CompressorStreamsFactory
Factory class for producing inflating and deflating-able InputStream and OutputStream instances for a selected compression algorithm.
ConfinedInputStream
An InputStream wrapper that limits the number of bytes that can be read form the underlying InputStream.
ConnectionFeatureNotAvailableException
Thrown when a client requests a connection-level feature that isn't available for this particular distribution of Connector/J (currently only used by code that is export-controlled).
ConnectionGroup  
ConnectionGroupManager  
ConnectionImpl
A Connection represents a session with a specific database.
ConnectionIsClosedException
Operation attempted on already closed Connection
ConnectionLifecycleInterceptor
Implementors of this interface can be installed via the "connectionLifecycleInterceptors" configuration property and receive events and alter behavior of "lifecycle" methods on our connection implementation.
ConnectionLifecycleInterceptorProvider  
ConnectionPropertiesTransform
Implement this interface, and pass the class name as the 'propertiesTransform' property in your URL, and the driver will pass the properties it has parsed to your transform implementation so that you can modify/substitute/add any that you desire.
ConnectionProvider
Implement this interface in order to handle physical connection creation process.
ConnectionUrl
A container for a database URL and a collection of given connection arguments.
ConnectionUrl.HostsCardinality
The rules describing the number of hosts a database URL may contain.
ConnectionUrl.Type
The database URL type which is determined by the scheme section of the connection string.
ConnectionUrlParser
This class parses a connection string using the general URI structure defined in RFC 3986.
ConnectionUrlParser.Pair<T,​U>
This class is a simple container for two elements.
ConnectionWrapper
This class serves as a wrapper for the connection object.
Constants
Represents various constants used in the driver.
ContinuousOutputStream
An OutputStream wrapper that can't be closed and flushes data instead when ContinuousOutputStream.close() is called.
CoreSession  
CreateIndexParams
Internally-used object passing index creation parameters to XMessageBuilder.
CreateIndexParams.IndexField
Internally used object parsed from indexDefinition; see Collection.createIndex(String, DbDoc) description.
DatabaseMetaData
JDBC Interface to Mysql functions
DatabaseMetaData.ProcedureType
Enumeration for Procedure Types
DatabaseMetaData.TableType
Enumeration for Table Types
DatabaseMetaDataUsingInfoSchema
DatabaseMetaData implementation that uses INFORMATION_SCHEMA
DatabaseMetaDataUsingInfoSchema.FunctionConstant  
DatabaseObject
A client-side representation of X Plugin server object, e.g.
DatabaseObject.DbObjectStatus
Existence states of database objects.
DatabaseObject.DbObjectType
Type of database objects.
DatabaseObjectDescription
Represents the item of XPLUGIN_STMT_LIST_OBJECTS operation result.
DatabaseUrlContainer
Implementors of this class must be able to provide a database URL.
DataConversionException
Indicates that data could not be converted according to the given request.
DataReadException
Indicates that data could not be read according to the given request.
DataStoreMetadata  
DataStoreMetadataImpl  
DataTruncationException  
DataTypeUtil
Utilities to manipulate internal data type formats.
DbDoc
The object representation of a JSON document.
DbDocFactory
Create DbDoc objects from internal row representation.
DbDocImpl
Represents a JSON object:
DbDocValueFactory
A ValueFactory implementation to create DbDocs.
DeadlockTimeoutRollbackMarker
Marker interface for exceptions that are caused by deadlock/wait timeout
DebugBufferingPacketReader
A decorating MessageReader which put debugging info to a ring-buffer.
DebugBufferingPacketSender  
DefaultColumnDefinition
Protocol::ColumnDefinition41 object
DefaultPropertySet  
DefaultValueFactory<T>
The default value factory provides a base class that can be used for value factories that do not support creation from every type.
DeleteStatement
A statement to delete rows from a table.
DeleteStatementImpl
DeleteStatement implementation.
DevApiSample  
DnsSrv  
DnsSrv.SrvRecord  
DocFilterParams
FilterParams implementation for Collection syntax.
DocResult
A sequence of documents retrieved from a find query.
DocResultBuilder
Result builder producing a DocResult instance.
DocResultImpl
A sequence of documents retrieved from a find query.
DoubleValueFactory
A value factory for creating double values.
Driver
The Java SQL framework allows for multiple database drivers.
Driver
Backwards compatibility to support apps that call Class.forName("com.mysql.jdbc.Driver");.
Driver
The Java SQL framework allows for multiple database drivers.
EnumProperty<T extends java.lang.Enum<T>>  
EnumPropertyDefinition<T extends java.lang.Enum<T>>  
ErrorMappingsDocGenerator
Creates XML file describing mapping of MySQL error #'s to SQL92 and X/Open states.
ErrorToFutureCompletionHandler<T>
Base class that propagates any error to the given future allowing only implementation of the success callback.
EscapeTokenizer
EscapeTokenizer breaks up an SQL statement into SQL and escape code parts.
ExceptionFactory  
ExceptionInterceptor  
ExceptionInterceptorChain  
ExpiringCache<K,​V>  
ExportControlled
Holds functionality that falls under export-control regulations.
ExportControlled.X509TrustManagerWrapper
Implementation of X509TrustManager wrapping JVM X509TrustManagers to add expiration and identity check
Expression
A wrapper for expression strings.
ExprParser
Expression parser for X protocol.
ExprUnparser
Serializer utility for dealing with X Protocol expression trees.
ExprUtil
Utilities to deal with Expr (and related) structures.
FailoverConnectionProxy
A proxy for a dynamic com.mysql.cj.jdbc.JdbcConnection implementation that provides failover features for list of hosts.
FailoverConnectionUrl  
FailoverDnsSrvConnectionUrl  
FeatureNotAvailableException  
FetchDoneEntity
ProtocolEntity representing a MysqlxResultset.FetchDone message.
FetchDoneEntityFactory
Factory producing FetchDoneEntity from protocol message.
FetchDoneMoreResults
ProtocolEntity representing a FetchDoneMoreResults message.
FetchDoneMoreResultsFactory
Factory producing FetchDoneMoreResults from protocol message.
FetchResult<T>
A set of elements from a query command.
Field
Field is a class used to describe fields in a ResultSet
FieldFactory
Factory producing Field from protocol message.
FilterableStatement<STMT_T,​RES_T>
Abstract class, common to several X DevAPI statement classes.
FilterParams
Transforms X DevAPI filter parameters into X Protocol message entities.
FilterParams.RowLock
The type of row lock.
FilterParams.RowLockOptions
Options that define the behavior while retrieving locked rows.
FindStatement
A statement to find the set of documents according to the given specification.
FindStatementImpl
FindStatement implementation.
FloatValueFactory
A value factory for creating float values.
FullReadInputStream
InputStream wrapper that provides methods to aggregate reads of a given size.
HostInfo
This class holds the following MySQL host information: host: an IP or host name.
HostsListView
An enumeration that identifies the type of the view intended for getting hosts lists for multi-host connections.
InsertParams
Helper class for collecting parameters for relational insert command.
InsertResult
A result from the table.insert() statement.
InsertResultBuilder
Result builder producing an InsertResult instance.
InsertResultImpl
A result from a statement that doesn't return a set of rows.
InsertStatement
A statement INSERTing new row(s) into a table.
InsertStatementImpl  
IntegerProperty  
IntegerPropertyDefinition  
IntegerValueFactory
A value factory for creating int values.
InternalDate  
InternalTime  
InternalTimestamp  
InvalidConnectionAttributeException  
IpAddressUtils  
IterateBlock<T>  
JdbcConnection
This interface contains methods that are considered the "vendor extension" to the JDBC API for MySQL's implementation of java.sql.Connection.
JdbcPreparedStatement  
JdbcPropertySet  
JdbcPropertySetImpl  
JdbcStatement
This interface contains methods that are considered the "vendor extension" to the JDBC API for MySQL's implementation of java.sql.Statement.
Jdk14Logger
Logging functionality for JDK1.4
JsonArray
Represents a JSON array.
JsonLiteral
Represents JSON true, false and null literals.
JsonNumber
Represents a JSON number.
JsonParser  
JsonString
Represents a JSON string.
JsonValue
Common interface for classes representing standard JSON object, array, number, string and 'true', 'false' and 'null' literals and non-standard extensions like mysqlx.expr() expressions.
LazyString
A lazy string that can take a byte buffer and encoding and interpret it as a string if/when requested.
LicenseConfiguration
Used in commercially-licensed clients that require connections to commercially-licensed servers as part of the licensing terms.
LoadBalanceConnectionGroupManager  
LoadBalanceConnectionGroupManagerMBean  
LoadBalanceConnectionUrl  
LoadBalancedAutoCommitInterceptor  
LoadBalancedConnection  
LoadBalancedConnectionProxy
A proxy for a dynamic com.mysql.cj.jdbc.JdbcConnection implementation that load balances requests across a series of MySQL JDBC connections, where the balancing takes place at transaction commit.
LoadBalancedMySQLConnection  
LoadBalanceDnsSrvConnectionUrl  
LoadBalanceExceptionChecker  
LocalDateTimeValueFactory
Value factory to create LocalDateTime instances.
LocalDateValueFactory
A value factory for creating LocalDate values.
LocalTimeValueFactory
A value factory to create LocalTime instances.
Log
Unified interface to logging facilities on different platforms
LogFactory
Creates instances of loggers for the driver to use.
LoggingProfilerEventHandler
A profile event handler that just logs to the standard logging mechanism of the driver.
LogUtils  
LongProperty  
LongPropertyDefinition  
LongValueFactory
A value factory for creating long values.
LRUCache<K,​V>  
MemorySizeProperty  
MemorySizePropertyDefinition  
MergingColumnDefinitionFactory  
Message
Message is the content of a full single message (native protocol packet or protobuf message), independent from on-wire splitting, communicated with the server.
MessageBuilder<M extends Message>  
MessageConstants
Constants related to X Protocol messages.
MessageHeader
Represents the protocol specific message header
MessageListener<M extends Message>
Sink for messages that are read asynchonously from the socket.
MessageReader<H extends MessageHeader,​M extends Message>  
Messages
Support for localized messages.
MessageSender<M extends Message>
This interface provides a facility for sending messages to server.
MiniAdmin
Utility functions for admin functionality from Java.
ModifyStatement
A statement representing a set of document modifications.
ModifyStatementImpl
ModifyStatement implementation.
MultiHostConnectionProxy
An abstract class that processes generic multi-host configurations.
MultiHostMySQLConnection
Each instance of MultiHostMySQLConnection is coupled with a MultiHostConnectionProxy instance.
MultiPacketReader
A MessageReader which reads a full packet built from sequence of it's on-wire parts.
MysqlBinaryValueDecoder
A ValueDecoder for the MySQL binary (prepared statement) protocol.
MysqlClearPasswordPlugin
MySQL Clear Password Authentication Plugin
MysqlConnection  
MysqlConnectionPoolDataSource
This class is used to obtain a physical connection and instantiate and return a MysqlPooledConnection.
MysqlConnectionTester
ConnectionTester for C3P0 connection pool that uses the more efficient COM_PING method of testing connection 'liveness' for MySQL, and 'sorts' exceptions based on SQLState or class of 'CommunicationsException' for handling exceptions.
MysqlDataSource
A JNDI DataSource for a Mysql JDBC connection
MysqlDataSourceFactory
Factory class for MysqlDataSource objects
MysqlDataTruncation
MySQL wrapper for DataTruncation until the server can support sending all needed information.
MysqlErrorNumbers
Constants representing MySQL error numbers returned by the server in error messages.
MysqlNativePasswordPlugin
MySQL Native Password Authentication Plugin
MysqlOldPasswordPlugin
MySQL Native Old-Password Authentication Plugin
MysqlParameterMetadata  
MysqlPooledConnection
This class is used to wrap and return a physical connection within a logical handle.
MySQLQueryInterruptedException  
MysqlSavepoint
Represents SQL SAVEPOINTS in MySQL.
MysqlSQLXML  
MySQLStatementCancelledException  
MysqlTextValueDecoder
Implementation of ValueDecoder for the MySQL text protocol.
MySQLTimeoutException  
MySQLTransactionRollbackException  
MysqlType  
Mysqlx  
Mysqlx.ClientMessages
IDs of messages that can be sent from client to the server ..
Mysqlx.ClientMessages.Builder
IDs of messages that can be sent from client to the server ..
Mysqlx.ClientMessages.Type
Protobuf enum Mysqlx.ClientMessages.Type
Mysqlx.ClientMessagesOrBuilder  
Mysqlx.Error
generic Error message A ``severity`` of ``ERROR`` indicates the current message sequence is aborted for the given error and the session is ready for more.
Mysqlx.Error.Builder
generic Error message A ``severity`` of ``ERROR`` indicates the current message sequence is aborted for the given error and the session is ready for more.
Mysqlx.Error.Severity
Protobuf enum Mysqlx.Error.Severity
Mysqlx.ErrorOrBuilder  
Mysqlx.Ok
generic Ok message
Mysqlx.Ok.Builder
generic Ok message
Mysqlx.OkOrBuilder  
Mysqlx.ServerMessages
IDs of messages that can be sent from server to client ..
Mysqlx.ServerMessages.Builder
IDs of messages that can be sent from server to client ..
Mysqlx.ServerMessages.Type
Protobuf enum Mysqlx.ServerMessages.Type
Mysqlx.ServerMessagesOrBuilder  
MysqlXAConnection  
MysqlXADataSource  
MysqlxConnection  
MysqlxConnection.Capabilities
Capabilities
MysqlxConnection.Capabilities.Builder
Capabilities
MysqlxConnection.CapabilitiesGet
get supported connection capabilities and their current state :returns: :protobuf:msg:`Mysqlx.Connection::Capabilities` or :protobuf:msg:`Mysqlx::Error`
MysqlxConnection.CapabilitiesGet.Builder
get supported connection capabilities and their current state :returns: :protobuf:msg:`Mysqlx.Connection::Capabilities` or :protobuf:msg:`Mysqlx::Error`
MysqlxConnection.CapabilitiesGetOrBuilder  
MysqlxConnection.CapabilitiesOrBuilder  
MysqlxConnection.CapabilitiesSet
sets connection capabilities atomically only provided values are changed, other values are left unchanged.
MysqlxConnection.CapabilitiesSet.Builder
sets connection capabilities atomically only provided values are changed, other values are left unchanged.
MysqlxConnection.CapabilitiesSetOrBuilder  
MysqlxConnection.Capability
a Capability a tuple of a ``name`` and a :protobuf:msg:`Mysqlx.Datatypes::Any`
MysqlxConnection.Capability.Builder
a Capability a tuple of a ``name`` and a :protobuf:msg:`Mysqlx.Datatypes::Any`
MysqlxConnection.CapabilityOrBuilder  
MysqlxConnection.Close
announce to the server that the client wants to close the connection it discards any session state of the server :Returns: :protobuf:msg:`Mysqlx::Ok`
MysqlxConnection.Close.Builder
announce to the server that the client wants to close the connection it discards any session state of the server :Returns: :protobuf:msg:`Mysqlx::Ok`
MysqlxConnection.CloseOrBuilder  
MysqlxConnection.Compression
Protobuf type Mysqlx.Connection.Compression
MysqlxConnection.Compression.Builder
Protobuf type Mysqlx.Connection.Compression
MysqlxConnection.CompressionOrBuilder  
MysqlxCrud  
MysqlxCrud.Collection
collection
MysqlxCrud.Collection.Builder
collection
MysqlxCrud.CollectionOrBuilder  
MysqlxCrud.Column
column definition
MysqlxCrud.Column.Builder
column definition
MysqlxCrud.ColumnOrBuilder  
MysqlxCrud.CreateView
Protobuf type Mysqlx.Crud.CreateView
MysqlxCrud.CreateView.Builder
Protobuf type Mysqlx.Crud.CreateView
MysqlxCrud.CreateViewOrBuilder  
MysqlxCrud.DataModel
DataModel to use for filters, names, ...
MysqlxCrud.Delete
Delete documents/rows from a Collection/Table :param collection: collection to change :param data_model: datamodel that the operations refer to :param criteria: filter expression to match rows that the operations will apply on :param args: values for parameters used in filter expression :param limit: limits the number of rows to match (user can set one of: limit, limit_expr) :param order: specifies order of matched rows :param limit_expr: limits the number of rows to match (user can set one of: limit, limit_expr) :Returns: :protobuf:msg:`Mysqlx.Resultset::`
MysqlxCrud.Delete.Builder
Delete documents/rows from a Collection/Table :param collection: collection to change :param data_model: datamodel that the operations refer to :param criteria: filter expression to match rows that the operations will apply on :param args: values for parameters used in filter expression :param limit: limits the number of rows to match (user can set one of: limit, limit_expr) :param order: specifies order of matched rows :param limit_expr: limits the number of rows to match (user can set one of: limit, limit_expr) :Returns: :protobuf:msg:`Mysqlx.Resultset::`
MysqlxCrud.DeleteOrBuilder  
MysqlxCrud.DropView
Protobuf type Mysqlx.Crud.DropView
MysqlxCrud.DropView.Builder
Protobuf type Mysqlx.Crud.DropView
MysqlxCrud.DropViewOrBuilder  
MysqlxCrud.Find
Find Documents/Rows in a Collection/Table ..
MysqlxCrud.Find.Builder
Find Documents/Rows in a Collection/Table ..
MysqlxCrud.Find.RowLock
Protobuf enum Mysqlx.Crud.Find.RowLock
MysqlxCrud.Find.RowLockOptions
Protobuf enum Mysqlx.Crud.Find.RowLockOptions
MysqlxCrud.FindOrBuilder  
MysqlxCrud.Insert
Insert documents/rows into a collection/table :param collection: collection to insert into :param data_model: datamodel that the operations refer to :param projection: name of the columns to insert data into (empty if data_model is DOCUMENT) :param row: set of rows to insert into the collection/table (a single expression with a JSON document literal or an OBJECT expression) :param args: values for parameters used in row expressions :param upsert: true if this should be treated as an Upsert (that is, update on duplicate key) :Returns: :protobuf:msg:`Mysqlx.Resultset::`
MysqlxCrud.Insert.Builder
Insert documents/rows into a collection/table :param collection: collection to insert into :param data_model: datamodel that the operations refer to :param projection: name of the columns to insert data into (empty if data_model is DOCUMENT) :param row: set of rows to insert into the collection/table (a single expression with a JSON document literal or an OBJECT expression) :param args: values for parameters used in row expressions :param upsert: true if this should be treated as an Upsert (that is, update on duplicate key) :Returns: :protobuf:msg:`Mysqlx.Resultset::`
MysqlxCrud.Insert.TypedRow
Protobuf type Mysqlx.Crud.Insert.TypedRow
MysqlxCrud.Insert.TypedRow.Builder
Protobuf type Mysqlx.Crud.Insert.TypedRow
MysqlxCrud.Insert.TypedRowOrBuilder  
MysqlxCrud.InsertOrBuilder  
MysqlxCrud.Limit
limit :param row_count: maximum rows to filter :param offset: maximum rows to skip before applying the row_count
MysqlxCrud.Limit.Builder
limit :param row_count: maximum rows to filter :param offset: maximum rows to skip before applying the row_count
MysqlxCrud.LimitExpr
limit expression LimitExpr in comparison to Limit, is able to specify that row_count and offset are placeholders.
MysqlxCrud.LimitExpr.Builder
limit expression LimitExpr in comparison to Limit, is able to specify that row_count and offset are placeholders.
MysqlxCrud.LimitExprOrBuilder  
MysqlxCrud.LimitOrBuilder  
MysqlxCrud.ModifyView
Protobuf type Mysqlx.Crud.ModifyView
MysqlxCrud.ModifyView.Builder
Protobuf type Mysqlx.Crud.ModifyView
MysqlxCrud.ModifyViewOrBuilder  
MysqlxCrud.Order
sort order
MysqlxCrud.Order.Builder
sort order
MysqlxCrud.Order.Direction
Protobuf enum Mysqlx.Crud.Order.Direction
MysqlxCrud.OrderOrBuilder  
MysqlxCrud.Projection
a projection :param source: the expression identifying an element from the source data which can include a column identifier or any expression :param alias: optional alias.
MysqlxCrud.Projection.Builder
a projection :param source: the expression identifying an element from the source data which can include a column identifier or any expression :param alias: optional alias.
MysqlxCrud.ProjectionOrBuilder  
MysqlxCrud.Update
Update documents/rows in a collection/table :param collection: collection to change :param data_model: datamodel that the operations refer to :param criteria: filter expression to match rows that the operations will apply on :param args: values for parameters used in filter expression :param limit: limits the number of rows to match (user can set one of: limit, limit_expr) :param order: specifies order of matched rows :param operation: list of operations to be applied.
MysqlxCrud.Update.Builder
Update documents/rows in a collection/table :param collection: collection to change :param data_model: datamodel that the operations refer to :param criteria: filter expression to match rows that the operations will apply on :param args: values for parameters used in filter expression :param limit: limits the number of rows to match (user can set one of: limit, limit_expr) :param order: specifies order of matched rows :param operation: list of operations to be applied.
MysqlxCrud.UpdateOperation
update operations :param source: specification of the value to be updated if data_model is TABLE, a column name may be specified and also a document path, if the column has type JSON if data_model is DOCUMENT, only document paths are allowed in both cases, schema and table must be not set :param operation: the type of operation to be performed :param value: an expression to be computed as the new value for the operation
MysqlxCrud.UpdateOperation.Builder
update operations :param source: specification of the value to be updated if data_model is TABLE, a column name may be specified and also a document path, if the column has type JSON if data_model is DOCUMENT, only document paths are allowed in both cases, schema and table must be not set :param operation: the type of operation to be performed :param value: an expression to be computed as the new value for the operation
MysqlxCrud.UpdateOperation.UpdateType
Protobuf enum Mysqlx.Crud.UpdateOperation.UpdateType
MysqlxCrud.UpdateOperationOrBuilder  
MysqlxCrud.UpdateOrBuilder  
MysqlxCrud.ViewAlgorithm
ViewAlgorithm defines how MySQL Server processes the view
MysqlxCrud.ViewCheckOption
ViewCheckOption limits the write operations done on a `VIEW` (`INSERT`, `UPDATE`, `DELETE`) to rows in which the `WHERE` clause is `TRUE`
MysqlxCrud.ViewSqlSecurity
ViewSqlSecurity defines the security context in which the view is going to be executed, this means that VIEW can be executed with current user permissions or with permissions of the uses who defined the VIEW
MysqlxCursor  
MysqlxCursor.Close
Close cursor ..
MysqlxCursor.Close.Builder
Close cursor ..
MysqlxCursor.CloseOrBuilder  
MysqlxCursor.Fetch
Fetch next portion of data from a cursor ..
MysqlxCursor.Fetch.Builder
Fetch next portion of data from a cursor ..
MysqlxCursor.FetchOrBuilder  
MysqlxCursor.Open
Open a cursor ..
MysqlxCursor.Open.Builder
Open a cursor ..
MysqlxCursor.Open.OneOfMessage
Protobuf type Mysqlx.Cursor.Open.OneOfMessage
MysqlxCursor.Open.OneOfMessage.Builder
Protobuf type Mysqlx.Cursor.Open.OneOfMessage
MysqlxCursor.Open.OneOfMessage.Type
Protobuf enum Mysqlx.Cursor.Open.OneOfMessage.Type
MysqlxCursor.Open.OneOfMessageOrBuilder  
MysqlxCursor.OpenOrBuilder  
MysqlxDatatypes  
MysqlxDatatypes.Any
a helper to allow all field types
MysqlxDatatypes.Any.Builder
a helper to allow all field types
MysqlxDatatypes.Any.Type
Protobuf enum Mysqlx.Datatypes.Any.Type
MysqlxDatatypes.AnyOrBuilder  
MysqlxDatatypes.Array
a Array
MysqlxDatatypes.Array.Builder
a Array
MysqlxDatatypes.ArrayOrBuilder  
MysqlxDatatypes.Object
a object
MysqlxDatatypes.Object.Builder
a object
MysqlxDatatypes.Object.ObjectField
Protobuf type Mysqlx.Datatypes.Object.ObjectField
MysqlxDatatypes.Object.ObjectField.Builder
Protobuf type Mysqlx.Datatypes.Object.ObjectField
MysqlxDatatypes.Object.ObjectFieldOrBuilder  
MysqlxDatatypes.ObjectOrBuilder  
MysqlxDatatypes.Scalar
a scalar
MysqlxDatatypes.Scalar.Builder
a scalar
MysqlxDatatypes.Scalar.Octets
an opaque octet sequence, with an optional content_type See ``Mysqlx.Resultset.ContentType_BYTES`` for list of known values.
MysqlxDatatypes.Scalar.Octets.Builder
an opaque octet sequence, with an optional content_type See ``Mysqlx.Resultset.ContentType_BYTES`` for list of known values.
MysqlxDatatypes.Scalar.OctetsOrBuilder  
MysqlxDatatypes.Scalar.String
a string with a charset/collation
MysqlxDatatypes.Scalar.String.Builder
a string with a charset/collation
MysqlxDatatypes.Scalar.StringOrBuilder  
MysqlxDatatypes.Scalar.Type
Protobuf enum Mysqlx.Datatypes.Scalar.Type
MysqlxDatatypes.ScalarOrBuilder  
MysqlxExpect  
MysqlxExpect.Close
close a Expect block closing a Expect block restores the state of the previous Expect block for the following messages :returns: :protobuf:msg:`Mysqlx::Ok` on success, :protobuf:msg:`Mysqlx::Error` on error
MysqlxExpect.Close.Builder
close a Expect block closing a Expect block restores the state of the previous Expect block for the following messages :returns: :protobuf:msg:`Mysqlx::Ok` on success, :protobuf:msg:`Mysqlx::Error` on error
MysqlxExpect.CloseOrBuilder  
MysqlxExpect.Open
open an Expect block and set/unset the conditions that have to be fulfilled if any of the conditions fail, all enclosed messages will fail with a Mysqlx.Error message.
MysqlxExpect.Open.Builder
open an Expect block and set/unset the conditions that have to be fulfilled if any of the conditions fail, all enclosed messages will fail with a Mysqlx.Error message.
MysqlxExpect.Open.Condition
Protobuf type Mysqlx.Expect.Open.Condition
MysqlxExpect.Open.Condition.Builder
Protobuf type Mysqlx.Expect.Open.Condition
MysqlxExpect.Open.Condition.ConditionOperation
Protobuf enum Mysqlx.Expect.Open.Condition.ConditionOperation
MysqlxExpect.Open.Condition.Key
Protobuf enum Mysqlx.Expect.Open.Condition.Key
MysqlxExpect.Open.ConditionOrBuilder  
MysqlxExpect.Open.CtxOperation
Protobuf enum Mysqlx.Expect.Open.CtxOperation
MysqlxExpect.OpenOrBuilder  
MysqlxExpr  
MysqlxExpr.Array
a Array of expressions
MysqlxExpr.Array.Builder
a Array of expressions
MysqlxExpr.ArrayOrBuilder  
MysqlxExpr.ColumnIdentifier
col_identifier (table): col@doc_path, tbl.col@doc_path col, tbl.col, schema.tbl.col col_identifier (document): doc_path ..
MysqlxExpr.ColumnIdentifier.Builder
col_identifier (table): col@doc_path, tbl.col@doc_path col, tbl.col, schema.tbl.col col_identifier (document): doc_path ..
MysqlxExpr.ColumnIdentifierOrBuilder  
MysqlxExpr.DocumentPathItem
DocumentPathItem ..
MysqlxExpr.DocumentPathItem.Builder
DocumentPathItem ..
MysqlxExpr.DocumentPathItem.Type
Protobuf enum Mysqlx.Expr.DocumentPathItem.Type
MysqlxExpr.DocumentPathItemOrBuilder  
MysqlxExpr.Expr
Expressions the "root" of the expression tree ..
MysqlxExpr.Expr.Builder
Expressions the "root" of the expression tree ..
MysqlxExpr.Expr.Type
Protobuf enum Mysqlx.Expr.Expr.Type
MysqlxExpr.ExprOrBuilder  
MysqlxExpr.FunctionCall
function call: ``func(a, b, "1", 3)`` ..
MysqlxExpr.FunctionCall.Builder
function call: ``func(a, b, "1", 3)`` ..
MysqlxExpr.FunctionCallOrBuilder  
MysqlxExpr.Identifier
identifier: name, schame.name ..
MysqlxExpr.Identifier.Builder
identifier: name, schame.name ..
MysqlxExpr.IdentifierOrBuilder  
MysqlxExpr.Object
an object (with expression values)
MysqlxExpr.Object.Builder
an object (with expression values)
MysqlxExpr.Object.ObjectField
Protobuf type Mysqlx.Expr.Object.ObjectField
MysqlxExpr.Object.ObjectField.Builder
Protobuf type Mysqlx.Expr.Object.ObjectField
MysqlxExpr.Object.ObjectFieldOrBuilder  
MysqlxExpr.ObjectOrBuilder  
MysqlxExpr.Operator
operator: ``<<(a, b)`` ..
MysqlxExpr.Operator.Builder
operator: ``<<(a, b)`` ..
MysqlxExpr.OperatorOrBuilder  
MysqlXid
Implementation of the XID interface for MySQL XA
MysqlxNotice  
MysqlxNotice.Frame
Common Frame for all Notices ===================================================== ===== .type value ===================================================== ===== :protobuf:msg:`Mysqlx.Notice::Warning` 1 :protobuf:msg:`Mysqlx.Notice::SessionVariableChanged` 2 :protobuf:msg:`Mysqlx.Notice::SessionStateChanged` 3 ===================================================== ===== :param type: the type of the payload :param payload: the payload of the notification :param scope: global or local notification
MysqlxNotice.Frame.Builder
Common Frame for all Notices ===================================================== ===== .type value ===================================================== ===== :protobuf:msg:`Mysqlx.Notice::Warning` 1 :protobuf:msg:`Mysqlx.Notice::SessionVariableChanged` 2 :protobuf:msg:`Mysqlx.Notice::SessionStateChanged` 3 ===================================================== ===== :param type: the type of the payload :param payload: the payload of the notification :param scope: global or local notification
MysqlxNotice.Frame.Scope
Protobuf enum Mysqlx.Notice.Frame.Scope
MysqlxNotice.Frame.Type
Protobuf enum Mysqlx.Notice.Frame.Type
MysqlxNotice.FrameOrBuilder  
MysqlxNotice.GroupReplicationStateChanged
Notify clients about group replication state changes ========================================== ========== :protobuf:msg:`Mysqlx.Notice::Frame` field value ========================================== ========== ``.type`` 4 ``.scope`` ``global`` ========================================== ========== :param type: type of group replication event :param view_id: view identifier
MysqlxNotice.GroupReplicationStateChanged.Builder
Notify clients about group replication state changes ========================================== ========== :protobuf:msg:`Mysqlx.Notice::Frame` field value ========================================== ========== ``.type`` 4 ``.scope`` ``global`` ========================================== ========== :param type: type of group replication event :param view_id: view identifier
MysqlxNotice.GroupReplicationStateChanged.Type
Protobuf enum Mysqlx.Notice.GroupReplicationStateChanged.Type
MysqlxNotice.GroupReplicationStateChangedOrBuilder  
MysqlxNotice.ServerHello
Notify clients about connection to X Protocol server ========================================== ========== :protobuf:msg:`Mysqlx.Notice::Frame` field value ========================================== ========== ``.type`` 5 ``.scope`` ``global`` ========================================== ==========
MysqlxNotice.ServerHello.Builder
Notify clients about connection to X Protocol server ========================================== ========== :protobuf:msg:`Mysqlx.Notice::Frame` field value ========================================== ========== ``.type`` 5 ``.scope`` ``global`` ========================================== ==========
MysqlxNotice.ServerHelloOrBuilder  
MysqlxNotice.SessionStateChanged
Notify clients about changes to the internal session state ========================================== ========= :protobuf:msg:`Mysqlx.Notice::Frame` field value ========================================== ========= ``.type`` 3 ``.scope`` ``local`` ========================================== ========= :param param: parameter key :param value: updated value
MysqlxNotice.SessionStateChanged.Builder
Notify clients about changes to the internal session state ========================================== ========= :protobuf:msg:`Mysqlx.Notice::Frame` field value ========================================== ========= ``.type`` 3 ``.scope`` ``local`` ========================================== ========= :param param: parameter key :param value: updated value
MysqlxNotice.SessionStateChanged.Parameter
Protobuf enum Mysqlx.Notice.SessionStateChanged.Parameter
MysqlxNotice.SessionStateChangedOrBuilder  
MysqlxNotice.SessionVariableChanged
Notify clients about changes to the current session variables Every change to a variable that is accessible through: ..
MysqlxNotice.SessionVariableChanged.Builder
Notify clients about changes to the current session variables Every change to a variable that is accessible through: ..
MysqlxNotice.SessionVariableChangedOrBuilder  
MysqlxNotice.Warning
Server-side warnings and notes ``.scope`` == ``local`` ``.level``, ``.code`` and ``.msg`` map the content of ..
MysqlxNotice.Warning.Builder
Server-side warnings and notes ``.scope`` == ``local`` ``.level``, ``.code`` and ``.msg`` map the content of ..
MysqlxNotice.Warning.Level
Protobuf enum Mysqlx.Notice.Warning.Level
MysqlxNotice.WarningOrBuilder  
MysqlxPrepare  
MysqlxPrepare.Deallocate
Deallocate already prepared statement Deallocating the statement.
MysqlxPrepare.Deallocate.Builder
Deallocate already prepared statement Deallocating the statement.
MysqlxPrepare.DeallocateOrBuilder  
MysqlxPrepare.Execute
Execute already prepared statement ..
MysqlxPrepare.Execute.Builder
Execute already prepared statement ..
MysqlxPrepare.ExecuteOrBuilder  
MysqlxPrepare.Prepare
Prepare a new statement ..
MysqlxPrepare.Prepare.Builder
Prepare a new statement ..
MysqlxPrepare.Prepare.OneOfMessage
Protobuf type Mysqlx.Prepare.Prepare.OneOfMessage
MysqlxPrepare.Prepare.OneOfMessage.Builder
Protobuf type Mysqlx.Prepare.Prepare.OneOfMessage
MysqlxPrepare.Prepare.OneOfMessage.Type
Determine which of optional fields was set by the client (Workaround for missing "oneof" keyword in pb2.5)
MysqlxPrepare.Prepare.OneOfMessageOrBuilder  
MysqlxPrepare.PrepareOrBuilder  
MysqlxResultset  
MysqlxResultset.ColumnMetaData
meta data of a Column ..
MysqlxResultset.ColumnMetaData.Builder
meta data of a Column ..
MysqlxResultset.ColumnMetaData.FieldType
Protobuf enum Mysqlx.Resultset.ColumnMetaData.FieldType
MysqlxResultset.ColumnMetaDataOrBuilder  
MysqlxResultset.ContentType_BYTES
a hint about the higher-level encoding of a BYTES field ====== ====== =========== type value description ====== ====== =========== BYTES 0x0001 GEOMETRY (WKB encoding) BYTES 0x0002 JSON (text encoding) BYTES 0x0003 XML (text encoding) ====== ====== =========== ..
MysqlxResultset.ContentType_DATETIME
a hint about the higher-level encoding of a DATETIME field ====== ====== =========== type value description ======== ====== =========== DATE 0x0001 DATETIME contains only date part DATETIME 0x0002 DATETIME contains both date and time parts ====== ====== ===========
MysqlxResultset.FetchDone
all resultsets are finished
MysqlxResultset.FetchDone.Builder
all resultsets are finished
MysqlxResultset.FetchDoneMoreOutParams
resultsets are finished, OUT paramset is next
MysqlxResultset.FetchDoneMoreOutParams.Builder
resultsets are finished, OUT paramset is next
MysqlxResultset.FetchDoneMoreOutParamsOrBuilder  
MysqlxResultset.FetchDoneMoreResultsets
resultset and out-params are finished, but more resultsets available
MysqlxResultset.FetchDoneMoreResultsets.Builder
resultset and out-params are finished, but more resultsets available
MysqlxResultset.FetchDoneMoreResultsetsOrBuilder  
MysqlxResultset.FetchDoneOrBuilder  
MysqlxResultset.FetchSuspended
cursor is opened still the execution of PrepFetch or PrepExecute ended
MysqlxResultset.FetchSuspended.Builder
cursor is opened still the execution of PrepFetch or PrepExecute ended
MysqlxResultset.FetchSuspendedOrBuilder  
MysqlxResultset.Row
Row in a Resultset a row is represented as a list of fields encoded as byte blobs.
MysqlxResultset.Row.Builder
Row in a Resultset a row is represented as a list of fields encoded as byte blobs.
MysqlxResultset.RowOrBuilder  
MysqlxSession  
MysqlxSession  
MysqlxSession.AuthenticateContinue
send by client or server after a :protobuf:msg:`Mysqlx.Session::AuthenticateStart` to exchange more auth data :param auth_data: authentication data :Returns: :protobuf:msg:`Mysqlx.Session::AuthenticateContinue`
MysqlxSession.AuthenticateContinue.Builder
send by client or server after a :protobuf:msg:`Mysqlx.Session::AuthenticateStart` to exchange more auth data :param auth_data: authentication data :Returns: :protobuf:msg:`Mysqlx.Session::AuthenticateContinue`
MysqlxSession.AuthenticateContinueOrBuilder  
MysqlxSession.AuthenticateOk
sent by the server after successful authentication :param auth_data: authentication data
MysqlxSession.AuthenticateOk.Builder
sent by the server after successful authentication :param auth_data: authentication data
MysqlxSession.AuthenticateOkOrBuilder  
MysqlxSession.AuthenticateStart
the initial message send from the client to the server to start the authentication proccess :param mech_name: authentication mechanism name :param auth_data: authentication data :param initial_response: initial response :Returns: :protobuf:msg:`Mysqlx.Session::AuthenticateContinue`
MysqlxSession.AuthenticateStart.Builder
the initial message send from the client to the server to start the authentication proccess :param mech_name: authentication mechanism name :param auth_data: authentication data :param initial_response: initial response :Returns: :protobuf:msg:`Mysqlx.Session::AuthenticateContinue`
MysqlxSession.AuthenticateStartOrBuilder  
MysqlxSession.Close
close the current session :Returns: :protobuf:msg:`Mysqlx::Ok`
MysqlxSession.Close.Builder
close the current session :Returns: :protobuf:msg:`Mysqlx::Ok`
MysqlxSession.CloseOrBuilder  
MysqlxSession.Reset
reset the current session param keep_open: if is true the session will be reset, but stays authenticated.
MysqlxSession.Reset.Builder
reset the current session param keep_open: if is true the session will be reset, but stays authenticated.
MysqlxSession.ResetOrBuilder  
MysqlxSql  
MysqlxSql.StmtExecute
execute a statement in the given namespace ..
MysqlxSql.StmtExecute.Builder
execute a statement in the given namespace ..
MysqlxSql.StmtExecuteOk
statement executed successful
MysqlxSql.StmtExecuteOk.Builder
statement executed successful
MysqlxSql.StmtExecuteOkOrBuilder  
MysqlxSql.StmtExecuteOrBuilder  
NamedPipeSocketFactory
A socket factory for named pipes (on Windows)
NativeAuthenticationProvider  
NativeCapabilities  
NativeConstants
Constants specific to legacy MySQL protocol
NativeConstants.IntegerDataType
Basic protocol data types as they are defined in http://dev.mysql.com/doc/internals/en/integer.html
NativeConstants.StringLengthDataType
Basic protocol data types as they are defined in http://dev.mysql.com/doc/internals/en/string.html which require explicit length specification.
NativeConstants.StringSelfDataType
Basic self-describing protocol data types as they are defined in http://dev.mysql.com/doc/internals/en/string.html
NativeMessageBuilder  
NativePacketHeader
Represents the legacy protocol packet header, consisting of 3-bytes payload_length and 1-byte sequence_id.
NativePacketPayload
PacketPayload is the content of a full single packet (independent from on-wire splitting) communicated with the server.
NativeProtocol  
NativeResultset  
NativeServerSession  
NativeSession  
NativeSocketConnection  
NativeUtils
Utilities to manipulate MySQL protocol-specific formats.
NClob
Simplistic implementation of java.sql.NClob for MySQL Connector/J
NdbLoadBalanceExceptionChecker  
NetworkResources  
NonRegisteringDriver
The Java SQL framework allows for multiple database drivers.
NoSubInterceptorWrapper
Wraps query interceptors during driver startup so that they don't produce different result sets than we expect.
Notice
ProtocolEntity representing a Notice message.
Notice.XSessionStateChanged  
Notice.XSessionVariableChanged  
Notice.XWarning  
NoticeFactory
Factory producing Notice from protocol message.
NotUpdatable
Thrown when a result sate is not updatable.
NullLogger
A logger that does nothing.
NumberOutOfRange
Indicates that a number was out of the expected range.
OffsetDateTimeValueFactory
Value factory to create OffsetDateTime instances.
OffsetTimeValueFactory
A value factory to create OffsetTime instances.
Ok
ProtocolEntity representing an OK message.
OkBuilder
Result builder producing an Ok instance.
OkFactory
Factory producing Ok from protocol message.
OkPacket  
OperationCancelledException  
OperationNotSupportedException  
OutputStreamWatcher
Objects that want to be notified of lifecycle events on a WatchableOutputStream should implement this interface, and register themselves with setWatcher() on the WatchableOutputStream instance.
PacketReceivedTimeHolder
Holds the time the last packet was received.
PacketSentTimeHolder
Holds the time the last packet was sent.
PacketSplitter
Keep track of splitting a large packet into multi-packets segments.
PacketTooBigException
Thrown when a packet that is too big for the server is created.
ParameterBindings
Interface to allow PreparedStatement implementations to expose their parameter bindings to QueryInterceptors.
ParameterBindingsImpl  
ParseInfo
Represents the "parsed" state of a prepared query, with the statement broken up into its static and dynamic (where parameters are bound) parts.
PasswordExpiredException
Equivalent to SQLSTATE ER_MUST_CHANGE_PASSWORD = 1820 "You must SET PASSWORD before executing this statement" Server entered to sandbox morde when this failure happens.
PerConnectionLRUFactory  
PerVmServerConfigCacheFactory  
PingTarget  
PreparableStatement<RES_T>
Abstract class, common to all X DevAPI statement classes that can be prepared.
PreparableStatement.PreparableStatementFinalizer
PhantomReference to track prepared statement ids.
PreparableStatement.PreparedState  
PreparedQuery<T extends QueryBindings<?>>  
PreparedStatementWrapper
Wraps prepared statements so that errors can be reported correctly to ConnectionEventListeners.
ProfilerEvent  
ProfilerEventHandler  
ProfilerEventImpl  
PropertiesDocGenerator
Creates docbook table of connection properties from ConnectionProperties class.
PropertyDefinition<T>  
PropertyDefinitions  
PropertyDefinitions.AuthMech  
PropertyDefinitions.Compression  
PropertyDefinitions.DatabaseTerm  
PropertyDefinitions.SslMode  
PropertyDefinitions.XdevapiSslMode  
PropertyDefinitions.ZeroDatetimeBehavior  
PropertyKey
PropertyKey handles connection property names, their camel-case aliases and case sensitivity.
PropertyNotModifiableException  
PropertySet  
Protocol<M extends Message>
A protocol provides the facilities to communicate with a MySQL server.
ProtocolEntity  
ProtocolEntityFactory<T,​M extends Message>  
ProtocolEntityReader<T extends ProtocolEntity,​M extends Message>  
Query  
Query.CancelStatus  
QueryBindings<T extends BindValue>  
QueryInterceptor
Implement this interface to be placed "in between" query execution, so that you can influence it.
QueryResult  
RandomBalanceStrategy  
ReadAheadInputStream
A non-blocking buffered input stream.
ReaderFailoverHandler
Interface for Reader Failover Process handler.
ReaderFailoverResult
This class holds results of Reader Failover Process.
RemoveStatement
A statement requesting to remove a set of documents.
RemoveStatementImpl
RemoveStatement implementation.
ReplicationConnection  
ReplicationConnectionGroup
Group of connection objects which can be configured as a group.
ReplicationConnectionGroupManager  
ReplicationConnectionProxy
Connection that opens two connections, one two a replication source, and another to one or more replicas, and decides to use source when the connection is not read-only, and use replica(s) when the connection is read-only.
ReplicationConnectionUrl  
ReplicationDnsSrvConnectionUrl  
ReplicationGroupManager  
ReplicationGroupManagerMBean  
ReplicationMySQLConnection  
Result
Base result.
ResultBuilder<T>
Classes implementing this interface are responsible for building result of specific type from incoming ProtocolEntity objects.
ResultMessageListener<R>
A MessageListener to handle result data and propagate it to a ResultBuilder.
Resultset
Represents protocol specific result set, eg., for native protocol, a ProtocolText::Resultset or ProtocolBinary::Resultset entity.
Resultset.Concurrency  
Resultset.Type  
ResultsetFactory  
ResultSetFactory  
ResultSetImpl  
ResultSetInternalMethods
This interface is intended to be used by implementors of statement interceptors so that implementors can create static or dynamic (via java.lang.reflect.Proxy) proxy instances of ResultSets.
ResultSetMetaData
A ResultSetMetaData object can be used to find out about the types and properties of the columns in a ResultSet
ResultsetRow
Classes that implement this interface represent one row of data from the MySQL server that might be stored in different ways depending on whether the result set was streaming (so they wrap a reusable packet), or whether the result set was cached or via a server-side cursor (so they represent a byte[][]).
ResultsetRowReader  
ResultsetRows
This interface abstracts away how row data is accessed by the result set.
ResultsetRowsCursor
Model for result set data backed by a cursor (see http://dev.mysql.com/doc/refman/5.7/en/cursors.html and SERVER_STATUS_CURSOR_EXISTS flag description on http://dev.mysql.com/doc/internals/en/status-flags.html).
ResultsetRowsOwner  
ResultsetRowsStatic
Represents an in-memory result set
ResultsetRowsStreaming<T extends ProtocolEntity>
Provides streaming of Resultset rows.
ResultSetScannerInterceptor  
ResultStreamer
A result streamer is a result object that is streaming results from the current connection.
ReusableInputStream
An InputStream wrapper that allows switching to different underlying InputStreams under the same InputStream instance.
ReusableOutputStream
An OutputStream wrapper that allows switching to different underlying OutputStreams under the same OutputStream instance.
Row  
Row
A row element returned from a SELECT query.
RowFactory
Create Row objects from internal row representation.
RowImpl
Row implementation.
RowList
A list of Rows.
RowResult
A result exposing a set of rows from a SELECT query.
RowResultBuilder
Result builder producing a RowResult instance.
RowResultImpl
RowResult implementation.
RSAException  
RuntimeProperty<T>  
RuntimeProperty.RuntimePropertyListener  
SaslPrep
Implementation for SASLprep: Stringprep Profile for User Names and Passwords, as specified in RFC 4013.
SaslPrep.StringType
The type of string usage regarding the support for unassigned code points as described in RFC 3454, Section 7.
Schema
A client-side representation of a database schema.
Schema.CreateCollectionOptions
Schema.ModifyCollectionOptions
Schema.Validation
Schema.Validation.ValidationLevel
Defines how validation options are applied.
SchemaImpl
Schema implementation.
ScramSha1SaslClient
A SaslClient implementation for SCRAM-SHA-1, as specified in RFC 5802.
ScramSha1SaslClientFactory
A SaslClientFactory for ScramSha1SaslClient instances.
ScramSha1SaslProvider
A SASL provider for the authentication mechanism SCRAM-SHA-1 here renamed to MYSQLCJ-SCRAM-SHA-1 to avoid conflicts with future standard implementations.
ScramSha256SaslClient
A SaslClient implementation for SCRAM-SHA-256, as specified in RFC 5802 and RFC 7677.
ScramShaSaslClient
A SaslClient implementation for SCRAM-SHA mechanisms as specified in RFC 5802.
ScramShaSaslClient.ScramExchangeStage  
ScramShaSaslClientFactory
A SaslClientFactory for ScramSha1SaslClient and ScramSha256SaslClient instances.
ScramShaSaslProvider
A SASL provider for the authentication mechanisms SCRAM-SHA-1 and SCRAM-SHA-256, here renamed to MYSQLCJ-SCRAM-SHA-1 and MYSQL-SRAM-SHA-256 respectively to avoid conflicts with future default implementations.
Security
Methods for doing secure authentication with MySQL-4.1 and newer.
SelectStatement
A statement representing a SELECT query.
SelectStatementImpl
SelectStatement implementation.
SequentialBalanceStrategy
A balancing strategy that starts at a random point, and then advances in the list (wrapping around) for each new pickConnection() call.
SequentialIdLease  
ServerAffinityStrategy  
ServerCapabilities
Represents server capabilities, retrieved right after creating physical connection and before handshake.
ServerController
Controls a MySQL server using Java RunTime methods
ServerPreparedQuery  
ServerPreparedQueryBindings  
ServerPreparedQueryBindValue  
ServerPreparedQueryTestcaseGenerator  
ServerPreparedStatement
JDBC Interface for MySQL-4.1 and newer server-side PreparedStatements.
ServerSession
Keeps the effective states of server/session variables, contains methods for initial retrieving of these states and for their actualization.
ServerStatusDiffInterceptor  
ServerVersion
A server version.
Session
Session exposes logical level which user API uses internally to call Protocol methods.
Session
X DevAPI introduces a new, high-level database connection concept that is called Session.
Session.SessionEventListener  
SessionAssociationInterceptor  
SessionFactory
SessionFactory is used for creation of sessions.
SessionImpl
Session implementation.
Sha256PasswordPlugin  
ShortValueFactory
A value factory for creating short values.
SimplePacketReader
Simple implementation of MessageReader which handles the receiving of logical MySQL packets from the provided socket input stream.
SimplePacketSender
Simple implementation of MessageSender which handles the transmission of logical MySQL packets to the provided output stream.
SimpleQuery  
SingleConnectionUrl  
Slf4JLogger  
SocketConnection
Represents physical connection with endpoint
SocketFactory
Interface to allow pluggable socket creation in the driver
SocketFactory Deprecated.
Use SocketFactory instead.
SocketFactoryWrapper
Wraps the legacy com.mysql.jdbc.SocketFactory implementations so they can be used as SocketFactory
SocketMetadata  
SocksProxySocketFactory
A socket factory used to create sockets connecting through a SOCKS proxy.
SqlDateValueFactory
A value factory for creating Date values.
SQLError
SQLError is a utility class that maps MySQL error codes to SQL error codes as is required by the JDBC spec.
SQLExceptionsMapping  
SqlMultiResult
SqlResult representing a multiple result sets.
SqlResult
A result from a SQL statement which may have several sets of data following by a DML result.
SqlResultBuilder
Result builder producing a SqlResult instance.
SqlSingleResult
SqlResult representing a single result set.
SqlStatement
A statement representing a raw SQL command.
SqlStatementImpl
SqlStatement implementation.
SqlTimestampValueFactory
Value factory to create Timestamp instances.
SqlTimeValueFactory
A value factory to create Time instances.
SqlUpdateResult
SqlResult for insert, update, delete and DDL statements.
SSLParamsException  
StandardLoadBalanceExceptionChecker  
StandardLogger
Provides logging facilities for those platforms that don't have built-in facilities.
StandardSocketFactory
Socket factory for vanilla TCP/IP sockets (the standard)
Statement<STMT_T,​RES_T>
A statement is a query or state-affecting command against a database that returns a result.
Statement.LockContention
The lock contention options for the locking modes available.
StatementExecuteOk
ProtocolEntity representing a StatementExecuteOk message.
StatementExecuteOkBuilder
Result builder producing a StatementExecuteOk instance.
StatementExecuteOkFactory
Factory producing StatementExecuteOk from protocol message.
StatementImpl
A Statement object is used for executing a static SQL statement and obtaining the results produced by it.
StatementIsClosedException
Operation attempted on already closed Statement
StatementWrapper
Wraps statements so that errors can be reported correctly to ConnectionEventListeners.
StreamingDocResultBuilder
Result builder producing a streaming DocResult instance.
StreamingNotifiable  
StreamingRowResultBuilder
Result builder producing a streaming RowResult instance.
StreamingSqlResultBuilder
Result builder producing a streaming SqlResult instance.
StringProperty  
StringPropertyDefinition  
StringUtils
Various utility methods for converting to/from byte arrays in the platform encoding
StringUtils.SearchMode  
StringValueFactory
A ValueFactory implementation to create strings.
SuspendableXAConnection  
SyncFlushDeflaterOutputStream
Wrapper around DeflaterOutputStream that enables sync flush by default.
SyncMessageReader
Synchronous-only implementation of MessageReader.
SyncMessageSender
Synchronous-only implementation of MessageSender.
Table
A client-side representation of a database table.
TableFilterParams
FilterParams implementation for Table syntax.
TableImpl
Table implementation
TestUtils  
TextBufferRow
A ResultSetRow implementation that holds one row packet (which is re-used by the driver, and thus saves memory allocations), and tries when possible to avoid allocations to break out the results as individual byte[]s.
TextResultsetReader  
TextRowFactory  
TimeTrackingPacketReader
A MessageReader which tracks the last time a packet was received.
TimeTrackingPacketSender
A MessageSender which tracks the last time a packet was sent.
TimeUtil
Time zone conversion routines and other time related methods
TimezoneDump
Dumps the timezone of the MySQL server represented by the JDBC url given on the commandline (or localhost/test if none provided).
TopologyService
It's a generic interface for all topology services.
TopologyServicePropertyKeys
Property keys that topology service has to use to store additional properties to HostInfo.
TracingPacketReader
A decorating MessageReader which traces all received packets to the provided logger.
TracingPacketSender
A decorating MessageSender which traces all sent packets to the provided logger.
TransactionEventHandler  
TranslateExceptions  
Type
Column type.
UnableToConnectException  
UnsupportedConnectionStringException  
UpdatableResultSet
A result set that is updatable.
UpdateParams
Class collecting parameters for Table.update().
UpdateResult
A result from a statement that doesn't return a set of rows.
UpdateResultBuilder<T extends Result>
Result builder producing an UpdateResult instance.
UpdateSpec
Representation of a single update operation in a list of operations to be performed by ModifyStatement.
UpdateStatement
A statement representing a set of row modifications.
UpdateStatementImpl
UpdateStatement implementation.
UpdateType
Update operation type.
Util
Various utility methods for the driver.
UtilCalendarValueFactory
Value factory to create Calendar instances.
ValueDecoder
A value decoder is responsible for interpreting a byte array as a value.
ValueFactory<T>
A class implements the ValueFactory<T> interface to create value instances from intermediate forms.
Warning  
Warning
A warning generated during statement execution.
WarningImpl
Warning implementation
WarningListener
A warning listener is notified of warnings as they happen throughout the driver.
WatchableOutputStream
A java.io.OutputStream used to write ASCII data into Blobs and Clobs
WatchableStream  
WatchableWriter
A java.io.Writer used to write unicode data into Blobs and Clobs
WriterFailoverHandler
Interface for Writer Failover Process handler.
WriterFailoverResult
This class holds results of Writer Failover Process.
WriterWatcher
Objects that want to be notified of lifecycle events on a WatchableWriter should implement this interface, and register themselves with setWatcher() on the WatchableWriter instance.
WrongArgumentException  
XAuthenticationProvider  
XDevApiConnectionUrl  
XDevApiDnsSrvConnectionUrl  
XDevAPIError
An Error returned from X DevAPI.
XMessage  
XMessageBuilder  
XMessageHeader  
XpluginStatementCommand  
XProtocol
Low-level interface to communications with X Plugin.
XProtocolDecoder  
XProtocolError
An Error returned from X Plugin.
XProtocolRow
ProtocolEntity representing an X Protocol result row.
XProtocolRowFactory
Factory producing an XProtocolRow from protocol message.
XProtocolRowInputStream  
XServerCapabilities  
XServerSession  
ZonedDateTimeValueFactory
Value factory to create ZonedDateTime instances.