Checkstyle Results

The following document contains the results of Checkstyle 9.3 with /home/runner/work/shardingsphere-doc/shardingsphere-doc/shardingsphere/src/resources/checkstyle.xml ruleset.

Summary

Files  Info  Warnings  Errors
7910 0 673 0

Files

File  I  W  E
org/apache/shardingsphere/agent/plugin/metrics/core/advice/SQLParseCountAdviceTest.java 0 1 0
org/apache/shardingsphere/agent/plugin/metrics/core/advice/SQLRouteCountAdviceTest.java 0 1 0
org/apache/shardingsphere/agent/plugin/metrics/prometheus/PrometheusPluginLifecycleServiceTest.java 0 1 0
org/apache/shardingsphere/agent/plugin/tracing/opentelemetry/advice/OpenTelemetryJDBCExecutorCallbackAdviceTest.java 0 1 0
org/apache/shardingsphere/broadcast/route/BroadcastSQLRouter.java 0 3 0
org/apache/shardingsphere/broadcast/route/BroadcastSqlRouterTest.java 0 2 0
org/apache/shardingsphere/broadcast/route/engine/BroadcastRouteEngineFactory.java 0 1 0
org/apache/shardingsphere/data/pipeline/cdc/CDCJob.java 0 2 0
org/apache/shardingsphere/data/pipeline/cdc/api/CDCJobAPI.java 0 2 0
org/apache/shardingsphere/data/pipeline/cdc/client/CDCClient.java 0 1 0
org/apache/shardingsphere/data/pipeline/cdc/client/util/ProtobufAnyValueConverter.java 0 2 0
org/apache/shardingsphere/data/pipeline/cdc/core/prepare/CDCJobPreparer.java 0 2 0
org/apache/shardingsphere/data/pipeline/cdc/distsql/parser/core/CDCDistSQLStatementVisitor.java 0 1 0
org/apache/shardingsphere/data/pipeline/cdc/handler/CDCBackendHandler.java 0 2 0
org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtils.java 0 3 0
org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtilsTest.java 0 2 0
org/apache/shardingsphere/data/pipeline/core/consistencycheck/ConsistencyCheckDataBuilder.java 0 2 0
org/apache/shardingsphere/data/pipeline/core/consistencycheck/result/RecordSingleTableInventoryCalculatedResult.java 0 2 0
org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/MatchingTableInventoryChecker.java 0 1 0
org/apache/shardingsphere/data/pipeline/core/ingest/dumper/inventory/InventoryDumper.java 0 2 0
org/apache/shardingsphere/data/pipeline/core/ingest/dumper/inventory/column/InventoryColumnValueReaderEngine.java 0 2 0
org/apache/shardingsphere/data/pipeline/core/metadata/generator/PipelineDDLGenerator.java 0 1 0
org/apache/shardingsphere/data/pipeline/migration/distsql/parser/core/MigrationDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/client/MySQLBinlogClient.java 0 2 0
org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/client/netty/MySQLBinlogEventPacketDecoder.java 0 2 0
org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/dumper/MySQLIncrementalDumper.java 0 1 0
org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/dumper/MySQLIncrementalDumperTest.java 0 2 0
org/apache/shardingsphere/data/pipeline/opengauss/ingest/incremental/dumper/OpenGaussIncrementalDumper.java 0 1 0
org/apache/shardingsphere/data/pipeline/opengauss/ingest/incremental/wal/decode/MppdbDecodingPlugin.java 0 5 0
org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/dumper/PostgreSQLIncrementalDumper.java 0 1 0
org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/dumper/PostgreSQLIncrementalDumperTest.java 0 2 0
org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/wal/WALEventConverterTest.java 0 2 0
org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/wal/decode/TestDecodingPlugin.java 0 2 0
org/apache/shardingsphere/data/pipeline/postgresql/sqlbuilder/ddl/column/PostgreSQLColumnPropertiesAppender.java 0 2 0
org/apache/shardingsphere/data/pipeline/scenario/consistencycheck/api/ConsistencyCheckJobAPI.java 0 1 0
org/apache/shardingsphere/data/pipeline/scenario/migration/MigrationJobExecutorCallback.java 0 2 0
org/apache/shardingsphere/data/pipeline/scenario/migration/api/MigrationJobAPI.java 0 2 0
org/apache/shardingsphere/data/pipeline/scenario/migration/check/consistency/MigrationDataConsistencyChecker.java 0 1 0
org/apache/shardingsphere/data/pipeline/scenario/migration/preparer/MigrationJobPreparer.java 0 2 0
org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/MySQLBinlogTableMapEventPacket.java 0 1 0
org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/column/value/MySQLBinlogProtocolValueFactory.java 0 2 0
org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/column/value/string/MySQLJsonValueDecoder.java 0 2 0
org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/column/value/string/MySQLJsonValueDecoderTest.java 0 1 0
org/apache/shardingsphere/db/protocol/opengauss/packet/command/OpenGaussCommandPacketFactory.java 0 2 0
org/apache/shardingsphere/db/protocol/opengauss/packet/command/generic/OpenGaussErrorResponsePacket.java 0 2 0
org/apache/shardingsphere/db/protocol/postgresql/packet/command/PostgreSQLCommandPacketFactory.java 0 1 0
org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLAggregatedCommandPacket.java 0 2 0
org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLColumnType.java 0 1 0
org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/bind/protocol/PostgreSQLBinaryProtocolValueFactory.java 0 2 0
org/apache/shardingsphere/distsql/handler/executor/rdl/resource/AlterStorageUnitExecutor.java 0 1 0
org/apache/shardingsphere/distsql/parser/core/kernel/KernelDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/driver/executor/batch/preparedstatement/BatchPreparedStatementExecutorTest.java 0 2 0
org/apache/shardingsphere/driver/executor/engine/DriverExecuteExecutor.java 0 1 0
org/apache/shardingsphere/driver/executor/engine/batch/preparedstatement/DriverExecuteBatchExecutor.java 0 1 0
org/apache/shardingsphere/driver/executor/engine/facade/standard/StandardDriverExecutorFacade.java 0 1 0
org/apache/shardingsphere/driver/executor/engine/pushdown/jdbc/DriverJDBCPushDownExecuteExecutor.java 0 1 0
org/apache/shardingsphere/driver/executor/engine/pushdown/jdbc/DriverJDBCPushDownExecuteQueryExecutor.java 0 1 0
org/apache/shardingsphere/driver/executor/engine/pushdown/jdbc/DriverJDBCPushDownExecuteUpdateExecutor.java 0 1 0
org/apache/shardingsphere/driver/jdbc/adapter/AdaptedDatabaseMetaData.java 0 2 0
org/apache/shardingsphere/driver/jdbc/adapter/PreparedStatementAdapterTest.java 0 2 0
org/apache/shardingsphere/driver/jdbc/core/connection/ShardingSphereConnection.java 0 2 0
org/apache/shardingsphere/driver/jdbc/core/datasource/metadata/ShardingSphereDatabaseMetaDataTest.java 0 2 0
org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSet.java 0 1 0
org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetTest.java 0 1 0
org/apache/shardingsphere/driver/jdbc/core/statement/ShardingSpherePreparedStatement.java 0 1 0
org/apache/shardingsphere/driver/jdbc/core/statement/ShardingSphereStatement.java 0 1 0
org/apache/shardingsphere/driver/state/circuit/metadata/CircuitBreakerDatabaseMetaData.java 0 2 0
org/apache/shardingsphere/driver/state/circuit/metadata/CircuitBreakerDatabaseMetaDataTest.java 0 2 0
org/apache/shardingsphere/encrypt/distsql/handler/update/CreateEncryptRuleExecutorTest.java 0 1 0
org/apache/shardingsphere/encrypt/distsql/parser/core/EncryptDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/encrypt/merge/dal/show/DecoratedEncryptShowCreateTableMergedResultTest.java 0 1 0
org/apache/shardingsphere/encrypt/merge/dal/show/MergedEncryptShowCreateTableMergedResultTest.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/condition/EncryptConditionEngine.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/token/EncryptTokenGenerateBuilder.java 0 2 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/ddl/EncryptAlterTableTokenGenerator.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/ddl/EncryptAlterTableTokenGeneratorTest.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/fixture/EncryptGeneratorFixtureBuilder.java 0 2 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/insert/EncryptInsertOnUpdateTokenGenerator.java 0 2 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/insert/EncryptInsertValuesTokenGenerator.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/predicate/EncryptPredicateColumnTokenGenerator.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/predicate/EncryptPredicateRightValueTokenGenerator.java 0 1 0
org/apache/shardingsphere/encrypt/rewrite/token/generator/projection/EncryptProjectionTokenGeneratorTest.java 0 1 0
org/apache/shardingsphere/infra/binder/context/segment/insert/keygen/engine/GeneratedKeyContextEngineTest.java 0 2 0
org/apache/shardingsphere/infra/binder/context/segment/select/groupby/engine/GroupByContextEngineTest.java 0 1 0
org/apache/shardingsphere/infra/binder/context/segment/select/orderby/engine/OrderByContextEngineTest.java 0 1 0
org/apache/shardingsphere/infra/binder/context/segment/select/pagination/PaginationContextTest.java 0 1 0
org/apache/shardingsphere/infra/binder/context/segment/select/pagination/engine/PaginationContextEngineTest.java 0 2 0
org/apache/shardingsphere/infra/binder/context/segment/select/projection/engine/ProjectionEngineTest.java 0 1 0
org/apache/shardingsphere/infra/binder/context/segment/select/projection/engine/ProjectionsContextEngineTest.java 0 2 0
org/apache/shardingsphere/infra/binder/context/statement/SQLStatementContextFactory.java 0 7 0
org/apache/shardingsphere/infra/binder/context/statement/SQLStatementContextFactoryTest.java 0 2 0
org/apache/shardingsphere/infra/binder/context/statement/ddl/AlterTableStatementContextTest.java 0 2 0
org/apache/shardingsphere/infra/binder/context/statement/ddl/PrepareStatementContextTest.java 0 1 0
org/apache/shardingsphere/infra/binder/context/statement/dml/InsertStatementContext.java 0 2 0
org/apache/shardingsphere/infra/binder/context/statement/dml/InsertStatementContextTest.java 0 2 0
org/apache/shardingsphere/infra/binder/context/statement/dml/SelectStatementContext.java 0 1 0
org/apache/shardingsphere/infra/binder/context/statement/dml/SelectStatementContextTest.java 0 2 0
org/apache/shardingsphere/infra/binder/engine/segment/expression/type/ColumnSegmentBinder.java 0 2 0
org/apache/shardingsphere/infra/binder/engine/segment/expression/type/SubquerySegmentBinderTest.java 0 1 0
org/apache/shardingsphere/infra/binder/engine/segment/from/type/SimpleTableSegmentBinder.java 0 1 0
org/apache/shardingsphere/infra/binder/engine/segment/from/type/SubqueryTableSegmentBinderTest.java 0 1 0
org/apache/shardingsphere/infra/binder/engine/segment/projection/type/ShorthandProjectionSegmentBinderTest.java 0 1 0
org/apache/shardingsphere/infra/binder/engine/statement/DeleteStatementBinderTest.java 0 1 0
org/apache/shardingsphere/infra/binder/engine/statement/InsertStatementBinderTest.java 0 2 0
org/apache/shardingsphere/infra/binder/engine/statement/SelectStatementBinderTest.java 0 1 0
org/apache/shardingsphere/infra/binder/engine/statement/UpdateStatementBinderTest.java 0 1 0
org/apache/shardingsphere/infra/database/core/metadata/data/loader/MetaDataLoaderConnection.java 0 1 0
org/apache/shardingsphere/infra/database/core/metadata/data/loader/MetaDataLoaderConnectionTest.java 0 1 0
org/apache/shardingsphere/infra/database/core/resultset/ResultSetMapper.java 0 1 0
org/apache/shardingsphere/infra/datasource/pool/creator/DataSourcePoolReflection.java 0 1 0
org/apache/shardingsphere/infra/exception/mysql/mapper/MySQLDialectExceptionMapper.java 0 3 0
org/apache/shardingsphere/infra/exception/postgresql/mapper/PostgreSQLDialectExceptionMapper.java 0 2 0
org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilderTest.java 0 1 0
org/apache/shardingsphere/infra/executor/sql/execute/result/query/impl/driver/jdbc/type/memory/JDBCMemoryQueryResultTest.java 0 2 0
org/apache/shardingsphere/infra/executor/sql/execute/result/query/impl/driver/jdbc/type/stream/JDBCStreamQueryResult.java 0 2 0
org/apache/shardingsphere/infra/executor/sql/execute/result/query/impl/driver/jdbc/type/util/ResultSetUtils.java 0 3 0
org/apache/shardingsphere/infra/hint/SQLHintUtils.java 0 2 0
org/apache/shardingsphere/infra/merge/result/impl/local/LocalDataQueryResultRow.java 0 2 0
org/apache/shardingsphere/infra/props/TypedPropertyValue.java 0 2 0
org/apache/shardingsphere/infra/rewrite/SQLRewriteEntryTest.java 0 1 0
org/apache/shardingsphere/infra/rewrite/engine/RouteSQLRewriteEngine.java 0 1 0
org/apache/shardingsphere/mask/distsql/parser/core/MaskDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/mode/manager/ContextManagerTest.java 0 2 0
org/apache/shardingsphere/mode/manager/cluster/ClusterContextManagerBuilder.java 0 2 0
org/apache/shardingsphere/mode/manager/cluster/event/subscriber/registry/ClusterDispatchEventSubscriberRegistry.java 0 1 0
org/apache/shardingsphere/mode/manager/cluster/listener/DatabaseMetaDataChangedListener.java 0 1 0
org/apache/shardingsphere/mode/manager/standalone/persist/StandaloneMetaDataManagerPersistService.java 0 1 0
org/apache/shardingsphere/mode/manager/standalone/persist/StandaloneMetaDataManagerPersistServiceTest.java 0 1 0
org/apache/shardingsphere/mode/metadata/MetaDataContextManager.java 0 2 0
org/apache/shardingsphere/mode/metadata/MetaDataContextsFactory.java 0 2 0
org/apache/shardingsphere/mode/metadata/MetaDataContextsFactoryTest.java 0 1 0
org/apache/shardingsphere/mode/repository/cluster/etcd/EtcdRepositoryTest.java 0 1 0
org/apache/shardingsphere/mode/repository/cluster/zookeeper/ZookeeperRepository.java 0 1 0
org/apache/shardingsphere/mode/repository/cluster/zookeeper/ZookeeperRepositoryTest.java 0 1 0
org/apache/shardingsphere/mode/tuple/RepositoryTupleSwapperEngine.java 0 3 0
org/apache/shardingsphere/proxy/backend/connector/DatabaseConnector.java 0 2 0
org/apache/shardingsphere/proxy/backend/connector/DatabaseConnectorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/connector/ProxyDatabaseConnectionManagerTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/connector/ProxySQLExecutor.java 0 2 0
org/apache/shardingsphere/proxy/backend/connector/ProxySQLExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/connector/jdbc/datasource/JDBCBackendDataSourceTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/connector/jdbc/transaction/BackendTransactionManagerTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/handler/ProxyBackendHandlerFactory.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/ProxyBackendHandlerFactoryTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/admin/executor/DefaultDatabaseMetaDataExecutorTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/handler/data/impl/UnicastDatabaseBackendHandlerTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/handler/database/DatabaseOperateBackendHandlerFactoryTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportDatabaseConfigurationExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportMetaDataExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportStorageNodesExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportDatabaseConfigurationExecutorTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportMetaDataExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/distsql/rul/PreviewExecutor.java 0 2 0
org/apache/shardingsphere/proxy/backend/handler/transaction/TransactionBackendHandler.java 0 1 0
org/apache/shardingsphere/proxy/backend/handler/transaction/TransactionBackendHandlerFactory.java 0 2 0
org/apache/shardingsphere/proxy/backend/mysql/connector/sane/MySQLDialectSaneQueryResultEngineTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/mysql/handler/admin/MySQLAdminExecutorCreator.java 0 4 0
org/apache/shardingsphere/proxy/backend/mysql/handler/admin/MySQLAdminExecutorCreatorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowDatabasesExecutorTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowTablesExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/UnicastResourceShowExecutor.java 0 1 0
org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/information/SelectInformationSchemataExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/opengauss/handler/admin/OpenGaussSystemCatalogAdminQueryExecutor.java 0 2 0
org/apache/shardingsphere/proxy/backend/opengauss/handler/admin/OpenGaussSystemCatalogAdminQueryExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/PostgreSQLAdminExecutorCreatorTest.java 0 1 0
org/apache/shardingsphere/proxy/backend/util/YamlDatabaseConfigurationImportExecutor.java 0 1 0
org/apache/shardingsphere/proxy/frontend/command/CommandExecutorTaskTest.java 0 1 0
org/apache/shardingsphere/proxy/frontend/mysql/authentication/MySQLAuthenticationEngine.java 0 2 0
org/apache/shardingsphere/proxy/frontend/mysql/authentication/MySQLAuthenticationEngineTest.java 0 1 0
org/apache/shardingsphere/proxy/frontend/mysql/command/MySQLCommandExecutorFactory.java 0 3 0
org/apache/shardingsphere/proxy/frontend/mysql/command/MySQLCommandPacketFactory.java 0 2 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/execute/MySQLComStmtExecuteExecutor.java 0 1 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/execute/MySQLComStmtExecuteExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareCheckerTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareExecutor.java 0 1 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLComQueryPacketExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandler.java 0 1 0
org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandlerTest.java 0 1 0
org/apache/shardingsphere/proxy/frontend/netty/CDCChannelInboundHandler.java 0 1 0
org/apache/shardingsphere/proxy/frontend/opengauss/authentication/OpenGaussAuthenticationEngine.java 0 2 0
org/apache/shardingsphere/proxy/frontend/opengauss/authentication/OpenGaussAuthenticationEngineTest.java 0 1 0
org/apache/shardingsphere/proxy/frontend/opengauss/command/OpenGaussCommandExecutorFactory.java 0 3 0
org/apache/shardingsphere/proxy/frontend/opengauss/command/OpenGaussCommandExecutorFactoryTest.java 0 1 0
org/apache/shardingsphere/proxy/frontend/opengauss/command/query/extended/bind/OpenGaussComBatchBindExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/opengauss/command/query/simple/OpenGaussComQueryExecutor.java 0 1 0
org/apache/shardingsphere/proxy/frontend/postgresql/authentication/PostgreSQLAuthenticationEngine.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/authentication/PostgreSQLAuthenticationEngineTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/PostgreSQLCommandExecutorFactory.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/Portal.java 0 1 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PortalTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PostgreSQLAggregatedBatchedStatementsCommandExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PostgreSQLBatchedStatementsExecutor.java 0 1 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PostgreSQLBatchedStatementsExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/describe/PostgreSQLComDescribeExecutor.java 0 1 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/describe/PostgreSQLComDescribeExecutorTest.java 0 2 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/parse/PostgreSQLComParseExecutorTest.java 0 1 0
org/apache/shardingsphere/proxy/frontend/postgresql/command/query/simple/PostgreSQLComQueryExecutor.java 0 1 0
org/apache/shardingsphere/readwritesplitting/distsql/parser/core/ReadwriteSplittingDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/readwritesplitting/route/ReadwriteSplittingSQLRouterTest.java 0 2 0
org/apache/shardingsphere/shadow/distsql/parser/core/ShadowDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/shadow/route/engine/impl/ShadowNonDMLStatementRoutingEngineTest.java 0 1 0
org/apache/shardingsphere/sharding/algorithm/sharding/datetime/IntervalShardingAlgorithm.java 0 1 0
org/apache/shardingsphere/sharding/cache/checker/ShardingRouteCacheableChecker.java 0 2 0
org/apache/shardingsphere/sharding/cache/checker/ShardingRouteCacheableCheckerTest.java 0 2 0
org/apache/shardingsphere/sharding/decider/ShardingSQLFederationDecider.java 0 1 0
org/apache/shardingsphere/sharding/distsql/checker/ShardingRuleStatementCheckerTest.java 0 2 0
org/apache/shardingsphere/sharding/distsql/handler/checker/ShardingTableRuleStatementChecker.java 0 2 0
org/apache/shardingsphere/sharding/distsql/handler/converter/ShardingTableRuleStatementConverter.java 0 1 0
org/apache/shardingsphere/sharding/distsql/parser/core/ShardingDistSQLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRuleExecutorTest.java 0 1 0
org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRulesUsedAlgorithmExecutorTest.java 0 1 0
org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRulesUsedAuditorExecutorTest.java 0 1 0
org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRulesUsedKeyGeneratorExecutorTest.java 0 1 0
org/apache/shardingsphere/sharding/distsql/update/AlterShardingTableRuleExecutorTest.java 0 2 0
org/apache/shardingsphere/sharding/distsql/update/CreateShardingTableRuleExecutorTest.java 0 2 0
org/apache/shardingsphere/sharding/distsql/update/DropShardingTableRuleExecutorTest.java 0 1 0
org/apache/shardingsphere/sharding/merge/ShardingResultMergerEngineTest.java 0 2 0
org/apache/shardingsphere/sharding/merge/dal/ShardingDALResultMerger.java 0 1 0
org/apache/shardingsphere/sharding/merge/ddl/ShardingDDLResultMergerTest.java 0 1 0
org/apache/shardingsphere/sharding/merge/ddl/fetch/FetchStreamMergedResultTest.java 0 2 0
org/apache/shardingsphere/sharding/merge/dql/ShardingDQLResultMerger.java 0 1 0
org/apache/shardingsphere/sharding/merge/dql/ShardingDQLResultMergerTest.java 0 2 0
org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByMemoryMergedResultTest.java 0 2 0
org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByRowComparatorTest.java 0 1 0
org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByStreamMergedResultTest.java 0 2 0
org/apache/shardingsphere/sharding/merge/dql/orderby/CompareUtils.java 0 2 0
org/apache/shardingsphere/sharding/merge/dql/orderby/OrderByStreamMergedResultTest.java 0 1 0
org/apache/shardingsphere/sharding/merge/dql/orderby/OrderByValueTest.java 0 2 0
org/apache/shardingsphere/sharding/rewrite/token/ShardingTokenGenerateBuilder.java 0 2 0
org/apache/shardingsphere/sharding/rewrite/token/generator/ShardingRemoveTokenGeneratorTest.java 0 1 0
org/apache/shardingsphere/sharding/rewrite/token/generator/impl/ShardingProjectionsTokenGenerator.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/condition/engine/InsertClauseShardingConditionEngine.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/condition/engine/InsertClauseShardingConditionEngineTest.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/condition/engine/WhereClauseShardingConditionEngine.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/condition/generator/ConditionValueGeneratorFactoryTest.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/condition/generator/impl/ConditionValueBetweenOperatorGeneratorTest.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/condition/generator/impl/ConditionValueCompareOperatorGenerator.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/condition/generator/impl/ConditionValueInOperatorGeneratorTest.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/fixture/ShardingRoutingEngineFixtureBuilder.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/type/ShardingRouteEngineFactory.java 0 4 0
org/apache/shardingsphere/sharding/route/engine/type/ShardingRouteEngineFactoryTest.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/type/standard/ShardingStandardRoutingEngine.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/type/standard/assertion/ShardingRouteAssert.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/validator/ShardingStatementValidatorFactory.java 0 4 0
org/apache/shardingsphere/sharding/route/engine/validator/ddl/ShardingCreateTableStatementValidatorTest.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/validator/ddl/ShardingDropTableStatementValidatorTest.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/validator/dml/ShardingDeleteStatementValidatorTest.java 0 1 0
org/apache/shardingsphere/sharding/route/engine/validator/dml/ShardingInsertStatementValidatorTest.java 0 2 0
org/apache/shardingsphere/sharding/route/engine/validator/dml/ShardingUpdateStatementValidatorTest.java 0 2 0
org/apache/shardingsphere/sharding/rule/ShardingRule.java 0 2 0
org/apache/shardingsphere/sharding/rule/ShardingRuleTest.java 0 2 0
org/apache/shardingsphere/sharding/yaml/ShardingRuleConfigurationYamlIT.java 0 1 0
org/apache/shardingsphere/single/distsql/handler/update/LoadSingleTableExecutorTest.java 0 1 0
org/apache/shardingsphere/single/distsql/parser/core/SingleDistSQLStatementVisitor.java 0 1 0
org/apache/shardingsphere/single/route/SingleSQLRouterTest.java 0 2 0
org/apache/shardingsphere/single/route/engine/SingleStandardRouteEngineTest.java 0 1 0
org/apache/shardingsphere/sql/parser/clickhouse/visitor/statement/ClickHouseStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/clickhouse/visitor/statement/type/ClickHouseDMLStatementVisitor.java 0 4 0
org/apache/shardingsphere/sql/parser/doris/visitor/statement/DorisStatementVisitor.java 0 15 0
org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDALStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDCLStatementVisitor.java 0 3 0
org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDDLStatementVisitor.java 0 6 0
org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDMLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisTCLStatementVisitor.java 0 3 0
org/apache/shardingsphere/sql/parser/hive/visitor/statement/HiveStatementVisitor.java 0 6 0
org/apache/shardingsphere/sql/parser/hive/visitor/statement/type/HiveDMLStatementVisitor.java 0 7 0
org/apache/shardingsphere/sql/parser/mysql/visitor/format/MySQLFormatVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/mysql/visitor/statement/MySQLStatementVisitor.java 0 15 0
org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDALStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDCLStatementVisitor.java 0 3 0
org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDDLStatementVisitor.java 0 6 0
org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDMLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLTCLStatementVisitor.java 0 3 0
org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/OpenGaussStatementVisitor.java 0 5 0
org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussDALStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussDCLStatementVisitor.java 0 1 0
org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussDDLStatementVisitor.java 0 5 0
org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussTCLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/oracle/visitor/statement/OracleStatementVisitor.java 0 9 0
org/apache/shardingsphere/sql/parser/oracle/visitor/statement/type/OracleDCLStatementVisitor.java 0 1 0
org/apache/shardingsphere/sql/parser/oracle/visitor/statement/type/OracleDDLStatementVisitor.java 0 9 0
org/apache/shardingsphere/sql/parser/oracle/visitor/statement/type/OracleDMLStatementVisitor.java 0 5 0
org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/PostgreSQLStatementVisitor.java 0 5 0
org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDALStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDCLStatementVisitor.java 0 1 0
org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDDLStatementVisitor.java 0 5 0
org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDMLStatementVisitor.java 0 1 0
org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLTCLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/presto/visitor/statement/PrestoStatementVisitor.java 0 6 0
org/apache/shardingsphere/sql/parser/presto/visitor/statement/type/PrestoDDLStatementVisitor.java 0 1 0
org/apache/shardingsphere/sql/parser/presto/visitor/statement/type/PrestoDMLStatementVisitor.java 0 7 0
org/apache/shardingsphere/sql/parser/sql92/visitor/statement/SQL92StatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/sql92/visitor/statement/type/SQL92DDLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/sql92/visitor/statement/type/SQL92DMLStatementVisitor.java 0 4 0
org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/SQLServerStatementVisitor.java 0 7 0
org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/type/SQLServerDCLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/type/SQLServerDDLStatementVisitor.java 0 2 0
org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/type/SQLServerTCLStatementVisitor.java 0 1 0
org/apache/shardingsphere/sql/parser/statement/core/util/ColumnExtractUtils.java 0 1 0
org/apache/shardingsphere/sql/parser/statement/core/util/ExpressionExtractUtils.java 0 4 0
org/apache/shardingsphere/sql/parser/statement/core/util/ExpressionExtractUtilsTest.java 0 1 0
org/apache/shardingsphere/sql/parser/statement/core/util/SQLUtils.java 0 1 0
org/apache/shardingsphere/sql/parser/statement/core/util/SubqueryExtractUtils.java 0 3 0
org/apache/shardingsphere/sql/parser/statement/core/util/SubqueryExtractUtilsTest.java 0 2 0
org/apache/shardingsphere/sql/parser/statement/core/util/TableExtractor.java 0 4 0
org/apache/shardingsphere/sql/parser/statement/core/util/TableExtractorTest.java 0 2 0
org/apache/shardingsphere/sql/parser/statement/core/util/WhereExtractUtilsTest.java 0 1 0
org/apache/shardingsphere/sqlfederation/engine/SQLFederationEngine.java 0 2 0
org/apache/shardingsphere/sqlfederation/executor/enumerable/EnumerableScanExecutor.java 0 2 0
org/apache/shardingsphere/sqlfederation/optimizer/converter/segment/expression/ExpressionConverter.java 0 3 0
org/apache/shardingsphere/sqlfederation/optimizer/it/SQLStatementCompilerIT.java 0 2 0
org/apache/shardingsphere/sqlfederation/optimizer/metadata/schema/SQLFederationTable.java 0 1 0
org/apache/shardingsphere/sqlfederation/optimizer/planner/util/SQLFederationPlannerUtils.java 0 1 0
org/apache/shardingsphere/sqlfederation/resultset/SQLFederationResultSet.java 0 1 0
org/apache/shardingsphere/test/e2e/cases/value/SQLValue.java 0 3 0
org/apache/shardingsphere/test/e2e/data/pipeline/cases/PipelineContainerComposer.java 0 1 0
org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/CDCE2EIT.java 0 2 0
org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/DataSourceRecordConsumer.java 0 1 0
org/apache/shardingsphere/test/e2e/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java 0 1 0
org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/IndexesMigrationE2EIT.java 0 1 0
org/apache/shardingsphere/test/e2e/driver/statement/ShardingPreparedStatementTest.java 0 2 0
org/apache/shardingsphere/test/e2e/engine/type/dml/BaseDMLE2EIT.java 0 2 0
org/apache/shardingsphere/test/e2e/engine/type/dql/BaseDQLE2EIT.java 0 2 0
org/apache/shardingsphere/test/e2e/showprocesslist/engine/ShowProcessListE2EIT.java 0 1 0
org/apache/shardingsphere/test/it/data/pipeline/core/importer/PipelineDataSourceSinkTest.java 0 2 0
org/apache/shardingsphere/test/it/data/pipeline/core/util/PipelineContextUtils.java 0 2 0
org/apache/shardingsphere/test/it/data/pipeline/scenario/migration/api/impl/MigrationJobAPITest.java 0 2 0
org/apache/shardingsphere/test/it/optimizer/converter/SQLNodeConverterEngineIT.java 0 1 0
org/apache/shardingsphere/test/it/optimizer/converter/cases/jaxb/RootSQLNodeConverterTestCases.java 0 1 0
org/apache/shardingsphere/test/it/rewrite/engine/SQLRewriterIT.java 0 2 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/assignment/AssignmentValueAssert.java 0 1 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/expression/ExpressionAssert.java 0 3 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/projection/ProjectionAssert.java 0 1 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/table/TableAssert.java 0 1 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/SQLStatementAssert.java 0 1 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/dal/DALStatementAssert.java 0 4 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/dcl/DCLStatementAssert.java 0 3 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ddl/DDLStatementAssert.java 0 3 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/dml/DMLStatementAssert.java 0 2 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ral/impl/QueryableRALStatementAssert.java 0 1 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ral/impl/UpdatableRALStatementAssert.java 0 1 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ral/impl/pipeline/UpdatablePipelineRALStatementAssert.java 0 2 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/rdl/create/CreateRuleStatementAssert.java 0 2 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/rdl/drop/DropRuleStatementAssert.java 0 2 0
org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/tcl/TCLStatementAssert.java 0 2 0
org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/jaxb/segment/impl/expr/ExpectedExpression.java 0 1 0
org/apache/shardingsphere/transaction/base/seata/at/fixture/MockMessageHandler.java 0 2 0

Rules

Category Rule Violations Severity
coding NestedForDepth 2  Warning
metrics BooleanExpressionComplexity 5  Warning
ClassDataAbstractionCoupling
  • max: "10"
195  Warning
ClassFanOutComplexity 258  Warning
CyclomaticComplexity 105  Warning
JavaNCSS 12  Warning
NPathComplexity 70  Warning
sizes ExecutableStatementCount
  • max: "50"
4  Warning
MethodCount 22  Warning

Details

org/apache/shardingsphere/agent/plugin/metrics/core/advice/SQLParseCountAdviceTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [DatabaseSegment, FormatStatement, MetricConfiguration, MySQLCommitStatement, MySQLCreateDatabaseStatement, MySQLCreateUserStatement, MySQLDeleteStatement, MySQLInsertStatement, MySQLSelectStatement, MySQLShowDatabasesStatement, MySQLUpdateStatement, RegisterStorageUnitStatement, SQLParseCountAdvice, ShowMigrationListStatement, ShowStorageUnitsStatement, TargetAdviceObjectFixture]. 49

org/apache/shardingsphere/agent/plugin/metrics/core/advice/SQLRouteCountAdviceTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [ConnectionContext, HintValueContext, MetricConfiguration, MySQLDeleteStatement, MySQLInsertStatement, MySQLSelectStatement, MySQLUpdateStatement, QueryContext, SQLRouteCountAdvice, TargetAdviceObjectFixture, UnknownSQLStatementContext]. 47

org/apache/shardingsphere/agent/plugin/metrics/prometheus/PrometheusPluginLifecycleServiceTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ComputeNodeInstance, ComputeNodeInstanceContext, ContextManager, EventBusContext, InetSocketAddress, ModeConfiguration, PluginConfiguration, PrometheusPluginLifecycleService, Property, ShardingSphereMetaData, Socket, StandaloneWorkerIdGenerator]. 51

org/apache/shardingsphere/agent/plugin/tracing/opentelemetry/advice/OpenTelemetryJDBCExecutorCallbackAdviceTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 64

org/apache/shardingsphere/broadcast/route/BroadcastSQLRouter.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 33 (max allowed is 20). 63
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 93
 Warning metrics NPathComplexity NPath Complexity is 576 (max allowed is 200). 93

org/apache/shardingsphere/broadcast/route/BroadcastSqlRouterTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 17 (max allowed is 10) classes [BroadcastRule, BroadcastSQLRouter, ConfigurationProperties, CreateTableStatementContext, DataNode, HintValueContext, IdentifierValue, MockedDataSource, MySQLCreateTableStatement, Properties, QueryContext, RouteContext, RouteMapper, RouteUnit, SimpleTableSegment, StorageUnit, TableNameSegment]. 73
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 73

org/apache/shardingsphere/broadcast/route/engine/BroadcastRouteEngineFactory.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 56

org/apache/shardingsphere/data/pipeline/cdc/CDCJob.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [CDCExecuteCallback, CDCJobItemContext, CDCJobPreparer, CDCJobRunnerCleaner, CDCTaskConfiguration, CDCTasksRunner, DumperCommonContext, ImporterConfiguration, IncrementalDumperContext, PipelineJobItemManager, PipelineJobRunnerManager, PipelineProcessConfigurationPersistService, ShardingColumnsExtractor, TableAndSchemaNameMapper, TransmissionProcessContext]. 82
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 37 (max allowed is 20). 82

org/apache/shardingsphere/data/pipeline/cdc/api/CDCJobAPI.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 32 (max allowed is 10) classes [CDCJob, CDCJobId, CDCJobItemInfo, CDCJobType, DumperCommonContext, IncrementalDumperContext, IncrementalTaskPositionManager, IncrementalTaskProgress, JobDataNodeEntry, JobDataNodeLine, JobItemIncrementalTasksProgress, OneOffJobBootstrap, PipelineContextKey, PipelineDataSourceManager, PipelineInternalException, PipelineJobConfigurationManager, PipelineJobCreationWithInvalidShardingCountException, PipelineJobItemManager, PipelineJobManager, PrepareJobWithGetBinlogPositionException, ShardingSpherePipelineDataSourceConfiguration, StandardPipelineDataSourceConfiguration, TableAndSchemaNameMapper, TransmissionJobItemProgress, TransmissionJobManager, YamlCDCJobConfiguration, YamlCDCJobConfigurationSwapper, YamlDataSourceConfigurationSwapper, YamlPipelineDataSourceConfigurationSwapper, YamlRootConfiguration, YamlRuleConfigurationSwapperEngine, YamlSinkConfiguration]. 93
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 49 (max allowed is 20). 93

org/apache/shardingsphere/data/pipeline/cdc/client/CDCClient.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 62

org/apache/shardingsphere/data/pipeline/cdc/client/util/ProtobufAnyValueConverter.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 55
 Warning metrics NPathComplexity NPath Complexity is 12,288 (max allowed is 200). 55

org/apache/shardingsphere/data/pipeline/cdc/core/prepare/CDCJobPreparer.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [AtomicBoolean, AtomicReference, CDCChannelProgressPair, CDCImporter, CDCIncrementalTask, CDCInventoryTask, CopyOnWriteArrayList, CreateIncrementalDumperParameter, IncrementalTaskPositionManager, InventoryDumper, InventoryDumperContext, InventoryDumperContextSplitter, PlaceholderInventoryDataRecordPositionCreator, PrepareJobWithGetBinlogPositionException, UniqueKeyInventoryDataRecordPositionCreator]. 68
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 34 (max allowed is 20). 68

org/apache/shardingsphere/data/pipeline/cdc/distsql/parser/core/CDCDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 55

org/apache/shardingsphere/data/pipeline/cdc/handler/CDCBackendHandler.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CDCExceptionWrapper, CDCJobType, DatabaseTypeRegistry, MissingRequiredStreamDataSourceException, PipelineCDCSocketSink, PipelineInternalException, PipelineInvalidParameterException, PipelineJobConfigurationManager, PipelineJobNotFoundException, Properties, StreamDataParameter, StreamDatabaseNotFoundException]. 75
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 75

org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtils.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 25 (max allowed is 10). 63
 Warning metrics JavaNCSS NCSS for this method is 56 (max allowed is 50). 63
 Warning metrics NPathComplexity NPath Complexity is 16,777,216 (max allowed is 200). 63

org/apache/shardingsphere/data/pipeline/cdc/util/ColumnValueConvertUtilsTest.java

Severity Category Rule Message Line
 Warning sizes ExecutableStatementCount Executable statement count is 61 (max allowed is 50). 46
 Warning metrics JavaNCSS NCSS for this method is 62 (max allowed is 50). 46

org/apache/shardingsphere/data/pipeline/core/consistencycheck/ConsistencyCheckDataBuilder.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 68
 Warning metrics NPathComplexity NPath Complexity is 16,384 (max allowed is 200). 68

org/apache/shardingsphere/data/pipeline/core/consistencycheck/result/RecordSingleTableInventoryCalculatedResult.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 55
 Warning metrics NPathComplexity NPath Complexity is 288 (max allowed is 200). 55

org/apache/shardingsphere/data/pipeline/core/consistencycheck/table/MatchingTableInventoryChecker.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 50

org/apache/shardingsphere/data/pipeline/core/ingest/dumper/inventory/InventoryDumper.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [AtomicLong, AtomicReference, BuildDivisibleSQLParameter, Column, DataRecord, FinishedRecord, IngestException, IngestFinishedPosition, InventoryColumnValueReaderEngine, PipelineInternalException, PipelineInvalidParameterException, PipelineInventoryDumpSQLBuilder, QueryRange]. 69
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 34 (max allowed is 20). 69

org/apache/shardingsphere/data/pipeline/core/ingest/dumper/inventory/column/InventoryColumnValueReaderEngine.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 34 (max allowed is 10). 62
 Warning metrics JavaNCSS NCSS for this method is 63 (max allowed is 50). 62

org/apache/shardingsphere/data/pipeline/core/metadata/generator/PipelineDDLGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 58

org/apache/shardingsphere/data/pipeline/migration/distsql/parser/core/MigrationDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 27 (max allowed is 10) classes [AlgorithmSegment, AlterTransmissionRuleStatement, CheckMigrationStatement, CommitMigrationStatement, DataNode, DropMigrationCheckStatement, HostnameAndPortBasedDataSourceSegment, IdentifierValue, MigrateTableStatement, Properties, ReadOrWriteSegment, RegisterMigrationSourceStorageUnitStatement, RollbackMigrationStatement, ShowMigrationCheckStatusStatement, ShowMigrationListStatement, ShowMigrationRuleStatement, ShowMigrationSourceStorageUnitsStatement, ShowMigrationStatusStatement, ShowPluginsStatement, SourceTargetEntry, StartMigrationCheckStatement, StartMigrationStatement, StopMigrationCheckStatement, StopMigrationStatement, TransmissionRuleSegment, URLBasedDataSourceSegment, UnregisterMigrationSourceStorageUnitStatement]. 97
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 66 (max allowed is 20). 97

org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/client/MySQLBinlogClient.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 21 (max allowed is 10) classes [ArrayBlockingQueue, Bootstrap, ChannelAttrInitializer, ChannelInitializer, DefaultPromise, MySQLBinlogEventHandler, MySQLBinlogEventPacketDecoder, MySQLComBinlogDumpCommandPacket, MySQLComQueryPacket, MySQLComRegisterSlaveCommandPacket, MySQLCommandPacketDecoder, MySQLCommandResponseHandler, MySQLNegotiateHandler, MySQLNegotiatePackageDecoder, MySQLPacketCodecEngine, MySQLSequenceIdInboundHandler, NioEventLoopGroup, PacketCodec, PipelineInternalException, PlaceholderBinlogEvent, UnsupportedSQLOperationException]. 71
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 37 (max allowed is 20). 71

org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/client/netty/MySQLBinlogEventPacketDecoder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [MySQLBinlogContext, MySQLBinlogEventHeader, MySQLBinlogFormatDescriptionEventPacket, MySQLBinlogRotateEventPacket, MySQLBinlogRowsEventPacket, MySQLBinlogTableMapEventPacket, MySQLDeleteRowsBinlogEvent, MySQLPacketPayload, MySQLQueryBinlogEvent, MySQLUpdateRowsBinlogEvent, MySQLWriteRowsBinlogEvent, MySQLXidBinlogEvent, PipelineInternalException, PlaceholderBinlogEvent]. 51
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 148

org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/dumper/MySQLIncrementalDumper.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 61

org/apache/shardingsphere/data/pipeline/mysql/ingest/incremental/dumper/MySQLIncrementalDumperTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 17 (max allowed is 10) classes [ActualAndLogicTableNameMapper, CaseInsensitiveIdentifier, DumperCommonContext, IncrementalDumperContext, MemoryPipelineChannel, MySQLBinlogPosition, MySQLDeleteRowsBinlogEvent, MySQLIncrementalDumper, MySQLUpdateRowsBinlogEvent, MySQLWriteRowsBinlogEvent, PipelineColumnMetaData, PipelineDataSourceManager, PipelineTableMetaData, PlaceholderBinlogEvent, Serializable, StandardPipelineDataSourceConfiguration, TableAndSchemaNameMapper]. 72
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 72

org/apache/shardingsphere/data/pipeline/opengauss/ingest/incremental/dumper/OpenGaussIncrementalDumper.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 33 (max allowed is 20). 64

org/apache/shardingsphere/data/pipeline/opengauss/ingest/incremental/wal/decode/MppdbDecodingPlugin.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BeginTXEvent, BigDecimal, CommitTXEvent, DecodingException, DeleteRowEvent, IngestException, PGInterval, PGobject, PlaceholderEvent, UpdateRowEvent, WriteRowEvent]. 52
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 52
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 36 (max allowed is 10). 184
 Warning metrics JavaNCSS NCSS for this method is 56 (max allowed is 50). 184
 Warning metrics NPathComplexity NPath Complexity is 280 (max allowed is 200). 184

org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/dumper/PostgreSQLIncrementalDumper.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 60

org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/dumper/PostgreSQLIncrementalDumperTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [ActualAndLogicTableNameMapper, CaseInsensitiveIdentifier, DumperCommonContext, IncrementalDumperContext, IngestException, MemoryPipelineChannel, PipelineDataSourceManager, PostgreSQLIncrementalDumper, PostgreSQLLogSequenceNumber, SQLWrapperException, StandardPipelineDataSourceConfiguration, StandardPipelineTableMetaDataLoader, TableAndSchemaNameMapper, WALPosition]. 65
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 65

org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/wal/WALEventConverterTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 19 (max allowed is 10) classes [AbstractRowEvent, ActualAndLogicTableNameMapper, BeginTXEvent, CaseInsensitiveIdentifier, CommitTXEvent, DeleteRowEvent, DumperCommonContext, IncrementalDumperContext, PipelineColumnMetaData, PipelineDataSourceManager, PipelineTableMetaData, PlaceholderEvent, PostgreSQLLogSequenceNumber, StandardPipelineDataSourceConfiguration, StandardPipelineTableMetaDataLoader, TableAndSchemaNameMapper, UpdateRowEvent, WALEventConverter, WriteRowEvent]. 70
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 70

org/apache/shardingsphere/data/pipeline/postgresql/ingest/incremental/wal/decode/TestDecodingPlugin.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 23 (max allowed is 10). 169
 Warning metrics NPathComplexity NPath Complexity is 612 (max allowed is 200). 169

org/apache/shardingsphere/data/pipeline/postgresql/sqlbuilder/ddl/column/PostgreSQLColumnPropertiesAppender.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 205
 Warning metrics NPathComplexity NPath Complexity is 384 (max allowed is 200). 205

org/apache/shardingsphere/data/pipeline/scenario/consistencycheck/api/ConsistencyCheckJobAPI.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 65

org/apache/shardingsphere/data/pipeline/scenario/migration/MigrationJobExecutorCallback.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [CaseInsensitiveQualifiedTable, CreateTableConfiguration, DatabaseTypeRegistry, ImporterConfiguration, MigrationIncrementalDumperContextCreator, MigrationJobItemContext, MigrationJobPreparer, MigrationTaskConfiguration, ShardingColumnsExtractor, TransmissionProcessContext, TransmissionTasksRunner]. 55
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 55

org/apache/shardingsphere/data/pipeline/scenario/migration/api/MigrationJobAPI.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 23 (max allowed is 10) classes [DatabaseTypeRegistry, DuplicateStorageUnitException, EmptyRuleException, JobDataNodeEntry, JobDataNodeLine, MigrationJobId, MigrationJobType, MissingRequiredStorageUnitsException, PipelineDataSource, PipelineDataSourcePersistService, PipelineInvalidParameterException, PipelineJobConfigurationManager, PipelineJobManager, PipelinePrepareSQLBuilder, ShardingSpherePipelineDataSourceConfiguration, StandardPipelineDataSourceConfiguration, TableAndSchemaNameMapper, YamlDataSourceConfigurationSwapper, YamlMigrationJobConfiguration, YamlMigrationJobConfigurationSwapper, YamlPipelineDataSourceConfiguration, YamlRootConfiguration, YamlRuleConfigurationSwapperEngine]. 90
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 41 (max allowed is 20). 90

org/apache/shardingsphere/data/pipeline/scenario/migration/check/consistency/MigrationDataConsistencyChecker.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 64

org/apache/shardingsphere/data/pipeline/scenario/migration/preparer/MigrationJobPreparer.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [CreateIncrementalDumperParameter, GlobalLockDefinition, IncrementalTask, IncrementalTaskPositionManager, InventoryDumperContext, InventoryTaskSplitter, JobOffsetInfo, MigrationJobType, PipelineDataSourceCheckEngine, PipelineJobDataSourcePreparer, PipelineJobItemManager, PrepareJobWithGetBinlogPositionException, PrepareTargetSchemasParameter, PrepareTargetTablesParameter, SingleChannelConsumerImporter, UnsupportedSQLOperationException]. 84
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 40 (max allowed is 20). 84

org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/MySQLBinlogTableMapEventPacket.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 16 (max allowed is 10). 88

org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/column/value/MySQLBinlogProtocolValueFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 22 (max allowed is 10) classes [EnumMap, MySQLBitBinlogProtocolValue, MySQLBlobBinlogProtocolValue, MySQLDateBinlogProtocolValue, MySQLDatetime2BinlogProtocolValue, MySQLDatetimeBinlogProtocolValue, MySQLDecimalBinlogProtocolValue, MySQLDoubleBinlogProtocolValue, MySQLFloatBinlogProtocolValue, MySQLInt24BinlogProtocolValue, MySQLJsonBinlogProtocolValue, MySQLLongBinlogProtocolValue, MySQLLongLongBinlogProtocolValue, MySQLShortBinlogProtocolValue, MySQLStringBinlogProtocolValue, MySQLTime2BinlogProtocolValue, MySQLTimeBinlogProtocolValue, MySQLTimestamp2BinlogProtocolValue, MySQLTimestampBinlogProtocolValue, MySQLTinyBinlogProtocolValue, MySQLVarcharBinlogProtocolValue, MySQLYearBinlogProtocolValue]. 52
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 52

org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/column/value/string/MySQLJsonValueDecoder.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 51
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 144

org/apache/shardingsphere/db/protocol/mysql/packet/binlog/row/column/value/string/MySQLJsonValueDecoderTest.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 326

org/apache/shardingsphere/db/protocol/opengauss/packet/command/OpenGaussCommandPacketFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [OpenGaussComBatchBindPacket, PostgreSQLAggregatedCommandPacket, PostgreSQLComBindPacket, PostgreSQLComClosePacket, PostgreSQLComDescribePacket, PostgreSQLComExecutePacket, PostgreSQLComFlushPacket, PostgreSQLComParsePacket, PostgreSQLComQueryPacket, PostgreSQLComSyncPacket, PostgreSQLComTerminationPacket, PostgreSQLPacketPayload, PostgreSQLUnsupportedCommandPacket]. 46
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 71

org/apache/shardingsphere/db/protocol/opengauss/packet/command/generic/OpenGaussErrorResponsePacket.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 77
 Warning metrics NPathComplexity NPath Complexity is 8,192 (max allowed is 200). 77

org/apache/shardingsphere/db/protocol/postgresql/packet/command/PostgreSQLCommandPacketFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [PostgreSQLAggregatedCommandPacket, PostgreSQLComBindPacket, PostgreSQLComClosePacket, PostgreSQLComDescribePacket, PostgreSQLComExecutePacket, PostgreSQLComFlushPacket, PostgreSQLComParsePacket, PostgreSQLComQueryPacket, PostgreSQLComSyncPacket, PostgreSQLComTerminationPacket, PostgreSQLPacketPayload, PostgreSQLUnsupportedCommandPacket]. 41

org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLAggregatedCommandPacket.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 41
 Warning metrics NPathComplexity NPath Complexity is 932 (max allowed is 200). 41

org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLColumnType.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [PostgreSQLBitValueParser, PostgreSQLBoolValueParser, PostgreSQLDateValueParser, PostgreSQLDoubleValueParser, PostgreSQLFloatValueParser, PostgreSQLIntValueParser, PostgreSQLJsonValueParser, PostgreSQLLongValueParser, PostgreSQLNumericValueParser, PostgreSQLProtocolException, PostgreSQLTextArrayValueParser, PostgreSQLTimeValueParser, PostgreSQLTimestampValueParser, PostgreSQLUnspecifiedValueParser, PostgreSQLVarcharArrayValueParser, PostgreSQLVarcharValueParser]. 49

org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/bind/protocol/PostgreSQLBinaryProtocolValueFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 21 (max allowed is 10) classes [PostgreSQLBoolArrayBinaryProtocolValue, PostgreSQLBoolBinaryProtocolValue, PostgreSQLByteaBinaryProtocolValue, PostgreSQLDateBinaryProtocolValue, PostgreSQLDoubleBinaryProtocolValue, PostgreSQLFloat4ArrayBinaryProtocolValue, PostgreSQLFloat8ArrayBinaryProtocolValue, PostgreSQLFloatBinaryProtocolValue, PostgreSQLInt2ArrayBinaryProtocolValue, PostgreSQLInt2BinaryProtocolValue, PostgreSQLInt4ArrayBinaryProtocolValue, PostgreSQLInt4BinaryProtocolValue, PostgreSQLInt8ArrayBinaryProtocolValue, PostgreSQLInt8BinaryProtocolValue, PostgreSQLNumericBinaryProtocolValue, PostgreSQLStringArrayBinaryProtocolValue, PostgreSQLStringBinaryProtocolValue, PostgreSQLTextArrayBinaryProtocolValue, PostgreSQLTimeBinaryProtocolValue, PostgreSQLUUIDBinaryProtocolValue, PostgreSQLUnspecifiedBinaryProtocolValue]. 32
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 32

org/apache/shardingsphere/distsql/handler/executor/rdl/resource/AlterStorageUnitExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 55

org/apache/shardingsphere/distsql/parser/core/kernel/KernelDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 34 (max allowed is 10) classes [AlgorithmSegment, AlterComputeNodeStatement, AlterStorageUnitStatement, ConvertYamlConfigurationStatement, DatabaseSegment, ExportDatabaseConfigurationStatement, ExportMetaDataStatement, ExportStorageNodesStatement, HostnameAndPortBasedDataSourceSegment, IdentifierValue, ImportDatabaseConfigurationStatement, ImportMetaDataStatement, LabelComputeNodeStatement, LockClusterStatement, Properties, RefreshDatabaseMetaDataStatement, RefreshTableMetaDataStatement, RegisterStorageUnitStatement, SetComputeNodeStateStatement, SetDistVariableStatement, ShowComputeNodeInfoStatement, ShowComputeNodeModeStatement, ShowComputeNodesStatement, ShowDistVariableStatement, ShowDistVariablesStatement, ShowLogicalTablesStatement, ShowPluginsStatement, ShowRulesUsedStorageUnitStatement, ShowStorageUnitsStatement, ShowTableMetaDataStatement, URLBasedDataSourceSegment, UnlabelComputeNodeStatement, UnlockClusterStatement, UnregisterStorageUnitStatement]. 113
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 83 (max allowed is 20). 113

org/apache/shardingsphere/driver/executor/batch/preparedstatement/BatchPreparedStatementExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [BatchExecutionUnit, BatchPreparedStatementExecutor, ExecutionGroup, ExecutionGroupContext, ExecutionGroupReportContext, ExecutionUnit, JDBCExecutionUnit, JDBCExecutor, RuleAttributes, RuleMetaData, SQLException, SQLUnit, UUID]. 71
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 71

org/apache/shardingsphere/driver/executor/engine/DriverExecuteExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 53

org/apache/shardingsphere/driver/executor/engine/batch/preparedstatement/DriverExecuteBatchExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 54

org/apache/shardingsphere/driver/executor/engine/facade/standard/StandardDriverExecutorFacade.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 55

org/apache/shardingsphere/driver/executor/engine/pushdown/jdbc/DriverJDBCPushDownExecuteExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 62

org/apache/shardingsphere/driver/executor/engine/pushdown/jdbc/DriverJDBCPushDownExecuteQueryExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 56

org/apache/shardingsphere/driver/executor/engine/pushdown/jdbc/DriverJDBCPushDownExecuteUpdateExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 57

org/apache/shardingsphere/driver/jdbc/adapter/AdaptedDatabaseMetaData.java

Severity Category Rule Message Line
 Warning sizes MethodCount Number of public methods is 147 (max allowed is 100). 29
 Warning sizes MethodCount Total number of methods is 147 (max allowed is 100). 29

org/apache/shardingsphere/driver/jdbc/adapter/PreparedStatementAdapterTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [ByteArrayInputStream, ConfigurationProperties, Date, DefaultSQLFederationRuleConfigurationBuilder, DefaultSQLParserRuleConfigurationBuilder, Properties, RuleMetaData, SQLFederationRule, SQLParserRule, ShardingSpherePreparedStatement, StringReader, Time, Timestamp]. 60
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 60

org/apache/shardingsphere/driver/jdbc/core/connection/ShardingSphereConnection.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [ConnectionClosedException, CopyOnWriteArrayList, DatabaseTypeRegistry, DriverDatabaseConnectionManager, ForceExecuteTemplate, ProcessEngine, SQLException, SQLFeatureNotSupportedException, ShardingSphereDatabaseMetaData, ShardingSpherePreparedStatement, ShardingSphereStatement]. 52
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 52

org/apache/shardingsphere/driver/jdbc/core/datasource/metadata/ShardingSphereDatabaseMetaDataTest.java

Severity Category Rule Message Line
 Warning sizes MethodCount Number of package methods is 174 (max allowed is 100). 58
 Warning sizes MethodCount Total number of methods is 175 (max allowed is 100). 58

org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSet.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 55

org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 65

org/apache/shardingsphere/driver/jdbc/core/statement/ShardingSpherePreparedStatement.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 74

org/apache/shardingsphere/driver/jdbc/core/statement/ShardingSphereStatement.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 67

org/apache/shardingsphere/driver/state/circuit/metadata/CircuitBreakerDatabaseMetaData.java

Severity Category Rule Message Line
 Warning sizes MethodCount Number of public methods is 176 (max allowed is 100). 28
 Warning sizes MethodCount Total number of methods is 176 (max allowed is 100). 28

org/apache/shardingsphere/driver/state/circuit/metadata/CircuitBreakerDatabaseMetaDataTest.java

Severity Category Rule Message Line
 Warning sizes MethodCount Number of package methods is 176 (max allowed is 100). 29
 Warning sizes MethodCount Total number of methods is 176 (max allowed is 100). 29

org/apache/shardingsphere/encrypt/distsql/handler/update/CreateEncryptRuleExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AlgorithmSegment, CreateEncryptRuleStatement, DistSQLUpdateExecuteEngine, EncryptColumnItemSegment, EncryptColumnSegment, EncryptRuleConfiguration, EncryptRuleSegment, EncryptTableRuleConfiguration, Properties, Property, RuleMetaData]. 56

org/apache/shardingsphere/encrypt/distsql/parser/core/EncryptDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [AlgorithmSegment, AlterEncryptRuleStatement, CountRuleStatement, CreateEncryptRuleStatement, DatabaseSegment, DropEncryptRuleStatement, EncryptColumnItemSegment, EncryptColumnSegment, EncryptRuleSegment, IdentifierValue, Properties, ShowEncryptRulesStatement, ShowPluginsStatement, TableNameSegment]. 57
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 57

org/apache/shardingsphere/encrypt/merge/dal/show/DecoratedEncryptShowCreateTableMergedResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [CacheOption, DecoratedEncryptShowCreateTableMergedResult, EncryptColumnItemRuleConfiguration, EncryptColumnRuleConfiguration, EncryptTable, EncryptTableRuleConfiguration, IdentifierValue, SQLParserRule, SQLParserRuleConfiguration, SimpleTableSegment, TableNameSegment]. 55

org/apache/shardingsphere/encrypt/merge/dal/show/MergedEncryptShowCreateTableMergedResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [CacheOption, EncryptColumnItemRuleConfiguration, EncryptColumnRuleConfiguration, EncryptTable, EncryptTableRuleConfiguration, IdentifierValue, MergedEncryptShowCreateTableMergedResult, SQLParserRule, SQLParserRuleConfiguration, SimpleTableSegment, TableNameSegment]. 54

org/apache/shardingsphere/encrypt/rewrite/condition/EncryptConditionEngine.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 58

org/apache/shardingsphere/encrypt/rewrite/token/EncryptTokenGenerateBuilder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 17 (max allowed is 10) classes [EncryptAlterTableTokenGenerator, EncryptCreateTableTokenGenerator, EncryptGroupByItemTokenGenerator, EncryptIndexColumnTokenGenerator, EncryptInsertAssignmentTokenGenerator, EncryptInsertCipherNameTokenGenerator, EncryptInsertDefaultColumnsTokenGenerator, EncryptInsertDerivedColumnsTokenGenerator, EncryptInsertOnUpdateTokenGenerator, EncryptInsertPredicateColumnTokenGenerator, EncryptInsertPredicateRightValueTokenGenerator, EncryptInsertSelectProjectionTokenGenerator, EncryptInsertValuesTokenGenerator, EncryptPredicateColumnTokenGenerator, EncryptPredicateRightValueTokenGenerator, EncryptSelectProjectionTokenGenerator, EncryptUpdateAssignmentTokenGenerator]. 53
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 53

org/apache/shardingsphere/encrypt/rewrite/token/generator/ddl/EncryptAlterTableTokenGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 57

org/apache/shardingsphere/encrypt/rewrite/token/generator/ddl/EncryptAlterTableTokenGeneratorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AddColumnDefinitionSegment, AssistedQueryColumnItem, ChangeColumnDefinitionSegment, CipherColumnItem, ColumnDefinitionSegment, ColumnSegment, DataTypeSegment, EncryptAlterTableTokenGenerator, EncryptColumn, IdentifierValue, LikeQueryColumnItem, ModifyColumnDefinitionSegment]. 53

org/apache/shardingsphere/encrypt/rewrite/token/generator/fixture/EncryptGeneratorFixtureBuilder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 31 (max allowed is 10) classes [AlgorithmConfiguration, BinaryOperationExpression, ColumnAssignmentSegment, ColumnProjectionSegment, ColumnSegment, ColumnSegmentBoundInfo, EncryptColumnItemRuleConfiguration, EncryptColumnRuleConfiguration, EncryptInsertValuesToken, EncryptRule, EncryptRuleConfiguration, EncryptTableRuleConfiguration, IdentifierValue, InsertColumnsSegment, InsertStatementContext, InsertValue, InsertValuesSegment, LiteralExpressionSegment, MySQLInsertStatement, MySQLSelectStatement, MySQLUpdateStatement, ParameterMarkerExpressionSegment, ProjectionsSegment, Properties, SetAssignmentSegment, ShardingSphereMetaData, SimpleTableSegment, SubquerySegment, TableNameSegment, UpdateStatementContext, WhereSegment]. 80
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 38 (max allowed is 20). 80

org/apache/shardingsphere/encrypt/rewrite/token/generator/insert/EncryptInsertOnUpdateTokenGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 56
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 135

org/apache/shardingsphere/encrypt/rewrite/token/generator/insert/EncryptInsertValuesTokenGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 58

org/apache/shardingsphere/encrypt/rewrite/token/generator/predicate/EncryptPredicateColumnTokenGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 57

org/apache/shardingsphere/encrypt/rewrite/token/generator/predicate/EncryptPredicateRightValueTokenGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 54

org/apache/shardingsphere/encrypt/rewrite/token/generator/projection/EncryptProjectionTokenGeneratorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AliasSegment, ColumnProjection, ColumnProjectionSegment, ColumnSegment, ColumnSegmentBoundInfo, EncryptProjectionTokenGenerator, IdentifierValue, OwnerSegment, SimpleTableSegment, TableNameSegment, TablesContext]. 53

org/apache/shardingsphere/infra/binder/context/segment/insert/keygen/engine/GeneratedKeyContextEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 20 (max allowed is 10) classes [CaseInsensitiveMap, ColumnSegment, CommonExpressionSegment, GeneratedKeyContextEngine, IdentifierValue, InsertColumnsSegment, InsertValueContext, InsertValuesSegment, LiteralExpressionSegment, MySQLInsertStatement, OracleInsertStatement, ParameterMarkerExpressionSegment, PostgreSQLInsertStatement, SQL92InsertStatement, SQLServerInsertStatement, ShardingSphereColumn, ShardingSphereSchema, ShardingSphereTable, SimpleTableSegment, TableNameSegment]. 59
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 59

org/apache/shardingsphere/infra/binder/context/segment/select/groupby/engine/GroupByContextEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ColumnOrderByItemSegment, ColumnSegment, GroupByContextEngine, GroupBySegment, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OracleSelectStatement, OrderByItem, PostgreSQLSelectStatement, SQL92SelectStatement, SQLServerSelectStatement]. 44

org/apache/shardingsphere/infra/binder/context/segment/select/orderby/engine/OrderByContextEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, GroupByContext, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OracleSelectStatement, OrderByContextEngine, OrderByItem, OrderBySegment, PostgreSQLSelectStatement, ProjectionsSegment, SQL92SelectStatement, SQLServerSelectStatement]. 52

org/apache/shardingsphere/infra/binder/context/segment/select/pagination/PaginationContextTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [GroupBySegment, IndexOrderByItemSegment, MySQLSelectStatement, NumberLiteralLimitValueSegment, OracleSelectStatement, OrderBySegment, PaginationContext, ParameterMarkerLimitValueSegment, PostgreSQLSelectStatement, ProjectionsSegment, SQL92SelectStatement, SQLServerSelectStatement, SelectStatementContext, ShardingSphereMetaData]. 56

org/apache/shardingsphere/infra/binder/context/segment/select/pagination/engine/PaginationContextEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [LimitSegment, MySQLDatabaseType, MySQLSelectStatement, NumberLiteralLimitValueSegment, OracleSelectStatement, PaginationContextEngine, PostgreSQLDatabaseType, PostgreSQLSelectStatement, ProjectionsContext, ProjectionsSegment, SQL92DatabaseType, SQL92SelectStatement, SQLServerDatabaseType, SQLServerSelectStatement, SubqueryProjectionSegment, SubquerySegment, TopProjectionSegment, WhereSegment]. 49
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 49

org/apache/shardingsphere/infra/binder/context/segment/select/projection/engine/ProjectionEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, ColumnProjectionSegment, ColumnSegment, ExpressionProjectionSegment, IdentifierValue, OwnerSegment, ParameterMarkerExpressionSegment, ProjectionEngine, ShorthandProjectionSegment]. 52

org/apache/shardingsphere/infra/binder/context/segment/select/projection/engine/ProjectionsContextEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 25 (max allowed is 10) classes [AliasSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, ExpressionOrderByItemSegment, GroupByContext, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OracleSelectStatement, OrderByContext, OrderByItem, OwnerSegment, PostgreSQLSelectStatement, ProjectionsContextEngine, ProjectionsSegment, SQL92SelectStatement, SQLServerSelectStatement, SelectStatementContext, ShardingSphereMetaData, ShorthandProjectionSegment, SimpleTableSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment]. 67
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 67

org/apache/shardingsphere/infra/binder/context/statement/SQLStatementContextFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 41 (max allowed is 10) classes [AlterIndexStatementContext, AlterTableStatementContext, AlterViewStatementContext, AnalyzeTableStatementContext, CloseStatementContext, CommentStatementContext, CopyStatementContext, CreateFunctionStatementContext, CreateIndexStatementContext, CreateProcedureStatementContext, CreateSchemaStatementContext, CreateTableStatementContext, CreateViewStatementContext, CursorStatementContext, DeleteStatementContext, DenyUserStatementContext, DropIndexStatementContext, DropTableStatementContext, DropViewStatementContext, ExplainStatementContext, FetchStatementContext, FlushStatementContext, GrantStatementContext, InsertStatementContext, LoadDataStatementContext, LoadXMLStatementContext, MoveStatementContext, OptimizeTableStatementContext, PrepareStatementContext, RenameTableStatementContext, RevokeStatementContext, SelectStatementContext, ShowColumnsStatementContext, ShowCreateTableStatementContext, ShowIndexStatementContext, ShowTableStatusStatementContext, ShowTablesStatementContext, TruncateStatementContext, UnknownSQLStatementContext, UnsupportedSQLOperationException, UpdateStatementContext]. 117
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 91 (max allowed is 20). 117
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 145
 Warning metrics NPathComplexity NPath Complexity is 512 (max allowed is 200). 145
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 21 (max allowed is 10). 173
 Warning metrics NPathComplexity NPath Complexity is 1,048,576 (max allowed is 200). 173
 Warning metrics NPathComplexity NPath Complexity is 512 (max allowed is 200). 250

org/apache/shardingsphere/infra/binder/context/statement/SQLStatementContextFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 21 (max allowed is 10) classes [ColumnAssignmentSegment, ColumnSegment, HintValueContext, IdentifierValue, LimitSegment, MySQLAlterDatabaseStatement, MySQLInsertStatement, MySQLSelectStatement, OpenGaussCloseStatement, OpenGaussFetchStatement, OpenGaussMoveStatement, OracleInsertStatement, PostgreSQLInsertStatement, ProjectionsSegment, SQL92InsertStatement, SQLBindEngine, SQLServerInsertStatement, SetAssignmentSegment, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment]. 67
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 67

org/apache/shardingsphere/infra/binder/context/statement/ddl/AlterTableStatementContextTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AlterTableStatementContext, ConstraintSegment, IdentifierValue, IndexNameSegment, IndexSegment, MySQLAlterTableStatement, OracleAlterTableStatement, PostgreSQLAlterTableStatement, SQL92AlterTableStatement, SQLServerAlterTableStatement, SimpleTableSegment, TableNameSegment]. 56
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 56

org/apache/shardingsphere/infra/binder/context/statement/ddl/PrepareStatementContextTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ColumnAssignmentSegment, ColumnSegment, IdentifierValue, PostgreSQLDeleteStatement, PostgreSQLInsertStatement, PostgreSQLPrepareStatement, PostgreSQLSelectStatement, PostgreSQLUpdateStatement, PrepareStatementContext, SetAssignmentSegment, SimpleTableSegment, TableNameSegment]. 48

org/apache/shardingsphere/infra/binder/context/statement/dml/InsertStatementContext.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AtomicInteger, CaseInsensitiveMap, DatabaseTypeRegistry, GeneratedKeyContextEngine, InsertSelectContext, InsertValueContext, OnDuplicateUpdateContext, SelectStatementContext, TableExtractor, TablesContext, UnknownDatabaseException]. 63
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 63

org/apache/shardingsphere/infra/binder/context/statement/dml/InsertStatementContextTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 22 (max allowed is 10) classes [ColumnAssignmentSegment, ColumnSegment, IdentifierValue, InsertColumnsSegment, InsertStatementContext, InsertValuesSegment, LiteralExpressionSegment, MySQLInsertStatement, MySQLSelectStatement, OnDuplicateKeyColumnsSegment, OracleInsertStatement, OwnerSegment, ParameterMarkerExpressionSegment, PostgreSQLInsertStatement, ProjectionsSegment, SQL92InsertStatement, SQLServerInsertStatement, SetAssignmentSegment, ShardingSphereMetaData, SimpleTableSegment, SubquerySegment, TableNameSegment]. 71
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 71

org/apache/shardingsphere/infra/binder/context/statement/dml/SelectStatementContext.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 40 (max allowed is 20). 87

org/apache/shardingsphere/infra/binder/context/statement/dml/SelectStatementContextTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 30 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BinaryOperationExpression, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, GroupBySegment, IdentifierValue, IndexOrderByItemSegment, JoinTableSegment, LiteralExpressionSegment, MySQLSelectStatement, OracleSelectStatement, OrderBySegment, OwnerSegment, ParameterMarkerExpressionSegment, PostgreSQLSelectStatement, ProjectionsSegment, SQL92SelectStatement, SQLServerSelectStatement, SelectStatementContext, ShardingSphereMetaData, SimpleTableSegment, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, WhereSegment]. 76
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 36 (max allowed is 20). 76

org/apache/shardingsphere/infra/binder/engine/segment/expression/type/ColumnSegmentBinder.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 129
 Warning metrics NPathComplexity NPath Complexity is 640 (max allowed is 200). 129

org/apache/shardingsphere/infra/binder/engine/segment/expression/type/SubquerySegmentBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [ColumnProjectionSegment, ColumnSegment, ColumnSegmentBoundInfo, IdentifierValue, MySQLSelectStatement, ProjectionsSegment, SQLStatementBinderContext, ShardingSphereColumn, SimpleTableSegment, SimpleTableSegmentBinderContext, SubquerySegment, TableNameSegment, WhereSegment]. 58

org/apache/shardingsphere/infra/binder/engine/segment/from/type/SimpleTableSegmentBinder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [CaseInsensitiveSet, ColumnProjectionSegment, ColumnSegment, ColumnSegmentBoundInfo, DatabaseTypeRegistry, IdentifierValue, OwnerSegment, SimpleTableSegment, SimpleTableSegmentBinderContext, TableNameSegment, TableNotFoundException]. 56

org/apache/shardingsphere/infra/binder/engine/segment/from/type/SubqueryTableSegmentBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AliasSegment, ColumnProjectionSegment, ColumnSegment, IdentifierValue, ProjectionsSegment, SQLStatementBinderContext, ShardingSphereColumn, ShorthandProjectionSegment, SimpleTableSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment]. 60

org/apache/shardingsphere/infra/binder/engine/segment/projection/type/ShorthandProjectionSegmentBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AliasSegment, ColumnProjectionSegment, ColumnSegment, IdentifierValue, JoinTableSegment, OwnerSegment, ShorthandProjectionSegment, SimpleTableSegment, SimpleTableSegmentBinderContext, SubquerySegment, SubqueryTableSegment, TableNameSegment]. 47

org/apache/shardingsphere/infra/binder/engine/statement/DeleteStatementBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BinaryOperationExpression, ColumnSegment, DeleteStatementBinder, IdentifierValue, LiteralExpressionSegment, MySQLDeleteStatement, SQLStatementBinderContext, ShardingSphereColumn, SimpleTableSegment, TableNameSegment, WhereSegment]. 48

org/apache/shardingsphere/infra/binder/engine/statement/InsertStatementBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [ColumnProjectionSegment, ColumnSegment, IdentifierValue, InsertColumnsSegment, InsertStatementBinder, InsertValuesSegment, LiteralExpressionSegment, MySQLInsertStatement, MySQLSelectStatement, ProjectionsSegment, SQLStatementBinderContext, ShardingSphereColumn, SimpleTableSegment, SubquerySegment, TableNameSegment]. 55
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 55

org/apache/shardingsphere/infra/binder/engine/statement/SelectStatementBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [BinaryOperationExpression, ColumnProjectionSegment, ColumnSegment, FunctionSegment, IdentifierValue, LiteralExpressionSegment, MySQLSelectStatement, ProjectionsSegment, SQLStatementBinderContext, SelectStatementBinder, ShardingSphereColumn, SimpleTableSegment, TableNameSegment, WhereSegment]. 54

org/apache/shardingsphere/infra/binder/engine/statement/UpdateStatementBinderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BinaryOperationExpression, ColumnSegment, IdentifierValue, LiteralExpressionSegment, MySQLUpdateStatement, SQLStatementBinderContext, ShardingSphereColumn, SimpleTableSegment, TableNameSegment, UpdateStatementBinder, WhereSegment]. 48

org/apache/shardingsphere/infra/database/core/metadata/data/loader/MetaDataLoaderConnection.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 46

org/apache/shardingsphere/infra/database/core/metadata/data/loader/MetaDataLoaderConnectionTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 55

org/apache/shardingsphere/infra/database/core/resultset/ResultSetMapper.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 27 (max allowed is 10). 47

org/apache/shardingsphere/infra/datasource/pool/creator/DataSourcePoolReflection.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 130

org/apache/shardingsphere/infra/exception/mysql/mapper/MySQLDialectExceptionMapper.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 52
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 24 (max allowed is 10). 54
 Warning metrics NPathComplexity NPath Complexity is 4,718,592 (max allowed is 200). 54

org/apache/shardingsphere/infra/exception/postgresql/mapper/PostgreSQLDialectExceptionMapper.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 51
 Warning metrics NPathComplexity NPath Complexity is 8,192 (max allowed is 200). 51

org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilderTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [ExecutionUnit, GenericSQLRewriteResult, ResourceMetaData, RouteMapper, RouteSQLRewriteResult, RouteUnit, RuleMetaData, SQLRewriteUnit, SQLUnit, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereSchema, ShardingSphereTable]. 53

org/apache/shardingsphere/infra/executor/sql/execute/result/query/impl/driver/jdbc/type/memory/JDBCMemoryQueryResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BigDecimal, BufferedReader, ByteArrayInputStream, ByteArrayOutputStream, Date, InputStreamReader, JDBCMemoryQueryResult, ObjectOutputStream, SQLException, Time, Timestamp]. 56
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 56

org/apache/shardingsphere/infra/executor/sql/execute/result/query/impl/driver/jdbc/type/stream/JDBCStreamQueryResult.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 57
 Warning metrics NPathComplexity NPath Complexity is 65,536 (max allowed is 200). 57

org/apache/shardingsphere/infra/executor/sql/execute/result/query/impl/driver/jdbc/type/util/ResultSetUtils.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 56
 Warning metrics NPathComplexity NPath Complexity is 3,075 (max allowed is 200). 56
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 153

org/apache/shardingsphere/infra/hint/SQLHintUtils.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 58
 Warning metrics NPathComplexity NPath Complexity is 1,152 (max allowed is 200). 58

org/apache/shardingsphere/infra/merge/result/impl/local/LocalDataQueryResultRow.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 44
 Warning metrics NPathComplexity NPath Complexity is 4,860 (max allowed is 200). 44

org/apache/shardingsphere/infra/props/TypedPropertyValue.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 38
 Warning metrics NPathComplexity NPath Complexity is 300 (max allowed is 200). 38

org/apache/shardingsphere/infra/rewrite/SQLRewriteEntryTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [ConfigurationProperties, DefaultSQLTranslatorRuleConfigurationBuilder, HintValueContext, Properties, RouteContext, RouteMapper, RuleMetaData, SQLRewriteEntry, SQLTranslatorContext, SQLTranslatorRule, ShardingSphereDatabase]. 55

org/apache/shardingsphere/infra/rewrite/engine/RouteSQLRewriteEngine.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 53

org/apache/shardingsphere/mask/distsql/parser/core/MaskDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AlgorithmSegment, AlterMaskRuleStatement, CountRuleStatement, CreateMaskRuleStatement, DatabaseSegment, DropMaskRuleStatement, IdentifierValue, MaskColumnSegment, MaskRuleSegment, Properties, ShowMaskRulesStatement, ShowPluginsStatement]. 54
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 54

org/apache/shardingsphere/mode/manager/ContextManagerTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ComputeNodeInstance, ConfigurationProperties, ContextManager, JDBCInstanceMetaData, MockedDataSource, Properties, ProxyInstanceMetaData, ResourceMetaData, RuleAttributes, RuleMetaData, ShardingSphereDatabase, ShardingSphereSchema]. 69
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 69

org/apache/shardingsphere/mode/manager/cluster/ClusterContextManagerBuilder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [ClusterDeliverEventSubscriberRegistry, ClusterDispatchEventSubscriberRegistry, ClusterWorkerIdGenerator, ComputeNodeInstance, ComputeNodeInstanceContext, ContextManager, DataChangedEventListenerRegistry, EventSubscriberRegistry, GlobalLockContext, GlobalLockPersistService, MetaDataPersistService]. 51
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 51

org/apache/shardingsphere/mode/manager/cluster/event/subscriber/registry/ClusterDispatchEventSubscriberRegistry.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CacheEvictedSubscriber, ComputeNodeStateSubscriber, DatabaseDataChangedSubscriber, GlobalRuleConfigurationEventSubscriber, ListenerAssistedSubscriber, MetaDataChangedSubscriber, ProcessListChangedSubscriber, PropertiesEventSubscriber, QualifiedDataSourceSubscriber, RuleItemChangedSubscriber, StateChangedSubscriber, StorageUnitEventSubscriber]. 42

org/apache/shardingsphere/mode/manager/cluster/listener/DatabaseMetaDataChangedListener.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [AlterStorageNodeEvent, AlterStorageUnitEvent, CreateOrAlterTableEvent, CreateOrAlterViewEvent, DropTableEvent, DropViewEvent, RegisterStorageNodeEvent, RegisterStorageUnitEvent, RuleConfigurationEventBuilder, SchemaAddedEvent, SchemaDeletedEvent, UnregisterStorageNodeEvent, UnregisterStorageUnitEvent]. 50

org/apache/shardingsphere/mode/manager/standalone/persist/StandaloneMetaDataManagerPersistService.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 67

org/apache/shardingsphere/mode/manager/standalone/persist/StandaloneMetaDataManagerPersistServiceTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 66

org/apache/shardingsphere/mode/metadata/MetaDataContextManager.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ConfigurationProperties, DatabaseRuleConfigurationManager, GlobalConfigurationManager, MetaDataPersistService, ResourceSwitchManager, RuleConfigurationPersistDecorateEngine, RuleItemManager, RuleMetaData, SchemaMetaDataManager, ShardingSphereDatabaseDataManager, ShardingSphereMetaData, StorageUnitManager]. 51
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 51

org/apache/shardingsphere/mode/metadata/MetaDataContextsFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [ConfigurationProperties, DataSourceGeneratedDatabaseConfiguration, DataSourcePoolDestroyer, DataSourceProvidedDatabaseConfiguration, DatabaseTypeRegistry, MetaDataContexts, ResourceMetaData, RuleConfigurationPersistDecorateEngine, RuleMetaData, ShardingSphereMetaData, ShardingSphereStatistics]. 72
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 72

org/apache/shardingsphere/mode/metadata/MetaDataContextsFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 65

org/apache/shardingsphere/mode/repository/cluster/etcd/EtcdRepositoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 67

org/apache/shardingsphere/mode/repository/cluster/zookeeper/ZookeeperRepository.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 62

org/apache/shardingsphere/mode/repository/cluster/zookeeper/ZookeeperRepositoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 72

org/apache/shardingsphere/mode/tuple/RepositoryTupleSwapperEngine.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 83
 Warning metrics NPathComplexity NPath Complexity is 1,728 (max allowed is 200). 83
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 199

org/apache/shardingsphere/proxy/backend/connector/DatabaseConnector.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 20 (max allowed is 10) classes [BackendTransactionManager, ConcurrentHashMap, DriverExecutionPrepareEngine, EmptyRuleException, EmptyStorageUnitException, IteratorStreamMergedResult, JDBCQueryResultMetaData, JDBCStreamQueryResult, KernelProcessor, MergeEngine, MetaDataRefreshEngine, ProxySQLExecutor, QueryHeaderBuilderEngine, QueryResponseCell, QueryResponseHeader, QueryResponseRow, SQLException, SQLFederationContext, StatementOption, UpdateResponseHeader]. 98
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 55 (max allowed is 20). 98

org/apache/shardingsphere/proxy/backend/connector/DatabaseConnectorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [ConfigurationProperties, HintValueContext, MemoryMergedResult, Properties, QueryContext, QueryHeaderBuilderEngine, QueryHeaderBuilderFixture, RuleMetaData, SQLException, SQLParserRule, SQLParserRuleConfiguration, ShardingSphereColumn, ShardingSphereIndex, ShardingSphereMetaData, ShardingSphereTable]. 97
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 41 (max allowed is 20). 97

org/apache/shardingsphere/proxy/backend/connector/ProxyDatabaseConnectionManagerTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 91

org/apache/shardingsphere/proxy/backend/connector/ProxySQLExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [DatabaseTypeRegistry, DriverExecutionPrepareEngine, ExecutionGroupReportContext, JDBCExecutor, ProxyJDBCExecutor, RawExecutionPrepareEngine, RawExecutor, RawSQLExecutorCallback, SQLFederationEngine, SaneQueryResultEngine, StatementOption, TableModifyInTransactionException]. 86
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 43 (max allowed is 20). 86

org/apache/shardingsphere/proxy/backend/connector/ProxySQLExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 19 (max allowed is 10) classes [ContextManager, CreateTableStatementContext, ExecutionContext, HintValueContext, IdentifierValue, InsertStatementContext, MySQLCreateTableStatement, MySQLInsertStatement, MySQLTruncateStatement, PostgreSQLCreateTableStatement, PostgreSQLInsertStatement, PostgreSQLTruncateStatement, ProxySQLExecutor, QueryContext, RuleMetaData, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment, TruncateStatementContext]. 83
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 35 (max allowed is 20). 83

org/apache/shardingsphere/proxy/backend/connector/jdbc/datasource/JDBCBackendDataSourceTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 73

org/apache/shardingsphere/proxy/backend/connector/jdbc/transaction/BackendTransactionManagerTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 55

org/apache/shardingsphere/proxy/backend/handler/ProxyBackendHandlerFactory.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 71
 Warning metrics NPathComplexity NPath Complexity is 384 (max allowed is 200). 109

org/apache/shardingsphere/proxy/backend/handler/ProxyBackendHandlerFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AuthorityRule, ConfigurationProperties, DefaultAuthorityRuleConfigurationBuilder, DefaultSQLParserRuleConfigurationBuilder, DefaultTransactionRuleConfigurationBuilder, EmptyStatement, Grantee, HintValueContext, Properties, RuleMetaData, SQLParserRule, TransactionRule]. 84
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 84

org/apache/shardingsphere/proxy/backend/handler/admin/executor/DefaultDatabaseMetaDataExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 65

org/apache/shardingsphere/proxy/backend/handler/data/impl/UnicastDatabaseBackendHandlerTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 72

org/apache/shardingsphere/proxy/backend/handler/database/DatabaseOperateBackendHandlerFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 69

org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportDatabaseConfigurationExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [AlgorithmConfiguration, DatabaseSegment, ExportDatabaseConfigurationExecutor, ExportDatabaseConfigurationStatement, IdentifierValue, KeyGenerateStrategyConfiguration, MockedDataSource, NoneShardingStrategyConfiguration, Properties, Property, ShardingRuleConfiguration, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration]. 62
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 62

org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportMetaDataExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [AuthorityRule, ComputeNodeInstance, ComputeNodeInstanceContext, ConfigurationProperties, DefaultAuthorityRuleConfigurationBuilder, DefaultGlobalClockRuleConfigurationBuilder, EventBusContext, ExportMetaDataExecutor, ExportMetaDataStatement, GlobalClockRule, MockedDataSource, ModeConfiguration, Properties, Property, ResourceMetaData, RuleMetaData, ShardingSphereMetaData, StandaloneWorkerIdGenerator]. 90
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 36 (max allowed is 20). 90

org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportStorageNodesExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 17 (max allowed is 10) classes [AlgorithmConfiguration, AuthorityRule, ConfigurationProperties, DefaultAuthorityRuleConfigurationBuilder, ExportStorageNodesExecutor, ExportStorageNodesStatement, KeyGenerateStrategyConfiguration, MockedDataSource, NoneShardingStrategyConfiguration, Properties, Property, ResourceMetaData, RuleMetaData, ShardingRuleConfiguration, ShardingSphereMetaData, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration]. 79
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 79

org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportDatabaseConfigurationExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 64

org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportMetaDataExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [ConfigurationProperties, ImportMetaDataExecutor, ImportMetaDataStatement, MockedDataSource, Property, ShardingSphereColumn, ShardingSphereIndex, ShardingSphereSchema, ShardingSphereTable, StorageUnit, YamlDatabaseConfigurationImportExecutor]. 66
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 66

org/apache/shardingsphere/proxy/backend/handler/distsql/rul/PreviewExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [DatabaseTypeRegistry, DriverExecutionPrepareEngine, EmptyRuleException, JDBCExecutor, JDBCExecutorCallback, JDBCStreamQueryResult, KernelProcessor, LocalDataQueryResultRow, QueryContext, SQLBindEngine, SQLFederationContext, SQLFederationEngine, StatementOption]. 75
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 35 (max allowed is 20). 75

org/apache/shardingsphere/proxy/backend/handler/transaction/TransactionBackendHandler.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 49

org/apache/shardingsphere/proxy/backend/handler/transaction/TransactionBackendHandlerFactory.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 58
 Warning metrics NPathComplexity NPath Complexity is 864 (max allowed is 200). 58

org/apache/shardingsphere/proxy/backend/mysql/connector/sane/MySQLDialectSaneQueryResultEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ExpressionProjectionSegment, IdentifierValue, MySQLDialectSaneQueryResultEngine, MySQLInsertStatement, MySQLSelectStatement, MySQLSetStatement, MySQLShowOtherStatement, ProjectionsSegment, SQLException, SimpleTableSegment, TableNameSegment, VariableSegment]. 44

org/apache/shardingsphere/proxy/backend/mysql/handler/admin/MySQLAdminExecutorCreator.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [KillProcessExecutor, MySQLSetVariableAdminExecutor, NoResourceShowExecutor, ShowConnectionIdExecutor, ShowCreateDatabaseExecutor, ShowCurrentDatabaseExecutor, ShowCurrentUserExecutor, ShowDatabasesExecutor, ShowFunctionStatusExecutor, ShowProcedureStatusExecutor, ShowProcessListExecutor, ShowTablesExecutor, ShowVersionExecutor, UnicastResourceShowExecutor, UseDatabaseExecutor]. 62
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 62
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 77
 Warning metrics NPathComplexity NPath Complexity is 1,024 (max allowed is 200). 77

org/apache/shardingsphere/proxy/backend/mysql/handler/admin/MySQLAdminExecutorCreatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 22 (max allowed is 10) classes [ConfigurationProperties, ExpressionProjectionSegment, IdentifierValue, MockedDataSource, MySQLAdminExecutorCreator, MySQLDeleteStatement, MySQLSetStatement, MySQLShowCreateDatabaseStatement, MySQLShowDatabasesStatement, MySQLShowFunctionStatusStatement, MySQLShowProcedureStatusStatement, MySQLShowProcessListStatement, MySQLShowTablesStatement, MySQLUseStatement, OwnerSegment, Properties, ResourceMetaData, ShardingSphereDatabase, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment, VariableSegment]. 89
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 89

org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowDatabasesExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 67

org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowTablesExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ConfigurationProperties, DatabaseSegment, FromDatabaseSegment, IdentifierValue, MySQLShowTablesStatement, Properties, RuleMetaData, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable, ShowLikeSegment, ShowTablesExecutor]. 68
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 68

org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/UnicastResourceShowExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 60

org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/information/SelectInformationSchemataExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ConfigurationProperties, DatabasePermittedPrivileges, DefaultSQLParserRuleConfigurationBuilder, Grantee, MockedDataSource, Properties, ResourceMetaData, RuleMetaData, SQLParserRule, SelectInformationSchemataExecutor, ShardingSphereDatabase, ShardingSphereMetaData]. 77
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 77

org/apache/shardingsphere/proxy/backend/opengauss/handler/admin/OpenGaussSystemCatalogAdminQueryExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [DriverExecutionPrepareEngine, IteratorStreamMergedResult, JDBCExecutor, JDBCExecutorCallback, JDBCMemoryQueryResult, JDBCQueryResultMetaData, JDBCStreamQueryResult, QueryContext, SQLFederationContext, SQLFederationEngine, StatementOption]. 64
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 64

org/apache/shardingsphere/proxy/backend/opengauss/handler/admin/OpenGaussSystemCatalogAdminQueryExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 25 (max allowed is 10) classes [BinaryOperationExpression, CacheOption, ColumnProjectionSegment, ColumnSegment, ConfigurationProperties, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, LiteralExpressionSegment, OpenGaussSelectStatement, OpenGaussSystemCatalogAdminQueryExecutor, ProjectionsSegment, Properties, RuleMetaData, SQLFederationRule, SQLFederationRuleConfiguration, SelectStatementContext, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable, SimpleTableSegment, TableNameSegment, WhereSegment]. 75
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 33 (max allowed is 20). 75

org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/PostgreSQLAdminExecutorCreatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CacheOption, DeleteStatementContext, PostgreSQLAdminExecutorCreator, PostgreSQLDeleteStatement, PostgreSQLInsertStatement, PostgreSQLResetParameterStatement, PostgreSQLSelectStatement, PostgreSQLSetStatement, PostgreSQLShowStatement, SQLParserRule, SQLParserRuleConfiguration, UnknownSQLStatementContext]. 54

org/apache/shardingsphere/proxy/backend/util/YamlDatabaseConfigurationImportExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 65

org/apache/shardingsphere/proxy/frontend/command/CommandExecutorTaskTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 57

org/apache/shardingsphere/proxy/frontend/mysql/authentication/MySQLAuthenticationEngine.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [AccessDeniedException, AuthenticatorFactory, AuthorityChecker, DatabaseAccessDeniedException, Grantee, HandshakeException, MySQLAuthSwitchRequestPacket, MySQLAuthSwitchResponsePacket, MySQLAuthenticationPluginData, MySQLHandshakePacket, MySQLHandshakeResponse41Packet, MySQLOKPacket, MySQLSSLRequestHandler, ShardingSphereUser, UnknownDatabaseException]. 66
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 66

org/apache/shardingsphere/proxy/frontend/mysql/authentication/MySQLAuthenticationEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 94

org/apache/shardingsphere/proxy/frontend/mysql/command/MySQLCommandExecutorFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [MySQLComFieldListPacketExecutor, MySQLComInitDbExecutor, MySQLComPingExecutor, MySQLComQueryPacketExecutor, MySQLComQuitExecutor, MySQLComResetConnectionExecutor, MySQLComSetOptionExecutor, MySQLComStmtCloseExecutor, MySQLComStmtExecuteExecutor, MySQLComStmtPrepareExecutor, MySQLComStmtResetExecutor, MySQLComStmtSendLongDataExecutor, MySQLUnsupportedCommandExecutor]. 56
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 56
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 69

org/apache/shardingsphere/proxy/frontend/mysql/command/MySQLCommandPacketFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [MySQLComFieldListPacket, MySQLComInitDbPacket, MySQLComPingPacket, MySQLComQueryPacket, MySQLComQuitPacket, MySQLComResetConnectionPacket, MySQLComSetOptionPacket, MySQLComStmtClosePacket, MySQLComStmtExecutePacket, MySQLComStmtPreparePacket, MySQLComStmtResetPacket, MySQLComStmtSendLongDataPacket, MySQLUnsupportedCommandPacket]. 44
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 55

org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/execute/MySQLComStmtExecuteExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 59

org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/execute/MySQLComStmtExecuteExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [ColumnAssignmentSegment, ColumnSegment, HintValueContext, IdentifierValue, MySQLComStmtExecuteExecutor, MySQLCommitStatement, MySQLSelectStatement, MySQLServerPreparedStatement, MySQLUpdateStatement, ParameterMarkerExpressionSegment, ProjectionsSegment, QueryResponseCell, QueryResponseHeader, QueryResponseRow, SetAssignmentSegment, ShardingSphereMetaData, UnknownSQLStatementContext, UpdateResponseHeader]. 91
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 36 (max allowed is 20). 91

org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareCheckerTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 55 (max allowed is 10) classes [MySQLAlterTableStatement, MySQLAlterUserStatement, MySQLAnalyzeTableStatement, MySQLCacheIndexStatement, MySQLCallStatement, MySQLChangeMasterStatement, MySQLChecksumTableStatement, MySQLCommitStatement, MySQLCreateDatabaseStatement, MySQLCreateIndexStatement, MySQLCreateTableStatement, MySQLCreateUserStatement, MySQLCreateViewStatement, MySQLDeleteStatement, MySQLDoStatement, MySQLDropDatabaseStatement, MySQLDropIndexStatement, MySQLDropTableStatement, MySQLDropUserStatement, MySQLDropViewStatement, MySQLFlushStatement, MySQLGrantStatement, MySQLInsertStatement, MySQLInstallPluginStatement, MySQLKillStatement, MySQLLoadIndexInfoStatement, MySQLOptimizeTableStatement, MySQLRenameTableStatement, MySQLRenameUserStatement, MySQLRepairTableStatement, MySQLResetStatement, MySQLRevokeStatement, MySQLSelectStatement, MySQLSetStatement, MySQLShowBinaryLogsStatement, MySQLShowBinlogEventsStatement, MySQLShowCreateEventStatement, MySQLShowCreateFunctionStatement, MySQLShowCreateProcedureStatement, MySQLShowCreateTableStatement, MySQLShowCreateViewStatement, MySQLShowErrorsStatement, MySQLShowStatusStatement, MySQLShowWarningsStatement, MySQLStartSlaveStatement, MySQLStopSlaveStatement, MySQLTruncateStatement, MySQLUninstallPluginStatement, MySQLUpdateStatement, XABeginStatement, XACommitStatement, XAEndStatement, XAPrepareStatement, XARecoveryStatement, XARollbackStatement]. 83
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 57 (max allowed is 20). 83

org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 69

org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [CacheOption, HintValueContext, MySQLComStmtPrepareExecutor, MySQLPacketPayload, ResourceMetaData, RuleMetaData, SQLParserRule, SQLParserRuleConfiguration, ServerPreparedStatementRegistry, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereSchema, ShardingSphereTable]. 83
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 83

org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLComQueryPacketExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [DefaultLoggingRuleConfigurationBuilder, DefaultSQLParserRuleConfigurationBuilder, DefaultSQLTranslatorRuleConfigurationBuilder, LoggingRule, MySQLComQueryPacketExecutor, QueryResponseHeader, ResourceMetaData, RuleMetaData, SQLParserRule, SQLTranslatorRule, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereSchema, ShardingSphereTable, UpdateResponseHeader]. 79
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 79

org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandler.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 33 (max allowed is 20). 77

org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandlerTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 68

org/apache/shardingsphere/proxy/frontend/netty/CDCChannelInboundHandler.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 67

org/apache/shardingsphere/proxy/frontend/opengauss/authentication/OpenGaussAuthenticationEngine.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [AuthenticatorFactory, AuthorityChecker, Grantee, InvalidPasswordException, OpenGaussAuthenticationHexData, OpenGaussAuthenticationSCRAMSha256Packet, PostgreSQLAuthenticationOKPacket, PostgreSQLComStartupPacket, PostgreSQLMD5PasswordAuthenticationPacket, PostgreSQLParameterStatusPacket, PostgreSQLPasswordMessagePacket, PostgreSQLSSLUnwillingPacket, PostgreSQLSSLWillingPacket, PrivilegeNotGrantedException, ProtocolViolationException, SslHandler, UnknownDatabaseException, UnknownUsernameException]. 73
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 73

org/apache/shardingsphere/proxy/frontend/opengauss/authentication/OpenGaussAuthenticationEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 71

org/apache/shardingsphere/proxy/frontend/opengauss/command/OpenGaussCommandExecutorFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [OpenGaussComBatchBindExecutor, OpenGaussComQueryExecutor, PostgreSQLAggregatedBatchedStatementsCommandExecutor, PostgreSQLAggregatedCommandExecutor, PostgreSQLComBindExecutor, PostgreSQLComCloseExecutor, PostgreSQLComDescribeExecutor, PostgreSQLComExecuteExecutor, PostgreSQLComFlushExecutor, PostgreSQLComParseExecutor, PostgreSQLComSyncExecutor, PostgreSQLComTerminationExecutor, PostgreSQLUnsupportedCommandExecutor]. 60
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 60
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 113

org/apache/shardingsphere/proxy/frontend/opengauss/command/OpenGaussCommandExecutorFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 69

org/apache/shardingsphere/proxy/frontend/opengauss/command/query/extended/bind/OpenGaussComBatchBindExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [CacheOption, ConnectionContext, DefaultLoggingRuleConfigurationBuilder, DefaultSQLTranslatorRuleConfigurationBuilder, HintValueContext, LoggingRule, OpenGaussComBatchBindExecutor, PostgreSQLServerPreparedStatement, RuleMetaData, SQLTranslatorRule, ServerPreparedStatementRegistry, ShardingSphereColumn, ShardingSphereSQLParserEngine]. 79
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 79

org/apache/shardingsphere/proxy/frontend/opengauss/command/query/simple/OpenGaussComQueryExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 61

org/apache/shardingsphere/proxy/frontend/postgresql/authentication/PostgreSQLAuthenticationEngine.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 17 (max allowed is 10) classes [AuthenticatorFactory, AuthorityChecker, Grantee, InvalidPasswordException, PostgreSQLAuthenticationOKPacket, PostgreSQLComStartupPacket, PostgreSQLMD5PasswordAuthenticationPacket, PostgreSQLParameterStatusPacket, PostgreSQLPasswordAuthenticationPacket, PostgreSQLPasswordMessagePacket, PostgreSQLSSLUnwillingPacket, PostgreSQLSSLWillingPacket, PrivilegeNotGrantedException, ProtocolViolationException, SslHandler, UnknownDatabaseException, UnknownUsernameException]. 69
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 69

org/apache/shardingsphere/proxy/frontend/postgresql/authentication/PostgreSQLAuthenticationEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AlgorithmConfiguration, AuthorityRuleBuilder, AuthorityRuleConfiguration, ConfigurationProperties, PostgreSQLAuthenticationEngine, PostgreSQLMD5PasswordAuthenticator, PostgreSQLPacketPayload, Properties, RuleMetaData, ShardingSphereMetaData, UnpooledHeapByteBuf, UserConfiguration]. 78
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 78

org/apache/shardingsphere/proxy/frontend/postgresql/command/PostgreSQLCommandExecutorFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [PostgreSQLAggregatedBatchedStatementsCommandExecutor, PostgreSQLAggregatedCommandExecutor, PostgreSQLComBindExecutor, PostgreSQLComCloseExecutor, PostgreSQLComDescribeExecutor, PostgreSQLComExecuteExecutor, PostgreSQLComFlushExecutor, PostgreSQLComParseExecutor, PostgreSQLComQueryExecutor, PostgreSQLComSyncExecutor, PostgreSQLComTerminationExecutor, PostgreSQLUnsupportedCommandExecutor]. 55
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 55

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/Portal.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 67

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PortalTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [HintValueContext, Portal, PostgreSQLEmptyStatement, PostgreSQLInsertStatement, PostgreSQLSelectStatement, PostgreSQLServerPreparedStatement, PostgreSQLSetStatement, QueryHeader, QueryResponseCell, QueryResponseRow, UnknownSQLStatementContext, VariableAssignSegment, VariableSegment]. 96
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 96

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PostgreSQLAggregatedBatchedStatementsCommandExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [CacheOption, ConnectionContext, DefaultLoggingRuleConfigurationBuilder, DefaultSQLTranslatorRuleConfigurationBuilder, HintValueContext, LoggingRule, PostgreSQLAggregatedBatchedStatementsCommandExecutor, PostgreSQLServerPreparedStatement, RuleMetaData, SQLTranslatorRule, ServerPreparedStatementRegistry, ShardingSphereColumn, ShardingSphereSQLParserEngine]. 81
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 81

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PostgreSQLBatchedStatementsExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 71

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/PostgreSQLBatchedStatementsExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [ConnectionContext, DefaultLoggingRuleConfigurationBuilder, DefaultSQLTranslatorRuleConfigurationBuilder, HintValueContext, IdentifierValue, LoggingRule, PostgreSQLBatchedStatementsExecutor, PostgreSQLServerPreparedStatement, PostgreSQLTypeUnspecifiedSQLParameter, RuleMetaData, SQLTranslatorRule, ShardingSphereColumn, SimpleTableSegment, TableNameSegment]. 80
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 80

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/describe/PostgreSQLComDescribeExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 39 (max allowed is 20). 80

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/describe/PostgreSQLComDescribeExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [CacheOption, DefaultLoggingRuleConfigurationBuilder, DefaultSQLTranslatorRuleConfigurationBuilder, HintValueContext, LoggingRule, PostgreSQLColumnDescription, PostgreSQLComDescribeExecutor, PostgreSQLServerPreparedStatement, RuleMetaData, SQLTranslatorRule, ServerPreparedStatementRegistry, ShardingSphereColumn, ShardingSphereSQLParserEngine, ShardingSphereTable]. 100
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 43 (max allowed is 20). 100

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/extended/parse/PostgreSQLComParseExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 70

org/apache/shardingsphere/proxy/frontend/postgresql/command/query/simple/PostgreSQLComQueryExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 26 (max allowed is 20). 61

org/apache/shardingsphere/readwritesplitting/distsql/parser/core/ReadwriteSplittingDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AlgorithmSegment, AlterReadwriteSplittingRuleStatement, AlterReadwriteSplittingStorageUnitStatusStatement, CountRuleStatement, CreateReadwriteSplittingRuleStatement, DatabaseSegment, DropReadwriteSplittingRuleStatement, IdentifierValue, Properties, ReadwriteSplittingRuleSegment, ShowReadwriteSplittingRulesStatement, ShowStatusFromReadwriteSplittingRulesStatement]. 54
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 54

org/apache/shardingsphere/readwritesplitting/route/ReadwriteSplittingSQLRouterTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [ConfigurationProperties, HintValueContext, Properties, QueryContext, ReadwriteSplittingDataSourceGroupRuleConfiguration, ReadwriteSplittingRule, ReadwriteSplittingRuleConfiguration, RouteContext, RouteMapper, RouteUnit, RuleMetaData, ShardingSphereDatabase]. 63
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 63

org/apache/shardingsphere/shadow/distsql/parser/core/ShadowDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 19 (max allowed is 10) classes [AlgorithmSegment, AlterDefaultShadowAlgorithmStatement, AlterShadowRuleStatement, CountRuleStatement, CreateDefaultShadowAlgorithmStatement, CreateShadowRuleStatement, DatabaseSegment, DropDefaultShadowAlgorithmStatement, DropShadowAlgorithmStatement, DropShadowRuleStatement, IdentifierValue, Properties, ShadowAlgorithmSegment, ShadowRuleSegment, ShowDefaultShadowAlgorithmStatement, ShowPluginsStatement, ShowShadowAlgorithmsStatement, ShowShadowRulesStatement, ShowShadowTableRulesStatement]. 73
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 41 (max allowed is 20). 73

org/apache/shardingsphere/shadow/route/engine/impl/ShadowNonDMLStatementRoutingEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AlgorithmConfiguration, HintValueContext, Property, RouteContext, RouteMapper, RouteUnit, ShadowDataSourceConfiguration, ShadowNonDMLStatementRoutingEngine, ShadowRule, ShadowRuleConfiguration, ShadowTableConfiguration]. 41

org/apache/shardingsphere/sharding/algorithm/sharding/datetime/IntervalShardingAlgorithm.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 54

org/apache/shardingsphere/sharding/cache/checker/ShardingRouteCacheableChecker.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 63
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 119

org/apache/shardingsphere/sharding/cache/checker/ShardingRouteCacheableCheckerTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 28 (max allowed is 10) classes [AlgorithmConfiguration, CacheOption, ComputeNodeInstanceContext, HintValueContext, MockedDataSource, Properties, Property, QueryContext, ResourceMetaData, RuleMetaData, SQLBindEngine, SQLStatementParserEngine, ShardingAutoTableRuleConfiguration, ShardingCacheConfiguration, ShardingCacheOptionsConfiguration, ShardingRouteCacheableChecker, ShardingRule, ShardingRuleConfiguration, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable, ShardingTableReferenceRuleConfiguration, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration, TimestampServiceRule, TimestampServiceRuleConfiguration]. 77
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 34 (max allowed is 20). 77

org/apache/shardingsphere/sharding/decider/ShardingSQLFederationDecider.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 38

org/apache/shardingsphere/sharding/distsql/checker/ShardingRuleStatementCheckerTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 19 (max allowed is 10) classes [AlgorithmConfiguration, AlgorithmSegment, AuditStrategySegment, AutoTableRuleSegment, KeyGenerateStrategyConfiguration, KeyGenerateStrategySegment, MockedDataSource, Properties, Property, ResourceMetaData, RuleMetaData, ShardingAuditorSegment, ShardingAutoTableRuleConfiguration, ShardingRuleConfiguration, ShardingStrategySegment, ShardingTableReferenceRuleConfiguration, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration, TableRuleSegment]. 70
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 70

org/apache/shardingsphere/sharding/distsql/handler/checker/ShardingTableRuleStatementChecker.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [AlgorithmInitializationException, BindingTableCheckedConfiguration, CaseInsensitiveSet, DataNode, DuplicateRuleException, DuplicateShardingActualDataNodeException, InvalidAlgorithmConfigurationException, InvalidRuleConfigurationException, InvalidShardingStrategyConfigurationException, MissingRequiredRuleException, MissingRequiredStorageUnitsException, NoneShardingStrategyConfiguration, ShardingAlgorithmClassImplementationException, ShardingRuleConfiguration, ShardingTable, ShardingTableRuleNotFoundException]. 85
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 33 (max allowed is 20). 85

org/apache/shardingsphere/sharding/distsql/handler/converter/ShardingTableRuleStatementConverter.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 60

org/apache/shardingsphere/sharding/distsql/parser/core/ShardingDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 39 (max allowed is 10) classes [AlgorithmSegment, AlterDefaultShardingStrategyStatement, AlterShardingTableReferenceRuleStatement, AlterShardingTableRuleStatement, AuditStrategySegment, AutoTableRuleSegment, CountRuleStatement, CreateDefaultShardingStrategyStatement, CreateShardingTableReferenceRuleStatement, CreateShardingTableRuleStatement, DatabaseSegment, DropDefaultShardingStrategyStatement, DropShardingAlgorithmStatement, DropShardingAuditorStatement, DropShardingKeyGeneratorStatement, DropShardingTableReferenceRuleStatement, DropShardingTableRuleStatement, IdentifierValue, KeyGenerateStrategySegment, Properties, ShardingAuditorSegment, ShardingStrategySegment, ShowDefaultShardingStrategyStatement, ShowPluginsStatement, ShowShardingAlgorithmsStatement, ShowShardingAuditorsStatement, ShowShardingKeyGeneratorsStatement, ShowShardingTableNodesStatement, ShowShardingTableReferenceRulesStatement, ShowShardingTableRulesStatement, ShowShardingTableRulesUsedAlgorithmStatement, ShowShardingTableRulesUsedAuditorStatement, ShowShardingTableRulesUsedKeyGeneratorStatement, ShowUnusedShardingAlgorithmsStatement, ShowUnusedShardingAuditorsStatement, ShowUnusedShardingKeyGeneratorsStatement, TableNameSegment, TableReferenceRuleSegment, TableRuleSegment]. 119
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 88 (max allowed is 20). 119

org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRuleExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AlgorithmConfiguration, KeyGenerateStrategyConfiguration, LocalDataQueryResultRow, NoneShardingStrategyConfiguration, Properties, Property, ShardingAuditStrategyConfiguration, ShardingRuleConfiguration, ShardingTableRuleConfiguration, ShowShardingTableRulesStatement, StandardShardingStrategyConfiguration]. 62

org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRulesUsedAlgorithmExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AlgorithmConfiguration, KeyGenerateStrategyConfiguration, LocalDataQueryResultRow, NoneShardingStrategyConfiguration, Properties, Property, ShardingAutoTableRuleConfiguration, ShardingRuleConfiguration, ShardingTableRuleConfiguration, ShowShardingTableRulesUsedAlgorithmStatement, StandardShardingStrategyConfiguration]. 62

org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRulesUsedAuditorExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AlgorithmConfiguration, LocalDataQueryResultRow, NoneShardingStrategyConfiguration, Properties, Property, ShardingAuditStrategyConfiguration, ShardingAutoTableRuleConfiguration, ShardingRuleConfiguration, ShardingTableRuleConfiguration, ShowShardingTableRulesUsedAuditorStatement, StandardShardingStrategyConfiguration]. 63

org/apache/shardingsphere/sharding/distsql/query/ShowShardingTableRulesUsedKeyGeneratorExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AlgorithmConfiguration, KeyGenerateStrategyConfiguration, LocalDataQueryResultRow, NoneShardingStrategyConfiguration, Properties, Property, ShardingAutoTableRuleConfiguration, ShardingRuleConfiguration, ShardingTableRuleConfiguration, ShowShardingTableRulesUsedKeyGeneratorStatement, StandardShardingStrategyConfiguration]. 62

org/apache/shardingsphere/sharding/distsql/update/AlterShardingTableRuleExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 20 (max allowed is 10) classes [AlgorithmConfiguration, AlgorithmSegment, AlterShardingTableRuleExecutor, AlterShardingTableRuleStatement, AutoTableRuleSegment, KeyGenerateStrategyConfiguration, KeyGenerateStrategySegment, MockedDataSource, Properties, Property, ResourceMetaData, RuleMetaData, ShardingAutoTableRuleConfiguration, ShardingDistSQLParserFacade, ShardingRuleChecker, ShardingRuleConfiguration, ShardingStrategySegment, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration, TableRuleSegment]. 66
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 66

org/apache/shardingsphere/sharding/distsql/update/CreateShardingTableRuleExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 21 (max allowed is 10) classes [AlgorithmConfiguration, AlgorithmSegment, AutoTableRuleSegment, CreateShardingTableRuleExecutor, CreateShardingTableRuleStatement, KeyGenerateStrategyConfiguration, KeyGenerateStrategySegment, MockedDataSource, Properties, Property, ResourceMetaData, RuleAttributes, RuleMetaData, ShardingAutoTableRuleConfiguration, ShardingDistSQLParserFacade, ShardingRuleChecker, ShardingRuleConfiguration, ShardingStrategySegment, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration, TableRuleSegment]. 75
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 75

org/apache/shardingsphere/sharding/distsql/update/DropShardingTableRuleExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [DropShardingTableRuleExecutor, DropShardingTableRuleStatement, IdentifierValue, KeyGenerateStrategyConfiguration, ShardingAuditStrategyConfiguration, ShardingAutoTableRuleConfiguration, ShardingRuleConfiguration, ShardingTableReferenceRuleConfiguration, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration, TableNameSegment]. 55

org/apache/shardingsphere/sharding/merge/ShardingResultMergerEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 21 (max allowed is 10) classes [ColumnSegment, ConfigurationProperties, IdentifierValue, InsertColumnsSegment, InsertStatementContext, MySQLInsertStatement, MySQLSelectStatement, OpenGaussFetchStatement, OracleSelectStatement, PostgreSQLSelectStatement, PostgreSQLShowStatement, ProjectionsSegment, Properties, SQL92SelectStatement, SQLServerSelectStatement, SelectStatementContext, ShardingResultMergerEngine, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment, UnknownSQLStatementContext]. 63
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 63

org/apache/shardingsphere/sharding/merge/dal/ShardingDALResultMerger.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 52

org/apache/shardingsphere/sharding/merge/ddl/ShardingDDLResultMergerTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CursorConnectionContext, CursorNameSegment, FetchStatementContext, IdentifierValue, MySQLSelectStatement, OpenGaussFetchStatement, ProjectionsSegment, SelectStatementContext, ShardingDDLResultMerger, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment]. 57

org/apache/shardingsphere/sharding/merge/ddl/fetch/FetchStreamMergedResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [CursorConnectionContext, CursorNameSegment, CursorStatementContext, DirectionSegment, FetchStatementContext, IdentifierValue, OpenGaussCursorStatement, OpenGaussFetchStatement, OpenGaussSelectStatement, ProjectionsSegment, ShardingDDLResultMerger, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment]. 65
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 65

org/apache/shardingsphere/sharding/merge/dql/ShardingDQLResultMerger.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 53

org/apache/shardingsphere/sharding/merge/dql/ShardingDQLResultMergerTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 23 (max allowed is 10) classes [AggregationProjectionSegment, ColumnSegment, GroupBySegment, IdentifierValue, IndexOrderByItemSegment, LimitSegment, LiteralExpressionSegment, MySQLSelectStatement, NumberLiteralLimitValueSegment, NumberLiteralRowNumberValueSegment, OracleSelectStatement, OrderBySegment, ProjectionsSegment, SQLServerSelectStatement, SelectStatementContext, ShardingDQLResultMerger, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable, SimpleTableSegment, TableNameSegment]. 81
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 37 (max allowed is 20). 81

org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByMemoryMergedResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [AggregationProjectionSegment, BigDecimal, GroupBySegment, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OrderBySegment, ProjectionsSegment, SelectStatementContext, ShardingDQLResultMerger, ShardingSphereMetaData, ShorthandProjectionSegment, SimpleTableSegment, TableNameSegment]. 71
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 71

org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByRowComparatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [GroupByRowComparator, GroupBySegment, IndexOrderByItemSegment, MemoryQueryResultRow, MySQLSelectStatement, OracleSelectStatement, OrderBySegment, PostgreSQLSelectStatement, ProjectionsSegment, SQL92SelectStatement, SQLServerSelectStatement, SelectStatementContext, ShardingSphereMetaData]. 58

org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByStreamMergedResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [AggregationProjectionSegment, BigDecimal, Date, GroupBySegment, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OrderBySegment, ProjectionsSegment, SelectStatementContext, ShardingDQLResultMerger, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable, SimpleTableSegment, TableNameSegment]. 65
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 65

org/apache/shardingsphere/sharding/merge/dql/orderby/CompareUtils.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 41
 Warning metrics NPathComplexity NPath Complexity is 216 (max allowed is 200). 41

org/apache/shardingsphere/sharding/merge/dql/orderby/OrderByStreamMergedResultTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OrderBySegment, ProjectionsSegment, SelectStatementContext, ShardingDQLResultMerger, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable, SimpleTableSegment, TableNameSegment]. 62

org/apache/shardingsphere/sharding/merge/dql/orderby/OrderByValueTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [ColumnOrderByItemSegment, ColumnSegment, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, OracleSelectStatement, OrderByItem, OrderBySegment, OrderByValue, PostgreSQLSelectStatement, ProjectionsSegment, SQL92SelectStatement, SQLServerSelectStatement, SelectStatementContext, ShardingSphereMetaData, ShardingSphereTable]. 61
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 61

org/apache/shardingsphere/sharding/rewrite/token/ShardingTokenGenerateBuilder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 17 (max allowed is 10) classes [GeneratedKeyAssignmentTokenGenerator, GeneratedKeyForUseDefaultInsertColumnsTokenGenerator, GeneratedKeyInsertColumnTokenGenerator, GeneratedKeyInsertValuesTokenGenerator, ShardingAggregationDistinctTokenGenerator, ShardingConstraintTokenGenerator, ShardingCursorTokenGenerator, ShardingDistinctProjectionPrefixTokenGenerator, ShardingFetchDirectionTokenGenerator, ShardingIndexTokenGenerator, ShardingInsertValuesTokenGenerator, ShardingOffsetTokenGenerator, ShardingOrderByTokenGenerator, ShardingProjectionsTokenGenerator, ShardingRemoveTokenGenerator, ShardingRowCountTokenGenerator, ShardingTableTokenGenerator]. 52
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 52

org/apache/shardingsphere/sharding/rewrite/token/generator/ShardingRemoveTokenGeneratorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [AggregationDistinctProjectionSegment, GroupBySegment, IdentifierValue, IndexOrderByItemSegment, MySQLSelectStatement, ProjectionsSegment, SelectStatementContext, ShardingRemoveTokenGenerator, ShardingSphereMetaData, SimpleTableSegment, TableNameSegment]. 56

org/apache/shardingsphere/sharding/rewrite/token/generator/impl/ShardingProjectionsTokenGenerator.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 55

org/apache/shardingsphere/sharding/route/engine/condition/engine/InsertClauseShardingConditionEngine.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 55

org/apache/shardingsphere/sharding/route/engine/condition/engine/InsertClauseShardingConditionEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CommonExpressionSegment, IdentifierValue, InsertClauseShardingConditionEngine, InsertValueContext, LiteralExpressionSegment, ParameterMarkerExpressionSegment, Properties, ShardingTable, SimpleTableSegment, TableNameSegment, TimestampServiceRule, TimestampServiceRuleConfiguration]. 67
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 67

org/apache/shardingsphere/sharding/route/engine/condition/engine/WhereClauseShardingConditionEngine.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 62

org/apache/shardingsphere/sharding/route/engine/condition/generator/ConditionValueGeneratorFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [BetweenExpression, BinaryOperationExpression, Column, ColumnSegment, ConditionValueBetweenOperatorGenerator, ConditionValueCompareOperatorGenerator, ConditionValueInOperatorGenerator, IdentifierValue, InExpression, ListExpression, LiteralExpressionSegment, ParameterMarkerExpressionSegment]. 46

org/apache/shardingsphere/sharding/route/engine/condition/generator/impl/ConditionValueBetweenOperatorGeneratorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BetweenExpression, Column, ColumnSegment, CommonExpressionSegment, ConditionValueBetweenOperatorGenerator, IdentifierValue, LiteralExpressionSegment, ParameterMarkerExpressionSegment, Properties, TimestampServiceRule, TimestampServiceRuleConfiguration]. 54

org/apache/shardingsphere/sharding/route/engine/condition/generator/impl/ConditionValueCompareOperatorGenerator.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 81

org/apache/shardingsphere/sharding/route/engine/condition/generator/impl/ConditionValueInOperatorGeneratorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [Column, ColumnSegment, CommonExpressionSegment, ConditionValueInOperatorGenerator, IdentifierValue, InExpression, ListExpression, LiteralExpressionSegment, ParameterMarkerExpressionSegment, Properties, TimestampServiceRule, TimestampServiceRuleConfiguration]. 47

org/apache/shardingsphere/sharding/route/engine/fixture/ShardingRoutingEngineFixtureBuilder.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [AlgorithmConfiguration, H2DatabaseType, HintShardingStrategyConfiguration, ListShardingConditionValue, MockedDataSource, Properties, Property, ShardingCondition, ShardingConditions, ShardingRule, ShardingRuleConfiguration, ShardingTableReferenceRuleConfiguration, ShardingTableRuleConfiguration, SingleRule, SingleRuleConfiguration, StandardShardingStrategyConfiguration, TimestampServiceRule, TimestampServiceRuleConfiguration]. 68
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 68

org/apache/shardingsphere/sharding/route/engine/type/ShardingRouteEngineFactory.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 46 (max allowed is 20). 74
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 109
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 143
 Warning metrics NPathComplexity NPath Complexity is 1,440 (max allowed is 200). 143

org/apache/shardingsphere/sharding/route/engine/type/ShardingRouteEngineFactoryTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [ConfigurationProperties, GrantStatementContext, HintValueContext, IdentifierValue, MySQLGrantStatement, OracleGrantStatement, PostgreSQLGrantStatement, Properties, QueryContext, SQL92GrantStatement, SQLServerGrantStatement, SimpleTableSegment, TableNameSegment]. 93
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 39 (max allowed is 20). 93

org/apache/shardingsphere/sharding/route/engine/type/standard/ShardingStandardRoutingEngine.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 60

org/apache/shardingsphere/sharding/route/engine/type/standard/assertion/ShardingRouteAssert.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [CacheOption, ConfigurationProperties, ConnectionContext, HintValueContext, Properties, QueryContext, RuleMetaData, SQLBindEngine, SQLRouteEngine, SQLStatementParserEngine, ShardingSphereColumn, ShardingSphereDatabase, ShardingSphereMetaData, ShardingSphereSchema, ShardingSphereTable]. 61
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 61

org/apache/shardingsphere/sharding/route/engine/validator/ShardingStatementValidatorFactory.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [ShardingAlterIndexStatementValidator, ShardingAlterTableStatementValidator, ShardingAlterViewStatementValidator, ShardingCopyStatementValidator, ShardingCreateFunctionStatementValidator, ShardingCreateIndexStatementValidator, ShardingCreateProcedureStatementValidator, ShardingCreateTableStatementValidator, ShardingCreateViewStatementValidator, ShardingDeleteStatementValidator, ShardingDropIndexStatementValidator, ShardingDropTableStatementValidator, ShardingInsertStatementValidator, ShardingLoadDataStatementValidator, ShardingLoadXMLStatementValidator, ShardingPrepareStatementValidator, ShardingRenameTableStatementValidator, ShardingUpdateStatementValidator]. 68
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 41 (max allowed is 20). 68
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 88
 Warning metrics NPathComplexity NPath Complexity is 4,096 (max allowed is 200). 88

org/apache/shardingsphere/sharding/route/engine/validator/ddl/ShardingCreateTableStatementValidatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [CreateTableStatementContext, HintValueContext, IdentifierValue, MySQLCreateTableStatement, OracleCreateTableStatement, PostgreSQLCreateTableStatement, RouteMapper, RouteUnit, SQL92CreateTableStatement, SQLServerCreateTableStatement, ShardingCreateTableStatementValidator, ShardingTable, SimpleTableSegment, TableNameSegment]. 60
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 60

org/apache/shardingsphere/sharding/route/engine/validator/ddl/ShardingDropTableStatementValidatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [DropTableStatementContext, HintValueContext, IdentifierValue, MySQLDropTableStatement, PostgreSQLDropTableStatement, RouteMapper, RouteUnit, ShardingDropTableStatementValidator, ShardingTable, SimpleTableSegment, TableNameSegment]. 63
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 63

org/apache/shardingsphere/sharding/route/engine/validator/dml/ShardingDeleteStatementValidatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [DeleteMultiTableSegment, DeleteStatementContext, IdentifierValue, MySQLDeleteStatement, OracleDeleteStatement, PostgreSQLDeleteStatement, SQL92DeleteStatement, SQLServerDeleteStatement, ShardingDeleteStatementValidator, SimpleTableSegment, TableNameSegment]. 52

org/apache/shardingsphere/sharding/route/engine/validator/dml/ShardingInsertStatementValidatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 22 (max allowed is 10) classes [ColumnAssignmentSegment, ColumnSegment, DataNode, HintValueContext, IdentifierValue, InsertColumnsSegment, InsertStatementContext, MySQLInsertStatement, MySQLSelectStatement, OnDuplicateKeyColumnsSegment, ParameterMarkerExpressionSegment, ProjectionsSegment, Property, RouteContext, RouteMapper, RouteUnit, ShardingInsertStatementValidator, ShardingSphereMetaData, SimpleTableSegment, SubquerySegment, TableNameSegment, TablesContext]. 82
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 33 (max allowed is 20). 82

org/apache/shardingsphere/sharding/route/engine/validator/dml/ShardingUpdateStatementValidatorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [ColumnAssignmentSegment, ColumnSegment, HintValueContext, IdentifierValue, JoinTableSegment, LiteralExpressionSegment, MySQLUpdateStatement, Property, RouteContext, RouteMapper, RouteUnit, SetAssignmentSegment, ShardingUpdateStatementValidator, SimpleTableSegment, TableNameSegment, UpdateStatementContext]. 66
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 66

org/apache/shardingsphere/sharding/rule/ShardingRule.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [AlgorithmInitializationException, BindingTableRule, CaseInsensitiveMap, DataNode, DatabaseTypeRegistry, NoneShardingStrategyConfiguration, RuleAttributes, ShardingAuditStrategyConfiguration, ShardingCache, ShardingDataNodeRuleAttribute, ShardingRuleChecker, ShardingTable, ShardingTableNamesRuleAttribute, ShardingTableRuleNotFoundException]. 84
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 39 (max allowed is 20). 84

org/apache/shardingsphere/sharding/rule/ShardingRuleTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 22 (max allowed is 10) classes [AlgorithmConfiguration, ColumnSegment, ComplexShardingStrategyConfiguration, DataNode, IdentifierValue, KeyGenerateStrategyConfiguration, MockedDataSource, NoneShardingStrategyConfiguration, OwnerSegment, Properties, Property, ShardingAuditStrategyConfiguration, ShardingAutoTableRuleConfiguration, ShardingRule, ShardingRuleConfiguration, ShardingTableReferenceRuleConfiguration, ShardingTableRuleConfiguration, SimpleTableSegment, StandardShardingStrategyConfiguration, TableNameSegment, TablesContext, WhereSegment]. 91
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 35 (max allowed is 20). 91

org/apache/shardingsphere/sharding/yaml/ShardingRuleConfigurationYamlIT.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [AlgorithmConfiguration, ComplexShardingStrategyConfiguration, HintShardingStrategyConfiguration, KeyGenerateStrategyConfiguration, NoneShardingStrategyConfiguration, Properties, Property, ShardingAuditStrategyConfiguration, ShardingCacheConfiguration, ShardingCacheOptionsConfiguration, ShardingRuleConfiguration, ShardingTableReferenceRuleConfiguration, ShardingTableRuleConfiguration, StandardShardingStrategyConfiguration]. 48

org/apache/shardingsphere/single/distsql/handler/update/LoadSingleTableExecutorTest.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 68

org/apache/shardingsphere/single/distsql/parser/core/SingleDistSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 58

org/apache/shardingsphere/single/route/SingleSQLRouterTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 21 (max allowed is 10) classes [ConfigurationProperties, CreateTableStatementContext, DataNode, H2DatabaseType, HintValueContext, IdentifierValue, MockedDataSource, MySQLCreateTableStatement, Properties, QueryContext, RouteContext, RouteMapper, RouteUnit, RuleMetaData, ShardingSphereDatabase, SimpleTableSegment, SingleRule, SingleRuleConfiguration, SingleSQLRouter, StorageUnit, TableNameSegment]. 77
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 77

org/apache/shardingsphere/single/route/engine/SingleStandardRouteEngineTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [DataNode, IdentifierValue, MockedDataSource, MySQLCreateTableStatement, MySQLDatabaseType, QualifiedTable, RouteContext, RuleAttributes, SimpleTableSegment, SingleRule, SingleRuleConfiguration, SingleStandardRouteEngine, TableNameSegment]. 63

org/apache/shardingsphere/sql/parser/clickhouse/visitor/statement/ClickHouseStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 33 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CollectionValue, ColumnOrderByItemSegment, ColumnSegment, CommonExpressionSegment, DataTypeLengthSegment, DataTypeSegment, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, InExpression, IndexOrderByItemSegment, Interval, KeywordValue, ListExpression, LiteralExpressionSegment, NotExpression, NullLiteralValue, NumberLiteralValue, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerValue, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubquerySegment, TableNameSegment]. 79
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 75 (max allowed is 20). 79

org/apache/shardingsphere/sql/parser/clickhouse/visitor/statement/type/ClickHouseDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 25 (max allowed is 10) classes [AliasSegment, BooleanLiteralValue, ClickHouseDeleteStatement, ClickHouseInsertStatement, ClickHouseSelectStatement, ClickHouseUpdateStatement, ColumnAssignmentSegment, ColumnProjectionSegment, CommonExpressionSegment, ExpressionProjectionSegment, GroupBySegment, HavingSegment, IdentifierValue, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, OwnerSegment, ProjectionsSegment, SetAssignmentSegment, ShorthandProjectionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, WhereSegment]. 81
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 75 (max allowed is 20). 81
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 279
 Warning metrics NPathComplexity NPath Complexity is 768 (max allowed is 200). 279

org/apache/shardingsphere/sql/parser/doris/visitor/statement/DorisStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 76 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BetweenExpression, BigDecimal, BinaryOperationExpression, BooleanLiteralValue, CaseWhenExpression, CollateExpression, CollectionValue, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, CombineSegment, CommonExpressionSegment, CommonTableExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, DatabaseSegment, DeleteMultiTableSegment, DorisDeleteStatement, DorisInsertStatement, DorisSelectStatement, DorisUpdateStatement, EngineSegment, ExistsSubqueryExpression, ExpressionOrderByItemSegment, ExpressionProjectionSegment, FunctionSegment, FunctionTableSegment, GroupBySegment, HavingSegment, IdentifierValue, InExpression, IndexNameSegment, IndexOrderByItemSegment, IndexSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, LimitSegment, ListExpression, LiteralExpressionSegment, LockSegment, MatchAgainstExpression, NotExpression, NullLiteralValue, NumberLiteralLimitValueSegment, NumberLiteralValue, OnDuplicateKeyColumnsSegment, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, ParameterMarkerValue, ParenthesesSegment, ProjectionsSegment, RowExpression, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, UnaryOperationExpression, ValuesExpression, VariableSegment, WhereSegment, WithSegment]. 253
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 217 (max allowed is 20). 253
 Warning sizes MethodCount Number of public methods is 109 (max allowed is 100). 253
 Warning sizes MethodCount Total number of methods is 140 (max allowed is 100). 253
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 440
 Warning metrics NPathComplexity NPath Complexity is 396 (max allowed is 200). 440
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 18 (max allowed is 10). 598
 Warning metrics NPathComplexity NPath Complexity is 20,736 (max allowed is 200). 598
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 990
 Warning metrics NPathComplexity NPath Complexity is 16,384 (max allowed is 200). 990
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 1223
 Warning metrics NPathComplexity NPath Complexity is 768 (max allowed is 200). 1223
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 1743
 Warning metrics NPathComplexity NPath Complexity is 5,376 (max allowed is 200). 1743
 Warning metrics BooleanExpressionComplexity Boolean expression complexity is 5 (max allowed is 3). 1789

org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDALStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 89 (max allowed is 10) classes [CacheTableIndexSegment, CloneActionSegment, CloneInstanceSegment, CollectionValue, DorisAlterResourceGroupStatement, DorisAnalyzeTableStatement, DorisBinlogStatement, DorisCacheIndexStatement, DorisCheckTableStatement, DorisChecksumTableStatement, DorisCloneStatement, DorisCreateLoadableFunctionStatement, DorisCreateResourceGroupStatement, DorisDelimiterStatement, DorisDropResourceGroupStatement, DorisExplainStatement, DorisFlushStatement, DorisHelpStatement, DorisInstallComponentStatement, DorisInstallPluginStatement, DorisKillStatement, DorisLoadIndexInfoStatement, DorisOptimizeTableStatement, DorisRepairTableStatement, DorisResetPersistStatement, DorisResetStatement, DorisRestartStatement, DorisSetResourceGroupStatement, DorisSetStatement, DorisShowBinaryLogsStatement, DorisShowBinlogEventsStatement, DorisShowCharacterSetStatement, DorisShowCollationStatement, DorisShowColumnsStatement, DorisShowCreateDatabaseStatement, DorisShowCreateEventStatement, DorisShowCreateFunctionStatement, DorisShowCreateProcedureStatement, DorisShowCreateTableStatement, DorisShowCreateTriggerStatement, DorisShowCreateUserStatement, DorisShowCreateViewStatement, DorisShowDatabasesStatement, DorisShowEngineStatement, DorisShowErrorsStatement, DorisShowEventsStatement, DorisShowFunctionCodeStatement, DorisShowFunctionStatusStatement, DorisShowGrantsStatement, DorisShowIndexStatement, DorisShowMasterStatusStatement, DorisShowOpenTablesStatement, DorisShowOtherStatement, DorisShowPluginsStatement, DorisShowPrivilegesStatement, DorisShowProcedureCodeStatement, DorisShowProcedureStatusStatement, DorisShowProcessListStatement, DorisShowProfileStatement, DorisShowProfilesStatement, DorisShowRelayLogEventsStatement, DorisShowReplicaStatusStatement, DorisShowReplicasStatement, DorisShowSlaveHostsStatement, DorisShowSlaveStatusStatement, DorisShowStatusStatement, DorisShowTableStatusStatement, DorisShowTablesStatement, DorisShowTriggersStatement, DorisShowVariablesStatement, DorisShowWarningsStatement, DorisShutdownStatement, DorisUninstallComponentStatement, DorisUninstallPluginStatement, DorisUseStatement, FromDatabaseSegment, FromTableSegment, IdentifierValue, LoadTableIndexSegment, NumberLiteralValue, PartitionDefinitionSegment, PartitionSegment, ResetMasterOptionSegment, ResetSlaveOptionSegment, ShowFilterSegment, ShowLikeSegment, VariableAssignSegment, VariableSegment, WhereSegment]. 226
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 198 (max allowed is 20). 226

org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 20 (max allowed is 10) classes [DorisAlterUserStatement, DorisCreateRoleStatement, DorisCreateUserStatement, DorisDropRoleStatement, DorisDropUserStatement, DorisGrantStatement, DorisRenameUserStatement, DorisRevokeStatement, DorisSetDefaultRoleStatement, DorisSetPasswordStatement, DorisSetRoleStatement, GrantLevelSegment, IdentifierValue, NumberLiteralValue, PasswordOrLockOptionSegment, PrivilegeSegment, RoleOrPrivilegeSegment, TLSOptionSegment, UserResourceSegment, UserSegment]. 120
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 92 (max allowed is 20). 120
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 599

org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 68 (max allowed is 10) classes [AddColumnDefinitionSegment, AddConstraintDefinitionSegment, AlgorithmTypeSegment, ChangeColumnDefinitionSegment, CharsetNameSegment, CollectionValue, ColumnAfterPositionSegment, ColumnDefinitionSegment, ColumnFirstPositionSegment, ColumnSegment, CommentSegment, ConstraintDefinitionSegment, ConstraintSegment, ConvertTableDefinitionSegment, CreateTableOptionSegment, DorisAlterDatabaseStatement, DorisAlterEventStatement, DorisAlterFunctionStatement, DorisAlterInstanceStatement, DorisAlterLogfileGroupStatement, DorisAlterProcedureStatement, DorisAlterServerStatement, DorisAlterTableStatement, DorisAlterTablespaceStatement, DorisAlterViewStatement, DorisCreateDatabaseStatement, DorisCreateEventStatement, DorisCreateFunctionStatement, DorisCreateIndexStatement, DorisCreateLogfileGroupStatement, DorisCreateProcedureStatement, DorisCreateServerStatement, DorisCreateTableStatement, DorisCreateTablespaceStatement, DorisCreateTriggerStatement, DorisCreateViewStatement, DorisDeallocateStatement, DorisDropDatabaseStatement, DorisDropEventStatement, DorisDropFunctionStatement, DorisDropIndexStatement, DorisDropLogfileGroupStatement, DorisDropProcedureStatement, DorisDropServerStatement, DorisDropTableStatement, DorisDropTablespaceStatement, DorisDropTriggerStatement, DorisDropViewStatement, DorisExecuteStatement, DorisPrepareStatement, DorisRenameTableStatement, DorisTruncateStatement, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, DropIndexDefinitionSegment, FunctionNameSegment, IdentifierValue, IndexNameSegment, IndexSegment, LockTableSegment, ModifyColumnDefinitionSegment, ModifyConstraintDefinitionSegment, RenameColumnSegment, RenameIndexDefinitionSegment, RenameTableDefinitionSegment, RoutineBodySegment, TablespaceSegment, ValidStatementSegment]. 202
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 171 (max allowed is 20). 202
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 326
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 396
 Warning metrics NPathComplexity NPath Complexity is 1,536 (max allowed is 200). 396
 Warning metrics NPathComplexity NPath Complexity is 216 (max allowed is 200). 596

org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CommonExpressionSegment, DorisCallStatement, DorisDoStatement, DorisHandlerStatement, DorisImportStatement, DorisLoadDataStatement, DorisLoadXMLStatement, FunctionSegment, IdentifierValue, IndexHintSegment, WindowItemSegment, WindowSegment]. 60
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 60

org/apache/shardingsphere/sql/parser/doris/visitor/statement/type/DorisTCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [AutoCommitSegment, DorisBeginTransactionStatement, DorisCommitStatement, DorisLockStatement, DorisReleaseSavepointStatement, DorisRollbackStatement, DorisSavepointStatement, DorisSetAutoCommitStatement, DorisSetTransactionStatement, DorisUnlockStatement, XABeginStatement, XACommitStatement, XAEndStatement, XAPrepareStatement, XARecoveryStatement, XARollbackStatement]. 70
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 42 (max allowed is 20). 70
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 72

org/apache/shardingsphere/sql/parser/hive/visitor/statement/HiveStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 29 (max allowed is 10) classes [BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CollateExpression, CollectionValue, ColumnSegment, CommonExpressionSegment, ExistsSubqueryExpression, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, InExpression, IndexNameSegment, IndexSegment, Interval, ListExpression, LiteralExpressionSegment, NotExpression, NullLiteralValue, NumberLiteralValue, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerValue, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubquerySegment, TableNameSegment]. 94
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 63 (max allowed is 20). 94
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 276
 Warning metrics NPathComplexity NPath Complexity is 396 (max allowed is 200). 276
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 16 (max allowed is 10). 440
 Warning metrics NPathComplexity NPath Complexity is 10,368 (max allowed is 200). 440

org/apache/shardingsphere/sql/parser/hive/visitor/statement/type/HiveDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 55 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BigDecimal, BooleanLiteralValue, CaseWhenExpression, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, CombineSegment, CommonExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, DeleteMultiTableSegment, ExpressionOrderByItemSegment, ExpressionProjectionSegment, FunctionSegment, GroupBySegment, HavingSegment, HiveDeleteStatement, HiveInsertStatement, HiveSelectStatement, HiveUpdateStatement, IdentifierValue, IndexOrderByItemSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, LimitSegment, LiteralExpressionSegment, LockSegment, NumberLiteralLimitValueSegment, NumberLiteralValue, OnDuplicateKeyColumnsSegment, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, ProjectionsSegment, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StringLiteralValue, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, ValuesExpression, VariableSegment, WhereSegment, WindowItemSegment, WindowSegment]. 201
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 168 (max allowed is 20). 201
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 507
 Warning metrics NPathComplexity NPath Complexity is 4,096 (max allowed is 200). 507
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 1150
 Warning metrics JavaNCSS NCSS for this method is 57 (max allowed is 50). 1150
 Warning metrics NPathComplexity NPath Complexity is 12,288 (max allowed is 200). 1150

org/apache/shardingsphere/sql/parser/mysql/visitor/format/MySQLFormatVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 53 (max allowed is 20). 82
 Warning metrics BooleanExpressionComplexity Boolean expression complexity is 4 (max allowed is 3). 812

org/apache/shardingsphere/sql/parser/mysql/visitor/statement/MySQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 76 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BetweenExpression, BigDecimal, BinaryOperationExpression, BooleanLiteralValue, CaseWhenExpression, CollateExpression, CollectionValue, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, CombineSegment, CommonExpressionSegment, CommonTableExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, DatabaseSegment, DeleteMultiTableSegment, EngineSegment, ExistsSubqueryExpression, ExpressionOrderByItemSegment, ExpressionProjectionSegment, FunctionSegment, FunctionTableSegment, GroupBySegment, HavingSegment, IdentifierValue, InExpression, IndexNameSegment, IndexOrderByItemSegment, IndexSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, LimitSegment, ListExpression, LiteralExpressionSegment, LockSegment, MatchAgainstExpression, MySQLDeleteStatement, MySQLInsertStatement, MySQLSelectStatement, MySQLUpdateStatement, NotExpression, NullLiteralValue, NumberLiteralLimitValueSegment, NumberLiteralValue, OnDuplicateKeyColumnsSegment, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, ParameterMarkerValue, ParenthesesSegment, ProjectionsSegment, RowExpression, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, UnaryOperationExpression, ValuesExpression, VariableSegment, WhereSegment, WithSegment]. 253
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 217 (max allowed is 20). 253
 Warning sizes MethodCount Number of public methods is 108 (max allowed is 100). 253
 Warning sizes MethodCount Total number of methods is 140 (max allowed is 100). 253
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 440
 Warning metrics NPathComplexity NPath Complexity is 396 (max allowed is 200). 440
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 18 (max allowed is 10). 598
 Warning metrics NPathComplexity NPath Complexity is 20,736 (max allowed is 200). 598
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 990
 Warning metrics NPathComplexity NPath Complexity is 8,192 (max allowed is 200). 990
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 1210
 Warning metrics NPathComplexity NPath Complexity is 768 (max allowed is 200). 1210
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 17 (max allowed is 10). 1739
 Warning metrics NPathComplexity NPath Complexity is 5,376 (max allowed is 200). 1739
 Warning metrics BooleanExpressionComplexity Boolean expression complexity is 5 (max allowed is 3). 1785

org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDALStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 89 (max allowed is 10) classes [CacheTableIndexSegment, CloneActionSegment, CloneInstanceSegment, CollectionValue, FromDatabaseSegment, FromTableSegment, IdentifierValue, LoadTableIndexSegment, MySQLAlterResourceGroupStatement, MySQLAnalyzeTableStatement, MySQLBinlogStatement, MySQLCacheIndexStatement, MySQLCheckTableStatement, MySQLChecksumTableStatement, MySQLCloneStatement, MySQLCreateLoadableFunctionStatement, MySQLCreateResourceGroupStatement, MySQLDelimiterStatement, MySQLDropResourceGroupStatement, MySQLExplainStatement, MySQLFlushStatement, MySQLHelpStatement, MySQLInstallComponentStatement, MySQLInstallPluginStatement, MySQLKillStatement, MySQLLoadIndexInfoStatement, MySQLOptimizeTableStatement, MySQLRepairTableStatement, MySQLResetPersistStatement, MySQLResetStatement, MySQLRestartStatement, MySQLSetResourceGroupStatement, MySQLSetStatement, MySQLShowBinaryLogsStatement, MySQLShowBinlogEventsStatement, MySQLShowCharacterSetStatement, MySQLShowCollationStatement, MySQLShowColumnsStatement, MySQLShowCreateDatabaseStatement, MySQLShowCreateEventStatement, MySQLShowCreateFunctionStatement, MySQLShowCreateProcedureStatement, MySQLShowCreateTableStatement, MySQLShowCreateTriggerStatement, MySQLShowCreateUserStatement, MySQLShowCreateViewStatement, MySQLShowDatabasesStatement, MySQLShowEngineStatement, MySQLShowErrorsStatement, MySQLShowEventsStatement, MySQLShowFunctionCodeStatement, MySQLShowFunctionStatusStatement, MySQLShowGrantsStatement, MySQLShowIndexStatement, MySQLShowMasterStatusStatement, MySQLShowOpenTablesStatement, MySQLShowOtherStatement, MySQLShowPluginsStatement, MySQLShowPrivilegesStatement, MySQLShowProcedureCodeStatement, MySQLShowProcedureStatusStatement, MySQLShowProcessListStatement, MySQLShowProfileStatement, MySQLShowProfilesStatement, MySQLShowRelayLogEventsStatement, MySQLShowReplicaStatusStatement, MySQLShowReplicasStatement, MySQLShowSlaveHostsStatement, MySQLShowSlaveStatusStatement, MySQLShowStatusStatement, MySQLShowTableStatusStatement, MySQLShowTablesStatement, MySQLShowTriggersStatement, MySQLShowVariablesStatement, MySQLShowWarningsStatement, MySQLShutdownStatement, MySQLUninstallComponentStatement, MySQLUninstallPluginStatement, MySQLUseStatement, NumberLiteralValue, PartitionDefinitionSegment, PartitionSegment, ResetMasterOptionSegment, ResetSlaveOptionSegment, ShowFilterSegment, ShowLikeSegment, VariableAssignSegment, VariableSegment, WhereSegment]. 226
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 198 (max allowed is 20). 226

org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 20 (max allowed is 10) classes [GrantLevelSegment, IdentifierValue, MySQLAlterUserStatement, MySQLCreateRoleStatement, MySQLCreateUserStatement, MySQLDropRoleStatement, MySQLDropUserStatement, MySQLGrantStatement, MySQLRenameUserStatement, MySQLRevokeStatement, MySQLSetDefaultRoleStatement, MySQLSetPasswordStatement, MySQLSetRoleStatement, NumberLiteralValue, PasswordOrLockOptionSegment, PrivilegeSegment, RoleOrPrivilegeSegment, TLSOptionSegment, UserResourceSegment, UserSegment]. 120
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 91 (max allowed is 20). 120
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 598

org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 68 (max allowed is 10) classes [AddColumnDefinitionSegment, AddConstraintDefinitionSegment, AlgorithmTypeSegment, ChangeColumnDefinitionSegment, CharsetNameSegment, CollectionValue, ColumnAfterPositionSegment, ColumnDefinitionSegment, ColumnFirstPositionSegment, ColumnSegment, CommentSegment, ConstraintDefinitionSegment, ConstraintSegment, ConvertTableDefinitionSegment, CreateTableOptionSegment, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, DropIndexDefinitionSegment, FunctionNameSegment, IdentifierValue, IndexNameSegment, IndexSegment, LockTableSegment, ModifyColumnDefinitionSegment, ModifyConstraintDefinitionSegment, MySQLAlterDatabaseStatement, MySQLAlterEventStatement, MySQLAlterFunctionStatement, MySQLAlterInstanceStatement, MySQLAlterLogfileGroupStatement, MySQLAlterProcedureStatement, MySQLAlterServerStatement, MySQLAlterTableStatement, MySQLAlterTablespaceStatement, MySQLAlterViewStatement, MySQLCreateDatabaseStatement, MySQLCreateEventStatement, MySQLCreateFunctionStatement, MySQLCreateIndexStatement, MySQLCreateLogfileGroupStatement, MySQLCreateProcedureStatement, MySQLCreateServerStatement, MySQLCreateTableStatement, MySQLCreateTablespaceStatement, MySQLCreateTriggerStatement, MySQLCreateViewStatement, MySQLDeallocateStatement, MySQLDropDatabaseStatement, MySQLDropEventStatement, MySQLDropFunctionStatement, MySQLDropIndexStatement, MySQLDropLogfileGroupStatement, MySQLDropProcedureStatement, MySQLDropServerStatement, MySQLDropTableStatement, MySQLDropTablespaceStatement, MySQLDropTriggerStatement, MySQLDropViewStatement, MySQLExecuteStatement, MySQLPrepareStatement, MySQLRenameTableStatement, MySQLTruncateStatement, RenameColumnSegment, RenameIndexDefinitionSegment, RenameTableDefinitionSegment, RoutineBodySegment, TablespaceSegment, ValidStatementSegment]. 203
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 170 (max allowed is 20). 203
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 328
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 398
 Warning metrics NPathComplexity NPath Complexity is 1,536 (max allowed is 200). 398
 Warning metrics NPathComplexity NPath Complexity is 216 (max allowed is 200). 603

org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [CommonExpressionSegment, FunctionSegment, IdentifierValue, IndexHintSegment, MySQLCallStatement, MySQLDoStatement, MySQLHandlerStatement, MySQLImportStatement, MySQLLoadDataStatement, MySQLLoadXMLStatement, ProjectionsSegment, ReturningSegment, WindowItemSegment, WindowSegment]. 66
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 37 (max allowed is 20). 66

org/apache/shardingsphere/sql/parser/mysql/visitor/statement/type/MySQLTCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 16 (max allowed is 10) classes [AutoCommitSegment, MySQLBeginTransactionStatement, MySQLCommitStatement, MySQLLockStatement, MySQLReleaseSavepointStatement, MySQLRollbackStatement, MySQLSavepointStatement, MySQLSetAutoCommitStatement, MySQLSetTransactionStatement, MySQLUnlockStatement, XABeginStatement, XACommitStatement, XAEndStatement, XAPrepareStatement, XARecoveryStatement, XARollbackStatement]. 70
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 42 (max allowed is 20). 70
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 72

org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/OpenGaussStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 71 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CaseWhenExpression, CollectionValue, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, CombineSegment, CommonExpressionSegment, CommonTableExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, ExistsSubqueryExpression, ExpressionOrderByItemSegment, ExpressionProjectionSegment, ExtractArgExpression, FunctionSegment, FunctionTableSegment, GroupBySegment, HavingSegment, IdentifierValue, InExpression, IndexNameSegment, IndexOrderByItemSegment, IndexSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, KeywordValue, LimitSegment, ListExpression, LiteralExpressionSegment, LockSegment, NameSegment, NullLiteralValue, NumberLiteralLimitValueSegment, NumberLiteralValue, OnDuplicateKeyColumnsSegment, OpenGaussDeleteStatement, OpenGaussExecuteStatement, OpenGaussInsertStatement, OpenGaussSelectStatement, OpenGaussUpdateStatement, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, ParameterMarkerValue, ProjectionsSegment, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, TypeCastExpression, WhereSegment, WindowItemSegment, WindowSegment, WithSegment]. 215
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 178 (max allowed is 20). 215
 Warning sizes MethodCount Total number of methods is 108 (max allowed is 100). 215
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 324
 Warning metrics NPathComplexity NPath Complexity is 1,024 (max allowed is 200). 324

org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussDALStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [CollectionValue, IdentifierValue, OpenGaussAnalyzeTableStatement, OpenGaussEmptyStatement, OpenGaussExplainStatement, OpenGaussLoadStatement, OpenGaussResetParameterStatement, OpenGaussSetStatement, OpenGaussShowStatement, OpenGaussVacuumStatement, SimpleTableSegment, TableNameSegment, VariableAssignSegment, VariableSegment]. 58
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 58

org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussDCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 48

org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 95 (max allowed is 10) classes [AddColumnDefinitionSegment, AddConstraintDefinitionSegment, CollectionValue, ColumnDefinitionSegment, ColumnSegment, ConstraintDefinitionSegment, CursorNameSegment, DirectionSegment, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, FunctionSegment, IdentifierValue, IndexNameSegment, IndexSegment, ModifyColumnDefinitionSegment, ModifyConstraintDefinitionSegment, OpenGaussAlterAggregateStatement, OpenGaussAlterConversionStatement, OpenGaussAlterDefaultPrivilegesStatement, OpenGaussAlterDirectoryStatement, OpenGaussAlterDomainStatement, OpenGaussAlterExtensionStatement, OpenGaussAlterForeignTableStatement, OpenGaussAlterFunctionStatement, OpenGaussAlterGroupStatement, OpenGaussAlterIndexStatement, OpenGaussAlterLanguageStatement, OpenGaussAlterMaterializedViewStatement, OpenGaussAlterPackageStatement, OpenGaussAlterProcedureStatement, OpenGaussAlterRuleStatement, OpenGaussAlterSchemaStatement, OpenGaussAlterSequenceStatement, OpenGaussAlterSynonymStatement, OpenGaussAlterTableStatement, OpenGaussAlterTablespaceStatement, OpenGaussAlterTextSearchStatement, OpenGaussAlterTypeStatement, OpenGaussAlterViewStatement, OpenGaussCloseStatement, OpenGaussCommentStatement, OpenGaussCreateAggregateStatement, OpenGaussCreateCastStatement, OpenGaussCreateConversionStatement, OpenGaussCreateDatabaseStatement, OpenGaussCreateDirectoryStatement, OpenGaussCreateDomainStatement, OpenGaussCreateExtensionStatement, OpenGaussCreateFunctionStatement, OpenGaussCreateIndexStatement, OpenGaussCreateLanguageStatement, OpenGaussCreateProcedureStatement, OpenGaussCreatePublicationStatement, OpenGaussCreateRuleStatement, OpenGaussCreateSchemaStatement, OpenGaussCreateSequenceStatement, OpenGaussCreateSynonymStatement, OpenGaussCreateTableStatement, OpenGaussCreateTablespaceStatement, OpenGaussCreateTextSearchStatement, OpenGaussCreateTypeStatement, OpenGaussCreateViewStatement, OpenGaussCursorStatement, OpenGaussDeallocateStatement, OpenGaussDeclareStatement, OpenGaussDropCastStatement, OpenGaussDropConversionStatement, OpenGaussDropDatabaseStatement, OpenGaussDropDirectoryStatement, OpenGaussDropDomainStatement, OpenGaussDropExtensionStatement, OpenGaussDropFunctionStatement, OpenGaussDropIndexStatement, OpenGaussDropLanguageStatement, OpenGaussDropProcedureStatement, OpenGaussDropPublicationStatement, OpenGaussDropRuleStatement, OpenGaussDropSchemaStatement, OpenGaussDropSequenceStatement, OpenGaussDropServerStatement, OpenGaussDropSynonymStatement, OpenGaussDropTableStatement, OpenGaussDropTablespaceStatement, OpenGaussDropTypeStatement, OpenGaussDropViewStatement, OpenGaussFetchStatement, OpenGaussMoveStatement, OpenGaussPrepareStatement, OpenGaussTruncateStatement, OwnerSegment, RenameColumnSegment, RenameTableDefinitionSegment, SimpleTableSegment, TableNameSegment, ValidateConstraintDefinitionSegment]. 260
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 227 (max allowed is 20). 260
 Warning sizes MethodCount Number of public methods is 110 (max allowed is 100). 260
 Warning sizes MethodCount Total number of methods is 117 (max allowed is 100). 260
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 294

org/apache/shardingsphere/sql/parser/opengauss/visitor/statement/type/OpenGaussTCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [OpenGaussBeginTransactionStatement, OpenGaussCheckpointStatement, OpenGaussCommitPreparedStatement, OpenGaussCommitStatement, OpenGaussReleaseSavepointStatement, OpenGaussRollbackPreparedStatement, OpenGaussRollbackStatement, OpenGaussSavepointStatement, OpenGaussSetConstraintsStatement, OpenGaussSetTransactionStatement, OpenGaussStartTransactionStatement]. 52
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 52

org/apache/shardingsphere/sql/parser/oracle/visitor/statement/OracleStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 57 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CaseWhenExpression, CollectionValue, ColumnOrderByItemSegment, ColumnSegment, CommonExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, DateTimeLiteralValue, DatetimeExpression, ExpressionOrderByItemSegment, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, InExpression, IndexNameSegment, IndexOrderByItemSegment, IndexSegment, IndexTypeSegment, Interval, IntervalDayToSecondExpression, IntervalExpressionProjection, IntervalYearToMonthExpression, KeywordValue, ListExpression, LiteralExpressionSegment, MultisetExpression, NotExpression, NullLiteralValue, NumberLiteralValue, OrderBySegment, OtherLiteralValue, OuterJoinExpression, OwnerSegment, PackageSegment, ParameterMarkerExpressionSegment, ParameterMarkerValue, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubquerySegment, TableNameSegment, TypeSegment, XmlElementFunctionSegment, XmlNamespaceStringAsIdentifierSegment, XmlNamespacesClauseSegment, XmlPiFunctionSegment, XmlQueryAndExistsFunctionSegment, XmlSerializeFunctionSegment, XmlTableColumnSegment, XmlTableFunctionSegment, XmlTableOptionsSegment]. 192
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 148 (max allowed is 20). 192
 Warning metrics NPathComplexity NPath Complexity is 512 (max allowed is 200). 222
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 606
 Warning metrics NPathComplexity NPath Complexity is 384 (max allowed is 200). 606
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 791
 Warning metrics NPathComplexity NPath Complexity is 4,096 (max allowed is 200). 791
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 1006
 Warning metrics NPathComplexity NPath Complexity is 8,192 (max allowed is 200). 1006

org/apache/shardingsphere/sql/parser/oracle/visitor/statement/type/OracleDCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 46

org/apache/shardingsphere/sql/parser/oracle/visitor/statement/type/OracleDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 144 (max allowed is 10) classes [AddColumnDefinitionSegment, AddConstraintDefinitionSegment, CollectionValue, ColumnDefinitionSegment, ConstraintDefinitionSegment, CursorForLoopStatementSegment, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, FunctionNameSegment, IdentifierValue, ModifyCollectionRetrievalSegment, ModifyColumnDefinitionSegment, ModifyConstraintDefinitionSegment, OracleAlterAnalyticViewStatement, OracleAlterAttributeDimensionStatement, OracleAlterAuditPolicyStatement, OracleAlterClusterStatement, OracleAlterDatabaseDictionaryStatement, OracleAlterDatabaseLinkStatement, OracleAlterDatabaseStatement, OracleAlterDimensionStatement, OracleAlterDiskgroupStatement, OracleAlterFlashbackArchiveStatement, OracleAlterFunctionStatement, OracleAlterHierarchyStatement, OracleAlterInMemoryJoinGroupStatement, OracleAlterIndexStatement, OracleAlterIndexTypeStatement, OracleAlterJavaStatement, OracleAlterLibraryStatement, OracleAlterLockdownProfileStatement, OracleAlterMaterializedViewLogStatement, OracleAlterMaterializedViewStatement, OracleAlterMaterializedZoneMapStatement, OracleAlterOperatorStatement, OracleAlterOutlineStatement, OracleAlterPackageStatement, OracleAlterPluggableDatabaseStatement, OracleAlterProcedureStatement, OracleAlterProfileStatement, OracleAlterRollbackSegmentStatement, OracleAlterSequenceStatement, OracleAlterSessionStatement, OracleAlterSynonymStatement, OracleAlterSystemStatement, OracleAlterTableStatement, OracleAlterTablespaceStatement, OracleAlterTriggerStatement, OracleAlterTypeStatement, OracleAlterViewStatement, OracleAnalyzeStatement, OracleAssociateStatisticsStatement, OracleAuditStatement, OracleCommentStatement, OracleCreateClusterStatement, OracleCreateContextStatement, OracleCreateControlFileStatement, OracleCreateDatabaseLinkStatement, OracleCreateDatabaseStatement, OracleCreateDimensionStatement, OracleCreateDirectoryStatement, OracleCreateDiskgroupStatement, OracleCreateEditionStatement, OracleCreateFlashbackArchiveStatement, OracleCreateFunctionStatement, OracleCreateInMemoryJoinGroupStatement, OracleCreateIndexStatement, OracleCreateJavaStatement, OracleCreateLibraryStatement, OracleCreateLockdownProfileStatement, OracleCreateMaterializedViewLogStatement, OracleCreateMaterializedViewStatement, OracleCreateNestedTableTypeStatement, OracleCreateObjectTypeStatement, OracleCreateOperatorStatement, OracleCreateOutlineStatement, OracleCreatePFileStatement, OracleCreateProcedureStatement, OracleCreateProfileStatement, OracleCreateRestorePointStatement, OracleCreateRollbackSegmentStatement, OracleCreateSPFileStatement, OracleCreateSequenceStatement, OracleCreateSubTypeStatement, OracleCreateSynonymStatement, OracleCreateTableStatement, OracleCreateTablespaceStatement, OracleCreateTriggerStatement, OracleCreateVarrayTypeStatement, OracleCreateViewStatement, OracleDMLStatementVisitor, OracleDisassociateStatisticsStatement, OracleDropClusterStatement, OracleDropContextStatement, OracleDropDatabaseLinkStatement, OracleDropDatabaseStatement, OracleDropDimensionStatement, OracleDropDirectoryStatement, OracleDropDiskgroupStatement, OracleDropEditionStatement, OracleDropFlashbackArchiveStatement, OracleDropFunctionStatement, OracleDropInMemoryJoinGroupStatement, OracleDropIndexStatement, OracleDropIndexTypeStatement, OracleDropJavaStatement, OracleDropLibraryStatement, OracleDropLockdownProfileStatement, OracleDropMaterializedViewLogStatement, OracleDropMaterializedViewStatement, OracleDropMaterializedZoneMapStatement, OracleDropOperatorStatement, OracleDropOutlineStatement, OracleDropPackageStatement, OracleDropPluggableDatabaseStatement, OracleDropProcedureStatement, OracleDropProfileStatement, OracleDropRestorePointStatement, OracleDropRollbackSegmentStatement, OracleDropSequenceStatement, OracleDropSynonymStatement, OracleDropTableStatement, OracleDropTablespaceStatement, OracleDropTriggerStatement, OracleDropTypeStatement, OracleDropViewStatement, OracleFlashbackDatabaseStatement, OracleFlashbackTableStatement, OracleNoAuditStatement, OraclePLSQLBlockStatement, OraclePurgeStatement, OracleRenameStatement, OracleSwitchStatement, OracleSystemActionStatement, OracleTCLStatementVisitor, OracleTruncateStatement, OwnerSegment, ProcedureBodyEndNameSegment, ProcedureCallNameSegment, SQLStatementSegment, StringLiteralValue, TablespaceSegment, TypeDefinitionSegment, VariableSegment]. 369
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 338 (max allowed is 20). 369
 Warning sizes MethodCount Number of public methods is 152 (max allowed is 100). 369
 Warning sizes MethodCount Total number of methods is 163 (max allowed is 100). 369
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 937
 Warning metrics NPathComplexity NPath Complexity is 1,215 (max allowed is 200). 937
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 1373
 Warning metrics NPathComplexity NPath Complexity is 972 (max allowed is 200). 1373
 Warning metrics NPathComplexity NPath Complexity is 512 (max allowed is 200). 1529

org/apache/shardingsphere/sql/parser/oracle/visitor/statement/type/OracleDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 50 (max allowed is 10) classes [AliasSegment, BooleanLiteralValue, CollectionTableSegment, CollectionValue, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, CombineSegment, CommonExpressionSegment, CommonTableExpressionSegment, DatetimeProjectionSegment, ExpressionOrderByItemSegment, ExpressionProjectionSegment, ExpressionWithParamsSegment, FunctionTableSegment, GroupBySegment, HavingSegment, IdentifierValue, IndexOrderByItemSegment, InsertColumnsSegment, InsertValuesSegment, Interval, IntervalExpressionProjection, JoinTableSegment, LockSegment, ModelSegment, MultiTableConditionalIntoElseSegment, MultiTableConditionalIntoSegment, MultiTableConditionalIntoThenSegment, MultiTableConditionalIntoWhenThenSegment, MultiTableInsertIntoSegment, OracleDeleteStatement, OracleInsertStatement, OracleMergeStatement, OracleSelectStatement, OracleUpdateStatement, OwnerSegment, PivotSegment, ProjectionsSegment, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, WhereSegment, WithSegment]. 202
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 166 (max allowed is 20). 202
 Warning sizes MethodCount Total number of methods is 101 (max allowed is 100). 202
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 877
 Warning metrics BooleanExpressionComplexity Boolean expression complexity is 4 (max allowed is 3). 894

org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/PostgreSQLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 71 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CaseWhenExpression, CollectionValue, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, CombineSegment, CommonExpressionSegment, CommonTableExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, ExistsSubqueryExpression, ExpressionOrderByItemSegment, ExpressionProjectionSegment, ExtractArgExpression, FunctionSegment, FunctionTableSegment, GroupBySegment, HavingSegment, IdentifierValue, InExpression, IndexNameSegment, IndexOrderByItemSegment, IndexSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, KeywordValue, LimitSegment, ListExpression, LiteralExpressionSegment, LockSegment, NameSegment, NullLiteralValue, NumberLiteralLimitValueSegment, NumberLiteralValue, OnDuplicateKeyColumnsSegment, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, ParameterMarkerValue, PostgreSQLDeleteStatement, PostgreSQLExecuteStatement, PostgreSQLInsertStatement, PostgreSQLSelectStatement, PostgreSQLUpdateStatement, ProjectionsSegment, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, TypeCastExpression, WhereSegment, WindowItemSegment, WindowSegment, WithSegment]. 216
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 179 (max allowed is 20). 216
 Warning sizes MethodCount Total number of methods is 109 (max allowed is 100). 216
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 325
 Warning metrics NPathComplexity NPath Complexity is 1,024 (max allowed is 200). 325

org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDALStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [CollectionValue, IdentifierValue, PostgreSQLAnalyzeTableStatement, PostgreSQLEmptyStatement, PostgreSQLExplainStatement, PostgreSQLLoadStatement, PostgreSQLResetParameterStatement, PostgreSQLSetStatement, PostgreSQLShowStatement, PostgreSQLVacuumStatement, SimpleTableSegment, TableNameSegment, VariableAssignSegment, VariableSegment]. 58
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 58

org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 52

org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 132 (max allowed is 10) classes [AddColumnDefinitionSegment, AddConstraintDefinitionSegment, CollectionValue, ColumnDefinitionSegment, ColumnSegment, ConstraintDefinitionSegment, CursorNameSegment, DirectionSegment, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, FunctionSegment, IdentifierValue, IndexNameSegment, IndexSegment, ModifyColumnDefinitionSegment, ModifyConstraintDefinitionSegment, OwnerSegment, PostgreSQLAlterAggregateStatement, PostgreSQLAlterCollationStatement, PostgreSQLAlterConversionStatement, PostgreSQLAlterDefaultPrivilegesStatement, PostgreSQLAlterDomainStatement, PostgreSQLAlterExtensionStatement, PostgreSQLAlterForeignDataWrapperStatement, PostgreSQLAlterForeignTableStatement, PostgreSQLAlterFunctionStatement, PostgreSQLAlterGroupStatement, PostgreSQLAlterIndexStatement, PostgreSQLAlterLanguageStatement, PostgreSQLAlterMaterializedViewStatement, PostgreSQLAlterOperatorStatement, PostgreSQLAlterPolicyStatement, PostgreSQLAlterProcedureStatement, PostgreSQLAlterPublicationStatement, PostgreSQLAlterRoutineStatement, PostgreSQLAlterRuleStatement, PostgreSQLAlterSchemaStatement, PostgreSQLAlterSequenceStatement, PostgreSQLAlterServerStatement, PostgreSQLAlterStatisticsStatement, PostgreSQLAlterSubscriptionStatement, PostgreSQLAlterTableStatement, PostgreSQLAlterTablespaceStatement, PostgreSQLAlterTextSearchStatement, PostgreSQLAlterTriggerStatement, PostgreSQLAlterTypeStatement, PostgreSQLAlterViewStatement, PostgreSQLCloseStatement, PostgreSQLClusterStatement, PostgreSQLCommentStatement, PostgreSQLCreateAccessMethodStatement, PostgreSQLCreateAggregateStatement, PostgreSQLCreateCastStatement, PostgreSQLCreateCollationStatement, PostgreSQLCreateConversionStatement, PostgreSQLCreateDatabaseStatement, PostgreSQLCreateDomainStatement, PostgreSQLCreateEventTriggerStatement, PostgreSQLCreateExtensionStatement, PostgreSQLCreateForeignDataWrapperStatement, PostgreSQLCreateForeignTableStatement, PostgreSQLCreateFunctionStatement, PostgreSQLCreateIndexStatement, PostgreSQLCreateLanguageStatement, PostgreSQLCreateMaterializedViewStatement, PostgreSQLCreateOperatorStatement, PostgreSQLCreatePolicyStatement, PostgreSQLCreateProcedureStatement, PostgreSQLCreatePublicationStatement, PostgreSQLCreateRuleStatement, PostgreSQLCreateSchemaStatement, PostgreSQLCreateSequenceStatement, PostgreSQLCreateTableStatement, PostgreSQLCreateTablespaceStatement, PostgreSQLCreateTextSearchStatement, PostgreSQLCreateTypeStatement, PostgreSQLCreateViewStatement, PostgreSQLDeallocateStatement, PostgreSQLDeclareStatement, PostgreSQLDiscardStatement, PostgreSQLDropAccessMethodStatement, PostgreSQLDropAggregateStatement, PostgreSQLDropCastStatement, PostgreSQLDropCollationStatement, PostgreSQLDropConversionStatement, PostgreSQLDropDatabaseStatement, PostgreSQLDropDomainStatement, PostgreSQLDropEventTriggerStatement, PostgreSQLDropExtensionStatement, PostgreSQLDropForeignDataWrapperStatement, PostgreSQLDropForeignTableStatement, PostgreSQLDropFunctionStatement, PostgreSQLDropGroupStatement, PostgreSQLDropIndexStatement, PostgreSQLDropLanguageStatement, PostgreSQLDropMaterializedViewStatement, PostgreSQLDropOperatorClassStatement, PostgreSQLDropOperatorFamilyStatement, PostgreSQLDropOperatorStatement, PostgreSQLDropOwnedStatement, PostgreSQLDropPolicyStatement, PostgreSQLDropProcedureStatement, PostgreSQLDropPublicationStatement, PostgreSQLDropRoutineStatement, PostgreSQLDropRuleStatement, PostgreSQLDropSchemaStatement, PostgreSQLDropSequenceStatement, PostgreSQLDropServerStatement, PostgreSQLDropStatisticsStatement, PostgreSQLDropSubscriptionStatement, PostgreSQLDropTableStatement, PostgreSQLDropTablespaceStatement, PostgreSQLDropTextSearchStatement, PostgreSQLDropTriggerStatement, PostgreSQLDropTypeStatement, PostgreSQLDropViewStatement, PostgreSQLFetchStatement, PostgreSQLListenStatement, PostgreSQLMoveStatement, PostgreSQLNotifyStmtStatement, PostgreSQLOpenStatement, PostgreSQLPrepareStatement, PostgreSQLRefreshMatViewStmtStatement, PostgreSQLReindexStatement, PostgreSQLSecurityLabelStmtStatement, PostgreSQLTruncateStatement, PostgreSQLUnlistenStatement, RenameColumnSegment, RenameTableDefinitionSegment, SimpleTableSegment, TableNameSegment, ValidateConstraintDefinitionSegment]. 335
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 302 (max allowed is 20). 335
 Warning sizes MethodCount Number of public methods is 148 (max allowed is 100). 335
 Warning sizes MethodCount Total number of methods is 156 (max allowed is 100). 335
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 369

org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 56

org/apache/shardingsphere/sql/parser/postgresql/visitor/statement/type/PostgreSQLTCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [PostgreSQLBeginTransactionStatement, PostgreSQLCheckpointStatement, PostgreSQLCommitPreparedStatement, PostgreSQLCommitStatement, PostgreSQLLockStatement, PostgreSQLPrepareTransactionStatement, PostgreSQLReleaseSavepointStatement, PostgreSQLRollbackPreparedStatement, PostgreSQLRollbackStatement, PostgreSQLSavepointStatement, PostgreSQLSetConstraintsStatement, PostgreSQLSetTransactionStatement, PostgreSQLStartTransactionStatement]. 65
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 37 (max allowed is 20). 65

org/apache/shardingsphere/sql/parser/presto/visitor/statement/PrestoStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 33 (max allowed is 10) classes [BetweenExpression, BigDecimal, BinaryOperationExpression, BooleanLiteralValue, CollateExpression, CollectionValue, ColumnSegment, CommonExpressionSegment, DataTypeLengthSegment, DataTypeSegment, DatabaseSegment, ExistsSubqueryExpression, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, InExpression, IndexNameSegment, IndexSegment, Interval, ListExpression, LiteralExpressionSegment, NotExpression, NullLiteralValue, NumberLiteralValue, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerValue, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubquerySegment, TableNameSegment]. 105
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 72 (max allowed is 20). 105
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 299
 Warning metrics NPathComplexity NPath Complexity is 396 (max allowed is 200). 299
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 463
 Warning metrics NPathComplexity NPath Complexity is 3,456 (max allowed is 200). 463

org/apache/shardingsphere/sql/parser/presto/visitor/statement/type/PrestoDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 52

org/apache/shardingsphere/sql/parser/presto/visitor/statement/type/PrestoDMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 54 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BooleanLiteralValue, CaseWhenExpression, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, CombineSegment, CommonExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, DeleteMultiTableSegment, ExpressionOrderByItemSegment, ExpressionProjectionSegment, FunctionSegment, GroupBySegment, HavingSegment, IdentifierValue, IndexOrderByItemSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, LimitSegment, LiteralExpressionSegment, LockSegment, NumberLiteralLimitValueSegment, NumberLiteralValue, OnDuplicateKeyColumnsSegment, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, PrestoDeleteStatement, PrestoInsertStatement, PrestoSelectStatement, PrestoUpdateStatement, ProjectionsSegment, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StringLiteralValue, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, ValuesExpression, VariableSegment, WhereSegment, WindowItemSegment, WindowSegment]. 197
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 164 (max allowed is 20). 197
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 503
 Warning metrics NPathComplexity NPath Complexity is 4,096 (max allowed is 200). 503
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 1109
 Warning metrics JavaNCSS NCSS for this method is 57 (max allowed is 50). 1109
 Warning metrics NPathComplexity NPath Complexity is 12,288 (max allowed is 200). 1109

org/apache/shardingsphere/sql/parser/sql92/visitor/statement/SQL92StatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 33 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CollectionValue, ColumnOrderByItemSegment, ColumnSegment, CommonExpressionSegment, DataTypeLengthSegment, DataTypeSegment, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, InExpression, IndexOrderByItemSegment, Interval, KeywordValue, ListExpression, LiteralExpressionSegment, NotExpression, NullLiteralValue, NumberLiteralValue, OrderBySegment, OtherLiteralValue, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerValue, SimpleTableSegment, StringLiteralValue, SubqueryExpressionSegment, SubquerySegment, TableNameSegment]. 110
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 75 (max allowed is 20). 110

org/apache/shardingsphere/sql/parser/sql92/visitor/statement/type/SQL92DDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [AddColumnDefinitionSegment, AddConstraintDefinitionSegment, CollectionValue, ColumnDefinitionSegment, ConstraintDefinitionSegment, ConstraintSegment, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, ModifyColumnDefinitionSegment, SQL92AlterTableStatement, SQL92CreateTableStatement, SQL92DropTableStatement]. 63
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 37 (max allowed is 20). 63

org/apache/shardingsphere/sql/parser/sql92/visitor/statement/type/SQL92DMLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 25 (max allowed is 10) classes [AliasSegment, BooleanLiteralValue, ColumnAssignmentSegment, ColumnProjectionSegment, CommonExpressionSegment, ExpressionProjectionSegment, GroupBySegment, HavingSegment, IdentifierValue, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, OwnerSegment, ProjectionsSegment, SQL92DeleteStatement, SQL92InsertStatement, SQL92SelectStatement, SQL92UpdateStatement, SetAssignmentSegment, ShorthandProjectionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, WhereSegment]. 105
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 74 (max allowed is 20). 105
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 304
 Warning metrics NPathComplexity NPath Complexity is 768 (max allowed is 200). 304

org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/SQLServerStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 81 (max allowed is 10) classes [AggregationDistinctProjectionSegment, AggregationProjectionSegment, AliasSegment, BetweenExpression, BinaryOperationExpression, BooleanLiteralValue, CollectionValue, ColumnAssignmentSegment, ColumnOrderByItemSegment, ColumnProjectionSegment, ColumnSegment, CommonExpressionSegment, CommonTableExpressionSegment, ConstraintSegment, DataTypeLengthSegment, DataTypeSegment, DeleteMultiTableSegment, ExecSegment, ExpressionOrderByItemSegment, ExpressionProjectionSegment, ExpressionWithParamsSegment, FunctionNameSegment, FunctionSegment, FunctionTableSegment, GroupBySegment, HavingSegment, IdentifierValue, InExpression, IndexNameSegment, IndexOrderByItemSegment, IndexSegment, InsertColumnsSegment, InsertValuesSegment, Interval, JoinTableSegment, JsonNullClauseSegment, KeyValueSegment, KeywordValue, LimitSegment, ListExpression, LiteralExpressionSegment, MergeWhenAndThenSegment, NotExpression, NullLiteralValue, NumberLiteralLimitValueSegment, NumberLiteralRowNumberValueSegment, NumberLiteralValue, OptionHintSegment, OrderBySegment, OtherLiteralValue, OutputSegment, OwnerSegment, ParameterMarkerExpressionSegment, ParameterMarkerLimitValueSegment, ParameterMarkerRowNumberValueSegment, ParameterMarkerValue, ProjectionsSegment, SQLServerCreateTableStatement, SQLServerDeleteStatement, SQLServerInsertStatement, SQLServerMergeStatement, SQLServerSelectStatement, SQLServerUpdateStatement, SQLServerUpdateStatisticsStatement, SampleOptionSegment, SetAssignmentSegment, ShorthandProjectionSegment, SimpleTableSegment, StatisticsOptionSegment, StatisticsStrategySegment, StringLiteralValue, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableHintLimitedSegment, TableNameSegment, TopProjectionSegment, WhereSegment, WithSegment, WithTableHintSegment]. 249
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 213 (max allowed is 20). 249
 Warning sizes MethodCount Total number of methods is 129 (max allowed is 100). 249
 Warning metrics NPathComplexity NPath Complexity is 512 (max allowed is 200). 682
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 969
 Warning metrics NPathComplexity NPath Complexity is 768 (max allowed is 200). 969
 Warning metrics NPathComplexity NPath Complexity is 256 (max allowed is 200). 1500

org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/type/SQLServerDCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 20 (max allowed is 10) classes [IdentifierValue, LoginSegment, OwnerSegment, SQLServerAlterLoginStatement, SQLServerAlterRoleStatement, SQLServerAlterUserStatement, SQLServerCreateLoginStatement, SQLServerCreateRoleStatement, SQLServerCreateUserStatement, SQLServerDenyUserStatement, SQLServerDropLoginStatement, SQLServerDropRoleStatement, SQLServerDropUserStatement, SQLServerGrantStatement, SQLServerRevertStatement, SQLServerRevokeStatement, SQLServerSetUserStatement, SimpleTableSegment, TableNameSegment, UserSegment]. 76
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 49 (max allowed is 20). 76

org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/type/SQLServerDDLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 39 (max allowed is 10) classes [AddColumnDefinitionSegment, CollectionValue, ColumnDefinitionSegment, ConstraintDefinitionSegment, DropColumnDefinitionSegment, DropConstraintDefinitionSegment, ModifyColumnDefinitionSegment, ModifyConstraintDefinitionSegment, SQLServerAlterDatabaseStatement, SQLServerAlterFunctionStatement, SQLServerAlterIndexStatement, SQLServerAlterProcedureStatement, SQLServerAlterSchemaStatement, SQLServerAlterSequenceStatement, SQLServerAlterServiceStatement, SQLServerAlterTableStatement, SQLServerAlterTriggerStatement, SQLServerAlterViewStatement, SQLServerCreateDatabaseStatement, SQLServerCreateFunctionStatement, SQLServerCreateIndexStatement, SQLServerCreateProcedureStatement, SQLServerCreateSchemaStatement, SQLServerCreateSequenceStatement, SQLServerCreateServiceStatement, SQLServerCreateTableStatement, SQLServerCreateTriggerStatement, SQLServerCreateViewStatement, SQLServerDropDatabaseStatement, SQLServerDropFunctionStatement, SQLServerDropIndexStatement, SQLServerDropProcedureStatement, SQLServerDropSchemaStatement, SQLServerDropSequenceStatement, SQLServerDropServiceStatement, SQLServerDropTableStatement, SQLServerDropTriggerStatement, SQLServerDropViewStatement, SQLServerTruncateStatement]. 128
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 100 (max allowed is 20). 128

org/apache/shardingsphere/sql/parser/sqlserver/visitor/statement/type/SQLServerTCLStatementVisitor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 45

org/apache/shardingsphere/sql/parser/statement/core/util/ColumnExtractUtils.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 56

org/apache/shardingsphere/sql/parser/statement/core/util/ExpressionExtractUtils.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 58
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 25 (max allowed is 10). 164
 Warning metrics JavaNCSS NCSS for this method is 55 (max allowed is 50). 164
 Warning metrics NPathComplexity NPath Complexity is 2,985,984 (max allowed is 200). 164

org/apache/shardingsphere/sql/parser/statement/core/util/ExpressionExtractUtilsTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BinaryOperationExpression, ColumnSegment, CommonExpressionSegment, FunctionSegment, IdentifierValue, InExpression, ListExpression, LiteralExpressionSegment, ParameterMarkerExpressionSegment, TypeCastExpression, WhereSegment]. 45

org/apache/shardingsphere/sql/parser/statement/core/util/SQLUtils.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 122

org/apache/shardingsphere/sql/parser/statement/core/util/SubqueryExtractUtils.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 56
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 142
 Warning metrics NPathComplexity NPath Complexity is 16,384 (max allowed is 200). 142

org/apache/shardingsphere/sql/parser/statement/core/util/SubqueryExtractUtilsTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 19 (max allowed is 10) classes [AggregationProjectionSegment, BinaryOperationExpression, ColumnProjectionSegment, ColumnSegment, CombineSegment, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, InExpression, JoinTableSegment, LiteralExpressionSegment, ProjectionsSegment, SimpleTableSegment, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, WhereSegment]. 54
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 54

org/apache/shardingsphere/sql/parser/statement/core/util/TableExtractor.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 44 (max allowed is 20). 75
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 16 (max allowed is 10). 144
 Warning metrics NPathComplexity NPath Complexity is 32,768 (max allowed is 200). 144
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 205

org/apache/shardingsphere/sql/parser/statement/core/util/TableExtractorTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 25 (max allowed is 10) classes [AggregationProjectionSegment, AliasSegment, BinaryOperationExpression, ColumnAssignmentSegment, ColumnProjectionSegment, ColumnSegment, CombineSegment, ExpressionProjectionSegment, FunctionSegment, IdentifierValue, JoinTableSegment, LiteralExpressionSegment, LockSegment, OnDuplicateKeyColumnsSegment, OwnerSegment, ProjectionsSegment, RoutineBodySegment, ShorthandProjectionSegment, SimpleTableSegment, SubqueryExpressionSegment, SubqueryProjectionSegment, SubquerySegment, TableExtractor, TableNameSegment, ValidStatementSegment]. 64
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 29 (max allowed is 20). 64

org/apache/shardingsphere/sql/parser/statement/core/util/WhereExtractUtilsTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [BinaryOperationExpression, ColumnSegment, IdentifierValue, JoinTableSegment, ProjectionsSegment, SimpleTableSegment, SubqueryProjectionSegment, SubquerySegment, SubqueryTableSegment, TableNameSegment, WhereSegment]. 44

org/apache/shardingsphere/sqlfederation/engine/SQLFederationEngine.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 13 (max allowed is 10) classes [CalciteConnectionConfigImpl, EnumerableScanExecutor, ExecutionPlanCacheKey, JavaTypeFactoryImpl, NoSuchTableException, ProcessEngine, SQLFederationBindContext, SQLFederationCompilerEngine, SQLFederationExecutorContext, SQLFederationResultSet, SQLFederationSchemaNotFoundException, SQLFederationUnsupportedSQLException, SQLStatementCompiler]. 87
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 46 (max allowed is 20). 87

org/apache/shardingsphere/sqlfederation/executor/enumerable/EnumerableScanExecutor.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 14 (max allowed is 10) classes [AbstractEnumerable, ConnectionContext, EmptyRowEnumerator, ExecutionGroupReportContext, HintValueContext, JDBCRowEnumerator, KernelProcessor, MemoryRowEnumerator, MergeEngine, ProcessEngine, QueryContext, SQLBindEngine, SQLStatementParserEngine, SystemDatabase]. 85
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 43 (max allowed is 20). 85

org/apache/shardingsphere/sqlfederation/optimizer/converter/segment/expression/ExpressionConverter.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 74
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 24 (max allowed is 10). 84
 Warning metrics NPathComplexity NPath Complexity is 8,388,608 (max allowed is 200). 84

org/apache/shardingsphere/sqlfederation/optimizer/it/SQLStatementCompilerIT.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 11 (max allowed is 10) classes [CalciteConnectionConfigImpl, DefaultSQLParserRuleConfigurationBuilder, JavaTypeFactoryImpl, Properties, RexBuilder, SQLFederationSchema, SQLParserRule, SQLStatementCompiler, ShardingSphereColumn, ShardingSphereSchema, ShardingSphereTable]. 62
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 62

org/apache/shardingsphere/sqlfederation/optimizer/metadata/schema/SQLFederationTable.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 30 (max allowed is 20). 64

org/apache/shardingsphere/sqlfederation/optimizer/planner/util/SQLFederationPlannerUtils.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 72

org/apache/shardingsphere/sqlfederation/resultset/SQLFederationResultSet.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 27 (max allowed is 20). 58

org/apache/shardingsphere/test/e2e/cases/value/SQLValue.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 45 (max allowed is 10). 48
 Warning metrics JavaNCSS NCSS for this method is 64 (max allowed is 50). 48
 Warning metrics NPathComplexity NPath Complexity is 328 (max allowed is 200). 48

org/apache/shardingsphere/test/e2e/data/pipeline/cases/PipelineContainerComposer.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 34 (max allowed is 20). 84

org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/CDCE2EIT.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 18 (max allowed is 10) classes [CDCClient, CDCClientConfiguration, CDCJobType, CDCLoginParameter, CaseInsensitiveQualifiedTable, ConsistencyCheckJobItemProgressContext, DataSourceRecordConsumer, DatabaseTypeRegistry, E2EIncrementalTask, PipelineContainerComposer, PipelineDataSource, Properties, RetryStreamingExceptionHandler, SnowflakeKeyGenerateAlgorithm, StandardPipelineDataSourceConfiguration, StandardPipelineTableMetaDataLoader, StartStreamingParameter, TableInventoryCheckParameter]. 77
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 32 (max allowed is 20). 77

org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/DataSourceRecordConsumer.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 115

org/apache/shardingsphere/test/e2e/data/pipeline/cases/createtable/CreateTableSQLGeneratorIT.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 56

org/apache/shardingsphere/test/e2e/data/pipeline/cases/migration/primarykey/IndexesMigrationE2EIT.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 63

org/apache/shardingsphere/test/e2e/driver/statement/ShardingPreparedStatementTest.java

Severity Category Rule Message Line
 Warning sizes ExecutableStatementCount Executable statement count is 53 (max allowed is 50). 162
 Warning sizes ExecutableStatementCount Executable statement count is 51 (max allowed is 50). 442

org/apache/shardingsphere/test/e2e/engine/type/dml/BaseDMLE2EIT.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 71
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 14 (max allowed is 10). 240

org/apache/shardingsphere/test/e2e/engine/type/dql/BaseDQLE2EIT.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 21 (max allowed is 20). 59
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 15 (max allowed is 10). 175

org/apache/shardingsphere/test/e2e/showprocesslist/engine/ShowProcessListE2EIT.java

Severity Category Rule Message Line
 Warning coding NestedForDepth Nested for depth is 2 (max allowed is 1). 126

org/apache/shardingsphere/test/it/data/pipeline/core/importer/PipelineDataSourceSinkTest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 12 (max allowed is 10) classes [CaseInsensitiveIdentifier, Column, DataRecord, FinishedRecord, FixtureTransmissionJobItemContext, ImporterConfiguration, IngestFinishedPosition, IngestPlaceholderPosition, PipelineDataSourceSink, SingleChannelConsumerImporter, StandardPipelineDataSourceConfiguration, TableAndSchemaNameMapper]. 64
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 25 (max allowed is 20). 64

org/apache/shardingsphere/test/it/data/pipeline/core/util/PipelineContextUtils.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 24 (max allowed is 10) classes [CaseInsensitiveQualifiedTable, ContextManager, CreateTableConfiguration, DatabaseTypeRegistry, ImporterConfiguration, MetaDataPersistService, MigrationIncrementalDumperContextCreator, MigrationJobItemContext, MigrationTaskConfiguration, PipelineColumnMetaData, PipelineContext, PipelineContextKey, PipelineDataSourceManager, ShardingColumnsExtractor, ShardingSphereColumn, ShardingSpherePipelineDataSourceConfiguration, ShardingSphereTable, TransmissionProcessContext, YamlDataSourceConfigurationSwapper, YamlModeConfigurationSwapper, YamlPipelineProcessConfiguration, YamlPipelineProcessConfigurationSwapper, YamlPipelineReadConfiguration, YamlRuleConfigurationSwapperEngine]. 91
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 42 (max allowed is 20). 91

org/apache/shardingsphere/test/it/data/pipeline/scenario/migration/api/impl/MigrationJobAPITest.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [ConsistencyCheckJobItemProgressContext, DataNode, DataSourcePoolProperties, MigrateTableStatement, MigrationJobType, PipelineDataSource, PipelineDataSourcePersistService, PipelineJobConfigurationManager, PipelineJobItemManager, PipelineJobManager, PipelineProcessConfigurationPersistService, SourceTargetEntry, TransmissionJobManager, TransmissionProcessContext, YamlTransmissionJobItemProgress]. 96
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 38 (max allowed is 20). 96

org/apache/shardingsphere/test/it/optimizer/converter/SQLNodeConverterEngineIT.java

Severity Category Rule Message Line
 Warning metrics BooleanExpressionComplexity Boolean expression complexity is 5 (max allowed is 3). 109

org/apache/shardingsphere/test/it/optimizer/converter/cases/jaxb/RootSQLNodeConverterTestCases.java

Severity Category Rule Message Line
 Warning coding NestedForDepth Nested for depth is 2 (max allowed is 1). 55

org/apache/shardingsphere/test/it/rewrite/engine/SQLRewriterIT.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 23 (max allowed is 10) classes [ConfigurationProperties, CursorConnectionContext, DataSourceProvidedDatabaseConfiguration, DatabaseTypeRegistry, DefaultSQLTranslatorRuleConfigurationBuilder, HintValueContext, Properties, QueryContext, ResourceMetaData, RuleMetaData, SQLBindEngine, SQLParserRule, SQLParserRuleConfiguration, SQLRewriteEntry, SQLRouteEngine, SQLStatementParserEngine, SQLTranslatorRule, ShardingSphereDatabase, ShardingSphereMetaData, TimestampServiceRule, TimestampServiceRuleConfiguration, YamlDataSourceConfigurationSwapper, YamlRuleConfigurationSwapperEngine]. 94
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 42 (max allowed is 20). 94

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/assignment/AssignmentValueAssert.java

Severity Category Rule Message Line
 Warning metrics NPathComplexity NPath Complexity is 512 (max allowed is 200). 51

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/expression/ExpressionAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 66 (max allowed is 20). 108
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 32 (max allowed is 10). 631
 Warning metrics JavaNCSS NCSS for this method is 96 (max allowed is 50). 631

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/projection/ProjectionAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 62

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/segment/table/TableAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 64

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/SQLStatementAssert.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 12 (max allowed is 10). 62

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/dal/DALStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 110 (max allowed is 20). 188
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 54 (max allowed is 10). 198
 Warning sizes ExecutableStatementCount Executable statement count is 54 (max allowed is 50). 198
 Warning metrics JavaNCSS NCSS for this method is 159 (max allowed is 50). 198

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/dcl/DCLStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 40 (max allowed is 20). 83
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 19 (max allowed is 10). 93
 Warning metrics JavaNCSS NCSS for this method is 54 (max allowed is 50). 93

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ddl/DDLStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 78 (max allowed is 20). 140
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 38 (max allowed is 10). 150
 Warning metrics JavaNCSS NCSS for this method is 111 (max allowed is 50). 150

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/dml/DMLStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 59
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 69

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ral/impl/QueryableRALStatementAssert.java

Severity Category Rule Message Line
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 59

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ral/impl/UpdatableRALStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 22 (max allowed is 20). 56

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/ral/impl/pipeline/UpdatablePipelineRALStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 64
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 74

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/rdl/create/CreateRuleStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 23 (max allowed is 20). 58
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 68

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/rdl/drop/DropRuleStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 28 (max allowed is 20). 65
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 13 (max allowed is 10). 75

org/apache/shardingsphere/test/it/sql/parser/internal/asserts/statement/tcl/TCLStatementAssert.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 24 (max allowed is 20). 59
 Warning metrics CyclomaticComplexity Cyclomatic Complexity is 11 (max allowed is 10). 69

org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/jaxb/segment/impl/expr/ExpectedExpression.java

Severity Category Rule Message Line
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 34 (max allowed is 20). 40

org/apache/shardingsphere/transaction/base/seata/at/fixture/MockMessageHandler.java

Severity Category Rule Message Line
 Warning metrics ClassDataAbstractionCoupling Class Data Abstraction Coupling is 15 (max allowed is 10) classes [AbstractResultMessage, AtomicLong, BranchCommitResponse, BranchRegisterResponse, BranchReportResponse, BranchRollbackResponse, ConcurrentLinkedQueue, GlobalBeginResponse, GlobalCommitResponse, GlobalRollbackResponse, GlobalStatusResponse, MergeResultMessage, RegisterRMResponse, RegisterTMResponse, RpcMessage]. 62
 Warning metrics ClassFanOutComplexity Class Fan-Out Complexity is 31 (max allowed is 20). 62