Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 

A

abort(Executor) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
absolute(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
AbstractAlterParser - Class in io.shardingsphere.core.parsing.parser.sql.ddl.alter
Alter parser.
AbstractAlterParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.alter.AbstractAlterParser
 
AbstractBestEffortsDeliveryJobConfiguration - Class in io.shardingsphere.transaction.api.config
Best efforts delivery job's configuration.
AbstractBestEffortsDeliveryJobConfiguration() - Constructor for class io.shardingsphere.transaction.api.config.AbstractBestEffortsDeliveryJobConfiguration
 
AbstractConnectionAdapter - Class in io.shardingsphere.core.jdbc.adapter
Adapter for Connection.
AbstractConnectionAdapter() - Constructor for class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
AbstractCreateParser - Class in io.shardingsphere.core.parsing.parser.sql.ddl.create
Create parser.
AbstractCreateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.create.AbstractCreateParser
 
AbstractDALParser - Class in io.shardingsphere.core.parsing.parser.sql.dal
Database administrator parser.
AbstractDALParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.AbstractDALParser
 
AbstractDataSourceAdapter - Class in io.shardingsphere.core.jdbc.adapter
Adapter for Datasource.
AbstractDataSourceAdapter(Collection<DataSource>) - Constructor for class io.shardingsphere.core.jdbc.adapter.AbstractDataSourceAdapter
 
AbstractDeleteClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.clause.facade
Delete clause parser facade.
AbstractDeleteClauseParserFacade() - Constructor for class io.shardingsphere.core.parsing.parser.clause.facade.AbstractDeleteClauseParserFacade
 
AbstractDeleteParser - Class in io.shardingsphere.core.parsing.parser.sql.dml.delete
Delete parser.
AbstractDeleteParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.delete.AbstractDeleteParser
 
AbstractDescribeParser - Class in io.shardingsphere.core.parsing.parser.sql.dal.describe
Describe parser.
AbstractDescribeParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.describe.AbstractDescribeParser
 
AbstractDropParser - Class in io.shardingsphere.core.parsing.parser.sql.ddl.drop
Drop parser.
AbstractDropParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.drop.AbstractDropParser
 
AbstractExecutionEvent - Class in io.shardingsphere.core.executor.event
SQL execution event.
AbstractExecutionEvent() - Constructor for class io.shardingsphere.core.executor.event.AbstractExecutionEvent
 
AbstractInsertClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.clause.facade
Insert clause parser facade.
AbstractInsertClauseParserFacade() - Constructor for class io.shardingsphere.core.parsing.parser.clause.facade.AbstractInsertClauseParserFacade
 
AbstractInsertParser - Class in io.shardingsphere.core.parsing.parser.sql.dml.insert
Insert parser.
AbstractInsertParser(ShardingRule, ShardingMetaData, LexerEngine, AbstractInsertClauseParserFacade) - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.insert.AbstractInsertParser
 
AbstractMasterSlavePreparedStatementAdapter - Class in io.shardingsphere.core.jdbc.adapter
Master-slave adapter for PreparedStatement.
AbstractMasterSlavePreparedStatementAdapter() - Constructor for class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
AbstractOrchestrationBeanDefinitionParser - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Abstract orchestration parser for spring namespace.
AbstractOrchestrationBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.AbstractOrchestrationBeanDefinitionParser
 
AbstractRefreshHandler - Class in io.shardingsphere.core.metadata
abstract class for refreshing sharding metadata.
AbstractRefreshHandler() - Constructor for class io.shardingsphere.core.metadata.AbstractRefreshHandler
 
AbstractResultSetAdapter - Class in io.shardingsphere.core.jdbc.adapter
Adapter for ResultSet.
AbstractResultSetAdapter(List<ResultSet>, Statement) - Constructor for class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
AbstractSelectClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.clause.facade
Select clause parser facade.
AbstractSelectClauseParserFacade() - Constructor for class io.shardingsphere.core.parsing.parser.clause.facade.AbstractSelectClauseParserFacade
 
AbstractSelectParser - Class in io.shardingsphere.core.parsing.parser.sql.dql.select
Select parser.
AbstractSelectParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
AbstractShardingPreparedStatementAdapter - Class in io.shardingsphere.core.jdbc.adapter
Sharding adapter for PreparedStatement.
AbstractShardingPreparedStatementAdapter() - Constructor for class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
AbstractShowParser - Class in io.shardingsphere.core.parsing.parser.sql.dal.show
Show parser.
AbstractShowParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.show.AbstractShowParser
 
AbstractSoftTransaction - Class in io.shardingsphere.transaction.api
B.A.S.E transaction abstract class.
AbstractSoftTransaction() - Constructor for class io.shardingsphere.transaction.api.AbstractSoftTransaction
 
AbstractSQLExecutionEvent - Class in io.shardingsphere.core.executor.event
SQL execution event.
AbstractSQLExecutionEvent() - Constructor for class io.shardingsphere.core.executor.event.AbstractSQLExecutionEvent
 
AbstractSQLStatement - Class in io.shardingsphere.core.parsing.parser.sql
SQL statement abstract class.
AbstractSQLStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.AbstractSQLStatement
 
AbstractStatementAdapter - Class in io.shardingsphere.core.jdbc.adapter
Adapter for Statement.
AbstractStatementAdapter() - Constructor for class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
AbstractTruncateParser - Class in io.shardingsphere.core.parsing.parser.sql.ddl.truncate
Truncate parser.
AbstractTruncateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.truncate.AbstractTruncateParser
 
AbstractUnsupportedGeneratedKeysResultSet - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported ResultSet methods for generated keys.
AbstractUnsupportedGeneratedKeysResultSet() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
AbstractUnsupportedOperationConnection - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported Connection methods.
AbstractUnsupportedOperationConnection() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
AbstractUnsupportedOperationDataSource - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported Datasource methods.
AbstractUnsupportedOperationDataSource() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationDataSource
 
AbstractUnsupportedOperationPreparedStatement - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported PreparedStatement methods.
AbstractUnsupportedOperationPreparedStatement() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
AbstractUnsupportedOperationResultSet - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported ResultSet methods.
AbstractUnsupportedOperationResultSet() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
AbstractUnsupportedOperationStatement - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported Statement methods.
AbstractUnsupportedOperationStatement() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
AbstractUnsupportedUpdateOperationResultSet - Class in io.shardingsphere.core.jdbc.unsupported
Unsupported ResultSet methods.
AbstractUnsupportedUpdateOperationResultSet() - Constructor for class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
AbstractUpdateClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.clause.facade
Update clause parser facade.
AbstractUpdateClauseParserFacade() - Constructor for class io.shardingsphere.core.parsing.parser.clause.facade.AbstractUpdateClauseParserFacade
 
AbstractUpdateParser - Class in io.shardingsphere.core.parsing.parser.sql.dml.update
Update parser.
AbstractUpdateParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.update.AbstractUpdateParser
 
AbstractUseParser - Class in io.shardingsphere.core.parsing.parser.sql.dal.use
Use parser.
AbstractUseParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.use.AbstractUseParser
 
accept(TokenType) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Assert current token type should equals input token and go to next token type.
AccumulationAggregationUnit - Class in io.shardingsphere.core.merger.dql.groupby.aggregation
Accumulation aggregation unit.
AccumulationAggregationUnit() - Constructor for class io.shardingsphere.core.merger.dql.groupby.aggregation.AccumulationAggregationUnit
 
ACTUAL_DATA_NODES_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
ACTUAL_DATA_NODES_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
add(Condition, ShardingRule) - Method in class io.shardingsphere.core.parsing.parser.context.condition.Conditions
Add condition.
add(Condition) - Method in class io.shardingsphere.core.parsing.parser.context.condition.OrCondition
Add condition.
add(Table) - Method in class io.shardingsphere.core.parsing.parser.context.table.Tables
添加表解析对象.
add(TransactionLog) - Method in class io.shardingsphere.transaction.storage.impl.MemoryTransactionLogStorage
 
add(TransactionLog) - Method in class io.shardingsphere.transaction.storage.impl.RdbTransactionLogStorage
 
add(TransactionLog) - Method in interface io.shardingsphere.transaction.storage.TransactionLogStorage
Save transaction log.
addBatch() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
addBatch() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
addBatch(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
addBatch() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
addDatabaseShardingValue(String, String, Comparable<?>) - Method in class io.shardingsphere.core.api.HintManager
Add sharding value for database.
addDatabaseShardingValue(String, String, ShardingOperator, Comparable<?>...) - Method in class io.shardingsphere.core.api.HintManager
Add sharding value for database.
addPacket(DatabaseProtocolPacket) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandResponsePackets
Add packet.
addTableShardingValue(String, String, Comparable<?>) - Method in class io.shardingsphere.core.api.HintManager
Add sharding value for table.
addTableShardingValue(String, String, ShardingOperator, Comparable<?>...) - Method in class io.shardingsphere.core.api.HintManager
Add sharding value for table.
afterLast() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
afterPropertiesSet() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
afterPropertiesSet() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
AggregationSelectItem - Class in io.shardingsphere.core.parsing.parser.context.selectitem
Aggregation select item.
AggregationSelectItem() - Constructor for class io.shardingsphere.core.parsing.parser.context.selectitem.AggregationSelectItem
 
AggregationType - Enum in io.shardingsphere.core.constant
Aggregation function enum.
AggregationUnit - Interface in io.shardingsphere.core.merger.dql.groupby.aggregation
Aggregation unit interface.
AggregationUnitFactory - Class in io.shardingsphere.core.merger.dql.groupby.aggregation
Aggregation unit factory.
AggregationUnitFactory() - Constructor for class io.shardingsphere.core.merger.dql.groupby.aggregation.AggregationUnitFactory
 
ALGORITHM_EXPRESSION_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
ALGORITHM_EXPRESSION_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
ALGORITHM_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
ALGORITHM_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
AliasExpressionParser - Class in io.shardingsphere.core.parsing.parser.clause.expression
Alias expression parser.
AliasExpressionParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.expression.AliasExpressionParser
 
allProceduresAreCallable() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
allTablesAreSelectable() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
AlterParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.ddl.alter
Alter parser factory.
AlterParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.alter.AlterParserFactory
 
AlwaysFalseShardingCondition - Class in io.shardingsphere.core.optimizer.query
Always false sharding condition.
AlwaysFalseShardingCondition() - Constructor for class io.shardingsphere.core.optimizer.query.AlwaysFalseShardingCondition
 
AlwaysFalseShardingValue - Class in io.shardingsphere.core.optimizer.query
Always false sharding value.
AlwaysFalseShardingValue() - Constructor for class io.shardingsphere.core.optimizer.query.AlwaysFalseShardingValue
 
AndCondition - Class in io.shardingsphere.core.parsing.parser.context.condition
And conditions.
AndCondition() - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.AndCondition
 
appendLiterals(String) - Method in class io.shardingsphere.core.rewrite.SQLBuilder
Append literals.
appendPlaceholder(ShardingPlaceholder) - Method in class io.shardingsphere.core.rewrite.SQLBuilder
Append sharding placeholder.
Assist - Enum in io.shardingsphere.core.parsing.lexer.token
Assist token.
AsyncSoftTransactionJobConfiguration - Class in io.shardingsphere.transaction.config
Asynchronized B.A.S.E transaction job configuration.
AsyncSoftTransactionJobConfiguration() - Constructor for class io.shardingsphere.transaction.config.AsyncSoftTransactionJobConfiguration
 
auth(ChannelHandlerContext, ByteBuf) - Method in class io.shardingsphere.proxy.frontend.common.FrontendHandler
 
auth(ChannelHandlerContext, ByteBuf) - Method in class io.shardingsphere.proxy.frontend.mysql.MySQLFrontendHandler
 
AuthPluginData - Class in io.shardingsphere.proxy.transport.mysql.packet.handshake
Auth plugin data.
AuthPluginData() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.handshake.AuthPluginData
 
autoCommitFailureClosesAllResultSets() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
AverageAggregationUnit - Class in io.shardingsphere.core.merger.dql.groupby.aggregation
Average aggregation unit.
AverageAggregationUnit() - Constructor for class io.shardingsphere.core.merger.dql.groupby.aggregation.AverageAggregationUnit
 

B

BackendHandler - Interface in io.shardingsphere.proxy.backend.common
Backend handler.
BASE_SLEEP_TIME_MILLISECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
BaseStatementUnit - Interface in io.shardingsphere.core.executor
Statement execute unit interface.
BASETransactionJob - Class in io.shardingsphere.transaction.job
B.A.S.E transaction job.
BASETransactionJob() - Constructor for class io.shardingsphere.transaction.job.BASETransactionJob
 
BASETransactionJobBootStrap - Class in io.shardingsphere.transaction.job
B.A.S.E transaction job main entrance.
BASETransactionJobBootStrap() - Constructor for class io.shardingsphere.transaction.job.BASETransactionJobBootStrap
 
BASETransactionJobConfiguration - Class in io.shardingsphere.transaction.job
B.A.S.E transaction job configuration.
BASETransactionJobConfiguration() - Constructor for class io.shardingsphere.transaction.job.BASETransactionJobConfiguration
 
BASETransactionJobFactory - Class in io.shardingsphere.transaction.job
B.A.S.E transaction job factory.
BASETransactionJobFactory() - Constructor for class io.shardingsphere.transaction.job.BASETransactionJobFactory
 
BasicExpressionParser - Class in io.shardingsphere.core.parsing.parser.clause.expression
Basic expression parser.
BasicExpressionParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.expression.BasicExpressionParser
 
BatchPreparedStatementExecutor - Class in io.shardingsphere.core.executor.type.batch
PreparedStatement Executor for multiple threads to process add batch.
BatchPreparedStatementExecutor() - Constructor for class io.shardingsphere.core.executor.type.batch.BatchPreparedStatementExecutor
 
BatchPreparedStatementUnit - Class in io.shardingsphere.core.executor.type.batch
PreparedStatement add batch execute unit.
BatchPreparedStatementUnit() - Constructor for class io.shardingsphere.core.executor.type.batch.BatchPreparedStatementUnit
 
BEDSoftTransaction - Class in io.shardingsphere.transaction.bed
Best efforts delivery B.A.S.E transaction.
BEDSoftTransaction() - Constructor for class io.shardingsphere.transaction.bed.BEDSoftTransaction
 
beforeFirst() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
begin(Connection) - Method in class io.shardingsphere.transaction.bed.BEDSoftTransaction
Begin transaction.
begin(Connection) - Method in class io.shardingsphere.transaction.tcc.TCCSoftTransaction
Begin transaction.
beginInternal(Connection, SoftTransactionType) - Method in class io.shardingsphere.transaction.api.AbstractSoftTransaction
 
BestEffortsDeliveryListener - Class in io.shardingsphere.transaction.bed.sync
Best efforts delivery B.A.S.E transaction listener.
BestEffortsDeliveryListener() - Constructor for class io.shardingsphere.transaction.bed.sync.BestEffortsDeliveryListener
 
BinaryProtocolValueUtility - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
Binary protocol value.
BinaryProtocolValueUtility() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.BinaryProtocolValueUtility
 
BinaryResultSetRowPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
Binary result set row packet.
BinaryResultSetRowPacket(int, int, List<Object>, List<ColumnType>) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.BinaryResultSetRowPacket
 
BINDING_TABLE_RULE_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
BINDING_TABLE_RULE_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
BINDING_TABLE_RULES_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
BINDING_TABLE_RULES_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
BindingTableRule - Class in io.shardingsphere.core.rule
Binding table rule configuration.
BindingTableRule() - Constructor for class io.shardingsphere.core.rule.BindingTableRule
 
Bootstrap - Class in io.shardingsphere.proxy
Sharding-Proxy Bootstrap.
Bootstrap() - Constructor for class io.shardingsphere.proxy.Bootstrap
 
build(SQLRouteResult, ShardingConnection) - Static method in class io.shardingsphere.core.jdbc.metadata.dialect.JDBCShardingRefreshHandler
create new instance of JDBCShardingRefreshHandler.
build() - Method in class io.shardingsphere.core.yaml.sharding.YamlShardingStrategyConfiguration
Build sharding strategy configuration.
build() - Method in class io.shardingsphere.core.yaml.sharding.YamlTableRuleConfiguration
Build table rule configuration.
build(SQLRouteResult) - Static method in class io.shardingsphere.proxy.metadata.ProxyShardingRefreshHandler
create new instance of ProxyShardingRefreshHandler.
buildTransactionLogDataSource() - Method in class io.shardingsphere.transaction.api.config.SoftTransactionConfiguration
Build transaction log data source.

C

calculateHandshakeCapabilityFlagsLower() - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.CapabilityFlag
Get handshake capability flags lower bit.
calculateHandshakeCapabilityFlagsUpper() - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.CapabilityFlag
Get handshake capability flags upper bit.
cancel() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
cancel() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
cancelRowUpdates() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
canRefreshMetaData() - Method in class io.shardingsphere.core.routing.SQLRouteResult
whether SQLRouteResult can refresh table metadata.
CapabilityFlag - Enum in io.shardingsphere.proxy.transport.mysql.constant
Capability flag.
CartesianRoutingEngine - Class in io.shardingsphere.core.routing.type.complex
cartesian routing engine.
CartesianRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.complex.CartesianRoutingEngine
 
changeValueArgument(Object) - Method in class io.shardingsphere.core.jdbc.adapter.invocation.SetParameterMethodInvocation
Set argument.
channelActive(ChannelHandlerContext) - Method in class io.shardingsphere.proxy.frontend.common.FrontendHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.shardingsphere.proxy.frontend.common.FrontendHandler
 
CHARSET - Static variable in interface io.shardingsphere.proxy.transport.mysql.constant.ServerInfo
Charset code 0x21 is utf8_general_ci.
CharType - Class in io.shardingsphere.core.parsing.lexer.analyzer
Char type.
CharType() - Constructor for class io.shardingsphere.core.parsing.lexer.analyzer.CharType
 
CircuitBreakerConnection - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.connection
Circuit breaker connection.
CircuitBreakerConnection() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
CircuitBreakerDatabaseMetaData - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata
Circuit breaker metadata.
CircuitBreakerDatabaseMetaData() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
CircuitBreakerDataSource - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource
Circuit breaker datasource.
CircuitBreakerDataSource() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
CircuitBreakerPreparedStatement - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.statement
Circuit breaker preparedStatement.
CircuitBreakerPreparedStatement() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
CircuitBreakerResultSet - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset
Circuit breaker result set.
CircuitBreakerResultSet() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
CircuitBreakerResultSetMetaData - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset
Circuit breaker result set metadata.
CircuitBreakerResultSetMetaData() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
CircuitBreakerStatement - Class in io.shardingsphere.jdbc.orchestration.internal.jdbc.statement
Circuit breaker statement.
CircuitBreakerStatement() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
CLAZZ_NAME - Static variable in class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceGsonTypeConstants
 
clear() - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Clear hint manager for current thread-local.
clear() - Method in class io.shardingsphere.core.parsing.cache.ParsingResultCache
Clear cache.
clear() - Static method in class io.shardingsphere.core.routing.router.masterslave.MasterVisitedManager
Clear master data source visited.
clearBatch() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
clearBatch() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
clearBatch() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
clearBatch() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
clearParameters() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
clearParameters() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
clearParameters() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
clearWarnings() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
clearWarnings() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
clearWarnings() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
clearWarnings() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
clearWarnings() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
clearWarnings() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
clearWarnings() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
close() - Method in class io.shardingsphere.core.api.HintManager
 
close() - Method in class io.shardingsphere.core.executor.ExecutorEngine
 
close() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
close() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
close() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
close() - Method in class io.shardingsphere.core.jdbc.core.datasource.ShardingDataSource
 
close() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationFacade
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationMasterSlaveDataSource
 
close() - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationShardingDataSource
 
close() - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
close() - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.keepalive.KeepAlive
 
close() - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
closeOnCompletion() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
Column - Class in io.shardingsphere.core.parsing.parser.context.condition
Column.
Column() - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.Column
 
ColumnDefinition41Packet - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.query
Column definition above MySQL 4.1 packet protocol.
ColumnDefinition41Packet(int, String, String, String, String, String, int, ColumnType, int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ColumnDefinition41Packet
 
ColumnDefinition41Packet(MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ColumnDefinition41Packet
 
ColumnMetaData - Class in io.shardingsphere.core.metadata
Column metadata.
ColumnMetaData() - Constructor for class io.shardingsphere.core.metadata.ColumnMetaData
 
ColumnType - Enum in io.shardingsphere.proxy.transport.mysql.constant
Column types.
ComFieldListPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist
COM_FIELD_LIST command packet.
ComFieldListPacket(int, MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist.ComFieldListPacket
 
ComInitDbPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb
COM_INIT_DB command packet.
ComInitDbPacket(int, MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb.ComInitDbPacket
 
CommandPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command
Command packet.
CommandPacket(int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacket
 
CommandPacketFactory - Class in io.shardingsphere.proxy.transport.mysql.packet.command
Command packet factory.
CommandPacketFactory() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacketFactory
 
CommandPacketType - Enum in io.shardingsphere.proxy.transport.mysql.packet.command
Command packet type.
CommandResponsePackets - Class in io.shardingsphere.proxy.transport.mysql.packet.command
Command response packet.
CommandResponsePackets(DatabaseProtocolPacket) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.CommandResponsePackets
 
commit() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
commit() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
CommonSelectItem - Class in io.shardingsphere.core.parsing.parser.context.selectitem
Common select item.
CommonSelectItem() - Constructor for class io.shardingsphere.core.parsing.parser.context.selectitem.CommonSelectItem
 
ComparableAggregationUnit - Class in io.shardingsphere.core.merger.dql.groupby.aggregation
Comparable aggregation unit.
ComparableAggregationUnit() - Constructor for class io.shardingsphere.core.merger.dql.groupby.aggregation.ComparableAggregationUnit
 
compare(MemoryQueryResultRow, MemoryQueryResultRow) - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByRowComparator
 
compareTo(Comparable, Comparable, OrderDirection, OrderDirection) - Static method in class io.shardingsphere.core.merger.dql.orderby.CompareUtil
Compare two object with order type.
compareTo(OrderByValue) - Method in class io.shardingsphere.core.merger.dql.orderby.OrderByValue
 
CompareUtil - Class in io.shardingsphere.core.merger.dql.orderby
Compare util.
CompareUtil() - Constructor for class io.shardingsphere.core.merger.dql.orderby.CompareUtil
 
ComPingPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.ping
COM_PING command packet.
ComPingPacket(int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.ping.ComPingPacket
 
COMPLEX_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
COMPLEX_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
ComplexKeysShardingAlgorithm - Interface in io.shardingsphere.core.api.algorithm.sharding.complex
Complex keys sharding algorithm.
ComplexRoutingEngine - Class in io.shardingsphere.core.routing.type.complex
Complex routing engine.
ComplexRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.complex.ComplexRoutingEngine
 
ComplexShardingStrategy - Class in io.shardingsphere.core.routing.strategy.complex
Complex sharding strategy.
ComplexShardingStrategy(ComplexShardingStrategyConfiguration) - Constructor for class io.shardingsphere.core.routing.strategy.complex.ComplexShardingStrategy
 
ComplexShardingStrategyConfiguration - Class in io.shardingsphere.core.api.config.strategy
Complex sharding strategy configuration.
ComplexShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.api.config.strategy.ComplexShardingStrategyConfiguration
 
ComQueryPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.query
COM_QUERY command packet.
ComQueryPacket(int, MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ComQueryPacket
 
ComQuitPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.quit
COM_QUIT command packet.
ComQuitPacket(int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.quit.ComQuitPacket
 
ComStmtClosePacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.close
COM_STMT_CLOSE command packet.
ComStmtClosePacket(int, MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.close.ComStmtClosePacket
 
ComStmtExecutePacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
COM_STMT_EXECUTE command packet.
ComStmtExecutePacket(int, MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.ComStmtExecutePacket
 
ComStmtPrepareOKPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare
COM_STMT_PREPARE_OK packet.
ComStmtPrepareOKPacket(int, int, int, int, int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPrepareOKPacket
 
ComStmtPreparePacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare
COM_STMT_PREPARE command packet.
ComStmtPreparePacket(int, MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPreparePacket
 
Condition - Class in io.shardingsphere.core.parsing.parser.context.condition
Condition.
Condition() - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.Condition
 
Condition(Column, SQLExpression) - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.Condition
 
Condition(Column, SQLExpression, SQLExpression) - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.Condition
 
Condition(Column, List<SQLExpression>) - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.Condition
 
Conditions - Class in io.shardingsphere.core.parsing.parser.context.condition
Conditions collection.
Conditions(Conditions) - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.Conditions
 
CONFIG_MAP_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
CONFIG_MAP_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
CONFIG_MAP_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
ConfigMapContext - Class in io.shardingsphere.core.api
The config map context.
ConfigMapContext() - Constructor for class io.shardingsphere.core.api.ConfigMapContext
 
ConfigMapListenerManager - Class in io.shardingsphere.jdbc.orchestration.internal.config
Config map listener manager.
ConfigMapListenerManager(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.config.ConfigMapListenerManager
 
ConfigurationListenerManager - Class in io.shardingsphere.jdbc.orchestration.internal.config
Configuration listener manager.
ConfigurationListenerManager(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationListenerManager
 
ConfigurationLoader - Class in io.shardingsphere.opentracing.config
Config loader.
ConfigurationLoader() - Constructor for class io.shardingsphere.opentracing.config.ConfigurationLoader
 
ConfigurationNode - Class in io.shardingsphere.jdbc.orchestration.internal.config
Data configuration node.
ConfigurationNode() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
ConfigurationService - Class in io.shardingsphere.jdbc.orchestration.internal.config
Configuration service.
ConfigurationService(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
 
CONNECTION_TIMEOUT_MILLISECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
ConnectionIdGenerator - Class in io.shardingsphere.proxy.transport.mysql.packet.handshake
Connection ID generator.
ConnectionIdGenerator() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.handshake.ConnectionIdGenerator
 
containsSubQuery() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Adjust contains sub query statement or not.
convertValue(Object, Class<?>) - Static method in class io.shardingsphere.core.jdbc.core.resultset.ResultSetUtil
Convert value via expected class type.
create(AggregationType) - Static method in class io.shardingsphere.core.merger.dql.groupby.aggregation.AggregationUnitFactory
Create aggregation unit instance.
createAliasExpressionParser(LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.dialect.ExpressionParserFactory
Create alias parser instance.
createArrayOf(String, Object[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
createBasicExpressionParser(LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.dialect.ExpressionParserFactory
Create expression parser instance.
createBlob() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
createClob() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
createDataSource(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>) - Static method in class io.shardingsphere.core.api.MasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties) - Static method in class io.shardingsphere.core.api.ShardingDataSourceFactory
Create sharding data source.
createDataSource(File) - Static method in class io.shardingsphere.core.api.yaml.YamlMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(byte[]) - Static method in class io.shardingsphere.core.api.yaml.YamlMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(Map<String, DataSource>, File) - Static method in class io.shardingsphere.core.api.yaml.YamlMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(Map<String, DataSource>, byte[]) - Static method in class io.shardingsphere.core.api.yaml.YamlMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(File) - Static method in class io.shardingsphere.core.api.yaml.YamlShardingDataSourceFactory
Create sharding data source.
createDataSource(byte[]) - Static method in class io.shardingsphere.core.api.yaml.YamlShardingDataSourceFactory
Create sharding data source.
createDataSource(Map<String, DataSource>, File) - Static method in class io.shardingsphere.core.api.yaml.YamlShardingDataSourceFactory
Create sharding data source.
createDataSource(Map<String, DataSource>, byte[]) - Static method in class io.shardingsphere.core.api.yaml.YamlShardingDataSourceFactory
Create sharding data source.
createDataSource(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>, OrchestrationConfiguration) - Static method in class io.shardingsphere.jdbc.orchestration.api.OrchestrationMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(OrchestrationConfiguration) - Static method in class io.shardingsphere.jdbc.orchestration.api.OrchestrationMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties, OrchestrationConfiguration) - Static method in class io.shardingsphere.jdbc.orchestration.api.OrchestrationShardingDataSourceFactory
Create sharding data source.
createDataSource(OrchestrationConfiguration) - Static method in class io.shardingsphere.jdbc.orchestration.api.OrchestrationShardingDataSourceFactory
Create sharding data source.
createDataSource(File) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(Map<String, DataSource>, File) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(byte[]) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(Map<String, DataSource>, byte[]) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationMasterSlaveDataSourceFactory
Create master-slave data source.
createDataSource(File) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationShardingDataSourceFactory
Create sharding data source.
createDataSource(Map<String, DataSource>, File) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationShardingDataSourceFactory
Create sharding data source.
createDataSource(byte[]) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationShardingDataSourceFactory
Create sharding data source.
createDataSource(Map<String, DataSource>, byte[]) - Static method in class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationShardingDataSourceFactory
Create sharding data source.
createFrontendHandlerInstance(DatabaseType, EventLoopGroup) - Static method in class io.shardingsphere.proxy.frontend.common.FrontendHandlerFactory
Create frontend handler instance.
createNClob() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
createPacketCodecInstance(DatabaseType) - Static method in class io.shardingsphere.proxy.transport.common.codec.PacketCodecFactory
Create packet codec instance.
CreateParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.ddl.create
Create parser factory.
CreateParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.create.CreateParserFactory
 
createSQLRouter(ShardingRule, ShardingMetaData, DatabaseType, boolean) - Static method in class io.shardingsphere.core.routing.router.sharding.ShardingRouterFactory
Create sharding router.
createSQLXML() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
createStatement() - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
createStatement(int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
createStatement(int, int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
createStatement() - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
createStatement(int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
createStatement(int, int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
createStatement() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
createStatement(int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
createStatement(int, int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
createStruct(String, Object[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
createTransactionLogStorage(TransactionLogDataSource) - Static method in class io.shardingsphere.transaction.storage.TransactionLogStorageFactory
Create transaction log storage.

D

DALMergeEngine - Class in io.shardingsphere.core.merger.dal
DAL result set merge engine.
DALMergeEngine() - Constructor for class io.shardingsphere.core.merger.dal.DALMergeEngine
 
DALStatement - Class in io.shardingsphere.core.parsing.parser.sql.dal
DAL statement.
DALStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.DALStatement
 
DATA_SOURCE_NAMES_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DATA_SOURCE_NAMES_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DATA_SOURCE_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
DATABASE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DATABASE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DatabaseBroadcastRoutingEngine - Class in io.shardingsphere.core.routing.type.broadcast
Broadcast routing engine for databases.
DatabaseBroadcastRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.broadcast.DatabaseBroadcastRoutingEngine
 
DatabaseHintRoutingEngine - Class in io.shardingsphere.core.routing.type.hint
Database hint only routing engine.
DatabaseHintRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.hint.DatabaseHintRoutingEngine
 
DatabaseHintSQLRouter - Class in io.shardingsphere.core.routing.router.sharding
Sharding router for hint database only.
DatabaseHintSQLRouter() - Constructor for class io.shardingsphere.core.routing.router.sharding.DatabaseHintSQLRouter
 
DatabaseProtocolPacket - Interface in io.shardingsphere.proxy.transport.common.packet
Database protocol packet.
DatabaseType - Enum in io.shardingsphere.core.constant
Supported database.
DataChangedEvent - Class in io.shardingsphere.jdbc.orchestration.reg.listener
Data changed event.
DataChangedEvent() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.listener.DataChangedEvent
 
DataChangedEvent.Type - Enum in io.shardingsphere.jdbc.orchestration.reg.listener
Data changed event type.
dataDefinitionCausesTransactionCommit() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
dataDefinitionIgnoredInTransactions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
DataNode - Class in io.shardingsphere.core.rule
Sharding data unit node.
DataNode(String) - Constructor for class io.shardingsphere.core.rule.DataNode
Constructs a data node with well-formatted string.
dataSource() - Method in class io.shardingsphere.jdbc.orchestration.spring.boot.OrchestrationSpringBootConfiguration
Get data source bean.
dataSource() - Method in class io.shardingsphere.jdbc.spring.boot.SpringBootConfiguration
Get data source bean.
DATASOURCE_NAME - Static variable in class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceGsonTypeConstants
 
DataSourceGsonTypeAdapter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Data source gson type adapter.
DataSourceGsonTypeAdapter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceGsonTypeAdapter
 
DataSourceGsonTypeConstants - Class in io.shardingsphere.jdbc.orchestration.internal.json
Data source constants for json.
DataSourceGsonTypeConstants() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceGsonTypeConstants
 
DataSourceJsonConverter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Data source map json converter.
DataSourceJsonConverter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceJsonConverter
 
DataSourceListenerManager - Class in io.shardingsphere.jdbc.orchestration.internal.state.datasource
Data source listener manager.
DataSourceListenerManager(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceListenerManager
 
DataSourceParameter - Class in io.shardingsphere.core.yaml.sharding
Data source parameters.
DataSourceParameter() - Constructor for class io.shardingsphere.core.yaml.sharding.DataSourceParameter
 
DataSourceService - Class in io.shardingsphere.jdbc.orchestration.internal.state.datasource
Data source service.
DataSourceService(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceService
 
DataSourceUtil - Class in io.shardingsphere.core.util
Data source utility class.
DataSourceUtil() - Constructor for class io.shardingsphere.core.util.DataSourceUtil
 
DB_COLUMN_NAME - Static variable in class io.shardingsphere.core.hint.HintManagerHolder
 
DB_TABLE_NAME - Static variable in class io.shardingsphere.core.hint.HintManagerHolder
 
DDLStatement - Class in io.shardingsphere.core.parsing.parser.sql.ddl
DDL statement.
DDLStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.DDLStatement
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class io.shardingsphere.proxy.transport.common.codec.PacketCodec
 
DecoratorMergedResult - Class in io.shardingsphere.core.merger.dql.common
Decorator merged result.
DecoratorMergedResult() - Constructor for class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
DEFAULT_DATA_SOURCE_NAME_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_DATA_SOURCE_NAME_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_DATABASE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_DATABASE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_KEY_GENERATOR_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_KEY_GENERATOR_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_TABLE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DEFAULT_TABLE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
DefaultKeyGenerator - Class in io.shardingsphere.core.keygen
Default distributed primary key generator.
DefaultKeyGenerator() - Constructor for class io.shardingsphere.core.keygen.DefaultKeyGenerator
 
DefaultKeyword - Enum in io.shardingsphere.core.parsing.lexer.token
Default keyword.
DefaultShardingMetaDataHandler - Class in io.shardingsphere.core.jdbc.metadata.dialect
MySQL table metadata handler.
DefaultShardingMetaDataHandler(DataSource, String) - Constructor for class io.shardingsphere.core.jdbc.metadata.dialect.DefaultShardingMetaDataHandler
 
DeleteParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dml.delete
Delete parser factory.
DeleteParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.delete.DeleteParserFactory
 
deleteRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
deletesAreDetected(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
DescribeParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dal.describe
Describe parser factory.
DescribeParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.describe.DescribeParserFactory
 
DescribeStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Describe statement.
DescribeStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.DescribeStatement
 
destroy() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
destroy() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
Dictionary - Class in io.shardingsphere.core.parsing.lexer.analyzer
Token dictionary.
Dictionary(Keyword...) - Constructor for class io.shardingsphere.core.parsing.lexer.analyzer.Dictionary
 
DIGEST_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
DistinctClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Distinct clause parser.
DistinctClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.DistinctClauseParser
 
DMLExecutionEvent - Class in io.shardingsphere.core.executor.event
DML execution event.
DMLExecutionEvent(String, SQLUnit, List<Object>) - Constructor for class io.shardingsphere.core.executor.event.DMLExecutionEvent
 
DMLStatement - Class in io.shardingsphere.core.parsing.parser.sql.dml
DML statement.
DMLStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.DMLStatement
 
doDecode(ChannelHandlerContext, ByteBuf, List<Object>, int) - Method in class io.shardingsphere.proxy.transport.common.codec.PacketCodec
 
doDecode(ChannelHandlerContext, ByteBuf, List<Object>, int) - Method in class io.shardingsphere.proxy.transport.mysql.codec.MySQLPacketCodec
 
doEncode(ChannelHandlerContext, T, ByteBuf) - Method in class io.shardingsphere.proxy.transport.common.codec.PacketCodec
 
doEncode(ChannelHandlerContext, MySQLPacket, ByteBuf) - Method in class io.shardingsphere.proxy.transport.mysql.codec.MySQLPacketCodec
 
doesMaxRowSizeIncludeBlobs() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
doSharding(Collection<String>, Collection<ShardingValue>) - Method in interface io.shardingsphere.core.api.algorithm.sharding.complex.ComplexKeysShardingAlgorithm
Sharding.
doSharding(Collection<String>, ShardingValue) - Method in interface io.shardingsphere.core.api.algorithm.sharding.hint.HintShardingAlgorithm
Sharding.
doSharding(Collection<String>, PreciseShardingValue<T>) - Method in interface io.shardingsphere.core.api.algorithm.sharding.standard.PreciseShardingAlgorithm
Sharding.
doSharding(Collection<String>, RangeShardingValue<T>) - Method in interface io.shardingsphere.core.api.algorithm.sharding.standard.RangeShardingAlgorithm
Sharding.
doSharding(Collection<String>, Collection<ShardingValue>) - Method in class io.shardingsphere.core.routing.strategy.complex.ComplexShardingStrategy
 
doSharding(Collection<String>, Collection<ShardingValue>) - Method in class io.shardingsphere.core.routing.strategy.hint.HintShardingStrategy
 
doSharding(Collection<String>, Collection<ShardingValue>) - Method in class io.shardingsphere.core.routing.strategy.inline.InlineShardingStrategy
 
doSharding(Collection<String>, Collection<ShardingValue>) - Method in class io.shardingsphere.core.routing.strategy.none.NoneShardingStrategy
 
doSharding(Collection<String>, Collection<ShardingValue>) - Method in interface io.shardingsphere.core.routing.strategy.ShardingStrategy
Sharding.
doSharding(Collection<String>, Collection<ShardingValue>) - Method in class io.shardingsphere.core.routing.strategy.standard.StandardShardingStrategy
 
DQLExecutionEvent - Class in io.shardingsphere.core.executor.event
DQL execution event.
DQLExecutionEvent(String, SQLUnit, List<Object>) - Constructor for class io.shardingsphere.core.executor.event.DQLExecutionEvent
 
DQLMergeEngine - Class in io.shardingsphere.core.merger.dql
DQL result set merge engine.
DQLMergeEngine(List<QueryResult>, SelectStatement) - Constructor for class io.shardingsphere.core.merger.dql.DQLMergeEngine
 
DQLStatement - Class in io.shardingsphere.core.parsing.parser.sql.dql
DQL statement.
DQLStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dql.DQLStatement
 
DropParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.ddl.drop
Drop parser factory.
DropParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.drop.DropParserFactory
 
DummyPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.close
Customized dummy packet.
DummyPacket() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.close.DummyPacket
 

E

encode(ChannelHandlerContext, T, ByteBuf) - Method in class io.shardingsphere.proxy.transport.common.codec.PacketCodec
 
end() - Method in class io.shardingsphere.transaction.api.AbstractSoftTransaction
End transaction.
EofPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.generic
EOF packet protocol.
EofPacket(int, int, int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.generic.EofPacket
 
EofPacket(MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.generic.EofPacket
 
EOI - Static variable in class io.shardingsphere.core.parsing.lexer.analyzer.CharType
End of input.
EPOCH - Static variable in class io.shardingsphere.core.keygen.DefaultKeyGenerator
 
equalAny(TokenType...) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Adjust current token equals one of input tokens or not.
equals(Object) - Method in class io.shardingsphere.core.parsing.parser.context.condition.Column
 
equals(Object) - Method in class io.shardingsphere.core.parsing.parser.context.OrderItem
 
ErrPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.generic
ERR packet protocol.
ErrPacket(int, int, String, String, String) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.generic.ErrPacket
 
ErrPacket(MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.generic.ErrPacket
 
EtcdBeanDefinitionParser - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Etcd namespace parser for spring namespace.
EtcdBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.EtcdBeanDefinitionParser
 
EtcdChannelFactory - Class in io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel
Etcd channel factory.
EtcdChannelFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel.EtcdChannelFactory
 
EtcdConfiguration - Class in io.shardingsphere.jdbc.orchestration.reg.etcd
Etcd configuration.
EtcdConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdConfiguration
 
EtcdNameSolverFactory - Class in io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel
Etcd name solver factory.
EtcdNameSolverFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel.EtcdNameSolverFactory
 
EtcdRegistryCenter - Class in io.shardingsphere.jdbc.orchestration.reg.etcd
Etcd based registry center.
EtcdRegistryCenter(EtcdConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
EtcdRegistryCenterBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.constants
Etcd registry center parser tag constants.
EtcdRegistryCenterBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
EtcdRetryEngine - Class in io.shardingsphere.jdbc.orchestration.reg.etcd.internal.retry
Etcd retry engine.
EtcdRetryEngine() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.retry.EtcdRetryEngine
 
EtcdWatchStreamObserver - Class in io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher
Watch stream observer.
EtcdWatchStreamObserver() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher.EtcdWatchStreamObserver
 
evaluate() - Method in class io.shardingsphere.core.util.InlineExpressionParser
Split and evaluate inline expression.
EventBusInstance - Class in io.shardingsphere.core.util
Event bus for singleton instance.
EventBusInstance() - Constructor for class io.shardingsphere.core.util.EventBusInstance
 
EventExecutionType - Enum in io.shardingsphere.core.executor.event
Event execution type.
EventListener - Interface in io.shardingsphere.jdbc.orchestration.reg.listener
Coordinator registry event change listener.
execute(BaseStatementUnit) - Method in interface io.shardingsphere.core.executor.ExecuteCallback
Execute task.
execute(SQLType, Collection<? extends BaseStatementUnit>, ExecuteCallback<T>) - Method in class io.shardingsphere.core.executor.ExecutorEngine
Execute.
execute() - Method in class io.shardingsphere.core.executor.type.prepared.PreparedStatementExecutor
Execute SQL.
execute() - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute SQL.
execute(int) - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute SQL with auto generated keys.
execute(int[]) - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute SQL with column indexes.
execute(String[]) - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute SQL with column names.
execute() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
execute(String) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
execute(String, int) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
execute(String, int[]) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
execute(String, String[]) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
execute() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
execute(String) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
execute(String, int) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
execute(String, int[]) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
execute(String, String[]) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
execute() - Method in class io.shardingsphere.core.jdbc.metadata.dialect.JDBCShardingRefreshHandler
 
execute(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
execute(String, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
execute(String, int[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
execute(String, String[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
execute() - Method in class io.shardingsphere.core.metadata.AbstractRefreshHandler
execute refresh sharding table metadata.
execute() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
execute(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
execute(String, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
execute(String, int[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
execute(String, String[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
execute(Callable<T>) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.retry.EtcdRetryEngine
Retry to execute callable command.
execute() - Method in interface io.shardingsphere.proxy.backend.common.BackendHandler
Execute command.
execute() - Method in class io.shardingsphere.proxy.backend.common.SQLExecuteBackendHandler
 
execute() - Method in class io.shardingsphere.proxy.backend.common.StatementExecuteBackendHandler
 
execute() - Method in class io.shardingsphere.proxy.metadata.ProxyShardingRefreshHandler
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacket
Execute command.
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.close.ComStmtClosePacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.ComStmtExecutePacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPreparePacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist.ComFieldListPacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb.ComInitDbPacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.ping.ComPingPacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ComQueryPacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.quit.ComQuitPacket
 
execute() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.UnsupportedCommandPacket
 
execute(JobExecutionContext) - Method in class io.shardingsphere.transaction.job.BASETransactionJob
 
executeBatch() - Method in class io.shardingsphere.core.executor.type.batch.BatchPreparedStatementExecutor
Execute batch.
executeBatch() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
executeBatch() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
executeBatch() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
executeBatch() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
ExecuteCallback<T> - Interface in io.shardingsphere.core.executor
Statement execute callback interface.
executeCommand(ChannelHandlerContext, ByteBuf) - Method in class io.shardingsphere.proxy.frontend.common.FrontendHandler
 
executeCommand(ChannelHandlerContext, ByteBuf) - Method in class io.shardingsphere.proxy.frontend.mysql.MySQLFrontendHandler
 
ExecuteEventListener - Class in io.shardingsphere.opentracing
Listen to the event of sql execution.
ExecuteEventListener() - Constructor for class io.shardingsphere.opentracing.ExecuteEventListener
 
executeQuery() - Method in class io.shardingsphere.core.executor.type.prepared.PreparedStatementExecutor
Execute query.
executeQuery() - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute query.
executeQuery() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
executeQuery(String) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
executeQuery() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
executeQuery(String) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
executeQuery(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
executeQuery() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
executeQuery(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
executeUpdate() - Method in class io.shardingsphere.core.executor.type.prepared.PreparedStatementExecutor
Execute update.
executeUpdate() - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute update.
executeUpdate(int) - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute update with auto generated keys.
executeUpdate(int[]) - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute update with column indexes.
executeUpdate(String[]) - Method in class io.shardingsphere.core.executor.type.statement.StatementExecutor
Execute update with column names.
executeUpdate() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
executeUpdate(String) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
executeUpdate(String, int) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
executeUpdate(String, int[]) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
executeUpdate(String, String[]) - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
executeUpdate() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
executeUpdate(String) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
executeUpdate(String, int) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
executeUpdate(String, int[]) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
executeUpdate(String, String[]) - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
executeUpdate(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
executeUpdate(String, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
executeUpdate(String, int[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
executeUpdate(String, String[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
executeUpdate() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
executeUpdate(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
executeUpdate(String, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
executeUpdate(String, int[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
executeUpdate(String, String[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
ExecutorDataMap - Class in io.shardingsphere.core.executor.threadlocal
Executor runtime data map.
ExecutorDataMap() - Constructor for class io.shardingsphere.core.executor.threadlocal.ExecutorDataMap
 
ExecutorEngine - Class in io.shardingsphere.core.executor
SQL execute engine.
ExecutorEngine(int) - Constructor for class io.shardingsphere.core.executor.ExecutorEngine
 
ExecutorExceptionHandler - Class in io.shardingsphere.core.executor.threadlocal
Executor runtime exception handler.
ExecutorExceptionHandler() - Constructor for class io.shardingsphere.core.executor.threadlocal.ExecutorExceptionHandler
 
ExpressionParserFactory - Class in io.shardingsphere.core.parsing.parser.dialect
Expression parser factory.
ExpressionParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.ExpressionParserFactory
 

F

FieldCountPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.query
COM_QUERY response field count packet.
FieldCountPacket(int, int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.FieldCountPacket
 
find(Column) - Method in class io.shardingsphere.core.parsing.parser.context.condition.AndCondition
Deprecated.
only test call
find(Column) - Method in class io.shardingsphere.core.parsing.parser.context.condition.Conditions
Deprecated.
only test call
find(Column, int) - Method in class io.shardingsphere.core.parsing.parser.context.condition.Conditions
Deprecated.
only test call
find(Column, int) - Method in class io.shardingsphere.core.parsing.parser.context.condition.OrCondition
Deprecated.
only test call
find(String) - Method in class io.shardingsphere.core.parsing.parser.context.table.Tables
根据表名称或别名查找表解析对象.
findBindingTableRule(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Get binding table rule via logic table name.
findByKey(String) - Static method in enum io.shardingsphere.core.constant.ShardingPropertiesConstant
Find value via property key.
findColumn(String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
findColumn(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
findColumn(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
findDataNode(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Find data node by logic table.
findDataNode(String, String) - Method in class io.shardingsphere.core.rule.ShardingRule
Find data node by data source and logic table.
findEligibleTransactionLogs(int, int, long) - Method in class io.shardingsphere.transaction.storage.impl.MemoryTransactionLogStorage
 
findEligibleTransactionLogs(int, int, long) - Method in class io.shardingsphere.transaction.storage.impl.RdbTransactionLogStorage
 
findEligibleTransactionLogs(int, int, long) - Method in interface io.shardingsphere.transaction.storage.TransactionLogStorage
Find eligible transaction logs.
findGeneratedKeyToken() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.insert.InsertStatement
Find generated key token.
findRoutingTable(String, String) - Method in class io.shardingsphere.core.routing.type.TableUnit
Find routing table via data source name and actual table name.
findRoutingTable(String, String) - Method in class io.shardingsphere.core.routing.type.TableUnits
Find routing table via data source name and actual table name.
first() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
fromJson(String) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceJsonConverter
Convert data source map from json.
fromJson(String) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.MasterSlaveRuleConfigurationConverter
Convert master-slave rule configuration from json.
fromJson(String) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.ShardingRuleConfigurationConverter
Convert sharding rule configuration from json.
FrontendHandler - Class in io.shardingsphere.proxy.frontend.common
Frontend handler.
FrontendHandler() - Constructor for class io.shardingsphere.proxy.frontend.common.FrontendHandler
 
FrontendHandlerFactory - Class in io.shardingsphere.proxy.frontend.common
Frontend handler factory.
FrontendHandlerFactory() - Constructor for class io.shardingsphere.proxy.frontend.common.FrontendHandlerFactory
 

G

GENERATE_KEY_COLUMN_NAME_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
GENERATE_KEY_COLUMN_NAME_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
GeneratedKey - Class in io.shardingsphere.core.routing.router.sharding
Generated key.
GeneratedKey() - Constructor for class io.shardingsphere.core.routing.router.sharding.GeneratedKey
 
generatedKeyAlwaysReturned() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
GeneratedKeyCondition - Class in io.shardingsphere.core.parsing.parser.context.condition
Generated key condition.
GeneratedKeyCondition(Column, int, Number) - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.GeneratedKeyCondition
 
GeneratedKeysResultSet - Class in io.shardingsphere.core.jdbc.core.resultset
ResultSet for generated keys.
GeneratedKeysResultSet() - Constructor for class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
GeneratedKeysResultSetMetaData - Class in io.shardingsphere.core.jdbc.core.resultset
ResultSet metadata for generated keys.
GeneratedKeysResultSetMetaData() - Constructor for class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
GeneratedKeyToken - Class in io.shardingsphere.core.parsing.parser.token
Generated key token.
GeneratedKeyToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.GeneratedKeyToken
 
generateKey() - Method in class io.shardingsphere.core.keygen.DefaultKeyGenerator
Generate key.
generateKey() - Method in interface io.shardingsphere.core.keygen.KeyGenerator
Generate key.
generateKey(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Generate key.
generateRandomBytes(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.handshake.RandomGenerator
Generate random bytes.
generateSQL(TableUnit, SQLBuilder) - Method in class io.shardingsphere.core.rewrite.SQLRewriteEngine
Generate SQL string.
get() - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Get hint manager in current thread.
get(String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Get data from registry center.
get(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
get(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
get() - Static method in class io.shardingsphere.opentracing.ShardingJDBCTracer
Get the tracer from container.
getActualDatasourceNames() - Method in class io.shardingsphere.core.rule.TableRule
Get actual data source names.
getActualTableNameGroups(String, Set<String>) - Method in class io.shardingsphere.core.routing.type.TableUnits
Get actual tables group via data source name and logic tables' names.
getActualTableNames(String, String) - Method in class io.shardingsphere.core.routing.type.TableUnit
Get actual tables' names via data source name.
getActualTableNames(String) - Method in class io.shardingsphere.core.rule.TableRule
Get actual table names via target data source name.
getAggregationSelectItems() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Get aggregation select items.
getAlias() - Method in interface io.shardingsphere.core.parsing.parser.context.selectitem.SelectItem
获取别名.
getAlias() - Method in class io.shardingsphere.core.parsing.parser.context.selectitem.StarSelectItem
 
getAlias(String) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Get alias.
getAllColumnNames() - Method in class io.shardingsphere.core.metadata.TableMetaData
Get all column names.
getAllDataSources() - Method in class io.shardingsphere.core.jdbc.core.datasource.MasterSlaveDataSource
Get map of all actual data source name and all actual data sources.
getArray(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getArray(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getAsciiStream(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getAsciiStream(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getAsciiStream(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getAsciiStream(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getAsciiStream(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getAsciiStream(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getAttributes(String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getAutoCommit() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
getAutoCommit() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
getAvailableDataSources() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceService
Get available data sources.
getAvailableMasterSlaveRuleConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceService
Get available master-slave rule configuration.
getAvailableShardingRuleConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceService
Get available sharding rule configuration.
getBeginPosition() - Method in interface io.shardingsphere.core.parsing.parser.token.SQLToken
Get begin position.
getBestRowIdentifier(String, String, String, int, boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getBigDecimal(int, int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getBigDecimal(String, int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getBigDecimal(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getBigDecimal(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getBigDecimal(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBigDecimal(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBigDecimal(int, int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBigDecimal(String, int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBigDecimal(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBigDecimal(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBigDecimal(int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBigDecimal(String, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBinaryStream(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBinaryStream(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBinaryStream(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getBinaryStream(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getBinaryStream(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBinaryStream(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBindingActualTable(String, String, String) - Method in class io.shardingsphere.core.rule.BindingTableRule
Deduce actual table name from other actual table name in same binding table rule.
getBlob(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBlob(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBlob(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getBlob(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getBlob(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBlob(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBoolean(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBoolean(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBoolean(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getBoolean(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getBoolean(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBoolean(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getByte(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getByte(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getByte(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getByte(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getByte(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getByte(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBytes(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getBytes(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getBytes(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBytes(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getBytes(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getBytes(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByStreamMergedResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByStreamMergedResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in interface io.shardingsphere.core.merger.MergedResult
Get calendar value.
getCalendarValue(String, Class<?>, Calendar) - Method in interface io.shardingsphere.core.merger.MergedResult
Get calendar value.
getCalendarValue(int, Class<?>, Calendar) - Method in interface io.shardingsphere.core.merger.QueryResult
Get calendar value.
getCalendarValue(String, Class<?>, Calendar) - Method in interface io.shardingsphere.core.merger.QueryResult
Get calendar value.
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getCalendarValue(int, Class<?>, Calendar) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getCalendarValue(String, Class<?>, Calendar) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getCatalog() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
getCatalogName(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getCatalogName(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getCatalogs() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getCatalogSeparator() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getCatalogTerm() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getCell(int) - Method in class io.shardingsphere.core.merger.dql.common.MemoryQueryResultRow
Get data from cell.
getCharacterStream(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getCharacterStream(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getCharacterStream(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getCharacterStream(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getCharacterStream(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getCharacterStream(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getChildrenKeys(String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Get node's sub-nodes list.
getChildrenKeys(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
getChildrenKeys(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
getClientInfo() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
getClientInfo(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
getClientInfoProperties() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getClob(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getClob(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getClob(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getClob(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getClob(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getClob(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getColumnClassName(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnClassName(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getColumnCount() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnCount() - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getColumnCount() - Method in interface io.shardingsphere.core.merger.QueryResult
Get column count.
getColumnCount() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getColumnCount() - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getColumnCount() - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getColumnDisplaySize(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnDisplaySize(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getColumnLabel(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnLabel(int) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getColumnLabel(int) - Method in interface io.shardingsphere.core.merger.QueryResult
Get column label.
getColumnLabel() - Method in class io.shardingsphere.core.parsing.parser.context.OrderItem
Get column label.
getColumnLabel() - Method in class io.shardingsphere.core.parsing.parser.context.selectitem.AggregationSelectItem
Get column label.
getColumnLabel(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getColumnLabel(int) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getColumnLabel(int) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getColumnMetaDataList() - Method in class io.shardingsphere.core.jdbc.metadata.dialect.ShardingMetaDataHandler
Get column meta data list.
getColumnMetaDataList(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.ShardingMetaDataHandler
Get column metadata by Sharding Connection.
getColumnMetaDataList(DataNode, ShardingDataSourceNames, Map<String, Connection>) - Method in class io.shardingsphere.core.jdbc.metadata.JDBCShardingMetaData
 
getColumnMetaDataList(DataNode, ShardingDataSourceNames, Map<String, Connection>) - Method in class io.shardingsphere.core.metadata.ShardingMetaData
Get column metadata implementing by concrete handler.
getColumnMetaDataList(DataNode, ShardingDataSourceNames, Map<String, Connection>) - Method in class io.shardingsphere.proxy.metadata.ProxyShardingMetaData
 
getColumnMetaDataList() - Method in class io.shardingsphere.proxy.metadata.ShardingMetaDataHandler
Get column meta data list.
getColumnName() - Method in interface io.shardingsphere.core.api.algorithm.sharding.ShardingValue
Get column name.
getColumnName(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnName() - Method in class io.shardingsphere.core.optimizer.query.AlwaysFalseShardingValue
 
getColumnName(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getColumnPrivileges(String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getColumns(String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getColumnType(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnType(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getColumnTypeName(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getColumnTypeName(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getCommandPacket(int, MySQLPacketPayload) - Static method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacketFactory
Get command Packet.
getConcurrency() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
getConcurrency() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getConcurrency() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getConditions() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Get conditions.
getConditionsMap() - Method in class io.shardingsphere.core.parsing.parser.context.condition.AndCondition
Get conditions map.
getConditionValues(List<?>) - Method in class io.shardingsphere.core.parsing.parser.context.condition.Condition
Get condition values.
getConditionValues(List<?>) - Method in class io.shardingsphere.core.parsing.parser.context.condition.GeneratedKeyCondition
 
getConnection(String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
Get database connection.
getConnection(String, String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractDataSourceAdapter
 
getConnection() - Method in class io.shardingsphere.core.jdbc.core.datasource.MasterSlaveDataSource
 
getConnection() - Method in class io.shardingsphere.core.jdbc.core.datasource.ShardingDataSource
 
getConnection() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
getConnection(String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
getConnection() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getConnection() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getConnection() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getCrossReference(String, String, String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getCurrentChar(int) - Method in class io.shardingsphere.core.parsing.lexer.Lexer
 
getCurrentMillis() - Method in class io.shardingsphere.core.keygen.TimeService
Get current millis.
getCurrentQueryResult() - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getCurrentToken() - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Get current token.
getCurrentTransaction() - Static method in class io.shardingsphere.transaction.api.SoftTransactionManager
Get current transaction.
getCurrentTransactionConfiguration() - Static method in class io.shardingsphere.transaction.api.SoftTransactionManager
Get transaction configuration from current thread.
getCursorName() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getCustomizedAvailableKeywordsForSelectItemAlias() - Method in class io.shardingsphere.core.parsing.parser.clause.expression.AliasExpressionParser
 
getCustomizedAvailableKeywordsForSelectItemAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.expression.MySQLAliasExpressionParser
 
getCustomizedAvailableKeywordsForSelectItemAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.expression.OracleAliasExpressionParser
 
getCustomizedAvailableKeywordsForSelectItemAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.expression.PostgreSQLAliasExpressionParser
 
getCustomizedAvailableKeywordsForSelectItemAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.expression.SQLServerAliasExpressionParser
 
getCustomizedAvailableKeywordsForTableAlias() - Method in class io.shardingsphere.core.parsing.parser.clause.expression.AliasExpressionParser
 
getCustomizedAvailableKeywordsForTableAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.expression.MySQLAliasExpressionParser
 
getCustomizedAvailableKeywordsForTableAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.expression.OracleAliasExpressionParser
 
getCustomizedAvailableKeywordsForTableAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.expression.PostgreSQLAliasExpressionParser
 
getCustomizedAvailableKeywordsForTableAlias() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.expression.SQLServerAliasExpressionParser
 
getCustomizedInsertKeywords() - Method in class io.shardingsphere.core.parsing.parser.clause.InsertSetClauseParser
 
getCustomizedInsertKeywords() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLInsertSetClauseParser
 
getCustomizedOtherConditionOperators() - Method in class io.shardingsphere.core.parsing.parser.clause.WhereClauseParser
 
getCustomizedOtherConditionOperators() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLWhereClauseParser
 
getDatabaseMajorVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDatabaseMinorVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDatabaseProductName() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDatabaseProductVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDatabaseShardingStrategy(TableRule) - Method in class io.shardingsphere.core.rule.ShardingRule
Get database sharding strategy.
getDatabaseShardingValue(ShardingKey) - Method in class io.shardingsphere.core.api.HintManager
Get sharding value for database.
getDatabaseShardingValue(ShardingKey) - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Get database sharding value.
getDatabaseType(Collection<DataSource>) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractDataSourceAdapter
 
getDatabaseType() - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Get database type.
getDatabaseTypes(String) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get database types.
getDataMap() - Static method in class io.shardingsphere.core.executor.threadlocal.ExecutorDataMap
Get data map.
getDataSource(String, String, List<String>) - Method in interface io.shardingsphere.core.api.algorithm.masterslave.MasterSlaveLoadBalanceAlgorithm
Get data source.
getDataSource(String, String, List<String>) - Method in class io.shardingsphere.core.api.algorithm.masterslave.RandomMasterSlaveLoadBalanceAlgorithm
 
getDataSource(String, String, List<String>) - Method in class io.shardingsphere.core.api.algorithm.masterslave.RoundRobinMasterSlaveLoadBalanceAlgorithm
 
getDataSource(String, Map<String, Object>) - Static method in class io.shardingsphere.core.util.DataSourceUtil
Get data source.
getDataSource() - Method in class io.shardingsphere.transaction.datasource.impl.MemoryTransactionLogDataSource
 
getDataSource() - Method in class io.shardingsphere.transaction.datasource.impl.RdbTransactionLogDataSource
 
getDataSource() - Method in interface io.shardingsphere.transaction.datasource.TransactionLogDataSource
Get transaction log data source.
getDataSourceLogicTablesMap(Collection<String>) - Method in class io.shardingsphere.core.routing.type.TableUnits
Get map relationship between data source and logic tables via data sources' names.
getDataSourceMap() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
getDataSourceMap() - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
getDataSourceMap() - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
getDataSourceNames() - Method in class io.shardingsphere.core.routing.type.TableUnits
Get all data source names.
getDataSourcesNodeFullPath() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.StateNode
Get data source node full path.
getDate(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getDate(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getDate(int, Calendar) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getDate(String, Calendar) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getDate(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getDate(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getDate(int, Calendar) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getDate(String, Calendar) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getDate(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getDate(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getDate(int, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getDate(String, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getDefaultAlgorithmType() - Static method in enum io.shardingsphere.core.api.algorithm.masterslave.MasterSlaveLoadBalanceAlgorithmType
Get default master-slave database load-balance algorithm type.
getDefaultDataSourceName() - Method in class io.shardingsphere.core.rule.ShardingDataSourceNames
Get default data source name.
getDefaultScheme() - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel.EtcdNameSolverFactory
 
getDefaultTransactionIsolation() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDefaultTransactionLogDataSource() - Method in class io.shardingsphere.transaction.job.BASETransactionJobConfiguration
Get next one transaction log data source.
getDirectly(String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Get data from registry center directly.
getDirectly(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
getDirectly(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
getDouble(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getDouble(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getDouble(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getDouble(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getDouble(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getDouble(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getDriverMajorVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDriverMinorVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDriverName() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getDriverVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getExactlyNumber(String, int) - Static method in class io.shardingsphere.core.util.NumberUtil
Get exactly number value and type.
getExactlyValue(String) - Static method in class io.shardingsphere.core.util.SQLUtil
Get exactly value for SQL expression.
getException() - Method in class io.shardingsphere.core.executor.event.AbstractExecutionEvent
Get exception.
getException() - Method in class io.shardingsphere.core.executor.event.AbstractSQLExecutionEvent
Get exception.
getExistColumnMeta(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.DefaultShardingMetaDataHandler
 
getExistColumnMeta(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.H2ShardingMetaDataHandler
 
getExistColumnMeta(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.MySQLShardingMetaDataHandler
 
getExistColumnMeta(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.ShardingMetaDataHandler
Get exit table's column metadata list.
getExportedKeys(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getExpression() - Method in class io.shardingsphere.core.parsing.parser.context.selectitem.AggregationSelectItem
 
getExpression() - Method in interface io.shardingsphere.core.parsing.parser.context.selectitem.SelectItem
获取表达式.
getExpression() - Method in class io.shardingsphere.core.parsing.parser.context.selectitem.StarSelectItem
 
getExtraNameCharacters() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getFetchDirection() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
getFetchDirection() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getFetchDirection() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
getFetchDirection() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getFetchSize() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
getFetchSize() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getFetchSize() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getFetchSize() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getFetchSize() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getFloat(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getFloat(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getFloat(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getFloat(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getFloat(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getFloat(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getFullPath(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
Get node full path.
getFunctionColumns(String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getFunctions(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getGeneratedKeys() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
getGeneratedKeys() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
getGeneratedKeys() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
getGeneratedKeys() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
getGeneratedKeys() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getGeneratedKeys() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getGenerateKeyColumn(String) - Method in class io.shardingsphere.core.rule.ShardingRule
get generated key's column.
getGson() - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.GsonFactory
Get gson instance.
getHeadPacket() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandResponsePackets
Get head packet.
getHoldability() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
getHoldability() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getHoldability() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
getIdentifierQuoteString() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getImportedKeys(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getIndexInfo(String, String, String, boolean, boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getIndexName() - Method in class io.shardingsphere.core.parsing.parser.token.IndexToken
Get index name.
getInput() - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Get input string.
getInputStream(int, String) - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
getInputStream(String, String) - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
getInputStream(int, String) - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
getInputStream(String, String) - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
getInputStream(int, String) - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
getInputStream(String, String) - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
getInputStream(int, String) - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
getInputStream(String, String) - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
getInputStream(int, String) - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getInputStream(String, String) - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getInputStream(int, String) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getInputStream(String, String) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getInputStream(int, String) - Method in interface io.shardingsphere.core.merger.MergedResult
Get InputStream.
getInputStream(String, String) - Method in interface io.shardingsphere.core.merger.MergedResult
Get InputStream.
getInputStream(int, String) - Method in interface io.shardingsphere.core.merger.QueryResult
Get InputStream.
getInputStream(String, String) - Method in interface io.shardingsphere.core.merger.QueryResult
Get InputStream.
getInputStream(int, String) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getInputStream(String, String) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getInputStream(int, String) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getInputStream(String, String) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getInstance() - Static method in class io.shardingsphere.core.api.ConfigMapContext
Get a new instance for ConfigMapContext.
getInstance() - Static method in class io.shardingsphere.core.api.HintManager
Get a new instance for HintManager.
getInstance() - Static method in class io.shardingsphere.core.parsing.cache.ParsingResultCache
Get parsing result cache instance.
getInstance() - Static method in class io.shardingsphere.core.util.EventBusInstance
Get event bus instance.
getInstance() - Static method in class io.shardingsphere.jdbc.orchestration.internal.state.instance.OrchestrationInstance
Get instance.
getInstance(List<String>) - Static method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel.EtcdChannelFactory
Get etcd channel instance.
getInstance() - Static method in class io.shardingsphere.proxy.config.RuleRegistry
Get instance of sharding rule registry.
getInstance() - Static method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.BinaryProtocolValueUtility
Get binary protocol value utility instance.
getInstance() - Static method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.PreparedStatementRegistry
Get prepared statement registry instance.
getInstance() - Static method in class io.shardingsphere.test.sql.SQLCasesLoader
Get singleton instance.
getInstancesNodeFullPath(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.state.StateNode
Get instance node full path.
getInt(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getInt(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getInt(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getInt(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getInt(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getInt(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getIp() - Static method in class io.shardingsphere.jdbc.orchestration.internal.util.IpUtils
获取本机IP地址.
getItemsTokens() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.insert.InsertStatement
Get items tokens.
getJDBCMajorVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getJDBCMinorVersion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getKeywordsForJoinType() - Method in class io.shardingsphere.core.parsing.parser.clause.TableReferencesClauseParser
 
getKeywordsForJoinType() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLTableReferencesClauseParser
 
getKeywordsForJoinType() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerTableReferencesClauseParser
 
getLogicTableName() - Method in interface io.shardingsphere.core.api.algorithm.sharding.ShardingValue
Get logic table name.
getLogicTableName() - Method in class io.shardingsphere.core.optimizer.query.AlwaysFalseShardingValue
 
getLogicTableName() - Method in interface io.shardingsphere.core.rewrite.placeholder.ShardingPlaceholder
Get logic table name.
getLogicTableName(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Get logic table name base on logic index name.
getLogicTableNames(String) - Method in class io.shardingsphere.core.routing.type.TableUnit
Get logic tables' names via data source name.
getLoginTimeout() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationDataSource
 
getLogWriter() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractDataSourceAdapter
 
getLogWriter() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
getLong(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getLong(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getLong(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getLong(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getLong(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getLong(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getMasterSlaveRuleConfiguration() - Method in class io.shardingsphere.core.yaml.masterslave.YamlMasterSlaveRuleConfiguration
Get master-slave rule configuration from yaml.
getMaxBinaryLiteralLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxCatalogNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxCharLiteralLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxColumnNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxColumnsInGroupBy() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxColumnsInIndex() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxColumnsInOrderBy() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxColumnsInSelect() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxColumnsInTable() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxConnections() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxCursorNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxFieldSize() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getMaxFieldSize() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getMaxIndexLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxProcedureNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxRows() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getMaxRows() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getMaxRowSize() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxSchemaNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxStatementLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxStatements() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxTableNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxTablesInSelect() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMaxUserNameLength() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getMetaData() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
getMetaData() - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
getMetaData() - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
getMetaData() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getMetaData() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
getMetaData() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
getMetaData() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getMoreResults() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getMoreResults(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getMoreResults() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getMoreResults(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getNCharacterStream(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getNCharacterStream(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getNClob(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getNClob(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getNetworkTimeout() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
getNString(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getNString(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getNullOrderDirection() - Method in class io.shardingsphere.core.parsing.parser.clause.OrderByClauseParser
 
getNullOrderDirection() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleOrderByClauseParser
 
getNullOrderDirection() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLOrderByClauseParser
 
getNullOrderDirection() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerOrderByClauseParser
 
getNumericFunctions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getObject(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getObject(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getObject(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getObject(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getObject(int, Class<T>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getObject(String, Class<T>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getObject(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getObject(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getObject() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
getObject() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
getObjectType() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
getObjectType() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
getOffsetValue() - Method in class io.shardingsphere.core.parsing.parser.context.limit.Limit
Get offset value.
getOrchestrationConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.yaml.YamlOrchestrationConfiguration
Get orchestration master-slave rule configuration from yaml.
getOriginalValue(String, DatabaseType) - Static method in class io.shardingsphere.core.util.SQLUtil
Get original value for SQL expression.
getParameterHeader(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.PreparedStatementRegistry
Get parameter header.
getParameterMetaData() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
getParametersIndex() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Get index of parameters.
getParentLogger() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractDataSourceAdapter
 
getParentLogger() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
getPrecision(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getPrecision(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getPrimaryKeys(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getProcedureColumns(String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getProcedures(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getProcedureTerm() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getPseudoColumns(String, String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getQualifiedName() - Method in class io.shardingsphere.core.parsing.parser.context.OrderItem
Get qualified name.
getQueryTimeout() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getQueryTimeout() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getRawMasterDataSourceName(String) - Method in class io.shardingsphere.core.rule.ShardingDataSourceNames
Get raw master data source name.
getRef(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getRef(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getResult() - Method in class io.shardingsphere.core.merger.dql.groupby.aggregation.AccumulationAggregationUnit
 
getResult() - Method in interface io.shardingsphere.core.merger.dql.groupby.aggregation.AggregationUnit
Get aggregation result.
getResult() - Method in class io.shardingsphere.core.merger.dql.groupby.aggregation.AverageAggregationUnit
 
getResult() - Method in class io.shardingsphere.core.merger.dql.groupby.aggregation.ComparableAggregationUnit
 
getResultSet() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
getResultSet() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
getResultSet() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
getResultSet() - Method in class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
getResultSet() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getResultSet() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getResultSetConcurrency() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
getResultSetConcurrency() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getResultSetConcurrency() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getResultSetHoldability() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
getResultSetHoldability() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getResultSetHoldability() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getResultSetHoldability() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getResultSetType() - Method in class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
getResultSetType() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getResultSetType() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getResultValue() - Method in class io.shardingsphere.proxy.backend.common.SQLExecuteBackendHandler
Get result value.
getResultValue() - Method in class io.shardingsphere.proxy.backend.common.StatementExecuteBackendHandler
Get result value.
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacket
Get result value.
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.close.ComStmtClosePacket
 
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.ComStmtExecutePacket
Get result value.
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPreparePacket
 
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist.ComFieldListPacket
 
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb.ComInitDbPacket
 
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.ping.ComPingPacket
 
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ComQueryPacket
Get result value.
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.quit.ComQuitPacket
 
getResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.UnsupportedCommandPacket
 
getRoutedStatements() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getRoutedStatements() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
getRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getRowCountValue() - Method in class io.shardingsphere.core.parsing.parser.context.limit.Limit
Get row count value.
getRowId(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getRowId(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
getRowIdLifetime() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getScale(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getScale(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getSchema() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
getSchemaName(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getSchemaName() - Method in class io.shardingsphere.core.parsing.parser.token.SchemaToken
Get schema name.
getSchemaName(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getSchemas() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSchemas(String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSchemaTerm() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSearchStringEscape() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getShardingColumns() - Method in class io.shardingsphere.core.routing.strategy.inline.InlineShardingStrategy
 
getShardingColumns() - Method in interface io.shardingsphere.core.routing.strategy.ShardingStrategy
Get sharding columns.
getShardingColumns() - Method in class io.shardingsphere.core.routing.strategy.standard.StandardShardingStrategy
 
getShardingRule(Collection<String>) - Method in class io.shardingsphere.core.yaml.sharding.YamlShardingConfiguration
Get sharding rule from yaml.
getShardingRuleConfiguration() - Method in class io.shardingsphere.core.yaml.sharding.YamlShardingRuleConfiguration
Get sharding rule configuration.
getShardingValue(List<?>) - Method in class io.shardingsphere.core.parsing.parser.context.condition.Condition
Deprecated.
only test call
getShort(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getShort(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getShort(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getShort(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getShort(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getShort(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getSingleTableName() - Method in class io.shardingsphere.core.parsing.parser.context.table.Tables
获取表名称.
getSkippedKeywordAfterGroupBy() - Method in class io.shardingsphere.core.parsing.parser.clause.GroupByClauseParser
 
getSkippedKeywordAfterGroupBy() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLGroupByClauseParser
 
getSkippedKeywordsBeforeSelectItem() - Method in class io.shardingsphere.core.parsing.parser.clause.SelectListClauseParser
 
getSkippedKeywordsBeforeSelectItem() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleSelectListClauseParser
 
getSkippedKeywordsBetweenAlterTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLAlterParser
 
getSkippedKeywordsBetweenAlterTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.alter.AbstractAlterParser
 
getSkippedKeywordsBetweenCreateAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLCreateParser
 
getSkippedKeywordsBetweenCreateAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleCreateParser
 
getSkippedKeywordsBetweenCreateAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLCreateParser
 
getSkippedKeywordsBetweenCreateAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerCreateParser
 
getSkippedKeywordsBetweenCreateAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.create.AbstractCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndIndexName() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndIndexName() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.create.AbstractCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerCreateParser
 
getSkippedKeywordsBetweenCreateIndexAndKeyword() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.create.AbstractCreateParser
 
getSkippedKeywordsBetweenCreateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLCreateParser
 
getSkippedKeywordsBetweenCreateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleCreateParser
 
getSkippedKeywordsBetweenCreateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLCreateParser
 
getSkippedKeywordsBetweenCreateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerCreateParser
 
getSkippedKeywordsBetweenCreateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.create.AbstractCreateParser
 
getSkippedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDeleteParser
 
getSkippedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleDeleteParser
 
getSkippedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLDeleteParser
 
getSkippedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerDeleteParser
 
getSkippedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.delete.AbstractDeleteParser
 
getSkippedKeywordsBetweenDropAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDropParser
 
getSkippedKeywordsBetweenDropAndTable() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.drop.AbstractDropParser
 
getSkippedKeywordsBetweenDropIndexAndIndexName() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLDropParser
 
getSkippedKeywordsBetweenDropIndexAndIndexName() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.drop.AbstractDropParser
 
getSkippedKeywordsBetweenDropTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDropParser
 
getSkippedKeywordsBetweenDropTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleDropParser
 
getSkippedKeywordsBetweenDropTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLDropParser
 
getSkippedKeywordsBetweenDropTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerDropParser
 
getSkippedKeywordsBetweenDropTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.drop.AbstractDropParser
 
getSkippedKeywordsBetweenTableAndValues() - Method in class io.shardingsphere.core.parsing.parser.clause.InsertIntoClauseParser
 
getSkippedKeywordsBetweenTableAndValues() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLInsertIntoClauseParser
 
getSkippedKeywordsBetweenTruncateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLTruncateParser
 
getSkippedKeywordsBetweenTruncateTableAndTableName() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.truncate.AbstractTruncateParser
 
getSkippedKeywordsBetweenUpdateAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLUpdateParser
 
getSkippedKeywordsBetweenUpdateAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLUpdateParser
 
getSkippedKeywordsBetweenUpdateAndTable() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.update.AbstractUpdateParser
 
getSQL(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.PreparedStatementRegistry
Get SQL.
getSqlExecutionUnit() - Method in interface io.shardingsphere.core.executor.BaseStatementUnit
Get SQL execute unit.
getSQLKeywords() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSQLStatement(String) - Method in class io.shardingsphere.core.parsing.cache.ParsingResultCache
Get SQL statement.
getSQLStateType() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSqlTokens() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Get SQL Tokens.
getSQLXML(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getSQLXML(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getSQLXML(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getSQLXML(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getSQLXML(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getSQLXML(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getStarSelectItems() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Get start select items.
getStatement() - Method in interface io.shardingsphere.core.executor.BaseStatementUnit
Get statement.
getStatement() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getStatement() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getString(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getString(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getString(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getString(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getString(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getString(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getStringFunctions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSuperTables(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSuperTypes(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getSupportedLiteralSQL(String, List<?>) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get supported SQL with literal.
getSupportedPlaceholderSQL(String) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get supported SQL with placeholder.
getSupportedSQL(String) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get supported SQL.
getSupportedSQL(String, SQLCaseType, List<?>) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get supported SQL.
getSupportedSQLTestParameters(Collection<? extends Enum>, Class<? extends Enum>) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get test parameters for junit parameterized test case for supported SQL.
getSynonymousKeywordsForDistinct() - Method in class io.shardingsphere.core.parsing.parser.clause.DistinctClauseParser
 
getSynonymousKeywordsForDistinct() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLDistinctClauseParser
 
getSynonymousKeywordsForDistinct() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleDistinctClauseParser
 
getSynonymousKeywordsForValues() - Method in class io.shardingsphere.core.parsing.parser.clause.InsertValuesClauseParser
 
getSynonymousKeywordsForValues() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLInsertValuesClauseParser
 
getSystemFunctions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getTableName(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
getTableName() - Method in class io.shardingsphere.core.parsing.parser.token.IndexToken
Get table name.
getTableName() - Method in class io.shardingsphere.core.parsing.parser.token.SchemaToken
Get table name.
getTableName() - Method in class io.shardingsphere.core.parsing.parser.token.TableToken
Get table name.
getTableName(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
getTableNames() - Method in class io.shardingsphere.core.parsing.parser.context.table.Tables
获取表名称集合.
getTablePrivileges(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getTableRule(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Find table rule though logic table name.
getTables() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Get tables.
getTables(String, String, String, String[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getTableShardingStrategy(TableRule) - Method in class io.shardingsphere.core.rule.ShardingRule
Get table sharding strategy.
getTableShardingValue(ShardingKey) - Method in class io.shardingsphere.core.api.HintManager
Get sharding value for table.
getTableShardingValue(ShardingKey) - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Get table sharding value.
getTableTypes() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getTargetConnection(String) - Method in class io.shardingsphere.transaction.api.config.SoftTransactionConfiguration
Get connection for transaction manager.
getTargetDataSource(String) - Method in class io.shardingsphere.transaction.job.BASETransactionJobConfiguration
Get one data source by name.
getTime(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTime(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTime(int, Calendar) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTime(String, Calendar) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTime(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTime(int, Calendar) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTime(String, Calendar) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTime(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTime(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTime(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTime(int, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTime(String, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTimeDateFunctions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getTimestamp(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTimestamp(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTimestamp(int, Calendar) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTimestamp(String, Calendar) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getTimestamp(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTimestamp(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTimestamp(int, Calendar) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTimestamp(String, Calendar) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getTimestamp(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTimestamp(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTimestamp(int, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTimestamp(String, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getTransaction(SoftTransactionType) - Method in class io.shardingsphere.transaction.api.SoftTransactionManager
Get B.A.S.E transaction.
getTransactionIsolation() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
getTransactionIsolation() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
getType() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
getType() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
getType() - Method in class io.shardingsphere.core.parsing.parser.sql.AbstractSQLStatement
 
getType() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Get SQL type.
getType() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getType() - Method in class io.shardingsphere.transaction.datasource.impl.MemoryTransactionLogDataSource
 
getType() - Method in class io.shardingsphere.transaction.datasource.impl.RdbTransactionLogDataSource
 
getType() - Method in interface io.shardingsphere.transaction.datasource.TransactionLogDataSource
Get transaction log data source type.
getTypeInfo() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getTypeMap() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
getUDTs(String, String, String, int[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getUnicodeStream(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getUnicodeStream(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getUnicodeStream(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getUnicodeStream(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getUnicodeStream(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getUnicodeStream(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getUnsupportedKeywordBeforeGroupByItem() - Method in class io.shardingsphere.core.parsing.parser.clause.GroupByClauseParser
 
getUnsupportedKeywordBeforeGroupByItem() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleGroupByClauseParser
 
getUnsupportedKeywordsBeforeInto() - Method in class io.shardingsphere.core.parsing.parser.clause.InsertIntoClauseParser
 
getUnsupportedKeywordsBeforeInto() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleInsertIntoClauseParser
 
getUnsupportedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerDeleteParser
 
getUnsupportedKeywordsBetweenDeleteAndTable() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.delete.AbstractDeleteParser
 
getUnsupportedKeywordsBetweenUpdateAndTable() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerUpdateParser
 
getUnsupportedKeywordsBetweenUpdateAndTable() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.update.AbstractUpdateParser
 
getUnsupportedKeywordsRest() - Method in class io.shardingsphere.core.parsing.parser.clause.SelectRestClauseParser
 
getUnsupportedKeywordsRest() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLSelectRestClauseParser
 
getUnsupportedKeywordsRest() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLSelectRestClauseParser
 
getUnsupportedKeywordsRest() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerSelectRestClauseParser
 
getUnsupportedSQL(String, SQLCaseType, List<?>) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get unsupported SQL.
getUnsupportedSQLTestParameters(Collection<? extends Enum>, Class<? extends Enum>) - Method in class io.shardingsphere.test.sql.SQLCasesLoader
Get test parameters for junit parameterized test case for unsupported SQL.
getUpdateCount() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getUpdateCount() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
getURL(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getURL(String) - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
getURL(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getURL(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getURL() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getURL(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getURL(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getUserName() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getValue(ShardingPropertiesConstant) - Method in class io.shardingsphere.core.constant.ShardingProperties
Get property value.
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByStreamMergedResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByStreamMergedResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
getValue(int, Class<?>) - Method in interface io.shardingsphere.core.merger.MergedResult
Get data value.
getValue(String, Class<?>) - Method in interface io.shardingsphere.core.merger.MergedResult
Get data value.
getValue(int, Class<?>) - Method in interface io.shardingsphere.core.merger.QueryResult
Get data value.
getValue(String, Class<?>) - Method in interface io.shardingsphere.core.merger.QueryResult
Get data value.
getValue(int, Class<?>) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
getValue(int, Class<?>) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getValue(String, Class<?>) - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
getVersionColumns(String, String, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
getWarnings() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
getWarnings() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
getWarnings() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
getWarnings() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
getWarnings() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
getWarnings() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
getWarnings() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
GroupByClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Group by clause parser.
GroupByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.GroupByClauseParser
 
GroupByMemoryMergedResult - Class in io.shardingsphere.core.merger.dql.groupby
Memory merged result for group by.
GroupByMemoryMergedResult(Map<String, Integer>, List<QueryResult>, SelectStatement) - Constructor for class io.shardingsphere.core.merger.dql.groupby.GroupByMemoryMergedResult
 
GroupByRowComparator - Class in io.shardingsphere.core.merger.dql.groupby
Group by row comparator.
GroupByRowComparator() - Constructor for class io.shardingsphere.core.merger.dql.groupby.GroupByRowComparator
 
GroupByStreamMergedResult - Class in io.shardingsphere.core.merger.dql.groupby
Stream merged result for group by.
GroupByStreamMergedResult(Map<String, Integer>, List<QueryResult>, SelectStatement) - Constructor for class io.shardingsphere.core.merger.dql.groupby.GroupByStreamMergedResult
 
GroupByValue - Class in io.shardingsphere.core.merger.dql.groupby
Group by value.
GroupByValue(QueryResult, List<OrderItem>) - Constructor for class io.shardingsphere.core.merger.dql.groupby.GroupByValue
 
GsonFactory - Class in io.shardingsphere.jdbc.orchestration.internal.json
Gson Factor.
GsonFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.GsonFactory
 

H

H2ShardingMetaDataHandler - Class in io.shardingsphere.core.jdbc.metadata.dialect
MySQL table metadata handler.
H2ShardingMetaDataHandler(DataSource, String) - Constructor for class io.shardingsphere.core.jdbc.metadata.dialect.H2ShardingMetaDataHandler
 
handle(Environment, String, Class<T>) - Static method in class io.shardingsphere.jdbc.orchestration.spring.boot.util.PropertyUtil
Spring Boot 1.x is compatible with Spring Boot 2.x by Using Java Reflect.
handle(Environment, String, Class<T>) - Static method in class io.shardingsphere.jdbc.spring.boot.util.PropertyUtil
Spring Boot 1.x is compatible with Spring Boot 2.x by Using Java Reflect.
handleException(Exception) - Static method in class io.shardingsphere.core.executor.threadlocal.ExecutorExceptionHandler
Handle exception.
handleException(Exception) - Static method in class io.shardingsphere.jdbc.orchestration.reg.exception.RegExceptionHandler
Handle exception.
handlePlaceHolder(String) - Static method in class io.shardingsphere.core.util.InlineExpressionParser
Replace all the inlineExpression placeholders.
handshake(ChannelHandlerContext) - Method in class io.shardingsphere.proxy.frontend.common.FrontendHandler
 
handshake(ChannelHandlerContext) - Method in class io.shardingsphere.proxy.frontend.mysql.MySQLFrontendHandler
 
HandshakePacket - Class in io.shardingsphere.proxy.transport.mysql.packet.handshake
Handshake packet protocol.
HandshakePacket(int, AuthPluginData) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.handshake.HandshakePacket
 
HandshakeResponse41Packet - Class in io.shardingsphere.proxy.transport.mysql.packet.handshake
Handshake response above MySQL 4.1 packet protocol.
HandshakeResponse41Packet(MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.handshake.HandshakeResponse41Packet
 
hasDataSourceConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Adjust has data source configuration or not in registry center.
hashCode() - Method in class io.shardingsphere.core.parsing.parser.context.condition.Column
 
hashCode() - Method in class io.shardingsphere.core.parsing.parser.context.OrderItem
 
hasLogicTable(String) - Method in class io.shardingsphere.core.rule.BindingTableRule
Adjust contains this logic table in this rule.
hasMasterSlaveConfigMap() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Adjust has master-slave config map or not in registry center.
hasMasterSlaveRuleConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Adjust has master-slave rule configuration or not in registry center.
hasMoreResultValue() - Method in class io.shardingsphere.proxy.backend.common.SQLExecuteBackendHandler
Has more Result value.
hasMoreResultValue() - Method in class io.shardingsphere.proxy.backend.common.StatementExecuteBackendHandler
Has more Result value.
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacket
Has more result value.
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.close.ComStmtClosePacket
 
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.ComStmtExecutePacket
Has more Result value.
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPreparePacket
 
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist.ComFieldListPacket
 
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb.ComInitDbPacket
 
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.ping.ComPingPacket
 
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ComQueryPacket
Has more Result value.
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.quit.ComQuitPacket
 
hasMoreResultValue() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.UnsupportedCommandPacket
 
hasShardingConfigMap() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Adjust has sharding config map or not in registry center.
hasShardingProperties() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Adjust has sharding properties or not in registry center.
hasShardingRuleConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Adjust has sharding rule configuration or not in registry center.
HavingClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Having clause parser.
HavingClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.HavingClauseParser
 
heartbeat(long) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.keepalive.KeepAlive
keep lease alive.
HINT_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
HINT_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
HintManager - Class in io.shardingsphere.core.api
The manager that use hint to inject sharding key directly through ThreadLocal.
HintManager() - Constructor for class io.shardingsphere.core.api.HintManager
 
HintManagerHolder - Class in io.shardingsphere.core.hint
Hint manager holder.
HintManagerHolder() - Constructor for class io.shardingsphere.core.hint.HintManagerHolder
 
HintShardingAlgorithm - Interface in io.shardingsphere.core.api.algorithm.sharding.hint
Sharding algorithm for hint without sharding keys.
HintShardingStrategy - Class in io.shardingsphere.core.routing.strategy.hint
Hint sharding strategy.
HintShardingStrategy(HintShardingStrategyConfiguration) - Constructor for class io.shardingsphere.core.routing.strategy.hint.HintShardingStrategy
 
HintShardingStrategyConfiguration - Class in io.shardingsphere.core.api.config.strategy
Hint sharding strategy configuration.
HintShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.api.config.strategy.HintShardingStrategyConfiguration
 

I

IgnoreRoutingEngine - Class in io.shardingsphere.core.routing.type.ignore
Ignore routing engine.
IgnoreRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.ignore.IgnoreRoutingEngine
 
increaseAsyncDeliveryTryTimes(String) - Method in class io.shardingsphere.transaction.storage.impl.MemoryTransactionLogStorage
 
increaseAsyncDeliveryTryTimes(String) - Method in class io.shardingsphere.transaction.storage.impl.RdbTransactionLogStorage
 
increaseAsyncDeliveryTryTimes(String) - Method in interface io.shardingsphere.transaction.storage.TransactionLogStorage
Increase asynchronized delivery try times.
increaseParametersIndex() - Method in class io.shardingsphere.core.parsing.parser.sql.AbstractSQLStatement
 
increaseParametersIndex() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Increase parameters index.
IndexPlaceholder - Class in io.shardingsphere.core.rewrite.placeholder
Index placeholder for rewrite.
IndexPlaceholder() - Constructor for class io.shardingsphere.core.rewrite.placeholder.IndexPlaceholder
 
IndexToken - Class in io.shardingsphere.core.parsing.parser.token
Index token.
IndexToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.IndexToken
 
init(ShardingRule) - Method in class io.shardingsphere.core.metadata.ShardingMetaData
Initialize sharding metadata.
init(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties, ShardingDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationFacade
Initialize for sharding orchestration.
init(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>, MasterSlaveDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationFacade
Initialize for master-slave orchestration.
init() - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationMasterSlaveDataSource
Initialize for master-slave orchestration.
init() - Method in class io.shardingsphere.jdbc.orchestration.internal.OrchestrationShardingDataSource
Initialize for sharding orchestration.
init() - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.handler.OrchestrationMasterSlaveNamespaceHandler
 
init() - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.handler.OrchestrationShardingNamespaceHandler
 
init() - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.handler.RegNamespaceHandler
 
init() - Method in class io.shardingsphere.jdbc.spring.namespace.handler.MasterSlaveNamespaceHandler
 
init() - Method in class io.shardingsphere.jdbc.spring.namespace.handler.ShardingNamespaceHandler
 
init() - Static method in class io.shardingsphere.opentracing.ShardingJDBCTracer
Initialize tracer.
init(Tracer) - Static method in class io.shardingsphere.opentracing.ShardingJDBCTracer
Initialize tracer from another one.
init() - Method in class io.shardingsphere.transaction.api.SoftTransactionManager
Initialize B.A.S.E transaction manager.
initChannel(SocketChannel) - Method in class io.shardingsphere.proxy.frontend.netty.ServerHandlerInitializer
 
initMasterSlaveListeners(MasterSlaveDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.listener.ListenerFactory
Initialize listeners for master-slave data source.
initShardingListeners(ShardingDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.listener.ListenerFactory
Initialize listeners for sharding data source.
INLINE_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
INLINE_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
InlineExpressionParser - Class in io.shardingsphere.core.util
Inline expression parser.
InlineExpressionParser() - Constructor for class io.shardingsphere.core.util.InlineExpressionParser
 
InlineShardingStrategy - Class in io.shardingsphere.core.routing.strategy.inline
Standard sharding strategy.
InlineShardingStrategy(InlineShardingStrategyConfiguration) - Constructor for class io.shardingsphere.core.routing.strategy.inline.InlineShardingStrategy
 
InlineShardingStrategyConfiguration - Class in io.shardingsphere.core.api.config.strategy
Inline sharding strategy configuration.
InlineShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.api.config.strategy.InlineShardingStrategyConfiguration
 
InsertColumnsClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Insert columns clause parser.
InsertColumnsClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.InsertColumnsClauseParser
 
InsertColumnToken - Class in io.shardingsphere.core.parsing.parser.token
Symbol token.
InsertColumnToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.InsertColumnToken
 
InsertIntoClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Insert into clause parser.
InsertIntoClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.InsertIntoClauseParser
 
InsertOptimizeEngine - Class in io.shardingsphere.core.optimizer.insert
Insert optimize engine.
InsertOptimizeEngine() - Constructor for class io.shardingsphere.core.optimizer.insert.InsertOptimizeEngine
 
InsertParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dml.insert
Insert parser factory.
InsertParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.insert.InsertParserFactory
 
insertRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
insertsAreDetected(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
InsertSetClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Insert set clause parser.
InsertSetClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.InsertSetClauseParser
 
InsertShardingCondition - Class in io.shardingsphere.core.optimizer.insert
Sharding condition.
InsertShardingCondition() - Constructor for class io.shardingsphere.core.optimizer.insert.InsertShardingCondition
 
InsertStatement - Class in io.shardingsphere.core.parsing.parser.sql.dml.insert
Insert statement.
InsertStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.insert.InsertStatement
 
InsertValue - Class in io.shardingsphere.core.parsing.parser.context.insertvalue
Insert value.
InsertValue() - Constructor for class io.shardingsphere.core.parsing.parser.context.insertvalue.InsertValue
 
InsertValues - Class in io.shardingsphere.core.parsing.parser.context.insertvalue
Insert values.
InsertValues() - Constructor for class io.shardingsphere.core.parsing.parser.context.insertvalue.InsertValues
 
InsertValuesClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Insert values clause parser.
InsertValuesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.InsertValuesClauseParser
 
InsertValuesPlaceholder - Class in io.shardingsphere.core.rewrite.placeholder
Insert values placeholder for rewrite.
InsertValuesPlaceholder() - Constructor for class io.shardingsphere.core.rewrite.placeholder.InsertValuesPlaceholder
 
InsertValuesToken - Class in io.shardingsphere.core.parsing.parser.token
Insert values token.
InsertValuesToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.InsertValuesToken
 
InstanceListenerManager - Class in io.shardingsphere.jdbc.orchestration.internal.state.instance
Instance listener manager.
InstanceListenerManager(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.state.instance.InstanceListenerManager
 
InstanceStateService - Class in io.shardingsphere.jdbc.orchestration.internal.state.instance
Instance state service.
InstanceStateService(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.state.instance.InstanceStateService
 
invoke(Object) - Method in class io.shardingsphere.core.jdbc.adapter.invocation.JdbcMethodInvocation
Invoke JDBC method.
io.shardingsphere.core.api - package io.shardingsphere.core.api
 
io.shardingsphere.core.api.algorithm.masterslave - package io.shardingsphere.core.api.algorithm.masterslave
 
io.shardingsphere.core.api.algorithm.sharding - package io.shardingsphere.core.api.algorithm.sharding
 
io.shardingsphere.core.api.algorithm.sharding.complex - package io.shardingsphere.core.api.algorithm.sharding.complex
 
io.shardingsphere.core.api.algorithm.sharding.hint - package io.shardingsphere.core.api.algorithm.sharding.hint
 
io.shardingsphere.core.api.algorithm.sharding.standard - package io.shardingsphere.core.api.algorithm.sharding.standard
 
io.shardingsphere.core.api.config - package io.shardingsphere.core.api.config
 
io.shardingsphere.core.api.config.strategy - package io.shardingsphere.core.api.config.strategy
 
io.shardingsphere.core.api.yaml - package io.shardingsphere.core.api.yaml
 
io.shardingsphere.core.constant - package io.shardingsphere.core.constant
 
io.shardingsphere.core.exception - package io.shardingsphere.core.exception
 
io.shardingsphere.core.executor - package io.shardingsphere.core.executor
 
io.shardingsphere.core.executor.event - package io.shardingsphere.core.executor.event
 
io.shardingsphere.core.executor.threadlocal - package io.shardingsphere.core.executor.threadlocal
 
io.shardingsphere.core.executor.type.batch - package io.shardingsphere.core.executor.type.batch
 
io.shardingsphere.core.executor.type.prepared - package io.shardingsphere.core.executor.type.prepared
 
io.shardingsphere.core.executor.type.statement - package io.shardingsphere.core.executor.type.statement
 
io.shardingsphere.core.hint - package io.shardingsphere.core.hint
 
io.shardingsphere.core.jdbc.adapter - package io.shardingsphere.core.jdbc.adapter
 
io.shardingsphere.core.jdbc.adapter.invocation - package io.shardingsphere.core.jdbc.adapter.invocation
 
io.shardingsphere.core.jdbc.core - package io.shardingsphere.core.jdbc.core
 
io.shardingsphere.core.jdbc.core.connection - package io.shardingsphere.core.jdbc.core.connection
 
io.shardingsphere.core.jdbc.core.datasource - package io.shardingsphere.core.jdbc.core.datasource
 
io.shardingsphere.core.jdbc.core.resultset - package io.shardingsphere.core.jdbc.core.resultset
 
io.shardingsphere.core.jdbc.core.statement - package io.shardingsphere.core.jdbc.core.statement
 
io.shardingsphere.core.jdbc.metadata - package io.shardingsphere.core.jdbc.metadata
 
io.shardingsphere.core.jdbc.metadata.dialect - package io.shardingsphere.core.jdbc.metadata.dialect
 
io.shardingsphere.core.jdbc.unsupported - package io.shardingsphere.core.jdbc.unsupported
 
io.shardingsphere.core.keygen - package io.shardingsphere.core.keygen
 
io.shardingsphere.core.merger - package io.shardingsphere.core.merger
 
io.shardingsphere.core.merger.dal - package io.shardingsphere.core.merger.dal
 
io.shardingsphere.core.merger.dal.show - package io.shardingsphere.core.merger.dal.show
 
io.shardingsphere.core.merger.dql - package io.shardingsphere.core.merger.dql
 
io.shardingsphere.core.merger.dql.common - package io.shardingsphere.core.merger.dql.common
 
io.shardingsphere.core.merger.dql.groupby - package io.shardingsphere.core.merger.dql.groupby
 
io.shardingsphere.core.merger.dql.groupby.aggregation - package io.shardingsphere.core.merger.dql.groupby.aggregation
 
io.shardingsphere.core.merger.dql.iterator - package io.shardingsphere.core.merger.dql.iterator
 
io.shardingsphere.core.merger.dql.orderby - package io.shardingsphere.core.merger.dql.orderby
 
io.shardingsphere.core.merger.dql.pagination - package io.shardingsphere.core.merger.dql.pagination
 
io.shardingsphere.core.metadata - package io.shardingsphere.core.metadata
 
io.shardingsphere.core.optimizer - package io.shardingsphere.core.optimizer
 
io.shardingsphere.core.optimizer.condition - package io.shardingsphere.core.optimizer.condition
 
io.shardingsphere.core.optimizer.insert - package io.shardingsphere.core.optimizer.insert
 
io.shardingsphere.core.optimizer.query - package io.shardingsphere.core.optimizer.query
 
io.shardingsphere.core.parsing - package io.shardingsphere.core.parsing
 
io.shardingsphere.core.parsing.cache - package io.shardingsphere.core.parsing.cache
 
io.shardingsphere.core.parsing.lexer - package io.shardingsphere.core.parsing.lexer
 
io.shardingsphere.core.parsing.lexer.analyzer - package io.shardingsphere.core.parsing.lexer.analyzer
 
io.shardingsphere.core.parsing.lexer.dialect.mysql - package io.shardingsphere.core.parsing.lexer.dialect.mysql
 
io.shardingsphere.core.parsing.lexer.dialect.oracle - package io.shardingsphere.core.parsing.lexer.dialect.oracle
 
io.shardingsphere.core.parsing.lexer.dialect.postgresql - package io.shardingsphere.core.parsing.lexer.dialect.postgresql
 
io.shardingsphere.core.parsing.lexer.dialect.sqlserver - package io.shardingsphere.core.parsing.lexer.dialect.sqlserver
 
io.shardingsphere.core.parsing.lexer.token - package io.shardingsphere.core.parsing.lexer.token
 
io.shardingsphere.core.parsing.parser.clause - package io.shardingsphere.core.parsing.parser.clause
 
io.shardingsphere.core.parsing.parser.clause.condition - package io.shardingsphere.core.parsing.parser.clause.condition
 
io.shardingsphere.core.parsing.parser.clause.expression - package io.shardingsphere.core.parsing.parser.clause.expression
 
io.shardingsphere.core.parsing.parser.clause.facade - package io.shardingsphere.core.parsing.parser.clause.facade
 
io.shardingsphere.core.parsing.parser.context - package io.shardingsphere.core.parsing.parser.context
 
io.shardingsphere.core.parsing.parser.context.condition - package io.shardingsphere.core.parsing.parser.context.condition
 
io.shardingsphere.core.parsing.parser.context.insertvalue - package io.shardingsphere.core.parsing.parser.context.insertvalue
 
io.shardingsphere.core.parsing.parser.context.limit - package io.shardingsphere.core.parsing.parser.context.limit
 
io.shardingsphere.core.parsing.parser.context.selectitem - package io.shardingsphere.core.parsing.parser.context.selectitem
 
io.shardingsphere.core.parsing.parser.context.table - package io.shardingsphere.core.parsing.parser.context.table
 
io.shardingsphere.core.parsing.parser.dialect - package io.shardingsphere.core.parsing.parser.dialect
 
io.shardingsphere.core.parsing.parser.dialect.mysql.clause - package io.shardingsphere.core.parsing.parser.dialect.mysql.clause
 
io.shardingsphere.core.parsing.parser.dialect.mysql.clause.expression - package io.shardingsphere.core.parsing.parser.dialect.mysql.clause.expression
 
io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade - package io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade
 
io.shardingsphere.core.parsing.parser.dialect.mysql.sql - package io.shardingsphere.core.parsing.parser.dialect.mysql.sql
 
io.shardingsphere.core.parsing.parser.dialect.mysql.statement - package io.shardingsphere.core.parsing.parser.dialect.mysql.statement
 
io.shardingsphere.core.parsing.parser.dialect.oracle.clause - package io.shardingsphere.core.parsing.parser.dialect.oracle.clause
 
io.shardingsphere.core.parsing.parser.dialect.oracle.clause.expression - package io.shardingsphere.core.parsing.parser.dialect.oracle.clause.expression
 
io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade - package io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade
 
io.shardingsphere.core.parsing.parser.dialect.oracle.sql - package io.shardingsphere.core.parsing.parser.dialect.oracle.sql
 
io.shardingsphere.core.parsing.parser.dialect.postgresql.clause - package io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
 
io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.expression - package io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.expression
 
io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade - package io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade
 
io.shardingsphere.core.parsing.parser.dialect.postgresql.sql - package io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
 
io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause - package io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
 
io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.expression - package io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.expression
 
io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade - package io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade
 
io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql - package io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
 
io.shardingsphere.core.parsing.parser.exception - package io.shardingsphere.core.parsing.parser.exception
 
io.shardingsphere.core.parsing.parser.expression - package io.shardingsphere.core.parsing.parser.expression
 
io.shardingsphere.core.parsing.parser.sql - package io.shardingsphere.core.parsing.parser.sql
 
io.shardingsphere.core.parsing.parser.sql.dal - package io.shardingsphere.core.parsing.parser.sql.dal
 
io.shardingsphere.core.parsing.parser.sql.dal.describe - package io.shardingsphere.core.parsing.parser.sql.dal.describe
 
io.shardingsphere.core.parsing.parser.sql.dal.show - package io.shardingsphere.core.parsing.parser.sql.dal.show
 
io.shardingsphere.core.parsing.parser.sql.dal.use - package io.shardingsphere.core.parsing.parser.sql.dal.use
 
io.shardingsphere.core.parsing.parser.sql.ddl - package io.shardingsphere.core.parsing.parser.sql.ddl
 
io.shardingsphere.core.parsing.parser.sql.ddl.alter - package io.shardingsphere.core.parsing.parser.sql.ddl.alter
 
io.shardingsphere.core.parsing.parser.sql.ddl.create - package io.shardingsphere.core.parsing.parser.sql.ddl.create
 
io.shardingsphere.core.parsing.parser.sql.ddl.drop - package io.shardingsphere.core.parsing.parser.sql.ddl.drop
 
io.shardingsphere.core.parsing.parser.sql.ddl.truncate - package io.shardingsphere.core.parsing.parser.sql.ddl.truncate
 
io.shardingsphere.core.parsing.parser.sql.dml - package io.shardingsphere.core.parsing.parser.sql.dml
 
io.shardingsphere.core.parsing.parser.sql.dml.delete - package io.shardingsphere.core.parsing.parser.sql.dml.delete
 
io.shardingsphere.core.parsing.parser.sql.dml.insert - package io.shardingsphere.core.parsing.parser.sql.dml.insert
 
io.shardingsphere.core.parsing.parser.sql.dml.update - package io.shardingsphere.core.parsing.parser.sql.dml.update
 
io.shardingsphere.core.parsing.parser.sql.dql - package io.shardingsphere.core.parsing.parser.sql.dql
 
io.shardingsphere.core.parsing.parser.sql.dql.select - package io.shardingsphere.core.parsing.parser.sql.dql.select
 
io.shardingsphere.core.parsing.parser.sql.tcl - package io.shardingsphere.core.parsing.parser.sql.tcl
 
io.shardingsphere.core.parsing.parser.token - package io.shardingsphere.core.parsing.parser.token
 
io.shardingsphere.core.rewrite - package io.shardingsphere.core.rewrite
 
io.shardingsphere.core.rewrite.placeholder - package io.shardingsphere.core.rewrite.placeholder
 
io.shardingsphere.core.routing - package io.shardingsphere.core.routing
 
io.shardingsphere.core.routing.router.masterslave - package io.shardingsphere.core.routing.router.masterslave
 
io.shardingsphere.core.routing.router.sharding - package io.shardingsphere.core.routing.router.sharding
 
io.shardingsphere.core.routing.strategy - package io.shardingsphere.core.routing.strategy
 
io.shardingsphere.core.routing.strategy.complex - package io.shardingsphere.core.routing.strategy.complex
 
io.shardingsphere.core.routing.strategy.hint - package io.shardingsphere.core.routing.strategy.hint
 
io.shardingsphere.core.routing.strategy.inline - package io.shardingsphere.core.routing.strategy.inline
 
io.shardingsphere.core.routing.strategy.none - package io.shardingsphere.core.routing.strategy.none
 
io.shardingsphere.core.routing.strategy.standard - package io.shardingsphere.core.routing.strategy.standard
 
io.shardingsphere.core.routing.type - package io.shardingsphere.core.routing.type
 
io.shardingsphere.core.routing.type.broadcast - package io.shardingsphere.core.routing.type.broadcast
 
io.shardingsphere.core.routing.type.complex - package io.shardingsphere.core.routing.type.complex
 
io.shardingsphere.core.routing.type.hint - package io.shardingsphere.core.routing.type.hint
 
io.shardingsphere.core.routing.type.ignore - package io.shardingsphere.core.routing.type.ignore
 
io.shardingsphere.core.routing.type.standard - package io.shardingsphere.core.routing.type.standard
 
io.shardingsphere.core.routing.type.unicast - package io.shardingsphere.core.routing.type.unicast
 
io.shardingsphere.core.rule - package io.shardingsphere.core.rule
 
io.shardingsphere.core.util - package io.shardingsphere.core.util
 
io.shardingsphere.core.yaml.masterslave - package io.shardingsphere.core.yaml.masterslave
 
io.shardingsphere.core.yaml.proxy - package io.shardingsphere.core.yaml.proxy
 
io.shardingsphere.core.yaml.sharding - package io.shardingsphere.core.yaml.sharding
 
io.shardingsphere.core.yaml.sharding.strategy - package io.shardingsphere.core.yaml.sharding.strategy
 
io.shardingsphere.jdbc.orchestration.api - package io.shardingsphere.jdbc.orchestration.api
 
io.shardingsphere.jdbc.orchestration.api.config - package io.shardingsphere.jdbc.orchestration.api.config
 
io.shardingsphere.jdbc.orchestration.api.yaml - package io.shardingsphere.jdbc.orchestration.api.yaml
 
io.shardingsphere.jdbc.orchestration.internal - package io.shardingsphere.jdbc.orchestration.internal
 
io.shardingsphere.jdbc.orchestration.internal.config - package io.shardingsphere.jdbc.orchestration.internal.config
 
io.shardingsphere.jdbc.orchestration.internal.jdbc.connection - package io.shardingsphere.jdbc.orchestration.internal.jdbc.connection
 
io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource - package io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource
 
io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata - package io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata
 
io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset - package io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset
 
io.shardingsphere.jdbc.orchestration.internal.jdbc.statement - package io.shardingsphere.jdbc.orchestration.internal.jdbc.statement
 
io.shardingsphere.jdbc.orchestration.internal.json - package io.shardingsphere.jdbc.orchestration.internal.json
 
io.shardingsphere.jdbc.orchestration.internal.listener - package io.shardingsphere.jdbc.orchestration.internal.listener
 
io.shardingsphere.jdbc.orchestration.internal.state - package io.shardingsphere.jdbc.orchestration.internal.state
 
io.shardingsphere.jdbc.orchestration.internal.state.datasource - package io.shardingsphere.jdbc.orchestration.internal.state.datasource
 
io.shardingsphere.jdbc.orchestration.internal.state.instance - package io.shardingsphere.jdbc.orchestration.internal.state.instance
 
io.shardingsphere.jdbc.orchestration.internal.util - package io.shardingsphere.jdbc.orchestration.internal.util
 
io.shardingsphere.jdbc.orchestration.reg.api - package io.shardingsphere.jdbc.orchestration.reg.api
 
io.shardingsphere.jdbc.orchestration.reg.etcd - package io.shardingsphere.jdbc.orchestration.reg.etcd
 
io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel - package io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel
 
io.shardingsphere.jdbc.orchestration.reg.etcd.internal.keepalive - package io.shardingsphere.jdbc.orchestration.reg.etcd.internal.keepalive
 
io.shardingsphere.jdbc.orchestration.reg.etcd.internal.retry - package io.shardingsphere.jdbc.orchestration.reg.etcd.internal.retry
 
io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher - package io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher
 
io.shardingsphere.jdbc.orchestration.reg.exception - package io.shardingsphere.jdbc.orchestration.reg.exception
 
io.shardingsphere.jdbc.orchestration.reg.listener - package io.shardingsphere.jdbc.orchestration.reg.listener
 
io.shardingsphere.jdbc.orchestration.reg.zookeeper - package io.shardingsphere.jdbc.orchestration.reg.zookeeper
 
io.shardingsphere.jdbc.orchestration.spring.boot - package io.shardingsphere.jdbc.orchestration.spring.boot
 
io.shardingsphere.jdbc.orchestration.spring.boot.masterslave - package io.shardingsphere.jdbc.orchestration.spring.boot.masterslave
 
io.shardingsphere.jdbc.orchestration.spring.boot.orchestration - package io.shardingsphere.jdbc.orchestration.spring.boot.orchestration
 
io.shardingsphere.jdbc.orchestration.spring.boot.sharding - package io.shardingsphere.jdbc.orchestration.spring.boot.sharding
 
io.shardingsphere.jdbc.orchestration.spring.boot.util - package io.shardingsphere.jdbc.orchestration.spring.boot.util
 
io.shardingsphere.jdbc.orchestration.spring.datasource - package io.shardingsphere.jdbc.orchestration.spring.datasource
 
io.shardingsphere.jdbc.orchestration.spring.namespace.constants - package io.shardingsphere.jdbc.orchestration.spring.namespace.constants
 
io.shardingsphere.jdbc.orchestration.spring.namespace.handler - package io.shardingsphere.jdbc.orchestration.spring.namespace.handler
 
io.shardingsphere.jdbc.orchestration.spring.namespace.parser - package io.shardingsphere.jdbc.orchestration.spring.namespace.parser
 
io.shardingsphere.jdbc.orchestration.yaml - package io.shardingsphere.jdbc.orchestration.yaml
 
io.shardingsphere.jdbc.spring.boot - package io.shardingsphere.jdbc.spring.boot
 
io.shardingsphere.jdbc.spring.boot.masterslave - package io.shardingsphere.jdbc.spring.boot.masterslave
 
io.shardingsphere.jdbc.spring.boot.sharding - package io.shardingsphere.jdbc.spring.boot.sharding
 
io.shardingsphere.jdbc.spring.boot.util - package io.shardingsphere.jdbc.spring.boot.util
 
io.shardingsphere.jdbc.spring.datasource - package io.shardingsphere.jdbc.spring.datasource
 
io.shardingsphere.jdbc.spring.namespace.constants - package io.shardingsphere.jdbc.spring.namespace.constants
 
io.shardingsphere.jdbc.spring.namespace.handler - package io.shardingsphere.jdbc.spring.namespace.handler
 
io.shardingsphere.jdbc.spring.namespace.parser - package io.shardingsphere.jdbc.spring.namespace.parser
 
io.shardingsphere.opentracing - package io.shardingsphere.opentracing
 
io.shardingsphere.opentracing.config - package io.shardingsphere.opentracing.config
 
io.shardingsphere.proxy - package io.shardingsphere.proxy
 
io.shardingsphere.proxy.backend.common - package io.shardingsphere.proxy.backend.common
 
io.shardingsphere.proxy.backend.mysql - package io.shardingsphere.proxy.backend.mysql
 
io.shardingsphere.proxy.config - package io.shardingsphere.proxy.config
 
io.shardingsphere.proxy.frontend - package io.shardingsphere.proxy.frontend
 
io.shardingsphere.proxy.frontend.common - package io.shardingsphere.proxy.frontend.common
 
io.shardingsphere.proxy.frontend.mysql - package io.shardingsphere.proxy.frontend.mysql
 
io.shardingsphere.proxy.frontend.netty - package io.shardingsphere.proxy.frontend.netty
 
io.shardingsphere.proxy.metadata - package io.shardingsphere.proxy.metadata
 
io.shardingsphere.proxy.transport.common.codec - package io.shardingsphere.proxy.transport.common.codec
 
io.shardingsphere.proxy.transport.common.packet - package io.shardingsphere.proxy.transport.common.packet
 
io.shardingsphere.proxy.transport.mysql.codec - package io.shardingsphere.proxy.transport.mysql.codec
 
io.shardingsphere.proxy.transport.mysql.constant - package io.shardingsphere.proxy.transport.mysql.constant
 
io.shardingsphere.proxy.transport.mysql.packet - package io.shardingsphere.proxy.transport.mysql.packet
 
io.shardingsphere.proxy.transport.mysql.packet.command - package io.shardingsphere.proxy.transport.mysql.packet.command
 
io.shardingsphere.proxy.transport.mysql.packet.command.statement - package io.shardingsphere.proxy.transport.mysql.packet.command.statement
 
io.shardingsphere.proxy.transport.mysql.packet.command.statement.close - package io.shardingsphere.proxy.transport.mysql.packet.command.statement.close
 
io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute - package io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
 
io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare - package io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare
 
io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist - package io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist
 
io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb - package io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb
 
io.shardingsphere.proxy.transport.mysql.packet.command.text.ping - package io.shardingsphere.proxy.transport.mysql.packet.command.text.ping
 
io.shardingsphere.proxy.transport.mysql.packet.command.text.query - package io.shardingsphere.proxy.transport.mysql.packet.command.text.query
 
io.shardingsphere.proxy.transport.mysql.packet.command.text.quit - package io.shardingsphere.proxy.transport.mysql.packet.command.text.quit
 
io.shardingsphere.proxy.transport.mysql.packet.generic - package io.shardingsphere.proxy.transport.mysql.packet.generic
 
io.shardingsphere.proxy.transport.mysql.packet.handshake - package io.shardingsphere.proxy.transport.mysql.packet.handshake
 
io.shardingsphere.test.sql - package io.shardingsphere.test.sql
 
io.shardingsphere.transaction.api - package io.shardingsphere.transaction.api
 
io.shardingsphere.transaction.api.config - package io.shardingsphere.transaction.api.config
 
io.shardingsphere.transaction.bed - package io.shardingsphere.transaction.bed
 
io.shardingsphere.transaction.bed.sync - package io.shardingsphere.transaction.bed.sync
 
io.shardingsphere.transaction.config - package io.shardingsphere.transaction.config
 
io.shardingsphere.transaction.constants - package io.shardingsphere.transaction.constants
 
io.shardingsphere.transaction.datasource - package io.shardingsphere.transaction.datasource
 
io.shardingsphere.transaction.datasource.impl - package io.shardingsphere.transaction.datasource.impl
 
io.shardingsphere.transaction.exception - package io.shardingsphere.transaction.exception
 
io.shardingsphere.transaction.job - package io.shardingsphere.transaction.job
 
io.shardingsphere.transaction.storage - package io.shardingsphere.transaction.storage
 
io.shardingsphere.transaction.storage.impl - package io.shardingsphere.transaction.storage.impl
 
io.shardingsphere.transaction.tcc - package io.shardingsphere.transaction.tcc
 
IpUtils - Class in io.shardingsphere.jdbc.orchestration.internal.util
获取真实本机网络的服务.
IpUtils() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.util.IpUtils
 
isAfterLast() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
isAllBindingTables(Collection<String>) - Method in class io.shardingsphere.core.rule.ShardingRule
Adjust logic tables is all belong to binding tables.
isAllInDefaultDataSource(Collection<String>) - Method in class io.shardingsphere.core.rule.ShardingRule
Adjust logic tables is all belong to default data source.
isAlphabet(char) - Static method in class io.shardingsphere.core.parsing.lexer.analyzer.CharType
Adjust is alphabet or not.
isAlwaysFalse() - Method in class io.shardingsphere.core.optimizer.condition.ShardingConditions
Adjust sharding conditions is always false or not.
isAutoIncrement(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isAutoIncrement(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isBeforeFirst() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
isBooleanValue(String) - Static method in class io.shardingsphere.core.util.StringUtil
Adjust is boolean value or not.
isCaseSensitive(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isCaseSensitive(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isCatalogAtStart() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
isClosed() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
isClosed() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
isClosed() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
isClosed() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
isClosed() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
isClosed() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
isClosed() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
isCloseOnCompletion() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
isCommentBegin() - Method in class io.shardingsphere.core.parsing.lexer.dialect.mysql.MySQLLexer
 
isCommentBegin() - Method in class io.shardingsphere.core.parsing.lexer.Lexer
 
isCurrency(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isCurrency(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isDatabaseShardingOnly() - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Adjust database sharding only.
isDefinitelyWritable(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isDefinitelyWritable(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isDigital(char) - Static method in class io.shardingsphere.core.parsing.lexer.analyzer.CharType
Adjust is digital or not.
isEmpty() - Method in class io.shardingsphere.core.parsing.parser.context.table.Tables
判断是否为空.
isEndOfInput(char) - Static method in class io.shardingsphere.core.parsing.lexer.analyzer.CharType
Adjust is end of input or not.
isExceptionThrown() - Static method in class io.shardingsphere.core.executor.threadlocal.ExecutorExceptionHandler
Get throw exception if error occur or not.
isExisted(String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Adjust data is existed or not.
isExisted(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
isExisted(String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
isFirst() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
isHintBegin() - Method in class io.shardingsphere.core.parsing.lexer.dialect.mysql.MySQLLexer
 
isHintBegin() - Method in class io.shardingsphere.core.parsing.lexer.dialect.oracle.OracleLexer
 
isHintBegin() - Method in class io.shardingsphere.core.parsing.lexer.dialect.sqlserver.SQLServerLexer
 
isHintBegin() - Method in class io.shardingsphere.core.parsing.lexer.Lexer
 
isIntValue(String) - Static method in class io.shardingsphere.core.util.StringUtil
Adjust is int value or not.
isLast() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
isLogicIndex(String, String) - Method in class io.shardingsphere.core.rule.ShardingRule
Adjust is logic index or not.
isLongValue(String) - Static method in class io.shardingsphere.core.util.StringUtil
Adjust is long value or not.
isMasterRouteOnly() - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Adjust is force route to master database only or not.
isMasterVisited() - Static method in class io.shardingsphere.core.routing.router.masterslave.MasterVisitedManager
Adjust master data source visited in current thread.
isNeedRewriteRowCount() - Method in class io.shardingsphere.core.parsing.parser.context.limit.Limit
Is need rewrite row count.
isNullable(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isNullable(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isParameterNull(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.NullBitmap
Is parameter null.
isPoolable() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
isPoolable() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
isReadOnly() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
isReadOnly(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isReadOnly() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
isReadOnly() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
isReadOnly(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isRowNumberCondition(List<SelectItem>, String) - Method in class io.shardingsphere.core.parsing.parser.clause.WhereClauseParser
 
isRowNumberCondition(List<SelectItem>, String) - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleWhereClauseParser
 
isRowNumberCondition(List<SelectItem>, String) - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerWhereClauseParser
 
isRowNumberSelectItem() - Method in class io.shardingsphere.core.parsing.parser.clause.SelectListClauseParser
 
isRowNumberSelectItem() - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerSelectListClauseParser
 
isSameGroupByAndOrderByItems() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Adjust group by and order by sequence is same or not.
isSearchable(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isSearchable(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isShardingColumn(Column) - Method in class io.shardingsphere.core.rule.ShardingRule
Adjust is sharding column or not.
isSigned(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isSigned(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isSingleRouting() - Method in class io.shardingsphere.core.routing.type.RoutingResult
Adjust is route for single database and table only or not.
isSingleTable() - Method in class io.shardingsphere.core.parsing.parser.context.table.Tables
判断是否为单表.
isSingleton() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
isSingleton() - Method in class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
isSupportNChars() - Method in class io.shardingsphere.core.parsing.lexer.dialect.sqlserver.SQLServerLexer
 
isSupportNChars() - Method in class io.shardingsphere.core.parsing.lexer.Lexer
 
isSymbol(char) - Static method in class io.shardingsphere.core.parsing.lexer.analyzer.CharType
Adjust is symbol or not.
isTableExist(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.DefaultShardingMetaDataHandler
 
isTableExist(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.H2ShardingMetaDataHandler
 
isTableExist(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.MySQLShardingMetaDataHandler
 
isTableExist(Connection) - Method in class io.shardingsphere.core.jdbc.metadata.dialect.ShardingMetaDataHandler
Judge whether table exist or not.
isUseShardingHint() - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Adjust use sharding hint in current thread.
isValid(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
isValidHeader(int) - Method in class io.shardingsphere.proxy.transport.common.codec.PacketCodec
 
isValidHeader(int) - Method in class io.shardingsphere.proxy.transport.mysql.codec.MySQLPacketCodec
 
isVariableBegin() - Method in class io.shardingsphere.core.parsing.lexer.dialect.mysql.MySQLLexer
 
isVariableBegin() - Method in class io.shardingsphere.core.parsing.lexer.dialect.sqlserver.SQLServerLexer
 
isVariableBegin() - Method in class io.shardingsphere.core.parsing.lexer.Lexer
 
isWhitespace(char) - Static method in class io.shardingsphere.core.parsing.lexer.analyzer.CharType
Adjust is whitespace or not.
isWrapperFor(Class<?>) - Method in class io.shardingsphere.core.jdbc.adapter.WrapperAdapter
 
isWrapperFor(Class<?>) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
isWrapperFor(Class<?>) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
isWritable(int) - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSetMetaData
 
isWritable(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
ItemsToken - Class in io.shardingsphere.core.parsing.parser.token
Select items token.
ItemsToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.ItemsToken
 
IteratorStreamMergedResult - Class in io.shardingsphere.core.merger.dql.iterator
Stream merged result for iterator.
IteratorStreamMergedResult(List<QueryResult>) - Constructor for class io.shardingsphere.core.merger.dql.iterator.IteratorStreamMergedResult
 

J

JdbcMethodInvocation - Class in io.shardingsphere.core.jdbc.adapter.invocation
Invocation that reflected call for JDBC method.
JdbcMethodInvocation() - Constructor for class io.shardingsphere.core.jdbc.adapter.invocation.JdbcMethodInvocation
 
JDBCQueryResult - Class in io.shardingsphere.core.merger
Query result form database for JDBC.
JDBCQueryResult() - Constructor for class io.shardingsphere.core.merger.JDBCQueryResult
 
JDBCShardingMetaData - Class in io.shardingsphere.core.jdbc.metadata
Sharding metadata for JDBC.
JDBCShardingMetaData() - Constructor for class io.shardingsphere.core.jdbc.metadata.JDBCShardingMetaData
 
JDBCShardingRefreshHandler - Class in io.shardingsphere.core.jdbc.metadata.dialect
Refresh table metadata of JDBC sharding.
judge() - Method in class io.shardingsphere.core.parsing.SQLJudgeEngine
judge SQL Type only.

K

KeepAlive - Class in io.shardingsphere.jdbc.orchestration.reg.etcd.internal.keepalive
Keep the lease alive.
KeepAlive(Channel, long) - Constructor for class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.keepalive.KeepAlive
 
KEY_GENERATOR_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
KEY_GENERATOR_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
KeyGenerator - Interface in io.shardingsphere.core.keygen
Key generator interface.
KeyGeneratorFactory - Class in io.shardingsphere.core.keygen
Key generator factory.
KeyGeneratorFactory() - Constructor for class io.shardingsphere.core.keygen.KeyGeneratorFactory
 
KeyGeneratorGsonTypeAdapter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Key generator gson type adapter.
KeyGeneratorGsonTypeAdapter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.KeyGeneratorGsonTypeAdapter
 
Keyword - Interface in io.shardingsphere.core.parsing.lexer.token
Keyword interface.

L

last() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
Lexer - Class in io.shardingsphere.core.parsing.lexer
Lexical analysis.
Lexer() - Constructor for class io.shardingsphere.core.parsing.lexer.Lexer
 
LexerEngine - Class in io.shardingsphere.core.parsing.lexer
Lexical analysis engine.
LexerEngine() - Constructor for class io.shardingsphere.core.parsing.lexer.LexerEngine
 
LexerEngineFactory - Class in io.shardingsphere.core.parsing.lexer
Lexical analysis factory.
LexerEngineFactory() - Constructor for class io.shardingsphere.core.parsing.lexer.LexerEngineFactory
 
Limit - Class in io.shardingsphere.core.parsing.parser.context.limit
Limit object.
Limit() - Constructor for class io.shardingsphere.core.parsing.parser.context.limit.Limit
 
LimitDecoratorMergedResult - Class in io.shardingsphere.core.merger.dql.pagination
Decorator merged result for limit pagination.
LimitDecoratorMergedResult(MergedResult, Limit) - Constructor for class io.shardingsphere.core.merger.dql.pagination.LimitDecoratorMergedResult
 
LimitValue - Class in io.shardingsphere.core.parsing.parser.context.limit
Limit value.
LimitValue() - Constructor for class io.shardingsphere.core.parsing.parser.context.limit.LimitValue
 
listen(DMLExecutionEvent) - Method in class io.shardingsphere.transaction.bed.sync.BestEffortsDeliveryListener
Listen event.
listenDML(DMLExecutionEvent) - Method in class io.shardingsphere.opentracing.ExecuteEventListener
listen DML execution event.
listenDQL(DQLExecutionEvent) - Method in class io.shardingsphere.opentracing.ExecuteEventListener
listen DQL execution event.
ListenerFactory - Class in io.shardingsphere.jdbc.orchestration.internal.listener
Registry center's listener factory.
ListenerFactory(String, RegistryCenter) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.listener.ListenerFactory
 
ListenerManager - Interface in io.shardingsphere.jdbc.orchestration.internal.listener
Registry center's listener manager.
listenOverall(OverallExecutionEvent) - Method in class io.shardingsphere.opentracing.ExecuteEventListener
listen overall sql execution event.
ListShardingValue<T extends Comparable<?>> - Class in io.shardingsphere.core.api.algorithm.sharding
Sharding value for list values.
ListShardingValue() - Constructor for class io.shardingsphere.core.api.algorithm.sharding.ListShardingValue
 
Literals - Enum in io.shardingsphere.core.parsing.lexer.token
Literals token.
literalsOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.token.Symbol
通过字面量查找词法符号.
loadDataSourceMap() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Load data source configuration.
loadMasterSlaveConfigMap() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Load master-slave config map.
loadMasterSlaveRuleConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Load master-slave rule configuration.
loadShardingConfigMap() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Load sharding config map.
loadShardingProperties() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Load sharding properties configuration.
loadShardingRuleConfiguration() - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Load sharding rule configuration.
locatorsUpdateCopy() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
LOGIC_INDEX - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
LOGIC_INDEX_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
LOGIC_SCHEMA_NAME - Static variable in interface io.shardingsphere.core.constant.ShardingConstant
Logic database schema name.
LOGIC_TABLE_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
LOGIC_TABLE_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
LOGIC_TABLES_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
LOGIC_TABLES_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
logSQL(String, SQLStatement, Collection<SQLExecutionUnit>) - Static method in class io.shardingsphere.core.util.SQLLogger
Print SQL log.

M

main(String[]) - Static method in class io.shardingsphere.proxy.Bootstrap
Main Entrance.
main(String[]) - Static method in class io.shardingsphere.transaction.job.BASETransactionJobBootStrap
Main entrance.
mapAddBatchCount(int) - Method in class io.shardingsphere.core.executor.type.batch.BatchPreparedStatementUnit
Map times of use JDBC API call addBatch and times of actual call addBatch after route.
MASTER_DATA_SOURCE_NAME_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
MASTER_DATA_SOURCE_NAME_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
MASTER_SLAVE_CONFIG_MAP_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
MASTER_SLAVE_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
MASTER_SLAVE_RULE_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
MasterSlaveConnection - Class in io.shardingsphere.core.jdbc.core.connection
Connection that support master-slave.
MasterSlaveConnection() - Constructor for class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
MasterSlaveDataSource - Class in io.shardingsphere.core.jdbc.core.datasource
Database that support master-slave.
MasterSlaveDataSource(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>) - Constructor for class io.shardingsphere.core.jdbc.core.datasource.MasterSlaveDataSource
 
MasterSlaveDataSourceBeanDefinitionParser - Class in io.shardingsphere.jdbc.spring.namespace.parser
Master-slave data source parser for spring namespace.
MasterSlaveDataSourceBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.spring.namespace.parser.MasterSlaveDataSourceBeanDefinitionParser
 
MasterSlaveDataSourceBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.constants
Master-slave data source parser tag constants.
MasterSlaveDataSourceBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
MasterSlaveDataSourceBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.spring.namespace.constants
Master-slave data source parser tag constants.
MasterSlaveDataSourceBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
MasterSlaveDataSourceFactory - Class in io.shardingsphere.core.api
Master-slave data source factory.
MasterSlaveDataSourceFactory() - Constructor for class io.shardingsphere.core.api.MasterSlaveDataSourceFactory
 
MasterSlaveLoadBalanceAlgorithm - Interface in io.shardingsphere.core.api.algorithm.masterslave
Master-slave database load-balance algorithm.
MasterSlaveLoadBalanceAlgorithmGsonTypeAdapter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Master-slave load balance algorithm gson type adapter.
MasterSlaveLoadBalanceAlgorithmGsonTypeAdapter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.MasterSlaveLoadBalanceAlgorithmGsonTypeAdapter
 
MasterSlaveLoadBalanceAlgorithmType - Enum in io.shardingsphere.core.api.algorithm.masterslave
Master-slave database load-balance algorithm type.
MasterSlaveNamespaceHandler - Class in io.shardingsphere.jdbc.spring.namespace.handler
Spring namespace handler for master-slave.
MasterSlaveNamespaceHandler() - Constructor for class io.shardingsphere.jdbc.spring.namespace.handler.MasterSlaveNamespaceHandler
 
MasterSlavePreparedStatement - Class in io.shardingsphere.core.jdbc.core.statement
PreparedStatement that support master-slave.
MasterSlavePreparedStatement(MasterSlaveConnection, String) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
MasterSlavePreparedStatement(MasterSlaveConnection, String, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
MasterSlavePreparedStatement(MasterSlaveConnection, String, int, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
MasterSlavePreparedStatement(MasterSlaveConnection, String, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
MasterSlavePreparedStatement(MasterSlaveConnection, String, int[]) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
MasterSlavePreparedStatement(MasterSlaveConnection, String, String[]) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlavePreparedStatement
 
MasterSlaveRouter - Class in io.shardingsphere.core.routing.router.masterslave
Master slave router interface.
MasterSlaveRouter() - Constructor for class io.shardingsphere.core.routing.router.masterslave.MasterSlaveRouter
 
MasterSlaveRule - Class in io.shardingsphere.core.rule
Databases and tables master-slave rule configuration.
MasterSlaveRule(MasterSlaveRuleConfiguration) - Constructor for class io.shardingsphere.core.rule.MasterSlaveRule
 
MasterSlaveRuleConfiguration - Class in io.shardingsphere.core.api.config
Master-slave rule configuration.
MasterSlaveRuleConfiguration() - Constructor for class io.shardingsphere.core.api.config.MasterSlaveRuleConfiguration
 
MasterSlaveRuleConfigurationConverter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Master-slave rule configuration json converter.
MasterSlaveRuleConfigurationConverter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.MasterSlaveRuleConfigurationConverter
 
MasterSlaveStatement - Class in io.shardingsphere.core.jdbc.core.statement
Statement that support master-slave.
MasterSlaveStatement(MasterSlaveConnection) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
MasterSlaveStatement(MasterSlaveConnection, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
MasterSlaveStatement(MasterSlaveConnection, int, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.MasterSlaveStatement
 
MasterVisitedManager - Class in io.shardingsphere.core.routing.router.masterslave
Master data source visited manager.
MasterVisitedManager() - Constructor for class io.shardingsphere.core.routing.router.masterslave.MasterVisitedManager
 
MAX_RETRIES_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
MAX_RETRIES_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
MAX_SLEEP_TIME_MILLISECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
MemoryMergedResult - Class in io.shardingsphere.core.merger.dql.common
Memory merged result.
MemoryMergedResult() - Constructor for class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
MemoryQueryResultRow - Class in io.shardingsphere.core.merger.dql.common
Memory query result row.
MemoryQueryResultRow(QueryResult) - Constructor for class io.shardingsphere.core.merger.dql.common.MemoryQueryResultRow
 
MemoryTransactionLogDataSource - Class in io.shardingsphere.transaction.datasource.impl
Transaction log data source in memory.
MemoryTransactionLogDataSource() - Constructor for class io.shardingsphere.transaction.datasource.impl.MemoryTransactionLogDataSource
 
MemoryTransactionLogStorage - Class in io.shardingsphere.transaction.storage.impl
Transaction log memory storage.
MemoryTransactionLogStorage() - Constructor for class io.shardingsphere.transaction.storage.impl.MemoryTransactionLogStorage
 
merge() - Method in class io.shardingsphere.core.merger.dal.DALMergeEngine
 
merge() - Method in class io.shardingsphere.core.merger.dql.DQLMergeEngine
 
merge(List<Comparable<?>>) - Method in class io.shardingsphere.core.merger.dql.groupby.aggregation.AccumulationAggregationUnit
 
merge(List<Comparable<?>>) - Method in interface io.shardingsphere.core.merger.dql.groupby.aggregation.AggregationUnit
merge aggregation values.
merge(List<Comparable<?>>) - Method in class io.shardingsphere.core.merger.dql.groupby.aggregation.AverageAggregationUnit
 
merge(List<Comparable<?>>) - Method in class io.shardingsphere.core.merger.dql.groupby.aggregation.ComparableAggregationUnit
 
merge() - Method in interface io.shardingsphere.core.merger.MergeEngine
Merge result sets.
MergedResult - Interface in io.shardingsphere.core.merger
Merged result after merge engine.
MergeEngine - Interface in io.shardingsphere.core.merger
Result set merge engine.
MergeEngineFactory - Class in io.shardingsphere.core.merger
Result merge engine factory.
MergeEngineFactory() - Constructor for class io.shardingsphere.core.merger.MergeEngineFactory
 
mergeSubQueryStatement() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Merge sub query statement if contains.
moveToCurrentRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
moveToInsertRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
MultipleInsertValuesToken - Class in io.shardingsphere.core.parsing.parser.token
Multiple insert values token.
MultipleInsertValuesToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.MultipleInsertValuesToken
 
MySQLAliasExpressionParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause.expression
Alias clause parser for MySQL.
MySQLAliasExpressionParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.expression.MySQLAliasExpressionParser
 
MySQLAlterParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Alter parser for MySQL.
MySQLAlterParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLAlterParser
 
MySQLCreateParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Create parser for MySQL.
MySQLCreateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLCreateParser
 
MySQLDeleteClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade
Delete clause parser facade for MySQL.
MySQLDeleteClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade.MySQLDeleteClauseParserFacade
 
MySQLDeleteParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Delete parser for MySQL.
MySQLDeleteParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDeleteParser
 
MySQLDescribeParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Describe parser for MySQL.
MySQLDescribeParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDescribeParser
 
MySQLDistinctClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Distinct clause parser for MySQL.
MySQLDistinctClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLDistinctClauseParser
 
MySQLDropParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Drop parser for MySQL.
MySQLDropParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDropParser
 
MySQLFrontendHandler - Class in io.shardingsphere.proxy.frontend.mysql
MySQL frontend handler.
MySQLFrontendHandler() - Constructor for class io.shardingsphere.proxy.frontend.mysql.MySQLFrontendHandler
 
MySQLGroupByClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Group by clause parser for MySQL.
MySQLGroupByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLGroupByClauseParser
 
MySQLInsertClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade
Insert clause parser facade for MySQL.
MySQLInsertClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade.MySQLInsertClauseParserFacade
 
MySQLInsertIntoClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Insert into clause parser for MySQL.
MySQLInsertIntoClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLInsertIntoClauseParser
 
MySQLInsertParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Insert parser for MySQL.
MySQLInsertParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLInsertParser
 
MySQLInsertSetClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Insert set clause parser for MySQL.
MySQLInsertSetClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLInsertSetClauseParser
 
MySQLInsertValuesClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Insert values clause parser for MySQL.
MySQLInsertValuesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLInsertValuesClauseParser
 
MySQLKeyword - Enum in io.shardingsphere.core.parsing.lexer.dialect.mysql
MySQL keyword.
MySQLLexer - Class in io.shardingsphere.core.parsing.lexer.dialect.mysql
MySQL Lexical analysis.
MySQLLexer(String) - Constructor for class io.shardingsphere.core.parsing.lexer.dialect.mysql.MySQLLexer
 
MySQLLimitClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Limit clause parser for MySQL.
MySQLLimitClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLLimitClauseParser
 
MySQLPacket - Class in io.shardingsphere.proxy.transport.mysql.packet
MySQL packet.
MySQLPacket() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacket
 
MySQLPacketCodec - Class in io.shardingsphere.proxy.transport.mysql.codec
MySQL packet codec.
MySQLPacketCodec() - Constructor for class io.shardingsphere.proxy.transport.mysql.codec.MySQLPacketCodec
 
MySQLPacketPayload - Class in io.shardingsphere.proxy.transport.mysql.packet
Payload operation for MySQL packet data types.
MySQLPacketPayload() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
 
MySQLPacketQueryResult - Class in io.shardingsphere.proxy.backend.mysql
MySQL packet query result.
MySQLPacketQueryResult(CommandResponsePackets, ResultSet) - Constructor for class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
MySQLPacketStatementExecuteQueryResult - Class in io.shardingsphere.proxy.backend.mysql
MySQL packet statement execute query result.
MySQLPacketStatementExecuteQueryResult(CommandResponsePackets, ResultSet, List<ColumnType>) - Constructor for class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
MySQLSelectClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade
Select clause parser facade for MySQL.
MySQLSelectClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade.MySQLSelectClauseParserFacade
 
MySQLSelectOptionClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Select option clause parser for MySQL.
MySQLSelectOptionClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLSelectOptionClauseParser
 
MySQLSelectParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Select parser for MySQL.
MySQLSelectParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLSelectParser
 
MySQLSelectRestClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Select rest clause parser for MySQL.
MySQLSelectRestClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLSelectRestClauseParser
 
MySQLShardingMetaDataHandler - Class in io.shardingsphere.core.jdbc.metadata.dialect
MySQL table metadata handler.
MySQLShardingMetaDataHandler(DataSource, String) - Constructor for class io.shardingsphere.core.jdbc.metadata.dialect.MySQLShardingMetaDataHandler
 
MySQLShowParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Show parser for MySQL.
MySQLShowParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLShowParser
 
MySQLTableReferencesClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Select table references clause parser for MySQL.
MySQLTableReferencesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLTableReferencesClauseParser
 
MySQLTruncateParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Truncate parser for MySQL.
MySQLTruncateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLTruncateParser
 
MySQLUpdateClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade
Update clause parser facade for MySQL.
MySQLUpdateClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.facade.MySQLUpdateClauseParserFacade
 
MySQLUpdateParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Update parser for MySQL.
MySQLUpdateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLUpdateParser
 
MySQLUseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.sql
Use parser for MySQL.
MySQLUseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLUseParser
 
MySQLWhereClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.clause
Where clause parser for MySQL.
MySQLWhereClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLWhereClauseParser
 

N

NamedDataSource - Class in io.shardingsphere.core.jdbc.core.datasource
Data source with name.
NamedDataSource() - Constructor for class io.shardingsphere.core.jdbc.core.datasource.NamedDataSource
 
NAMESPACE_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
nativeSQL(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
NestedBestEffortsDeliveryJobConfiguration - Class in io.shardingsphere.transaction.api.config
Embed best efforts delivery B.A.S.E transaction asynchronized job configuration.
NestedBestEffortsDeliveryJobConfiguration() - Constructor for class io.shardingsphere.transaction.api.config.NestedBestEffortsDeliveryJobConfiguration
 
newInstance(DataSource, String, DatabaseType) - Static method in class io.shardingsphere.core.jdbc.metadata.ShardingMetaDataHandlerFactory
To generate table metadata handler by data type.
newInstance(String, DatabaseType) - Static method in class io.shardingsphere.core.jdbc.metadata.ShardingMetaDataHandlerFactory
To generate table metadata handler by existing sharding connection.
newInstance(String) - Static method in class io.shardingsphere.core.keygen.KeyGeneratorFactory
Create key generator.
newInstance(ShardingRule, List<QueryResult>, SQLStatement) - Static method in class io.shardingsphere.core.merger.MergeEngineFactory
Create merge engine instance.
newInstance(ShardingRule, SQLStatement, List<Object>, GeneratedKey) - Static method in class io.shardingsphere.core.optimizer.OptimizeEngineFactory
Create optimize engine instance.
newInstance(DatabaseType, String) - Static method in class io.shardingsphere.core.parsing.lexer.LexerEngineFactory
Create lexical analysis engine instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.dal.describe.DescribeParserFactory
Create describe parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.dal.show.ShowParserFactory
Create show parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.dal.use.UseParserFactory
Create use parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.ddl.alter.AlterParserFactory
Create alter parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.ddl.create.CreateParserFactory
Create create parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.ddl.drop.DropParserFactory
Create drop parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.ddl.truncate.TruncateParserFactory
Create truncate parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.dml.delete.DeleteParserFactory
Create delete parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine, ShardingMetaData) - Static method in class io.shardingsphere.core.parsing.parser.sql.dml.insert.InsertParserFactory
Create insert parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.dml.update.UpdateParserFactory
Create update parser instance.
newInstance(DatabaseType, ShardingRule, LexerEngine, ShardingMetaData) - Static method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectParserFactory
Create select parser instance.
newInstance(DatabaseType, TokenType, ShardingRule, LexerEngine, ShardingMetaData) - Static method in class io.shardingsphere.core.parsing.parser.sql.SQLParserFactory
Create SQL parser.
newInstance(DatabaseType, ShardingRule, LexerEngine) - Static method in class io.shardingsphere.core.parsing.parser.sql.tcl.TCLParserFactory
Create TCL parser instance.
newInstance(String, Class<T>) - Static method in class io.shardingsphere.core.routing.strategy.ShardingAlgorithmFactory
Create sharding algorithm.
newInstance(ShardingStrategyConfiguration) - Static method in class io.shardingsphere.core.routing.strategy.ShardingStrategyFactory
Create sharding algorithm.
newNameResolver(URI, Attributes) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.channel.EtcdNameSolverFactory
 
NewParametersBoundFlag - Enum in io.shardingsphere.proxy.transport.mysql.constant
New parameters bound flag.
next() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
next() - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
next() - Method in class io.shardingsphere.core.merger.dal.show.ShowCreateTableMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dal.show.ShowTablesMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByMemoryMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.groupby.GroupByStreamMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.iterator.IteratorStreamMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.orderby.OrderByStreamMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.orderby.OrderByValue
iterate next data.
next() - Method in class io.shardingsphere.core.merger.dql.pagination.LimitDecoratorMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.pagination.RowNumberDecoratorMergedResult
 
next() - Method in class io.shardingsphere.core.merger.dql.pagination.TopAndRowNumberDecoratorMergedResult
 
next() - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
next() - Method in interface io.shardingsphere.core.merger.MergedResult
iterate next data.
next() - Method in interface io.shardingsphere.core.merger.QueryResult
iterate next data.
next() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
next() - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
next() - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
nextId() - Method in class io.shardingsphere.proxy.transport.mysql.packet.handshake.ConnectionIdGenerator
Get next connection ID.
nextToken() - Method in class io.shardingsphere.core.parsing.lexer.Lexer
Analyse next token.
nextToken() - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Analyse next token.
NONE_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
NONE_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
NoneShardingStrategy - Class in io.shardingsphere.core.routing.strategy.none
None sharding strategy.
NoneShardingStrategy() - Constructor for class io.shardingsphere.core.routing.strategy.none.NoneShardingStrategy
 
NoneShardingStrategyConfiguration - Class in io.shardingsphere.core.api.config.strategy
None sharding strategy configuration.
NoneShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.api.config.strategy.NoneShardingStrategyConfiguration
 
NullBitmap - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
Null bitmap.
NullBitmap(int, int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.NullBitmap
 
NullCondition - Class in io.shardingsphere.core.parsing.parser.clause.condition
No sharding condition.
NullCondition() - Constructor for class io.shardingsphere.core.parsing.parser.clause.condition.NullCondition
 
nullPlusNonNullIsNull() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
nullsAreSortedAtEnd() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
nullsAreSortedAtStart() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
nullsAreSortedHigh() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
nullsAreSortedLow() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
NumberUtil - Class in io.shardingsphere.core.util
Number utility class.
NumberUtil() - Constructor for class io.shardingsphere.core.util.NumberUtil
 

O

obtainMasterSlaveRule() - Method in class io.shardingsphere.core.yaml.proxy.YamlProxyConfiguration
Get master slave rule from yaml.
obtainShardingRule(Collection<String>) - Method in class io.shardingsphere.core.yaml.proxy.YamlProxyConfiguration
Get sharding rule from yaml.
OffsetToken - Class in io.shardingsphere.core.parsing.parser.token
Offset token for limit.
OffsetToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.OffsetToken
 
OKPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.generic
OK packet protocol.
OKPacket(int, long, long, int, int, String) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.generic.OKPacket
 
OKPacket(MySQLPacketPayload) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.generic.OKPacket
 
onChange(DataChangedEvent) - Method in interface io.shardingsphere.jdbc.orchestration.reg.listener.EventListener
Fire when event changed.
onCompleted() - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher.EtcdWatchStreamObserver
 
onError(Throwable) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher.EtcdWatchStreamObserver
 
onNext(Rpc.WatchResponse) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.internal.watcher.EtcdWatchStreamObserver
 
OpentracingConfigurationParser - Class in io.shardingsphere.opentracing.config
Parse config from java opts.
OpentracingConfigurationParser() - Constructor for class io.shardingsphere.opentracing.config.OpentracingConfigurationParser
 
optimize() - Method in class io.shardingsphere.core.optimizer.insert.InsertOptimizeEngine
 
optimize() - Method in interface io.shardingsphere.core.optimizer.OptimizeEngine
Optimize sharding conditions.
optimize() - Method in class io.shardingsphere.core.optimizer.query.QueryOptimizeEngine
 
optimize() - Method in class io.shardingsphere.core.parsing.parser.context.condition.AndCondition
Optimize and condition.
optimize() - Method in class io.shardingsphere.core.parsing.parser.context.condition.OrCondition
Optimize or condition.
OptimizeEngine - Interface in io.shardingsphere.core.optimizer
Optimize engine.
OptimizeEngineFactory - Class in io.shardingsphere.core.optimizer
Optimize engine factory.
OptimizeEngineFactory() - Constructor for class io.shardingsphere.core.optimizer.OptimizeEngineFactory
 
OracleAliasExpressionParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause.expression
Alias clause parser for Oracle.
OracleAliasExpressionParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.expression.OracleAliasExpressionParser
 
OracleAlterParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Alter parser for Oracle.
OracleAlterParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleAlterParser
 
OracleCreateParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Create parser for Oracle.
OracleCreateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleCreateParser
 
OracleDeleteClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade
Delete clause parser facade for Oracle.
OracleDeleteClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade.OracleDeleteClauseParserFacade
 
OracleDeleteParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Delete parser for Oracle.
OracleDeleteParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleDeleteParser
 
OracleDistinctClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Distinct clause parser for Oracle.
OracleDistinctClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleDistinctClauseParser
 
OracleDropParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Drop parser for Oracle.
OracleDropParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleDropParser
 
OracleForClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Select for clause parser for Oracle.
OracleForClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleForClauseParser
 
OracleGroupByClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Group by clause parser for Oracle.
OracleGroupByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleGroupByClauseParser
 
OracleHierarchicalQueryClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Hierarchical query clause parser for Oracle.
OracleHierarchicalQueryClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleHierarchicalQueryClauseParser
 
OracleInsertClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade
Insert clause parser facade for Oracle.
OracleInsertClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade.OracleInsertClauseParserFacade
 
OracleInsertIntoClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Insert into clause parser for Oracle.
OracleInsertIntoClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleInsertIntoClauseParser
 
OracleInsertParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Insert parser for Oracle.
OracleInsertParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleInsertParser
 
OracleKeyword - Enum in io.shardingsphere.core.parsing.lexer.dialect.oracle
Oracle keyword.
OracleLexer - Class in io.shardingsphere.core.parsing.lexer.dialect.oracle
Oracle Lexical analysis.
OracleLexer(String) - Constructor for class io.shardingsphere.core.parsing.lexer.dialect.oracle.OracleLexer
 
OracleModelClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Model clause parser for Oracle.
OracleModelClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleModelClauseParser
 
OracleOrderByClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Order by clause parser for Oracle.
OracleOrderByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleOrderByClauseParser
 
OracleSelectClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade
Select clause parser facade for Oracle.
OracleSelectClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade.OracleSelectClauseParserFacade
 
OracleSelectListClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Select list clause parser for Oracle.
OracleSelectListClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleSelectListClauseParser
 
OracleSelectParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Select parser for Oracle.
OracleSelectParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleSelectParser
 
OracleTableReferencesClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Table references clause parser for Oracle.
OracleTableReferencesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleTableReferencesClauseParser
 
OracleTruncateParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Truncate parser for Oracle.
OracleTruncateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleTruncateParser
 
OracleUpdateClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade
Update clause parser facade for Oracle.
OracleUpdateClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.facade.OracleUpdateClauseParserFacade
 
OracleUpdateParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.sql
Update parser for Oracle.
OracleUpdateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleUpdateParser
 
OracleWhereClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.oracle.clause
Where clause parser for Oracle.
OracleWhereClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleWhereClauseParser
 
OrchestrationConfiguration - Class in io.shardingsphere.jdbc.orchestration.api.config
Orchestration configuration.
OrchestrationConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.api.config.OrchestrationConfiguration
 
OrchestrationFacade - Class in io.shardingsphere.jdbc.orchestration.internal
Orchestration service facade.
OrchestrationFacade(OrchestrationConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.OrchestrationFacade
 
OrchestrationInstance - Class in io.shardingsphere.jdbc.orchestration.internal.state.instance
Orchestration instance.
OrchestrationMasterSlaveDataSource - Class in io.shardingsphere.jdbc.orchestration.internal
Orchestration master-slave datasource.
OrchestrationMasterSlaveDataSource(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>, OrchestrationFacade) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.OrchestrationMasterSlaveDataSource
 
OrchestrationMasterSlaveDataSourceBeanDefinitionParser - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Orchestration master-slave data source parser for spring namespace.
OrchestrationMasterSlaveDataSourceBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.OrchestrationMasterSlaveDataSourceBeanDefinitionParser
 
OrchestrationMasterSlaveDataSourceFactory - Class in io.shardingsphere.jdbc.orchestration.api
Orchestration master-slave data source factory.
OrchestrationMasterSlaveDataSourceFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.api.OrchestrationMasterSlaveDataSourceFactory
 
OrchestrationMasterSlaveDataSourceFactoryBean - Class in io.shardingsphere.jdbc.orchestration.spring.datasource
Orchestration master-slave data source factory bean.
OrchestrationMasterSlaveDataSourceFactoryBean(OrchestrationConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
OrchestrationMasterSlaveDataSourceFactoryBean(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>, OrchestrationConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationMasterSlaveDataSourceFactoryBean
 
OrchestrationMasterSlaveNamespaceHandler - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.handler
Orchestration spring namespace handler for master-slave.
OrchestrationMasterSlaveNamespaceHandler() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.handler.OrchestrationMasterSlaveNamespaceHandler
 
OrchestrationShardingDataSource - Class in io.shardingsphere.jdbc.orchestration.internal
Orchestration sharding datasource.
OrchestrationShardingDataSource(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties, OrchestrationFacade) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.OrchestrationShardingDataSource
 
OrchestrationShardingDataSourceBeanDefinitionParser - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Orchestration sharding data source parser for spring namespace.
OrchestrationShardingDataSourceBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.OrchestrationShardingDataSourceBeanDefinitionParser
 
OrchestrationShardingDataSourceFactory - Class in io.shardingsphere.jdbc.orchestration.api
Orchestration sharding data source factory.
OrchestrationShardingDataSourceFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.api.OrchestrationShardingDataSourceFactory
 
OrchestrationShardingDataSourceFactoryBean - Class in io.shardingsphere.jdbc.orchestration.spring.datasource
Orchestration sharding data source factory bean.
OrchestrationShardingDataSourceFactoryBean(OrchestrationConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
OrchestrationShardingDataSourceFactoryBean(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties, OrchestrationConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.OrchestrationShardingDataSourceFactoryBean
 
OrchestrationShardingNamespaceHandler - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.handler
Orchestration spring namespace handler for sharding.
OrchestrationShardingNamespaceHandler() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.handler.OrchestrationShardingNamespaceHandler
 
OrchestrationSpringBootConfiguration - Class in io.shardingsphere.jdbc.orchestration.spring.boot
Orchestration spring boot sharding and master-slave configuration.
OrchestrationSpringBootConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.boot.OrchestrationSpringBootConfiguration
 
OrchestrationType - Enum in io.shardingsphere.jdbc.orchestration.api.config
Orchestration type.
OrCondition - Class in io.shardingsphere.core.parsing.parser.context.condition
Or conditions.
OrCondition(Condition) - Constructor for class io.shardingsphere.core.parsing.parser.context.condition.OrCondition
 
OrderByClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Order by clause parser.
OrderByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.OrderByClauseParser
 
OrderByStreamMergedResult - Class in io.shardingsphere.core.merger.dql.orderby
Stream merged result for order by.
OrderByStreamMergedResult(List<QueryResult>, List<OrderItem>) - Constructor for class io.shardingsphere.core.merger.dql.orderby.OrderByStreamMergedResult
 
OrderByToken - Class in io.shardingsphere.core.parsing.parser.token
Order by token.
OrderByToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.OrderByToken
 
OrderByValue - Class in io.shardingsphere.core.merger.dql.orderby
Order by value.
OrderByValue() - Constructor for class io.shardingsphere.core.merger.dql.orderby.OrderByValue
 
OrderDirection - Enum in io.shardingsphere.core.constant
Order direction.
OrderItem - Class in io.shardingsphere.core.parsing.parser.context
Order item.
OrderItem(String, OrderDirection, OrderDirection, Optional<String>) - Constructor for class io.shardingsphere.core.parsing.parser.context.OrderItem
 
OrderItem(String, String, OrderDirection, OrderDirection, Optional<String>) - Constructor for class io.shardingsphere.core.parsing.parser.context.OrderItem
 
OrderItem(int, OrderDirection, OrderDirection) - Constructor for class io.shardingsphere.core.parsing.parser.context.OrderItem
 
othersDeletesAreVisible(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
othersInsertsAreVisible(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
othersUpdatesAreVisible(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
OverallExecutionEvent - Class in io.shardingsphere.core.executor.event
Overall sql execution event.
OverallExecutionEvent() - Constructor for class io.shardingsphere.core.executor.event.OverallExecutionEvent
 
ownDeletesAreVisible(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
ownInsertsAreVisible(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
ownUpdatesAreVisible(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 

P

PacketCodec<T extends DatabaseProtocolPacket> - Class in io.shardingsphere.proxy.transport.common.codec
Database protocol packet codec.
PacketCodec() - Constructor for class io.shardingsphere.proxy.transport.common.codec.PacketCodec
 
PacketCodecFactory - Class in io.shardingsphere.proxy.transport.common.codec
Database protocol packet codec factory.
PacketCodecFactory() - Constructor for class io.shardingsphere.proxy.transport.common.codec.PacketCodecFactory
 
parse() - Method in class io.shardingsphere.core.parsing.parser.clause.DistinctClauseParser
Parse distinct.
parse(SQLStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.expression.BasicExpressionParser
Parse expression.
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.GroupByClauseParser
Parse group by.
parse() - Method in class io.shardingsphere.core.parsing.parser.clause.HavingClauseParser
Parse having.
parse(InsertStatement, ShardingMetaData) - Method in class io.shardingsphere.core.parsing.parser.clause.InsertColumnsClauseParser
Parse insert columns.
parse(InsertStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.InsertIntoClauseParser
Parse insert into.
parse(InsertStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.InsertSetClauseParser
Parse insert set.
parse(InsertStatement, ShardingMetaData) - Method in class io.shardingsphere.core.parsing.parser.clause.InsertValuesClauseParser
Parse insert values.
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.OrderByClauseParser
Parse order by.
parse(SelectStatement, List<SelectItem>) - Method in class io.shardingsphere.core.parsing.parser.clause.SelectListClauseParser
Parse select list.
parse() - Method in class io.shardingsphere.core.parsing.parser.clause.SelectRestClauseParser
Parse select rest.
parse(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.clause.TableReferencesClauseParser
Parse table references.
parse(DMLStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.UpdateSetItemsClauseParser
Parse set items.
parse(ShardingRule, SQLStatement, List<SelectItem>) - Method in class io.shardingsphere.core.parsing.parser.clause.WhereClauseParser
Parse where.
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLLimitClauseParser
Parse limit.
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLSelectOptionClauseParser
解析Option.
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLDescribeParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLShowParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLUseParser
 
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleForClauseParser
Parse for.
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleHierarchicalQueryClauseParser
Parse hierarchical query.
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleModelClauseParser
Parse model.
parse() - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLForClauseParser
Parse for.
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLLimitClauseParser
Parse limit.
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerOffsetClauseParser
Parse offset.
parse(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerTopClauseParser
Parse top.
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.alter.AbstractAlterParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.create.AbstractCreateParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.drop.AbstractDropParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.ddl.truncate.AbstractTruncateParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.delete.AbstractDeleteParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.insert.AbstractInsertParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.dml.update.AbstractUpdateParser
 
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parse() - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLParser
Parse SQL.
parse() - Method in class io.shardingsphere.core.parsing.parser.sql.tcl.TCLParser
 
parse(boolean) - Method in class io.shardingsphere.core.parsing.SQLParsingEngine
Parse SQL.
parse(String, boolean) - Method in class io.shardingsphere.core.routing.router.sharding.DatabaseHintSQLRouter
 
parse(String, boolean) - Method in class io.shardingsphere.core.routing.router.sharding.ParsingSQLRouter
 
parse(String, boolean) - Method in interface io.shardingsphere.core.routing.router.sharding.ShardingRouter
Parse SQL.
parse(String) - Method in class io.shardingsphere.opentracing.config.OpentracingConfigurationParser
 
parseDistinct() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseFrom(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseGroupBy(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseHaving() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseInternal(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.sql.MySQLSelectParser
 
parseInternal(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.sql.OracleSelectParser
 
parseInternal(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLSelectParser
 
parseInternal(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerSelectParser
 
parseInternal(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.EtcdBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.OrchestrationMasterSlaveDataSourceBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.OrchestrationShardingDataSourceBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.ShardingStrategyBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.ZookeeperBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.spring.namespace.parser.MasterSlaveDataSourceBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.spring.namespace.parser.ShardingDataSourceBeanDefinitionParser
 
parseInternal(Element, ParserContext) - Method in class io.shardingsphere.jdbc.spring.namespace.parser.ShardingStrategyBeanDefinitionParser
 
parseOrchestrationConfiguration(Element, OrchestrationType) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.AbstractOrchestrationBeanDefinitionParser
 
parseOrderBy(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseRegistryCenterRef(Element) - Method in class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.AbstractOrchestrationBeanDefinitionParser
 
parseRowNumberSelectItem(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.SelectListClauseParser
 
parseRowNumberSelectItem(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerSelectListClauseParser
 
parseSelectItemAlias() - Method in class io.shardingsphere.core.parsing.parser.clause.expression.AliasExpressionParser
Parse alias for select item.
parseSelectList(SelectStatement, List<SelectItem>) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseSelectRest() - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
parseSingleTableWithoutAlias(SQLStatement) - Method in class io.shardingsphere.core.parsing.parser.clause.TableReferencesClauseParser
Parse single table without alias.
parseTableAlias() - Method in class io.shardingsphere.core.parsing.parser.clause.expression.AliasExpressionParser
Parse alias for table.
parseTableFactor(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.clause.TableReferencesClauseParser
 
parseTableReference(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.clause.TableReferencesClauseParser
 
parseTableReference(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.dialect.mysql.clause.MySQLTableReferencesClauseParser
 
parseTableReference(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.dialect.oracle.clause.OracleTableReferencesClauseParser
 
parseTableReference(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLTableReferencesClauseParser
 
parseTableReference(SQLStatement, boolean) - Method in class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerTableReferencesClauseParser
 
parseWhere(ShardingRule, SelectStatement, List<SelectItem>) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.AbstractSelectParser
 
ParsingResultCache - Class in io.shardingsphere.core.parsing.cache
Parsing result cache.
ParsingResultCache() - Constructor for class io.shardingsphere.core.parsing.cache.ParsingResultCache
 
ParsingSQLRouter - Class in io.shardingsphere.core.routing.router.sharding
Sharding router with parse.
ParsingSQLRouter() - Constructor for class io.shardingsphere.core.routing.router.sharding.ParsingSQLRouter
 
PAYLOAD_LENGTH - Static variable in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacket
 
persist(String, String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Persist data.
persist(String, String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
persist(String, String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
persistDataSourcesNode() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceService
Persist master-salve data sources node.
persistEphemeral(String, String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Persist ephemeral data.
persistEphemeral(String, String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
persistEphemeral(String, String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
persistMasterSlaveConfiguration(Map<String, DataSource>, MasterSlaveRuleConfiguration, Map<String, Object>, boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Persist master-slave configuration.
persistMasterSlaveInstanceOnline() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.instance.InstanceStateService
Persist master-salve instance online.
persistShardingConfiguration(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties, boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationService
Persist sharding configuration.
persistShardingInstanceOnline() - Method in class io.shardingsphere.jdbc.orchestration.internal.state.instance.InstanceStateService
Persist sharding instance online.
PostgreSQLAliasExpressionParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.expression
Alias clause parser for PostgreSQL.
PostgreSQLAliasExpressionParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.expression.PostgreSQLAliasExpressionParser
 
PostgreSQLAlterParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Alter parser for PostgreSQL.
PostgreSQLAlterParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLAlterParser
 
PostgreSQLCreateParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Create parser for PostgreSQL.
PostgreSQLCreateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLCreateParser
 
PostgreSQLDeleteClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade
Delete clause parser facade for PostgreSQL.
PostgreSQLDeleteClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade.PostgreSQLDeleteClauseParserFacade
 
PostgreSQLDeleteParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Delete parser for PostgreSQL.
PostgreSQLDeleteParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLDeleteParser
 
PostgreSQLDropParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Drop parser for PostgreSQL.
PostgreSQLDropParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLDropParser
 
PostgreSQLForClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
Select for clause parser for PostgreSQL.
PostgreSQLForClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLForClauseParser
 
PostgreSQLInsertClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade
Insert clause parser facade for PostgreSQL.
PostgreSQLInsertClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade.PostgreSQLInsertClauseParserFacade
 
PostgreSQLInsertIntoClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
Insert into clause parser for PostgreSQL.
PostgreSQLInsertIntoClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLInsertIntoClauseParser
 
PostgreSQLInsertParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Insert parser for PostgreSQL.
PostgreSQLInsertParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLInsertParser
 
PostgreSQLKeyword - Enum in io.shardingsphere.core.parsing.lexer.dialect.postgresql
PostgreSQL keyword.
PostgreSQLLexer - Class in io.shardingsphere.core.parsing.lexer.dialect.postgresql
PostgreSQL Lexical analysis.
PostgreSQLLexer(String) - Constructor for class io.shardingsphere.core.parsing.lexer.dialect.postgresql.PostgreSQLLexer
 
PostgreSQLLimitClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
Limit clause parser for PostgreSQL.
PostgreSQLLimitClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLLimitClauseParser
 
PostgreSQLOrderByClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
Order by clause parser for PostgreSQL.
PostgreSQLOrderByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLOrderByClauseParser
 
PostgreSQLSelectClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade
Select clause parser facade for PostgreSQL.
PostgreSQLSelectClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade.PostgreSQLSelectClauseParserFacade
 
PostgreSQLSelectParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Select parser for PostgreSQL.
PostgreSQLSelectParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLSelectParser
 
PostgreSQLSelectRestClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
Select rest clause parser for PostgreSQL.
PostgreSQLSelectRestClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLSelectRestClauseParser
 
PostgreSQLTableReferencesClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause
Table references clause parser for PostgreSQL.
PostgreSQLTableReferencesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.PostgreSQLTableReferencesClauseParser
 
PostgreSQLTruncateParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Truncate parser for PostgreSQL.
PostgreSQLTruncateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLTruncateParser
 
PostgreSQLUpdateClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade
Update clause parser facade for PostgreSQL.
PostgreSQLUpdateClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.clause.facade.PostgreSQLUpdateClauseParserFacade
 
PostgreSQLUpdateParser - Class in io.shardingsphere.core.parsing.parser.dialect.postgresql.sql
Update parser for PostgreSQL.
PostgreSQLUpdateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.postgresql.sql.PostgreSQLUpdateParser
 
PRECISE_ALGORITHM_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
PRECISE_ALGORITHM_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
PreciseShardingAlgorithm<T extends Comparable<?>> - Interface in io.shardingsphere.core.api.algorithm.sharding.standard
Precise sharding algorithm.
PreciseShardingValue<T extends Comparable<?>> - Class in io.shardingsphere.core.api.algorithm.sharding
Sharding value for precise value.
PreciseShardingValue() - Constructor for class io.shardingsphere.core.api.algorithm.sharding.PreciseShardingValue
 
prepareCall(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
prepareCall(String, int, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
prepareCall(String, int, int, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
PreparedStatementExecutor - Class in io.shardingsphere.core.executor.type.prepared
PreparedStatement Executor for multiple threads.
PreparedStatementExecutor() - Constructor for class io.shardingsphere.core.executor.type.prepared.PreparedStatementExecutor
 
PreparedStatementParameter - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
Prepared statement parameter.
PreparedStatementParameter(ColumnType, int) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.PreparedStatementParameter
 
PreparedStatementParameter(ColumnType, int, String) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.PreparedStatementParameter
 
PreparedStatementParameterHeader - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute
Prepared statement parameter header.
PreparedStatementParameterHeader() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.PreparedStatementParameterHeader
 
PreparedStatementRegistry - Class in io.shardingsphere.proxy.transport.mysql.packet.command.statement
Prepared statement registry.
PreparedStatementRegistry() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.statement.PreparedStatementRegistry
 
PreparedStatementRoutingEngine - Class in io.shardingsphere.core.routing
PreparedStatement routing engine.
PreparedStatementRoutingEngine(String, ShardingRule, ShardingMetaData, DatabaseType, boolean) - Constructor for class io.shardingsphere.core.routing.PreparedStatementRoutingEngine
 
PreparedStatementUnit - Class in io.shardingsphere.core.executor.type.prepared
PreparedStatement execute unit.
PreparedStatementUnit() - Constructor for class io.shardingsphere.core.executor.type.prepared.PreparedStatementUnit
 
prepareStatement(String) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
prepareStatement(String, int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
prepareStatement(String, int, int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
prepareStatement(String, int) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
prepareStatement(String, int[]) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
prepareStatement(String, String[]) - Method in class io.shardingsphere.core.jdbc.core.connection.MasterSlaveConnection
 
prepareStatement(String) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
prepareStatement(String, int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
prepareStatement(String, int, int, int) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
prepareStatement(String, int) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
prepareStatement(String, int[]) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
prepareStatement(String, String[]) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
prepareStatement(String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
prepareStatement(String, int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
prepareStatement(String, int, int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
prepareStatement(String, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
prepareStatement(String, int[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
prepareStatement(String, String[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
previous() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
processData(Connection, TransactionLog, int) - Method in class io.shardingsphere.transaction.storage.impl.MemoryTransactionLogStorage
 
processData(Connection, TransactionLog, int) - Method in class io.shardingsphere.transaction.storage.impl.RdbTransactionLogStorage
 
processData(Connection, TransactionLog, int) - Method in interface io.shardingsphere.transaction.storage.TransactionLogStorage
Process transaction logs.
processParameters(List<Object>, boolean) - Method in class io.shardingsphere.core.parsing.parser.context.limit.Limit
Fill parameters for rewrite limit.
PropertyUtil - Class in io.shardingsphere.jdbc.orchestration.spring.boot.util
 
PropertyUtil() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.boot.util.PropertyUtil
 
PropertyUtil - Class in io.shardingsphere.jdbc.spring.boot.util
 
PropertyUtil() - Constructor for class io.shardingsphere.jdbc.spring.boot.util.PropertyUtil
 
PROPS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
PROPS_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
PROTOCOL_VERSION - Static variable in interface io.shardingsphere.proxy.transport.mysql.constant.ServerInfo
Protocol version is always 0x0A.
ProxyShardingMetaData - Class in io.shardingsphere.proxy.metadata
Sharding metadata for proxy.
ProxyShardingMetaData() - Constructor for class io.shardingsphere.proxy.metadata.ProxyShardingMetaData
 
ProxyShardingRefreshHandler - Class in io.shardingsphere.proxy.metadata
Refresh table metadata of ProxySharding.
put(String, SQLStatement) - Method in class io.shardingsphere.core.parsing.cache.ParsingResultCache
Put SQL and parsing result into cache.

Q

QueryOptimizeEngine - Class in io.shardingsphere.core.optimizer.query
Query optimize engine.
QueryOptimizeEngine() - Constructor for class io.shardingsphere.core.optimizer.query.QueryOptimizeEngine
 
QueryResult - Interface in io.shardingsphere.core.merger
Query result form database.

R

RandomGenerator - Class in io.shardingsphere.proxy.transport.mysql.packet.handshake
Random generator.
RandomGenerator() - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.handshake.RandomGenerator
 
RandomMasterSlaveLoadBalanceAlgorithm - Class in io.shardingsphere.core.api.algorithm.masterslave
Random slave database load-balance algorithm.
RandomMasterSlaveLoadBalanceAlgorithm() - Constructor for class io.shardingsphere.core.api.algorithm.masterslave.RandomMasterSlaveLoadBalanceAlgorithm
 
RANGE_ALGORITHM_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
RANGE_ALGORITHM_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
RangeShardingAlgorithm<T extends Comparable<?>> - Interface in io.shardingsphere.core.api.algorithm.sharding.standard
Range sharding algorithm.
RangeShardingValue<T extends Comparable<?>> - Class in io.shardingsphere.core.api.algorithm.sharding
Sharding value for range values.
RangeShardingValue() - Constructor for class io.shardingsphere.core.api.algorithm.sharding.RangeShardingValue
 
RdbTransactionLogDataSource - Class in io.shardingsphere.transaction.datasource.impl
Transaction log data source for relationship database.
RdbTransactionLogDataSource() - Constructor for class io.shardingsphere.transaction.datasource.impl.RdbTransactionLogDataSource
 
RdbTransactionLogStorage - Class in io.shardingsphere.transaction.storage.impl
Transaction relationship database log storage.
RdbTransactionLogStorage() - Constructor for class io.shardingsphere.transaction.storage.impl.RdbTransactionLogStorage
 
read(JsonReader) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceGsonTypeAdapter
 
read(JsonReader) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.KeyGeneratorGsonTypeAdapter
 
read(JsonReader) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.MasterSlaveLoadBalanceAlgorithmGsonTypeAdapter
 
read(JsonReader) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.ShardingStrategyConfigurationGsonTypeAdapter
 
readBinaryProtocolValue(ColumnType, MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.BinaryProtocolValueUtility
Read binary protocol value.
readDate() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read date from byte buffers.
readDouble() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 8 byte double from byte buffers.
readFloat() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 4 byte float from byte buffers.
readInt1() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 1 byte fixed length integer from byte buffers.
readInt2() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 2 byte fixed length integer from byte buffers.
readInt3() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 3 byte fixed length integer from byte buffers.
readInt4() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 4 byte fixed length integer from byte buffers.
readInt6() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 6 byte fixed length integer from byte buffers.
readInt8() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read 8 byte fixed length integer from byte buffers.
readIntLenenc() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read length encoded integer from byte buffers.
readStringEOF() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read rest of packet string from byte buffers.
readStringFix(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read fixed length string from byte buffers.
readStringLenenc() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read fixed length string from byte buffers.
readStringNul() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read null terminated string from byte buffers.
readStringVar() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read variable length string from byte buffers.
readTime() - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Read time from byte buffers.
recordMethodInvocation(Class<?>, String, Class<?>[], Object[]) - Method in class io.shardingsphere.core.jdbc.adapter.WrapperAdapter
记录方法调用.
refresh(TableRule, ShardingRule) - Method in class io.shardingsphere.core.metadata.ShardingMetaData
refresh each tableMetaData by TableRule.
refresh(TableRule, ShardingRule, Map<String, Connection>) - Method in class io.shardingsphere.core.metadata.ShardingMetaData
refresh each tableMetaData by TableRule.
refreshRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
RegException - Exception in io.shardingsphere.jdbc.orchestration.reg.exception
Registry center exception.
RegException(String, Object...) - Constructor for exception io.shardingsphere.jdbc.orchestration.reg.exception.RegException
 
RegException(Exception) - Constructor for exception io.shardingsphere.jdbc.orchestration.reg.exception.RegException
 
RegExceptionHandler - Class in io.shardingsphere.jdbc.orchestration.reg.exception
Registry center exception handler.
RegExceptionHandler() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.exception.RegExceptionHandler
 
register(String) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.PreparedStatementRegistry
Register SQL.
registerTypeAdapter(Type, TypeAdapter) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.GsonFactory
Register gson type adapter.
RegistryCenter - Interface in io.shardingsphere.jdbc.orchestration.reg.api
Registry center.
RegistryCenterConfiguration - Interface in io.shardingsphere.jdbc.orchestration.reg.api
Registry center configuration.
RegNamespaceHandler - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.handler
Registry center namespace handler.
RegNamespaceHandler() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.handler.RegNamespaceHandler
 
relative(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
release(Connection) - Method in class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
Release connection.
releaseSavepoint(Savepoint) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
remove(String) - Method in class io.shardingsphere.transaction.storage.impl.MemoryTransactionLogStorage
 
remove(String) - Method in class io.shardingsphere.transaction.storage.impl.RdbTransactionLogStorage
 
remove(String) - Method in interface io.shardingsphere.transaction.storage.TransactionLogStorage
Remove transaction log.
removeCache(Connection) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
RemoveToken - Class in io.shardingsphere.core.parsing.parser.token
Remove token.
RemoveToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.RemoveToken
 
renew(Map<String, DataSource>, MasterSlaveRuleConfiguration) - Method in class io.shardingsphere.core.jdbc.core.datasource.MasterSlaveDataSource
Renew master-slave data source.
renew(Map<String, DataSource>, ShardingRule, Properties) - Method in class io.shardingsphere.core.jdbc.core.datasource.ShardingDataSource
Renew sharding data source.
replayMethodsInvocation(Object) - Method in class io.shardingsphere.core.jdbc.adapter.WrapperAdapter
回放记录的方法调用.
replaySetParameter(PreparedStatement, List<Object>) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
ResultSetUtil - Class in io.shardingsphere.core.jdbc.core.resultset
ResultSet utility class.
ResultSetUtil() - Constructor for class io.shardingsphere.core.jdbc.core.resultset.ResultSetUtil
 
RETRY_INTERVAL_MILLISECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
rewrite(boolean) - Method in class io.shardingsphere.core.rewrite.SQLRewriteEngine
rewrite SQL.
rollback() - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
rollback(Savepoint) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
rollback() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
ROOT - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
roundHalfUp(Object) - Static method in class io.shardingsphere.core.util.NumberUtil
Round half up.
RoundRobinMasterSlaveLoadBalanceAlgorithm - Class in io.shardingsphere.core.api.algorithm.masterslave
Round-robin slave database load-balance algorithm.
RoundRobinMasterSlaveLoadBalanceAlgorithm() - Constructor for class io.shardingsphere.core.api.algorithm.masterslave.RoundRobinMasterSlaveLoadBalanceAlgorithm
 
route(List<Object>) - Method in class io.shardingsphere.core.routing.PreparedStatementRoutingEngine
SQL route.
route(SQLType) - Method in class io.shardingsphere.core.routing.router.masterslave.MasterSlaveRouter
Route Master slave.
route(SQLRouteResult) - Method in class io.shardingsphere.core.routing.router.masterslave.ShardingMasterSlaveRouter
Route Master slave after sharding.
route(String, List<Object>, SQLStatement) - Method in class io.shardingsphere.core.routing.router.sharding.DatabaseHintSQLRouter
 
route(String, List<Object>, SQLStatement) - Method in class io.shardingsphere.core.routing.router.sharding.ParsingSQLRouter
 
route(String, List<Object>, SQLStatement) - Method in interface io.shardingsphere.core.routing.router.sharding.ShardingRouter
Route SQL.
route(String) - Method in class io.shardingsphere.core.routing.StatementRoutingEngine
SQL route.
route() - Method in class io.shardingsphere.core.routing.type.broadcast.DatabaseBroadcastRoutingEngine
 
route() - Method in class io.shardingsphere.core.routing.type.broadcast.TableBroadcastRoutingEngine
 
route() - Method in class io.shardingsphere.core.routing.type.complex.CartesianRoutingEngine
 
route() - Method in class io.shardingsphere.core.routing.type.complex.ComplexRoutingEngine
 
route() - Method in class io.shardingsphere.core.routing.type.hint.DatabaseHintRoutingEngine
 
route() - Method in class io.shardingsphere.core.routing.type.ignore.IgnoreRoutingEngine
 
route() - Method in interface io.shardingsphere.core.routing.type.RoutingEngine
Route.
route() - Method in class io.shardingsphere.core.routing.type.standard.StandardRoutingEngine
 
route() - Method in class io.shardingsphere.core.routing.type.unicast.UnicastRoutingEngine
 
RoutingEngine - Interface in io.shardingsphere.core.routing.type
Routing engine interface.
RoutingResult - Class in io.shardingsphere.core.routing.type
Routing result.
RoutingResult() - Constructor for class io.shardingsphere.core.routing.type.RoutingResult
 
RoutingTable - Class in io.shardingsphere.core.routing.type
Routing table.
RoutingTable() - Constructor for class io.shardingsphere.core.routing.type.RoutingTable
 
RowCountToken - Class in io.shardingsphere.core.parsing.parser.token
Row count token for limit.
RowCountToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.RowCountToken
 
rowDeleted() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
rowInserted() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
RowNumberDecoratorMergedResult - Class in io.shardingsphere.core.merger.dql.pagination
Decorator merged result for rownum pagination.
RowNumberDecoratorMergedResult(MergedResult, Limit) - Constructor for class io.shardingsphere.core.merger.dql.pagination.RowNumberDecoratorMergedResult
 
rowUpdated() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
RULE_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
RuleRegistry - Class in io.shardingsphere.proxy.config
Sharding rule registry.

S

scanChars() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
scan chars.
scanHexDecimal() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
scan hex decimal.
scanIdentifier() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
scan identifier.
scanNumber() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
scan number.
scanSymbol() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
scan symbol.
scanVariable() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
scan variable.
SchemaPlaceholder - Class in io.shardingsphere.core.rewrite.placeholder
Schema placeholder for rewrite.
SchemaPlaceholder() - Constructor for class io.shardingsphere.core.rewrite.placeholder.SchemaPlaceholder
 
SchemaToken - Class in io.shardingsphere.core.parsing.parser.token
Schema token.
SchemaToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.SchemaToken
 
SelectItem - Interface in io.shardingsphere.core.parsing.parser.context.selectitem
Select item interface.
SelectListClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Select list clause parser.
SelectListClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.SelectListClauseParser
 
SelectParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dql.select
Select parser factory.
SelectParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectParserFactory
 
SelectRestClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Select rest clause parser.
SelectRestClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.clause.SelectRestClauseParser
 
SelectStatement - Class in io.shardingsphere.core.parsing.parser.sql.dql.select
Select statement.
SelectStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
 
SEQUENCE_LENGTH - Static variable in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacket
 
SERVER_LISTS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
SERVER_LISTS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
SERVER_VERSION - Static variable in interface io.shardingsphere.proxy.transport.mysql.constant.ServerInfo
Server version.
ServerHandlerInitializer - Class in io.shardingsphere.proxy.frontend.netty
Channel initializer.
ServerHandlerInitializer() - Constructor for class io.shardingsphere.proxy.frontend.netty.ServerHandlerInitializer
 
ServerInfo - Interface in io.shardingsphere.proxy.transport.mysql.constant
Sharding-Proxy's information.
SESSION_TIMEOUT_MILLISECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
setArray(int, Array) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setAsciiStream(int, InputStream) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setAsciiStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setAsciiStream(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setAsciiStream(int, InputStream) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setAsciiStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setAsciiStream(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setAsciiStream(int, InputStream, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setAsciiStream(int, InputStream) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setAsciiStream(int, InputStream, long) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setAutoCommit(boolean) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
setAutoCommit(boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
setBigDecimal(int, BigDecimal) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBigDecimal(int, BigDecimal) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBigDecimal(int, BigDecimal) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBinaryStream(int, InputStream) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBinaryStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBinaryStream(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBinaryStream(int, InputStream) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBinaryStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBinaryStream(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBinaryStream(int, InputStream, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBinaryStream(int, InputStream, long) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBinaryStream(int, InputStream) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBlob(int, Blob) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBlob(int, InputStream) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBlob(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBlob(int, Blob) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBlob(int, InputStream) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBlob(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBlob(int, Blob) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBlob(int, InputStream, long) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBlob(int, InputStream) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBoolean(int, boolean) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBoolean(int, boolean) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBoolean(int, boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setByte(int, byte) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setByte(int, byte) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setByte(int, byte) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setBytes(int, byte[]) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setBytes(int, byte[]) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setBytes(int, byte[]) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setCatalog(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setCell(int, Object) - Method in class io.shardingsphere.core.merger.dql.common.MemoryQueryResultRow
Set data for cell.
setCharacterStream(int, Reader) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setCharacterStream(int, Reader, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setCharacterStream(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setCharacterStream(int, Reader) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setCharacterStream(int, Reader, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setCharacterStream(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setCharacterStream(int, Reader, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setCharacterStream(int, Reader, long) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setCharacterStream(int, Reader) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setClientInfo(String, String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setClientInfo(Properties) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setClob(int, Clob) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setClob(int, Reader) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setClob(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setClob(int, Clob) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setClob(int, Reader) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setClob(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setClob(int, Clob) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setClob(int, Reader, long) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setClob(int, Reader) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setCursorName(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
setDatabaseShardingValue(Comparable<?>) - Method in class io.shardingsphere.core.api.HintManager
Set sharding value for database sharding only.
setDataMap(Map<String, Object>) - Static method in class io.shardingsphere.core.executor.threadlocal.ExecutorDataMap
Set data map.
setDate(int, Date) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setDate(int, Date, Calendar) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setDate(int, Date) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setDate(int, Date, Calendar) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setDate(int, Date) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setDate(int, Date, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setDouble(int, double) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setDouble(int, double) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setDouble(int, double) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setEnvironment(Environment) - Method in class io.shardingsphere.jdbc.orchestration.spring.boot.OrchestrationSpringBootConfiguration
 
setEnvironment(Environment) - Method in class io.shardingsphere.jdbc.spring.boot.SpringBootConfiguration
 
setEscapeProcessing(boolean) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
setEscapeProcessing(boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
setExceptionThrown(boolean) - Static method in class io.shardingsphere.core.executor.threadlocal.ExecutorExceptionHandler
Set throw exception if error occur or not.
setFetchDirection(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
setFetchDirection(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
setFetchDirection(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationStatement
 
setFetchDirection(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
setFetchSize(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractResultSetAdapter
 
setFetchSize(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
setFetchSize(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedGeneratedKeysResultSet
 
setFetchSize(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
setFetchSize(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
setFloat(int, float) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setFloat(int, float) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setFloat(int, float) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setHintManager(HintManager) - Static method in class io.shardingsphere.core.hint.HintManagerHolder
Set hint manager.
setHoldability(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
setHoldability(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
setIndexForItems(Map<String, Integer>) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Set index for select items.
setInt(int, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setInt(int, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setInt(int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setLoginTimeout(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationDataSource
 
setLogWriter(PrintWriter) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractDataSourceAdapter
 
setLogWriter(PrintWriter) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.datasource.CircuitBreakerDataSource
 
setLong(int, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setLong(int, long) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setLong(int, long) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setMasterRouteOnly() - Method in class io.shardingsphere.core.api.HintManager
Set CRUD operation force route to master database only.
setMasterVisited() - Static method in class io.shardingsphere.core.routing.router.masterslave.MasterVisitedManager
Set master data source visited in current thread.
setMaxFieldSize(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
setMaxFieldSize(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
setMaxRows(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
setMaxRows(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
setNCharacterStream(int, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setNCharacterStream(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setNClob(int, NClob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setNClob(int, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setNClob(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setNetworkTimeout(Executor, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setNString(int, String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setNull(int, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setNull(int, int, String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setNull(int, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setNull(int, int, String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setNull(int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setNull(int, int, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setNullBit(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.NullBitmap
Set null bit.
setObject(int, Object) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setObject(int, Object, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setObject(int, Object, int, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setObject(int, Object) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setObject(int, Object, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setObject(int, Object, int, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setObject(int, Object) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setObject(int, Object, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setObject(int, Object, int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setParameterHeaders(int, List<PreparedStatementParameterHeader>) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.PreparedStatementRegistry
Set parameter headers.
SetParameterMethodInvocation - Class in io.shardingsphere.core.jdbc.adapter.invocation
Invocation that reflected call for PreparedStatement.setParameter method.
SetParameterMethodInvocation(Method, Object[], Object) - Constructor for class io.shardingsphere.core.jdbc.adapter.invocation.SetParameterMethodInvocation
 
setParametersIndex(int) - Method in interface io.shardingsphere.core.parsing.parser.sql.SQLStatement
Set index of parameters.
setPoolable(boolean) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
setPoolable(boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
setQueryTimeout(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractStatementAdapter
 
setQueryTimeout(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerStatement
 
setReadOnly(boolean) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
setReadOnly(boolean) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
setRef(int, Ref) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setRowId(int, RowId) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationPreparedStatement
 
setSavepoint() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setSavepoint(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setSchema(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setShort(int, short) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setShort(int, short) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setShort(int, short) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setSQLXML(int, SQLXML) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setSQLXML(int, SQLXML) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setSQLXML(int, SQLXML) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setString(int, String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setString(int, String) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setString(int, String) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setSubQueryStatement(SelectStatement) - Method in class io.shardingsphere.core.parsing.parser.sql.dql.select.SelectStatement
Set sub query statement.
setTime(int, Time) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setTime(int, Time, Calendar) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setTime(int, Time) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setTime(int, Time, Calendar) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setTime(int, Time) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setTime(int, Time, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setTimestamp(int, Timestamp) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setTimestamp(int, Timestamp, Calendar) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setTimestamp(int, Timestamp) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setTimestamp(int, Timestamp, Calendar) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setTimestamp(int, Timestamp) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setTransactionIsolation(int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractConnectionAdapter
 
setTransactionIsolation(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.connection.CircuitBreakerConnection
 
setTypeMap(Map<String, Class<?>>) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationConnection
 
setUnicodeStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setUnicodeStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setUnicodeStream(int, InputStream, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setURL(int, URL) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractMasterSlavePreparedStatementAdapter
 
setURL(int, URL) - Method in class io.shardingsphere.core.jdbc.adapter.AbstractShardingPreparedStatementAdapter
 
setURL(int, URL) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.statement.CircuitBreakerPreparedStatement
 
setWorkerId(long) - Static method in class io.shardingsphere.core.keygen.DefaultKeyGenerator
Set work process id.
SHARDING_COLUMN_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
SHARDING_COLUMN_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
SHARDING_COLUMNS_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
SHARDING_COLUMNS_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
SHARDING_CONFIG_MAP_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
SHARDING_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
SHARDING_PROPS_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
SHARDING_RULE_CONFIG_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
SHARDING_RULE_CONFIG_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
SHARDING_RULE_NODE_PATH - Static variable in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationNode
 
ShardingAlgorithm - Interface in io.shardingsphere.core.routing.strategy
Sharding algorithm interface.
ShardingAlgorithmFactory - Class in io.shardingsphere.core.routing.strategy
Sharding algorithm factory.
ShardingAlgorithmFactory() - Constructor for class io.shardingsphere.core.routing.strategy.ShardingAlgorithmFactory
 
ShardingCondition - Class in io.shardingsphere.core.optimizer.condition
Sharding condition.
ShardingCondition() - Constructor for class io.shardingsphere.core.optimizer.condition.ShardingCondition
 
ShardingConditions - Class in io.shardingsphere.core.optimizer.condition
Sharding conditions.
ShardingConditions() - Constructor for class io.shardingsphere.core.optimizer.condition.ShardingConditions
 
ShardingConfigurationException - Exception in io.shardingsphere.core.exception
Sharding rule exception.
ShardingConfigurationException(String, Object...) - Constructor for exception io.shardingsphere.core.exception.ShardingConfigurationException
Constructs an exception with formatted error message and arguments.
ShardingConfigurationException(Exception) - Constructor for exception io.shardingsphere.core.exception.ShardingConfigurationException
Constructs an exception with cause exception.
ShardingConnection - Class in io.shardingsphere.core.jdbc.core.connection
Connection that support sharding.
ShardingConnection() - Constructor for class io.shardingsphere.core.jdbc.core.connection.ShardingConnection
 
ShardingConstant - Interface in io.shardingsphere.core.constant
Sharding constant.
ShardingContext - Class in io.shardingsphere.core.jdbc.core
Sharding runtime context.
ShardingContext() - Constructor for class io.shardingsphere.core.jdbc.core.ShardingContext
 
ShardingDataSource - Class in io.shardingsphere.core.jdbc.core.datasource
Database that support sharding.
ShardingDataSource(Map<String, DataSource>, ShardingRule) - Constructor for class io.shardingsphere.core.jdbc.core.datasource.ShardingDataSource
 
ShardingDataSource(Map<String, DataSource>, ShardingRule, Map<String, Object>, Properties) - Constructor for class io.shardingsphere.core.jdbc.core.datasource.ShardingDataSource
 
ShardingDataSourceBeanDefinitionParser - Class in io.shardingsphere.jdbc.spring.namespace.parser
Sharding data source parser for spring namespace.
ShardingDataSourceBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.spring.namespace.parser.ShardingDataSourceBeanDefinitionParser
 
ShardingDataSourceBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.constants
Sharding data source parser tag constants.
ShardingDataSourceBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
ShardingDataSourceBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.spring.namespace.constants
Sharding data source parser tag constants.
ShardingDataSourceBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
ShardingDataSourceFactory - Class in io.shardingsphere.core.api
Sharding data source factory.
ShardingDataSourceFactory() - Constructor for class io.shardingsphere.core.api.ShardingDataSourceFactory
 
ShardingDataSourceNames - Class in io.shardingsphere.core.rule
Sharding data source names.
ShardingDataSourceNames(ShardingRuleConfiguration, Collection<String>) - Constructor for class io.shardingsphere.core.rule.ShardingDataSourceNames
 
ShardingException - Exception in io.shardingsphere.core.exception
Base exception.
ShardingException(String, Object...) - Constructor for exception io.shardingsphere.core.exception.ShardingException
Constructs an exception with formatted error message and arguments.
ShardingException(String, Exception) - Constructor for exception io.shardingsphere.core.exception.ShardingException
Constructs an exception with error message and cause.
ShardingException(Exception) - Constructor for exception io.shardingsphere.core.exception.ShardingException
Constructs an exception with cause.
ShardingJDBCTracer - Class in io.shardingsphere.opentracing
A container of tracer object.
ShardingJDBCTracer() - Constructor for class io.shardingsphere.opentracing.ShardingJDBCTracer
 
ShardingKey - Class in io.shardingsphere.core.hint
Sharding key.
ShardingKey(String, String) - Constructor for class io.shardingsphere.core.hint.ShardingKey
 
ShardingMasterSlaveRouter - Class in io.shardingsphere.core.routing.router.masterslave
Sharding with master-slave router interface.
ShardingMasterSlaveRouter() - Constructor for class io.shardingsphere.core.routing.router.masterslave.ShardingMasterSlaveRouter
 
ShardingMetaData - Class in io.shardingsphere.core.metadata
Abstract Sharding metadata.
ShardingMetaData() - Constructor for class io.shardingsphere.core.metadata.ShardingMetaData
 
ShardingMetaDataHandler - Class in io.shardingsphere.core.jdbc.metadata.dialect
Abstract table meta handler.
ShardingMetaDataHandler() - Constructor for class io.shardingsphere.core.jdbc.metadata.dialect.ShardingMetaDataHandler
 
ShardingMetaDataHandler - Class in io.shardingsphere.proxy.metadata
Sharding meta data handler.
ShardingMetaDataHandler() - Constructor for class io.shardingsphere.proxy.metadata.ShardingMetaDataHandler
 
ShardingMetaDataHandlerFactory - Class in io.shardingsphere.core.jdbc.metadata
Table metadata handler factory.
ShardingMetaDataHandlerFactory() - Constructor for class io.shardingsphere.core.jdbc.metadata.ShardingMetaDataHandlerFactory
 
ShardingNamespaceHandler - Class in io.shardingsphere.jdbc.spring.namespace.handler
Spring namespace handler for sharding.
ShardingNamespaceHandler() - Constructor for class io.shardingsphere.jdbc.spring.namespace.handler.ShardingNamespaceHandler
 
ShardingOperator - Enum in io.shardingsphere.core.constant
Supported sharding operator.
ShardingPlaceholder - Interface in io.shardingsphere.core.rewrite.placeholder
Sharding placeholder for rewrite.
ShardingPreparedStatement - Class in io.shardingsphere.core.jdbc.core.statement
PreparedStatement that support sharding.
ShardingPreparedStatement(ShardingConnection, String) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
ShardingPreparedStatement(ShardingConnection, String, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
ShardingPreparedStatement(ShardingConnection, String, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
ShardingPreparedStatement(ShardingConnection, String, int, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingPreparedStatement
 
ShardingProperties - Class in io.shardingsphere.core.constant
Properties for sharding configuration.
ShardingProperties(Properties) - Constructor for class io.shardingsphere.core.constant.ShardingProperties
 
ShardingPropertiesConstant - Enum in io.shardingsphere.core.constant
Sharding properties constant.
ShardingProxy - Class in io.shardingsphere.proxy.frontend
Sharding-Proxy.
ShardingProxy() - Constructor for class io.shardingsphere.proxy.frontend.ShardingProxy
 
ShardingResultSet - Class in io.shardingsphere.core.jdbc.core.resultset
Result that support sharding.
ShardingResultSet(List<ResultSet>, MergedResult, Statement) - Constructor for class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
ShardingRouter - Interface in io.shardingsphere.core.routing.router.sharding
Sharding router.
ShardingRouterFactory - Class in io.shardingsphere.core.routing.router.sharding
Sharding router factory.
ShardingRouterFactory() - Constructor for class io.shardingsphere.core.routing.router.sharding.ShardingRouterFactory
 
ShardingRule - Class in io.shardingsphere.core.rule
Databases and tables sharding rule configuration.
ShardingRule(ShardingRuleConfiguration, Collection<String>) - Constructor for class io.shardingsphere.core.rule.ShardingRule
 
ShardingRuleConfiguration - Class in io.shardingsphere.core.api.config
Sharding rule configuration.
ShardingRuleConfiguration() - Constructor for class io.shardingsphere.core.api.config.ShardingRuleConfiguration
 
ShardingRuleConfigurationConverter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Sharding rule configuration json converter.
ShardingRuleConfigurationConverter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.ShardingRuleConfigurationConverter
 
ShardingStatement - Class in io.shardingsphere.core.jdbc.core.statement
Statement that support sharding.
ShardingStatement(ShardingConnection) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
ShardingStatement(ShardingConnection, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
ShardingStatement(ShardingConnection, int, int, int) - Constructor for class io.shardingsphere.core.jdbc.core.statement.ShardingStatement
 
ShardingStrategy - Interface in io.shardingsphere.core.routing.strategy
Sharding strategy.
ShardingStrategyBeanDefinition - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Sharding strategy parser for spring namespace.
ShardingStrategyBeanDefinition() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.ShardingStrategyBeanDefinition
 
ShardingStrategyBeanDefinition - Class in io.shardingsphere.jdbc.spring.namespace.parser
Sharding strategy parser for spring namespace.
ShardingStrategyBeanDefinition() - Constructor for class io.shardingsphere.jdbc.spring.namespace.parser.ShardingStrategyBeanDefinition
 
ShardingStrategyBeanDefinitionParser - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Sharding strategy bean parser for spring namespace.
ShardingStrategyBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.ShardingStrategyBeanDefinitionParser
 
ShardingStrategyBeanDefinitionParser - Class in io.shardingsphere.jdbc.spring.namespace.parser
Sharding strategy bean parser for spring namespace.
ShardingStrategyBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.spring.namespace.parser.ShardingStrategyBeanDefinitionParser
 
ShardingStrategyBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.constants
Sharding strategy parser tag constants.
ShardingStrategyBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
ShardingStrategyBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.spring.namespace.constants
Sharding strategy parser tag constants.
ShardingStrategyBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
ShardingStrategyConfiguration - Interface in io.shardingsphere.core.api.config.strategy
Sharding strategy configuration.
ShardingStrategyConfigurationGsonTypeAdapter - Class in io.shardingsphere.jdbc.orchestration.internal.json
Sharding strategy configuration gson type adapter.
ShardingStrategyConfigurationGsonTypeAdapter() - Constructor for class io.shardingsphere.jdbc.orchestration.internal.json.ShardingStrategyConfigurationGsonTypeAdapter
 
ShardingStrategyFactory - Class in io.shardingsphere.core.routing.strategy
Sharding strategy factory.
ShardingStrategyFactory() - Constructor for class io.shardingsphere.core.routing.strategy.ShardingStrategyFactory
 
ShardingValue - Interface in io.shardingsphere.core.api.algorithm.sharding
Sharding value interface.
ShowColumnsStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Show columns statement.
ShowColumnsStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.ShowColumnsStatement
 
ShowCreateTableMergedResult - Class in io.shardingsphere.core.merger.dal.show
Merged result for show create table.
ShowCreateTableMergedResult(ShardingRule, List<QueryResult>) - Constructor for class io.shardingsphere.core.merger.dal.show.ShowCreateTableMergedResult
 
ShowCreateTableStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Show create table statement.
ShowCreateTableStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.ShowCreateTableStatement
 
ShowDatabasesMergedResult - Class in io.shardingsphere.core.merger.dal.show
Merged result for show databases.
ShowDatabasesMergedResult() - Constructor for class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
ShowDatabasesStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Show databases statement.
ShowDatabasesStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.ShowDatabasesStatement
 
ShowOtherMergedResult - Class in io.shardingsphere.core.merger.dal.show
Merged result for show others.
ShowOtherMergedResult() - Constructor for class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
ShowOtherStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Other show statement.
ShowOtherStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.ShowOtherStatement
 
ShowParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dal.show
Show parser factory.
ShowParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.show.ShowParserFactory
 
ShowTablesMergedResult - Class in io.shardingsphere.core.merger.dal.show
Merged result for show tables.
ShowTablesMergedResult(ShardingRule, List<QueryResult>) - Constructor for class io.shardingsphere.core.merger.dal.show.ShowTablesMergedResult
 
ShowTablesStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Show tables statement.
ShowTablesStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.ShowTablesStatement
 
size() - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.CommandResponsePackets
Size of databaseProtocolPackets.
skipAll(TokenType...) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Skip all input tokens.
skipComment() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
skip comment.
skipHint() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
skip hint.
skipIfEqual(TokenType...) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Skip current token if equals one of input tokens.
skipParentheses(SQLStatement) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
skip all tokens that inside parentheses.
skipReserved(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Skip reserved from byte buffers.
skipUntil(TokenType...) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Skip until one of input tokens.
skipWhitespace() - Method in class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
skip whitespace.
SLAVE_DATA_SOURCE_NAMES_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
SLAVE_DATA_SOURCE_NAMES_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
SoftTransactionConfiguration - Class in io.shardingsphere.transaction.api.config
B.A.S.E transaction configuration.
SoftTransactionConfiguration() - Constructor for class io.shardingsphere.transaction.api.config.SoftTransactionConfiguration
 
SoftTransactionManager - Class in io.shardingsphere.transaction.api
B.A.S.E transaction manager.
SoftTransactionManager() - Constructor for class io.shardingsphere.transaction.api.SoftTransactionManager
 
SoftTransactionType - Enum in io.shardingsphere.transaction.constants
Type of B.A.S.E transaction.
splitWithComma(String) - Static method in class io.shardingsphere.core.util.StringUtil
Split string value to list by comma delimiter.
SpringBootConfiguration - Class in io.shardingsphere.jdbc.spring.boot
Spring boot sharding and master-slave configuration.
SpringBootConfiguration() - Constructor for class io.shardingsphere.jdbc.spring.boot.SpringBootConfiguration
 
SpringBootMasterSlaveRuleConfigurationProperties - Class in io.shardingsphere.jdbc.orchestration.spring.boot.masterslave
Master-slave rule configuration properties.
SpringBootMasterSlaveRuleConfigurationProperties() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.boot.masterslave.SpringBootMasterSlaveRuleConfigurationProperties
 
SpringBootMasterSlaveRuleConfigurationProperties - Class in io.shardingsphere.jdbc.spring.boot.masterslave
Master-slave rule configuration properties.
SpringBootMasterSlaveRuleConfigurationProperties() - Constructor for class io.shardingsphere.jdbc.spring.boot.masterslave.SpringBootMasterSlaveRuleConfigurationProperties
 
SpringBootOrchestrationConfigurationProperties - Class in io.shardingsphere.jdbc.orchestration.spring.boot.orchestration
Orchestration configuration properties.
SpringBootOrchestrationConfigurationProperties() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.boot.orchestration.SpringBootOrchestrationConfigurationProperties
 
SpringBootShardingRuleConfigurationProperties - Class in io.shardingsphere.jdbc.orchestration.spring.boot.sharding
Sharding rule configuration properties.
SpringBootShardingRuleConfigurationProperties() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.boot.sharding.SpringBootShardingRuleConfigurationProperties
 
SpringBootShardingRuleConfigurationProperties - Class in io.shardingsphere.jdbc.spring.boot.sharding
Sharding rule configuration properties.
SpringBootShardingRuleConfigurationProperties() - Constructor for class io.shardingsphere.jdbc.spring.boot.sharding.SpringBootShardingRuleConfigurationProperties
 
SpringMasterSlaveDataSource - Class in io.shardingsphere.jdbc.orchestration.spring.datasource
Master-slave datasource for spring namespace.
SpringMasterSlaveDataSource(Map<String, DataSource>, String, String, Collection<String>, MasterSlaveLoadBalanceAlgorithm) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.SpringMasterSlaveDataSource
 
SpringMasterSlaveDataSource(Map<String, DataSource>, String, String, Collection<String>, MasterSlaveLoadBalanceAlgorithmType) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.SpringMasterSlaveDataSource
 
SpringMasterSlaveDataSource - Class in io.shardingsphere.jdbc.spring.datasource
Master-slave datasource for spring namespace.
SpringMasterSlaveDataSource(Map<String, DataSource>, String, String, Collection<String>, MasterSlaveLoadBalanceAlgorithm, Map<String, Object>) - Constructor for class io.shardingsphere.jdbc.spring.datasource.SpringMasterSlaveDataSource
 
SpringMasterSlaveDataSource(Map<String, DataSource>, String, String, Collection<String>, MasterSlaveLoadBalanceAlgorithmType, Map<String, Object>) - Constructor for class io.shardingsphere.jdbc.spring.datasource.SpringMasterSlaveDataSource
 
SpringShardingDataSource - Class in io.shardingsphere.jdbc.orchestration.spring.datasource
Sharding datasource for spring namespace.
SpringShardingDataSource(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties) - Constructor for class io.shardingsphere.jdbc.orchestration.spring.datasource.SpringShardingDataSource
 
SpringShardingDataSource - Class in io.shardingsphere.jdbc.spring.datasource
Sharding datasource for spring namespace.
SpringShardingDataSource(Map<String, DataSource>, ShardingRuleConfiguration, Map<String, Object>, Properties) - Constructor for class io.shardingsphere.jdbc.spring.datasource.SpringShardingDataSource
 
SQLBuilder - Class in io.shardingsphere.core.rewrite
SQL builder.
SQLBuilder() - Constructor for class io.shardingsphere.core.rewrite.SQLBuilder
 
SQLBuilder(List<Object>) - Constructor for class io.shardingsphere.core.rewrite.SQLBuilder
 
SQLCase - Class in io.shardingsphere.test.sql
SQL test case for xml tag.
SQLCase() - Constructor for class io.shardingsphere.test.sql.SQLCase
 
SQLCases - Class in io.shardingsphere.test.sql
SQL test cases for xml root tag.
SQLCases() - Constructor for class io.shardingsphere.test.sql.SQLCases
 
SQLCasesLoader - Class in io.shardingsphere.test.sql
SQL test cases loader.
SQLCaseType - Enum in io.shardingsphere.test.sql
SQL case type.
SQLClauseParser - Interface in io.shardingsphere.core.parsing.parser.clause
SQL clause parser interface.
SQLExecuteBackendHandler - Class in io.shardingsphere.proxy.backend.common
SQL execute backend handler.
SQLExecuteBackendHandler(String, DatabaseType, boolean) - Constructor for class io.shardingsphere.proxy.backend.common.SQLExecuteBackendHandler
 
SQLExecutionUnit - Class in io.shardingsphere.core.routing
SQL execution unit.
SQLExecutionUnit() - Constructor for class io.shardingsphere.core.routing.SQLExecutionUnit
 
SQLExpression - Interface in io.shardingsphere.core.parsing.parser.expression
SQL expression interface.
SQLIdentifierExpression - Class in io.shardingsphere.core.parsing.parser.expression
Identifier expression.
SQLIdentifierExpression() - Constructor for class io.shardingsphere.core.parsing.parser.expression.SQLIdentifierExpression
 
SQLIgnoreExpression - Class in io.shardingsphere.core.parsing.parser.expression
Ignored expression when SQL parsing.
SQLIgnoreExpression() - Constructor for class io.shardingsphere.core.parsing.parser.expression.SQLIgnoreExpression
 
SQLJudgeEngine - Class in io.shardingsphere.core.parsing
SQL judge engine.
SQLJudgeEngine() - Constructor for class io.shardingsphere.core.parsing.SQLJudgeEngine
 
SQLLogger - Class in io.shardingsphere.core.util
SQL logger.
SQLLogger() - Constructor for class io.shardingsphere.core.util.SQLLogger
 
SQLNumberExpression - Class in io.shardingsphere.core.parsing.parser.expression
Number expression.
SQLNumberExpression() - Constructor for class io.shardingsphere.core.parsing.parser.expression.SQLNumberExpression
 
SQLParser - Interface in io.shardingsphere.core.parsing.parser.sql
SQL parser.
SQLParserFactory - Class in io.shardingsphere.core.parsing.parser.sql
SQL parser factory.
SQLParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.SQLParserFactory
 
SQLParsingEngine - Class in io.shardingsphere.core.parsing
SQL parsing engine.
SQLParsingEngine() - Constructor for class io.shardingsphere.core.parsing.SQLParsingEngine
 
SQLParsingException - Exception in io.shardingsphere.core.parsing.parser.exception
Throw exception when SQL parsing error.
SQLParsingException(String, Object...) - Constructor for exception io.shardingsphere.core.parsing.parser.exception.SQLParsingException
 
SQLParsingException(Lexer, TokenType) - Constructor for exception io.shardingsphere.core.parsing.parser.exception.SQLParsingException
 
SQLParsingException(LexerEngine) - Constructor for exception io.shardingsphere.core.parsing.parser.exception.SQLParsingException
 
SQLParsingUnsupportedException - Exception in io.shardingsphere.core.parsing.parser.exception
Throw exception when SQL not supported.
SQLParsingUnsupportedException(TokenType) - Constructor for exception io.shardingsphere.core.parsing.parser.exception.SQLParsingUnsupportedException
 
SQLPlaceholderExpression - Class in io.shardingsphere.core.parsing.parser.expression
Placeholder expression.
SQLPlaceholderExpression() - Constructor for class io.shardingsphere.core.parsing.parser.expression.SQLPlaceholderExpression
 
SQLPropertyExpression - Class in io.shardingsphere.core.parsing.parser.expression
Property expression.
SQLPropertyExpression() - Constructor for class io.shardingsphere.core.parsing.parser.expression.SQLPropertyExpression
 
SQLRewriteEngine - Class in io.shardingsphere.core.rewrite
SQL rewrite engine.
SQLRewriteEngine(ShardingRule, String, DatabaseType, SQLStatement, ShardingConditions, List<Object>) - Constructor for class io.shardingsphere.core.rewrite.SQLRewriteEngine
Constructs SQL rewrite engine.
SQLRouteResult - Class in io.shardingsphere.core.routing
SQL route result.
SQLRouteResult() - Constructor for class io.shardingsphere.core.routing.SQLRouteResult
 
SQLServerAliasExpressionParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.expression
Alias clause parser for SQLServer.
SQLServerAliasExpressionParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.expression.SQLServerAliasExpressionParser
 
SQLServerAlterParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Alter parser for SQLServer.
SQLServerAlterParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerAlterParser
 
SQLServerCreateParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Create parser for SQLServer.
SQLServerCreateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerCreateParser
 
SQLServerDeleteClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade
Delete clause parser facade for SQLServer.
SQLServerDeleteClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade.SQLServerDeleteClauseParserFacade
 
SQLServerDeleteParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Delete parser for SQLServer.
SQLServerDeleteParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerDeleteParser
 
SQLServerDropParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Drop parser for SQLServer.
SQLServerDropParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerDropParser
 
SQLServerInsertClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade
Insert clause parser facade for SQLServer.
SQLServerInsertClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade.SQLServerInsertClauseParserFacade
 
SQLServerInsertIntoClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Insert into clause parser for SQLServer.
SQLServerInsertIntoClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerInsertIntoClauseParser
 
SQLServerInsertParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Insert parser for SQLServer.
SQLServerInsertParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerInsertParser
 
SQLServerKeyword - Enum in io.shardingsphere.core.parsing.lexer.dialect.sqlserver
SQLServer keyword.
SQLServerLexer - Class in io.shardingsphere.core.parsing.lexer.dialect.sqlserver
SQLServer Lexical analysis.
SQLServerLexer(String) - Constructor for class io.shardingsphere.core.parsing.lexer.dialect.sqlserver.SQLServerLexer
 
SQLServerOffsetClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Offset clause parser for SQLServer.
SQLServerOffsetClauseParser() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerOffsetClauseParser
 
SQLServerOrderByClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Order by clause parser for SQLServer.
SQLServerOrderByClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerOrderByClauseParser
 
SQLServerSelectClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade
Select clause parser facade for SQLServer.
SQLServerSelectClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade.SQLServerSelectClauseParserFacade
 
SQLServerSelectListClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Select list clause parser for SQLServer.
SQLServerSelectListClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerSelectListClauseParser
 
SQLServerSelectParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Select parser for SQLServer.
SQLServerSelectParser(ShardingRule, LexerEngine, ShardingMetaData) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerSelectParser
 
SQLServerSelectRestClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Select rest clause parser for SQLServer.
SQLServerSelectRestClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerSelectRestClauseParser
 
SQLServerTableReferencesClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Table references clause parser for SQLServer.
SQLServerTableReferencesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerTableReferencesClauseParser
 
SQLServerTopClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Top clause parser for SQLServer.
SQLServerTopClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerTopClauseParser
 
SQLServerTruncateParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Truncate parser for SQLServer.
SQLServerTruncateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerTruncateParser
 
SQLServerUpdateClauseParserFacade - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade
Update clause parser facade for SQLServer.
SQLServerUpdateClauseParserFacade(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.facade.SQLServerUpdateClauseParserFacade
 
SQLServerUpdateParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql
Update parser for SQLServer.
SQLServerUpdateParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.sql.SQLServerUpdateParser
 
SQLServerWhereClauseParser - Class in io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause
Where clause parser for SQLServer.
SQLServerWhereClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.dialect.sqlserver.clause.SQLServerWhereClauseParser
 
SQLStatement - Interface in io.shardingsphere.core.parsing.parser.sql
SQL statement.
SQLTextExpression - Class in io.shardingsphere.core.parsing.parser.expression
Text expression.
SQLTextExpression() - Constructor for class io.shardingsphere.core.parsing.parser.expression.SQLTextExpression
 
SQLToken - Interface in io.shardingsphere.core.parsing.parser.token
SQL Token.
SQLType - Enum in io.shardingsphere.core.constant
SQL Type.
SQLUnit - Class in io.shardingsphere.core.routing
SQL unit.
SQLUnit() - Constructor for class io.shardingsphere.core.routing.SQLUnit
 
SQLUtil - Class in io.shardingsphere.core.util
SQL utility class.
SQLUtil() - Constructor for class io.shardingsphere.core.util.SQLUtil
 
STANDARD_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
STANDARD_STRATEGY_ROOT_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingStrategyBeanDefinitionParserTag
 
StandardRoutingEngine - Class in io.shardingsphere.core.routing.type.standard
Standard routing engine.
StandardRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.standard.StandardRoutingEngine
 
StandardShardingStrategy - Class in io.shardingsphere.core.routing.strategy.standard
Standard sharding strategy.
StandardShardingStrategy(StandardShardingStrategyConfiguration) - Constructor for class io.shardingsphere.core.routing.strategy.standard.StandardShardingStrategy
 
StandardShardingStrategyConfiguration - Class in io.shardingsphere.core.api.config.strategy
Standard strategy configuration.
StandardShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.api.config.strategy.StandardShardingStrategyConfiguration
 
StarSelectItem - Class in io.shardingsphere.core.parsing.parser.context.selectitem
Select all item.
StarSelectItem() - Constructor for class io.shardingsphere.core.parsing.parser.context.selectitem.StarSelectItem
 
start(ShardingDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigMapListenerManager
 
start(MasterSlaveDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigMapListenerManager
 
start(ShardingDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationListenerManager
 
start(MasterSlaveDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.config.ConfigurationListenerManager
 
start(ShardingDataSource) - Method in interface io.shardingsphere.jdbc.orchestration.internal.listener.ListenerManager
Start sharding datasource change listener.
start(MasterSlaveDataSource) - Method in interface io.shardingsphere.jdbc.orchestration.internal.listener.ListenerManager
Start master-slave datasource change listener.
start(ShardingDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceListenerManager
 
start(MasterSlaveDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.state.datasource.DataSourceListenerManager
 
start(ShardingDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.state.instance.InstanceListenerManager
 
start(MasterSlaveDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.state.instance.InstanceListenerManager
 
start(int) - Method in class io.shardingsphere.proxy.frontend.ShardingProxy
Start Sharding-Proxy.
start() - Method in class io.shardingsphere.transaction.job.BASETransactionJobFactory
start job.
StatementExecuteBackendHandler - Class in io.shardingsphere.proxy.backend.common
Statement execute backend handler.
StatementExecuteBackendHandler(List<PreparedStatementParameter>, int, DatabaseType, boolean) - Constructor for class io.shardingsphere.proxy.backend.common.StatementExecuteBackendHandler
 
StatementExecutor - Class in io.shardingsphere.core.executor.type.statement
Statement Executor for multiple threads.
StatementExecutor() - Constructor for class io.shardingsphere.core.executor.type.statement.StatementExecutor
 
StatementRoutingEngine - Class in io.shardingsphere.core.routing
Statement routing engine.
StatementRoutingEngine(ShardingRule, ShardingMetaData, DatabaseType, boolean) - Constructor for class io.shardingsphere.core.routing.StatementRoutingEngine
 
StatementUnit - Class in io.shardingsphere.core.executor.type.statement
Statement execute unit.
StatementUnit() - Constructor for class io.shardingsphere.core.executor.type.statement.StatementUnit
 
StateNode - Class in io.shardingsphere.jdbc.orchestration.internal.state
State node.
StateNode(String) - Constructor for class io.shardingsphere.jdbc.orchestration.internal.state.StateNode
 
StateNodeStatus - Enum in io.shardingsphere.jdbc.orchestration.internal.state
State node status.
StatusFlag - Enum in io.shardingsphere.proxy.transport.mysql.constant
Status flags are a bit-field.
storesLowerCaseIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
storesLowerCaseQuotedIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
storesMixedCaseIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
storesMixedCaseQuotedIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
storesUpperCaseIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
storesUpperCaseQuotedIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
STRATEGY_TYPE_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
STRATEGY_TYPE_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.MasterSlaveDataSourceBeanDefinitionParserTag
 
StreamMergedResult - Class in io.shardingsphere.core.merger.dql.common
流式归并结果集.
StreamMergedResult() - Constructor for class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
StringUtil - Class in io.shardingsphere.core.util
String utility class.
StringUtil() - Constructor for class io.shardingsphere.core.util.StringUtil
 
supportsAlterTableWithAddColumn() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsAlterTableWithDropColumn() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsANSI92EntryLevelSQL() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsANSI92FullSQL() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsANSI92IntermediateSQL() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsBatchUpdates() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCatalogsInDataManipulation() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCatalogsInIndexDefinitions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCatalogsInPrivilegeDefinitions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCatalogsInProcedureCalls() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCatalogsInTableDefinitions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsColumnAliasing() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsConvert() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsConvert(int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCoreSQLGrammar() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsCorrelatedSubqueries() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsDataDefinitionAndDataManipulationTransactions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsDataManipulationTransactionsOnly() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsDifferentTableCorrelationNames() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsExpressionsInOrderBy() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsExtendedSQLGrammar() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsFullOuterJoins() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsGetGeneratedKeys() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsGroupBy() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsGroupByBeyondSelect() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsGroupByUnrelated() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsIntegrityEnhancementFacility() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsLikeEscapeClause() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsLimitedOuterJoins() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsMinimumSQLGrammar() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsMixedCaseIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsMixedCaseQuotedIdentifiers() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsMultipleOpenResults() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsMultipleResultSets() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsMultipleTransactions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsNamedParameters() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsNonNullableColumns() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsOpenCursorsAcrossCommit() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsOpenCursorsAcrossRollback() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsOpenStatementsAcrossCommit() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsOpenStatementsAcrossRollback() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsOrderByUnrelated() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsOuterJoins() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsPositionedDelete() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsPositionedUpdate() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsResultSetConcurrency(int, int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsResultSetHoldability(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsResultSetType(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSavepoints() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSchemasInDataManipulation() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSchemasInIndexDefinitions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSchemasInPrivilegeDefinitions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSchemasInProcedureCalls() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSchemasInTableDefinitions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSelectForUpdate() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsStatementPooling() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsStoredFunctionsUsingCallSyntax() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsStoredProcedures() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSubqueriesInComparisons() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSubqueriesInExists() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSubqueriesInIns() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsSubqueriesInQuantifieds() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsTableCorrelationNames() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsTransactionIsolationLevel(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsTransactions() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsUnion() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
supportsUnionAll() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
Symbol - Enum in io.shardingsphere.core.parsing.lexer.token
Symbol token.

T

Table - Class in io.shardingsphere.core.parsing.parser.context.table
Table.
Table() - Constructor for class io.shardingsphere.core.parsing.parser.context.table.Table
 
TABLE_RULE_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
TABLE_RULE_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
TABLE_RULES_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
TABLE_RULES_TAG - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
TABLE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
TABLE_STRATEGY_REF_ATTRIBUTE - Static variable in class io.shardingsphere.jdbc.spring.namespace.constants.ShardingDataSourceBeanDefinitionParserTag
 
TableBroadcastRoutingEngine - Class in io.shardingsphere.core.routing.type.broadcast
Broadcast routing engine for tables.
TableBroadcastRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.broadcast.TableBroadcastRoutingEngine
 
TableMetaData - Class in io.shardingsphere.core.metadata
Table metadata.
TableMetaData() - Constructor for class io.shardingsphere.core.metadata.TableMetaData
 
TablePlaceholder - Class in io.shardingsphere.core.rewrite.placeholder
Table placeholder for rewrite.
TablePlaceholder() - Constructor for class io.shardingsphere.core.rewrite.placeholder.TablePlaceholder
 
TableReferencesClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Table references clause parser.
TableReferencesClauseParser(ShardingRule, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.TableReferencesClauseParser
 
TableRule - Class in io.shardingsphere.core.rule
Table rule configuration.
TableRule(TableRuleConfiguration, ShardingDataSourceNames) - Constructor for class io.shardingsphere.core.rule.TableRule
 
TableRuleConfiguration - Class in io.shardingsphere.core.api.config
Table rule configuration.
TableRuleConfiguration() - Constructor for class io.shardingsphere.core.api.config.TableRuleConfiguration
 
Tables - Class in io.shardingsphere.core.parsing.parser.context.table
Tables collection.
Tables() - Constructor for class io.shardingsphere.core.parsing.parser.context.table.Tables
 
TableToken - Class in io.shardingsphere.core.parsing.parser.token
Table token.
TableToken() - Constructor for class io.shardingsphere.core.parsing.parser.token.TableToken
 
TableUnit - Class in io.shardingsphere.core.routing.type
Route table unit.
TableUnit() - Constructor for class io.shardingsphere.core.routing.type.TableUnit
 
TableUnits - Class in io.shardingsphere.core.routing.type
Route table unit collection.
TableUnits() - Constructor for class io.shardingsphere.core.routing.type.TableUnits
 
TCCSoftTransaction - Class in io.shardingsphere.transaction.tcc
Try confirm cancel B.A.S.E transaction.
TCCSoftTransaction() - Constructor for class io.shardingsphere.transaction.tcc.TCCSoftTransaction
 
TCCWorkflow - Enum in io.shardingsphere.transaction.tcc
TCC workflow.
TCLParser - Class in io.shardingsphere.core.parsing.parser.sql.tcl
TCL parser.
TCLParser() - Constructor for class io.shardingsphere.core.parsing.parser.sql.tcl.TCLParser
 
TCLParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.tcl
Transaction Control Language parser factory.
TCLParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.tcl.TCLParserFactory
 
TCLStatement - Class in io.shardingsphere.core.parsing.parser.sql.tcl
Transaction Control Language statement.
TCLStatement() - Constructor for class io.shardingsphere.core.parsing.parser.sql.tcl.TCLStatement
 
TextResultSetRowPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command.text.query
Text result set row packet.
TextResultSetRowPacket(int, List<Object>) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.TextResultSetRowPacket
 
throwSQLExceptionIfNecessary(Collection<SQLException>) - Method in class io.shardingsphere.core.jdbc.adapter.WrapperAdapter
 
TIME_TO_LIVE_SECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
TIMEOUT_MILLISECONDS_TAG - Static variable in class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.EtcdRegistryCenterBeanDefinitionParserTag
 
TimeService - Class in io.shardingsphere.core.keygen
Time service.
TimeService() - Constructor for class io.shardingsphere.core.keygen.TimeService
 
toJson(Map<String, DataSource>) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceJsonConverter
Convert data source map to json.
toJson(MasterSlaveRuleConfiguration) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.MasterSlaveRuleConfigurationConverter
Convert master-slave rule configuration to json.
toJson(ShardingRuleConfiguration) - Static method in class io.shardingsphere.jdbc.orchestration.internal.json.ShardingRuleConfigurationConverter
Convert sharding rule configuration to json.
Token - Class in io.shardingsphere.core.parsing.lexer.token
Token.
Token() - Constructor for class io.shardingsphere.core.parsing.lexer.token.Token
 
Tokenizer - Class in io.shardingsphere.core.parsing.lexer.analyzer
Tokenizer.
Tokenizer() - Constructor for class io.shardingsphere.core.parsing.lexer.analyzer.Tokenizer
 
TokenType - Interface in io.shardingsphere.core.parsing.lexer.token
Token type.
TopAndRowNumberDecoratorMergedResult - Class in io.shardingsphere.core.merger.dql.pagination
Decorator merged result for top and rownum pagination.
TopAndRowNumberDecoratorMergedResult(MergedResult, Limit) - Constructor for class io.shardingsphere.core.merger.dql.pagination.TopAndRowNumberDecoratorMergedResult
 
toSQL(TableUnit, Map<String, String>, ShardingRule) - Method in class io.shardingsphere.core.rewrite.SQLBuilder
Convert to SQL unit.
toString() - Method in class io.shardingsphere.core.rewrite.placeholder.IndexPlaceholder
 
toString() - Method in class io.shardingsphere.core.rewrite.placeholder.SchemaPlaceholder
 
toString() - Method in class io.shardingsphere.core.rewrite.placeholder.TablePlaceholder
 
TransactionCompensationException - Exception in io.shardingsphere.transaction.exception
Transaction compensation exception.
TransactionCompensationException(String, Object...) - Constructor for exception io.shardingsphere.transaction.exception.TransactionCompensationException
 
TransactionCompensationException(String, Exception) - Constructor for exception io.shardingsphere.transaction.exception.TransactionCompensationException
 
TransactionCompensationException(Exception) - Constructor for exception io.shardingsphere.transaction.exception.TransactionCompensationException
 
TransactionLog - Class in io.shardingsphere.transaction.storage
Transaction log.
TransactionLog() - Constructor for class io.shardingsphere.transaction.storage.TransactionLog
 
TransactionLogDataSource - Interface in io.shardingsphere.transaction.datasource
Transaction log data source.
TransactionLogDataSourceType - Enum in io.shardingsphere.transaction.constants
Transaction log data source type.
TransactionLogStorage - Interface in io.shardingsphere.transaction.storage
Transaction log storage interface.
TransactionLogStorageException - Exception in io.shardingsphere.transaction.exception
Transaction log storage exception.
TransactionLogStorageException(String, Object...) - Constructor for exception io.shardingsphere.transaction.exception.TransactionLogStorageException
 
TransactionLogStorageException(String, Exception) - Constructor for exception io.shardingsphere.transaction.exception.TransactionLogStorageException
 
TransactionLogStorageException(Exception) - Constructor for exception io.shardingsphere.transaction.exception.TransactionLogStorageException
 
TransactionLogStorageFactory - Class in io.shardingsphere.transaction.storage
Transaction log storage factory.
TransactionLogStorageFactory() - Constructor for class io.shardingsphere.transaction.storage.TransactionLogStorageFactory
 
TruncateParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.ddl.truncate
Truncate parser factory.
TruncateParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.ddl.truncate.TruncateParserFactory
 
tryFindTableRuleByActualTable(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Try to find table rule though actual table name.
tryFindTableRuleByLogicTable(String) - Method in class io.shardingsphere.core.rule.ShardingRule
Try to find table rule though logic table name.

U

UnicastRoutingEngine - Class in io.shardingsphere.core.routing.type.unicast
Unicast routing engine.
UnicastRoutingEngine() - Constructor for class io.shardingsphere.core.routing.type.unicast.UnicastRoutingEngine
 
unmarshal(File) - Static method in class io.shardingsphere.core.yaml.masterslave.YamlMasterSlaveConfiguration
Unmarshal yaml master slave configuration from yaml file.
unmarshal(byte[]) - Static method in class io.shardingsphere.core.yaml.masterslave.YamlMasterSlaveConfiguration
Unmarshal yaml sharding configuration from yaml bytes.
unmarshal(File) - Static method in class io.shardingsphere.core.yaml.proxy.YamlProxyConfiguration
Unmarshal yaml sharding configuration from yaml file.
unmarshal(byte[]) - Static method in class io.shardingsphere.core.yaml.proxy.YamlProxyConfiguration
Unmarshal yaml sharding configuration from yaml bytes.
unmarshal(File) - Static method in class io.shardingsphere.core.yaml.sharding.YamlShardingConfiguration
Unmarshal yaml sharding configuration from yaml file.
unmarshal(byte[]) - Static method in class io.shardingsphere.core.yaml.sharding.YamlShardingConfiguration
Unmarshal yaml sharding configuration from yaml bytes.
UnsupportedCommandPacket - Class in io.shardingsphere.proxy.transport.mysql.packet.command
Unsupported command packet.
UnsupportedCommandPacket(int, CommandPacketType) - Constructor for class io.shardingsphere.proxy.transport.mysql.packet.command.UnsupportedCommandPacket
 
unsupportedIfEqual(TokenType...) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Throw unsupported exception if current token equals one of input tokens.
unsupportedIfNotSkip(TokenType...) - Method in class io.shardingsphere.core.parsing.lexer.LexerEngine
Throw unsupported exception if current token not equals one of input tokens.
UnterminatedCharException - Exception in io.shardingsphere.core.parsing.lexer.analyzer
Unterminated char exception.
UnterminatedCharException(char) - Constructor for exception io.shardingsphere.core.parsing.lexer.analyzer.UnterminatedCharException
 
UnterminatedCharException(String) - Constructor for exception io.shardingsphere.core.parsing.lexer.analyzer.UnterminatedCharException
 
unwrap(Class<T>) - Method in class io.shardingsphere.core.jdbc.adapter.WrapperAdapter
 
unwrap(Class<T>) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
unwrap(Class<T>) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSetMetaData
 
update(String, String) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Update data.
update(String, String) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
update(String, String) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
updateArray(int, Array) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateArray(String, Array) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateAsciiStream(int, InputStream) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateAsciiStream(String, InputStream) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateAsciiStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateAsciiStream(String, InputStream, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateAsciiStream(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateAsciiStream(String, InputStream, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBigDecimal(int, BigDecimal) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBigDecimal(String, BigDecimal) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBinaryStream(int, InputStream) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBinaryStream(String, InputStream) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBinaryStream(int, InputStream, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBinaryStream(String, InputStream, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBinaryStream(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBinaryStream(String, InputStream, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBlob(int, Blob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBlob(String, Blob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBlob(int, InputStream) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBlob(String, InputStream) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBlob(int, InputStream, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBlob(String, InputStream, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBoolean(int, boolean) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBoolean(String, boolean) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateByte(int, byte) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateByte(String, byte) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBytes(int, byte[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateBytes(String, byte[]) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateCharacterStream(int, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateCharacterStream(String, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateCharacterStream(int, Reader, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateCharacterStream(String, Reader, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateCharacterStream(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateCharacterStream(String, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateClob(int, Clob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateClob(String, Clob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateClob(int, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateClob(String, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateClob(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateClob(String, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateDate(int, Date) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateDate(String, Date) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateDouble(int, double) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateDouble(String, double) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateFloat(int, float) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateFloat(String, float) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateInt(int, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateInt(String, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateLong(int, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateLong(String, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNCharacterStream(int, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNCharacterStream(String, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNCharacterStream(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNCharacterStream(String, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNClob(int, NClob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNClob(String, NClob) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNClob(int, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNClob(String, Reader) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNClob(int, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNClob(String, Reader, long) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNString(int, String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNString(String, String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNull(int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateNull(String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateObject(int, Object) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateObject(String, Object) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateObject(int, Object, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateObject(String, Object, int) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
UpdateParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dml.update
Update parser factory.
UpdateParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dml.update.UpdateParserFactory
 
updateRef(int, Ref) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateRef(String, Ref) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateRow() - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedOperationResultSet
 
updateRowId(int, RowId) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateRowId(String, RowId) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updatesAreDetected(int) - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
UpdateSetItemsClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Update set items clause parser.
UpdateSetItemsClauseParser(LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.UpdateSetItemsClauseParser
 
updateShort(int, short) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateShort(String, short) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateSQLXML(int, SQLXML) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateSQLXML(String, SQLXML) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateString(int, String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateString(String, String) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateTime(int, Time) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateTime(String, Time) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateTimestamp(int, Timestamp) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
updateTimestamp(String, Timestamp) - Method in class io.shardingsphere.core.jdbc.unsupported.AbstractUnsupportedUpdateOperationResultSet
 
UseParserFactory - Class in io.shardingsphere.core.parsing.parser.sql.dal.use
Use parser factory.
UseParserFactory() - Constructor for class io.shardingsphere.core.parsing.parser.sql.dal.use.UseParserFactory
 
usesLocalFilePerTable() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
usesLocalFiles() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.metadata.CircuitBreakerDatabaseMetaData
 
UseStatement - Class in io.shardingsphere.core.parsing.parser.dialect.mysql.statement
Use statement.
UseStatement() - Constructor for class io.shardingsphere.core.parsing.parser.dialect.mysql.statement.UseStatement
 

V

valueFrom(String) - Static method in enum io.shardingsphere.core.constant.DatabaseType
Get database type enum via database name string.
valueOf(String) - Static method in enum io.shardingsphere.core.api.algorithm.masterslave.MasterSlaveLoadBalanceAlgorithmType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.constant.AggregationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.constant.DatabaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.constant.OrderDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.constant.ShardingOperator
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.constant.ShardingPropertiesConstant
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.constant.SQLType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.executor.event.EventExecutionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.mysql.MySQLKeyword
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.oracle.OracleKeyword
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.postgresql.PostgreSQLKeyword
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.sqlserver.SQLServerKeyword
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.token.Assist
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.token.DefaultKeyword
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.token.Literals
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.core.parsing.lexer.token.Symbol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.jdbc.orchestration.api.config.OrchestrationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.jdbc.orchestration.internal.state.StateNodeStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.jdbc.orchestration.reg.listener.DataChangedEvent.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.CapabilityFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.ColumnType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.ColumnType
Value of.
valueOf(String) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.NewParametersBoundFlag
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.NewParametersBoundFlag
Value of.
valueOf(String) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.StatusFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacketType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacketType
Value of integer.
valueOf(String) - Static method in enum io.shardingsphere.test.sql.SQLCaseType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.transaction.constants.SoftTransactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.transaction.constants.TransactionLogDataSourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum io.shardingsphere.transaction.tcc.TCCWorkflow
Returns the enum constant of this type with the specified name.
valueOfJDBCType(int) - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.ColumnType
Value of JDBC type.
values() - Static method in enum io.shardingsphere.core.api.algorithm.masterslave.MasterSlaveLoadBalanceAlgorithmType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.constant.AggregationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.constant.DatabaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.constant.OrderDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.constant.ShardingOperator
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.constant.ShardingPropertiesConstant
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.constant.SQLType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.executor.event.EventExecutionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.mysql.MySQLKeyword
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.oracle.OracleKeyword
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.postgresql.PostgreSQLKeyword
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.dialect.sqlserver.SQLServerKeyword
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.token.Assist
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.token.DefaultKeyword
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.token.Literals
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.core.parsing.lexer.token.Symbol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.jdbc.orchestration.api.config.OrchestrationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.jdbc.orchestration.internal.state.StateNodeStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.jdbc.orchestration.reg.listener.DataChangedEvent.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.CapabilityFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.ColumnType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.NewParametersBoundFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.proxy.transport.mysql.constant.StatusFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.proxy.transport.mysql.packet.command.CommandPacketType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.test.sql.SQLCaseType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.transaction.constants.SoftTransactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.transaction.constants.TransactionLogDataSourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum io.shardingsphere.transaction.tcc.TCCWorkflow
Returns an array containing the constants of this enum type, in the order they are declared.

W

wasNull() - Method in class io.shardingsphere.core.jdbc.core.resultset.GeneratedKeysResultSet
 
wasNull() - Method in class io.shardingsphere.core.jdbc.core.resultset.ShardingResultSet
 
wasNull() - Method in class io.shardingsphere.core.merger.dal.show.ShowDatabasesMergedResult
 
wasNull() - Method in class io.shardingsphere.core.merger.dal.show.ShowOtherMergedResult
 
wasNull() - Method in class io.shardingsphere.core.merger.dql.common.DecoratorMergedResult
 
wasNull() - Method in class io.shardingsphere.core.merger.dql.common.MemoryMergedResult
 
wasNull() - Method in class io.shardingsphere.core.merger.dql.common.StreamMergedResult
 
wasNull() - Method in class io.shardingsphere.core.merger.JDBCQueryResult
 
wasNull() - Method in interface io.shardingsphere.core.merger.MergedResult
Adjust ResultSet is null or not.
wasNull() - Method in interface io.shardingsphere.core.merger.QueryResult
Adjust ResultSet is null or not.
wasNull() - Method in class io.shardingsphere.jdbc.orchestration.internal.jdbc.resultset.CircuitBreakerResultSet
 
wasNull() - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketQueryResult
 
wasNull() - Method in class io.shardingsphere.proxy.backend.mysql.MySQLPacketStatementExecuteQueryResult
 
watch(String, EventListener) - Method in interface io.shardingsphere.jdbc.orchestration.reg.api.RegistryCenter
Watch key or path of the registry.
watch(String, EventListener) - Method in class io.shardingsphere.jdbc.orchestration.reg.etcd.EtcdRegistryCenter
 
watch(String, EventListener) - Method in class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
WhereClauseParser - Class in io.shardingsphere.core.parsing.parser.clause
Where clause parser.
WhereClauseParser(DatabaseType, LexerEngine) - Constructor for class io.shardingsphere.core.parsing.parser.clause.WhereClauseParser
 
WrapperAdapter - Class in io.shardingsphere.core.jdbc.adapter
Adapter for Wrapper.
WrapperAdapter() - Constructor for class io.shardingsphere.core.jdbc.adapter.WrapperAdapter
 
write(JsonWriter, NamedDataSource) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.DataSourceGsonTypeAdapter
 
write(JsonWriter, KeyGenerator) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.KeyGeneratorGsonTypeAdapter
 
write(JsonWriter, MasterSlaveLoadBalanceAlgorithm) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.MasterSlaveLoadBalanceAlgorithmGsonTypeAdapter
 
write(JsonWriter, ShardingStrategyConfiguration) - Method in class io.shardingsphere.jdbc.orchestration.internal.json.ShardingStrategyConfigurationGsonTypeAdapter
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.close.ComStmtClosePacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.BinaryResultSetRowPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.ComStmtExecutePacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPrepareOKPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.prepare.ComStmtPreparePacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.fieldlist.ComFieldListPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.initdb.ComInitDbPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.ping.ComPingPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ColumnDefinition41Packet
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.ComQueryPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.FieldCountPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.query.TextResultSetRowPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.text.quit.ComQuitPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.UnsupportedCommandPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.generic.EofPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.generic.ErrPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.generic.OKPacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.handshake.HandshakePacket
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.handshake.HandshakeResponse41Packet
 
write(MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacket
Write packet to byte buffer.
writeBinaryProtocolValue(ColumnType, Object, MySQLPacketPayload) - Method in class io.shardingsphere.proxy.transport.mysql.packet.command.statement.execute.BinaryProtocolValueUtility
Write binary protocol value.
writeDate(Timestamp) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write date to byte buffers.
writeDouble(double) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 8 byte double to byte buffers.
writeFloat(float) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 4 byte float to byte buffers.
writeInt1(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 1 byte fixed length integer to byte buffers.
writeInt2(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 2 byte fixed length integer to byte buffers.
writeInt3(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 3 byte fixed length integer to byte buffers.
writeInt4(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 4 byte fixed length integer to byte buffers.
writeInt6(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 6 byte fixed length integer to byte buffers.
writeInt8(long) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write 8 byte fixed length integer to byte buffers.
writeIntLenenc(long) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write length encoded integer to byte buffers.
writeReserved(int) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write null for reserved to byte buffers.
writeStringEOF(String) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write rest of packet string to byte buffers.
writeStringFix(String) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write variable length string to byte buffers.
writeStringLenenc(String) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write fixed length string to byte buffers.
writeStringNul(String) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write null terminated string to byte buffers.
writeStringVar(String) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write fixed length string to byte buffers.
writeTime(Date) - Method in class io.shardingsphere.proxy.transport.mysql.packet.MySQLPacketPayload
Write time to byte buffers.

Y

YamlComplexShardingStrategyConfiguration - Class in io.shardingsphere.core.yaml.sharding.strategy
Complex sharding strategy configuration for yaml.
YamlComplexShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.strategy.YamlComplexShardingStrategyConfiguration
 
YamlHintShardingStrategyConfiguration - Class in io.shardingsphere.core.yaml.sharding.strategy
Hint sharding strategy configuration for yaml.
YamlHintShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.strategy.YamlHintShardingStrategyConfiguration
 
YamlInlineShardingStrategyConfiguration - Class in io.shardingsphere.core.yaml.sharding.strategy
Inline sharding strategy configuration for yaml.
YamlInlineShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.strategy.YamlInlineShardingStrategyConfiguration
 
YamlMasterSlaveConfiguration - Class in io.shardingsphere.core.yaml.masterslave
Master-slave configuration for yaml.
YamlMasterSlaveConfiguration() - Constructor for class io.shardingsphere.core.yaml.masterslave.YamlMasterSlaveConfiguration
 
YamlMasterSlaveDataSourceFactory - Class in io.shardingsphere.core.api.yaml
Master-slave data source factory for YAML.
YamlMasterSlaveDataSourceFactory() - Constructor for class io.shardingsphere.core.api.yaml.YamlMasterSlaveDataSourceFactory
 
YamlMasterSlaveRuleConfiguration - Class in io.shardingsphere.core.yaml.masterslave
Master-slave rule configuration for yaml.
YamlMasterSlaveRuleConfiguration() - Constructor for class io.shardingsphere.core.yaml.masterslave.YamlMasterSlaveRuleConfiguration
 
YamlNoneShardingStrategyConfiguration - Class in io.shardingsphere.core.yaml.sharding.strategy
None sharding strategy configuration for yaml.
YamlNoneShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.strategy.YamlNoneShardingStrategyConfiguration
 
YamlOrchestrationConfiguration - Class in io.shardingsphere.jdbc.orchestration.yaml
Orchestration configuration for yaml.
YamlOrchestrationConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.yaml.YamlOrchestrationConfiguration
 
YamlOrchestrationMasterSlaveDataSourceFactory - Class in io.shardingsphere.jdbc.orchestration.api.yaml
Orchestration master-slave data source factory for YAML.
YamlOrchestrationMasterSlaveDataSourceFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationMasterSlaveDataSourceFactory
 
YamlOrchestrationMasterSlaveRuleConfiguration - Class in io.shardingsphere.jdbc.orchestration.yaml
Orchestration master-slave configuration for yaml.
YamlOrchestrationMasterSlaveRuleConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.yaml.YamlOrchestrationMasterSlaveRuleConfiguration
 
YamlOrchestrationShardingDataSourceFactory - Class in io.shardingsphere.jdbc.orchestration.api.yaml
Orchestration sharding data source factory for YAML.
YamlOrchestrationShardingDataSourceFactory() - Constructor for class io.shardingsphere.jdbc.orchestration.api.yaml.YamlOrchestrationShardingDataSourceFactory
 
YamlOrchestrationShardingRuleConfiguration - Class in io.shardingsphere.jdbc.orchestration.yaml
Orchestration sharding configuration for yaml.
YamlOrchestrationShardingRuleConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.yaml.YamlOrchestrationShardingRuleConfiguration
 
YamlProxyConfiguration - Class in io.shardingsphere.core.yaml.proxy
Yaml sharding configuration for proxy.
YamlProxyConfiguration() - Constructor for class io.shardingsphere.core.yaml.proxy.YamlProxyConfiguration
 
YamlShardingConfiguration - Class in io.shardingsphere.core.yaml.sharding
Sharding configuration for yaml.
YamlShardingConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.YamlShardingConfiguration
 
YamlShardingDataSourceFactory - Class in io.shardingsphere.core.api.yaml
Sharding data source factory for YAML.
YamlShardingDataSourceFactory() - Constructor for class io.shardingsphere.core.api.yaml.YamlShardingDataSourceFactory
 
YamlShardingRuleConfiguration - Class in io.shardingsphere.core.yaml.sharding
Sharding rule configuration for yaml.
YamlShardingRuleConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.YamlShardingRuleConfiguration
 
YamlShardingStrategyConfiguration - Interface in io.shardingsphere.core.yaml.sharding.strategy
Sharding strategy configuration for yaml.
YamlShardingStrategyConfiguration - Class in io.shardingsphere.core.yaml.sharding
Configuration for yaml sharding strategy.
YamlShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.YamlShardingStrategyConfiguration
 
YamlStandardShardingStrategyConfiguration - Class in io.shardingsphere.core.yaml.sharding.strategy
Standard strategy configuration for yaml.
YamlStandardShardingStrategyConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.strategy.YamlStandardShardingStrategyConfiguration
 
YamlTableRuleConfiguration - Class in io.shardingsphere.core.yaml.sharding
Yaml table rule configuration.
YamlTableRuleConfiguration() - Constructor for class io.shardingsphere.core.yaml.sharding.YamlTableRuleConfiguration
 

Z

ZookeeperBeanDefinitionParser - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.parser
Zookeeper namespace parser for spring namespace.
ZookeeperBeanDefinitionParser() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.parser.ZookeeperBeanDefinitionParser
 
ZookeeperConfiguration - Class in io.shardingsphere.jdbc.orchestration.reg.zookeeper
Zookeeper based registry center configuration.
ZookeeperConfiguration() - Constructor for class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperConfiguration
 
ZookeeperRegistryCenter - Class in io.shardingsphere.jdbc.orchestration.reg.zookeeper
Zookeeper based registry center.
ZookeeperRegistryCenter(ZookeeperConfiguration) - Constructor for class io.shardingsphere.jdbc.orchestration.reg.zookeeper.ZookeeperRegistryCenter
 
ZookeeperRegistryCenterBeanDefinitionParserTag - Class in io.shardingsphere.jdbc.orchestration.spring.namespace.constants
Zookeeper registry center parser tag constants.
ZookeeperRegistryCenterBeanDefinitionParserTag() - Constructor for class io.shardingsphere.jdbc.orchestration.spring.namespace.constants.ZookeeperRegistryCenterBeanDefinitionParserTag
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
Skip navigation links

Copyright © 2018. All rights reserved.