Tag List Report

The following document contains the listing of user tags found in the code. Below is the summary of the occurrences per tag.

Tag Class Total number of occurrences Tag strings used by tag class
@todo 0 @todo
TODO 338 TODO

Each tag is detailed below:

TODO

Number of occurrences found in the code: 338

org.apache.shardingsphere.broadcast.route.BroadcastSQLRouter Line
add dropResourceGroupStatement, alterResourceGroupStatement 141
org.apache.shardingsphere.data.pipeline.cdc.client.util.ProtobufAnyValueConverter Line
can't use JsonFormat, might change the original value without error prompt. there need to cover more types, 95
org.apache.shardingsphere.data.pipeline.cdc.core.importer.CDCImporter Line
Combine small transactions into a large transaction, to improve transformation performance. 104
openGauss CSN should be incremented for every transaction. Currently, CSN might be duplicated in transactions. 134
Use channels watermark depth to improve performance. 135
org.apache.shardingsphere.data.pipeline.cdc.core.prepare.CDCJobPreparer Line
Use pipeline tree to build it 74
org.apache.shardingsphere.data.pipeline.cdc.handler.CDCBackendHandler Line
if different schema have same table names, table name may be overwritten, because the table name at sharding rule not contain schema. 111
Add globalCSNSupported to isolate it with decodeWithTx flag, they're different. And also update CDCJobPreparer needSorting flag. 122
org.apache.shardingsphere.data.pipeline.cdc.util.CDCDataNodeUtils Line
support virtual data source name 58
org.apache.shardingsphere.data.pipeline.core.channel.PipelineChannel Line
Refactor ack param 66
org.apache.shardingsphere.data.pipeline.core.consistencycheck.pojo.ConsistencyCheckJobItemInfo Line
use final for fields 26
embed ConsistencyCheckJobItemProgress to reduce fields 27
org.apache.shardingsphere.data.pipeline.core.consistencycheck.table.MatchingTableInventoryChecker Line
use digest (crc32, murmurhash) 129
org.apache.shardingsphere.data.pipeline.core.consistencycheck.table.calculator.CRC32SingleTableInventoryCalculator Line
not support now 117
org.apache.shardingsphere.data.pipeline.core.datasource.creator.ShardingSpherePipelineDataSourceCreator Line
Another way is improving ExecuteQueryCallback.executeSQL to enable streaming query, then remove it 90
org.apache.shardingsphere.data.pipeline.core.exception.IngestException Line
extends from PipelineSQLException 23
org.apache.shardingsphere.data.pipeline.core.importer.ImporterConfiguration Line
columnName case-insensitive? 48
Remove concurrency 59
org.apache.shardingsphere.data.pipeline.core.importer.sink.type.PipelineDataSourceSink Line
There to be compatible with PostgreSQL before value is null except primary key and unsupported updating sharding value now. 199
if table without unique key the conditionColumns before values is null, so update will fail at PostgreSQL 206
org.apache.shardingsphere.data.pipeline.core.ingest.position.type.pk.PrimaryKeyIngestPositionFactory Line
support more types, e.g. byte[] (MySQL varbinary) 77
org.apache.shardingsphere.data.pipeline.core.ingest.record.group.DataRecordGroupEngine Line
Compatible with multiple unique indexes 143
org.apache.shardingsphere.data.pipeline.core.job.JobStatus Line
rename to SUCCESS 50
Remove unused field; Remove unused enum 76
org.apache.shardingsphere.data.pipeline.core.job.progress.ConsistencyCheckJobItemProgress Line
Refactor structure, List<TableProgress> 35
org.apache.shardingsphere.data.pipeline.core.job.progress.yaml.swapper.YamlJobItemIncrementalTasksProgressSwapper Line
consider to remove parameter databaseType 64
org.apache.shardingsphere.data.pipeline.core.listener.PipelineContextManagerLifecycleListener Line
When StandalonePersistRepository is equivalent with ClusterPersistRepository, use STANDALONE mode in pipeline IT and remove this check. 57
org.apache.shardingsphere.data.pipeline.core.listener.PipelineElasticJobListener Line
ElasticJobListenerFactory.createListener return new class instance, it's the reason why static variables 33
org.apache.shardingsphere.data.pipeline.core.metadata.generator.PipelineDDLGenerator Line
remove it after set search_path is supported. 99
remove it after set search_path is supported. 176
org.apache.shardingsphere.data.pipeline.core.metadata.loader.StandardPipelineTableMetaDataLoader Line
order primary keys 142
org.apache.shardingsphere.data.pipeline.core.metadata.model.PipelineTableMetaData Line
Remove it. Get column meta data by column name for incremental dumper, since columns ordering might be changed. 76
org.apache.shardingsphere.data.pipeline.core.preparer.inventory.InventoryTaskSplitter Line
Support string unique key table splitting. Ascii characters ordering are different in different versions of databases. 177
org.apache.shardingsphere.data.pipeline.core.registrycenter.elasticjob.CoordinatorRegistryCenterInitializer Line
Add registry center cache. Refer to RegistryCenterFactory.createCoordinatorRegistryCenter 44
Merge registry center code in ElasticJob and ShardingSphere mode; Use SPI to load impl 51
org.apache.shardingsphere.data.pipeline.migration.distsql.statement.pojo.SourceTargetEntry Line
Remove targetDatabaseName, or keep it but rebuild it 33
org.apache.shardingsphere.data.pipeline.mysql.ingest.GlobalTableMapEventMapping Line
Still save in memory, if proxy restart, the data will be lost. 33
org.apache.shardingsphere.data.pipeline.mysql.ingest.client.netty.MySQLBinlogEventPacketDecoder Line
May be used again later, keep this method first. 271
org.apache.shardingsphere.data.pipeline.mysql.ingest.client.netty.MySQLNegotiateHandler Line
not support sha256_password now 103
org.apache.shardingsphere.data.pipeline.opengauss.ingest.OpenGaussIngestPositionManager Line
reuse PostgreSQLIngestPositionManager 39
org.apache.shardingsphere.data.pipeline.opengauss.sqlbuilder.OpenGaussPipelineSQLBuilder Line
use ";" to split is not always correct 72
org.apache.shardingsphere.data.pipeline.postgresql.ingest.PostgreSQLWALDumper Line
use unified PgConnection 114
org.apache.shardingsphere.data.pipeline.postgresql.ingest.wal.WALEventConverter Line
completion columns 110
Unique key may be a column within unique index 112
org.apache.shardingsphere.data.pipeline.postgresql.sqlbuilder.PostgreSQLPipelineSQLBuilder Line
without unique key, job has been interrupted, which may lead to data duplication 51
support partitions etc. 75
use ";" to split is not always correct 84
org.apache.shardingsphere.data.pipeline.scenario.migration.api.MigrationJobAPI Line
use origin database name now, wait reloadDatabaseMetaData fix case-sensitive probelm 288
org.apache.shardingsphere.db.protocol.mysql.packet.binlog.management.MySQLBinlogFormatDescriptionEventPacket Line
--No comment-- 79
org.apache.shardingsphere.db.protocol.mysql.packet.binlog.row.MySQLBinlogRowsEventPacket Line
--No comment-- 114
org.apache.shardingsphere.db.protocol.mysql.packet.binlog.row.MySQLBinlogTableMapEventPacket Line
--No comment-- 115
org.apache.shardingsphere.db.protocol.mysql.packet.command.query.binary.prepare.MySQLComStmtPrepareOKPacket Line
Column Definition Block should be added in future when the meta data of the columns is cached. 46
org.apache.shardingsphere.db.protocol.mysql.payload.MySQLPacketPayload Line
--No comment-- 132
--No comment-- 311
--No comment-- 321
org.apache.shardingsphere.db.protocol.opengauss.codec.OpenGaussPacketCodecEngine Line
consider what severity to use 121
org.apache.shardingsphere.db.protocol.postgresql.codec.PostgreSQLPacketCodecEngine Line
consider what severity to use 119
org.apache.shardingsphere.db.protocol.postgresql.packet.command.query.extended.PostgreSQLColumnType Line
Temporary solution for https://github.com/apache/shardingsphere/issues/22522 196
org.apache.shardingsphere.distsql.handler.engine.update.rdl.rule.engine.database.type.DropDatabaseRuleOperator Line
refactor to new metadata refresh way 60
org.apache.shardingsphere.distsql.handler.engine.update.rdl.rule.spi.database.DatabaseRuleAlterExecutor Line
Remove temporary default implementation Build to be dropped rule configuration. 42
org.apache.shardingsphere.distsql.handler.engine.update.rdl.rule.spi.database.DatabaseRuleDropExecutor Line
Remove temporary default implementation Build to be dropped rule configuration. 34
org.apache.shardingsphere.driver.jdbc.adapter.AbstractStatementAdapter Line
Confirm MaxRows for multiple databases is need special handle. eg: 10 statements maybe MaxRows / 10 129
org.apache.shardingsphere.driver.jdbc.core.connection.ShardingSphereConnection Line
Support single DataSource scenario for now. Implement ShardingSphereCallableStatement to support multi DataSource scenarios. 140
Support single DataSource scenario for now. Implement ShardingSphereCallableStatement to support multi DataSource scenarios. 146
Support single DataSource scenario for now. Implement ShardingSphereCallableStatement to support multi DataSource scenarios. 152
return databaseName for now in getSchema(), the same as before 305
org.apache.shardingsphere.driver.jdbc.core.datasource.metadata.ShardingSphereDatabaseMetaData Line
consider get actual catalog by logic catalog rather than random physical datasource's catalog. 233
consider get actual schema by logic catalog rather than random physical datasource's schema. 243
org.apache.shardingsphere.driver.jdbc.core.resultset.ShardingSphereResultSet Line
To be supported: encrypt, mask, and so on 303
org.apache.shardingsphere.driver.jdbc.core.statement.ShardingSpherePreparedStatement Line
add raw SQL executor 682
org.apache.shardingsphere.driver.state.lock.LockDriverState Line
--No comment-- 33
org.apache.shardingsphere.encrypt.merge.dal.show.EncryptShowCreateTableMergedResult Line
decorate encrypt column index when we support index rewrite 85
org.apache.shardingsphere.encrypt.rewrite.token.pojo.EncryptAlterTableToken Line
refactor alter table token 48
org.apache.shardingsphere.encrypt.rule.changed.EncryptTableChangedProcessor Line
refactor DistSQL to only persist config 59
org.apache.shardingsphere.infra.algorithm.core.exception.AlgorithmExecuteException Line
It is runnable exception, consider about move out from AlgorithmDefinitionException 26
org.apache.shardingsphere.infra.algorithm.core.exception.InvalidAlgorithmConfigurationException Line
consider about merge with AlgorithmInitializationException 25
org.apache.shardingsphere.infra.binder.context.segment.select.pagination.PaginationContext Line
handle offsetSegment instance of ExpressionRowNumberValueSegment 114
handle offsetSegment instance of ExpressionRowNumberValueSegment 124
org.apache.shardingsphere.infra.binder.context.segment.select.projection.engine.ProjectionEngine Line
replace avg to constant, avoid calculate useless avg 137
org.apache.shardingsphere.infra.binder.context.segment.select.projection.util.ProjectionUtils Line
support postgresql subquery projection 114
org.apache.shardingsphere.infra.binder.context.statement.dal.ExplainStatementContext Line
extract table from declare, execute, createMaterializedView, refreshMaterializedView 51
org.apache.shardingsphere.infra.binder.segment.expression.ExpressionSegmentBinder Line
support more ExpressionSegment bind 86
org.apache.shardingsphere.infra.binder.segment.from.impl.SimpleTableSegmentBinder Line
getSchemaName according to search path 110
org.apache.shardingsphere.infra.binder.segment.from.impl.SubqueryTableSegmentBinder Line
add database and schema in ColumnSegmentBoundedInfo 94
org.apache.shardingsphere.infra.binder.segment.parameter.ParameterMarkerSegmentBinder Line
support more ParameterMarkerSegment bind 56
org.apache.shardingsphere.infra.binder.segment.projection.ProjectionsSegmentBinder Line
support more ProjectionSegment bind 86
org.apache.shardingsphere.infra.binder.segment.with.CommonTableExpressionSegmentBinder Line
bind with columns 48
org.apache.shardingsphere.infra.binder.statement.dml.MergeStatementBinder Line
bind parameter marker segments for merge statement 103
org.apache.shardingsphere.infra.binder.statement.dml.SelectStatementBinder Line
support other segment bind in select statement 64
org.apache.shardingsphere.infra.database.core.metadata.database.DialectDatabaseMetaData Line
Reuse java.sql.DatabaseMetaData.nullsAreSortedHigh and java.sql.DatabaseMetaData.nullsAreSortedLow 58
Reuse java.sql.DatabaseMetaData.getSQLKeywords 67
org.apache.shardingsphere.infra.database.opengauss.metadata.data.loader.OpenGaussMetaDataLoader Line
user defined collation which deterministic is false 172
org.apache.shardingsphere.infra.database.oracle.metadata.data.loader.OracleMetaDataLoader Line
need to support caseSensitive when version < 12.2. 146
The table name needs to be in uppercase, otherwise the index cannot be found. 221
org.apache.shardingsphere.infra.database.postgresql.metadata.data.loader.PostgreSQLMetaDataLoader Line
user defined collation which deterministic is false 203
org.apache.shardingsphere.infra.datanode.DataNode Line
add final for schemaName 51
remove duplicated splitting? 60
org.apache.shardingsphere.infra.executor.kernel.model.ExecutionGroupReportContext Line
processID should same with connectionId 31
org.apache.shardingsphere.infra.executor.sql.execute.engine.driver.jdbc.JDBCExecutorCallback Line
It is better to judge whether need sane result before execute, can avoid exception thrown 61
org.apache.shardingsphere.infra.executor.sql.execute.engine.raw.RawExecutor Line
Load query header for first query 60
org.apache.shardingsphere.infra.executor.sql.execute.result.query.type.memory.AbstractMemoryQueryResult Line
Support connection property character encoding 107
org.apache.shardingsphere.infra.expr.espresso.ReflectContext Line
<a href="https://github.com/oracle/graal/issues/4555">oracle/graal#4555</a> not yet closed. Maybe sometimes shardingsphere need `.option("java.Properties.org.graalvm.home", System.getenv("JAVA_HOME")). 43
org.apache.shardingsphere.infra.merge.result.impl.memory.MemoryMergedResult Line
implement with calendar 85
org.apache.shardingsphere.infra.metadata.caseinsensitive.CaseInsensitiveIdentifier Line
table name case-sensitive for some database 26
org.apache.shardingsphere.infra.metadata.caseinsensitive.CaseInsensitiveQualifiedTable Line
should merge with QualifiedTable 30
org.apache.shardingsphere.infra.metadata.database.schema.reviser.MetaDataReviseEngine Line
establish a corresponding relationship between tables and data sources 51
org.apache.shardingsphere.infra.rewrite.engine.RouteSQLRewriteEngineTest Line
check why data node is "ds.tbl_0", not "ds_0.tbl_0" 147
org.apache.shardingsphere.infra.route.engine.SQLRouteEngine Line
use dynamic config to judge unconfigured schema 62
org.apache.shardingsphere.infra.rule.builder.database.DatabaseRulesBuilder Line
consider about order for new put items 131
org.apache.shardingsphere.infra.util.yaml.YamlConfiguration Line
Only global.yaml and database.yaml handle empty YAML file currently.Other scenarios reading YAML files should also consider overriding this method to check for empty files. 31
org.apache.shardingsphere.infra.yaml.data.swapper.YamlShardingSphereRowDataSwapper Line
use general type convertor 59
use general type convertor 88
org.apache.shardingsphere.mask.rule.changed.MaskTableChangedProcessor Line
refactor DistSQL to only persist config 58
org.apache.shardingsphere.metadata.persist.data.ShardingSphereDataBasedPersistService Line
replace the old implementation after meta data refactor completed ShardingSphere data based registry service. 30
org.apache.shardingsphere.metadata.persist.service.schema.TableRowDataBasedPersistService Line
replace the old implementation after meta data refactor completed Schema meta data persist service. 27
org.apache.shardingsphere.mode.manager.cluster.coordinator.registry.process.subscriber.ProcessListChangedSubscriber Line
replace the old ProcessListChangedSubscriber after meta data refactor completed New process list changed subscriber. 40
org.apache.shardingsphere.mode.manager.cluster.coordinator.subscriber.StateChangedSubscriber Line
labels may be empty 120
org.apache.shardingsphere.mode.metadata.MetaDataContexts Line
can `protocolType instanceof SchemaSupportedDatabaseType ? "PostgreSQL" : protocolType.getType()` replace to trunk database type? 65
org.apache.shardingsphere.mode.metadata.MetaDataContextsFactory Line
load global data sources from persist service 92
org.apache.shardingsphere.mode.repository.cluster.etcd.EtcdRepository Line
--No comment-- 116
org.apache.shardingsphere.mode.repository.cluster.zookeeper.ZookeeperRepository Line
wait 500ms, close cache before close client, or will throw exception Because of asynchronous processing, may cause client to close first and cache has not yet closed the end. Wait for new version of Curator to fix this. BUG address: https://issues.apache.org/jira/browse/CURATOR-157 275
org.apache.shardingsphere.mode.repository.standalone.jdbc.JDBCRepository Line
remove it later. Add for reset standalone test e2e's env. Need to close DataSource to release H2's memory data 69
org.apache.shardingsphere.mode.subsciber.RuleItemChangedSubscriber Line
Remove isCluster judgment 58
Remove isCluster judgment 83
org.apache.shardingsphere.proxy.backend.config.ProxyConfigurationLoader Line
remove COMPATIBLE_GLOBAL_CONFIG_FILE in next major version 58
remove COMPATIBLE_DATABASE_CONFIG_FILE_PATTERN in next major version 67
org.apache.shardingsphere.proxy.backend.config.ProxyConfigurationLoaderTest Line
assert mode 61
assert authority rule 62
org.apache.shardingsphere.proxy.backend.connector.ProxySQLExecutor Line
implement DDL statement commit/rollback in PostgreSQL/openGauss transaction 131
handle query header 200
org.apache.shardingsphere.proxy.backend.handler.ProxyBackendHandlerFactoryTest Line
--No comment-- 170
org.apache.shardingsphere.proxy.backend.handler.distsql.ral.updatable.UnlockClusterExecutor Line
unlock snapshot info if locked 47
org.apache.shardingsphere.proxy.backend.handler.distsql.rul.PreviewExecutor Line
move dialect MySQLInsertStatement into database type module @zhangliang 130
org.apache.shardingsphere.proxy.backend.handler.transaction.TransactionXAHandler Line
Currently XA transaction started with `XA START` doesn't support for database with multiple datasource, a flag should be added for this both in init progress and add datasource from DistSQL. 46
org.apache.shardingsphere.proxy.backend.hbase.converter.type.HBaseSelectOperationConverter Line
consider about other dialect 126
org.apache.shardingsphere.proxy.backend.mysql.handler.admin.MySQLAdminExecutorCreator Line
remove DefaultDatabaseMetaDataExecutor when sql federation can support all system table query 163
org.apache.shardingsphere.proxy.backend.mysql.handler.admin.executor.sysvar.MySQLSystemVariable Line
Get or set session value. 78
Properly handling character set of session. 147
Retrieve proper system time zone. 934
org.apache.shardingsphere.proxy.backend.mysql.response.header.query.MySQLQueryHeaderBuilder Line
to be confirmed, QueryHeaderBuilder should not has default value, just throw unsupported exception if database type missing 77
org.apache.shardingsphere.proxy.backend.session.RequiredSessionVariableRecorder Line
Refactor the following switch by SPI if we support more database in future 68
Refactor the following switch by SPI if we support more database in future 105
org.apache.shardingsphere.proxy.frontend.mysql.authentication.authenticator.MySQLAuthenticatorType Line
impl OLD_PASSWORD Authenticator 33
impl WINDOWS_NATIVE Authenticator 40
impl SHA256 Authenticator 43
org.apache.shardingsphere.proxy.frontend.mysql.command.query.binary.prepare.MySQLComStmtPrepareExecutor Line
Multi statements should be identified by SQL Parser instead of checking if sql contains ";". 96
Calculate column definition flag for other projection types 154
org.apache.shardingsphere.proxy.frontend.mysql.command.query.binary.prepare.MySQLComStmtPrepareParameterMarkerExtractor Line
Support more statements and syntax. Find corresponding columns of parameter markers. 44
org.apache.shardingsphere.proxy.frontend.mysql.command.query.text.query.MySQLComQueryPacketExecutor Line
Multi statements should be identified by SQL Parser instead of checking if sql contains ";". 71
org.apache.shardingsphere.proxy.frontend.mysql.command.query.text.query.MySQLMultiStatementsHandler Line
Multi statements should be split by SQL Parser instead of simple regexp. 115
Each logic SQL should correspond to an OK Packet. 200
org.apache.shardingsphere.proxy.frontend.netty.CDCChannelInboundHandler Line
add CDC exception to wrapper this exception, and add the parameters requestId and whether to close connect 94
org.apache.shardingsphere.proxy.frontend.netty.FrontendChannelLimitationInboundHandler Line
This is not how actual databases does and should be refactored. 44
org.apache.shardingsphere.proxy.frontend.postgresql.authentication.PostgreSQLAuthenticationEngine Line
implement PostgreSQLServerInfo like MySQLServerInfo 111
org.apache.shardingsphere.proxy.frontend.postgresql.authentication.authenticator.PostgreSQLAuthenticatorType Line
impl SCRAM_SHA256 Authenticator 37
org.apache.shardingsphere.proxy.frontend.postgresql.command.generic.PostgreSQLUnsupportedCommandExecutor Line
consider what severity and error code to use 38
org.apache.shardingsphere.readwritesplitting.distsql.handler.query.ShowStatusFromReadwriteSplittingRulesExecutorTest Line
Replace With DistSQLQueryExecuteEngine 41
org.apache.shardingsphere.readwritesplitting.rule.changed.ReadwriteSplittingDataSourceChangedProcessor Line
refactor DistSQL to only persist config 69
org.apache.shardingsphere.shadow.route.ShadowSQLRouter Line
--No comment-- 41
org.apache.shardingsphere.shadow.route.engine.impl.ShadowNonDMLStatementRoutingEngine Line
use SQLHintUtil to parse SQL comments and remove hint in sql 63
org.apache.shardingsphere.shadow.rule.changed.ShadowDataSourceChangedProcessor Line
refactor DistSQL to only persist config 51
org.apache.shardingsphere.sharding.cache.route.cache.ShardingRouteCacheValue Line
This could be simplified if all fields of DataNode were immutable 68
Implements deep copy for route stage contexts 88
org.apache.shardingsphere.sharding.merge.dql.groupby.aggregation.AverageAggregationUnit Line
use metadata to fetch float number precise for database field 56
org.apache.shardingsphere.sharding.merge.dql.groupby.aggregation.DistinctAverageAggregationUnit Line
use metadata to fetch float number precise for database field 64
org.apache.shardingsphere.sharding.route.engine.ShardingSQLRouter Line
--No comment-- 92
org.apache.shardingsphere.sharding.route.engine.condition.engine.WhereClauseShardingConditionEngine Line
remove startIndex when federation has perfect support for subquery 102
org.apache.shardingsphere.sharding.route.engine.type.ShardingRouteEngineFactory Line
remove this logic when jdbc adapter can support executing create logic view 131
add dropResourceGroupStatement, alterResourceGroupStatement 188
config for cartesian set 229
org.apache.shardingsphere.sharding.route.engine.type.standard.SQLRouteTest Line
add assertion for ShardingRouteAssert.assertRoute 37
org.apache.shardingsphere.sharding.route.engine.type.standard.SubqueryRouteTest Line
add assertion for ShardingRouteAssert.assertRoute 34
org.apache.shardingsphere.sharding.route.engine.validator.ddl.impl.ShardingDropTableStatementValidator Line
check actual tables not be used in multi rules, and remove this check logic 85
org.apache.shardingsphere.sharding.yaml.swapper.ShardingRuleConfigurationConverter Line
Move to pipeline module 32
org.apache.shardingsphere.single.distsql.statement.rql.ShowUnloadedSingleTableStatement Line
support like later 35
org.apache.shardingsphere.single.route.engine.SingleRouteEngineFactory Line
move this logic to common route logic 48
org.apache.shardingsphere.sql.parser.mysql.visitor.format.MySQLFormatVisitorIT Line
fix only comment parse Arguments.of("only_comment", "/* c_zz_xdba_test_4 login */", "", ""), 115
org.apache.shardingsphere.sql.parser.mysql.visitor.statement.MySQLStatementVisitor Line
deal with TemporalLiterals 303
deal with hexadecimalLiterals 309
deal with bitValueLiterals 315
optimize operatorToken 440
FIXME, sql case id: insert_with_str_to_date 1277
FIXME, since there is no segment for insertValuesClause, InsertStatement is created by sub rule. 1363
FIXME, since there is no segment for replaceValuesClause, ReplaceStatement is created by sub rule. 1438
org.apache.shardingsphere.sql.parser.mysql.visitor.statement.type.MySQLDALStatementVisitor Line
Consider setting all three system variables: character_set_client, character_set_results, character_set_connection 939
Consider setting all three system variables: character_set_client, character_set_results, character_set_connection 978
org.apache.shardingsphere.sql.parser.mysql.visitor.statement.type.MySQLDDLStatementVisitor Line
parse not null 354
parse not null 575
org.apache.shardingsphere.sql.parser.opengauss.visitor.statement.OpenGaussStatementVisitor Line
replace aggregation segment 444
FIXME, since there is no segment for insertValuesClause, InsertStatement is created by sub rule. 695
deal with insert select 696
Unsupported for withClause. 925
deal with functionTable and xmlTable 1195
org.apache.shardingsphere.sql.parser.opengauss.visitor.statement.type.OpenGaussDALStatementVisitor Line
visit declare statement 165
visit create materialized view statement 172
visit refresh materialized view statement 175
org.apache.shardingsphere.sql.parser.opengauss.visitor.statement.type.OpenGaussDDLStatementVisitor Line
parse not null 447
visit pk and table ref 487
org.apache.shardingsphere.sql.parser.oracle.visitor.statement.OracleStatementVisitor Line
deal with hexadecimalLiterals 286
deal with bitValueLiterals 292
throw exception if more than one defaultString exists in a xml name space clause 935
FIXME, sql case id: insert_with_str_to_date 1176
org.apache.shardingsphere.sql.parser.oracle.visitor.statement.type.OracleDDLStatementVisitor Line
More alter definition parse 580
Support rename constraint 608
handle no columnDefinition and multiple columnDefinitions 645
visit pk and reference table 673
handle SQL in dynamicString 1506
visit collection_method_call 1535
Handling dynamicSqlStmt if we can 1625
Visit intoClause 1631
org.apache.shardingsphere.sql.parser.oracle.visitor.statement.type.OracleDMLStatementVisitor Line
FIXME, since there is no segment for insertValuesClause, InsertStatement is created by sub rule. 308
Visit selectIntoClause, bulkCollectIntoClause 434
Visit hierarchicalQueryClause 442
Visit windowClause 446
Visit rowLimitingClause 450
org.apache.shardingsphere.sql.parser.postgresql.visitor.statement.PostgreSQLStatementVisitor Line
replace aggregation segment 444
FIXME, since there is no segment for insertValuesClause, InsertStatement is created by sub rule. 695
deal with insert select 696
Unsupported for withClause. 895
deal with functionTable and xmlTable 1169
org.apache.shardingsphere.sql.parser.postgresql.visitor.statement.type.PostgreSQLDALStatementVisitor Line
visit declare statement 172
visit refresh materialized view statement 181
org.apache.shardingsphere.sql.parser.postgresql.visitor.statement.type.PostgreSQLDDLStatementVisitor Line
parse not null 560
visit pk and table ref 600
org.apache.shardingsphere.sql.parser.sql.common.segment.dml.expr.TypeCastExpression Line
Parse data type after https://github.com/apache/shardingsphere/issues/23466 fixed 39
org.apache.shardingsphere.sql.parser.sql.common.segment.dml.pagination.top.TopProjectionSegment Line
return column label according to database result 42
org.apache.shardingsphere.sql.parser.sql.common.util.ExpressionExtractUtils Line
support more expression type if necessary 126
org.apache.shardingsphere.sql.parser.sql.common.value.literal.impl.NumberLiteralValue Line
make sure with double and float 42
org.apache.shardingsphere.sql.parser.sql92.visitor.statement.SQL92StatementVisitor Line
deal with hexadecimalLiterals 155
deal with bitValueLiterals 161
FIXME, sql case id: insert_with_str_to_date 510
org.apache.shardingsphere.sql.parser.sql92.visitor.statement.type.SQL92DDLStatementVisitor Line
parse not null 105
visit pk and table ref 202
org.apache.shardingsphere.sql.parser.sql92.visitor.statement.type.SQL92DMLStatementVisitor Line
Unsupported for withClause. 210
Unsupported for union SQL. 218
org.apache.shardingsphere.sql.parser.sqlserver.visitor.statement.SQLServerStatementVisitor Line
deal with hexadecimalLiterals 298
deal with bitValueLiterals 304
FIXME, sql case id: insert_with_str_to_date 895
Unsupported for union | except | intersect SQL. 966
org.apache.shardingsphere.sql.parser.sqlserver.visitor.statement.type.SQLServerDDLStatementVisitor Line
parse not null 168
visit pk and table ref 287
org.apache.shardingsphere.sqlfederation.engine.SQLFederationEngine Line
BEGIN: move this logic to SQLFederationDecider implement class when we remove sql federation type 132
END 136
open useCache flag when ShardingSphereTable contains version 202
replace DEFAULT_METADATA_VERSION with actual version in ShardingSphereTable 229
register only the required tables 244
org.apache.shardingsphere.sqlfederation.executor.enumerable.EnumerableScanExecutor Line
pass grantee from proxy and jdbc adapter 132
org.apache.shardingsphere.sqlfederation.executor.utils.StatisticsAssembleUtils Line
move this logic to ShardingSphere statistics 50
org.apache.shardingsphere.sqlfederation.optimizer.context.OptimizerContextFactory Line
consider to use sqlParserRule in global rule 49
org.apache.shardingsphere.sqlfederation.optimizer.context.parser.dialect.impl.H2OptimizerBuilder Line
No suitable type of Lex 36
org.apache.shardingsphere.sqlfederation.optimizer.converter.segment.expression.ExpressionConverter Line
--No comment-- 92
org.apache.shardingsphere.sqlfederation.optimizer.converter.segment.expression.impl.FunctionConverter Line
optimize sql parse logic for select current_user. 57
org.apache.shardingsphere.sqlfederation.optimizer.converter.segment.projection.ProjectionsConverter Line
process other projection 83
org.apache.shardingsphere.sqlfederation.optimizer.metadata.schema.SQLFederationSchema Line
implement table statistic logic after using custom operators 59
org.apache.shardingsphere.sqlfederation.optimizer.operator.physical.EnumerableModify Line
generate modification statements based on dataset and related table information. 49
org.apache.shardingsphere.sqlfederation.optimizer.planner.cache.ExecutionPlanCacheKey Line
replace sql with parameterized sql 37
org.apache.shardingsphere.sqlfederation.optimizer.planner.util.SQLFederationPlannerUtils Line
remove withRemoveSortInSubQuery when calcite can expand view which contains order by correctly 250
org.apache.shardingsphere.sqlfederation.resultset.SQLFederationResultSet Line
implement with calendar 476
org.apache.shardingsphere.sqltranslator.natived.NativeSQLTranslator Line
--No comment-- 37
org.apache.shardingsphere.test.e2e.container.compose.ContainerComposerRegistry Line
cluster mode often throw exception sometimes, issue is #15517 67
org.apache.shardingsphere.test.e2e.container.compose.mode.ClusterContainerComposer Line
support other types of governance 56
add more version of databases 58
org.apache.shardingsphere.test.e2e.container.compose.mode.StandaloneContainerComposer Line
add more version of databases 50
org.apache.shardingsphere.test.e2e.data.pipeline.cases.PipelineContainerComposer Line
Use registerStorageUnit instead, and remove the method, keep it now 257
use DAO to query via DistSQL 504
proxy support for some fields still needs to be optimized, such as binary of MySQL, after these problems are optimized, Proxy dataSource can be used. 595
org.apache.shardingsphere.test.e2e.data.pipeline.cases.cdc.CDCE2EIT Line
add full=false test case later 179
org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.AbstractMigrationE2EIT Line
Need to add after the stop then to start, can continue the consistency check from the previous progress 159
org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.primarykey.IndexesMigrationE2EIT Line
PostgreSQL update delete events not support if table without unique keys at increment task. 96
Insert binary string in VARBINARY column. But KeyGenerateAlgorithm.generateKey() require returning Comparable, and byte[] is not Comparable 223
Select by byte[] from proxy doesn't work, so unhex function is used for now 227
org.apache.shardingsphere.test.e2e.data.pipeline.cases.migration.primarykey.MariaDBMigrationE2EIT Line
Use MariaDB docker image 47
org.apache.shardingsphere.test.e2e.data.pipeline.cases.task.E2EIncrementalTask Line
0000-00-00 00:00:00 now will cause consistency check failed of MySQL. DataSourceUtil.execute(dataSource, String.format("UPDATE %s SET t_datetime='0000-00-00 00:00:00' WHERE order_id = ?", orderTableName) 95
org.apache.shardingsphere.test.e2e.data.pipeline.framework.param.PipelineTestParameter Line
It's not scenario. Remove it later 34
org.apache.shardingsphere.test.e2e.driver.AbstractDriverTest Line
merge in to sql-e2e 34
org.apache.shardingsphere.test.e2e.engine.arg.E2ETestCaseArgumentsProvider Line
make sure test case can not be null 47
make sure test case can not be null 53
org.apache.shardingsphere.test.e2e.engine.type.DALE2EIT Line
make sure test case can not be null 56
org.apache.shardingsphere.test.e2e.engine.type.DCLE2EIT Line
make sure test case can not be null 47
make sure test case can not be null 78
org.apache.shardingsphere.test.e2e.engine.type.DDLE2EIT Line
make sure test case can not be null 64
make sure test case can not be null 99
org.apache.shardingsphere.test.e2e.engine.type.RALE2EIT Line
make sure test case can not be null 58
org.apache.shardingsphere.test.e2e.engine.type.RDLE2EIT Line
make sure test case can not be null 58
org.apache.shardingsphere.test.e2e.engine.type.RQLE2EIT Line
make sure test case can not be null 53
org.apache.shardingsphere.test.e2e.engine.type.dml.AdditionalDMLE2EIT Line
make sure test case can not be null 50
support oracle insert statement return auto generated keys 68
--No comment-- 98
--No comment-- 133
make sure test case can not be null 172
make sure test case can not be null 211
--No comment-- 250
--No comment-- 287
org.apache.shardingsphere.test.e2e.engine.type.dml.BaseDMLE2EIT Line
make sure test case can not be null 81
org.apache.shardingsphere.test.e2e.engine.type.dml.BatchDMLE2EIT Line
make sure test case can not be null 48
make sure test case can not be null 81
org.apache.shardingsphere.test.e2e.engine.type.dml.GeneralDMLE2EIT Line
make sure test case can not be null 48
make sure test case can not be null 82
org.apache.shardingsphere.test.e2e.engine.type.dql.AdditionalDQLE2EIT Line
make sure test case can not be null 50
fix e2e test blocked exception with PostgreSQL or openGuass in #23643 56
make sure test case can not be null 71
fix e2e test blocked exception with PostgreSQL or openGuass in #23643 77
make sure test case can not be null 92
fix e2e test blocked exception with PostgreSQL or openGuass in #23643 98
make sure test case can not be null 113
fix e2e test blocked exception with PostgreSQL or openGuass in #23643 119
Fix jdbc adapter 136
Fix jdbc adapter 196
org.apache.shardingsphere.test.e2e.engine.type.dql.BaseDQLE2EIT Line
Since mysql 8.0.23, for the DATETIME type, the mysql driver returns the LocalDateTime type, but the proxy returns the Timestamp type. 178
org.apache.shardingsphere.test.e2e.engine.type.dql.GeneralDQLE2EIT Line
make sure test case can not be null 52
Fix jdbc adapter and empty_storage_units proxy adapter 69
make sure test case can not be null 126
Fix jdbc adapter 143
org.apache.shardingsphere.test.e2e.env.DataSetEnvironmentManager Line
ExecutorEngine.execute and callback 62
org.apache.shardingsphere.test.e2e.env.container.atomic.adapter.impl.ShardingSphereJdbcContainer Line
process more types 93
org.apache.shardingsphere.test.e2e.showprocesslist.engine.ShowProcessListE2EIT Line
add jdbc 49
org.apache.shardingsphere.test.e2e.transaction.cases.autocommit.MySQLAutoCommitTestCase Line
Currently XA transaction does not support two transactions in the same thread at the same time 53
org.apache.shardingsphere.test.e2e.transaction.cases.cursor.OpenGaussCursorTestCase Line
fix #25236 63
org.apache.shardingsphere.test.e2e.transaction.cases.savepoint.PostgreSQLSavePointTestCase Line
can not run to get the correct result in JDBC mode. 64
can not run to get the correct result in JDBC mode. 71
org.apache.shardingsphere.test.e2e.transaction.cases.truncate.MySQLXATruncateTestCase Line
This test case may cause bad effects to other test cases in JDBC adapter 63
org.apache.shardingsphere.test.e2e.transaction.engine.base.TransactionBaseE2EIT Line
zhangcheng make sure the test cases should not empty 348
org.apache.shardingsphere.test.e2e.transaction.env.TransactionE2EEnvironment Line
this should extract into a constant 162
this should extract into a constant 172
org.apache.shardingsphere.test.it.data.pipeline.core.task.InventoryTaskTest Line
use t_order_0, and also others 76
org.apache.shardingsphere.test.it.data.pipeline.core.util.JobConfigurationBuilder Line
Rename createJobConfiguration 56
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.segment.assignment.AssignmentAssert Line
assert assign operator 55
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.statement.dal.impl.mysql.MySQLUseStatementAssert Line
create a new assert class named `SchemaAssert` 44
extract and assert start index, stop index, start delimiter and end delimiter 45
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.statement.ddl.impl.AlterIndexStatementAssert Line
should assert index for all databases(mysql and sqlserver do not parse index right now) 65
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.statement.ddl.impl.CreateIndexStatementAssert Line
should assert index for all databases(mysql and sqlserver do not parse index right now) 69
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.statement.ddl.impl.DropIndexStatementAssert Line
should assert index for all databases(mysql and sqlserver do not parse index right now) 70
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.statement.ral.impl.pipeline.QueryablePipelineRALStatementAssert Line
add more test case 54
org.apache.shardingsphere.test.it.sql.parser.internal.asserts.statement.ral.impl.pipeline.UpdatablePipelineRALStatementAssert Line
add more test case 75
org.apache.shardingsphere.test.natived.jdbc.commons.repository.OrderRepository Line
There is a bug in this function in shadow's unit test and requires additional fixes. 96
org.apache.shardingsphere.test.natived.jdbc.modes.cluster.EtcdTest Line
On low-performance devices in Github Actions, `INSERT` related SQLs may throw a table not found error under nativeTest. So that we need to wait for a period of time after executing `CREATE TABLE` related SQLs before executing `INSERT` related SQLs. This may mean that the implementation of {@link org.apache.shardingsphere.mode.repository.cluster.etcd.EtcdRepository} needs optimization. 53
org.apache.shardingsphere.test.natived.jdbc.modes.cluster.ZookeeperTest Line
On low-performance devices in Github Actions, `INSERT` related SQLs may throw a table not found error under nativeTest. So that we need to wait for a period of time after executing `CREATE TABLE` related SQLs before executing `INSERT` related SQLs. This may mean that the implementation of {@link org.apache.shardingsphere.mode.repository.cluster.zookeeper.ZookeeperRepository} needs optimization. 46
org.apache.shardingsphere.transaction.rule.TransactionRule Line
Consider shutting down the transaction manager gracefully 106