Serialized Form

  • Package com.microsoft.sqlserver.jdbc

    • Class com.microsoft.sqlserver.jdbc.SQLServerBlob extends com.microsoft.sqlserver.jdbc.SQLServerLob implements Serializable

      serialVersionUID:
      -3526170228097889085L
      • Serialized Fields

        • activeStreams
          java.util.ArrayList<java.io.Closeable> activeStreams
          Active streams which must be closed when the Blob is closed Initial size of the array is based on an assumption that a Blob object is typically used either for input or output, and then only once. The array size grows automatically if multiple streams are used.
        • isClosed
          boolean isClosed
          check if LOB has been freed
        • traceID
          java.lang.String traceID
          trace id
        • value
          byte[] value
          The value of the BLOB that this Blob object represents. This value is never null unless/until the free() method is called.
    • Class com.microsoft.sqlserver.jdbc.SQLServerBulkCopy extends java.lang.Object implements Serializable

      serialVersionUID:
      1989903904654306244L
      • Serialized Fields

        • columnMappings
          java.util.List<com.microsoft.sqlserver.jdbc.SQLServerBulkCopy.ColumnMapping> columnMappings
          Mappings between columns in the data source and columns in the destination
        • connection
          SQLServerConnection connection
          Destination server connection.
        • copyOptions
          SQLServerBulkCopyOptions copyOptions
          Options to control how the WriteToServer methods behave.
        • destCekTable
          com.microsoft.sqlserver.jdbc.CekTable destCekTable
          The CekTable for the destination table.
        • destColumnCount
          int destColumnCount
          Variable to store destination column count.
        • destColumnMetadata
          java.util.Map<java.lang.Integer,​com.microsoft.sqlserver.jdbc.SQLServerBulkCopy.BulkColumnMetaData> destColumnMetadata
          A map to store the metadata information for the destination table.
        • destinationTableMetadata
          java.sql.ResultSet destinationTableMetadata
          Destination table metadata
        • destinationTableName
          java.lang.String destinationTableName
          Name of destination table on server. If destinationTable has not been set when WriteToServer is called, an Exception is thrown. destinationTable is a three-part name (<database>.<owningschema>.<name>). You can qualify the table name with its database and owning schema if you choose. However, if the table name uses an underscore ("_") or any other special characters, you must escape the name using surrounding brackets. For more information, see "Identifiers" in SQL Server Books Online. You can bulk-copy data to a temporary table by using a value such as tempdb..#table or tempdb.<owner>.#table for the destinationTable property.
        • ownsConnection
          boolean ownsConnection
          Flag if SQLServerBulkCopy owns the connection and should close it when Close is called
        • serverBulkData
          ISQLServerBulkData serverBulkData
          Source data (from a Record). Is null unless the corresponding version of writeToServer is called.
        • sourceResultSet
          java.sql.ResultSet sourceResultSet
          Source data (from ResultSet). Is null unless the corresponding version of writeToServer is called.
        • sourceResultSetMetaData
          java.sql.ResultSetMetaData sourceResultSetMetaData
          Metadata for the source table columns
        • srcColumnCount
          int srcColumnCount
          Variable to store source column count.
        • srcColumnMetadata
          java.util.Map<java.lang.Integer,​com.microsoft.sqlserver.jdbc.SQLServerBulkCopy.BulkColumnMetaData> srcColumnMetadata
          A map to store the metadata information for the source table.
        • stmtColumnEncriptionSetting
          SQLServerStatementColumnEncryptionSetting stmtColumnEncriptionSetting
          Statement level encryption setting needed for querying against encrypted columns.
        • timeout
          java.util.concurrent.ScheduledFuture<?> timeout
          Shared timer
    • Class com.microsoft.sqlserver.jdbc.SQLServerBulkCopyOptions extends java.lang.Object implements Serializable

      serialVersionUID:
      711570696894155194L
      • Serialized Fields

        • allowEncryptedValueModifications
          boolean allowEncryptedValueModifications
          Flag to determine whether encrypted value modifications are allwoed
        • batchSize
          int batchSize
          Number of rows in each batch. A batch is complete when BatchSize rows have been processed or there are no more rows to send to the destination data source. Zero (the default) indicates that each WriteToServer operation is a single batch. If the SqlBulkCopy instance has been declared without the UseInternalTransaction option in effect, rows are sent to the server BatchSize rows at a time, but no transaction-related action is taken. If UseInternalTransaction is in effect, each batch of rows is inserted as a separate transaction. Default: 0
        • bulkCopyTimeout
          int bulkCopyTimeout
          Number of seconds for the operation to complete before it times out. A value of 0 indicates no limit; the bulk copy will wait indefinitely. If the operation does time out, the transaction is not committed and all copied rows are removed from the destination table. Default: 60
        • checkConstraints
          boolean checkConstraints
          Checks constraints while data is being inserted. Default: false - constraints are not checked
        • fireTriggers
          boolean fireTriggers
          When specified, cause the server to fire the insert triggers for the rows being inserted into the database. Default: false - no triggers are fired.
        • keepIdentity
          boolean keepIdentity
          Preserve source identity values. Default: false - identity values are assigned by the destination.
        • keepNulls
          boolean keepNulls
          Preserve null values in the destination table regardless of the settings for default values. Default: false - null values are replaced by default values where applicable.
        • tableLock
          boolean tableLock
          Obtain a bulk update lock for the duration of the bulk copy operation. Default: false - row locks are used.
        • useInternalTransaction
          boolean useInternalTransaction
          When specified, each batch of the bulk-copy operation will occur within a transaction. Default: false - no transaction
    • Class com.microsoft.sqlserver.jdbc.SQLServerBulkCSVFileRecord extends com.microsoft.sqlserver.jdbc.SQLServerBulkRecord implements Serializable

      serialVersionUID:
      1546487135640225989L
      • Serialized Fields

        • currentLine
          java.lang.String currentLine
          Current line of data to parse.
        • delimiter
          java.lang.String delimiter
          Delimiter to parse lines with.
        • escapeDelimiters
          boolean escapeDelimiters
          Escape delimiters
        • fileReader
          java.io.BufferedReader fileReader
          file reader
        • fis
          java.io.FileInputStream fis
          file input stream
        • sr
          java.io.InputStreamReader sr
          input stream reader
    • Class com.microsoft.sqlserver.jdbc.SQLServerCallableStatement extends SQLServerPreparedStatement implements Serializable

      serialVersionUID:
      5044984771674532350L
      • Serialized Fields

        • activeStream
          java.io.Closeable activeStream
          Currently active Stream Note only one stream can be active at a time
        • ai
          java.util.concurrent.atomic.AtomicInteger ai
          atomic integer
        • insensitiveParameterNames
          java.util.TreeMap<java.lang.String,​java.lang.Integer> insensitiveParameterNames
          insensitive param names
        • lastParamAccessed
          com.microsoft.sqlserver.jdbc.Parameter lastParamAccessed
          The last out param accessed.
        • map
          java.util.Map<java.lang.String,​java.lang.Integer> map
          map
        • nOutParams
          int nOutParams
          Number of registered OUT parameters
        • nOutParamsAssigned
          int nOutParamsAssigned
          number of out params assigned already
        • outParamIndex
          int outParamIndex
          The index of the out params indexed - internal index
        • parameterNames
          java.util.HashMap<java.lang.String,​java.lang.Integer> parameterNames
          the call param names
    • Class com.microsoft.sqlserver.jdbc.SQLServerClob extends com.microsoft.sqlserver.jdbc.SQLServerClobBase implements Serializable

      serialVersionUID:
      2872035282200133865L
    • Class com.microsoft.sqlserver.jdbc.SQLServerConnection extends java.lang.Object implements Serializable

      serialVersionUID:
      1965647556064751510L
      • Serialized Fields

        • aadPrincipalID
          java.lang.String aadPrincipalID
          AAD principal id
        • aadPrincipalSecret
          java.lang.String aadPrincipalSecret
          AAD principal secret
        • accessTokenInByte
          byte[] accessTokenInByte
          access token in byte
        • activeConnectionProperties
          java.util.Properties activeConnectionProperties
          the active set of connection properties
        • aeVersion
          int aeVersion
          Always Encrypted version
        • applicationIntent
          com.microsoft.sqlserver.jdbc.ApplicationIntent applicationIntent
          application intent
        • attemptRefreshTokenLocked
          boolean attemptRefreshTokenLocked
          flag to indicate if attempt refresh token is locked
        • authenticationString
          java.lang.String authenticationString
          authentication string
        • cancelQueryTimeoutSeconds
          int cancelQueryTimeoutSeconds
          Timeout value for canceling the query timeout.
        • clientCertificate
          java.lang.String clientCertificate
          client certificate
        • clientConnectionId
          java.util.UUID clientConnectionId
          client connection id
        • clientKey
          java.lang.String clientKey
          client key
        • clientKeyPassword
          java.lang.String clientKeyPassword
          client key password
        • columnEncryptionSetting
          java.lang.String columnEncryptionSetting
          column encryption setting
        • connectRetryCount
          int connectRetryCount
          connect retry count
        • connectRetryInterval
          int connectRetryInterval
          connect retry interval
        • currentCommand
          com.microsoft.sqlserver.jdbc.TDSCommand currentCommand
          current command
        • currentConnectPlaceHolder
          com.microsoft.sqlserver.jdbc.ServerPortPlaceHolder currentConnectPlaceHolder
          This is the current connect place holder this should point one of the primary or failover place holder
        • databaseAutoCommitMode
          boolean databaseAutoCommitMode
          database auto commit mode
        • databaseCollation
          com.microsoft.sqlserver.jdbc.SQLCollation databaseCollation
          Default database collation read from ENVCHANGE_SQLCOLLATION token.
        • databaseMetaData
          SQLServerDatabaseMetaData databaseMetaData
          the meta data for this connection
        • delayLoadingLobs
          boolean delayLoadingLobs
          Boolean that indicates whether LOB objects created by this connection should be loaded into memory
        • disableStatementPooling
          boolean disableStatementPooling
          Checks whether statement pooling is enabled or disabled. The default is set to true;
        • discardedPreparedStatementHandleCount
          java.util.concurrent.atomic.AtomicInteger discardedPreparedStatementHandleCount
          discardedPreparedStatementHandle count
        • discardedPreparedStatementHandles
          java.util.concurrent.ConcurrentLinkedQueue<com.microsoft.sqlserver.jdbc.SQLServerConnection.PreparedStatementHandle> discardedPreparedStatementHandles
          Handle the actual queue of discarded prepared statements.
        • enablePrepareOnFirstPreparedStatementCall
          java.lang.Boolean enablePrepareOnFirstPreparedStatementCall
          Current limit for this particular connection.
        • enclaveAttestationProtocol
          java.lang.String enclaveAttestationProtocol
          Enclave Attestation protocol
        • enclaveAttestationUrl
          java.lang.String enclaveAttestationUrl
          Enclave Attestation URL
        • enclaveProvider
          com.microsoft.sqlserver.jdbc.ISQLServerEnclaveProvider enclaveProvider
          Enclave provider
        • enclaveType
          java.lang.String enclaveType
          Enclave type
        • ENGINE_EDITION_SQL_AZURE_DB
          int ENGINE_EDITION_SQL_AZURE_DB
          Engine Edition 5 = SQL Database
        • ENGINE_EDITION_SQL_AZURE_MI
          int ENGINE_EDITION_SQL_AZURE_MI
          Engine Edition 8 = Azure SQL Managed Instance
        • ENGINE_EDITION_SQL_AZURE_SQL_EDGE
          int ENGINE_EDITION_SQL_AZURE_SQL_EDGE
          Engine Edition 9 = Azure SQL Edge (This is returned for all editions of Azure SQL Edge)
        • ENGINE_EDITION_SQL_AZURE_SYNAPSE_ANALYTICS
          int ENGINE_EDITION_SQL_AZURE_SYNAPSE_ANALYTICS
          Engine Edition 6 = Microsoft Azure Synapse Analytics
        • ENGINE_EDITION_SQL_AZURE_SYNAPSE_SERVERLESS_SQL_POOL
          int ENGINE_EDITION_SQL_AZURE_SYNAPSE_SERVERLESS_SQL_POOL
          Engine Edition 11 = Azure Synapse serverless SQL pool
        • failoverPartnerServerProvided
          java.lang.String failoverPartnerServerProvided
          There are three ways to get a failover partner connection string, from the failover map, the connecting server returned the following variable only stores the serverReturned failver information.
        • fedAuthFeatureExtensionData
          com.microsoft.sqlserver.jdbc.SQLServerConnection.FederatedAuthenticationFeatureExtensionData fedAuthFeatureExtensionData
          fedAuth feature extension data
        • fedAuthRequiredByUser
          boolean fedAuthRequiredByUser
          fedAuth required by user flag
        • fedAuthRequiredPreLoginResponse
          boolean fedAuthRequiredPreLoginResponse
          fedAuth required prelogin response flag
        • fedAuthToken
          com.microsoft.sqlserver.jdbc.SqlFedAuthToken fedAuthToken
          fedAuth token
        • federatedAuthenticationInfoRequested
          boolean federatedAuthenticationInfoRequested
          Keep this distinct from _federatedAuthenticationRequested, since some fedauth library types may not need more info
        • federatedAuthenticationRequested
          boolean federatedAuthenticationRequested
          fedAuth requested flag
        • holdability
          int holdability
          holdability
        • hostName
          java.lang.String hostName
          hostname
        • impersonatedUserCred
          org.ietf.jgss.GSSCredential impersonatedUserCred
          impersonated user credential
        • intAuthScheme
          com.microsoft.sqlserver.jdbc.AuthenticationScheme intAuthScheme
          integrated authentication scheme
        • integratedSecurity
          boolean integratedSecurity
          integrated security property
        • inXATransaction
          boolean inXATransaction
          Set to true when in an XA transaction.
        • isAzure
          java.lang.Boolean isAzure
          flag indicated whether server is Azure
        • isAzureDW
          java.lang.Boolean isAzureDW
          flag indicated whether server is Azure DW
        • isAzureMI
          java.lang.Boolean isAzureMI
          flag indicated whether server is Azure MI
        • isRoutedInCurrentAttempt
          boolean isRoutedInCurrentAttempt
          Indicates if we received a routing ENVCHANGE in the current connection attempt
        • isUserCreatedCredential
          boolean isUserCreatedCredential
          user created credential flag
        • keyStoreAuthentication
          java.lang.String keyStoreAuthentication
          keystore authentication
        • keyStoreLocation
          java.lang.String keyStoreLocation
          keystore location
        • keyStorePrincipalId
          java.lang.String keyStorePrincipalId
          keystore principal id
        • keystoreProvider
          SQLServerColumnEncryptionKeyStoreProvider keystoreProvider
          keystore provider
        • keyStoreSecret
          java.lang.String keyStoreSecret
          keystore secret
        • lastUpdateCount
          boolean lastUpdateCount
          last update count flag
        • maxFieldSize
          int maxFieldSize
          Limit for the size of data (in bytes) returned for value on this connection
        • maxRows
          int maxRows
          Limit for the maximum number of rows returned from queries on this connection
        • multiSubnetFailover
          boolean multiSubnetFailover
          see feature_connection_director_multi_subnet_JDBC.docx
        • negotiatedEncryptionLevel
          byte negotiatedEncryptionLevel
          negotiated encryption level
        • nLockTimeout
          int nLockTimeout
          nLockTimeout
        • nNextSavePointId
          int nNextSavePointId
          first save point id
        • ntlmAuthentication
          boolean ntlmAuthentication
          NTLM authentication flag
        • ntlmPasswordHash
          byte[] ntlmPasswordHash
          NTLM password hash
        • openStatements
          java.util.List<ISQLServerStatement> openStatements
          open statements
        • originalCatalog
          java.lang.String originalCatalog
          This is the catalog immediately after login.
        • originalDatabaseAutoCommitMode
          boolean originalDatabaseAutoCommitMode
          original database autocommit mode
        • originalDelayLoadingLobs
          boolean originalDelayLoadingLobs
          original delayLoadingLobs
        • originalDisableStatementPooling
          boolean originalDisableStatementPooling
          original disableStatementPooling
        • originalEnablePrepareOnFirstPreparedStatementCall
          java.lang.Boolean originalEnablePrepareOnFirstPreparedStatementCall
          original enable prepareOnFirstPreparedStatementCall
        • originalHoldability
          int originalHoldability
          original holdability
        • originalHostNameInCertificate
          java.lang.String originalHostNameInCertificate
          original hostNameInCertificate
        • originalNetworkTimeout
          int originalNetworkTimeout
          original network timeout
        • originalSCatalog
          java.lang.String originalSCatalog
          original sCatalog
        • originalSendTimeAsDatetime
          boolean originalSendTimeAsDatetime
          original sendTimeAsDateTime flag
        • originalServerPreparedStatementDiscardThreshold
          int originalServerPreparedStatementDiscardThreshold
          original server prepared statement discard threshold
        • originalSqlWarnings
          java.sql.SQLWarning originalSqlWarnings
          original SqlWarnings
        • originalStatementPoolingCacheSize
          int originalStatementPoolingCacheSize
          original statement pooling cache size
        • originalTransactionIsolationLevel
          int originalTransactionIsolationLevel
          original transaction isolation level
        • originalUseBulkCopyForBatchInsert
          boolean originalUseBulkCopyForBatchInsert
          original useBulkCopyForBatchInsert flag
        • originalUseFmtOnly
          boolean originalUseFmtOnly
          original usesFmtOnly flag
        • parameterMetadataCache
          mssql.googlecode.concurrentlinkedhashmap.ConcurrentLinkedHashMap<com.microsoft.sqlserver.jdbc.SQLServerConnection.CityHash128Key,​SQLServerParameterMetaData> parameterMetadataCache
          Cache of prepared statement parameter metadata
        • pooledConnectionParent
          SQLServerPooledConnection pooledConnectionParent
          pooled connection parent
        • preparedStatementHandleCache
          mssql.googlecode.concurrentlinkedhashmap.ConcurrentLinkedHashMap<com.microsoft.sqlserver.jdbc.SQLServerConnection.CityHash128Key,​com.microsoft.sqlserver.jdbc.SQLServerConnection.PreparedStatementHandle> preparedStatementHandleCache
          Cache of prepared statement handles
        • proxy
          com.microsoft.sqlserver.jdbc.SQLServerConnectionPoolProxy proxy
          connection pool proxy
        • queryTimeoutSeconds
          int queryTimeoutSeconds
          queryTimeout seconds
        • replication
          boolean replication
          get default replication value
        • requestedEncryptionLevel
          byte requestedEncryptionLevel
          requested encryption level
        • requestedPacketSize
          int requestedPacketSize
          requested packet size
        • requestStarted
          boolean requestStarted
          request started flag
        • responseBuffering
          java.lang.String responseBuffering
          response buffering
        • rolledBackTransaction
          boolean rolledBackTransaction
          Flag (Yukon and later) set to true whenever a transaction is rolled back..The flag's value is reset to false when a new transaction starts or when the autoCommit mode changes.
        • routingInfo
          com.microsoft.sqlserver.jdbc.ServerPortPlaceHolder routingInfo
          Contains the routing info received from routing ENVCHANGE
        • sCatalog
          java.lang.String sCatalog
          This is the current catalog
        • selectMethod
          java.lang.String selectMethod
          select method
        • sendStringParametersAsUnicode
          boolean sendStringParametersAsUnicode
          see connection properties doc (default is false)
        • sendTemporalDataTypesAsStringForBulkCopy
          boolean sendTemporalDataTypesAsStringForBulkCopy
          sendTemporalDataTypesAsStringForBulkCopy flag
        • sendTimeAsDatetime
          boolean sendTimeAsDatetime
          sendTimeAsDatetime flag
        • serverColumnEncryptionVersion
          com.microsoft.sqlserver.jdbc.ColumnEncryptionVersion serverColumnEncryptionVersion
          server column encryption version
        • serverMajorVersion
          int serverMajorVersion
          server major version
        • serverNameAsACE
          boolean serverNameAsACE
          Translates the serverName from Unicode to ASCII Compatible Encoding (ACE), as defined by the ToASCII operation of RFC 3490
        • serverPreparedStatementDiscardThreshold
          int serverPreparedStatementDiscardThreshold
          Current limit for this particular connection
        • serverSupportedDataClassificationVersion
          byte serverSupportedDataClassificationVersion
          server supported data classification version
        • serverSupportsDataClassification
          boolean serverSupportsDataClassification
          whether server supports data classiciation
        • serverSupportsDNSCaching
          boolean serverSupportsDNSCaching
          whether server supports DNS caching
        • sharedTimer
          com.microsoft.sqlserver.jdbc.SharedTimer sharedTimer
          shared timer
        • socketFactoryClass
          java.lang.String socketFactoryClass
          socket factory class
        • socketFactoryConstructorArg
          java.lang.String socketFactoryConstructorArg
          socket factory constructor argument
        • socketTimeoutMilliseconds
          int socketTimeoutMilliseconds
          socket timeout in ms
        • sqlServerVersion
          java.lang.String sqlServerVersion
          SQL Server version string
        • sqlWarnings
          java.sql.SQLWarning sqlWarnings
          the SQL warnings chain
        • state
          com.microsoft.sqlserver.jdbc.SQLServerConnection.State state
          connection state
        • statementPoolingCacheSize
          int statementPoolingCacheSize
          Size of the prepared statement handle cache
        • systemColumnEncryptionKeyStoreProvider
          java.util.Map<java.lang.String,​SQLServerColumnEncryptionKeyStoreProvider> systemColumnEncryptionKeyStoreProvider
          This is a per-connection store provider. It can be JKS or AKV.
        • tdsChannel
          com.microsoft.sqlserver.jdbc.TDSChannel tdsChannel
          TDS channel
        • tdsPacketSize
          int tdsPacketSize
          Default TDS packet size used after logon if no other value was set via the packetSize connection property. The value was chosen to take maximum advantage of SQL Server's default page size.
        • tdsVersion
          int tdsVersion
          TDS version
        • timerExpire
          long timerExpire
          timer expiry
        • traceID
          java.lang.String traceID
          trace iD
        • transactionDescriptor
          byte[] transactionDescriptor
          transaction descriptor
        • transactionIsolationLevel
          int transactionIsolationLevel
          transaction isolation level
        • transparentNetworkIPResolution
          boolean transparentNetworkIPResolution
          transparent network IP resolution
        • trustedServerNameAE
          java.lang.String trustedServerNameAE
          trusted servername AE
        • trustManagerClass
          java.lang.String trustManagerClass
          trust manager class
        • trustManagerConstructorArg
          java.lang.String trustManagerConstructorArg
          trust manager constructor argument
        • trustServerCertificate
          boolean trustServerCertificate
          trust server certificate
        • useBulkCopyForBatchInsert
          boolean useBulkCopyForBatchInsert
          boolean value for deciding if the driver should use bulk copy API for batch inserts.
        • useFmtOnly
          boolean useFmtOnly
          useFmtOnly property
        • userSetTNIR
          boolean userSetTNIR
          user set TNIR flag
        • warningSynchronization
          java.lang.Object warningSynchronization
          warnings synchronization object
        • xopenStates
          boolean xopenStates
          XOPEN or SQL 92 state codes?
    • Class com.microsoft.sqlserver.jdbc.SQLServerConnection43 extends SQLServerConnection implements Serializable

      serialVersionUID:
      -6904163521498951547L
    • Class com.microsoft.sqlserver.jdbc.SQLServerConnectionPoolDataSource extends SQLServerDataSource implements Serializable

      • Serialization Methods

        • readObject
          private void readObject​(java.io.ObjectInputStream stream) throws java.io.InvalidObjectException
          For added security/robustness, the only way to rehydrate a serialized SQLServerDataSource is to use a SerializationProxy. Direct use of readObject() is not supported.
          Throws:
          java.io.InvalidObjectException - if error
        • writeReplace
          private java.lang.Object writeReplace() throws java.io.ObjectStreamException
          writeReplace
          Throws:
          java.io.ObjectStreamException - if error
    • Class com.microsoft.sqlserver.jdbc.SQLServerDatabaseMetaData extends java.lang.Object implements Serializable

      serialVersionUID:
      -116977606028371577L
      • Serialized Fields

        • connection
          SQLServerConnection connection
          connection
        • handleMap
          java.util.EnumMap<com.microsoft.sqlserver.jdbc.SQLServerDatabaseMetaData.CallableHandles,​com.microsoft.sqlserver.jdbc.SQLServerDatabaseMetaData.HandleAssociation> handleMap
          handle map
        • traceID
          java.lang.String traceID
          trace ID
    • Class com.microsoft.sqlserver.jdbc.SQLServerDataSource extends java.lang.Object implements Serializable

      serialVersionUID:
      654861379544314296L
      • Serialization Methods

        • readObject
          private void readObject​(java.io.ObjectInputStream stream) throws java.io.InvalidObjectException
          For added security/robustness, the only way to rehydrate a serialized SQLServerDataSource is to use a SerializationProxy. Direct use of readObject() is not supported.
          Throws:
          java.io.InvalidObjectException - if error
        • writeReplace
          private java.lang.Object writeReplace() throws java.io.ObjectStreamException
          writeReplace
          Throws:
          java.io.ObjectStreamException - if error
      • Serialized Fields

        • connectionProps
          java.util.Properties connectionProps
          Properties passed to SQLServerConnection class
        • dataSourceDescription
          java.lang.String dataSourceDescription
          Description for datasource.
        • dataSourceURL
          java.lang.String dataSourceURL
          URL for datasource
        • loggingClassName
          java.lang.String loggingClassName
          logging class name
        • traceID
          java.lang.String traceID
          trace ID
        • trustStorePasswordStripped
          boolean trustStorePasswordStripped
          trustStorePasswordStripped flag
    • Class com.microsoft.sqlserver.jdbc.SQLServerError extends com.microsoft.sqlserver.jdbc.StreamPacket implements Serializable

      serialVersionUID:
      -7304033613218700719L
      • Serialized Fields

        • errorMessage
          java.lang.String errorMessage
          error message string
        • errorNumber
          int errorNumber
          error number
        • errorSeverity
          int errorSeverity
          error severity
        • errorState
          int errorState
          error state
        • lineNumber
          long lineNumber
          line number
        • procName
          java.lang.String procName
          procedure name
        • serverName
          java.lang.String serverName
          server name
    • Class com.microsoft.sqlserver.jdbc.SQLServerException extends java.sql.SQLException implements Serializable

      serialVersionUID:
      -2195310557661496761L
      • Serialized Fields

        • driverErrorCode
          int driverErrorCode
          driver error code
        • sqlServerError
          SQLServerError sqlServerError
          SQL server error
    • Class com.microsoft.sqlserver.jdbc.SQLServerNClob extends com.microsoft.sqlserver.jdbc.SQLServerClobBase implements Serializable

      serialVersionUID:
      3593610902551842327L
    • Class com.microsoft.sqlserver.jdbc.SQLServerPooledConnection extends java.lang.Object implements Serializable

      serialVersionUID:
      3492921646187451164L
      • Serialized Fields

        • factoryDataSource
          SQLServerDataSource factoryDataSource
          factory datasource
        • factoryPassword
          java.lang.String factoryPassword
          factory password
        • factoryUser
          java.lang.String factoryUser
          factory password
        • lastProxyConnection
          com.microsoft.sqlserver.jdbc.SQLServerConnectionPoolProxy lastProxyConnection
          last proxy connection
        • listeners
          java.util.Vector<javax.sql.ConnectionEventListener> listeners
          listeners
        • pcLogger
          java.util.logging.Logger pcLogger
          logger
        • physicalConnection
          SQLServerConnection physicalConnection
          physical connection
        • traceID
          java.lang.String traceID
          trace ID
    • Class com.microsoft.sqlserver.jdbc.SQLServerPreparedStatement extends SQLServerStatement implements Serializable

      serialVersionUID:
      -6292257029445685221L
      • Serialized Fields

        • batchParamValues
          java.util.ArrayList<com.microsoft.sqlserver.jdbc.Parameter[]> batchParamValues
          Set of parameter values in the current batch
        • bReturnValueSyntax
          boolean bReturnValueSyntax
          Set to true if the statement is a stored procedure call that expects a return value
        • cachedPreparedStatementHandle
          com.microsoft.sqlserver.jdbc.SQLServerConnection.PreparedStatementHandle cachedPreparedStatementHandle
          Reference to cache item for statement handle pooling. Only used to decrement ref count on statement close.
        • cryptoMetaBatch
          java.util.Vector<com.microsoft.sqlserver.jdbc.CryptoMetadata> cryptoMetaBatch
          crypto meta batch
        • enclaveCEKs
          java.util.ArrayList<byte[]> enclaveCEKs
          enclave CEKs
        • encryptionMetadataIsRetrieved
          boolean encryptionMetadataIsRetrieved
          Flag set to true when all encryption metadata of inOutParam is retrieved
        • expectPrepStmtHandle
          boolean expectPrepStmtHandle
          Flag set to true when statement execution is expected to return the prepared statement handle
        • internalStmt
          SQLServerStatement internalStmt
          Statement used for getMetadata(). Declared as a field to facilitate closing the statement.
        • isExecutedAtLeastOnce
          boolean isExecutedAtLeastOnce
          True if this execute has been called for this statement at least once
        • localUserSQL
          java.lang.String localUserSQL
          local user SQL
        • nBatchStatementDelimiter
          int nBatchStatementDelimiter
          batch statement delimiter
        • outParamIndexAdjustment
          int outParamIndexAdjustment
          The number of OUT parameters to skip in the response to get to the first app-declared OUT parameter. When executing prepared and callable statements and/or statements that produce cursored results, the first OUT parameters returned by the server contain the internal values like the prepared statement handle and the cursor ID and row count. This value indicates how many of those internal OUT parameters were in the response.
        • parameterNames
          java.util.ArrayList<java.lang.String> parameterNames
          Array with parameter names generated in buildParamTypeDefinitions For mapping encryption information to parameters, as the second result set returned by sp_describe_parameter_encryption doesn't depend on order of input parameter
        • preparedSQL
          java.lang.String preparedSQL
          SQL statement with expanded parameter tokens
        • preparedTypeDefinitions
          java.lang.String preparedTypeDefinitions
          The prepared type definitions
        • prepStmtHandle
          int prepStmtHandle
          The prepared statement handle returned by the server
        • sqlTextCacheKey
          com.microsoft.sqlserver.jdbc.SQLServerConnection.CityHash128Key sqlTextCacheKey
          Hash of user supplied SQL statement used for various cache lookups
        • useBulkCopyForBatchInsert
          boolean useBulkCopyForBatchInsert
          boolean value for deciding if the driver should use bulk copy API for batch inserts
        • useFmtOnly
          boolean useFmtOnly
          user FMTOnly flag
        • userSQL
          java.lang.String userSQL
          Processed SQL statement text, may not be same as what user initially passed.
        • userSQLParamPositions
          int[] userSQLParamPositions
          Parameter positions in processed SQL statement text.
    • Class com.microsoft.sqlserver.jdbc.SQLServerResultSet extends java.lang.Object implements Serializable

      serialVersionUID:
      -1624082547992040463L
      • Serialized Fields

        • activeLOB
          com.microsoft.sqlserver.jdbc.SQLServerLob activeLOB
          active LOB
        • areNullCompressedColumnsInitialized
          boolean areNullCompressedColumnsInitialized
          Indicates if the null bit map is loaded for the current row in the resultset
        • cekTable
          com.microsoft.sqlserver.jdbc.CekTable cekTable
          The CekTable retrieved from the COLMETADATA token for this resultset
        • columnNames
          java.util.Map<java.lang.String,​java.lang.Integer> columnNames
          Column name hash map for caching
        • columns
          com.microsoft.sqlserver.jdbc.Column[] columns
          The current row's column values
        • currentRow
          int currentRow
          current row
        • deletedCurrentRow
          boolean deletedCurrentRow
          Flag set to true if the current row was deleted through this ResultSet object
        • fetchBuffer
          com.microsoft.sqlserver.jdbc.SQLServerResultSet.FetchBuffer fetchBuffer
          fetch buffer
        • fetchDirection
          int fetchDirection
          the intended fetch direction to optimize cursor performance
        • fetchSize
          int fetchSize
          the desired fetch size to optimize cursor performance
        • isClosed
          boolean isClosed
          is the result set close
        • isOnInsertRow
          boolean isOnInsertRow
          true if the cursor is positioned on the insert row
        • lastColumnIndex
          int lastColumnIndex
          The index (1-based) of the last column in the current row that has been marked for reading
        • lastValueWasNull
          boolean lastValueWasNull
          true if the last value read was SQL NULL
        • loggingClassName
          java.lang.String loggingClassName
          logging classname
        • maxRows
          int maxRows
          max rows to return from this result set
        • metaData
          SQLServerResultSetMetaData metaData
          the meta data for this result set
        • numFetchedRows
          int numFetchedRows
          Absolute position in this ResultSet where the fetch buffer starts
        • resultSetCurrentRowType
          com.microsoft.sqlserver.jdbc.RowType resultSetCurrentRowType
          Indicates the type of the current row in the result set
        • rowCount
          int rowCount
          row count
        • rowErrorException
          SQLServerException rowErrorException
          row error exception
        • scrollWindow
          com.microsoft.sqlserver.jdbc.ScrollWindow scrollWindow
          A window of fetchSize quickly accessible rows for scrollable result sets
        • serverCursorId
          int serverCursorId
          server cursor id
        • stmt
          SQLServerStatement stmt
          the statement that generated this result set
        • tdsReader
          com.microsoft.sqlserver.jdbc.TDSReader tdsReader
          TDS reader from which row values are read
        • traceID
          java.lang.String traceID
          trace ID
        • updatedCurrentRow
          boolean updatedCurrentRow
          Flag set to true if the current row was updated through this ResultSet object
    • Class com.microsoft.sqlserver.jdbc.SQLServerResultSetMetaData extends java.lang.Object implements Serializable

      serialVersionUID:
      -5747558730471411712L
    • Class com.microsoft.sqlserver.jdbc.SQLServerSavepoint extends java.lang.Object implements Serializable

      serialVersionUID:
      1857415943191289598L
      • Serialized Fields

    • Class com.microsoft.sqlserver.jdbc.SQLServerStatement extends java.lang.Object implements Serializable

      serialVersionUID:
      -4421134713913331507L
      • Serialized Fields

        • appResultSetType
          int appResultSetType
          The app result set type. This is the value passed to the statement's constructor (or inferred by default) when the statement was created. ResultSet.getType() returns this value. It may differ from the SQL Server result set type (see below). Namely, an app result set type of TYPE_FORWARD_ONLY will have an SQL Server result set type of TYPE_SS_DIRECT_FORWARD_ONLY or TYPE_SS_SERVER_CURSOR_FORWARD_ONLY depending on the value of the selectMethod connection property. Possible values of the app result set type are: TYPE_FORWARD_ONLY TYPE_SCROLL_INSENSITIVE TYPE_SCROLL_SENSITIVE TYPE_SS_DIRECT_FORWARD_ONLY TYPE_SS_SERVER_CURSOR_FORWARD_ONLY TYPE_SS_SCROLL_DYNAMIC TYPE_SS_SCROLL_KEYSET TYPE_SS_SCROLL_STATIC
        • autoGeneratedKeys
          java.sql.ResultSet autoGeneratedKeys
          The result set if auto generated keys were requested.
        • batchStatementBuffer
          java.util.ArrayList<java.lang.String> batchStatementBuffer
          The buffer that accumulates batchable statements
        • bIsClosed
          boolean bIsClosed
          True is the statement is closed
        • bRequestedGeneratedKeys
          boolean bRequestedGeneratedKeys
          True if the user requested to driver to generate insert keys
        • cancelQueryTimeoutSeconds
          int cancelQueryTimeoutSeconds
          timeout value for canceling the query timeout
        • connection
          SQLServerConnection connection
          The statement's connection.
        • currentCommand
          com.microsoft.sqlserver.jdbc.TDSCommand currentCommand
          Currently executing or most recently executed TDSCommand (statement cmd, server cursor cmd, ...) subject to cancellation through Statement.cancel. Note: currentCommand is declared volatile to ensure that the JVM always returns the most recently set value for currentCommand to the cancelling thread.
        • cursorName
          java.lang.String cursorName
          The cursor name.
        • defaultFetchSize
          int defaultFetchSize
          default fetch size
        • escapeProcessing
          boolean escapeProcessing
          The status of escape processing.
        • execProps
          com.microsoft.sqlserver.jdbc.SQLServerStatement.ExecuteProperties execProps
          execute properties
        • executedSqlDirectly
          boolean executedSqlDirectly
          Indicates whether SQL Server executed this statement with a cursor or not. When trying to execute a cursor-unfriendly statement with a server cursor, SQL Server may choose to execute the statement directly (i.e. as if no server cursor had been requested) rather than fail to execute the statement at all. We need to know when this happens so that if no rows are returned, we can tell whether the result is an empty result set or a cursored result set with rows to be fetched later.
        • executeMethod
          int executeMethod
          execute method
        • expectCursorOutParams
          boolean expectCursorOutParams
          Indicates whether OUT parameters (cursor ID and row count) from cursorized execution of this statement are expected in the response. In most cases, except for severe errors, cursor OUT parameters are returned whenever a cursor is requested for statement execution. Even if SQL Server does not cursorize the statement as requested, these values are still present in the response and must be processed, even though their values are meaningless in that case.
        • inOutParam
          com.microsoft.sqlserver.jdbc.Parameter[] inOutParam
          The input and out parameters for statement execution.
        • isCloseOnCompletion
          boolean isCloseOnCompletion
          Is closeOnCompletion is enabled? If true statement will be closed when all of its dependent result sets are closed
        • isInternalEncryptionQuery
          boolean isInternalEncryptionQuery
          Flag to indicate that it is an internal query to retrieve encryption metadata.
        • isResponseBufferingAdaptive
          boolean isResponseBufferingAdaptive
          response buffer adaptive flag
        • lastStmtExecCmd
          com.microsoft.sqlserver.jdbc.TDSCommand lastStmtExecCmd
          last statment exec command
        • loggingClassName
          java.lang.String loggingClassName
          logging class name
        • maxFieldSize
          int maxFieldSize
          Limit for the size of data (in bytes) returned for any column value
        • maxRows
          int maxRows
          Limit for the maximum number of rows in a ResultSet
        • moreResults
          boolean moreResults
          Flag to indicate that are potentially more results (ResultSets, update counts, or errors) to be processed in the response.
        • nFetchDirection
          int nFetchDirection
          The users specified result set fetch direction
        • nFetchSize
          int nFetchSize
          The user's specified fetch size. Only used for server side result sets. Client side cursors read all rows.
        • procedureName
          java.lang.String procedureName
          the stored procedure name to call (if there is one)
        • queryTimeout
          int queryTimeout
          The user's specifed query timeout (in seconds).
        • resultSet
          SQLServerResultSet resultSet
          The statement's current result set.
        • resultSetConcurrency
          int resultSetConcurrency
          The user's specified result set concurrency.
        • resultSetCount
          int resultSetCount
          The number of opened result sets in the statement.
        • resultSetType
          int resultSetType
          The SQL Server result set type. This is the value used everywhere EXCEPT ResultSet.getType(). This value may or may not be the same as the app result set type (above). Possible values of the SQL Server result set type are: TYPE_SS_DIRECT_FORWARD_ONLY TYPE_SS_SERVER_CURSOR_FORWARD_ONLY TYPE_SS_SCROLL_DYNAMIC TYPE_SS_SCROLL_KEYSET TYPE_SS_SCROLL_STATIC
        • serverCursorId
          int serverCursorId
          OUT parameters associated with this statement's execution
        • serverCursorRowCount
          int serverCursorRowCount
          server cursor row count
        • sqlWarnings
          java.util.Vector<java.sql.SQLWarning> sqlWarnings
          the SQL warnings chain
        • stmtColumnEncriptionSetting
          SQLServerStatementColumnEncryptionSetting stmtColumnEncriptionSetting
          Column Encryption Override. Defaults to the connection setting, in which case it will be Enabled if columnEncryptionSetting = true in the connection setting, Disabled if false. This may also be used to set other behavior which overrides connection level setting.
        • stmtPoolable
          boolean stmtPoolable
          The value of the poolable state
        • tdsReader
          com.microsoft.sqlserver.jdbc.TDSReader tdsReader
          Streaming access to the response TDS data stream
        • traceID
          java.lang.String traceID
          trace ID
        • updateCount
          long updateCount
          The update count returned from an update.
        • wasResponseBufferingSet
          boolean wasResponseBufferingSet
          flag if response buffering is set
    • Class com.microsoft.sqlserver.jdbc.SQLServerXAConnection extends SQLServerPooledConnection implements Serializable

      serialVersionUID:
      -8154621218821899459L
      • Serialized Fields

        • physicalControlConnection
          SQLServerConnection physicalControlConnection
          physical connection
        • xaLogger
          java.util.logging.Logger xaLogger
          logger
        • XAResource
          SQLServerXAResource XAResource
          NB These instances are not used by applications, only by the app server who is providing the connection pool and transactional processing to the application. That app server is the one who should restrict commit/rollback on the connections it issues to applications, not the driver. These instances can and must commit/rollback
    • Class com.microsoft.sqlserver.jdbc.SQLServerXADataSource extends SQLServerConnectionPoolDataSource implements Serializable

      • Serialization Methods

        • readObject
          private void readObject​(java.io.ObjectInputStream stream) throws java.io.InvalidObjectException
          For added security/robustness, the only way to rehydrate a serialized SQLServerXADataSource is to use a SerializationProxy. Direct use of readObject() is not supported.
          Throws:
          java.io.InvalidObjectException - if error
        • writeReplace
          private java.lang.Object writeReplace() throws java.io.ObjectStreamException
          writeReplace
          Throws:
          java.io.ObjectStreamException - if error
  • Package microsoft.sql

    • Class microsoft.sql.DateTimeOffset extends java.lang.Object implements Serializable

      serialVersionUID:
      541973748553014280L
      • Serialization Methods

        • readObject
          private void readObject​(java.io.ObjectInputStream stream) throws java.io.InvalidObjectException
          readObject
          Throws:
          java.io.InvalidObjectException - if error
        • writeReplace
          private java.lang.Object writeReplace()
          writeReplace
      • Serialized Fields

        • formattedValue
          java.lang.String formattedValue
          formatted value
        • minutesOffset
          int minutesOffset
          minutes offset
        • nanos
          int nanos
          nano sec
        • utcMillis
          long utcMillis
          UTC ms