You are viewing a plain text version of this content. The canonical link for it is here.
Posted to notifications@shardingsphere.apache.org by to...@apache.org on 2023/05/21 16:15:12 UTC

[shardingsphere] branch master updated: Fix sonar issues on Upper-case this literal "f" and "d" suffix (#25831)

This is an automated email from the ASF dual-hosted git repository.

totalo pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/shardingsphere.git


The following commit(s) were added to refs/heads/master by this push:
     new 16fd7f44ccf Fix sonar issues on Upper-case this literal "f" and "d" suffix (#25831)
16fd7f44ccf is described below

commit 16fd7f44ccfbca7e72d14365a97dcecb916a035b
Author: Liang Zhang <zh...@apache.org>
AuthorDate: Mon May 22 00:15:04 2023 +0800

    Fix sonar issues on Upper-case this literal "f" and "d" suffix (#25831)
---
 .../agent/core/advisor/executor/AdviceExecutorFactory.java |  2 +-
 .../advice/jdbc/AbstractExecuteLatencyHistogramAdvice.java |  2 +-
 .../core/advice/proxy/ExecuteLatencyHistogramAdvice.java   |  2 +-
 .../metrics/core/exporter/impl/BuildInfoExporter.java      |  2 +-
 .../collector/type/PrometheusMetricsCounterCollector.java  |  4 ++--
 .../collector/type/PrometheusMetricsGaugeCollector.java    |  8 ++++----
 .../protocol/mysql/constant/MySQLAuthenticationPlugin.java |  2 +-
 .../db/protocol/mysql/constant/MySQLBinaryColumnType.java  |  4 ++--
 .../db/protocol/mysql/constant/MySQLBinlogEventType.java   |  2 +-
 .../command/generic/OpenGaussErrorResponsePacket.java      |  4 ++--
 .../postgresql/constant/PostgreSQLArrayColumnType.java     |  2 +-
 .../command/query/extended/PostgreSQLColumnType.java       |  2 +-
 .../packet/generic/PostgreSQLErrorResponsePacket.java      |  4 ++--
 .../packet/handshake/PostgreSQLComStartupPacketTest.java   |  2 +-
 .../scenario/framework/type/JDBCExampleScenario.java       |  2 +-
 .../type/SpringBootStarterJdbcExampleScenario.java         |  2 +-
 .../type/SpringBootStarterJpaExampleScenario.java          |  4 ++--
 .../framework/type/SpringNamespaceJdbcExampleScenario.java |  2 +-
 .../framework/type/SpringNamespaceJpaExampleScenario.java  |  2 +-
 .../encrypt/rewrite/condition/EncryptConditionEngine.java  |  2 +-
 .../YamlCompatibleEncryptRuleConfigurationSwapper.java     |  2 +-
 .../yaml/swapper/YamlEncryptRuleConfigurationSwapper.java  |  2 +-
 .../generator/fixture/EncryptGeneratorFixtureBuilder.java  |  2 +-
 .../shardingsphere/encrypt/rule/EncryptRuleTest.java       |  2 +-
 ...CompatibleEncryptTableRuleConfigurationSwapperTest.java |  5 ++---
 .../rule/YamlEncryptTableRuleConfigurationSwapperTest.java |  5 ++---
 .../handler/converter/EncryptRuleStatementConverter.java   |  2 +-
 .../update/DropEncryptRuleStatementUpdaterTest.java        |  2 +-
 .../yaml/swapper/YamlMaskRuleConfigurationSwapper.java     |  2 +-
 .../handler/converter/MaskRuleStatementConverter.java      |  2 +-
 .../ReadwriteSplittingRuleConfigurationChecker.java        |  2 +-
 .../readwritesplitting/rule/ReadwriteSplittingRule.java    | 12 ++++++------
 .../YamlReadwriteSplittingRuleConfigurationSwapper.java    |  2 +-
 .../ReadwriteSplittingRuleConfigurationCheckerTest.java    |  2 +-
 .../ReadwriteSplittingRuleStatementConverter.java          |  2 +-
 .../query/ShowReadwriteSplittingRuleExecutorTest.java      |  6 +++---
 .../shadow/checker/ShadowRuleConfigurationCheckerTest.java |  2 +-
 .../sharding/datetime/AutoIntervalShardingAlgorithm.java   |  2 +-
 .../algorithm/sharding/mod/ModShardingAlgorithm.java       |  2 +-
 .../sharding/range/AbstractRangeShardingAlgorithm.java     |  2 +-
 .../range/BoundaryBasedRangeShardingAlgorithm.java         |  2 +-
 .../sharding/range/VolumeBasedRangeShardingAlgorithm.java  |  2 +-
 .../merge/dql/groupby/GroupByMemoryMergedResult.java       |  4 ++--
 .../sharding/rewrite/token/pojo/TokenUtils.java            |  2 +-
 .../engine/WhereClauseShardingConditionEngine.java         |  2 +-
 .../type/complex/ShardingCartesianRoutingEngine.java       |  2 +-
 .../engine/type/unicast/ShardingUnicastRoutingEngine.java  |  2 +-
 .../strategy/type/complex/ComplexShardingStrategy.java     |  4 ++--
 .../apache/shardingsphere/sharding/rule/ShardingRule.java  |  6 +++---
 .../org/apache/shardingsphere/sharding/rule/TableRule.java |  6 +++---
 .../keygen/SnowflakeKeyGenerateAlgorithmTest.java          |  2 +-
 .../complex/ComplexInlineShardingAlgorithmTest.java        |  2 +-
 .../fixture/CoreStandardShardingAlgorithmFixture.java      |  2 +-
 .../merge/dal/show/ShowCreateTableMergedResultTest.java    |  2 +-
 .../fixture/ShardingRoutingEngineFixtureBuilder.java       |  2 +-
 .../ShardingDataSourceGroupBroadcastRoutingEngineTest.java |  2 +-
 .../type/standard/assertion/ShardingRouteAssert.java       |  2 +-
 .../sharding/route/strategy/ShardingStrategyTest.java      |  2 +-
 .../handler/checker/ShardingTableRuleStatementChecker.java |  2 +-
 .../distsql/checker/ShardingRuleStatementCheckerTest.java  |  2 +-
 .../fixture/sharding/CoreAutoShardingAlgorithmFixture.java |  2 +-
 .../sharding/CoreStandardShardingAlgorithmFixture.java     |  2 +-
 .../update/AlterShardingTableRuleStatementUpdaterTest.java |  2 +-
 .../CreateShardingTableRuleStatementUpdaterTest.java       |  2 +-
 .../segment/select/projection/engine/ProjectionEngine.java |  2 +-
 .../infra/binder/segment/table/TablesContext.java          |  6 +++---
 .../infra/binder/statement/dml/DeleteStatementContext.java |  2 +-
 .../infra/binder/statement/dml/SelectStatementContext.java |  2 +-
 .../projection/engine/ProjectionsContextEngineTest.java    |  2 +-
 .../infra/database/type/DatabaseTypeEngine.java            |  2 +-
 .../shardingsphere/infra/datanode/DataNodeUtils.java       |  2 +-
 .../datasource/pool/creator/DataSourceReflection.java      |  6 +++---
 .../metadata/type/c3p0/C3P0DataSourcePoolMetaData.java     |  6 +++---
 .../metadata/type/hikari/HikariDataSourcePoolMetaData.java |  6 +++---
 .../infra/datasource/props/DataSourceProperties.java       |  4 ++--
 .../props/custom/CustomDataSourceProperties.java           |  2 +-
 .../infra/datasource/props/synonym/PropertySynonyms.java   |  4 ++--
 .../infra/datasource/state/DataSourceStateManager.java     |  2 +-
 .../infra/metadata/ShardingSphereMetaData.java             |  2 +-
 .../infra/metadata/database/ShardingSphereDatabase.java    |  2 +-
 .../database/resource/ShardingSphereResourceMetaData.java  |  4 ++--
 .../infra/metadata/database/schema/SchemaManager.java      |  4 ++--
 .../database/schema/builder/GenericSchemaBuilder.java      |  4 ++--
 .../database/schema/builder/SystemSchemaBuilder.java       |  4 ++--
 .../database/schema/builder/SystemSchemaBuilderRule.java   |  2 +-
 .../schema/loader/common/SchemaMetaDataLoader.java         |  2 +-
 .../loader/datatype/dialect/MySQLDataTypeLoader.java       |  2 +-
 .../schema/loader/metadata/SchemaMetaDataLoaderEngine.java |  2 +-
 .../metadata/dialect/OracleSchemaMetaDataLoader.java       |  8 ++++----
 .../metadata/dialect/PostgreSQLSchemaMetaDataLoader.java   |  2 +-
 .../database/schema/model/ShardingSphereSchema.java        |  4 ++--
 .../database/schema/model/ShardingSphereTable.java         |  6 +++---
 .../database/schema/reviser/MetaDataReviseEngine.java      |  2 +-
 .../rule/identifier/type/exportable/RuleExportEngine.java  |  2 +-
 .../config/shortcut/YamlRuleConfigurationShortcuts.java    |  2 +-
 .../resource/YamlDataSourceConfigurationSwapper.java       |  2 +-
 .../shardingsphere/infra/datanode/DataNodeUtilsTest.java   |  2 +-
 .../metadata/fixture/MockedDataSourcePoolMetaData.java     |  4 ++--
 .../infra/datasource/props/DataSourcePropertiesTest.java   |  6 +++---
 .../props/custom/CustomDataSourcePropertiesTest.java       |  2 +-
 .../props/synonym/ConnectionPropertySynonymsTest.java      |  6 +++---
 .../datasource/props/synonym/PoolPropertySynonymsTest.java |  6 +++---
 .../builder/PostgreSQLShardingSphereDataBuilderTest.java   | 14 ++++----------
 .../database/schema/util/SchemaMetaDataUtilsTest.java      |  2 +-
 .../resource/YamlDataSourcePropertiesSwapperTest.java      |  8 ++++----
 .../executor/sql/context/ExecutionContextBuilder.java      |  2 +-
 .../shardingsphere/infra/executor/sql/log/SQLLogger.java   |  2 +-
 .../sql/prepare/AbstractExecutionPrepareEngine.java        |  2 +-
 .../sql/prepare/driver/DriverExecutionPrepareEngine.java   |  2 +-
 .../executor/sql/context/ExecutionContextBuilderTest.java  | 14 ++++++--------
 .../infra/rewrite/engine/RouteSQLRewriteEngine.java        |  6 +++---
 .../shardingsphere/infra/rewrite/SQLRewriteEntryTest.java  |  2 +-
 .../shardingsphere/infra/route/context/RouteContext.java   |  4 ++--
 .../shardingsphere/infra/route/context/RouteUnit.java      |  2 +-
 .../shardingsphere/infra/util/props/TypedProperties.java   |  2 +-
 .../infra/util/spi/type/ordered/OrderedSPILoader.java      |  4 ++--
 .../util/spi/type/ordered/cache/OrderedServicesCache.java  |  4 ++--
 .../yaml/representer/ShardingSphereYamlRepresenter.java    |  2 +-
 .../spi/type/ordered/cache/OrderedServicesCacheTest.java   |  2 +-
 .../representer/ShardingSphereYamlRepresenterTest.java     |  2 +-
 .../jdbc/core/resultset/ShardingSphereResultSetUtils.java  |  2 +-
 .../api/yaml/YamlShardingSphereDataSourceFactoryTest.java  |  4 ++--
 .../executor/batch/BatchPreparedStatementExecutorTest.java |  2 +-
 .../connection/DriverDatabaseConnectionManagerTest.java    |  4 ++--
 .../core/resultset/ShardingSphereResultSetUtilsTest.java   |  2 +-
 .../database/builder/DatabasePrivilegeBuilder.java         |  4 ++--
 .../pipeline/api/config/TableNameSchemaNameMapping.java    |  2 +-
 .../impl/StandardPipelineDataSourceConfiguration.java      |  2 +-
 .../data/pipeline/cdc/util/CDCSchemaTableUtilsTest.java    |  4 ++--
 .../core/api/impl/GovernanceRepositoryAPIImpl.java         |  2 +-
 .../core/api/impl/PipelineDataSourcePersistService.java    |  4 ++--
 .../datasource/config/yaml/YamlJdbcConfigurationTest.java  |  2 +-
 .../core/datasource/PipelineDataSourceFactoryTest.java     |  2 +-
 .../mysql/check/datasource/MySQLDataSourceChecker.java     |  2 +-
 .../scenario/migration/api/impl/MigrationJobAPI.java       |  2 +-
 .../metadata/factory/ExternalMetaDataFactory.java          |  8 ++++----
 .../metadata/factory/InternalMetaDataFactory.java          |  2 +-
 .../metadata/factory/NewInternalMetaDataFactory.java       |  2 +-
 .../metadata/persist/MetaDataPersistService.java           |  4 ++--
 .../metadata/persist/NewMetaDataPersistService.java        |  4 ++--
 .../service/database/DatabaseMetaDataPersistService.java   |  2 +-
 .../service/schema/TableMetaDataPersistService.java        |  2 +-
 .../persist/service/schema/ViewMetaDataPersistService.java |  2 +-
 .../metadata/persist/MetaDataPersistServiceTest.java       |  2 +-
 .../single/datanode/SingleTableDataNodeLoader.java         |  2 +-
 .../single/datanode/SingleTableDataNodeLoaderTest.java     |  2 +-
 .../shardingsphere/single/route/SingleSQLRouterTest.java   |  4 ++--
 .../engine/SingleDatabaseBroadcastRouteEngineTest.java     |  2 +-
 .../single/route/engine/SingleStandardRouteEngineTest.java |  2 +-
 .../apache/shardingsphere/single/rule/SingleRuleTest.java  |  2 +-
 .../advanced/AdvancedSQLFederationExecutor.java            |  2 +-
 .../advanced/resultset/SQLFederationResultSet.java         |  4 ++--
 .../advanced/AdvancedSQLFederationExecutorTest.java        |  2 +-
 .../context/planner/OptimizerPlannerContextFactory.java    |  2 +-
 .../expression/impl/LiteralExpressionConverter.java        |  4 ++--
 .../optimizer/metadata/filter/FilterableDatabase.java      |  2 +-
 .../optimizer/metadata/filter/FilterableSchema.java        |  2 +-
 .../metadata/translatable/TranslatableDatabase.java        |  2 +-
 .../metadata/translatable/TranslatableSchema.java          |  2 +-
 .../transaction/ConnectionSavepointManager.java            |  2 +-
 .../shardingsphere/transaction/rule/TransactionRule.java   |  4 ++--
 .../transaction/rule/TransactionRuleTest.java              |  8 ++++----
 .../rule/builder/TransactionRuleBuilderTest.java           |  2 +-
 .../transaction/xa/XAShardingSphereTransactionManager.java |  2 +-
 .../xa/jta/datasource/swapper/DataSourceSwapper.java       |  2 +-
 .../xa/XAShardingSphereTransactionManagerTest.java         |  4 ++--
 .../apache/shardingsphere/mode/manager/ContextManager.java |  2 +-
 .../mode/manager/switcher/ResourceSwitchManager.java       |  2 +-
 .../mode/metadata/MetaDataContextsFactory.java             |  4 ++--
 .../mode/metadata/NewMetaDataContextsFactory.java          |  4 ++--
 .../shardingsphere/mode/manager/ContextManagerTest.java    |  4 ++--
 .../mode/manager/switcher/ResourceSwitchManagerTest.java   |  6 +++---
 .../status/storage/service/StorageNodeStatusService.java   |  2 +-
 .../subscriber/ConfigurationChangedSubscriberTest.java     |  6 +++---
 .../subscriber/ResourceMetaDataChangedSubscriberTest.java  |  2 +-
 .../mode/repository/cluster/consul/ConsulRepository.java   |  4 ++--
 .../repository/cluster/consul/ConsulRepositoryTest.java    |  2 +-
 .../mode/repository/cluster/nacos/NacosRepository.java     |  4 ++--
 .../mode/repository/cluster/nacos/NacosRepositoryTest.java |  4 ++--
 .../segment/converter/DataSourceSegmentsConverter.java     |  2 +-
 .../sql/parser/sql/common/enums/LogicalOperator.java       |  2 +-
 .../config/yaml/swapper/YamlProxyConfigurationSwapper.java |  4 ++--
 .../storage/unit/RegisterStorageUnitBackendHandler.java    |  2 +-
 .../distsql/rql/storage/unit/ShowStorageUnitExecutor.java  |  2 +-
 .../util/YamlDatabaseConfigurationImportExecutor.java      |  2 +-
 .../jdbc/datasource/JDBCBackendDataSourceTest.java         |  4 ++--
 .../proxy/backend/context/ProxyContextTest.java            |  2 +-
 .../executor/DefaultDatabaseMetaDataExecutorTest.java      |  2 +-
 .../data/impl/UnicastDatabaseBackendHandlerTest.java       |  2 +-
 .../handler/database/DropDatabaseBackendHandlerTest.java   |  2 +-
 .../queryable/ExportDatabaseConfigurationExecutorTest.java |  2 +-
 .../distsql/ral/queryable/ExportMetaDataExecutorTest.java  |  2 +-
 .../ral/queryable/ExportStorageNodesExecutorTest.java      |  2 +-
 .../distsql/ral/updatable/ImportMetaDataUpdaterTest.java   |  4 ++--
 .../rql/storage/unit/ShowStorageUnitExecutorTest.java      |  2 +-
 .../backend/hbase/connector/HBaseConnectionFactory.java    |  2 +-
 .../backend/hbase/result/query/HBaseListResultSet.java     |  2 +-
 .../admin/executor/ShowCreateDatabaseExecutorTest.java     |  2 +-
 .../handler/admin/executor/ShowDatabasesExecutorTest.java  |  6 +++---
 .../admin/executor/ShowFunctionStatusExecutorTest.java     |  2 +-
 .../admin/executor/ShowProcedureStatusExecutorTest.java    |  2 +-
 .../handler/admin/executor/ShowTablesExecutorTest.java     |  4 ++--
 .../handler/admin/executor/UseDatabaseExecutorTest.java    |  2 +-
 .../information/SelectInformationSchemataExecutorTest.java |  2 +-
 .../postgresql/handler/admin/PostgreSQLCharacterSets.java  |  2 +-
 .../handler/admin/executor/SelectTableExecutorTest.java    |  2 +-
 .../proxy/frontend/state/ProxyStateContext.java            |  2 +-
 .../MySQLComStmtPrepareParameterMarkerExtractor.java       |  2 +-
 .../postgresql/command/query/PostgreSQLCommand.java        |  2 +-
 .../shardingsphere/test/e2e/driver/AbstractDriverTest.java |  2 +-
 .../sharding/JDBCStandardShardingAlgorithmFixture.java     |  2 +-
 .../container/atomic/storage/EmbeddedStorageContainer.java |  4 ++--
 .../impl/mysql/MySQLContainerConfigurationFactory.java     |  2 +-
 .../opengauss/OpenGaussContainerConfigurationFactory.java  |  2 +-
 .../e2e/fixture/ITStandardShardingAlgorithmFixture.java    |  2 +-
 .../data/pipeline/cases/cdc/DataSourceRecordConsumer.java  |  2 +-
 .../PipelineProxyClusterContainerConfigurationFactory.java |  2 +-
 .../composer/ClusterShowProcessListContainerComposer.java  |  2 +-
 .../config/mysql/MySQLContainerConfigurationFactory.java   |  2 +-
 .../PostgreSQLContainerConfigurationFactory.java           |  2 +-
 .../proxy/ProxyClusterContainerConfigurationFactory.java   |  2 +-
 .../e2e/container/compose/ContainerComposerRegistry.java   |  2 +-
 .../config/ProxyClusterContainerConfigurationFactory.java  |  2 +-
 .../ProxyStandaloneContainerConfigurationFactory.java      |  2 +-
 .../test/e2e/env/DataSetEnvironmentManager.java            |  2 +-
 .../pool/metadata/MockedDataSourcePoolMetaData.java        |  4 ++--
 .../internal/cases/parser/jaxb/RootSQLParserTestCases.java |  2 +-
 .../parser/loader/SQLParserTestCaseLoaderCallback.java     |  4 ++--
 .../it/data/pipeline/core/util/PipelineContextUtils.java   |  2 +-
 .../scenario/migration/api/impl/MigrationJobAPITest.java   |  6 +++---
 .../test/it/rewrite/engine/SQLRewriterIT.java              |  4 ++--
 231 files changed, 337 insertions(+), 347 deletions(-)

diff --git a/agent/core/src/main/java/org/apache/shardingsphere/agent/core/advisor/executor/AdviceExecutorFactory.java b/agent/core/src/main/java/org/apache/shardingsphere/agent/core/advisor/executor/AdviceExecutorFactory.java
index 6b5f93aaa67..c915ce3436f 100644
--- a/agent/core/src/main/java/org/apache/shardingsphere/agent/core/advisor/executor/AdviceExecutorFactory.java
+++ b/agent/core/src/main/java/org/apache/shardingsphere/agent/core/advisor/executor/AdviceExecutorFactory.java
@@ -90,7 +90,7 @@ public final class AdviceExecutorFactory {
     
     @SuppressWarnings("unchecked")
     private <T extends AgentAdvice> Map<String, Collection<T>> convert(final Map<String, Collection<AgentAdvice>> advices) {
-        Map<String, Collection<T>> result = new HashMap<>(advices.size(), 1);
+        Map<String, Collection<T>> result = new HashMap<>(advices.size(), 1F);
         for (Entry<String, Collection<AgentAdvice>> entry : advices.entrySet()) {
             result.put(entry.getKey(), new LinkedList<>());
             for (AgentAdvice each : entry.getValue()) {
diff --git a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/jdbc/AbstractExecuteLatencyHistogramAdvice.java b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/jdbc/AbstractExecuteLatencyHistogramAdvice.java
index a0df6b72817..8f965cdb3ce 100644
--- a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/jdbc/AbstractExecuteLatencyHistogramAdvice.java
+++ b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/jdbc/AbstractExecuteLatencyHistogramAdvice.java
@@ -39,7 +39,7 @@ public abstract class AbstractExecuteLatencyHistogramAdvice implements InstanceM
             "Statement execute latency millis histogram", Collections.singletonMap("buckets", getBuckets()));
     
     private Map<String, Object> getBuckets() {
-        Map<String, Object> result = new HashMap<>(4, 1);
+        Map<String, Object> result = new HashMap<>(4, 1F);
         result.put("type", "exp");
         result.put("start", 1);
         result.put("factor", 2);
diff --git a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/proxy/ExecuteLatencyHistogramAdvice.java b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/proxy/ExecuteLatencyHistogramAdvice.java
index b3159528399..757f604cc95 100644
--- a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/proxy/ExecuteLatencyHistogramAdvice.java
+++ b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/advice/proxy/ExecuteLatencyHistogramAdvice.java
@@ -42,7 +42,7 @@ public final class ExecuteLatencyHistogramAdvice implements InstanceMethodAdvice
     private final MethodTimeRecorder methodTimeRecorder = new MethodTimeRecorder(ExecuteLatencyHistogramAdvice.class);
     
     private Map<String, Object> getBuckets() {
-        Map<String, Object> result = new HashMap<>(4, 1);
+        Map<String, Object> result = new HashMap<>(4, 1F);
         result.put("type", "exp");
         result.put("start", 1);
         result.put("factor", 2);
diff --git a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/BuildInfoExporter.java b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/BuildInfoExporter.java
index cdb446b9a9c..a55e6fc7393 100644
--- a/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/BuildInfoExporter.java
+++ b/agent/plugins/metrics/core/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/core/exporter/impl/BuildInfoExporter.java
@@ -40,7 +40,7 @@ public final class BuildInfoExporter implements MetricsExporter {
     public Optional<GaugeMetricFamilyMetricsCollector> export(final String pluginType) {
         GaugeMetricFamilyMetricsCollector result = MetricsCollectorRegistry.get(config, pluginType);
         result.cleanMetrics();
-        result.addMetric(Arrays.asList("ShardingSphere", ShardingSphereVersion.VERSION), 1d);
+        result.addMetric(Arrays.asList("ShardingSphere", ShardingSphereVersion.VERSION), 1D);
         return Optional.of(result);
     }
 }
diff --git a/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsCounterCollector.java b/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsCounterCollector.java
index 746a4d1808d..bc96c2ecc05 100644
--- a/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsCounterCollector.java
+++ b/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsCounterCollector.java
@@ -34,11 +34,11 @@ public final class PrometheusMetricsCounterCollector implements CounterMetricsCo
     
     @Override
     public void inc() {
-        counter.inc(1d);
+        counter.inc(1D);
     }
     
     @Override
     public void inc(final String... labels) {
-        counter.labels(labels).inc(1d);
+        counter.labels(labels).inc(1D);
     }
 }
diff --git a/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsGaugeCollector.java b/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsGaugeCollector.java
index b64581b5346..ea6b23796d2 100644
--- a/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsGaugeCollector.java
+++ b/agent/plugins/metrics/type/prometheus/src/main/java/org/apache/shardingsphere/agent/plugin/metrics/prometheus/collector/type/PrometheusMetricsGaugeCollector.java
@@ -34,21 +34,21 @@ public final class PrometheusMetricsGaugeCollector implements GaugeMetricsCollec
     
     @Override
     public void inc() {
-        gauge.inc(1d);
+        gauge.inc(1D);
     }
     
     @Override
     public void inc(final String... labels) {
-        gauge.labels(labels).inc(1d);
+        gauge.labels(labels).inc(1D);
     }
     
     @Override
     public void dec() {
-        gauge.dec(1d);
+        gauge.dec(1D);
     }
     
     @Override
     public void dec(final String... labels) {
-        gauge.labels(labels).dec(1d);
+        gauge.labels(labels).dec(1D);
     }
 }
diff --git a/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLAuthenticationPlugin.java b/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLAuthenticationPlugin.java
index fb13a007973..13af13af3e4 100644
--- a/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLAuthenticationPlugin.java
+++ b/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLAuthenticationPlugin.java
@@ -40,7 +40,7 @@ public enum MySQLAuthenticationPlugin {
     
     SHA256_AUTHENTICATION("sha256_password");
     
-    private static final Map<String, MySQLAuthenticationPlugin> VALUE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1);
+    private static final Map<String, MySQLAuthenticationPlugin> VALUE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1F);
     
     static {
         for (MySQLAuthenticationPlugin each : values()) {
diff --git a/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinaryColumnType.java b/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinaryColumnType.java
index 04cd61b8adf..f743664bed1 100644
--- a/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinaryColumnType.java
+++ b/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinaryColumnType.java
@@ -103,9 +103,9 @@ public enum MySQLBinaryColumnType implements BinaryColumnType {
     
     MYSQL_TYPE_GEOMETRY(0xff);
     
-    private static final Map<Integer, MySQLBinaryColumnType> JDBC_TYPE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1);
+    private static final Map<Integer, MySQLBinaryColumnType> JDBC_TYPE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1F);
     
-    private static final Map<Integer, MySQLBinaryColumnType> VALUE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1);
+    private static final Map<Integer, MySQLBinaryColumnType> VALUE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1F);
     
     private final int value;
     
diff --git a/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinlogEventType.java b/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinlogEventType.java
index 9621d85cc3f..cb4562795fd 100644
--- a/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinlogEventType.java
+++ b/db-protocol/mysql/src/main/java/org/apache/shardingsphere/db/protocol/mysql/constant/MySQLBinlogEventType.java
@@ -118,7 +118,7 @@ public enum MySQLBinlogEventType {
     
     HEARTBEAT_LOG_EVENT_V2(41);
     
-    private static final Map<Integer, MySQLBinlogEventType> VALUE_AND_EVENT_TYPE_MAP = new HashMap<>(values().length, 1);
+    private static final Map<Integer, MySQLBinlogEventType> VALUE_AND_EVENT_TYPE_MAP = new HashMap<>(values().length, 1F);
     
     private final int value;
     
diff --git a/db-protocol/opengauss/src/main/java/org/apache/shardingsphere/db/protocol/opengauss/packet/command/generic/OpenGaussErrorResponsePacket.java b/db-protocol/opengauss/src/main/java/org/apache/shardingsphere/db/protocol/opengauss/packet/command/generic/OpenGaussErrorResponsePacket.java
index 5a893d00fef..b6bb0fc88dc 100644
--- a/db-protocol/opengauss/src/main/java/org/apache/shardingsphere/db/protocol/opengauss/packet/command/generic/OpenGaussErrorResponsePacket.java
+++ b/db-protocol/opengauss/src/main/java/org/apache/shardingsphere/db/protocol/opengauss/packet/command/generic/OpenGaussErrorResponsePacket.java
@@ -61,13 +61,13 @@ public final class OpenGaussErrorResponsePacket implements PostgreSQLIdentifierP
     private final Map<Character, String> fields;
     
     public OpenGaussErrorResponsePacket(final ServerErrorMessage serverErrorMessage) {
-        fields = new LinkedHashMap<>(13, 1);
+        fields = new LinkedHashMap<>(13, 1F);
         fillFieldsByServerErrorMessage(serverErrorMessage);
         fillRequiredFieldsIfNecessary();
     }
     
     public OpenGaussErrorResponsePacket(final String severityLevel, final String sqlState, final String message) {
-        fields = new LinkedHashMap<>(4, 1);
+        fields = new LinkedHashMap<>(4, 1F);
         fields.put(FIELD_TYPE_SEVERITY, severityLevel);
         fields.put(FIELD_TYPE_CODE, sqlState);
         fields.put(FIELD_TYPE_MESSAGE, message);
diff --git a/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/constant/PostgreSQLArrayColumnType.java b/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/constant/PostgreSQLArrayColumnType.java
index 5e4fd87756e..1523579d60d 100644
--- a/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/constant/PostgreSQLArrayColumnType.java
+++ b/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/constant/PostgreSQLArrayColumnType.java
@@ -30,7 +30,7 @@ import java.util.Map;
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
 public final class PostgreSQLArrayColumnType {
     
-    private static final Map<String, Integer> COLUMN_TYPE_NAME_OID_MAP = new HashMap<>(128, 1);
+    private static final Map<String, Integer> COLUMN_TYPE_NAME_OID_MAP = new HashMap<>(128, 1F);
     
     // CHECKSTYLE:OFF
     static {
diff --git a/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLColumnType.java b/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLColumnType.java
index 64246486377..062b3773aeb 100644
--- a/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLColumnType.java
+++ b/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/command/query/extended/PostgreSQLColumnType.java
@@ -154,7 +154,7 @@ public enum PostgreSQLColumnType implements BinaryColumnType {
     
     POSTGRESQL_TYPE_REF_CURSOR_ARRAY(2201);
     
-    private static final Map<Integer, PostgreSQLColumnType> JDBC_TYPE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1);
+    private static final Map<Integer, PostgreSQLColumnType> JDBC_TYPE_AND_COLUMN_TYPE_MAP = new HashMap<>(values().length, 1F);
     
     private final int value;
     
diff --git a/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/generic/PostgreSQLErrorResponsePacket.java b/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/generic/PostgreSQLErrorResponsePacket.java
index 5d865cffa1a..7de1b7c4376 100644
--- a/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/generic/PostgreSQLErrorResponsePacket.java
+++ b/db-protocol/postgresql/src/main/java/org/apache/shardingsphere/db/protocol/postgresql/packet/generic/PostgreSQLErrorResponsePacket.java
@@ -73,7 +73,7 @@ public final class PostgreSQLErrorResponsePacket implements PostgreSQLIdentifier
     
     public static final char FIELD_TYPE_ROUTINE = 'R';
     
-    private final Map<Character, String> fields = new LinkedHashMap<>(16, 1);
+    private final Map<Character, String> fields = new LinkedHashMap<>(16, 1F);
     
     private PostgreSQLErrorResponsePacket(final Map<Character, String> fields) {
         this.fields.putAll(fields);
@@ -130,7 +130,7 @@ public final class PostgreSQLErrorResponsePacket implements PostgreSQLIdentifier
     
     public static final class Builder {
         
-        private final Map<Character, String> fields = new LinkedHashMap<>(16, 1);
+        private final Map<Character, String> fields = new LinkedHashMap<>(16, 1F);
         
         private Builder(final String severity, final String sqlState, final String message) {
             Preconditions.checkArgument(null != severity, "The severity is always present!");
diff --git a/db-protocol/postgresql/src/test/java/org/apache/shardingsphere/db/protocol/postgresql/packet/handshake/PostgreSQLComStartupPacketTest.java b/db-protocol/postgresql/src/test/java/org/apache/shardingsphere/db/protocol/postgresql/packet/handshake/PostgreSQLComStartupPacketTest.java
index 9274b12b333..414c8804897 100644
--- a/db-protocol/postgresql/src/test/java/org/apache/shardingsphere/db/protocol/postgresql/packet/handshake/PostgreSQLComStartupPacketTest.java
+++ b/db-protocol/postgresql/src/test/java/org/apache/shardingsphere/db/protocol/postgresql/packet/handshake/PostgreSQLComStartupPacketTest.java
@@ -48,7 +48,7 @@ class PostgreSQLComStartupPacketTest {
     }
     
     private Map<String, String> createParametersMap() {
-        Map<String, String> result = new LinkedHashMap<>(2, 1);
+        Map<String, String> result = new LinkedHashMap<>(2, 1F);
         result.put("database", "test_db");
         result.put("user", "postgres");
         result.put("client_encoding", "UTF8");
diff --git a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/JDBCExampleScenario.java b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/JDBCExampleScenario.java
index 710980af858..08012deae53 100644
--- a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/JDBCExampleScenario.java
+++ b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/JDBCExampleScenario.java
@@ -48,7 +48,7 @@ public final class JDBCExampleScenario implements FrameworkExampleScenario {
     
     @Override
     public Collection<String> getJavaClassPaths() {
-        Collection<String> result = new HashSet<>(2, 1);
+        Collection<String> result = new HashSet<>(2, 1F);
         result.add("config");
         result.add("repository");
         return result;
diff --git a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJdbcExampleScenario.java b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJdbcExampleScenario.java
index 144b4bc14b1..1fd50e26046 100644
--- a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJdbcExampleScenario.java
+++ b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJdbcExampleScenario.java
@@ -41,7 +41,7 @@ public final class SpringBootStarterJdbcExampleScenario implements FrameworkExam
     
     @Override
     public Map<String, String> getResourceTemplateMap() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("resources/properties/application.ftl", "application.properties");
         result.put("resources/yaml/config.ftl", "config.yaml");
         return result;
diff --git a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJpaExampleScenario.java b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJpaExampleScenario.java
index c7141761836..af20be8a67f 100644
--- a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJpaExampleScenario.java
+++ b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringBootStarterJpaExampleScenario.java
@@ -31,7 +31,7 @@ public final class SpringBootStarterJpaExampleScenario implements FrameworkExamp
     
     @Override
     public Map<String, String> getJavaClassTemplateMap() {
-        Map<String, String> result = new HashMap<>(4, 1);
+        Map<String, String> result = new HashMap<>(4, 1F);
         result.put("java/main/SpringBootStarJpaExampleMain.ftl", "ExampleMain.java");
         result.put("java/repository/jpa/OrderItemRepository.ftl", "repository/OrderItemRepository.java");
         result.put("java/repository/jpa/OrderRepository.ftl", "repository/OrderRepository.java");
@@ -41,7 +41,7 @@ public final class SpringBootStarterJpaExampleScenario implements FrameworkExamp
     
     @Override
     public Map<String, String> getResourceTemplateMap() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("resources/properties/application.ftl", "application.properties");
         result.put("resources/yaml/config.ftl", "config.yaml");
         return result;
diff --git a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJdbcExampleScenario.java b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJdbcExampleScenario.java
index ed7225ee1fd..db169eb665b 100644
--- a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJdbcExampleScenario.java
+++ b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJdbcExampleScenario.java
@@ -41,7 +41,7 @@ public final class SpringNamespaceJdbcExampleScenario implements FrameworkExampl
     
     @Override
     public Map<String, String> getResourceTemplateMap() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("resources/xml/application.ftl", "application.xml");
         result.put("resources/yaml/config.ftl", "config.yaml");
         return result;
diff --git a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJpaExampleScenario.java b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJpaExampleScenario.java
index e4d99874257..c417e479ec8 100644
--- a/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJpaExampleScenario.java
+++ b/examples/shardingsphere-example-generator/src/main/java/org/apache/shardingsphere/example/generator/scenario/framework/type/SpringNamespaceJpaExampleScenario.java
@@ -41,7 +41,7 @@ public final class SpringNamespaceJpaExampleScenario implements FrameworkExample
     
     @Override
     public Map<String, String> getResourceTemplateMap() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("resources/xml/application.ftl", "application.xml");
         result.put("resources/yaml/config.ftl", "config.yaml");
         return result;
diff --git a/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/rewrite/condition/EncryptConditionEngine.java b/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/rewrite/condition/EncryptConditionEngine.java
index 135f4e097b1..2c67868a7c5 100644
--- a/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/rewrite/condition/EncryptConditionEngine.java
+++ b/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/rewrite/condition/EncryptConditionEngine.java
@@ -104,7 +104,7 @@ public final class EncryptConditionEngine {
     }
     
     private void addEncryptConditions(final Collection<EncryptCondition> encryptConditions, final Collection<ExpressionSegment> predicates, final Map<String, String> expressionTableNames) {
-        Collection<Integer> stopIndexes = new HashSet<>(predicates.size(), 1);
+        Collection<Integer> stopIndexes = new HashSet<>(predicates.size(), 1F);
         for (ExpressionSegment each : predicates) {
             if (stopIndexes.add(each.getStopIndex())) {
                 addEncryptConditions(encryptConditions, each, expressionTableNames);
diff --git a/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlCompatibleEncryptRuleConfigurationSwapper.java b/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlCompatibleEncryptRuleConfigurationSwapper.java
index 5e09f246af8..0378d431ac6 100644
--- a/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlCompatibleEncryptRuleConfigurationSwapper.java
+++ b/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlCompatibleEncryptRuleConfigurationSwapper.java
@@ -70,7 +70,7 @@ public final class YamlCompatibleEncryptRuleConfigurationSwapper implements Yaml
     }
     
     private Map<String, AlgorithmConfiguration> swapEncryptAlgorithm(final YamlCompatibleEncryptRuleConfiguration yamlConfig) {
-        Map<String, AlgorithmConfiguration> result = new LinkedHashMap<>(yamlConfig.getEncryptors().size(), 1);
+        Map<String, AlgorithmConfiguration> result = new LinkedHashMap<>(yamlConfig.getEncryptors().size(), 1F);
         for (Entry<String, YamlAlgorithmConfiguration> entry : yamlConfig.getEncryptors().entrySet()) {
             result.put(entry.getKey(), algorithmSwapper.swapToObject(entry.getValue()));
         }
diff --git a/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlEncryptRuleConfigurationSwapper.java b/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlEncryptRuleConfigurationSwapper.java
index a32dd1b8334..dfbf9f9173e 100644
--- a/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlEncryptRuleConfigurationSwapper.java
+++ b/features/encrypt/core/src/main/java/org/apache/shardingsphere/encrypt/yaml/swapper/YamlEncryptRuleConfigurationSwapper.java
@@ -67,7 +67,7 @@ public final class YamlEncryptRuleConfigurationSwapper implements YamlRuleConfig
     }
     
     private Map<String, AlgorithmConfiguration> swapEncryptAlgorithm(final YamlEncryptRuleConfiguration yamlConfig) {
-        Map<String, AlgorithmConfiguration> result = new LinkedHashMap<>(yamlConfig.getEncryptors().size(), 1);
+        Map<String, AlgorithmConfiguration> result = new LinkedHashMap<>(yamlConfig.getEncryptors().size(), 1F);
         for (Entry<String, YamlAlgorithmConfiguration> entry : yamlConfig.getEncryptors().entrySet()) {
             result.put(entry.getKey(), algorithmSwapper.swapToObject(entry.getValue()));
         }
diff --git a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rewrite/token/generator/fixture/EncryptGeneratorFixtureBuilder.java b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rewrite/token/generator/fixture/EncryptGeneratorFixtureBuilder.java
index f0e0aad4dee..3979efc16ba 100644
--- a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rewrite/token/generator/fixture/EncryptGeneratorFixtureBuilder.java
+++ b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rewrite/token/generator/fixture/EncryptGeneratorFixtureBuilder.java
@@ -77,7 +77,7 @@ public final class EncryptGeneratorFixtureBuilder {
      * @return created encrypt rule
      */
     public static EncryptRule createEncryptRule() {
-        Map<String, AlgorithmConfiguration> encryptors = new LinkedHashMap<>(2, 1);
+        Map<String, AlgorithmConfiguration> encryptors = new LinkedHashMap<>(2, 1F);
         encryptors.put("standard_encryptor", new AlgorithmConfiguration("CORE.FIXTURE", new Properties()));
         encryptors.put("assisted_encryptor", new AlgorithmConfiguration("CORE.QUERY_ASSISTED.FIXTURE", new Properties()));
         encryptors.put("like_encryptor", new AlgorithmConfiguration("CORE.QUERY_LIKE.FIXTURE", new Properties()));
diff --git a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rule/EncryptRuleTest.java b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rule/EncryptRuleTest.java
index c80a312378b..cf35beb090f 100644
--- a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rule/EncryptRuleTest.java
+++ b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/rule/EncryptRuleTest.java
@@ -173,7 +173,7 @@ class EncryptRuleTest {
     
     private Map<String, AlgorithmConfiguration> getEncryptors(final AlgorithmConfiguration standardEncryptConfig, final AlgorithmConfiguration queryAssistedEncryptConfig,
                                                               final AlgorithmConfiguration queryLikeEncryptConfig) {
-        Map<String, AlgorithmConfiguration> result = new HashMap<>(2, 1);
+        Map<String, AlgorithmConfiguration> result = new HashMap<>(2, 1F);
         result.put("standard_encryptor", standardEncryptConfig);
         result.put("assisted_encryptor", queryAssistedEncryptConfig);
         result.put("like_encryptor", queryLikeEncryptConfig);
diff --git a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlCompatibleEncryptTableRuleConfigurationSwapperTest.java b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlCompatibleEncryptTableRuleConfigurationSwapperTest.java
index 62600472146..2e8c4f33215 100644
--- a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlCompatibleEncryptTableRuleConfigurationSwapperTest.java
+++ b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlCompatibleEncryptTableRuleConfigurationSwapperTest.java
@@ -26,7 +26,7 @@ import org.junit.jupiter.api.Test;
 
 import java.util.Arrays;
 import java.util.Collection;
-import java.util.LinkedHashMap;
+import java.util.Collections;
 import java.util.Map;
 
 import static org.hamcrest.CoreMatchers.is;
@@ -71,8 +71,7 @@ class YamlCompatibleEncryptTableRuleConfigurationSwapperTest {
         encryptColumnRuleConfig.setAssistedQueryColumn("encrypt_assisted");
         encryptColumnRuleConfig.setLikeQueryColumn("encrypt_like");
         encryptColumnRuleConfig.setEncryptorName("test_encryptor");
-        Map<String, YamlCompatibleEncryptColumnRuleConfiguration> columns = new LinkedHashMap<>(1);
-        columns.put("test_column", encryptColumnRuleConfig);
+        Map<String, YamlCompatibleEncryptColumnRuleConfiguration> columns = Collections.singletonMap("test_column", encryptColumnRuleConfig);
         YamlCompatibleEncryptTableRuleConfiguration yamlEncryptTableRuleConfig = new YamlCompatibleEncryptTableRuleConfiguration();
         yamlEncryptTableRuleConfig.setName("test_table");
         yamlEncryptTableRuleConfig.setColumns(columns);
diff --git a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlEncryptTableRuleConfigurationSwapperTest.java b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlEncryptTableRuleConfigurationSwapperTest.java
index d102ac604af..e9e886749bc 100644
--- a/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlEncryptTableRuleConfigurationSwapperTest.java
+++ b/features/encrypt/core/src/test/java/org/apache/shardingsphere/encrypt/yaml/swapper/rule/YamlEncryptTableRuleConfigurationSwapperTest.java
@@ -27,7 +27,7 @@ import org.junit.jupiter.api.Test;
 
 import java.util.Arrays;
 import java.util.Collection;
-import java.util.LinkedHashMap;
+import java.util.Collections;
 import java.util.Map;
 
 import static org.hamcrest.CoreMatchers.is;
@@ -65,8 +65,7 @@ class YamlEncryptTableRuleConfigurationSwapperTest {
     
     @Test
     void assertSwapToObject() {
-        Map<String, YamlEncryptColumnRuleConfiguration> columns = new LinkedHashMap<>(1);
-        columns.put("test_column", buildYamlEncryptColumnRuleConfiguration());
+        Map<String, YamlEncryptColumnRuleConfiguration> columns = Collections.singletonMap("test_column", buildYamlEncryptColumnRuleConfiguration());
         YamlEncryptTableRuleConfiguration yamlEncryptTableRuleConfig = new YamlEncryptTableRuleConfiguration();
         yamlEncryptTableRuleConfig.setName("test_table");
         yamlEncryptTableRuleConfig.setColumns(columns);
diff --git a/features/encrypt/distsql/handler/src/main/java/org/apache/shardingsphere/encrypt/distsql/handler/converter/EncryptRuleStatementConverter.java b/features/encrypt/distsql/handler/src/main/java/org/apache/shardingsphere/encrypt/distsql/handler/converter/EncryptRuleStatementConverter.java
index 7a41d02830a..69f644779da 100644
--- a/features/encrypt/distsql/handler/src/main/java/org/apache/shardingsphere/encrypt/distsql/handler/converter/EncryptRuleStatementConverter.java
+++ b/features/encrypt/distsql/handler/src/main/java/org/apache/shardingsphere/encrypt/distsql/handler/converter/EncryptRuleStatementConverter.java
@@ -75,7 +75,7 @@ public final class EncryptRuleStatementConverter {
     }
     
     private static Map<String, AlgorithmConfiguration> createEncryptorConfigurations(final EncryptRuleSegment ruleSegment) {
-        Map<String, AlgorithmConfiguration> result = new HashMap<>(ruleSegment.getColumns().size(), 1);
+        Map<String, AlgorithmConfiguration> result = new HashMap<>(ruleSegment.getColumns().size(), 1F);
         for (EncryptColumnSegment each : ruleSegment.getColumns()) {
             result.put(getEncryptorName(ruleSegment.getTableName(), each.getName()), createEncryptorConfiguration(each));
             if (null != each.getAssistedQueryEncryptor()) {
diff --git a/features/encrypt/distsql/handler/src/test/java/org/apache/shardingsphere/encrypt/distsql/handler/update/DropEncryptRuleStatementUpdaterTest.java b/features/encrypt/distsql/handler/src/test/java/org/apache/shardingsphere/encrypt/distsql/handler/update/DropEncryptRuleStatementUpdaterTest.java
index 37ea8a43ddb..94db161ba52 100644
--- a/features/encrypt/distsql/handler/src/test/java/org/apache/shardingsphere/encrypt/distsql/handler/update/DropEncryptRuleStatementUpdaterTest.java
+++ b/features/encrypt/distsql/handler/src/test/java/org/apache/shardingsphere/encrypt/distsql/handler/update/DropEncryptRuleStatementUpdaterTest.java
@@ -99,7 +99,7 @@ class DropEncryptRuleStatementUpdaterTest {
         EncryptColumnRuleConfiguration columnRuleConfig = new EncryptColumnRuleConfiguration("user_id", new EncryptColumnItemRuleConfiguration("user_cipher", "t_encrypt_user_id_MD5"));
         columnRuleConfig.setAssistedQuery(new EncryptColumnItemRuleConfiguration("user_assisted", "t_encrypt_test_assisted"));
         columnRuleConfig.setLikeQuery(new EncryptColumnItemRuleConfiguration("user_like", "t_encrypt_test_like"));
-        Map<String, AlgorithmConfiguration> encryptors = new HashMap<>(3, 1);
+        Map<String, AlgorithmConfiguration> encryptors = new HashMap<>(3, 1F);
         encryptors.put("t_encrypt_user_id_MD5", new AlgorithmConfiguration("TEST", new Properties()));
         encryptors.put("t_encrypt_test_assisted", new AlgorithmConfiguration("TEST", new Properties()));
         encryptors.put("t_encrypt_test_like", new AlgorithmConfiguration("TEST", new Properties()));
diff --git a/features/mask/core/src/main/java/org/apache/shardingsphere/mask/yaml/swapper/YamlMaskRuleConfigurationSwapper.java b/features/mask/core/src/main/java/org/apache/shardingsphere/mask/yaml/swapper/YamlMaskRuleConfigurationSwapper.java
index 4627808eca4..39bb1512e70 100644
--- a/features/mask/core/src/main/java/org/apache/shardingsphere/mask/yaml/swapper/YamlMaskRuleConfigurationSwapper.java
+++ b/features/mask/core/src/main/java/org/apache/shardingsphere/mask/yaml/swapper/YamlMaskRuleConfigurationSwapper.java
@@ -67,7 +67,7 @@ public final class YamlMaskRuleConfigurationSwapper implements YamlRuleConfigura
     }
     
     private Map<String, AlgorithmConfiguration> swapMaskAlgorithm(final YamlMaskRuleConfiguration yamlConfig) {
-        Map<String, AlgorithmConfiguration> result = new LinkedHashMap<>(yamlConfig.getMaskAlgorithms().size(), 1);
+        Map<String, AlgorithmConfiguration> result = new LinkedHashMap<>(yamlConfig.getMaskAlgorithms().size(), 1F);
         for (Entry<String, YamlAlgorithmConfiguration> entry : yamlConfig.getMaskAlgorithms().entrySet()) {
             result.put(entry.getKey(), algorithmSwapper.swapToObject(entry.getValue()));
         }
diff --git a/features/mask/distsql/handler/src/main/java/org/apache/shardingsphere/mask/distsql/handler/converter/MaskRuleStatementConverter.java b/features/mask/distsql/handler/src/main/java/org/apache/shardingsphere/mask/distsql/handler/converter/MaskRuleStatementConverter.java
index 5b7fecc9438..3f1497f2609 100644
--- a/features/mask/distsql/handler/src/main/java/org/apache/shardingsphere/mask/distsql/handler/converter/MaskRuleStatementConverter.java
+++ b/features/mask/distsql/handler/src/main/java/org/apache/shardingsphere/mask/distsql/handler/converter/MaskRuleStatementConverter.java
@@ -62,7 +62,7 @@ public final class MaskRuleStatementConverter {
     }
     
     private static Map<String, AlgorithmConfiguration> createMaskAlgorithmConfigurations(final MaskRuleSegment ruleSegment) {
-        Map<String, AlgorithmConfiguration> result = new HashMap<>(ruleSegment.getColumns().size(), 1);
+        Map<String, AlgorithmConfiguration> result = new HashMap<>(ruleSegment.getColumns().size(), 1F);
         for (MaskColumnSegment each : ruleSegment.getColumns()) {
             result.put(getAlgorithmName(ruleSegment.getTableName(), each), new AlgorithmConfiguration(each.getAlgorithm().getName(), each.getAlgorithm().getProps()));
         }
diff --git a/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationChecker.java b/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationChecker.java
index 8ae501150ba..4243d09148c 100644
--- a/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationChecker.java
+++ b/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationChecker.java
@@ -126,7 +126,7 @@ public final class ReadwriteSplittingRuleConfigurationChecker implements RuleCon
     }
     
     private Map<String, ReadQueryLoadBalanceAlgorithm> getLoadBalancer(final ReadwriteSplittingRuleConfiguration config) {
-        Map<String, ReadQueryLoadBalanceAlgorithm> result = new LinkedHashMap<>(config.getLoadBalancers().size(), 1);
+        Map<String, ReadQueryLoadBalanceAlgorithm> result = new LinkedHashMap<>(config.getLoadBalancers().size(), 1F);
         config.getLoadBalancers().forEach((key, value) -> result.put(key, TypedSPILoader.getService(ReadQueryLoadBalanceAlgorithm.class, value.getType(), value.getProps())));
         return result;
     }
diff --git a/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/rule/ReadwriteSplittingRule.java b/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/rule/ReadwriteSplittingRule.java
index 76b65d5402c..5cbb39a35d5 100644
--- a/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/rule/ReadwriteSplittingRule.java
+++ b/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/rule/ReadwriteSplittingRule.java
@@ -77,7 +77,7 @@ public final class ReadwriteSplittingRule implements DatabaseRule, DataSourceCon
     }
     
     private Map<String, ReadQueryLoadBalanceAlgorithm> createLoadBalancers(final ReadwriteSplittingRuleConfiguration ruleConfig) {
-        Map<String, ReadQueryLoadBalanceAlgorithm> result = new LinkedHashMap<>(ruleConfig.getDataSources().size(), 1);
+        Map<String, ReadQueryLoadBalanceAlgorithm> result = new LinkedHashMap<>(ruleConfig.getDataSources().size(), 1F);
         for (ReadwriteSplittingDataSourceRuleConfiguration each : ruleConfig.getDataSources()) {
             if (ruleConfig.getLoadBalancers().containsKey(each.getLoadBalancerName())) {
                 AlgorithmConfiguration algorithmConfig = ruleConfig.getLoadBalancers().get(each.getLoadBalancerName());
@@ -88,7 +88,7 @@ public final class ReadwriteSplittingRule implements DatabaseRule, DataSourceCon
     }
     
     private Map<String, ReadwriteSplittingDataSourceRule> createDataSourceRules(final ReadwriteSplittingRuleConfiguration ruleConfig) {
-        Map<String, ReadwriteSplittingDataSourceRule> result = new HashMap<>(ruleConfig.getDataSources().size(), 1);
+        Map<String, ReadwriteSplittingDataSourceRule> result = new HashMap<>(ruleConfig.getDataSources().size(), 1F);
         for (ReadwriteSplittingDataSourceRuleConfiguration each : ruleConfig.getDataSources()) {
             result.putAll(createDataSourceRules(each));
         }
@@ -111,7 +111,7 @@ public final class ReadwriteSplittingRule implements DatabaseRule, DataSourceCon
                 () -> new InvalidInlineExpressionDataSourceNameException("Inline expression write data source names size error."));
         inlineReadDatasourceNames.forEach(each -> ShardingSpherePreconditions.checkState(each.size() == inlineReadwriteDataSourceNames.size(),
                 () -> new InvalidInlineExpressionDataSourceNameException("Inline expression read data source names size error.")));
-        Map<String, ReadwriteSplittingDataSourceRule> result = new LinkedHashMap<>(inlineReadwriteDataSourceNames.size(), 1);
+        Map<String, ReadwriteSplittingDataSourceRule> result = new LinkedHashMap<>(inlineReadwriteDataSourceNames.size(), 1F);
         for (int i = 0; i < inlineReadwriteDataSourceNames.size(); i++) {
             ReadwriteSplittingDataSourceRuleConfiguration staticConfig = createStaticDataSourceRuleConfiguration(
                     config, i, inlineReadwriteDataSourceNames, inlineWriteDatasourceNames, inlineReadDatasourceNames);
@@ -184,16 +184,16 @@ public final class ReadwriteSplittingRule implements DatabaseRule, DataSourceCon
     
     @Override
     public Map<String, Object> getExportData() {
-        Map<String, Object> result = new HashMap<>(2, 1);
+        Map<String, Object> result = new HashMap<>(2, 1F);
         result.put(ExportableConstants.EXPORT_STATIC_READWRITE_SPLITTING_RULE, exportStaticDataSources());
         return result;
     }
     
     private Map<String, Map<String, String>> exportStaticDataSources() {
-        Map<String, Map<String, String>> result = new LinkedHashMap<>(dataSourceRules.size(), 1);
+        Map<String, Map<String, String>> result = new LinkedHashMap<>(dataSourceRules.size(), 1F);
         for (ReadwriteSplittingDataSourceRule each : dataSourceRules.values()) {
             if (each.getReadwriteSplittingGroup() instanceof StaticReadwriteSplittingGroup) {
-                Map<String, String> exportedDataSources = new LinkedHashMap<>(2, 1);
+                Map<String, String> exportedDataSources = new LinkedHashMap<>(2, 1F);
                 exportedDataSources.put(ExportableItemConstants.PRIMARY_DATA_SOURCE_NAME, each.getWriteDataSource());
                 exportedDataSources.put(ExportableItemConstants.REPLICA_DATA_SOURCE_NAMES, String.join(",", each.getReadwriteSplittingGroup().getReadDataSources()));
                 result.put(each.getName(), exportedDataSources);
diff --git a/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/yaml/swapper/YamlReadwriteSplittingRuleConfigurationSwapper.java b/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/yaml/swapper/YamlReadwriteSplittingRuleConfigurationSwapper.java
index f3e22d28eb3..8c66d728c6b 100644
--- a/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/yaml/swapper/YamlReadwriteSplittingRuleConfigurationSwapper.java
+++ b/features/readwrite-splitting/core/src/main/java/org/apache/shardingsphere/readwritesplitting/yaml/swapper/YamlReadwriteSplittingRuleConfigurationSwapper.java
@@ -70,7 +70,7 @@ public final class YamlReadwriteSplittingRuleConfigurationSwapper
         for (Entry<String, YamlReadwriteSplittingDataSourceRuleConfiguration> entry : yamlConfig.getDataSources().entrySet()) {
             dataSources.add(swapToObject(entry.getKey(), entry.getValue()));
         }
-        Map<String, AlgorithmConfiguration> loadBalancerMap = new LinkedHashMap<>(yamlConfig.getLoadBalancers().entrySet().size(), 1);
+        Map<String, AlgorithmConfiguration> loadBalancerMap = new LinkedHashMap<>(yamlConfig.getLoadBalancers().entrySet().size(), 1F);
         if (null != yamlConfig.getLoadBalancers()) {
             yamlConfig.getLoadBalancers().forEach((key, value) -> loadBalancerMap.put(key, algorithmSwapper.swapToObject(value)));
         }
diff --git a/features/readwrite-splitting/core/src/test/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationCheckerTest.java b/features/readwrite-splitting/core/src/test/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationCheckerTest.java
index a5f842a0136..255a93d19b6 100644
--- a/features/readwrite-splitting/core/src/test/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationCheckerTest.java
+++ b/features/readwrite-splitting/core/src/test/java/org/apache/shardingsphere/readwritesplitting/checker/ReadwriteSplittingRuleConfigurationCheckerTest.java
@@ -125,7 +125,7 @@ class ReadwriteSplittingRuleConfigurationCheckerTest {
     }
     
     private Map<String, DataSource> mockDataSources() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("read_ds_0", mock(DataSource.class));
         result.put("read_ds_1", mock(DataSource.class));
         result.put("write_ds_0", mock(DataSource.class));
diff --git a/features/readwrite-splitting/distsql/handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/converter/ReadwriteSplittingRuleStatementConverter.java b/features/readwrite-splitting/distsql/handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/converter/ReadwriteSplittingRuleStatementConverter.java
index b3c8ed9d479..eb881ac3cea 100644
--- a/features/readwrite-splitting/distsql/handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/converter/ReadwriteSplittingRuleStatementConverter.java
+++ b/features/readwrite-splitting/distsql/handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/converter/ReadwriteSplittingRuleStatementConverter.java
@@ -44,7 +44,7 @@ public final class ReadwriteSplittingRuleStatementConverter {
      */
     public static ReadwriteSplittingRuleConfiguration convert(final Collection<ReadwriteSplittingRuleSegment> ruleSegments) {
         Collection<ReadwriteSplittingDataSourceRuleConfiguration> dataSources = new LinkedList<>();
-        Map<String, AlgorithmConfiguration> loadBalancers = new HashMap<>(ruleSegments.size(), 1);
+        Map<String, AlgorithmConfiguration> loadBalancers = new HashMap<>(ruleSegments.size(), 1F);
         for (ReadwriteSplittingRuleSegment each : ruleSegments) {
             if (null == each.getLoadBalancer()) {
                 dataSources.add(createDataSourceRuleConfiguration(each, null));
diff --git a/features/readwrite-splitting/distsql/handler/src/test/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/query/ShowReadwriteSplittingRuleExecutorTest.java b/features/readwrite-splitting/distsql/handler/src/test/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/query/ShowReadwriteSplittingRuleExecutorTest.java
index 8fbb247b2b4..f9c86abeef9 100644
--- a/features/readwrite-splitting/distsql/handler/src/test/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/query/ShowReadwriteSplittingRuleExecutorTest.java
+++ b/features/readwrite-splitting/distsql/handler/src/test/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/query/ShowReadwriteSplittingRuleExecutorTest.java
@@ -98,7 +98,7 @@ class ShowReadwriteSplittingRuleExecutorTest {
     }
     
     private Map<String, Object> createExportedData() {
-        Map<String, Object> result = new HashMap<>(2, 1);
+        Map<String, Object> result = new HashMap<>(2, 1F);
         result.put(ExportableConstants.EXPORT_DYNAMIC_READWRITE_SPLITTING_RULE, Collections.emptyMap());
         result.put(ExportableConstants.EXPORT_STATIC_READWRITE_SPLITTING_RULE, Collections.emptyMap());
         return result;
@@ -150,14 +150,14 @@ class ShowReadwriteSplittingRuleExecutorTest {
     }
     
     private Map<String, Object> getExportData() {
-        Map<String, Object> result = new HashMap<>(2, 1);
+        Map<String, Object> result = new HashMap<>(2, 1F);
         result.put(ExportableConstants.EXPORT_STATIC_READWRITE_SPLITTING_RULE, exportStaticDataSources());
         return result;
     }
     
     private Map<String, Map<String, String>> exportStaticDataSources() {
         Map<String, Map<String, String>> result = new LinkedHashMap<>();
-        Map<String, String> staticRule = new LinkedHashMap<>(2, 1);
+        Map<String, String> staticRule = new LinkedHashMap<>(2, 1F);
         staticRule.put(ExportableItemConstants.PRIMARY_DATA_SOURCE_NAME, "ds_0");
         staticRule.put(ExportableItemConstants.REPLICA_DATA_SOURCE_NAMES, "ds_1");
         result.put("static_rule_1", staticRule);
diff --git a/features/shadow/core/src/test/java/org/apache/shardingsphere/shadow/checker/ShadowRuleConfigurationCheckerTest.java b/features/shadow/core/src/test/java/org/apache/shardingsphere/shadow/checker/ShadowRuleConfigurationCheckerTest.java
index 004e1872827..ae8b9b1933b 100644
--- a/features/shadow/core/src/test/java/org/apache/shardingsphere/shadow/checker/ShadowRuleConfigurationCheckerTest.java
+++ b/features/shadow/core/src/test/java/org/apache/shardingsphere/shadow/checker/ShadowRuleConfigurationCheckerTest.java
@@ -42,7 +42,7 @@ class ShadowRuleConfigurationCheckerTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("ds", mock(DataSource.class));
         result.put("ds_shadow", mock(DataSource.class));
         return result;
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/datetime/AutoIntervalShardingAlgorithm.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/datetime/AutoIntervalShardingAlgorithm.java
index a7b10295690..c00bbec90d0 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/datetime/AutoIntervalShardingAlgorithm.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/datetime/AutoIntervalShardingAlgorithm.java
@@ -91,7 +91,7 @@ public final class AutoIntervalShardingAlgorithm implements StandardShardingAlgo
     
     @Override
     public Collection<String> doSharding(final Collection<String> availableTargetNames, final RangeShardingValue<Comparable<?>> shardingValue) {
-        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size());
+        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size(), 1F);
         int firstPartition = getFirstPartition(shardingValue.getValueRange());
         int lastPartition = getLastPartition(shardingValue.getValueRange());
         for (int i = firstPartition; i <= lastPartition; i++) {
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/mod/ModShardingAlgorithm.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/mod/ModShardingAlgorithm.java
index 150b7159d8f..1bf10fc1f02 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/mod/ModShardingAlgorithm.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/mod/ModShardingAlgorithm.java
@@ -115,7 +115,7 @@ public final class ModShardingAlgorithm implements StandardShardingAlgorithm<Com
     }
     
     private Collection<String> getAvailableTargetNames(final Collection<String> availableTargetNames, final RangeShardingValue<Comparable<?>> shardingValue) {
-        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size());
+        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size(), 1F);
         BigInteger lower = new BigInteger(shardingValue.getValueRange().lowerEndpoint().toString());
         BigInteger upper = new BigInteger(shardingValue.getValueRange().upperEndpoint().toString());
         BigInteger shardingCountBigInter = new BigInteger(String.valueOf(shardingCount));
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/AbstractRangeShardingAlgorithm.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/AbstractRangeShardingAlgorithm.java
index b70d01ff31f..c9654c7005b 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/AbstractRangeShardingAlgorithm.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/AbstractRangeShardingAlgorithm.java
@@ -56,7 +56,7 @@ public abstract class AbstractRangeShardingAlgorithm implements StandardSharding
     
     @Override
     public final Collection<String> doSharding(final Collection<String> availableTargetNames, final RangeShardingValue<Comparable<?>> shardingValue) {
-        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size());
+        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size(), 1F);
         int firstPartition = getFirstPartition(shardingValue.getValueRange());
         int lastPartition = getLastPartition(shardingValue.getValueRange());
         for (int partition = firstPartition; partition <= lastPartition; partition++) {
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/BoundaryBasedRangeShardingAlgorithm.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/BoundaryBasedRangeShardingAlgorithm.java
index ab3d287a66c..32138c8880d 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/BoundaryBasedRangeShardingAlgorithm.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/BoundaryBasedRangeShardingAlgorithm.java
@@ -42,7 +42,7 @@ public final class BoundaryBasedRangeShardingAlgorithm extends AbstractRangeShar
         List<Long> partitionRanges = Splitter.on(",").trimResults().splitToList(props.getProperty(SHARDING_RANGES_KEY)).stream()
                 .map(this::parseLong).filter(Objects::nonNull).sorted().collect(Collectors.toList());
         ShardingSpherePreconditions.checkState(!partitionRanges.isEmpty(), () -> new ShardingAlgorithmInitializationException(getType(), "Sharding ranges can not be empty."));
-        Map<Integer, Range<Comparable<?>>> result = new HashMap<>(partitionRanges.size() + 1, 1);
+        Map<Integer, Range<Comparable<?>>> result = new HashMap<>(partitionRanges.size() + 1, 1F);
         for (int i = 0; i < partitionRanges.size(); i++) {
             Long rangeValue = partitionRanges.get(i);
             if (0 == i) {
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/VolumeBasedRangeShardingAlgorithm.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/VolumeBasedRangeShardingAlgorithm.java
index 28f9f995678..1cab1b5ad1f 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/VolumeBasedRangeShardingAlgorithm.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/algorithm/sharding/range/VolumeBasedRangeShardingAlgorithm.java
@@ -48,7 +48,7 @@ public final class VolumeBasedRangeShardingAlgorithm extends AbstractRangeShardi
         long volume = Long.parseLong(props.getProperty(SHARDING_VOLUME_KEY));
         ShardingSpherePreconditions.checkState(upper - lower >= volume, () -> new ShardingAlgorithmInitializationException(getType(), "Range can not be smaller than volume."));
         int partitionSize = Math.toIntExact(LongMath.divide(upper - lower, volume, RoundingMode.CEILING));
-        Map<Integer, Range<Comparable<?>>> result = new HashMap<>(partitionSize + 2, 1);
+        Map<Integer, Range<Comparable<?>>> result = new HashMap<>(partitionSize + 2, 1F);
         result.put(0, Range.lessThan(lower));
         for (int i = 0; i < partitionSize; i++) {
             result.put(i + 1, Range.closedOpen(lower + i * volume, Math.min(lower + (i + 1) * volume, upper)));
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByMemoryMergedResult.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByMemoryMergedResult.java
index 08e17f3051a..729dc896b2c 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByMemoryMergedResult.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/merge/dql/groupby/GroupByMemoryMergedResult.java
@@ -61,8 +61,8 @@ public final class GroupByMemoryMergedResult extends MemoryMergedResult<Sharding
     protected List<MemoryQueryResultRow> init(final ShardingRule shardingRule, final ShardingSphereSchema schema,
                                               final SQLStatementContext sqlStatementContext, final List<QueryResult> queryResults) throws SQLException {
         SelectStatementContext selectStatementContext = (SelectStatementContext) sqlStatementContext;
-        Map<GroupByValue, MemoryQueryResultRow> dataMap = new HashMap<>(1024);
-        Map<GroupByValue, Map<AggregationProjection, AggregationUnit>> aggregationMap = new HashMap<>(1024);
+        Map<GroupByValue, MemoryQueryResultRow> dataMap = new HashMap<>(1024, 1F);
+        Map<GroupByValue, Map<AggregationProjection, AggregationUnit>> aggregationMap = new HashMap<>(1024, 1F);
         for (QueryResult each : queryResults) {
             while (each.next()) {
                 GroupByValue groupByValue = new GroupByValue(each, selectStatementContext.getGroupByContext().getItems());
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rewrite/token/pojo/TokenUtils.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rewrite/token/pojo/TokenUtils.java
index 950c6a15ff9..67b16d2b912 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rewrite/token/pojo/TokenUtils.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rewrite/token/pojo/TokenUtils.java
@@ -44,7 +44,7 @@ public final class TokenUtils {
      */
     public static Map<String, String> getLogicAndActualTableMap(final RouteUnit routeUnit, final SQLStatementContext sqlStatementContext, final ShardingRule shardingRule) {
         Collection<String> tableNames = sqlStatementContext.getTablesContext().getTableNames();
-        Map<String, String> result = new HashMap<>(tableNames.size(), 1);
+        Map<String, String> result = new HashMap<>(tableNames.size(), 1F);
         for (RouteMapper each : routeUnit.getTableMappers()) {
             result.put(each.getLogicName().toLowerCase(), each.getActualName());
             result.putAll(shardingRule.getLogicAndActualTablesFromBindingTable(routeUnit.getDataSourceMapper().getLogicName(), each.getLogicName(), each.getActualName(), tableNames));
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/condition/engine/WhereClauseShardingConditionEngine.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/condition/engine/WhereClauseShardingConditionEngine.java
index f9b81d73d45..e1c3015e952 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/condition/engine/WhereClauseShardingConditionEngine.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/condition/engine/WhereClauseShardingConditionEngine.java
@@ -108,7 +108,7 @@ public final class WhereClauseShardingConditionEngine {
     
     private Map<Column, Collection<ShardingConditionValue>> createShardingConditionValueMap(final Collection<ExpressionSegment> predicates,
                                                                                             final List<Object> params, final Map<String, String> columnTableNames) {
-        Map<Column, Collection<ShardingConditionValue>> result = new HashMap<>(predicates.size(), 1);
+        Map<Column, Collection<ShardingConditionValue>> result = new HashMap<>(predicates.size(), 1F);
         for (ExpressionSegment each : predicates) {
             for (ColumnSegment columnSegment : ColumnExtractor.extract(each)) {
                 Optional<String> tableName = Optional.ofNullable(columnTableNames.get(columnSegment.getExpression()));
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingCartesianRoutingEngine.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingCartesianRoutingEngine.java
index 25e62d83237..f5bc83f2889 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingCartesianRoutingEngine.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingCartesianRoutingEngine.java
@@ -59,7 +59,7 @@ public final class ShardingCartesianRoutingEngine implements ShardingRouteEngine
     
     private Map<String, Set<String>> getDataSourceLogicTablesMap() {
         Collection<String> intersectionDataSources = getIntersectionDataSources();
-        Map<String, Set<String>> result = new HashMap<>(routeContexts.size());
+        Map<String, Set<String>> result = new HashMap<>(routeContexts.size(), 1F);
         for (RouteContext each : routeContexts) {
             for (Entry<String, Set<String>> entry : each.getDataSourceLogicTablesMap(intersectionDataSources).entrySet()) {
                 if (result.containsKey(entry.getKey())) {
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/unicast/ShardingUnicastRoutingEngine.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/unicast/ShardingUnicastRoutingEngine.java
index 84725bf9ae0..d23f68008d3 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/unicast/ShardingUnicastRoutingEngine.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/unicast/ShardingUnicastRoutingEngine.java
@@ -100,7 +100,7 @@ public final class ShardingUnicastRoutingEngine implements ShardingRouteEngine {
             DataNode dataNode = tableRule.getActualDataNodes().get(0);
             tableMappers.add(new RouteMapper(each, dataNode.getTableName()));
             Set<String> currentDataSourceNames = tableRule.getActualDataNodes().stream().map(DataNode::getDataSourceName).collect(
-                    Collectors.toCollection(() -> new LinkedHashSet<>(tableRule.getActualDataSourceNames().size())));
+                    Collectors.toCollection(() -> new LinkedHashSet<>(tableRule.getActualDataSourceNames().size(), 1F)));
             if (first) {
                 availableDataSourceNames = currentDataSourceNames;
                 first = false;
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/strategy/type/complex/ComplexShardingStrategy.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/strategy/type/complex/ComplexShardingStrategy.java
index ed4817e7e60..c796c89dbeb 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/strategy/type/complex/ComplexShardingStrategy.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/route/strategy/type/complex/ComplexShardingStrategy.java
@@ -58,8 +58,8 @@ public final class ComplexShardingStrategy implements ShardingStrategy {
     @Override
     public Collection<String> doSharding(final Collection<String> availableTargetNames, final Collection<ShardingConditionValue> shardingConditionValues,
                                          final DataNodeInfo dataNodeInfo, final ConfigurationProperties props) {
-        Map<String, Collection<Comparable<?>>> columnShardingValues = new HashMap<>(shardingConditionValues.size(), 1);
-        Map<String, Range<Comparable<?>>> columnRangeValues = new HashMap<>(shardingConditionValues.size(), 1);
+        Map<String, Collection<Comparable<?>>> columnShardingValues = new HashMap<>(shardingConditionValues.size(), 1F);
+        Map<String, Range<Comparable<?>>> columnRangeValues = new HashMap<>(shardingConditionValues.size(), 1F);
         String logicTableName = "";
         for (ShardingConditionValue each : shardingConditionValues) {
             if (each instanceof ListShardingConditionValue) {
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/ShardingRule.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/ShardingRule.java
index f31dbea8cc8..f0e00c90fa4 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/ShardingRule.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/ShardingRule.java
@@ -146,7 +146,7 @@ public final class ShardingRule implements DatabaseRule, DataNodeContainedRule,
     }
     
     private Map<String, Collection<DataNode>> createShardingTableDataNodes(final Map<String, TableRule> tableRules) {
-        Map<String, Collection<DataNode>> result = new HashMap<>(tableRules.size(), 1);
+        Map<String, Collection<DataNode>> result = new HashMap<>(tableRules.size(), 1F);
         for (TableRule each : tableRules.values()) {
             result.put(each.getLogicTable().toLowerCase(), each.getActualDataNodes());
         }
@@ -718,8 +718,8 @@ public final class ShardingRule implements DatabaseRule, DataNodeContainedRule,
     
     private boolean isJoinConditionContainsShardingColumns(final ShardingSphereSchema schema, final SelectStatementContext select,
                                                            final Collection<String> tableNames, final Collection<WhereSegment> whereSegments) {
-        Collection<String> databaseJoinConditionTables = new HashSet<>(tableNames.size());
-        Collection<String> tableJoinConditionTables = new HashSet<>(tableNames.size());
+        Collection<String> databaseJoinConditionTables = new HashSet<>(tableNames.size(), 1F);
+        Collection<String> tableJoinConditionTables = new HashSet<>(tableNames.size(), 1F);
         for (WhereSegment each : whereSegments) {
             Collection<AndPredicate> andPredicates = ExpressionExtractUtils.getAndPredicates(each.getExpr());
             if (andPredicates.size() > 1) {
diff --git a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/TableRule.java b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/TableRule.java
index f12cc30aba4..eec8cfa887b 100644
--- a/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/TableRule.java
+++ b/features/sharding/core/src/main/java/org/apache/shardingsphere/sharding/rule/TableRule.java
@@ -92,7 +92,7 @@ public final class TableRule {
     
     public TableRule(final Collection<String> dataSourceNames, final String logicTableName) {
         logicTable = logicTableName;
-        dataNodeIndexMap = new HashMap<>(dataSourceNames.size(), 1);
+        dataNodeIndexMap = new HashMap<>(dataSourceNames.size(), 1F);
         actualDataNodes = generateDataNodes(logicTableName, dataSourceNames);
         actualTables = getActualTables();
         databaseShardingStrategyConfig = null;
@@ -107,7 +107,7 @@ public final class TableRule {
     public TableRule(final ShardingTableRuleConfiguration tableRuleConfig, final Collection<String> dataSourceNames, final String defaultGenerateKeyColumn) {
         logicTable = tableRuleConfig.getLogicTable();
         List<String> dataNodes = InlineExpressionParserFactory.newInstance().splitAndEvaluate(tableRuleConfig.getActualDataNodes());
-        dataNodeIndexMap = new HashMap<>(dataNodes.size(), 1);
+        dataNodeIndexMap = new HashMap<>(dataNodes.size(), 1F);
         actualDataNodes = isEmptyDataNodes(dataNodes) ? generateDataNodes(tableRuleConfig.getLogicTable(), dataSourceNames) : generateDataNodes(dataNodes, dataSourceNames);
         actualTables = getActualTables();
         databaseShardingStrategyConfig = tableRuleConfig.getDatabaseShardingStrategy();
@@ -128,7 +128,7 @@ public final class TableRule {
         tableShardingStrategyConfig = tableRuleConfig.getShardingStrategy();
         auditStrategyConfig = tableRuleConfig.getAuditStrategy();
         List<String> dataNodes = getDataNodes(tableRuleConfig, shardingAutoTableAlgorithm, dataSourceNames);
-        dataNodeIndexMap = new HashMap<>(dataNodes.size(), 1);
+        dataNodeIndexMap = new HashMap<>(dataNodes.size(), 1F);
         actualDataNodes = isEmptyDataNodes(dataNodes) ? generateDataNodes(tableRuleConfig.getLogicTable(), dataSourceNames) : generateDataNodes(dataNodes, dataSourceNames);
         actualTables = getActualTables();
         KeyGenerateStrategyConfiguration keyGeneratorConfig = tableRuleConfig.getKeyGenerateStrategy();
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/keygen/SnowflakeKeyGenerateAlgorithmTest.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/keygen/SnowflakeKeyGenerateAlgorithmTest.java
index bc5a775aa5f..43bf919df29 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/keygen/SnowflakeKeyGenerateAlgorithmTest.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/keygen/SnowflakeKeyGenerateAlgorithmTest.java
@@ -80,7 +80,7 @@ class SnowflakeKeyGenerateAlgorithmTest {
         if (algorithm instanceof InstanceContextAware) {
             ((InstanceContextAware) algorithm).setInstanceContext(INSTANCE);
         }
-        Set<Comparable<?>> actual = new HashSet<>(taskNumber, 1);
+        Set<Comparable<?>> actual = new HashSet<>(taskNumber, 1F);
         for (int i = 0; i < taskNumber; i++) {
             actual.add(executor.submit((Callable<Comparable<?>>) algorithm::generateKey).get());
         }
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/sharding/complex/ComplexInlineShardingAlgorithmTest.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/sharding/complex/ComplexInlineShardingAlgorithmTest.java
index 994d75cadb7..19e2e069de7 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/sharding/complex/ComplexInlineShardingAlgorithmTest.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/algorithm/sharding/complex/ComplexInlineShardingAlgorithmTest.java
@@ -56,7 +56,7 @@ class ComplexInlineShardingAlgorithmTest {
     }
     
     private ComplexKeysShardingValue<Comparable<?>> createComplexKeysShardingValue(final List<Comparable<?>> values) {
-        Map<String, Collection<Comparable<?>>> sharingValues = new HashMap<>(2, 1);
+        Map<String, Collection<Comparable<?>>> sharingValues = new HashMap<>(2, 1F);
         sharingValues.put("type", values);
         sharingValues.put("order_id", values);
         return new ComplexKeysShardingValue<>("t_order", sharingValues, Collections.emptyMap());
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/fixture/CoreStandardShardingAlgorithmFixture.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/fixture/CoreStandardShardingAlgorithmFixture.java
index 44228b8c2eb..907e83db0ef 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/fixture/CoreStandardShardingAlgorithmFixture.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/fixture/CoreStandardShardingAlgorithmFixture.java
@@ -38,7 +38,7 @@ public final class CoreStandardShardingAlgorithmFixture implements StandardShard
     
     @Override
     public Collection<String> doSharding(final Collection<String> availableTargetNames, final RangeShardingValue<Integer> shardingValue) {
-        Collection<String> result = new HashSet<>(2);
+        Collection<String> result = new HashSet<>(2, 1F);
         for (int i = shardingValue.getValueRange().lowerEndpoint(); i <= shardingValue.getValueRange().upperEndpoint(); i++) {
             for (String each : availableTargetNames) {
                 if (each.endsWith(String.valueOf(i % 2))) {
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/merge/dal/show/ShowCreateTableMergedResultTest.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/merge/dal/show/ShowCreateTableMergedResultTest.java
index f49f92129f9..4e6e74091d7 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/merge/dal/show/ShowCreateTableMergedResultTest.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/merge/dal/show/ShowCreateTableMergedResultTest.java
@@ -62,7 +62,7 @@ class ShowCreateTableMergedResultTest {
     }
     
     private ShardingSphereSchema createSchema() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1F);
         tables.put("t_order",
                 new ShardingSphereTable("t_order", Collections.emptyList(), Collections.emptyList(), Collections.singleton(new ShardingSphereConstraint("t_order_foreign_key", "t_user"))));
         tables.put("t_user", new ShardingSphereTable("t_user", Collections.emptyList(), Collections.emptyList(), Collections.emptyList()));
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/fixture/ShardingRoutingEngineFixtureBuilder.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/fixture/ShardingRoutingEngineFixtureBuilder.java
index 6372c86dc00..422fb3fda7e 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/fixture/ShardingRoutingEngineFixtureBuilder.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/fixture/ShardingRoutingEngineFixtureBuilder.java
@@ -309,7 +309,7 @@ public final class ShardingRoutingEngineFixtureBuilder {
     
     @SneakyThrows(SQLException.class)
     private static Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new HashMap<>(3, 1);
+        Map<String, DataSource> result = new HashMap<>(3, 1F);
         Connection connection = mock(Connection.class, RETURNS_DEEP_STUBS);
         when(connection.getMetaData().getURL()).thenReturn("jdbc:h2:mem:db");
         result.put("ds_0", new MockedDataSource(connection));
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/broadcast/ShardingDataSourceGroupBroadcastRoutingEngineTest.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/broadcast/ShardingDataSourceGroupBroadcastRoutingEngineTest.java
index 97cb0bbb3b0..8314ab4cb6d 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/broadcast/ShardingDataSourceGroupBroadcastRoutingEngineTest.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/broadcast/ShardingDataSourceGroupBroadcastRoutingEngineTest.java
@@ -60,7 +60,7 @@ class ShardingDataSourceGroupBroadcastRoutingEngineTest {
     
     private TableRule mockTableRule(final List<String> dataSources) {
         TableRule result = mock(TableRule.class);
-        Map<String, List<DataNode>> dataNodeGroups = new HashMap<>(dataSources.size(), 1);
+        Map<String, List<DataNode>> dataNodeGroups = new HashMap<>(dataSources.size(), 1F);
         for (String each : dataSources) {
             dataNodeGroups.put(each, null);
         }
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/standard/assertion/ShardingRouteAssert.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/standard/assertion/ShardingRouteAssert.java
index fe9a8f17493..d359cbf334a 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/standard/assertion/ShardingRouteAssert.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/engine/type/standard/assertion/ShardingRouteAssert.java
@@ -93,7 +93,7 @@ public final class ShardingRouteAssert {
     }
     
     private static Map<String, ShardingSphereSchema> buildSchemas() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1F);
         tables.put("t_order", new ShardingSphereTable("t_order", Arrays.asList(new ShardingSphereColumn("order_id", Types.INTEGER, true, false, false, true, false),
                 new ShardingSphereColumn("user_id", Types.INTEGER, false, false, false, true, false),
                 new ShardingSphereColumn("status", Types.INTEGER, false, false, false, true, false)), Collections.emptyList(), Collections.emptyList()));
diff --git a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/strategy/ShardingStrategyTest.java b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/strategy/ShardingStrategyTest.java
index 623f4c54309..bc989e812d1 100644
--- a/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/strategy/ShardingStrategyTest.java
+++ b/features/sharding/core/src/test/java/org/apache/shardingsphere/sharding/route/strategy/ShardingStrategyTest.java
@@ -60,7 +60,7 @@ class ShardingStrategyTest {
     
     @Test
     void assertDoShardingForMultipleKeys() {
-        Collection<String> expected = new HashSet<>(3, 1);
+        Collection<String> expected = new HashSet<>(3, 1F);
         expected.add("1");
         expected.add("2");
         expected.add("3");
diff --git a/features/sharding/distsql/handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/checker/ShardingTableRuleStatementChecker.java b/features/sharding/distsql/handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/checker/ShardingTableRuleStatementChecker.java
index b69ba30cfa0..9fccd3941e5 100644
--- a/features/sharding/distsql/handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/checker/ShardingTableRuleStatementChecker.java
+++ b/features/sharding/distsql/handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/checker/ShardingTableRuleStatementChecker.java
@@ -156,7 +156,7 @@ public final class ShardingTableRuleStatementChecker {
     
     private static boolean check(final ShardingRuleConfiguration checkedConfig, final Collection<String> dataSourceNames) {
         Collection<String> allDataSourceNames = getDataSourceNames(checkedConfig.getTables(), checkedConfig.getAutoTables(), dataSourceNames);
-        Map<String, ShardingAlgorithm> shardingAlgorithms = new HashMap<>(checkedConfig.getShardingAlgorithms().size(), 1);
+        Map<String, ShardingAlgorithm> shardingAlgorithms = new HashMap<>(checkedConfig.getShardingAlgorithms().size(), 1F);
         Map<String, TableRule> tableRules = new HashMap<>();
         checkedConfig.getShardingAlgorithms().forEach((key, value) -> shardingAlgorithms.put(key, TypedSPILoader.getService(ShardingAlgorithm.class, value.getType(), value.getProps())));
         tableRules.putAll(createTableRules(checkedConfig.getTables(), checkedConfig.getDefaultKeyGenerateStrategy(), allDataSourceNames));
diff --git a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/checker/ShardingRuleStatementCheckerTest.java b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/checker/ShardingRuleStatementCheckerTest.java
index 7dabfefae13..23b9778db8d 100644
--- a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/checker/ShardingRuleStatementCheckerTest.java
+++ b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/checker/ShardingRuleStatementCheckerTest.java
@@ -306,7 +306,7 @@ class ShardingRuleStatementCheckerTest {
     }
     
     private Map<String, DataSource> createDataSource() {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         result.put("ds_0", new MockedDataSource());
         result.put("ds_1", new MockedDataSource());
         return result;
diff --git a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreAutoShardingAlgorithmFixture.java b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreAutoShardingAlgorithmFixture.java
index 8e8c969ea29..343eb2989b2 100644
--- a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreAutoShardingAlgorithmFixture.java
+++ b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreAutoShardingAlgorithmFixture.java
@@ -110,7 +110,7 @@ public final class CoreAutoShardingAlgorithmFixture implements StandardShardingA
     }
     
     private Collection<String> getAvailableTargetNames(final Collection<String> availableTargetNames, final RangeShardingValue<Comparable<?>> shardingValue) {
-        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size());
+        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size(), 1F);
         BigInteger lower = new BigInteger(shardingValue.getValueRange().lowerEndpoint().toString());
         BigInteger upper = new BigInteger(shardingValue.getValueRange().upperEndpoint().toString());
         BigInteger shardingCountBigInter = new BigInteger(String.valueOf(shardingCount));
diff --git a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreStandardShardingAlgorithmFixture.java b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreStandardShardingAlgorithmFixture.java
index 6db442171ad..33d60cccf9c 100644
--- a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreStandardShardingAlgorithmFixture.java
+++ b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/fixture/sharding/CoreStandardShardingAlgorithmFixture.java
@@ -38,7 +38,7 @@ public final class CoreStandardShardingAlgorithmFixture implements StandardShard
     
     @Override
     public Collection<String> doSharding(final Collection<String> availableTargetNames, final RangeShardingValue<Integer> shardingValue) {
-        Collection<String> result = new HashSet<>(2);
+        Collection<String> result = new HashSet<>(2, 1F);
         for (int i = shardingValue.getValueRange().lowerEndpoint(); i <= shardingValue.getValueRange().upperEndpoint(); i++) {
             for (String each : availableTargetNames) {
                 if (each.endsWith(String.valueOf(i % 2))) {
diff --git a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/AlterShardingTableRuleStatementUpdaterTest.java b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/AlterShardingTableRuleStatementUpdaterTest.java
index 3fd30bfae6f..d040afc2bc6 100644
--- a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/AlterShardingTableRuleStatementUpdaterTest.java
+++ b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/AlterShardingTableRuleStatementUpdaterTest.java
@@ -189,7 +189,7 @@ class AlterShardingTableRuleStatementUpdaterTest {
     }
     
     private Map<String, DataSource> createDataSource() {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         result.put("ds_0", new MockedDataSource());
         result.put("ds_1", new MockedDataSource());
         return result;
diff --git a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/CreateShardingTableRuleStatementUpdaterTest.java b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/CreateShardingTableRuleStatementUpdaterTest.java
index b7080d9d265..486dc8b51cc 100644
--- a/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/CreateShardingTableRuleStatementUpdaterTest.java
+++ b/features/sharding/distsql/handler/src/test/java/org/apache/shardingsphere/sharding/distsql/update/CreateShardingTableRuleStatementUpdaterTest.java
@@ -279,7 +279,7 @@ class CreateShardingTableRuleStatementUpdaterTest {
     }
     
     private Map<String, DataSource> createDataSource() {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         result.put("ds_0", new MockedDataSource());
         result.put("ds_1", new MockedDataSource());
         return result;
diff --git a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionEngine.java b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionEngine.java
index aba2fcddbd3..16c36c7cf6b 100644
--- a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionEngine.java
+++ b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionEngine.java
@@ -262,7 +262,7 @@ public final class ProjectionEngine {
     
     private Collection<String> getUsingColumnNamesByNaturalJoin(final Collection<Projection> actualProjections) {
         Collection<String> result = new LinkedHashSet<>();
-        Map<String, Projection> uniqueProjections = new LinkedHashMap<>(actualProjections.size(), 1);
+        Map<String, Projection> uniqueProjections = new LinkedHashMap<>(actualProjections.size(), 1F);
         for (Projection each : actualProjections) {
             Projection previousProjection = uniqueProjections.put(each.getColumnLabel().toLowerCase(), each);
             if (null != previousProjection) {
diff --git a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/table/TablesContext.java b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/table/TablesContext.java
index 1df3c6c33c6..d53ba08106d 100644
--- a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/table/TablesContext.java
+++ b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/segment/table/TablesContext.java
@@ -157,7 +157,7 @@ public final class TablesContext {
         if (ownerTableNames.size() == columns.size() || subqueryTables.isEmpty()) {
             return Collections.emptyMap();
         }
-        Map<String, String> result = new LinkedHashMap<>(columns.size(), 1);
+        Map<String, String> result = new LinkedHashMap<>(columns.size(), 1F);
         for (ColumnSegment each : columns) {
             if (ownerTableNames.containsKey(each.getExpression())) {
                 continue;
@@ -177,7 +177,7 @@ public final class TablesContext {
         if (ownerTableNames.size() == columns.size() || subqueryTables.isEmpty()) {
             return Collections.emptyMap();
         }
-        Map<String, String> result = new LinkedHashMap<>(columns.size(), 1);
+        Map<String, String> result = new LinkedHashMap<>(columns.size(), 1F);
         for (ColumnProjection each : columns) {
             if (ownerTableNames.containsKey(each.getExpression())) {
                 continue;
@@ -253,7 +253,7 @@ public final class TablesContext {
         if (noOwnerColumnNames.isEmpty()) {
             return Collections.emptyMap();
         }
-        Map<String, String> result = new LinkedHashMap<>(noOwnerColumnNames.size(), 1);
+        Map<String, String> result = new LinkedHashMap<>(noOwnerColumnNames.size(), 1F);
         for (SimpleTableSegment each : tables) {
             String tableName = each.getTableName().getIdentifier().getValue();
             for (String columnName : schema.getAllColumnNames(tableName)) {
diff --git a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/DeleteStatementContext.java b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/DeleteStatementContext.java
index 92f05d3a6c7..3e65416b6d4 100644
--- a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/DeleteStatementContext.java
+++ b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/DeleteStatementContext.java
@@ -72,7 +72,7 @@ public final class DeleteStatementContext extends CommonSQLStatementContext impl
     }
     
     private Map<String, SimpleTableSegment> getAliasAndTableSegmentMap(final Collection<SimpleTableSegment> tableSegments) {
-        Map<String, SimpleTableSegment> result = new HashMap<>(tableSegments.size(), 1);
+        Map<String, SimpleTableSegment> result = new HashMap<>(tableSegments.size(), 1F);
         for (SimpleTableSegment each : tableSegments) {
             each.getAlias().ifPresent(optional -> result.putIfAbsent(optional, each));
         }
diff --git a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/SelectStatementContext.java b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/SelectStatementContext.java
index f596bc2a86d..e0120aa47c5 100644
--- a/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/SelectStatementContext.java
+++ b/infra/binder/src/main/java/org/apache/shardingsphere/infra/binder/statement/dml/SelectStatementContext.java
@@ -121,7 +121,7 @@ public final class SelectStatementContext extends CommonSQLStatementContext impl
     
     private Map<Integer, SelectStatementContext> createSubqueryContexts(final ShardingSphereMetaData metaData, final List<Object> params, final String defaultDatabaseName) {
         Collection<SubquerySegment> subquerySegments = SubqueryExtractUtils.getSubquerySegments(getSqlStatement());
-        Map<Integer, SelectStatementContext> result = new HashMap<>(subquerySegments.size(), 1);
+        Map<Integer, SelectStatementContext> result = new HashMap<>(subquerySegments.size(), 1F);
         for (SubquerySegment each : subquerySegments) {
             SelectStatementContext subqueryContext = new SelectStatementContext(metaData, params, each.getSelect(), defaultDatabaseName);
             subqueryContext.setSubqueryType(each.getSubqueryType());
diff --git a/infra/binder/src/test/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionsContextEngineTest.java b/infra/binder/src/test/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionsContextEngineTest.java
index 96a3ad94624..08a29903faa 100644
--- a/infra/binder/src/test/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionsContextEngineTest.java
+++ b/infra/binder/src/test/java/org/apache/shardingsphere/infra/binder/segment/select/projection/engine/ProjectionsContextEngineTest.java
@@ -235,7 +235,7 @@ class ProjectionsContextEngineTest {
     }
     
     private Map<String, ShardingSphereSchema> mockSchemas() {
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(2, 1);
+        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(2, 1F);
         result.put(DefaultDatabase.LOGIC_NAME, schema);
         result.put("public", schema);
         return result;
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/database/type/DatabaseTypeEngine.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/database/type/DatabaseTypeEngine.java
index 9262ee17dd3..67a76ef98c7 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/database/type/DatabaseTypeEngine.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/database/type/DatabaseTypeEngine.java
@@ -85,7 +85,7 @@ public final class DatabaseTypeEngine {
      * @return storage types
      */
     public static Map<String, DatabaseType> getStorageTypes(final String databaseName, final DatabaseConfiguration databaseConfig) {
-        Map<String, DatabaseType> result = new LinkedHashMap<>(databaseConfig.getDataSources().size(), 1);
+        Map<String, DatabaseType> result = new LinkedHashMap<>(databaseConfig.getDataSources().size(), 1F);
         Map<String, DataSource> enabledDataSources = DataSourceStateManager.getInstance().getEnabledDataSourceMap(databaseName, databaseConfig.getDataSources());
         for (Entry<String, DataSource> entry : enabledDataSources.entrySet()) {
             result.put(entry.getKey(), getStorageType(entry.getValue()));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datanode/DataNodeUtils.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datanode/DataNodeUtils.java
index 33238b9bf62..cb847630c47 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datanode/DataNodeUtils.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datanode/DataNodeUtils.java
@@ -41,7 +41,7 @@ public final class DataNodeUtils {
      * @return data node groups, key is data source name, values are data nodes belong to this data source
      */
     public static Map<String, List<DataNode>> getDataNodeGroups(final Collection<DataNode> dataNodes) {
-        Map<String, List<DataNode>> result = new LinkedHashMap<>(dataNodes.size(), 1);
+        Map<String, List<DataNode>> result = new LinkedHashMap<>(dataNodes.size(), 1F);
         for (DataNode each : dataNodes) {
             result.computeIfAbsent(each.getDataSourceName(), unused -> new LinkedList<>()).add(each);
         }
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/creator/DataSourceReflection.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/creator/DataSourceReflection.java
index db2ca27dbe8..06ec54bda2a 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/creator/DataSourceReflection.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/creator/DataSourceReflection.java
@@ -76,7 +76,7 @@ public final class DataSourceReflection {
     public Map<String, Object> convertToProperties() {
         Map<String, Object> getterProps = convertToProperties(GETTER_PREFIX);
         Map<String, Object> isProps = convertToProperties(IS_PREFIX);
-        Map<String, Object> result = new LinkedHashMap<>(getterProps.size() + isProps.size(), 1);
+        Map<String, Object> result = new LinkedHashMap<>(getterProps.size() + isProps.size(), 1F);
         result.putAll(getterProps);
         result.putAll(isProps);
         return result;
@@ -85,7 +85,7 @@ public final class DataSourceReflection {
     @SneakyThrows(ReflectiveOperationException.class)
     private Map<String, Object> convertToProperties(final String prefix) {
         Collection<Method> getterMethods = findAllGetterMethods(prefix);
-        Map<String, Object> result = new LinkedHashMap<>(getterMethods.size(), 1);
+        Map<String, Object> result = new LinkedHashMap<>(getterMethods.size(), 1F);
         for (Method each : getterMethods) {
             String fieldName = getGetterFieldName(each, prefix);
             if (GENERAL_CLASS_TYPES.contains(each.getReturnType()) && !SKIPPED_PROPERTY_KEYS.contains(fieldName)) {
@@ -99,7 +99,7 @@ public final class DataSourceReflection {
     }
     
     private Collection<Method> findAllGetterMethods(final String methodPrefix) {
-        Collection<Method> result = new HashSet<>(dataSourceMethods.length);
+        Collection<Method> result = new HashSet<>(dataSourceMethods.length, 1F);
         for (Method each : dataSourceMethods) {
             if (each.getName().startsWith(methodPrefix) && 0 == each.getParameterTypes().length) {
                 result.add(each);
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/c3p0/C3P0DataSourcePoolMetaData.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/c3p0/C3P0DataSourcePoolMetaData.java
index e3155cbeb6f..d1de2d5eea9 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/c3p0/C3P0DataSourcePoolMetaData.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/c3p0/C3P0DataSourcePoolMetaData.java
@@ -31,11 +31,11 @@ import java.util.Map;
  */
 public final class C3P0DataSourcePoolMetaData implements DataSourcePoolMetaData {
     
-    private static final Map<String, Object> DEFAULT_PROPS = new HashMap<>(6, 1);
+    private static final Map<String, Object> DEFAULT_PROPS = new HashMap<>(6, 1F);
     
-    private static final Map<String, Object> INVALID_PROPS = new HashMap<>(2, 1);
+    private static final Map<String, Object> INVALID_PROPS = new HashMap<>(2, 1F);
     
-    private static final Map<String, String> PROP_SYNONYMS = new HashMap<>(5, 1);
+    private static final Map<String, String> PROP_SYNONYMS = new HashMap<>(5, 1F);
     
     private static final Collection<String> TRANSIENT_FIELD_NAMES = new LinkedList<>();
     
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/hikari/HikariDataSourcePoolMetaData.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/hikari/HikariDataSourcePoolMetaData.java
index afcd74d1561..1e0d5c592ac 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/hikari/HikariDataSourcePoolMetaData.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/pool/metadata/type/hikari/HikariDataSourcePoolMetaData.java
@@ -30,11 +30,11 @@ import java.util.Map;
  */
 public final class HikariDataSourcePoolMetaData implements DataSourcePoolMetaData {
     
-    private static final Map<String, Object> DEFAULT_PROPS = new HashMap<>(6, 1);
+    private static final Map<String, Object> DEFAULT_PROPS = new HashMap<>(6, 1F);
     
-    private static final Map<String, Object> INVALID_PROPS = new HashMap<>(2, 1);
+    private static final Map<String, Object> INVALID_PROPS = new HashMap<>(2, 1F);
     
-    private static final Map<String, String> PROP_SYNONYMS = new HashMap<>(6, 1);
+    private static final Map<String, String> PROP_SYNONYMS = new HashMap<>(6, 1F);
     
     private static final Collection<String> TRANSIENT_FIELD_NAMES = new LinkedList<>();
     
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/DataSourceProperties.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/DataSourceProperties.java
index 75c139412c8..62a842309e5 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/DataSourceProperties.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/DataSourceProperties.java
@@ -70,7 +70,7 @@ public final class DataSourceProperties {
      */
     public Map<String, Object> getAllStandardProperties() {
         Map<String, Object> result = new LinkedHashMap<>(
-                connectionPropertySynonyms.getStandardProperties().size() + poolPropertySynonyms.getStandardProperties().size() + customDataSourceProperties.getProperties().size(), 1);
+                connectionPropertySynonyms.getStandardProperties().size() + poolPropertySynonyms.getStandardProperties().size() + customDataSourceProperties.getProperties().size(), 1F);
         result.putAll(connectionPropertySynonyms.getStandardProperties());
         result.putAll(poolPropertySynonyms.getStandardProperties());
         result.putAll(customDataSourceProperties.getProperties());
@@ -84,7 +84,7 @@ public final class DataSourceProperties {
      */
     public Map<String, Object> getAllLocalProperties() {
         Map<String, Object> result = new LinkedHashMap<>(
-                connectionPropertySynonyms.getLocalProperties().size() + poolPropertySynonyms.getLocalProperties().size() + customDataSourceProperties.getProperties().size(), 1);
+                connectionPropertySynonyms.getLocalProperties().size() + poolPropertySynonyms.getLocalProperties().size() + customDataSourceProperties.getProperties().size(), 1F);
         result.putAll(connectionPropertySynonyms.getLocalProperties());
         result.putAll(poolPropertySynonyms.getLocalProperties());
         result.putAll(customDataSourceProperties.getProperties());
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourceProperties.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourceProperties.java
index 5fbd8c48b53..2462790915d 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourceProperties.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourceProperties.java
@@ -44,7 +44,7 @@ public final class CustomDataSourceProperties {
     }
     
     private Map<String, Object> getProperties(final Map<String, Object> props) {
-        Map<String, Object> result = new LinkedHashMap<>(props.size(), 1);
+        Map<String, Object> result = new LinkedHashMap<>(props.size(), 1F);
         for (Entry<String, Object> entry : props.entrySet()) {
             if (!entry.getKey().contains(".")) {
                 result.put(entry.getKey(), entry.getValue());
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/synonym/PropertySynonyms.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/synonym/PropertySynonyms.java
index c8a0953da77..2a23234c7a0 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/synonym/PropertySynonyms.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/props/synonym/PropertySynonyms.java
@@ -45,7 +45,7 @@ public abstract class PropertySynonyms {
     }
     
     private Map<String, Object> buildStandardProperties(final Map<String, Object> props, final Collection<String> standardPropertyKeys, final Map<String, String> propertySynonyms) {
-        Map<String, Object> result = new LinkedHashMap<>(standardPropertyKeys.size(), 1);
+        Map<String, Object> result = new LinkedHashMap<>(standardPropertyKeys.size(), 1F);
         for (String each : standardPropertyKeys) {
             if (props.containsKey(each)) {
                 result.put(each, props.get(each));
@@ -57,7 +57,7 @@ public abstract class PropertySynonyms {
     }
     
     private Map<String, Object> buildLocalProperties(final Map<String, Object> props, final Collection<String> standardPropertyKeys, final Map<String, String> propertySynonyms) {
-        Map<String, Object> result = new LinkedHashMap<>(standardPropertyKeys.size(), 1);
+        Map<String, Object> result = new LinkedHashMap<>(standardPropertyKeys.size(), 1F);
         for (String each : getLocalPropertyKeys(standardPropertyKeys, propertySynonyms)) {
             if (props.containsKey(each)) {
                 result.put(each, props.get(each));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/state/DataSourceStateManager.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/state/DataSourceStateManager.java
index e2edf119c0f..b43531b5310 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/state/DataSourceStateManager.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/datasource/state/DataSourceStateManager.java
@@ -117,7 +117,7 @@ public final class DataSourceStateManager {
     }
     
     private Map<String, DataSource> filterDisabledDataSources(final String databaseName, final Map<String, DataSource> dataSources) {
-        Map<String, DataSource> result = new LinkedHashMap<>(dataSources.size(), 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(dataSources.size(), 1F);
         dataSources.forEach((key, value) -> {
             DataSourceState dataSourceState = dataSourceStates.get(getCacheKey(databaseName, key));
             if (DataSourceState.DISABLED != dataSourceState) {
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/ShardingSphereMetaData.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/ShardingSphereMetaData.java
index fc8fe140408..26d8f0bcffa 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/ShardingSphereMetaData.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/ShardingSphereMetaData.java
@@ -52,7 +52,7 @@ public final class ShardingSphereMetaData {
     }
     
     public ShardingSphereMetaData(final Map<String, ShardingSphereDatabase> databases, final ShardingSphereRuleMetaData globalRuleMetaData, final ConfigurationProperties props) {
-        this.databases = new ConcurrentHashMap<>(databases.size(), 1);
+        this.databases = new ConcurrentHashMap<>(databases.size(), 1F);
         databases.forEach((key, value) -> this.databases.put(key.toLowerCase(), value));
         this.globalRuleMetaData = globalRuleMetaData;
         this.props = props;
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/ShardingSphereDatabase.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/ShardingSphereDatabase.java
index 9cd34c143d6..0cd0869d263 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/ShardingSphereDatabase.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/ShardingSphereDatabase.java
@@ -66,7 +66,7 @@ public final class ShardingSphereDatabase {
         this.protocolType = protocolType;
         this.resourceMetaData = resourceMetaData;
         this.ruleMetaData = ruleMetaData;
-        this.schemas = new ConcurrentHashMap<>(schemas.size(), 1);
+        this.schemas = new ConcurrentHashMap<>(schemas.size(), 1F);
         schemas.forEach((key, value) -> this.schemas.put(key.toLowerCase(), value));
     }
     
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/resource/ShardingSphereResourceMetaData.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/resource/ShardingSphereResourceMetaData.java
index ec355f3c7bd..dc1b2c0c9d7 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/resource/ShardingSphereResourceMetaData.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/resource/ShardingSphereResourceMetaData.java
@@ -56,7 +56,7 @@ public final class ShardingSphereResourceMetaData {
     }
     
     private Map<String, DatabaseType> createStorageTypes(final Map<String, DataSource> enabledDataSources) {
-        Map<String, DatabaseType> result = new LinkedHashMap<>(dataSources.size(), 1);
+        Map<String, DatabaseType> result = new LinkedHashMap<>(dataSources.size(), 1F);
         for (Entry<String, DataSource> entry : dataSources.entrySet()) {
             DatabaseType storageType = enabledDataSources.containsKey(entry.getKey()) ? DatabaseTypeEngine.getStorageType(Collections.singletonList(entry.getValue()))
                     : DatabaseTypeEngine.getStorageType(Collections.emptyList());
@@ -66,7 +66,7 @@ public final class ShardingSphereResourceMetaData {
     }
     
     private Map<String, DataSourceMetaData> createDataSourceMetaDataMap(final Map<String, DataSource> dataSources, final Map<String, DatabaseType> storageTypes) {
-        Map<String, DataSourceMetaData> result = new LinkedHashMap<>(dataSources.size(), 1);
+        Map<String, DataSourceMetaData> result = new LinkedHashMap<>(dataSources.size(), 1F);
         for (Entry<String, DataSource> entry : dataSources.entrySet()) {
             Map<String, Object> standardProps = DataSourcePropertiesCreator.create(entry.getValue()).getConnectionPropertySynonyms().getStandardProperties();
             DatabaseType storageType = storageTypes.get(entry.getKey());
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/SchemaManager.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/SchemaManager.java
index 056f2c5e7d2..24a5aabcc80 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/SchemaManager.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/SchemaManager.java
@@ -41,7 +41,7 @@ public final class SchemaManager {
      * @return To be added table meta data
      */
     public static Map<String, ShardingSphereSchema> getToBeAddedTablesBySchemas(final Map<String, ShardingSphereSchema> reloadSchemas, final Map<String, ShardingSphereSchema> currentSchemas) {
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(currentSchemas.size(), 1);
+        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(currentSchemas.size(), 1F);
         reloadSchemas.entrySet().stream().filter(entry -> currentSchemas.containsKey(entry.getKey())).collect(Collectors.toMap(Entry::getKey, Entry::getValue))
                 .forEach((key, value) -> result.put(key, getToBeAddedTablesBySchema(value, currentSchemas.get(key))));
         return result;
@@ -70,7 +70,7 @@ public final class SchemaManager {
      * @return To be deleted table meta data
      */
     public static Map<String, ShardingSphereSchema> getToBeDeletedTablesBySchemas(final Map<String, ShardingSphereSchema> reloadSchemas, final Map<String, ShardingSphereSchema> currentSchemas) {
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(currentSchemas.size(), 1);
+        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(currentSchemas.size(), 1F);
         currentSchemas.entrySet().stream().filter(entry -> reloadSchemas.containsKey(entry.getKey())).collect(Collectors.toMap(Entry::getKey, Entry::getValue))
                 .forEach((key, value) -> result.put(key, getToBeDeletedTablesBySchema(reloadSchemas.get(key), value)));
         return result;
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/GenericSchemaBuilder.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/GenericSchemaBuilder.java
index 8e12f1e9994..dfc1609fc1a 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/GenericSchemaBuilder.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/GenericSchemaBuilder.java
@@ -127,7 +127,7 @@ public final class GenericSchemaBuilder {
         if (schemaMetaDataMap.isEmpty()) {
             return Collections.singletonMap(material.getDefaultSchemaName(), new ShardingSphereSchema());
         }
-        Map<String, ShardingSphereSchema> result = new ConcurrentHashMap<>(schemaMetaDataMap.size(), 1);
+        Map<String, ShardingSphereSchema> result = new ConcurrentHashMap<>(schemaMetaDataMap.size(), 1F);
         for (Entry<String, SchemaMetaData> entry : schemaMetaDataMap.entrySet()) {
             Map<String, ShardingSphereTable> tables = convertToTableMap(entry.getValue().getTables());
             result.put(entry.getKey().toLowerCase(), new ShardingSphereSchema(tables, new LinkedHashMap<>()));
@@ -136,7 +136,7 @@ public final class GenericSchemaBuilder {
     }
     
     private static Map<String, ShardingSphereTable> convertToTableMap(final Collection<TableMetaData> tableMetaDataList) {
-        Map<String, ShardingSphereTable> result = new LinkedHashMap<>(tableMetaDataList.size(), 1);
+        Map<String, ShardingSphereTable> result = new LinkedHashMap<>(tableMetaDataList.size(), 1F);
         for (TableMetaData each : tableMetaDataList) {
             Collection<ShardingSphereColumn> columns = convertToColumns(each.getColumns());
             Collection<ShardingSphereIndex> indexes = convertToIndexes(each.getIndexes());
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilder.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilder.java
index 7dc7f148fa5..5890034899a 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilder.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilder.java
@@ -48,7 +48,7 @@ public final class SystemSchemaBuilder {
      * @return ShardingSphere system schema map
      */
     public static Map<String, ShardingSphereSchema> build(final String databaseName, final DatabaseType databaseType) {
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(databaseType.getSystemSchemas().size(), 1);
+        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(databaseType.getSystemSchemas().size(), 1F);
         YamlTableSwapper swapper = new YamlTableSwapper();
         for (String each : getSystemSchemas(databaseName, databaseType)) {
             result.put(each.toLowerCase(), createSchema(getSchemaStreams(each, databaseType), swapper));
@@ -71,7 +71,7 @@ public final class SystemSchemaBuilder {
     }
     
     private static ShardingSphereSchema createSchema(final Collection<InputStream> schemaStreams, final YamlTableSwapper swapper) {
-        Map<String, ShardingSphereTable> tables = new LinkedHashMap<>(schemaStreams.size(), 1);
+        Map<String, ShardingSphereTable> tables = new LinkedHashMap<>(schemaStreams.size(), 1F);
         for (InputStream each : schemaStreams) {
             YamlShardingSphereTable metaData = new Yaml().loadAs(each, YamlShardingSphereTable.class);
             tables.put(metaData.getName(), swapper.swapToObject(metaData));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilderRule.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilderRule.java
index 43cbd9c2167..5324feb2d99 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilderRule.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/builder/SystemSchemaBuilderRule.java
@@ -112,7 +112,7 @@ public enum SystemSchemaBuilderRule {
     
     OPEN_GAUSS_SHARDING_SPHERE("openGauss", "shardingsphere", new HashSet<>(Arrays.asList("sharding_table_statistics", "cluster_information")));
     
-    private static final Map<String, SystemSchemaBuilderRule> SCHEMA_PATH_SYSTEM_SCHEMA_BUILDER_RULE_MAP = new HashMap<>(values().length, 1);
+    private static final Map<String, SystemSchemaBuilderRule> SCHEMA_PATH_SYSTEM_SCHEMA_BUILDER_RULE_MAP = new HashMap<>(values().length, 1F);
     
     private final String databaseType;
     
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/common/SchemaMetaDataLoader.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/common/SchemaMetaDataLoader.java
index 4e181c488d7..fb3c074158f 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/common/SchemaMetaDataLoader.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/common/SchemaMetaDataLoader.java
@@ -63,7 +63,7 @@ public final class SchemaMetaDataLoader {
     public static Map<String, Collection<String>> loadSchemaTableNames(final String databaseName, final DatabaseType databaseType, final DataSource dataSource) throws SQLException {
         try (MetaDataLoaderConnectionAdapter connectionAdapter = new MetaDataLoaderConnectionAdapter(databaseType, dataSource.getConnection())) {
             Collection<String> schemaNames = loadSchemaNames(connectionAdapter, databaseType);
-            Map<String, Collection<String>> result = new HashMap<>(schemaNames.size(), 1);
+            Map<String, Collection<String>> result = new HashMap<>(schemaNames.size(), 1F);
             for (String each : schemaNames) {
                 String schemaName = databaseType instanceof SchemaSupportedDatabaseType ? each : databaseName;
                 result.put(schemaName, loadTableNames(connectionAdapter, each));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/datatype/dialect/MySQLDataTypeLoader.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/datatype/dialect/MySQLDataTypeLoader.java
index daa177a9522..5446274515d 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/datatype/dialect/MySQLDataTypeLoader.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/datatype/dialect/MySQLDataTypeLoader.java
@@ -31,7 +31,7 @@ public final class MySQLDataTypeLoader implements DialectDataTypeLoader {
     
     @Override
     public Map<String, Integer> load() throws SQLException {
-        Map<String, Integer> result = new HashMap<>(10, 1);
+        Map<String, Integer> result = new HashMap<>(10, 1F);
         result.putIfAbsent("JSON", Types.LONGVARCHAR);
         result.putIfAbsent("GEOMETRY", Types.BINARY);
         result.putIfAbsent("GEOMETRYCOLLECTION", Types.BINARY);
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/SchemaMetaDataLoaderEngine.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/SchemaMetaDataLoaderEngine.java
index b6d5d34adfd..fae78cf8293 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/SchemaMetaDataLoaderEngine.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/SchemaMetaDataLoaderEngine.java
@@ -56,7 +56,7 @@ public final class SchemaMetaDataLoaderEngine {
      * @throws SQLException SQL exception
      */
     public static Map<String, SchemaMetaData> load(final Collection<SchemaMetaDataLoaderMaterial> materials) throws SQLException {
-        Map<String, SchemaMetaData> result = new LinkedHashMap<>(materials.size(), 1);
+        Map<String, SchemaMetaData> result = new LinkedHashMap<>(materials.size(), 1F);
         Collection<Future<Collection<SchemaMetaData>>> futures = new LinkedList<>();
         for (SchemaMetaDataLoaderMaterial each : materials) {
             futures.add(EXECUTOR_SERVICE.submit(() -> load(each)));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/OracleSchemaMetaDataLoader.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/OracleSchemaMetaDataLoader.java
index eae705cdb8c..9ab0f3de1b4 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/OracleSchemaMetaDataLoader.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/OracleSchemaMetaDataLoader.java
@@ -74,8 +74,8 @@ public final class OracleSchemaMetaDataLoader implements DialectSchemaMetaDataLo
     
     @Override
     public Collection<SchemaMetaData> load(final DataSource dataSource, final Collection<String> tables, final String defaultSchemaName) throws SQLException {
-        Map<String, Collection<ColumnMetaData>> columnMetaDataMap = new HashMap<>(tables.size(), 1);
-        Map<String, Collection<IndexMetaData>> indexMetaDataMap = new HashMap<>(tables.size(), 1);
+        Map<String, Collection<ColumnMetaData>> columnMetaDataMap = new HashMap<>(tables.size(), 1F);
+        Map<String, Collection<IndexMetaData>> indexMetaDataMap = new HashMap<>(tables.size(), 1F);
         try (Connection connection = new MetaDataLoaderConnectionAdapter(TypedSPILoader.getService(DatabaseType.class, "Oracle"), dataSource.getConnection())) {
             for (List<String> each : Lists.partition(new ArrayList<>(tables), MAX_EXPRESSION_SIZE)) {
                 columnMetaDataMap.putAll(loadColumnMetaDataMap(connection, each));
@@ -91,7 +91,7 @@ public final class OracleSchemaMetaDataLoader implements DialectSchemaMetaDataLo
     }
     
     private Map<String, Collection<ColumnMetaData>> loadColumnMetaDataMap(final Connection connection, final Collection<String> tables) throws SQLException {
-        Map<String, Collection<ColumnMetaData>> result = new HashMap<>(tables.size(), 1);
+        Map<String, Collection<ColumnMetaData>> result = new HashMap<>(tables.size(), 1F);
         try (PreparedStatement preparedStatement = connection.prepareStatement(getTableMetaDataSQL(tables, connection.getMetaData()))) {
             Map<String, Integer> dataTypes = new DataTypeLoader().load(connection.getMetaData(), TypedSPILoader.getService(DatabaseType.class, getType()));
             Map<String, Collection<String>> tablePrimaryKeys = loadTablePrimaryKeys(connection, tables);
@@ -153,7 +153,7 @@ public final class OracleSchemaMetaDataLoader implements DialectSchemaMetaDataLo
     }
     
     private Map<String, Collection<IndexMetaData>> loadIndexMetaData(final Connection connection, final Collection<String> tableNames) throws SQLException {
-        Map<String, Collection<IndexMetaData>> result = new HashMap<>(tableNames.size(), 1);
+        Map<String, Collection<IndexMetaData>> result = new HashMap<>(tableNames.size(), 1F);
         try (PreparedStatement preparedStatement = connection.prepareStatement(getIndexMetaDataSQL(tableNames))) {
             preparedStatement.setString(1, connection.getSchema());
             try (ResultSet resultSet = preparedStatement.executeQuery()) {
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/PostgreSQLSchemaMetaDataLoader.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/PostgreSQLSchemaMetaDataLoader.java
index 3e6e6a36025..c703657f089 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/PostgreSQLSchemaMetaDataLoader.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/loader/metadata/dialect/PostgreSQLSchemaMetaDataLoader.java
@@ -127,7 +127,7 @@ public final class PostgreSQLSchemaMetaDataLoader implements DialectSchemaMetaDa
     }
     
     private Collection<String> loadRoleTableGrants(final Connection connection, final Collection<String> tables) throws SQLException {
-        Collection<String> result = new HashSet<>(tables.size(), 1);
+        Collection<String> result = new HashSet<>(tables.size(), 1F);
         try (PreparedStatement preparedStatement = connection.prepareStatement(getLoadRoleTableGrantsSQL(tables)); ResultSet resultSet = preparedStatement.executeQuery()) {
             while (resultSet.next()) {
                 result.add(resultSet.getString("table_name"));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereSchema.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereSchema.java
index 69e4c416e4d..572dbb806e2 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereSchema.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereSchema.java
@@ -43,8 +43,8 @@ public final class ShardingSphereSchema {
     }
     
     public ShardingSphereSchema(final Map<String, ShardingSphereTable> tables, final Map<String, ShardingSphereView> views) {
-        this.tables = new ConcurrentHashMap<>(tables.size(), 1);
-        this.views = new ConcurrentHashMap<>(views.size(), 1);
+        this.tables = new ConcurrentHashMap<>(tables.size(), 1F);
+        this.views = new ConcurrentHashMap<>(views.size(), 1F);
         tables.forEach((key, value) -> this.tables.put(key.toLowerCase(), value));
         views.forEach((key, value) -> this.views.put(key.toLowerCase(), value));
     }
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereTable.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereTable.java
index 28dfd15c748..95fc15f7898 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereTable.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/model/ShardingSphereTable.java
@@ -63,7 +63,7 @@ public final class ShardingSphereTable {
     }
     
     private Map<String, ShardingSphereColumn> createColumns(final Collection<ShardingSphereColumn> columns) {
-        Map<String, ShardingSphereColumn> result = new LinkedHashMap<>(columns.size(), 1);
+        Map<String, ShardingSphereColumn> result = new LinkedHashMap<>(columns.size(), 1F);
         for (ShardingSphereColumn each : columns) {
             String lowerColumnName = each.getName().toLowerCase();
             result.put(lowerColumnName, each);
@@ -79,7 +79,7 @@ public final class ShardingSphereTable {
     }
     
     private Map<String, ShardingSphereIndex> createIndexes(final Collection<ShardingSphereIndex> indexes) {
-        Map<String, ShardingSphereIndex> result = new LinkedHashMap<>(indexes.size(), 1);
+        Map<String, ShardingSphereIndex> result = new LinkedHashMap<>(indexes.size(), 1F);
         for (ShardingSphereIndex each : indexes) {
             result.put(each.getName().toLowerCase(), each);
         }
@@ -87,7 +87,7 @@ public final class ShardingSphereTable {
     }
     
     private Map<String, ShardingSphereConstraint> createConstraints(final Collection<ShardingSphereConstraint> constraints) {
-        Map<String, ShardingSphereConstraint> result = new LinkedHashMap<>(constraints.size(), 1);
+        Map<String, ShardingSphereConstraint> result = new LinkedHashMap<>(constraints.size(), 1F);
         for (ShardingSphereConstraint each : constraints) {
             result.put(each.getName().toLowerCase(), each);
         }
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/reviser/MetaDataReviseEngine.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/reviser/MetaDataReviseEngine.java
index 2ac54d9778c..da8dbb6cfb3 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/reviser/MetaDataReviseEngine.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/metadata/database/schema/reviser/MetaDataReviseEngine.java
@@ -46,7 +46,7 @@ public final class MetaDataReviseEngine {
      * @return revised meta data
      */
     public Map<String, SchemaMetaData> revise(final Map<String, SchemaMetaData> schemaMetaDataMap, final GenericSchemaBuilderMaterial material) {
-        Map<String, SchemaMetaData> result = new LinkedHashMap<>(schemaMetaDataMap.size(), 1);
+        Map<String, SchemaMetaData> result = new LinkedHashMap<>(schemaMetaDataMap.size(), 1F);
         for (Entry<String, SchemaMetaData> entry : schemaMetaDataMap.entrySet()) {
             // TODO establish a corresponding relationship between tables and data sources
             DatabaseType databaseType = material.getStorageTypes().values().stream().findFirst().orElse(null);
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/rule/identifier/type/exportable/RuleExportEngine.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/rule/identifier/type/exportable/RuleExportEngine.java
index ab84506bfb9..a45bab876f2 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/rule/identifier/type/exportable/RuleExportEngine.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/rule/identifier/type/exportable/RuleExportEngine.java
@@ -40,7 +40,7 @@ public final class RuleExportEngine {
      */
     public Map<String, Object> export(final Collection<String> keys) {
         Map<String, Object> exportMethods = rule.getExportData();
-        Map<String, Object> result = new HashMap<>(keys.size(), 1);
+        Map<String, Object> result = new HashMap<>(keys.size(), 1F);
         keys.forEach(each -> {
             if (exportMethods.containsKey(each)) {
                 result.put(each, exportMethods.get(each));
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/shortcut/YamlRuleConfigurationShortcuts.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/shortcut/YamlRuleConfigurationShortcuts.java
index 021aa337646..5dd9777f113 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/shortcut/YamlRuleConfigurationShortcuts.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/shortcut/YamlRuleConfigurationShortcuts.java
@@ -37,7 +37,7 @@ public final class YamlRuleConfigurationShortcuts implements ShardingSphereYamlS
     @SneakyThrows(ReflectiveOperationException.class)
     public Map<String, Class<?>> getYamlShortcuts() {
         Collection<YamlRuleConfigurationSwapper> swappers = ShardingSphereServiceLoader.getServiceInstances(YamlRuleConfigurationSwapper.class);
-        Map<String, Class<?>> result = new HashMap<>(swappers.size(), 1);
+        Map<String, Class<?>> result = new HashMap<>(swappers.size(), 1F);
         for (YamlRuleConfigurationSwapper each : swappers) {
             Class<?> yamlRuleConfigurationClass = Class.forName(((ParameterizedType) each.getClass().getGenericInterfaces()[0]).getActualTypeArguments()[0].getTypeName());
             result.put(String.format("!%s", each.getRuleTagName()), yamlRuleConfigurationClass);
diff --git a/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourceConfigurationSwapper.java b/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourceConfigurationSwapper.java
index 7af7babf99c..ec0f20dcea9 100644
--- a/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourceConfigurationSwapper.java
+++ b/infra/common/src/main/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourceConfigurationSwapper.java
@@ -67,7 +67,7 @@ public final class YamlDataSourceConfigurationSwapper {
      */
     public Map<String, DataSourceProperties> getDataSourcePropertiesMap(final YamlRootConfiguration yamlRootConfig) {
         Map<String, Map<String, Object>> yamlDataSourceConfigs = yamlRootConfig.getDataSources();
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(yamlDataSourceConfigs.size());
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(yamlDataSourceConfigs.size(), 1F);
         yamlDataSourceConfigs.forEach((key, value) -> result.put(key, swapToDataSourceProperties(value)));
         return result;
     }
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/datanode/DataNodeUtilsTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/datanode/DataNodeUtilsTest.java
index 3c709be1ed7..49006780cbf 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/datanode/DataNodeUtilsTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/datanode/DataNodeUtilsTest.java
@@ -35,7 +35,7 @@ class DataNodeUtilsTest {
     
     @Test
     void assertGetDataNodeGroups() {
-        Map<String, List<DataNode>> expected = new LinkedHashMap<>(2, 1);
+        Map<String, List<DataNode>> expected = new LinkedHashMap<>(2, 1F);
         expected.put("ds_0", Arrays.asList(new DataNode("ds_0.tbl_0"), new DataNode("ds_0.tbl_1")));
         expected.put("ds_1", Arrays.asList(new DataNode("ds_1.tbl_0"), new DataNode("ds_1.tbl_1")));
         List<DataNode> dataNodes = new LinkedList<>();
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/pool/metadata/fixture/MockedDataSourcePoolMetaData.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/pool/metadata/fixture/MockedDataSourcePoolMetaData.java
index e79ed992c52..459ada86677 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/pool/metadata/fixture/MockedDataSourcePoolMetaData.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/pool/metadata/fixture/MockedDataSourcePoolMetaData.java
@@ -35,7 +35,7 @@ public final class MockedDataSourcePoolMetaData implements DataSourcePoolMetaDat
     
     @Override
     public Map<String, Object> getInvalidProperties() {
-        Map<String, Object> result = new HashMap<>(2, 1);
+        Map<String, Object> result = new HashMap<>(2, 1F);
         result.put("maxPoolSize", -1);
         result.put("minPoolSize", -1);
         return result;
@@ -43,7 +43,7 @@ public final class MockedDataSourcePoolMetaData implements DataSourcePoolMetaDat
     
     @Override
     public Map<String, String> getPropertySynonyms() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("maxPoolSize", "maxPoolSize");
         result.put("minPoolSize", "minPoolSize");
         return result;
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/DataSourcePropertiesTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/DataSourcePropertiesTest.java
index dcd4864ec3c..9509e47c6d0 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/DataSourcePropertiesTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/DataSourcePropertiesTest.java
@@ -80,7 +80,7 @@ class DataSourcePropertiesTest {
     }
     
     private Map<String, Object> getProperties() {
-        Map<String, Object> result = new HashMap<>(7, 1);
+        Map<String, Object> result = new HashMap<>(7, 1F);
         result.put("driverClassName", MockedDataSource.class.getName());
         result.put("jdbcUrl", "jdbc:mock://127.0.0.1/foo_ds");
         result.put("username", "root");
@@ -133,14 +133,14 @@ class DataSourcePropertiesTest {
     }
     
     private Map<String, Object> createUserProperties(final String username) {
-        Map<String, Object> result = new LinkedHashMap<>(2, 1);
+        Map<String, Object> result = new LinkedHashMap<>(2, 1F);
         result.put("username", username);
         result.put("dataSourceProperties", getDataSourceProperties());
         return result;
     }
     
     private Map<String, String> getDataSourceProperties() {
-        Map<String, String> result = new LinkedHashMap<>(3, 1);
+        Map<String, String> result = new LinkedHashMap<>(3, 1F);
         result.put("maintainTimeStats", "false");
         result.put("rewriteBatchedStatements", "true");
         result.put("useLocalSessionState", "true");
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourcePropertiesTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourcePropertiesTest.java
index a7556d37cc2..ddf8a6c033d 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourcePropertiesTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/custom/CustomDataSourcePropertiesTest.java
@@ -45,7 +45,7 @@ class CustomDataSourcePropertiesTest {
     }
     
     private Map<String, Object> createProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(8, 1);
+        Map<String, Object> result = new LinkedHashMap<>(8, 1F);
         result.put("user", "root");
         result.put("password", "root");
         result.put("closed", false);
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/ConnectionPropertySynonymsTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/ConnectionPropertySynonymsTest.java
index f5f6bbb0499..12d72112951 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/ConnectionPropertySynonymsTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/ConnectionPropertySynonymsTest.java
@@ -64,7 +64,7 @@ class ConnectionPropertySynonymsTest {
     }
     
     private Map<String, Object> createStandardProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(3, 1);
+        Map<String, Object> result = new LinkedHashMap<>(3, 1F);
         result.put("url", "jdbc:mock://127.0.0.1/foo_ds");
         result.put("username", "root");
         result.put("password", "root");
@@ -72,7 +72,7 @@ class ConnectionPropertySynonymsTest {
     }
     
     private Map<String, Object> createLocalProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(3, 1);
+        Map<String, Object> result = new LinkedHashMap<>(3, 1F);
         result.put("jdbcUrl", "jdbc:mock://127.0.0.1/foo_ds");
         result.put("user", "root");
         result.put("password", "root");
@@ -80,7 +80,7 @@ class ConnectionPropertySynonymsTest {
     }
     
     private Map<String, String> createPropertySynonyms() {
-        Map<String, String> result = new LinkedHashMap<>(2, 1);
+        Map<String, String> result = new LinkedHashMap<>(2, 1F);
         result.put("url", "jdbcUrl");
         result.put("username", "user");
         return result;
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/PoolPropertySynonymsTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/PoolPropertySynonymsTest.java
index e926497bc45..d4183cbbc2d 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/PoolPropertySynonymsTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/datasource/props/synonym/PoolPropertySynonymsTest.java
@@ -77,7 +77,7 @@ class PoolPropertySynonymsTest {
     }
     
     private Map<String, Object> createStandardProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(6, 1);
+        Map<String, Object> result = new LinkedHashMap<>(6, 1F);
         result.put("connectionTimeoutMilliseconds", 30000);
         result.put("idleTimeoutMilliseconds", 180000);
         result.put("maxLifetimeMilliseconds", 180000);
@@ -88,7 +88,7 @@ class PoolPropertySynonymsTest {
     }
     
     private Map<String, Object> createLocalProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(6, 1);
+        Map<String, Object> result = new LinkedHashMap<>(6, 1F);
         result.put("connectionTimeout", 30000);
         result.put("idleTimeout", 180000);
         result.put("maxLifetime", 180000);
@@ -99,7 +99,7 @@ class PoolPropertySynonymsTest {
     }
     
     private Map<String, String> createPropertySynonyms() {
-        Map<String, String> result = new LinkedHashMap<>(5, 1);
+        Map<String, String> result = new LinkedHashMap<>(5, 1F);
         result.put("connectionTimeoutMilliseconds", "connectionTimeout");
         result.put("idleTimeoutMilliseconds", "idleTimeout");
         result.put("maxLifetimeMilliseconds", "maxLifetime");
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/data/builder/PostgreSQLShardingSphereDataBuilderTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/data/builder/PostgreSQLShardingSphereDataBuilderTest.java
index d7ac7f8452a..bb02c389d94 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/data/builder/PostgreSQLShardingSphereDataBuilderTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/data/builder/PostgreSQLShardingSphereDataBuilderTest.java
@@ -25,7 +25,7 @@ import org.apache.shardingsphere.infra.metadata.database.schema.model.ShardingSp
 import org.apache.shardingsphere.infra.metadata.database.schema.model.ShardingSphereTable;
 import org.junit.jupiter.api.Test;
 
-import java.util.LinkedHashMap;
+import java.util.Collections;
 import java.util.Map;
 
 import static org.junit.jupiter.api.Assertions.assertTrue;
@@ -51,28 +51,22 @@ class PostgreSQLShardingSphereDataBuilderTest {
     }
     
     private Map<String, ShardingSphereDatabase> mockDatabaseMap() {
-        Map<String, ShardingSphereDatabase> result = new LinkedHashMap<>(1);
         ShardingSphereDatabase database = mock(ShardingSphereDatabase.class);
         Map<String, ShardingSphereSchema> schemaMap = mockSchemaMap();
         when(database.getSchemas()).thenReturn(schemaMap);
-        result.put("logic_db", database);
-        return result;
+        return Collections.singletonMap("logic_db", database);
     }
     
     private Map<String, ShardingSphereSchema> mockSchemaMap() {
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(1);
         ShardingSphereSchema schema = mock(ShardingSphereSchema.class);
         Map<String, ShardingSphereTable> tableMap = mockTableMap();
         when(schema.getTables()).thenReturn(tableMap);
-        result.put("pg_catalog", schema);
-        return result;
+        return Collections.singletonMap("pg_catalog", schema);
     }
     
     private Map<String, ShardingSphereTable> mockTableMap() {
-        Map<String, ShardingSphereTable> result = new LinkedHashMap<>(1);
         ShardingSphereTable table = mock(ShardingSphereTable.class);
         when(table.getName()).thenReturn("pg_class");
-        result.put("pg_class", table);
-        return result;
+        return Collections.singletonMap("pg_class", table);
     }
 }
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/database/schema/util/SchemaMetaDataUtilsTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/database/schema/util/SchemaMetaDataUtilsTest.java
index 8b862313397..33e7b283018 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/database/schema/util/SchemaMetaDataUtilsTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/metadata/database/schema/util/SchemaMetaDataUtilsTest.java
@@ -101,7 +101,7 @@ class SchemaMetaDataUtilsTest {
     }
     
     private Map<String, DataSource> mockDataSourceMap() {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         result.put("ds_0", new MockedDataSource());
         result.put("ds_1", new MockedDataSource());
         return result;
diff --git a/infra/common/src/test/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourcePropertiesSwapperTest.java b/infra/common/src/test/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourcePropertiesSwapperTest.java
index ba4f3865e8c..ec81561831e 100644
--- a/infra/common/src/test/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourcePropertiesSwapperTest.java
+++ b/infra/common/src/test/java/org/apache/shardingsphere/infra/yaml/config/swapper/resource/YamlDataSourcePropertiesSwapperTest.java
@@ -49,7 +49,7 @@ class YamlDataSourcePropertiesSwapperTest {
     
     @Test
     void assertSwapToDataSourceProperties() {
-        Map<String, Object> yamlConfig = new HashMap<>(3, 1);
+        Map<String, Object> yamlConfig = new HashMap<>(3, 1F);
         yamlConfig.put("dataSourceClassName", MockedDataSource.class.getName());
         yamlConfig.put("url", "xx:xxx");
         yamlConfig.put("username", "root");
@@ -68,21 +68,21 @@ class YamlDataSourcePropertiesSwapperTest {
     }
     
     private Map<String, Object> createProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(2, 1);
+        Map<String, Object> result = new LinkedHashMap<>(2, 1F);
         result.put("url", "xx:xxx");
         result.put("username", "root");
         return result;
     }
     
     private Map<String, Map<String, Object>> createYamlConfig() {
-        Map<String, Map<String, Object>> result = new LinkedHashMap<>(2, 1);
+        Map<String, Map<String, Object>> result = new LinkedHashMap<>(2, 1F);
         result.put("ds_0", createPropertyMap("ds_0"));
         result.put("ds_1", createPropertyMap("ds_1"));
         return result;
     }
     
     private Map<String, Object> createPropertyMap(final String name) {
-        Map<String, Object> result = new LinkedHashMap<>(4, 1);
+        Map<String, Object> result = new LinkedHashMap<>(4, 1F);
         result.put("dataSourceClassName", MockedDataSource.class.getName());
         result.put("url", String.format("jdbc:mock://127.0.0.1/%s", name));
         result.put("username", "root");
diff --git a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilder.java b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilder.java
index 25b1e99b7e2..f21d4f1a7d9 100644
--- a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilder.java
+++ b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilder.java
@@ -68,7 +68,7 @@ public final class ExecutionContextBuilder {
     }
     
     private static Collection<ExecutionUnit> build(final RouteSQLRewriteResult sqlRewriteResult) {
-        Collection<ExecutionUnit> result = new LinkedHashSet<>(sqlRewriteResult.getSqlRewriteUnits().size(), 1f);
+        Collection<ExecutionUnit> result = new LinkedHashSet<>(sqlRewriteResult.getSqlRewriteUnits().size(), 1F);
         for (Entry<RouteUnit, SQLRewriteUnit> entry : sqlRewriteResult.getSqlRewriteUnits().entrySet()) {
             result.add(new ExecutionUnit(entry.getKey().getDataSourceMapper().getActualName(),
                     new SQLUnit(entry.getValue().getSql(), entry.getValue().getParameters(), getRouteTableRouteMappers(entry.getKey().getTableMappers()))));
diff --git a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/log/SQLLogger.java b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/log/SQLLogger.java
index 006c89b4ca2..b396dc77be3 100644
--- a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/log/SQLLogger.java
+++ b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/log/SQLLogger.java
@@ -52,7 +52,7 @@ public final class SQLLogger {
     }
     
     private static void logSimpleMode(final Collection<ExecutionUnit> executionUnits) {
-        Set<String> dataSourceNames = new HashSet<>(executionUnits.size());
+        Set<String> dataSourceNames = new HashSet<>(executionUnits.size(), 1F);
         for (ExecutionUnit each : executionUnits) {
             dataSourceNames.add(each.getDataSourceName());
         }
diff --git a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/AbstractExecutionPrepareEngine.java b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/AbstractExecutionPrepareEngine.java
index d9bd2c13ef9..c565164bc10 100644
--- a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/AbstractExecutionPrepareEngine.java
+++ b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/AbstractExecutionPrepareEngine.java
@@ -75,7 +75,7 @@ public abstract class AbstractExecutionPrepareEngine<T> implements ExecutionPrep
     protected abstract List<ExecutionGroup<T>> group(String dataSourceName, List<List<SQLUnit>> sqlUnitGroups, ConnectionMode connectionMode) throws SQLException;
     
     private Map<String, List<SQLUnit>> aggregateSQLUnitGroups(final Collection<ExecutionUnit> executionUnits) {
-        Map<String, List<SQLUnit>> result = new LinkedHashMap<>(executionUnits.size(), 1);
+        Map<String, List<SQLUnit>> result = new LinkedHashMap<>(executionUnits.size(), 1F);
         for (ExecutionUnit each : executionUnits) {
             if (!result.containsKey(each.getDataSourceName())) {
                 result.put(each.getDataSourceName(), new LinkedList<>());
diff --git a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/driver/DriverExecutionPrepareEngine.java b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/driver/DriverExecutionPrepareEngine.java
index 382661151da..c80acec9c92 100644
--- a/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/driver/DriverExecutionPrepareEngine.java
+++ b/infra/executor/src/main/java/org/apache/shardingsphere/infra/executor/sql/prepare/driver/DriverExecutionPrepareEngine.java
@@ -43,7 +43,7 @@ import java.util.concurrent.ConcurrentHashMap;
 public final class DriverExecutionPrepareEngine<T extends DriverExecutionUnit<?>, C> extends AbstractExecutionPrepareEngine<T> {
     
     @SuppressWarnings("rawtypes")
-    private static final Map<String, SQLExecutionUnitBuilder> TYPE_TO_BUILDER_MAP = new ConcurrentHashMap<>(8, 1);
+    private static final Map<String, SQLExecutionUnitBuilder> TYPE_TO_BUILDER_MAP = new ConcurrentHashMap<>(8, 1F);
     
     private final DatabaseConnectionManager<C> databaseConnectionManager;
     
diff --git a/infra/executor/src/test/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilderTest.java b/infra/executor/src/test/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilderTest.java
index ed4e04c9879..c0e43d6c047 100644
--- a/infra/executor/src/test/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilderTest.java
+++ b/infra/executor/src/test/java/org/apache/shardingsphere/infra/executor/sql/context/ExecutionContextBuilderTest.java
@@ -68,7 +68,7 @@ class ExecutionContextBuilderTest {
         SQLRewriteUnit sqlRewriteUnit1 = new SQLRewriteUnit("sql1", Collections.singletonList("parameter1"));
         RouteUnit routeUnit2 = new RouteUnit(new RouteMapper("logicName2", "actualName2"), Collections.singletonList(new RouteMapper("logicName1", "actualName1")));
         SQLRewriteUnit sqlRewriteUnit2 = new SQLRewriteUnit("sql2", Collections.singletonList("parameter2"));
-        Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits = new HashMap<>(2, 1);
+        Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits = new HashMap<>(2, 1F);
         sqlRewriteUnits.put(routeUnit1, sqlRewriteUnit1);
         sqlRewriteUnits.put(routeUnit2, sqlRewriteUnit2);
         ShardingSphereResourceMetaData resourceMetaData = new ShardingSphereResourceMetaData("sharding_db", Collections.emptyMap());
@@ -77,7 +77,7 @@ class ExecutionContextBuilderTest {
         Collection<ExecutionUnit> actual = ExecutionContextBuilder.build(database, new RouteSQLRewriteResult(sqlRewriteUnits), mock(SQLStatementContext.class));
         ExecutionUnit expectedUnit1 = new ExecutionUnit("actualName1", new SQLUnit("sql1", Collections.singletonList("parameter1")));
         ExecutionUnit expectedUnit2 = new ExecutionUnit("actualName2", new SQLUnit("sql2", Collections.singletonList("parameter2")));
-        Collection<ExecutionUnit> expected = new LinkedHashSet<>(2, 1);
+        Collection<ExecutionUnit> expected = new LinkedHashSet<>(2, 1F);
         expected.add(expectedUnit1);
         expected.add(expectedUnit2);
         assertThat(actual, is(expected));
@@ -87,20 +87,18 @@ class ExecutionContextBuilderTest {
     void assertBuildRouteSQLRewriteResultWithEmptyPrimaryKeyMeta() {
         RouteUnit routeUnit2 = new RouteUnit(new RouteMapper("logicName2", "actualName2"), Collections.singletonList(new RouteMapper("logicName2", "actualName2")));
         SQLRewriteUnit sqlRewriteUnit2 = new SQLRewriteUnit("sql2", Collections.singletonList("parameter2"));
-        Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits = new HashMap<>(2, 1);
+        Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits = new HashMap<>(2, 1F);
         sqlRewriteUnits.put(routeUnit2, sqlRewriteUnit2);
         ShardingSphereResourceMetaData resourceMetaData = new ShardingSphereResourceMetaData("sharding_db", Collections.emptyMap());
         ShardingSphereRuleMetaData ruleMetaData = new ShardingSphereRuleMetaData(Collections.emptyList());
         ShardingSphereDatabase database = new ShardingSphereDatabase(DefaultDatabase.LOGIC_NAME, mock(DatabaseType.class), resourceMetaData, ruleMetaData, buildDatabaseWithoutPrimaryKey());
         Collection<ExecutionUnit> actual = ExecutionContextBuilder.build(database, new RouteSQLRewriteResult(sqlRewriteUnits), mock(SQLStatementContext.class));
         ExecutionUnit expectedUnit2 = new ExecutionUnit("actualName2", new SQLUnit("sql2", Collections.singletonList("parameter2")));
-        Collection<ExecutionUnit> expected = new LinkedHashSet<>(1, 1);
-        expected.add(expectedUnit2);
-        assertThat(actual, is(expected));
+        assertThat(actual, is(Collections.singleton(expectedUnit2)));
     }
     
     private Map<String, ShardingSphereSchema> buildDatabaseWithoutPrimaryKey() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1F);
         tables.put("logicName1", new ShardingSphereTable("logicName1", Arrays.asList(new ShardingSphereColumn("order_id", Types.INTEGER, true, false, false, true, false),
                 new ShardingSphereColumn("user_id", Types.INTEGER, false, false, false, true, false),
                 new ShardingSphereColumn("status", Types.INTEGER, false, false, false, true, false)), Collections.emptySet(), Collections.emptyList()));
@@ -110,7 +108,7 @@ class ExecutionContextBuilderTest {
     }
     
     private Map<String, ShardingSphereSchema> buildDatabase() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1F);
         tables.put("logicName1", new ShardingSphereTable("logicName1", Arrays.asList(new ShardingSphereColumn("order_id", Types.INTEGER, true, false, false, true, false),
                 new ShardingSphereColumn("user_id", Types.INTEGER, false, false, false, true, false),
                 new ShardingSphereColumn("status", Types.INTEGER, false, false, false, true, false)), Collections.emptySet(), Collections.emptyList()));
diff --git a/infra/rewrite/src/main/java/org/apache/shardingsphere/infra/rewrite/engine/RouteSQLRewriteEngine.java b/infra/rewrite/src/main/java/org/apache/shardingsphere/infra/rewrite/engine/RouteSQLRewriteEngine.java
index de37c5d2314..bf724a699a7 100644
--- a/infra/rewrite/src/main/java/org/apache/shardingsphere/infra/rewrite/engine/RouteSQLRewriteEngine.java
+++ b/infra/rewrite/src/main/java/org/apache/shardingsphere/infra/rewrite/engine/RouteSQLRewriteEngine.java
@@ -63,7 +63,7 @@ public final class RouteSQLRewriteEngine {
      * @return SQL rewrite result
      */
     public RouteSQLRewriteResult rewrite(final SQLRewriteContext sqlRewriteContext, final RouteContext routeContext) {
-        Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits = new LinkedHashMap<>(routeContext.getRouteUnits().size(), 1);
+        Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits = new LinkedHashMap<>(routeContext.getRouteUnits().size(), 1F);
         for (Entry<String, Collection<RouteUnit>> entry : aggregateRouteUnitGroups(routeContext.getRouteUnits()).entrySet()) {
             Collection<RouteUnit> routeUnits = entry.getValue();
             if (isNeedAggregateRewrite(sqlRewriteContext.getSqlStatementContext(), routeUnits)) {
@@ -111,7 +111,7 @@ public final class RouteSQLRewriteEngine {
     }
     
     private Map<String, Collection<RouteUnit>> aggregateRouteUnitGroups(final Collection<RouteUnit> routeUnits) {
-        Map<String, Collection<RouteUnit>> result = new LinkedHashMap<>(routeUnits.size(), 1);
+        Map<String, Collection<RouteUnit>> result = new LinkedHashMap<>(routeUnits.size(), 1F);
         for (RouteUnit each : routeUnits) {
             String dataSourceName = each.getDataSourceMapper().getActualName();
             result.computeIfAbsent(dataSourceName, unused -> new LinkedList<>()).add(each);
@@ -154,7 +154,7 @@ public final class RouteSQLRewriteEngine {
     }
     
     private Map<RouteUnit, SQLRewriteUnit> translate(final SQLStatement sqlStatement, final Map<RouteUnit, SQLRewriteUnit> sqlRewriteUnits) {
-        Map<RouteUnit, SQLRewriteUnit> result = new LinkedHashMap<>(sqlRewriteUnits.size(), 1);
+        Map<RouteUnit, SQLRewriteUnit> result = new LinkedHashMap<>(sqlRewriteUnits.size(), 1F);
         for (Entry<RouteUnit, SQLRewriteUnit> entry : sqlRewriteUnits.entrySet()) {
             DatabaseType storageType = storageTypes.get(entry.getKey().getDataSourceMapper().getActualName());
             String sql = translatorRule.translate(entry.getValue().getSql(), sqlStatement, protocolType, storageType);
diff --git a/infra/rewrite/src/test/java/org/apache/shardingsphere/infra/rewrite/SQLRewriteEntryTest.java b/infra/rewrite/src/test/java/org/apache/shardingsphere/infra/rewrite/SQLRewriteEntryTest.java
index 9b5efc2f6f4..06426ea03ed 100644
--- a/infra/rewrite/src/test/java/org/apache/shardingsphere/infra/rewrite/SQLRewriteEntryTest.java
+++ b/infra/rewrite/src/test/java/org/apache/shardingsphere/infra/rewrite/SQLRewriteEntryTest.java
@@ -83,7 +83,7 @@ class SQLRewriteEntryTest {
     
     private ShardingSphereResourceMetaData mockResource() {
         ShardingSphereResourceMetaData result = mock(ShardingSphereResourceMetaData.class);
-        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(2, 1);
+        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(2, 1F);
         databaseTypes.put("ds_0", new H2DatabaseType());
         databaseTypes.put("ds_1", new MySQLDatabaseType());
         when(result.getStorageTypes()).thenReturn(databaseTypes);
diff --git a/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteContext.java b/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteContext.java
index ce6dc622989..a007c2cc63e 100644
--- a/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteContext.java
+++ b/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteContext.java
@@ -60,7 +60,7 @@ public final class RouteContext {
      * @return actual data source names
      */
     public Collection<String> getActualDataSourceNames() {
-        return routeUnits.stream().map(each -> each.getDataSourceMapper().getActualName()).collect(Collectors.toCollection(() -> new HashSet<>(routeUnits.size(), 1)));
+        return routeUnits.stream().map(each -> each.getDataSourceMapper().getActualName()).collect(Collectors.toCollection(() -> new HashSet<>(routeUnits.size(), 1L)));
     }
     
     /**
@@ -95,7 +95,7 @@ public final class RouteContext {
      * @return map relationship between data source and logic tables
      */
     public Map<String, Set<String>> getDataSourceLogicTablesMap(final Collection<String> actualDataSourceNames) {
-        Map<String, Set<String>> result = new HashMap<>(actualDataSourceNames.size(), 1);
+        Map<String, Set<String>> result = new HashMap<>(actualDataSourceNames.size(), 1F);
         for (String each : actualDataSourceNames) {
             Set<String> logicTableNames = getLogicTableNames(each);
             if (!logicTableNames.isEmpty()) {
diff --git a/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteUnit.java b/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteUnit.java
index 984c8d97ee7..f16d01fe8ec 100644
--- a/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteUnit.java
+++ b/infra/route/src/main/java/org/apache/shardingsphere/infra/route/context/RouteUnit.java
@@ -47,7 +47,7 @@ public final class RouteUnit {
      * @return logic table names
      */
     public Set<String> getLogicTableNames() {
-        return tableMappers.stream().map(RouteMapper::getLogicName).collect(Collectors.toCollection(() -> new HashSet<>(tableMappers.size(), 1)));
+        return tableMappers.stream().map(RouteMapper::getLogicName).collect(Collectors.toCollection(() -> new HashSet<>(tableMappers.size(), 1L)));
     }
     
     /**
diff --git a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/props/TypedProperties.java b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/props/TypedProperties.java
index b07201dc259..600a3aa7cfe 100644
--- a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/props/TypedProperties.java
+++ b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/props/TypedProperties.java
@@ -46,7 +46,7 @@ public abstract class TypedProperties<E extends Enum<?> & TypedPropertyKey> {
     
     private Map<E, TypedPropertyValue> preload(final Class<E> keyClass) {
         E[] enumConstants = keyClass.getEnumConstants();
-        Map<E, TypedPropertyValue> result = new HashMap<>(enumConstants.length, 1);
+        Map<E, TypedPropertyValue> result = new HashMap<>(enumConstants.length, 1F);
         Collection<String> errorMessages = new LinkedList<>();
         for (E each : enumConstants) {
             TypedPropertyValue value = null;
diff --git a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/OrderedSPILoader.java b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/OrderedSPILoader.java
index 5450c4db08f..5fe743a3679 100644
--- a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/OrderedSPILoader.java
+++ b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/OrderedSPILoader.java
@@ -46,7 +46,7 @@ public final class OrderedSPILoader {
      */
     public static <T extends OrderedSPI<?>> Map<Class<?>, T> getServicesByClass(final Class<T> spiClass, final Collection<Class<?>> types) {
         Collection<T> services = getServices(spiClass);
-        Map<Class<?>, T> result = new LinkedHashMap<>(services.size(), 1);
+        Map<Class<?>, T> result = new LinkedHashMap<>(services.size(), 1F);
         for (T each : services) {
             types.stream().filter(type -> each.getTypeClass() == type).forEach(type -> result.put(type, each));
         }
@@ -83,7 +83,7 @@ public final class OrderedSPILoader {
             return cachedServices.get();
         }
         Collection<V> services = getServices(spiClass, orderComparator);
-        Map<K, V> result = new LinkedHashMap<>(services.size(), 1);
+        Map<K, V> result = new LinkedHashMap<>(services.size(), 1F);
         for (V each : services) {
             types.stream().filter(type -> each.getTypeClass() == type.getClass()).forEach(type -> result.put(type, each));
         }
diff --git a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCache.java b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCache.java
index d603a4972b1..45476edfe9b 100644
--- a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCache.java
+++ b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCache.java
@@ -34,7 +34,7 @@ import java.util.concurrent.ConcurrentHashMap;
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
 public final class OrderedServicesCache {
     
-    private static volatile SoftReference<Map<Key, Map<?, ?>>> cache = new SoftReference<>(new ConcurrentHashMap<>(128));
+    private static volatile SoftReference<Map<Key, Map<?, ?>>> cache = new SoftReference<>(new ConcurrentHashMap<>(128, 1F));
     
     /**
      * Find cached services.
@@ -60,7 +60,7 @@ public final class OrderedServicesCache {
             synchronized (OrderedServicesCache.class) {
                 cache = OrderedServicesCache.cache.get();
                 if (null == cache) {
-                    cache = new ConcurrentHashMap<>(128);
+                    cache = new ConcurrentHashMap<>(128, 1F);
                     OrderedServicesCache.cache = new SoftReference<>(cache);
                 }
             }
diff --git a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenter.java b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenter.java
index 51524a42a95..33398cebec3 100644
--- a/infra/util/src/main/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenter.java
+++ b/infra/util/src/main/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenter.java
@@ -59,7 +59,7 @@ public final class ShardingSphereYamlRepresenter extends Representer {
     @SuppressWarnings({"rawtypes", "unchecked"})
     @Override
     protected Node representMapping(final Tag tag, final Map<?, ?> mapping, final DumperOptions.FlowStyle flowStyle) {
-        Map skippedEmptyValuesMapping = new LinkedHashMap<>(mapping.size(), 1);
+        Map skippedEmptyValuesMapping = new LinkedHashMap<>(mapping.size(), 1F);
         for (Entry<?, ?> entry : mapping.entrySet()) {
             if (entry.getValue() instanceof Collection && ((Collection) entry.getValue()).isEmpty()) {
                 continue;
diff --git a/infra/util/src/test/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCacheTest.java b/infra/util/src/test/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCacheTest.java
index f1dd2b5e7d1..81b58dac6f2 100644
--- a/infra/util/src/test/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCacheTest.java
+++ b/infra/util/src/test/java/org/apache/shardingsphere/infra/util/spi/type/ordered/cache/OrderedServicesCacheTest.java
@@ -50,7 +50,7 @@ class OrderedServicesCacheTest {
         OrderedInterfaceFixture orderedInterfaceFixture = new OrderedInterfaceFixtureImpl();
         Collection<OrderedInterfaceFixture> customInterfaces = Collections.singleton(orderedInterfaceFixture);
         OrderedSPIFixture<?> cacheOrderedSPIFixture = new OrderedSPIFixtureImpl();
-        Map<OrderedInterfaceFixture, OrderedSPIFixture<?>> cachedOrderedServices = new LinkedHashMap<>(customInterfaces.size(), 1);
+        Map<OrderedInterfaceFixture, OrderedSPIFixture<?>> cachedOrderedServices = new LinkedHashMap<>(customInterfaces.size(), 1F);
         cachedOrderedServices.put(orderedInterfaceFixture, cacheOrderedSPIFixture);
         OrderedServicesCache.cacheServices(OrderedSPIFixture.class, customInterfaces, cachedOrderedServices);
         Optional<Map<?, ?>> actual = OrderedServicesCache.findCachedServices(OrderedSPIFixture.class, customInterfaces);
diff --git a/infra/util/src/test/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenterTest.java b/infra/util/src/test/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenterTest.java
index 25f2ba692ee..2048854884d 100644
--- a/infra/util/src/test/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenterTest.java
+++ b/infra/util/src/test/java/org/apache/shardingsphere/infra/util/yaml/representer/ShardingSphereYamlRepresenterTest.java
@@ -45,7 +45,7 @@ class ShardingSphereYamlRepresenterTest {
         YamlConfigurationFixture actual = new YamlConfigurationFixture();
         actual.setValue("value");
         actual.setCollection(Arrays.asList("value1", "value2"));
-        Map<String, String> map = new LinkedHashMap<>(2, 1);
+        Map<String, String> map = new LinkedHashMap<>(2, 1F);
         map.put("key1", "value1");
         map.put("key2", "value2");
         actual.setMap(map);
diff --git a/jdbc/core/src/main/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtils.java b/jdbc/core/src/main/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtils.java
index 1300ae8efc0..ef2bb8b1077 100644
--- a/jdbc/core/src/main/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtils.java
+++ b/jdbc/core/src/main/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtils.java
@@ -57,7 +57,7 @@ public final class ShardingSphereResultSetUtils {
     
     private static Map<String, Integer> createColumnLabelAndIndexMapWithExpandProjections(final SelectStatementContext statementContext) {
         List<Projection> actualProjections = statementContext.getProjectionsContext().getExpandProjections();
-        Map<String, Integer> result = new CaseInsensitiveMap<>(actualProjections.size(), 1);
+        Map<String, Integer> result = new CaseInsensitiveMap<>(actualProjections.size(), 1F);
         for (int columnIndex = actualProjections.size(); columnIndex > 0; columnIndex--) {
             Projection projection = actualProjections.get(columnIndex - 1);
             result.put(DerivedColumn.isDerivedColumnName(projection.getColumnLabel()) ? projection.getExpression() : projection.getColumnLabel(), columnIndex);
diff --git a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/api/yaml/YamlShardingSphereDataSourceFactoryTest.java b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/api/yaml/YamlShardingSphereDataSourceFactoryTest.java
index c907263b528..7ce4af8f42f 100644
--- a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/api/yaml/YamlShardingSphereDataSourceFactoryTest.java
+++ b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/api/yaml/YamlShardingSphereDataSourceFactoryTest.java
@@ -51,7 +51,7 @@ class YamlShardingSphereDataSourceFactoryTest {
     
     @Test
     void assertCreateDataSourceWithFileForExternalDataSources() throws Exception {
-        Map<String, DataSource> dataSourceMap = new HashMap<>(2, 1);
+        Map<String, DataSource> dataSourceMap = new HashMap<>(2, 1F);
         dataSourceMap.put("ds_0", new MockedDataSource());
         dataSourceMap.put("ds_1", new MockedDataSource());
         assertDataSource(YamlShardingSphereDataSourceFactory.createDataSource(dataSourceMap, new File(getYamlFileUrl().toURI())));
@@ -64,7 +64,7 @@ class YamlShardingSphereDataSourceFactoryTest {
     
     @Test
     void assertCreateDataSourceWithBytesForExternalDataSources() throws Exception {
-        Map<String, DataSource> dataSourceMap = new HashMap<>(2, 1);
+        Map<String, DataSource> dataSourceMap = new HashMap<>(2, 1F);
         dataSourceMap.put("ds_0", new MockedDataSource());
         dataSourceMap.put("ds_1", new MockedDataSource());
         assertDataSource(YamlShardingSphereDataSourceFactory.createDataSource(dataSourceMap, readFile(getYamlFileUrl()).getBytes()));
diff --git a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/executor/batch/BatchPreparedStatementExecutorTest.java b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/executor/batch/BatchPreparedStatementExecutorTest.java
index 36554312668..1a5a5f973eb 100644
--- a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/executor/batch/BatchPreparedStatementExecutorTest.java
+++ b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/executor/batch/BatchPreparedStatementExecutorTest.java
@@ -126,7 +126,7 @@ class BatchPreparedStatementExecutorTest {
     }
     
     private Map<String, DataSource> mockDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         DataSource dataSource = mock(DataSource.class, RETURNS_DEEP_STUBS);
         result.put("ds_0", dataSource);
         result.put("ds_1", dataSource);
diff --git a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/connection/DriverDatabaseConnectionManagerTest.java b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/connection/DriverDatabaseConnectionManagerTest.java
index 3d610872c56..796bfa19d64 100644
--- a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/connection/DriverDatabaseConnectionManagerTest.java
+++ b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/connection/DriverDatabaseConnectionManagerTest.java
@@ -87,7 +87,7 @@ class DriverDatabaseConnectionManagerTest {
     }
     
     private Map<String, DataSource> mockDataSourceMap() throws SQLException {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         result.put("ds", new MockedDataSource());
         DataSource invalidDataSource = mock(DataSource.class);
         when(invalidDataSource.getConnection()).thenThrow(new SQLException());
@@ -104,7 +104,7 @@ class DriverDatabaseConnectionManagerTest {
     }
     
     private Map<String, Object> createProperties() {
-        Map<String, Object> result = new LinkedHashMap<>(3, 1);
+        Map<String, Object> result = new LinkedHashMap<>(3, 1F);
         result.put("jdbcUrl", "jdbc:mysql://127.0.0.1:3306/demo_ds_0?serverTimezone=UTC&useSSL=false");
         result.put("username", "root");
         result.put("password", "123456");
diff --git a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtilsTest.java b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtilsTest.java
index 48589237eed..4e41f49f4f4 100644
--- a/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtilsTest.java
+++ b/jdbc/core/src/test/java/org/apache/shardingsphere/driver/jdbc/core/resultset/ShardingSphereResultSetUtilsTest.java
@@ -56,7 +56,7 @@ class ShardingSphereResultSetUtilsTest {
         projections.add(new ColumnProjection(null, "col1", null));
         projections.add(new ColumnProjection(null, "col2", null));
         when(selectStatementContext.getProjectionsContext()).thenReturn(new ProjectionsContext(0, 0, false, projections));
-        Map<String, Integer> expected = new HashMap<>(2, 1);
+        Map<String, Integer> expected = new HashMap<>(2, 1F);
         expected.put("col1", 1);
         expected.put("col2", 2);
         Map<String, Integer> actual = ShardingSphereResultSetUtils.createColumnLabelAndIndexMap(selectStatementContext, null);
diff --git a/kernel/authority/core/src/main/java/org/apache/shardingsphere/authority/provider/database/builder/DatabasePrivilegeBuilder.java b/kernel/authority/core/src/main/java/org/apache/shardingsphere/authority/provider/database/builder/DatabasePrivilegeBuilder.java
index b0edac23873..89e7bf95d6a 100644
--- a/kernel/authority/core/src/main/java/org/apache/shardingsphere/authority/provider/database/builder/DatabasePrivilegeBuilder.java
+++ b/kernel/authority/core/src/main/java/org/apache/shardingsphere/authority/provider/database/builder/DatabasePrivilegeBuilder.java
@@ -67,7 +67,7 @@ public final class DatabasePrivilegeBuilder {
     
     private static Map<ShardingSphereUser, ShardingSpherePrivileges> buildPrivileges(final Collection<ShardingSphereUser> users, final String mappingProp) {
         Map<ShardingSphereUser, Collection<String>> userDatabaseMappings = convertDatabases(mappingProp);
-        Map<ShardingSphereUser, ShardingSpherePrivileges> result = new HashMap<>(users.size(), 1);
+        Map<ShardingSphereUser, ShardingSpherePrivileges> result = new HashMap<>(users.size(), 1F);
         users.forEach(each -> result.put(each, new DatabasePermittedPrivileges(new HashSet<>(getUserDatabases(each, userDatabaseMappings)))));
         return result;
     }
@@ -80,7 +80,7 @@ public final class DatabasePrivilegeBuilder {
      */
     private static Map<ShardingSphereUser, Collection<String>> convertDatabases(final String mappingProp) {
         String[] mappings = mappingProp.split(",");
-        Map<ShardingSphereUser, Collection<String>> result = new HashMap<>(mappings.length, 1);
+        Map<ShardingSphereUser, Collection<String>> result = new HashMap<>(mappings.length, 1F);
         Arrays.asList(mappings).forEach(each -> {
             String[] userDatabasePair = each.trim().split("=");
             String yamlUser = userDatabasePair[0];
diff --git a/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/config/TableNameSchemaNameMapping.java b/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/config/TableNameSchemaNameMapping.java
index ddea9295808..32dbc1620ef 100644
--- a/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/config/TableNameSchemaNameMapping.java
+++ b/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/config/TableNameSchemaNameMapping.java
@@ -43,7 +43,7 @@ public final class TableNameSchemaNameMapping {
     }
     
     private Map<LogicTableName, String> getLogicTableNameMap(final Map<String, String> tableSchemaMap) {
-        Map<LogicTableName, String> result = new HashMap<>(tableSchemaMap.size(), 1);
+        Map<LogicTableName, String> result = new HashMap<>(tableSchemaMap.size(), 1F);
         for (Entry<String, String> entry : tableSchemaMap.entrySet()) {
             String tableName = entry.getKey();
             String schemaName = entry.getValue();
diff --git a/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/impl/StandardPipelineDataSourceConfiguration.java b/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/impl/StandardPipelineDataSourceConfiguration.java
index 712dd2a2ea2..ed38f1869ed 100644
--- a/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/impl/StandardPipelineDataSourceConfiguration.java
+++ b/kernel/data-pipeline/api/src/main/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/impl/StandardPipelineDataSourceConfiguration.java
@@ -89,7 +89,7 @@ public final class StandardPipelineDataSourceConfiguration implements PipelineDa
     }
     
     private static Map<String, Object> wrapParameter(final String jdbcUrl, final String username, final String password) {
-        Map<String, Object> result = new LinkedHashMap<>(3, 1);
+        Map<String, Object> result = new LinkedHashMap<>(3, 1F);
         // Reference ConnectionPropertySynonyms
         result.put("url", jdbcUrl);
         result.put("username", username);
diff --git a/kernel/data-pipeline/cdc/core/src/test/java/org/apache/shardingsphere/data/pipeline/cdc/util/CDCSchemaTableUtilsTest.java b/kernel/data-pipeline/cdc/core/src/test/java/org/apache/shardingsphere/data/pipeline/cdc/util/CDCSchemaTableUtilsTest.java
index 0572b3577e4..6c7ff11919e 100644
--- a/kernel/data-pipeline/cdc/core/src/test/java/org/apache/shardingsphere/data/pipeline/cdc/util/CDCSchemaTableUtilsTest.java
+++ b/kernel/data-pipeline/cdc/core/src/test/java/org/apache/shardingsphere/data/pipeline/cdc/util/CDCSchemaTableUtilsTest.java
@@ -65,14 +65,14 @@ class CDCSchemaTableUtilsTest {
     }
     
     private ShardingSphereSchema mockedPublicSchema() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1F);
         tables.put("t_order", mock(ShardingSphereTable.class));
         tables.put("t_order2", mock(ShardingSphereTable.class));
         return new ShardingSphereSchema(tables, Collections.emptyMap());
     }
     
     private ShardingSphereSchema mockedTestSchema() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1F);
         tables.put("t_order_item", mock(ShardingSphereTable.class));
         tables.put("t_order_item2", mock(ShardingSphereTable.class));
         return new ShardingSphereSchema(tables, Collections.emptyMap());
diff --git a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/GovernanceRepositoryAPIImpl.java b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/GovernanceRepositoryAPIImpl.java
index 9f371b64e5c..a353fa34688 100644
--- a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/GovernanceRepositoryAPIImpl.java
+++ b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/GovernanceRepositoryAPIImpl.java
@@ -101,7 +101,7 @@ public final class GovernanceRepositoryAPIImpl implements GovernanceRepositoryAP
         }
         YamlDataConsistencyCheckResultSwapper swapper = new YamlDataConsistencyCheckResultSwapper();
         Map<String, String> yamlCheckResultMap = YamlEngine.unmarshal(yamlCheckResultMapText, Map.class, true);
-        Map<String, DataConsistencyCheckResult> result = new HashMap<>(yamlCheckResultMap.size(), 1);
+        Map<String, DataConsistencyCheckResult> result = new HashMap<>(yamlCheckResultMap.size(), 1F);
         for (Entry<String, String> entry : yamlCheckResultMap.entrySet()) {
             result.put(entry.getKey(), swapper.swapToObject(entry.getValue()));
         }
diff --git a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/PipelineDataSourcePersistService.java b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/PipelineDataSourcePersistService.java
index 67d7d62e838..d46eed8ba58 100644
--- a/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/PipelineDataSourcePersistService.java
+++ b/kernel/data-pipeline/core/src/main/java/org/apache/shardingsphere/data/pipeline/core/api/impl/PipelineDataSourcePersistService.java
@@ -46,14 +46,14 @@ public final class PipelineDataSourcePersistService implements PipelineMetaDataP
             return Collections.emptyMap();
         }
         Map<String, Map<String, Object>> yamlDataSources = YamlEngine.unmarshal(dataSourcesProps, Map.class);
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(yamlDataSources.size());
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(yamlDataSources.size(), 1F);
         yamlDataSources.forEach((key, value) -> result.put(key, swapper.swapToDataSourceProperties(value)));
         return result;
     }
     
     @Override
     public void persist(final PipelineContextKey contextKey, final JobType jobType, final Map<String, DataSourceProperties> dataSourcePropsMap) {
-        Map<String, Map<String, Object>> dataSourceMap = new LinkedHashMap<>(dataSourcePropsMap.size());
+        Map<String, Map<String, Object>> dataSourceMap = new LinkedHashMap<>(dataSourcePropsMap.size(), 1F);
         for (Entry<String, DataSourceProperties> entry : dataSourcePropsMap.entrySet()) {
             dataSourceMap.put(entry.getKey(), swapper.swapToMap(entry.getValue()));
         }
diff --git a/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/yaml/YamlJdbcConfigurationTest.java b/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/yaml/YamlJdbcConfigurationTest.java
index 69d2ee46557..83dca0d0ab4 100644
--- a/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/yaml/YamlJdbcConfigurationTest.java
+++ b/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/api/datasource/config/yaml/YamlJdbcConfigurationTest.java
@@ -40,7 +40,7 @@ class YamlJdbcConfigurationTest {
     }
     
     private Map<String, String> getDataSourcePropsWithUrl() {
-        Map<String, String> result = new HashMap<>(3, 1);
+        Map<String, String> result = new HashMap<>(3, 1F);
         result.put("url", JDBC_URL);
         result.put("username", USERNAME);
         result.put("password", PASSWORD);
diff --git a/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/core/datasource/PipelineDataSourceFactoryTest.java b/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/core/datasource/PipelineDataSourceFactoryTest.java
index 11746c3caec..51427d78ddf 100644
--- a/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/core/datasource/PipelineDataSourceFactoryTest.java
+++ b/kernel/data-pipeline/core/src/test/java/org/apache/shardingsphere/data/pipeline/core/datasource/PipelineDataSourceFactoryTest.java
@@ -31,7 +31,7 @@ class PipelineDataSourceFactoryTest {
     
     @Test
     void assertNewInstance() {
-        Map<String, Object> yamlDataSourceConfig = new HashMap<>(3, 1);
+        Map<String, Object> yamlDataSourceConfig = new HashMap<>(3, 1F);
         yamlDataSourceConfig.put("url", "jdbc:mysql://localhost:3306/database");
         yamlDataSourceConfig.put("username", "username");
         yamlDataSourceConfig.put("password", "password");
diff --git a/kernel/data-pipeline/dialect/mysql/src/main/java/org/apache/shardingsphere/data/pipeline/mysql/check/datasource/MySQLDataSourceChecker.java b/kernel/data-pipeline/dialect/mysql/src/main/java/org/apache/shardingsphere/data/pipeline/mysql/check/datasource/MySQLDataSourceChecker.java
index b40eecd350a..a1c7d855a03 100644
--- a/kernel/data-pipeline/dialect/mysql/src/main/java/org/apache/shardingsphere/data/pipeline/mysql/check/datasource/MySQLDataSourceChecker.java
+++ b/kernel/data-pipeline/dialect/mysql/src/main/java/org/apache/shardingsphere/data/pipeline/mysql/check/datasource/MySQLDataSourceChecker.java
@@ -44,7 +44,7 @@ public final class MySQLDataSourceChecker extends AbstractDataSourceChecker {
     
     private static final String[][] REQUIRED_PRIVILEGES = {{"ALL PRIVILEGES", "ON *.*"}, {"REPLICATION SLAVE", "REPLICATION CLIENT", "ON *.*"}};
     
-    private static final Map<String, String> REQUIRED_VARIABLES = new HashMap<>(3, 1);
+    private static final Map<String, String> REQUIRED_VARIABLES = new HashMap<>(3, 1F);
     
     private static final String SHOW_VARIABLES_SQL;
     
diff --git a/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/api/impl/MigrationJobAPI.java b/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/api/impl/MigrationJobAPI.java
index bf95b49d6f6..a2d5b43ef1b 100644
--- a/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/api/impl/MigrationJobAPI.java
+++ b/kernel/data-pipeline/scenario/migration/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/migration/api/impl/MigrationJobAPI.java
@@ -434,7 +434,7 @@ public final class MigrationJobAPI extends AbstractInventoryIncrementalJobAPIImp
      */
     public void addMigrationSourceResources(final PipelineContextKey contextKey, final Map<String, DataSourceProperties> dataSourcePropsMap) {
         Map<String, DataSourceProperties> existDataSources = dataSourcePersistService.load(contextKey, getJobType());
-        Collection<String> duplicateDataSourceNames = new HashSet<>(dataSourcePropsMap.size(), 1);
+        Collection<String> duplicateDataSourceNames = new HashSet<>(dataSourcePropsMap.size(), 1F);
         for (Entry<String, DataSourceProperties> entry : dataSourcePropsMap.entrySet()) {
             if (existDataSources.containsKey(entry.getKey())) {
                 duplicateDataSourceNames.add(entry.getKey());
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/ExternalMetaDataFactory.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/ExternalMetaDataFactory.java
index f4465709690..6ff59711536 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/ExternalMetaDataFactory.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/ExternalMetaDataFactory.java
@@ -48,7 +48,7 @@ public final class ExternalMetaDataFactory {
     
     private static final Collection<String> MOCKED_URL_PREFIXES = new HashSet<>(Arrays.asList("jdbc:fixture", "jdbc:mock"));
     
-    private static final Collection<DatabaseType> SUPPORTED_STORAGE_TYPES = new HashSet<>(8, 1);
+    private static final Collection<DatabaseType> SUPPORTED_STORAGE_TYPES = new HashSet<>(8, 1F);
     
     static {
         Arrays.asList("MySQL", "PostgreSQL", "openGauss", "Oracle", "SQLServer", "H2", "MariaDB")
@@ -83,7 +83,7 @@ public final class ExternalMetaDataFactory {
     public static Map<String, ShardingSphereDatabase> create(final Map<String, DatabaseConfiguration> databaseConfigMap,
                                                              final ConfigurationProperties props, final InstanceContext instanceContext) throws SQLException {
         DatabaseType protocolType = DatabaseTypeEngine.getProtocolType(databaseConfigMap, props);
-        Map<String, ShardingSphereDatabase> result = new ConcurrentHashMap<>(databaseConfigMap.size() + protocolType.getSystemDatabaseSchemaMap().size(), 1);
+        Map<String, ShardingSphereDatabase> result = new ConcurrentHashMap<>(databaseConfigMap.size() + protocolType.getSystemDatabaseSchemaMap().size(), 1F);
         result.putAll(createGenericDatabases(databaseConfigMap, protocolType, props, instanceContext));
         result.putAll(createSystemDatabases(databaseConfigMap, protocolType));
         return result;
@@ -91,7 +91,7 @@ public final class ExternalMetaDataFactory {
     
     private static Map<String, ShardingSphereDatabase> createGenericDatabases(final Map<String, DatabaseConfiguration> databaseConfigMap, final DatabaseType protocolType,
                                                                               final ConfigurationProperties props, final InstanceContext instanceContext) throws SQLException {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(databaseConfigMap.size(), 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(databaseConfigMap.size(), 1F);
         for (Entry<String, DatabaseConfiguration> entry : databaseConfigMap.entrySet()) {
             String databaseName = entry.getKey();
             if (!entry.getValue().getDataSources().isEmpty() || !protocolType.getSystemSchemas().contains(databaseName)) {
@@ -118,7 +118,7 @@ public final class ExternalMetaDataFactory {
     }
     
     private static Map<String, ShardingSphereDatabase> createSystemDatabases(final Map<String, DatabaseConfiguration> databaseConfigMap, final DatabaseType protocolType) {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(protocolType.getSystemDatabaseSchemaMap().size(), 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(protocolType.getSystemDatabaseSchemaMap().size(), 1F);
         for (String each : protocolType.getSystemDatabaseSchemaMap().keySet()) {
             if (!databaseConfigMap.containsKey(each) || databaseConfigMap.get(each).getDataSources().isEmpty()) {
                 result.put(each.toLowerCase(), ShardingSphereDatabase.create(each, protocolType));
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/InternalMetaDataFactory.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/InternalMetaDataFactory.java
index ec4c5cfc502..6cace5b99a9 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/InternalMetaDataFactory.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/InternalMetaDataFactory.java
@@ -70,7 +70,7 @@ public final class InternalMetaDataFactory {
     
     private static Map<String, ShardingSphereDatabase> createDatabases(final MetaDataBasedPersistService persistService, final Map<String, DatabaseConfiguration> databaseConfigMap,
                                                                        final DatabaseType protocolType, final ConfigurationProperties props, final InstanceContext instanceContext) {
-        Map<String, ShardingSphereDatabase> result = new ConcurrentHashMap<>(databaseConfigMap.size(), 1);
+        Map<String, ShardingSphereDatabase> result = new ConcurrentHashMap<>(databaseConfigMap.size(), 1F);
         for (Entry<String, DatabaseConfiguration> entry : databaseConfigMap.entrySet()) {
             String databaseName = entry.getKey();
             if (entry.getValue().getDataSources().isEmpty()) {
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/NewInternalMetaDataFactory.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/NewInternalMetaDataFactory.java
index 4c832a58ca9..81ad2e59a6d 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/NewInternalMetaDataFactory.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/factory/NewInternalMetaDataFactory.java
@@ -71,7 +71,7 @@ public final class NewInternalMetaDataFactory {
     
     private static Map<String, ShardingSphereDatabase> createDatabases(final NewMetaDataPersistService persistService, final Map<String, DatabaseConfiguration> databaseConfigMap,
                                                                        final DatabaseType protocolType, final ConfigurationProperties props, final InstanceContext instanceContext) {
-        Map<String, ShardingSphereDatabase> result = new ConcurrentHashMap<>(databaseConfigMap.size(), 1);
+        Map<String, ShardingSphereDatabase> result = new ConcurrentHashMap<>(databaseConfigMap.size(), 1F);
         for (Entry<String, DatabaseConfiguration> entry : databaseConfigMap.entrySet()) {
             String databaseName = entry.getKey();
             if (entry.getValue().getDataSources().isEmpty()) {
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistService.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistService.java
index ac24302c6e0..73256ad23be 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistService.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistService.java
@@ -107,7 +107,7 @@ public final class MetaDataPersistService implements MetaDataBasedPersistService
     }
     
     private Map<String, DataSourceProperties> getDataSourcePropertiesMap(final Map<String, DataSource> dataSourceMap) {
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(dataSourceMap.size(), 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(dataSourceMap.size(), 1F);
         for (Entry<String, DataSource> entry : dataSourceMap.entrySet()) {
             result.put(entry.getKey(), DataSourcePropertiesCreator.create(entry.getValue()));
         }
@@ -130,7 +130,7 @@ public final class MetaDataPersistService implements MetaDataBasedPersistService
     }
     
     private Map<String, DataSource> mergeEffectiveDataSources(final Map<String, DataSourceProperties> persistedDataSourcePropsMap, final Map<String, DataSource> localConfiguredDataSources) {
-        Map<String, DataSource> result = new LinkedHashMap<>(persistedDataSourcePropsMap.size(), 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(persistedDataSourcePropsMap.size(), 1F);
         for (Entry<String, DataSourceProperties> entry : persistedDataSourcePropsMap.entrySet()) {
             String dataSourceName = entry.getKey();
             DataSourceProperties persistedDataSourceProps = entry.getValue();
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/NewMetaDataPersistService.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/NewMetaDataPersistService.java
index b95ec4b7a74..b731e2e5a27 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/NewMetaDataPersistService.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/NewMetaDataPersistService.java
@@ -109,7 +109,7 @@ public final class NewMetaDataPersistService implements MetaDataBasedPersistServ
     }
     
     private Map<String, DataSourceProperties> getDataSourcePropertiesMap(final Map<String, DataSource> dataSourceMap) {
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(dataSourceMap.size(), 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(dataSourceMap.size(), 1F);
         for (Entry<String, DataSource> entry : dataSourceMap.entrySet()) {
             result.put(entry.getKey(), DataSourcePropertiesCreator.create(entry.getValue()));
         }
@@ -132,7 +132,7 @@ public final class NewMetaDataPersistService implements MetaDataBasedPersistServ
     }
     
     private Map<String, DataSource> mergeEffectiveDataSources(final Map<String, DataSourceProperties> persistedDataSourcePropsMap, final Map<String, DataSource> localConfiguredDataSources) {
-        Map<String, DataSource> result = new LinkedHashMap<>(persistedDataSourcePropsMap.size(), 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(persistedDataSourcePropsMap.size(), 1F);
         for (Entry<String, DataSourceProperties> entry : persistedDataSourcePropsMap.entrySet()) {
             String dataSourceName = entry.getKey();
             DataSourceProperties persistedDataSourceProps = entry.getValue();
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/database/DatabaseMetaDataPersistService.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/database/DatabaseMetaDataPersistService.java
index d6843448c28..2e30ecf8dac 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/database/DatabaseMetaDataPersistService.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/database/DatabaseMetaDataPersistService.java
@@ -153,7 +153,7 @@ public final class DatabaseMetaDataPersistService implements DatabaseMetaDataBas
     @Override
     public Map<String, ShardingSphereSchema> loadSchemas(final String databaseName) {
         Collection<String> schemaNames = loadAllSchemaNames(databaseName);
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(schemaNames.size(), 1);
+        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(schemaNames.size(), 1F);
         schemaNames.forEach(each -> result.put(each.toLowerCase(),
                 new ShardingSphereSchema(tableMetaDataPersistService.load(databaseName, each), viewMetaDataPersistService.load(databaseName, each))));
         return result;
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/TableMetaDataPersistService.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/TableMetaDataPersistService.java
index 9b5f30b5189..0216deb6932 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/TableMetaDataPersistService.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/TableMetaDataPersistService.java
@@ -57,7 +57,7 @@ public final class TableMetaDataPersistService implements SchemaMetaDataPersistS
     }
     
     private Map<String, ShardingSphereTable> getTableMetaDataByTableNames(final String databaseName, final String schemaName, final Collection<String> tableNames) {
-        Map<String, ShardingSphereTable> result = new LinkedHashMap<>(tableNames.size(), 1);
+        Map<String, ShardingSphereTable> result = new LinkedHashMap<>(tableNames.size(), 1F);
         tableNames.forEach(each -> {
             String table = repository.getDirectly(DatabaseMetaDataNode.getTableMetaDataPath(databaseName, schemaName, each));
             if (!Strings.isNullOrEmpty(table)) {
diff --git a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/ViewMetaDataPersistService.java b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/ViewMetaDataPersistService.java
index ea563998c7a..c0c02d217d7 100644
--- a/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/ViewMetaDataPersistService.java
+++ b/kernel/metadata/core/src/main/java/org/apache/shardingsphere/metadata/persist/service/schema/ViewMetaDataPersistService.java
@@ -57,7 +57,7 @@ public final class ViewMetaDataPersistService implements SchemaMetaDataPersistSe
     }
     
     private Map<String, ShardingSphereView> getViewMetaDataByViewNames(final String databaseName, final String schemaName, final Collection<String> viewNames) {
-        Map<String, ShardingSphereView> result = new LinkedHashMap<>(viewNames.size(), 1);
+        Map<String, ShardingSphereView> result = new LinkedHashMap<>(viewNames.size(), 1F);
         viewNames.forEach(each -> {
             String view = repository.getDirectly(DatabaseMetaDataNode.getViewMetaDataPath(databaseName, schemaName, each));
             if (!Strings.isNullOrEmpty(view)) {
diff --git a/kernel/metadata/core/src/test/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistServiceTest.java b/kernel/metadata/core/src/test/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistServiceTest.java
index e816573b34f..d00a1e30d0d 100644
--- a/kernel/metadata/core/src/test/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistServiceTest.java
+++ b/kernel/metadata/core/src/test/java/org/apache/shardingsphere/metadata/persist/MetaDataPersistServiceTest.java
@@ -93,7 +93,7 @@ class MetaDataPersistServiceTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("ds_0", createDataSource("ds_0"));
         result.put("ds_1", createDataSource("ds_1"));
         return result;
diff --git a/kernel/single/core/src/main/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoader.java b/kernel/single/core/src/main/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoader.java
index 747e2af9a7c..65a6b2624ff 100644
--- a/kernel/single/core/src/main/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoader.java
+++ b/kernel/single/core/src/main/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoader.java
@@ -56,7 +56,7 @@ public final class SingleTableDataNodeLoader {
             Map<String, Collection<DataNode>> dataNodeMap = load(databaseName, databaseType, entry.getKey(), entry.getValue(), excludedTables);
             for (Entry<String, Collection<DataNode>> each : dataNodeMap.entrySet()) {
                 Collection<DataNode> addedDataNodes = each.getValue();
-                Collection<DataNode> existDataNodes = result.getOrDefault(each.getKey().toLowerCase(), new LinkedHashSet<>(addedDataNodes.size(), 1));
+                Collection<DataNode> existDataNodes = result.getOrDefault(each.getKey().toLowerCase(), new LinkedHashSet<>(addedDataNodes.size(), 1F));
                 existDataNodes.addAll(addedDataNodes);
                 result.putIfAbsent(each.getKey().toLowerCase(), existDataNodes);
             }
diff --git a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoaderTest.java b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoaderTest.java
index 9493efbe405..e9e2340f1b5 100644
--- a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoaderTest.java
+++ b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/datanode/SingleTableDataNodeLoaderTest.java
@@ -60,7 +60,7 @@ class SingleTableDataNodeLoaderTest {
     
     @BeforeEach
     void setUp() throws SQLException {
-        dataSourceMap = new LinkedHashMap<>(2, 1);
+        dataSourceMap = new LinkedHashMap<>(2, 1F);
         dataSourceMap.put("ds0", mockDataSource("ds0", Arrays.asList("employee", "dept", "salary")));
         dataSourceMap.put("ds1", mockDataSource("ds1", Arrays.asList("student", "teacher", "class", "salary")));
     }
diff --git a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/SingleSQLRouterTest.java b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/SingleSQLRouterTest.java
index af74accef8f..23c1b003f6a 100644
--- a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/SingleSQLRouterTest.java
+++ b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/SingleSQLRouterTest.java
@@ -122,7 +122,7 @@ class SingleSQLRouterTest {
     }
     
     private Map<String, DataSource> createMultiDataSourceMap() throws SQLException {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         Connection connection = mockConnection();
         result.put("ds_0", new MockedDataSource(connection));
         result.put("ds_1", new MockedDataSource(connection));
@@ -143,7 +143,7 @@ class SingleSQLRouterTest {
     
     private ShardingSphereDatabase mockDatabaseWithMultipleResources() {
         ShardingSphereDatabase result = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
-        Map<String, DataSource> dataSourceMap = new HashMap<>(2, 1);
+        Map<String, DataSource> dataSourceMap = new HashMap<>(2, 1F);
         dataSourceMap.put("ds_0", new MockedDataSource());
         dataSourceMap.put("ds_1", new MockedDataSource());
         when(result.getResourceMetaData().getDataSources()).thenReturn(dataSourceMap);
diff --git a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleDatabaseBroadcastRouteEngineTest.java b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleDatabaseBroadcastRouteEngineTest.java
index 585b6b0e0c7..a6b62c37ad1 100644
--- a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleDatabaseBroadcastRouteEngineTest.java
+++ b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleDatabaseBroadcastRouteEngineTest.java
@@ -58,7 +58,7 @@ class SingleDatabaseBroadcastRouteEngineTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() throws SQLException {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         Connection connection = mock(Connection.class, RETURNS_DEEP_STUBS);
         when(connection.getMetaData().getURL()).thenReturn("jdbc:h2:mem:db");
         result.put("ds_0", new MockedDataSource(connection));
diff --git a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleStandardRouteEngineTest.java b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleStandardRouteEngineTest.java
index 84a430ddded..e319f338879 100644
--- a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleStandardRouteEngineTest.java
+++ b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/route/engine/SingleStandardRouteEngineTest.java
@@ -120,7 +120,7 @@ class SingleStandardRouteEngineTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() throws SQLException {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         Connection connection = mock(Connection.class, RETURNS_DEEP_STUBS);
         when(connection.getMetaData().getURL()).thenReturn("jdbc:h2:mem:db");
         result.put("ds_0", new MockedDataSource(connection));
diff --git a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/rule/SingleRuleTest.java b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/rule/SingleRuleTest.java
index 6ecef8f066e..27de1fbc8c8 100644
--- a/kernel/single/core/src/test/java/org/apache/shardingsphere/single/rule/SingleRuleTest.java
+++ b/kernel/single/core/src/test/java/org/apache/shardingsphere/single/rule/SingleRuleTest.java
@@ -66,7 +66,7 @@ class SingleRuleTest {
     
     @BeforeEach
     void setUp() throws SQLException {
-        dataSourceMap = new LinkedHashMap<>(2, 1);
+        dataSourceMap = new LinkedHashMap<>(2, 1F);
         dataSourceMap.put("foo_ds", mockDataSource("foo_ds", Arrays.asList("employee", "t_order_0")));
         dataSourceMap.put("bar_ds", mockDataSource("bar_ds", Arrays.asList("student", "t_order_1")));
     }
diff --git a/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutor.java b/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutor.java
index 857e3b253ea..caa87686b16 100644
--- a/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutor.java
+++ b/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutor.java
@@ -116,7 +116,7 @@ public final class AdvancedSQLFederationExecutor implements SQLFederationExecuto
     }
     
     private Map<String, Object> createParameters(final List<Object> params) {
-        Map<String, Object> result = new HashMap<>(params.size(), 1);
+        Map<String, Object> result = new HashMap<>(params.size(), 1F);
         int index = 0;
         for (Object each : params) {
             result.put("?" + index++, each);
diff --git a/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/resultset/SQLFederationResultSet.java b/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/resultset/SQLFederationResultSet.java
index 18bf1ca94e0..3fa7a90366d 100644
--- a/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/resultset/SQLFederationResultSet.java
+++ b/kernel/sql-federation/executor/advanced/src/main/java/org/apache/shardingsphere/sqlfederation/advanced/resultset/SQLFederationResultSet.java
@@ -77,8 +77,8 @@ public final class SQLFederationResultSet extends AbstractUnsupportedOperationRe
     public SQLFederationResultSet(final Enumerator<Object> enumerator, final ShardingSphereSchema schema, final AbstractSchema filterableSchema,
                                   final SelectStatementContext selectStatementContext, final RelDataType validatedNodeType) {
         this.enumerator = enumerator;
-        columnLabelAndIndexes = new HashMap<>(selectStatementContext.getProjectionsContext().getExpandProjections().size(), 1);
-        Map<Integer, String> indexAndColumnLabels = new HashMap<>(selectStatementContext.getProjectionsContext().getExpandProjections().size(), 1);
+        columnLabelAndIndexes = new HashMap<>(selectStatementContext.getProjectionsContext().getExpandProjections().size(), 1F);
+        Map<Integer, String> indexAndColumnLabels = new HashMap<>(selectStatementContext.getProjectionsContext().getExpandProjections().size(), 1F);
         handleColumnLabelAndIndex(columnLabelAndIndexes, indexAndColumnLabels, selectStatementContext);
         resultSetMetaData = new SQLFederationResultSetMetaData(schema, filterableSchema, selectStatementContext, validatedNodeType, indexAndColumnLabels);
     }
diff --git a/kernel/sql-federation/executor/advanced/src/test/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutorTest.java b/kernel/sql-federation/executor/advanced/src/test/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutorTest.java
index 2ff3de6126a..ded974c29a3 100644
--- a/kernel/sql-federation/executor/advanced/src/test/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutorTest.java
+++ b/kernel/sql-federation/executor/advanced/src/test/java/org/apache/shardingsphere/sqlfederation/advanced/AdvancedSQLFederationExecutorTest.java
@@ -47,7 +47,7 @@ class AdvancedSQLFederationExecutorTest {
     
     @BeforeEach
     void init() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(2, 1F);
         tables.put("t_order_federate", createOrderTableMetaData());
         tables.put("t_user_info", createUserInfoTableMetaData());
         String schemaName = "federate_jdbc";
diff --git a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/context/planner/OptimizerPlannerContextFactory.java b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/context/planner/OptimizerPlannerContextFactory.java
index 5eb6b1c6070..14edf5adf45 100644
--- a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/context/planner/OptimizerPlannerContextFactory.java
+++ b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/context/planner/OptimizerPlannerContextFactory.java
@@ -39,7 +39,7 @@ public final class OptimizerPlannerContextFactory {
      * @return created optimizer planner context map
      */
     public static Map<String, OptimizerPlannerContext> create(final Map<String, ShardingSphereDatabase> databases) {
-        Map<String, OptimizerPlannerContext> result = new ConcurrentHashMap<>(databases.size(), 1);
+        Map<String, OptimizerPlannerContext> result = new ConcurrentHashMap<>(databases.size(), 1F);
         for (Entry<String, ShardingSphereDatabase> entry : databases.entrySet()) {
             result.put(entry.getKey(), new OptimizerPlannerContext(SQLFederationPlannerUtils.createHepPlanner()));
         }
diff --git a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/converter/segment/expression/impl/LiteralExpressionConverter.java b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/converter/segment/expression/impl/LiteralExpressionConverter.java
index cc20b61ba5c..1c5ac07902c 100644
--- a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/converter/segment/expression/impl/LiteralExpressionConverter.java
+++ b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/converter/segment/expression/impl/LiteralExpressionConverter.java
@@ -36,9 +36,9 @@ import java.util.Optional;
  */
 public final class LiteralExpressionConverter implements SQLSegmentConverter<LiteralExpressionSegment, SqlNode> {
     
-    private static final Collection<String> TRIM_FUNCTION_FLAGS = new HashSet<>(3, 1);
+    private static final Collection<String> TRIM_FUNCTION_FLAGS = new HashSet<>(3, 1F);
     
-    private static final Collection<String> TIME_UNIT_NAMES = new HashSet<>(6, 1);
+    private static final Collection<String> TIME_UNIT_NAMES = new HashSet<>(6, 1F);
     
     static {
         TRIM_FUNCTION_FLAGS.add("BOTH");
diff --git a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableDatabase.java b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableDatabase.java
index fced1cf0cef..79cf9ae515d 100644
--- a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableDatabase.java
+++ b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableDatabase.java
@@ -45,7 +45,7 @@ public final class FilterableDatabase extends AbstractSchema {
     }
     
     private Map<String, Schema> createSubSchemaMap(final ShardingSphereDatabase database, final JavaTypeFactory javaTypeFactory, final TableScanExecutor executor) {
-        Map<String, Schema> result = new LinkedHashMap<>(database.getSchemas().size(), 1);
+        Map<String, Schema> result = new LinkedHashMap<>(database.getSchemas().size(), 1F);
         for (Entry<String, ShardingSphereSchema> entry : database.getSchemas().entrySet()) {
             result.put(entry.getKey(), new FilterableSchema(entry.getKey(), entry.getValue(), database.getProtocolType(), javaTypeFactory, executor));
         }
diff --git a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableSchema.java b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableSchema.java
index 7738945d0c9..0f9a1918b2f 100644
--- a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableSchema.java
+++ b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/filter/FilterableSchema.java
@@ -52,7 +52,7 @@ public final class FilterableSchema extends AbstractSchema {
     }
     
     private Map<String, Table> createTableMap(final ShardingSphereSchema schema, final DatabaseType protocolType, final JavaTypeFactory javaTypeFactory, final TableScanExecutor executor) {
-        Map<String, Table> result = new LinkedHashMap<>(schema.getTables().size(), 1);
+        Map<String, Table> result = new LinkedHashMap<>(schema.getTables().size(), 1F);
         for (ShardingSphereTable each : schema.getTables().values()) {
             if (schema.containsView(each.getName())) {
                 result.put(each.getName(), getViewTable(schema, protocolType, each, javaTypeFactory));
diff --git a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableDatabase.java b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableDatabase.java
index d80f44b4b5a..4b46c27f542 100644
--- a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableDatabase.java
+++ b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableDatabase.java
@@ -45,7 +45,7 @@ public final class TranslatableDatabase extends AbstractSchema {
     }
     
     private Map<String, Schema> createSubSchemaMap(final ShardingSphereDatabase database, final DatabaseType protocolType, final TableScanExecutor executor) {
-        Map<String, Schema> result = new LinkedHashMap<>(database.getSchemas().size(), 1);
+        Map<String, Schema> result = new LinkedHashMap<>(database.getSchemas().size(), 1F);
         for (Entry<String, ShardingSphereSchema> entry : database.getSchemas().entrySet()) {
             result.put(entry.getKey(), new TranslatableSchema(entry.getKey(), entry.getValue(), protocolType, null, executor));
         }
diff --git a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableSchema.java b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableSchema.java
index 0795889639d..09609d29c7e 100644
--- a/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableSchema.java
+++ b/kernel/sql-federation/optimizer/src/main/java/org/apache/shardingsphere/sqlfederation/optimizer/metadata/translatable/TranslatableSchema.java
@@ -52,7 +52,7 @@ public final class TranslatableSchema extends AbstractSchema {
     }
     
     private Map<String, Table> createTableMap(final ShardingSphereSchema schema, final DatabaseType protocolType, final JavaTypeFactory javaTypeFactory, final TableScanExecutor executor) {
-        Map<String, Table> result = new LinkedHashMap<>(schema.getTables().size(), 1);
+        Map<String, Table> result = new LinkedHashMap<>(schema.getTables().size(), 1F);
         for (ShardingSphereTable each : schema.getTables().values()) {
             if (schema.containsView(each.getName())) {
                 result.put(each.getName(), getViewTable(schema, each, protocolType, javaTypeFactory));
diff --git a/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ConnectionSavepointManager.java b/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ConnectionSavepointManager.java
index 422477c08c7..02e717c85e8 100644
--- a/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ConnectionSavepointManager.java
+++ b/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/ConnectionSavepointManager.java
@@ -39,7 +39,7 @@ public final class ConnectionSavepointManager {
     
     private static final ConnectionSavepointManager INSTANCE = new ConnectionSavepointManager();
     
-    private static final Map<Connection, Map<String, Savepoint>> CONNECTION_SAVEPOINT_MAP = new ConcurrentHashMap<>(128);
+    private static final Map<Connection, Map<String, Savepoint>> CONNECTION_SAVEPOINT_MAP = new ConcurrentHashMap<>(128, 1F);
     
     /**
      * Get instance of connection savepoint manager.
diff --git a/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/rule/TransactionRule.java b/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/rule/TransactionRule.java
index 4beb2eb5e8b..0398d8929ce 100644
--- a/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/rule/TransactionRule.java
+++ b/kernel/transaction/core/src/main/java/org/apache/shardingsphere/transaction/rule/TransactionRule.java
@@ -67,8 +67,8 @@ public final class TransactionRule implements GlobalRule, ResourceHeldRule<Shard
         if (databases.isEmpty()) {
             return new ShardingSphereTransactionManagerEngine(defaultType);
         }
-        Map<String, DataSource> dataSourceMap = new LinkedHashMap<>(databases.size(), 1);
-        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(databases.size(), 1);
+        Map<String, DataSource> dataSourceMap = new LinkedHashMap<>(databases.size(), 1F);
+        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(databases.size(), 1F);
         for (Entry<String, ShardingSphereDatabase> entry : databases.entrySet()) {
             ShardingSphereDatabase database = entry.getValue();
             database.getResourceMetaData().getDataSources().forEach((key, value) -> dataSourceMap.put(database.getName() + "." + key, value));
diff --git a/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/TransactionRuleTest.java b/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/TransactionRuleTest.java
index 48ee9af0569..544c7b5ad41 100644
--- a/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/TransactionRuleTest.java
+++ b/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/TransactionRuleTest.java
@@ -101,11 +101,11 @@ class TransactionRuleTest {
     
     private ShardingSphereResourceMetaData createResourceMetaData() {
         ShardingSphereResourceMetaData result = mock(ShardingSphereResourceMetaData.class);
-        Map<String, DataSource> dataSourceMap = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> dataSourceMap = new LinkedHashMap<>(2, 1F);
         dataSourceMap.put("ds_0", new MockedDataSource());
         dataSourceMap.put("ds_1", new MockedDataSource());
         when(result.getDataSources()).thenReturn(dataSourceMap);
-        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(2, 1);
+        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(2, 1F);
         databaseTypes.put("ds_0", new PostgreSQLDatabaseType());
         databaseTypes.put("ds_1", new OpenGaussDatabaseType());
         when(result.getStorageTypes()).thenReturn(databaseTypes);
@@ -122,11 +122,11 @@ class TransactionRuleTest {
     
     private ShardingSphereResourceMetaData createAddResourceMetaData() {
         ShardingSphereResourceMetaData result = mock(ShardingSphereResourceMetaData.class);
-        Map<String, DataSource> dataSourceMap = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> dataSourceMap = new LinkedHashMap<>(2, 1F);
         dataSourceMap.put("ds_0", new MockedDataSource());
         dataSourceMap.put("ds_1", new MockedDataSource());
         when(result.getDataSources()).thenReturn(dataSourceMap);
-        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(2, 1);
+        Map<String, DatabaseType> databaseTypes = new LinkedHashMap<>(2, 1F);
         databaseTypes.put("ds_0", new PostgreSQLDatabaseType());
         databaseTypes.put("ds_1", new OpenGaussDatabaseType());
         when(result.getStorageTypes()).thenReturn(databaseTypes);
diff --git a/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/builder/TransactionRuleBuilderTest.java b/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/builder/TransactionRuleBuilderTest.java
index b99e340dbc7..dc91f12257d 100644
--- a/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/builder/TransactionRuleBuilderTest.java
+++ b/kernel/transaction/core/src/test/java/org/apache/shardingsphere/transaction/rule/builder/TransactionRuleBuilderTest.java
@@ -53,7 +53,7 @@ class TransactionRuleBuilderTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new HashMap<>(2, 1);
+        Map<String, DataSource> result = new HashMap<>(2, 1F);
         result.put("not_change", new MockedDataSource());
         result.put("replace", new MockedDataSource());
         return result;
diff --git a/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManager.java b/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManager.java
index a762dcab471..9f183d9b49b 100644
--- a/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManager.java
+++ b/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManager.java
@@ -63,7 +63,7 @@ public final class XAShardingSphereTransactionManager implements ShardingSphereT
     }
     
     private Map<String, ResourceDataSource> getResourceDataSources(final Map<String, DataSource> dataSourceMap) {
-        Map<String, ResourceDataSource> result = new LinkedHashMap<>(dataSourceMap.size(), 1);
+        Map<String, ResourceDataSource> result = new LinkedHashMap<>(dataSourceMap.size(), 1F);
         for (Entry<String, DataSource> entry : dataSourceMap.entrySet()) {
             result.put(entry.getKey(), new ResourceDataSource(entry.getKey(), entry.getValue()));
         }
diff --git a/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/jta/datasource/swapper/DataSourceSwapper.java b/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/jta/datasource/swapper/DataSourceSwapper.java
index 305751eca8c..a64a210c6ee 100644
--- a/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/jta/datasource/swapper/DataSourceSwapper.java
+++ b/kernel/transaction/type/xa/core/src/main/java/org/apache/shardingsphere/transaction/xa/jta/datasource/swapper/DataSourceSwapper.java
@@ -78,7 +78,7 @@ public final class DataSourceSwapper {
     }
     
     private Map<String, Object> getDatabaseAccessConfiguration(final DataSource dataSource) {
-        Map<String, Object> result = new HashMap<>(3, 1);
+        Map<String, Object> result = new HashMap<>(3, 1F);
         DataSourcePropertyProvider provider = TypedSPILoader.getService(DataSourcePropertyProvider.class, dataSource.getClass().getName());
         try {
             result.put("url", findGetterMethod(dataSource, provider.getURLPropertyName()).invoke(dataSource));
diff --git a/kernel/transaction/type/xa/core/src/test/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManagerTest.java b/kernel/transaction/type/xa/core/src/test/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManagerTest.java
index a49a9e8906b..2c6d506c037 100644
--- a/kernel/transaction/type/xa/core/src/test/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManagerTest.java
+++ b/kernel/transaction/type/xa/core/src/test/java/org/apache/shardingsphere/transaction/xa/XAShardingSphereTransactionManagerTest.java
@@ -147,7 +147,7 @@ class XAShardingSphereTransactionManagerTest {
     }
     
     private Map<String, DataSource> createDataSources(final DatabaseType databaseType) {
-        Map<String, DataSource> result = new LinkedHashMap<>(3, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(3, 1F);
         result.put("sharding_db.ds_0", DataSourceUtils.build(HikariDataSource.class, databaseType, "demo_ds_0"));
         result.put("sharding_db.ds_1", DataSourceUtils.build(HikariDataSource.class, databaseType, "demo_ds_1"));
         result.put("sharding_db.ds_2", DataSourceUtils.build(AtomikosDataSourceBean.class, databaseType, "demo_ds_2"));
@@ -155,7 +155,7 @@ class XAShardingSphereTransactionManagerTest {
     }
     
     private Map<String, DatabaseType> createDatabaseTypes(final DatabaseType databaseType) {
-        Map<String, DatabaseType> result = new LinkedHashMap<>(3, 1);
+        Map<String, DatabaseType> result = new LinkedHashMap<>(3, 1F);
         result.put("sharding_db.ds_0", databaseType);
         result.put("sharding_db.ds_1", databaseType);
         result.put("sharding_db.ds_2", databaseType);
diff --git a/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/ContextManager.java b/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/ContextManager.java
index 5d3fd971c0e..d8268a65c3c 100644
--- a/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/ContextManager.java
+++ b/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/ContextManager.java
@@ -405,7 +405,7 @@ public final class ContextManager implements AutoCloseable {
     }
     
     private Map<String, ShardingSphereSchema> newShardingSphereSchemas(final ShardingSphereDatabase database) {
-        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(database.getSchemas().size(), 1);
+        Map<String, ShardingSphereSchema> result = new LinkedHashMap<>(database.getSchemas().size(), 1F);
         database.getSchemas().forEach((key, value) -> result.put(key, new ShardingSphereSchema(value.getTables(),
                 metaDataContexts.get().getPersistService().getDatabaseMetaDataService().getViewMetaDataPersistService().load(database.getName(), key))));
         return result;
diff --git a/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManager.java b/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManager.java
index 8b26db6c668..93f7a990afa 100644
--- a/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManager.java
+++ b/mode/core/src/main/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManager.java
@@ -98,7 +98,7 @@ public final class ResourceSwitchManager {
     }
     
     private Map<String, DataSource> getStaleDataSources(final ShardingSphereResourceMetaData resourceMetaData, final Map<String, DataSourceProperties> toBeChangedDataSourceProps) {
-        Map<String, DataSource> result = new LinkedHashMap<>(resourceMetaData.getDataSources().size(), 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(resourceMetaData.getDataSources().size(), 1F);
         result.putAll(getToBeChangedDataSources(resourceMetaData, toBeChangedDataSourceProps));
         return result;
     }
diff --git a/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/MetaDataContextsFactory.java b/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/MetaDataContextsFactory.java
index 0deec38a9d0..34e72b0ba15 100644
--- a/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/MetaDataContextsFactory.java
+++ b/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/MetaDataContextsFactory.java
@@ -114,7 +114,7 @@ public final class MetaDataContextsFactory {
     private static Map<String, DatabaseConfiguration> createEffectiveDatabaseConfigurations(final Collection<String> databaseNames,
                                                                                             final Map<String, DatabaseConfiguration> databaseConfigs, final MetaDataPersistService persistService) {
         return databaseNames.stream().collect(
-                Collectors.toMap(each -> each, each -> createEffectiveDatabaseConfiguration(each, databaseConfigs, persistService), (a, b) -> b, () -> new HashMap<>(databaseNames.size(), 1)));
+                Collectors.toMap(each -> each, each -> createEffectiveDatabaseConfiguration(each, databaseConfigs, persistService), (a, b) -> b, () -> new HashMap<>(databaseNames.size(), 1F)));
     }
     
     private static DatabaseConfiguration createEffectiveDatabaseConfiguration(final String databaseName,
@@ -134,7 +134,7 @@ public final class MetaDataContextsFactory {
     }
     
     private static Map<String, DataSourceState> getStorageDataSourceStates(final Map<String, StorageNodeDataSource> storageDataSourceStates) {
-        Map<String, DataSourceState> result = new HashMap<>(storageDataSourceStates.size(), 1);
+        Map<String, DataSourceState> result = new HashMap<>(storageDataSourceStates.size(), 1F);
         storageDataSourceStates.forEach((key, value) -> {
             List<String> values = Splitter.on(".").splitToList(key);
             Preconditions.checkArgument(3 == values.size(), "Illegal data source of storage node.");
diff --git a/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/NewMetaDataContextsFactory.java b/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/NewMetaDataContextsFactory.java
index ec96cc4f43b..82e8bf99b6a 100644
--- a/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/NewMetaDataContextsFactory.java
+++ b/mode/core/src/main/java/org/apache/shardingsphere/mode/metadata/NewMetaDataContextsFactory.java
@@ -116,7 +116,7 @@ public final class NewMetaDataContextsFactory {
     private static Map<String, DatabaseConfiguration> createEffectiveDatabaseConfigurations(final Collection<String> databaseNames,
                                                                                             final Map<String, DatabaseConfiguration> databaseConfigs, final NewMetaDataPersistService persistService) {
         return databaseNames.stream().collect(
-                Collectors.toMap(each -> each, each -> createEffectiveDatabaseConfiguration(each, databaseConfigs, persistService), (a, b) -> b, () -> new HashMap<>(databaseNames.size(), 1)));
+                Collectors.toMap(each -> each, each -> createEffectiveDatabaseConfiguration(each, databaseConfigs, persistService), (a, b) -> b, () -> new HashMap<>(databaseNames.size(), 1F)));
     }
     
     private static DatabaseConfiguration createEffectiveDatabaseConfiguration(final String databaseName,
@@ -136,7 +136,7 @@ public final class NewMetaDataContextsFactory {
     }
     
     private static Map<String, DataSourceState> getStorageDataSourceStates(final Map<String, StorageNodeDataSource> storageDataSourceStates) {
-        Map<String, DataSourceState> result = new HashMap<>(storageDataSourceStates.size(), 1);
+        Map<String, DataSourceState> result = new HashMap<>(storageDataSourceStates.size(), 1F);
         storageDataSourceStates.forEach((key, value) -> {
             List<String> values = Splitter.on(".").splitToList(key);
             Preconditions.checkArgument(3 == values.size(), "Illegal data source of storage node.");
diff --git a/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/ContextManagerTest.java b/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/ContextManagerTest.java
index a108aa060cc..72eda8e3a16 100644
--- a/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/ContextManagerTest.java
+++ b/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/ContextManagerTest.java
@@ -236,7 +236,7 @@ class ContextManagerTest {
     
     private ShardingSphereResourceMetaData createOriginalResource() {
         ShardingSphereResourceMetaData result = mock(ShardingSphereResourceMetaData.class);
-        Map<String, DataSource> originalDataSources = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> originalDataSources = new LinkedHashMap<>(2, 1F);
         originalDataSources.put("ds_1", new MockedDataSource());
         originalDataSources.put("ds_2", new MockedDataSource());
         when(result.getDataSources()).thenReturn(originalDataSources);
@@ -287,7 +287,7 @@ class ContextManagerTest {
     }
     
     private Map<String, Object> createProperties(final String username, final String password) {
-        Map<String, Object> result = new HashMap<>(3, 1);
+        Map<String, Object> result = new HashMap<>(3, 1F);
         result.putIfAbsent("url", "jdbc:mock://127.0.0.1/foo_ds");
         result.putIfAbsent("username", username);
         result.putIfAbsent("password", password);
diff --git a/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManagerTest.java b/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManagerTest.java
index 509a7d93153..73b9b91c769 100644
--- a/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManagerTest.java
+++ b/mode/core/src/test/java/org/apache/shardingsphere/mode/manager/switcher/ResourceSwitchManagerTest.java
@@ -47,7 +47,7 @@ class ResourceSwitchManagerTest {
     
     @Test
     void assertCreateByAlterDataSourceProps() {
-        Map<String, DataSource> dataSourceMap = new HashMap<>(3, 1);
+        Map<String, DataSource> dataSourceMap = new HashMap<>(3, 1F);
         dataSourceMap.put("ds_0", new MockedDataSource());
         dataSourceMap.put("ds_1", new MockedDataSource());
         SwitchingResource actual = new ResourceSwitchManager().createByAlterDataSourceProps(new ShardingSphereResourceMetaData("sharding_db", dataSourceMap), Collections.emptyMap());
@@ -59,14 +59,14 @@ class ResourceSwitchManagerTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new HashMap<>(3, 1);
+        Map<String, DataSource> result = new HashMap<>(3, 1F);
         result.put("not_change", new MockedDataSource());
         result.put("replace", new MockedDataSource());
         return result;
     }
     
     private Map<String, DataSourceProperties> createToBeChangedDataSourcePropsMap() {
-        Map<String, DataSourceProperties> result = new HashMap<>(3, 1);
+        Map<String, DataSourceProperties> result = new HashMap<>(3, 1F);
         result.put("new", new DataSourceProperties(MockedDataSource.class.getName(), Collections.emptyMap()));
         result.put("not_change", new DataSourceProperties(MockedDataSource.class.getName(), Collections.emptyMap()));
         result.put("replace", new DataSourceProperties(MockedDataSource.class.getName(), Collections.singletonMap("password", "new_pwd")));
diff --git a/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/storage/service/StorageNodeStatusService.java b/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/storage/service/StorageNodeStatusService.java
index 7cd1f434825..79ba7039b04 100644
--- a/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/storage/service/StorageNodeStatusService.java
+++ b/mode/type/cluster/core/src/main/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/status/storage/service/StorageNodeStatusService.java
@@ -45,7 +45,7 @@ public final class StorageNodeStatusService {
      */
     public Map<String, StorageNodeDataSource> loadStorageNodes() {
         Collection<String> storageNodes = repository.getChildrenKeys(StorageNode.getRootPath());
-        Map<String, StorageNodeDataSource> result = new HashMap<>(storageNodes.size(), 1);
+        Map<String, StorageNodeDataSource> result = new HashMap<>(storageNodes.size(), 1F);
         storageNodes.forEach(each -> {
             String yamlContext = repository.getDirectly(StorageNode.getStorageNodesDataSourcePath(each));
             if (!Strings.isNullOrEmpty(yamlContext)) {
diff --git a/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ConfigurationChangedSubscriberTest.java b/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ConfigurationChangedSubscriberTest.java
index a0697d84139..d79e9102d75 100644
--- a/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ConfigurationChangedSubscriberTest.java
+++ b/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ConfigurationChangedSubscriberTest.java
@@ -143,7 +143,7 @@ class ConfigurationChangedSubscriberTest {
     
     private Map<String, DataSourceProperties> createChangedDataSourcePropertiesMap() {
         MockedDataSource dataSource = new MockedDataSource();
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(3, 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(3, 1F);
         result.put("primary_ds", DataSourcePropertiesCreator.create(dataSource));
         result.put("ds_1", DataSourcePropertiesCreator.create(dataSource));
         result.put("ds_2", DataSourcePropertiesCreator.create(dataSource));
@@ -201,7 +201,7 @@ class ConfigurationChangedSubscriberTest {
     }
     
     private Map<String, DataSource> getDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(3, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(3, 1F);
         result.put("ds_0", new MockedDataSource());
         result.put("ds_1", new MockedDataSource());
         result.put("db", new MockedDataSource());
@@ -209,7 +209,7 @@ class ConfigurationChangedSubscriberTest {
     }
     
     private Map<String, DataSourceProperties> getVersionChangedDataSourcePropertiesMap() {
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(3, 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(3, 1F);
         result.put("primary_ds", DataSourcePropertiesCreator.create(new MockedDataSource()));
         result.put("ds_0", DataSourcePropertiesCreator.create(new MockedDataSource()));
         result.put("ds_1", DataSourcePropertiesCreator.create(getChangedDataSource()));
diff --git a/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ResourceMetaDataChangedSubscriberTest.java b/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ResourceMetaDataChangedSubscriberTest.java
index 096afbcb722..00459046d53 100644
--- a/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ResourceMetaDataChangedSubscriberTest.java
+++ b/mode/type/cluster/core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/subscriber/ResourceMetaDataChangedSubscriberTest.java
@@ -118,7 +118,7 @@ class ResourceMetaDataChangedSubscriberTest {
     
     private Map<String, DataSourceProperties> createDataSourcePropertiesMap() {
         MockedDataSource dataSource = new MockedDataSource();
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(3, 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(3, 1F);
         result.put("primary_ds", DataSourcePropertiesCreator.create(dataSource));
         result.put("replica_ds_0", DataSourcePropertiesCreator.create(dataSource));
         result.put("replica_ds_1", DataSourcePropertiesCreator.create(dataSource));
diff --git a/mode/type/cluster/repository/provider/consul/src/main/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepository.java b/mode/type/cluster/repository/provider/consul/src/main/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepository.java
index 744644a986f..9f793c28842 100644
--- a/mode/type/cluster/repository/provider/consul/src/main/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepository.java
+++ b/mode/type/cluster/repository/provider/consul/src/main/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepository.java
@@ -67,7 +67,7 @@ public final class ConsulRepository implements ClusterPersistRepository {
         consulClient = new ShardingSphereConsulClient(rawClient);
         consulProps = new ConsulProperties(config.getProps());
         distributedLockHolder = new DistributedLockHolder(getType(), consulClient, consulProps);
-        watchKeyMap = new HashMap<>(6, 1);
+        watchKeyMap = new HashMap<>(6, 1F);
     }
     
     @Override
@@ -156,7 +156,7 @@ public final class ConsulRepository implements ClusterPersistRepository {
             }
             if (null != index && index > currentIndex) {
                 currentIndex = index;
-                Collection<String> newKeys = new HashSet<>(response.getValue().size());
+                Collection<String> newKeys = new HashSet<>(response.getValue().size(), 1F);
                 Collection<String> watchKeys = watchKeyMap.get(key);
                 for (GetValue each : response.getValue()) {
                     newKeys.add(each.getKey());
diff --git a/mode/type/cluster/repository/provider/consul/src/test/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepositoryTest.java b/mode/type/cluster/repository/provider/consul/src/test/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepositoryTest.java
index d16efd39b88..bf70e7c11ef 100644
--- a/mode/type/cluster/repository/provider/consul/src/test/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepositoryTest.java
+++ b/mode/type/cluster/repository/provider/consul/src/test/java/org/apache/shardingsphere/mode/repository/cluster/consul/ConsulRepositoryTest.java
@@ -110,7 +110,7 @@ class ConsulRepositoryTest {
     private void setProperties() {
         MemberAccessor accessor = Plugins.getMemberAccessor();
         accessor.set(repository.getClass().getDeclaredField("consulProps"), repository, new ConsulProperties(new Properties()));
-        accessor.set(repository.getClass().getDeclaredField("watchKeyMap"), repository, new HashMap<>(4));
+        accessor.set(repository.getClass().getDeclaredField("watchKeyMap"), repository, new HashMap<>(4, 1F));
     }
     
     @Test
diff --git a/mode/type/cluster/repository/provider/nacos/src/main/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepository.java b/mode/type/cluster/repository/provider/nacos/src/main/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepository.java
index cff92a28413..7011fc71052 100644
--- a/mode/type/cluster/repository/provider/nacos/src/main/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepository.java
+++ b/mode/type/cluster/repository/provider/nacos/src/main/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepository.java
@@ -233,7 +233,7 @@ public final class NacosRepository implements ClusterPersistRepository {
         instance.setIp(serviceMetaData.getIp());
         instance.setPort(serviceMetaData.getPort());
         instance.setEphemeral(ephemeral);
-        Map<String, String> metadataMap = new HashMap<>(5, 1);
+        Map<String, String> metadataMap = new HashMap<>(5, 1F);
         if (ephemeral) {
             fillEphemeralMetaData(metadataMap);
         }
@@ -266,7 +266,7 @@ public final class NacosRepository implements ClusterPersistRepository {
             instance.setIp(persistentService.getIp());
             instance.setPort(persistentService.getPort());
             instance.setEphemeral(false);
-            Map<String, String> metaDataMap = new HashMap<>(2, 1);
+            Map<String, String> metaDataMap = new HashMap<>(2, 1F);
             metaDataMap.put(key, "");
             metaDataMap.put(NacosMetaDataUtils.UTC_ZONE_OFFSET.toString(), String.valueOf(NacosMetaDataUtils.getTimestamp()));
             instance.setMetadata(metaDataMap);
diff --git a/mode/type/cluster/repository/provider/nacos/src/test/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepositoryTest.java b/mode/type/cluster/repository/provider/nacos/src/test/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepositoryTest.java
index 5b46a6a27ec..a52e8fdecf2 100644
--- a/mode/type/cluster/repository/provider/nacos/src/test/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepositoryTest.java
+++ b/mode/type/cluster/repository/provider/nacos/src/test/java/org/apache/shardingsphere/mode/repository/cluster/nacos/NacosRepositoryTest.java
@@ -90,7 +90,7 @@ class NacosRepositoryTest {
         List<Instance> instances = new LinkedList<>();
         for (int count = 1; count <= total; count++) {
             Instance instance = new Instance();
-            Map<String, String> metaDataMap = new HashMap<>(2, 1);
+            Map<String, String> metaDataMap = new HashMap<>(2, 1F);
             metaDataMap.put(key, "value" + count);
             metaDataMap.put(NacosMetaDataUtils.UTC_ZONE_OFFSET.toString(), String.valueOf(count));
             instance.setMetadata(metaDataMap);
@@ -167,7 +167,7 @@ class NacosRepositoryTest {
         final String key = "/test/children/keys/ephemeral/1";
         final Instance instance = new Instance();
         instance.setEphemeral(true);
-        Map<String, String> metaDataMap = new HashMap<>(4, 1);
+        Map<String, String> metaDataMap = new HashMap<>(4, 1F);
         metaDataMap.put(PreservedMetadataKeys.HEART_BEAT_INTERVAL, String.valueOf(2000));
         metaDataMap.put(PreservedMetadataKeys.HEART_BEAT_TIMEOUT, String.valueOf(4000));
         metaDataMap.put(PreservedMetadataKeys.IP_DELETE_TIMEOUT, String.valueOf(6000));
diff --git a/parser/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/segment/converter/DataSourceSegmentsConverter.java b/parser/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/segment/converter/DataSourceSegmentsConverter.java
index cd890066349..ca1ad891f73 100644
--- a/parser/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/segment/converter/DataSourceSegmentsConverter.java
+++ b/parser/distsql/statement/src/main/java/org/apache/shardingsphere/distsql/parser/segment/converter/DataSourceSegmentsConverter.java
@@ -43,7 +43,7 @@ public final class DataSourceSegmentsConverter {
      * @return data source properties map
      */
     public static Map<String, DataSourceProperties> convert(final DatabaseType databaseType, final Collection<DataSourceSegment> dataSourceSegments) {
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(dataSourceSegments.size(), 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(dataSourceSegments.size(), 1F);
         for (DataSourceSegment each : dataSourceSegments) {
             result.put(each.getName(), new DataSourceProperties("com.zaxxer.hikari.HikariDataSource", createProperties(databaseType, each)));
         }
diff --git a/parser/sql/statement/src/main/java/org/apache/shardingsphere/sql/parser/sql/common/enums/LogicalOperator.java b/parser/sql/statement/src/main/java/org/apache/shardingsphere/sql/parser/sql/common/enums/LogicalOperator.java
index 4a01e668726..1f26086083c 100644
--- a/parser/sql/statement/src/main/java/org/apache/shardingsphere/sql/parser/sql/common/enums/LogicalOperator.java
+++ b/parser/sql/statement/src/main/java/org/apache/shardingsphere/sql/parser/sql/common/enums/LogicalOperator.java
@@ -28,7 +28,7 @@ public enum LogicalOperator {
     
     AND, OR;
     
-    private static final Map<String, LogicalOperator> MAPS = new HashMap<>(16, 1);
+    private static final Map<String, LogicalOperator> MAPS = new HashMap<>(16, 1F);
     
     static {
         MAPS.put("and", AND);
diff --git a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/config/yaml/swapper/YamlProxyConfigurationSwapper.java b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/config/yaml/swapper/YamlProxyConfigurationSwapper.java
index 554d2cb646c..ecf42a14e71 100644
--- a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/config/yaml/swapper/YamlProxyConfigurationSwapper.java
+++ b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/config/yaml/swapper/YamlProxyConfigurationSwapper.java
@@ -56,7 +56,7 @@ public final class YamlProxyConfigurationSwapper {
     }
     
     private Map<String, DatabaseConfiguration> swapDatabaseConfigurations(final YamlProxyConfiguration yamlConfig) {
-        Map<String, DatabaseConfiguration> result = new LinkedHashMap<>(yamlConfig.getDatabaseConfigurations().size(), 1);
+        Map<String, DatabaseConfiguration> result = new LinkedHashMap<>(yamlConfig.getDatabaseConfigurations().size(), 1F);
         for (Entry<String, YamlProxyDatabaseConfiguration> entry : yamlConfig.getDatabaseConfigurations().entrySet()) {
             Map<String, DataSourceConfiguration> databaseDataSourceConfigs = swapDataSourceConfigurations(entry.getValue().getDataSources());
             Collection<RuleConfiguration> databaseRuleConfigs = ruleConfigSwapperEngine.swapToRuleConfigurations(entry.getValue().getRules());
@@ -66,7 +66,7 @@ public final class YamlProxyConfigurationSwapper {
     }
     
     private Map<String, DataSourceConfiguration> swapDataSourceConfigurations(final Map<String, YamlProxyDataSourceConfiguration> yamlConfigs) {
-        Map<String, DataSourceConfiguration> result = new LinkedHashMap<>(yamlConfigs.size(), 1);
+        Map<String, DataSourceConfiguration> result = new LinkedHashMap<>(yamlConfigs.size(), 1F);
         for (Entry<String, YamlProxyDataSourceConfiguration> entry : yamlConfigs.entrySet()) {
             result.put(entry.getKey(), dataSourceConfigSwapper.swap(entry.getValue()));
         }
diff --git a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rdl/storage/unit/RegisterStorageUnitBackendHandler.java b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rdl/storage/unit/RegisterStorageUnitBackendHandler.java
index ef13816a4fc..6334a28a083 100644
--- a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rdl/storage/unit/RegisterStorageUnitBackendHandler.java
+++ b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rdl/storage/unit/RegisterStorageUnitBackendHandler.java
@@ -91,7 +91,7 @@ public final class RegisterStorageUnitBackendHandler extends StorageUnitDefiniti
     }
     
     private void checkDuplicatedDataSourceNames(final String databaseName, final Collection<String> dataSourceNames, final RegisterStorageUnitStatement sqlStatement) {
-        Collection<String> duplicatedDataSourceNames = new HashSet<>(sqlStatement.getStorageUnits().size(), 1);
+        Collection<String> duplicatedDataSourceNames = new HashSet<>(sqlStatement.getStorageUnits().size(), 1F);
         for (DataSourceSegment each : sqlStatement.getStorageUnits()) {
             if (dataSourceNames.contains(each.getName()) || getCurrentStorageUnitNames(databaseName).contains(each.getName())) {
                 duplicatedDataSourceNames.add(each.getName());
diff --git a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutor.java b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutor.java
index a90bf4a0242..cc6150fa1b7 100644
--- a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutor.java
+++ b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutor.java
@@ -96,7 +96,7 @@ public final class ShowStorageUnitExecutor implements RQLExecutor<ShowStorageUni
     }
     
     private Map<String, DataSourceProperties> getDataSourcePropsMap(final ShardingSphereDatabase database, final ShowStorageUnitsStatement sqlStatement) {
-        Map<String, DataSourceProperties> result = new LinkedHashMap<>(database.getResourceMetaData().getDataSources().size(), 1);
+        Map<String, DataSourceProperties> result = new LinkedHashMap<>(database.getResourceMetaData().getDataSources().size(), 1F);
         Optional<Integer> usageCountOptional = sqlStatement.getUsageCount();
         if (usageCountOptional.isPresent()) {
             Multimap<String, String> inUsedMultiMap = getInUsedResources(database.getRuleMetaData());
diff --git a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/util/YamlDatabaseConfigurationImportExecutor.java b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/util/YamlDatabaseConfigurationImportExecutor.java
index 550d5141eaa..a975025b013 100644
--- a/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/util/YamlDatabaseConfigurationImportExecutor.java
+++ b/proxy/backend/core/src/main/java/org/apache/shardingsphere/proxy/backend/util/YamlDatabaseConfigurationImportExecutor.java
@@ -139,7 +139,7 @@ public final class YamlDatabaseConfigurationImportExecutor {
     }
     
     private void addResources(final String databaseName, final Map<String, YamlProxyDataSourceConfiguration> yamlDataSourceMap) {
-        Map<String, DataSourceProperties> dataSourcePropsMap = new LinkedHashMap<>(yamlDataSourceMap.size(), 1);
+        Map<String, DataSourceProperties> dataSourcePropsMap = new LinkedHashMap<>(yamlDataSourceMap.size(), 1F);
         for (Entry<String, YamlProxyDataSourceConfiguration> entry : yamlDataSourceMap.entrySet()) {
             dataSourcePropsMap.put(entry.getKey(), DataSourcePropertiesCreator.create(HikariDataSource.class.getName(), dataSourceConfigSwapper.swap(entry.getValue())));
         }
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/connector/jdbc/datasource/JDBCBackendDataSourceTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/connector/jdbc/datasource/JDBCBackendDataSourceTest.java
index f1487a0c30a..988adf3b346 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/connector/jdbc/datasource/JDBCBackendDataSourceTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/connector/jdbc/datasource/JDBCBackendDataSourceTest.java
@@ -92,7 +92,7 @@ class JDBCBackendDataSourceTest {
     
     private Map<String, ShardingSphereDatabase> createDatabases() {
         ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
-        Map<String, DatabaseType> storageTypes = new LinkedHashMap<>(2, 1);
+        Map<String, DatabaseType> storageTypes = new LinkedHashMap<>(2, 1F);
         storageTypes.put("ds_0", new H2DatabaseType());
         storageTypes.put("ds_1", new H2DatabaseType());
         when(database.getResourceMetaData().getStorageTypes()).thenReturn(storageTypes);
@@ -107,7 +107,7 @@ class JDBCBackendDataSourceTest {
     }
     
     private Map<String, DataSource> mockDataSources(final int size) {
-        Map<String, DataSource> result = new HashMap<>(size, 1);
+        Map<String, DataSource> result = new HashMap<>(size, 1F);
         for (int i = 0; i < size; i++) {
             result.put(String.format(DATA_SOURCE_PATTERN, i), new CallTimeRecordDataSource());
         }
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/context/ProxyContextTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/context/ProxyContextTest.java
index a171293d004..4bf1d0de487 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/context/ProxyContextTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/context/ProxyContextTest.java
@@ -131,7 +131,7 @@ class ProxyContextTest {
     }
     
     private Map<String, ShardingSphereDatabase> createDatabases() {
-        Map<String, ShardingSphereDatabase> result = new LinkedHashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new LinkedHashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.getName()).thenReturn(String.format(SCHEMA_PATTERN, i));
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/DefaultDatabaseMetaDataExecutorTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/DefaultDatabaseMetaDataExecutorTest.java
index c34a0df7406..9175d8a5d8e 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/DefaultDatabaseMetaDataExecutorTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/admin/executor/DefaultDatabaseMetaDataExecutorTest.java
@@ -75,7 +75,7 @@ class DefaultDatabaseMetaDataExecutorTest {
     
     @Test
     void assertExecuteWithAlias() throws SQLException {
-        Map<String, String> expectedResultSetMap = new HashMap<>(2, 1);
+        Map<String, String> expectedResultSetMap = new HashMap<>(2, 1F);
         expectedResultSetMap.put("sn", "foo_ds");
         expectedResultSetMap.put("DEFAULT_CHARACTER_SET_NAME", "utf8mb4");
         String sql = "SELECT SCHEMA_NAME AS sn, DEFAULT_CHARACTER_SET_NAME FROM information_schema.SCHEMATA";
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/data/impl/UnicastDatabaseBackendHandlerTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/data/impl/UnicastDatabaseBackendHandlerTest.java
index 5ae8746a034..8d98d66f712 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/data/impl/UnicastDatabaseBackendHandlerTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/data/impl/UnicastDatabaseBackendHandlerTest.java
@@ -133,7 +133,7 @@ class UnicastDatabaseBackendHandlerTest {
     }
     
     private Map<String, ShardingSphereDatabase> createDatabases() {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.containsDataSource()).thenReturn(true);
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/database/DropDatabaseBackendHandlerTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/database/DropDatabaseBackendHandlerTest.java
index 738ee03ba39..37326327552 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/database/DropDatabaseBackendHandlerTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/database/DropDatabaseBackendHandlerTest.java
@@ -75,7 +75,7 @@ class DropDatabaseBackendHandlerTest {
     }
     
     private ContextManager mockContextManager() {
-        Map<String, ShardingSphereDatabase> databases = new HashMap<>(2, 1);
+        Map<String, ShardingSphereDatabase> databases = new HashMap<>(2, 1F);
         ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
         when(database.getRuleMetaData().getRules()).thenReturn(Collections.emptyList());
         databases.put("foo_db", database);
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportDatabaseConfigurationExecutorTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportDatabaseConfigurationExecutorTest.java
index 4fc2334e6c2..4491bf0a50a 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportDatabaseConfigurationExecutorTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportDatabaseConfigurationExecutorTest.java
@@ -86,7 +86,7 @@ class ExportDatabaseConfigurationExecutorTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("ds_0", createDataSource("demo_ds_0"));
         result.put("ds_1", createDataSource("demo_ds_1"));
         return result;
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportMetaDataExecutorTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportMetaDataExecutorTest.java
index 1d0ccf36b6d..1c7907c9f50 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportMetaDataExecutorTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportMetaDataExecutorTest.java
@@ -146,7 +146,7 @@ class ExportMetaDataExecutorTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("ds_0", createDataSource("demo_ds_0"));
         result.put("ds_1", createDataSource("demo_ds_1"));
         return result;
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportStorageNodesExecutorTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportStorageNodesExecutorTest.java
index b12537fa7a1..c6bdd5d5f73 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportStorageNodesExecutorTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/queryable/ExportStorageNodesExecutorTest.java
@@ -147,7 +147,7 @@ class ExportStorageNodesExecutorTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("ds_0", createDataSource("demo_ds_0"));
         result.put("ds_1", createDataSource("demo_ds_1"));
         return result;
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportMetaDataUpdaterTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportMetaDataUpdaterTest.java
index cb5d0c1e722..0a6e1de7487 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportMetaDataUpdaterTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/ral/updatable/ImportMetaDataUpdaterTest.java
@@ -67,7 +67,7 @@ class ImportMetaDataUpdaterTest {
     
     private ImportMetaDataUpdater importMetaDataUpdater;
     
-    private final Map<String, String> featureMap = new HashMap<>(1, 1);
+    private final Map<String, String> featureMap = new HashMap<>(1, 1F);
     
     @BeforeEach
     void setup() {
@@ -116,7 +116,7 @@ class ImportMetaDataUpdaterTest {
     }
     
     private Map<String, DataSource> createDataSourceMap() {
-        Map<String, DataSource> result = new LinkedHashMap<>(2, 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(2, 1F);
         result.put("ds_0", new MockedDataSource());
         result.put("ds_1", new MockedDataSource());
         return result;
diff --git a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutorTest.java b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutorTest.java
index f416ac7aa64..a780af6d42d 100644
--- a/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutorTest.java
+++ b/proxy/backend/core/src/test/java/org/apache/shardingsphere/proxy/backend/handler/distsql/rql/storage/unit/ShowStorageUnitExecutorTest.java
@@ -108,7 +108,7 @@ class ShowStorageUnitExecutorTest {
     void assertAllStorageUnit() {
         RQLExecutor<ShowStorageUnitsStatement> executor = new ShowStorageUnitExecutor();
         ShowStorageUnitsStatement showStorageUnitsStatement = new ShowStorageUnitsStatement(mock(DatabaseSegment.class), null);
-        Map<Integer, String> nameMap = new HashMap<>(3, 1);
+        Map<Integer, String> nameMap = new HashMap<>(3, 1F);
         nameMap.put(0, "ds_2");
         nameMap.put(1, "ds_1");
         nameMap.put(2, "ds_0");
diff --git a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/connector/HBaseConnectionFactory.java b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/connector/HBaseConnectionFactory.java
index fd0f6b5316b..5060e3e217e 100644
--- a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/connector/HBaseConnectionFactory.java
+++ b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/connector/HBaseConnectionFactory.java
@@ -48,7 +48,7 @@ public final class HBaseConnectionFactory {
      * @return A connection for per HBase cluster
      */
     public static Map<String, Connection> createHBaseConnections(final YamlHBaseConfiguration yamlProxyHBaseConfiguration) {
-        Map<String, Connection> result = new LinkedHashMap<>(yamlProxyHBaseConfiguration.getDataSources().size());
+        Map<String, Connection> result = new LinkedHashMap<>(yamlProxyHBaseConfiguration.getDataSources().size(), 1F);
         for (Entry<String, YamlHBaseParameter> entry : yamlProxyHBaseConfiguration.getDataSources().entrySet()) {
             result.put(entry.getKey(), createConnection(entry.getValue()));
         }
diff --git a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/result/query/HBaseListResultSet.java b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/result/query/HBaseListResultSet.java
index 6292a2c1c45..7fa66bb1c32 100644
--- a/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/result/query/HBaseListResultSet.java
+++ b/proxy/backend/type/hbase/src/main/java/org/apache/shardingsphere/proxy/backend/hbase/result/query/HBaseListResultSet.java
@@ -67,7 +67,7 @@ public final class HBaseListResultSet implements HBaseQueryResultSet {
     }
     
     private Map<String, String> listTablesInHBase() {
-        Map<String, String> result = new HashMap<>(HBaseContext.getInstance().getTableConnectionMap().size());
+        Map<String, String> result = new HashMap<>(HBaseContext.getInstance().getTableConnectionMap().size(), 1F);
         for (Entry<String, HBaseCluster> entry : HBaseContext.getInstance().getTableConnectionMap().entrySet()) {
             result.put(entry.getKey(), entry.getValue().getClusterName());
         }
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowCreateDatabaseExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowCreateDatabaseExecutorTest.java
index f2d96c77cf5..83982ada399 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowCreateDatabaseExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowCreateDatabaseExecutorTest.java
@@ -77,7 +77,7 @@ class ShowCreateDatabaseExecutorTest {
     }
     
     private Map<String, ShardingSphereDatabase> getDatabases() {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.getProtocolType()).thenReturn(new MySQLDatabaseType());
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowDatabasesExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowDatabasesExecutorTest.java
index ad5072fd033..7eb56e46e74 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowDatabasesExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowDatabasesExecutorTest.java
@@ -91,7 +91,7 @@ class ShowDatabasesExecutorTest {
     }
     
     private Collection<String> getActual(final ShowDatabasesExecutor executor) throws SQLException {
-        Map<String, String> result = new ConcurrentHashMap<>(10, 1);
+        Map<String, String> result = new ConcurrentHashMap<>(10, 1F);
         while (executor.getMergedResult().next()) {
             String value = executor.getMergedResult().getValue(1, Object.class).toString();
             result.put(value, value);
@@ -100,7 +100,7 @@ class ShowDatabasesExecutorTest {
     }
     
     private Collection<String> getExpected() {
-        Map<String, String> result = new ConcurrentHashMap<>(10, 1);
+        Map<String, String> result = new ConcurrentHashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             String value = String.format(DATABASE_PATTERN, i);
             result.put(value, value);
@@ -187,7 +187,7 @@ class ShowDatabasesExecutorTest {
     }
     
     private Map<String, ShardingSphereDatabase> getDatabases() {
-        Map<String, ShardingSphereDatabase> result = new LinkedHashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new LinkedHashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.getProtocolType()).thenReturn(new MySQLDatabaseType());
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowFunctionStatusExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowFunctionStatusExecutorTest.java
index 677112d6b5b..2df6ff4f3dd 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowFunctionStatusExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowFunctionStatusExecutorTest.java
@@ -69,7 +69,7 @@ class ShowFunctionStatusExecutorTest {
     }
     
     private Map<String, ShardingSphereDatabase> getDatabases() {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.getProtocolType()).thenReturn(new MySQLDatabaseType());
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowProcedureStatusExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowProcedureStatusExecutorTest.java
index 4d5703ce74a..0eb54628735 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowProcedureStatusExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowProcedureStatusExecutorTest.java
@@ -69,7 +69,7 @@ class ShowProcedureStatusExecutorTest {
     }
     
     private Map<String, ShardingSphereDatabase> getDatabases() {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.getProtocolType()).thenReturn(new MySQLDatabaseType());
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowTablesExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowTablesExecutorTest.java
index 1f2ecd223bb..679b4174568 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowTablesExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/ShowTablesExecutorTest.java
@@ -199,7 +199,7 @@ class ShowTablesExecutorTest {
     }
     
     private Map<String, ShardingSphereDatabase> getDatabases() {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(4, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(4, 1F);
         tables.put("t_account", new ShardingSphereTable("t_account", Collections.emptyList(), Collections.emptyList(), Collections.emptyList()));
         tables.put("t_account_bak", new ShardingSphereTable("t_account_bak", Collections.emptyList(), Collections.emptyList(), Collections.emptyList()));
         tables.put("t_account_detail", new ShardingSphereTable("t_account_detail", Collections.emptyList(), Collections.emptyList(), Collections.emptyList()));
@@ -209,7 +209,7 @@ class ShowTablesExecutorTest {
         when(database.getSchema(String.format(DATABASE_PATTERN, 0))).thenReturn(schema);
         when(database.isComplete()).thenReturn(true);
         when(database.getProtocolType()).thenReturn(new MySQLDatabaseType());
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(2, 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(2, 1F);
         result.put(String.format(DATABASE_PATTERN, 0), database);
         ShardingSphereDatabase uncompletedDatabase = mock(ShardingSphereDatabase.class);
         result.put("uncompleted", uncompletedDatabase);
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/UseDatabaseExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/UseDatabaseExecutorTest.java
index 390f9ac1b9e..3b47d1e39a5 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/UseDatabaseExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/UseDatabaseExecutorTest.java
@@ -87,7 +87,7 @@ class UseDatabaseExecutorTest {
     }
     
     private Map<String, ShardingSphereDatabase> getDatabases() {
-        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1);
+        Map<String, ShardingSphereDatabase> result = new HashMap<>(10, 1F);
         for (int i = 0; i < 10; i++) {
             ShardingSphereDatabase database = mock(ShardingSphereDatabase.class, RETURNS_DEEP_STUBS);
             when(database.getProtocolType()).thenReturn(new H2DatabaseType());
diff --git a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/information/SelectInformationSchemataExecutorTest.java b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/information/SelectInformationSchemataExecutorTest.java
index 0b274a96dd7..59267e7ef03 100644
--- a/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/information/SelectInformationSchemataExecutorTest.java
+++ b/proxy/backend/type/mysql/src/test/java/org/apache/shardingsphere/proxy/backend/mysql/handler/admin/executor/information/SelectInformationSchemataExecutorTest.java
@@ -99,7 +99,7 @@ class SelectInformationSchemataExecutorTest {
     
     @Test
     void assertExecuteWithAuthorizedDatabase() throws SQLException {
-        Map<String, String> expectedResultSetMap = new HashMap<>(2, 1);
+        Map<String, String> expectedResultSetMap = new HashMap<>(2, 1F);
         expectedResultSetMap.put("SCHEMA_NAME", "foo_ds");
         expectedResultSetMap.put("DEFAULT_COLLATION_NAME", "utf8mb4");
         ShardingSphereDatabase database = createDatabase(expectedResultSetMap);
diff --git a/proxy/backend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/PostgreSQLCharacterSets.java b/proxy/backend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/PostgreSQLCharacterSets.java
index 4acd2d935d5..ba4d756dbac 100644
--- a/proxy/backend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/PostgreSQLCharacterSets.java
+++ b/proxy/backend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/PostgreSQLCharacterSets.java
@@ -76,7 +76,7 @@ public enum PostgreSQLCharacterSets {
     private static final Map<String, PostgreSQLCharacterSets> CHARACTER_SETS_MAP;
     
     static {
-        Map<String, PostgreSQLCharacterSets> map = new HashMap<>(128);
+        Map<String, PostgreSQLCharacterSets> map = new HashMap<>(128, 1F);
         for (PostgreSQLCharacterSets each : values()) {
             map.put(each.name(), each);
             for (String eachAlias : each.aliases) {
diff --git a/proxy/backend/type/postgresql/src/test/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/executor/SelectTableExecutorTest.java b/proxy/backend/type/postgresql/src/test/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/executor/SelectTableExecutorTest.java
index 930ed1f6240..ee405083558 100644
--- a/proxy/backend/type/postgresql/src/test/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/executor/SelectTableExecutorTest.java
+++ b/proxy/backend/type/postgresql/src/test/java/org/apache/shardingsphere/proxy/backend/postgresql/handler/admin/executor/SelectTableExecutorTest.java
@@ -120,7 +120,7 @@ class SelectTableExecutorTest {
     }
     
     private Map<String, String> createExpectedResultSetMap() {
-        Map<String, String> result = new LinkedHashMap<>(3, 1);
+        Map<String, String> result = new LinkedHashMap<>(3, 1F);
         result.put("tablename", "t_order_1");
         result.put("c.oid", "0000");
         result.put("schemaname", "public");
diff --git a/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/ProxyStateContext.java b/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/ProxyStateContext.java
index 2de36e2de5b..c0470972b10 100644
--- a/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/ProxyStateContext.java
+++ b/proxy/frontend/core/src/main/java/org/apache/shardingsphere/proxy/frontend/state/ProxyStateContext.java
@@ -37,7 +37,7 @@ import java.util.concurrent.ConcurrentHashMap;
 @NoArgsConstructor(access = AccessLevel.PRIVATE)
 public final class ProxyStateContext {
     
-    private static final Map<InstanceState, ProxyState> STATES = new ConcurrentHashMap<>(3, 1);
+    private static final Map<InstanceState, ProxyState> STATES = new ConcurrentHashMap<>(3, 1F);
     
     static {
         STATES.put(InstanceState.OK, new OKProxyState());
diff --git a/proxy/frontend/type/mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareParameterMarkerExtractor.java b/proxy/frontend/type/mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareParameterMarkerExtractor.java
index 1c3b440930f..848d05dab93 100644
--- a/proxy/frontend/type/mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareParameterMarkerExtractor.java
+++ b/proxy/frontend/type/mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/binary/prepare/MySQLComStmtPrepareParameterMarkerExtractor.java
@@ -57,7 +57,7 @@ public final class MySQLComStmtPrepareParameterMarkerExtractor {
     private static Map<ParameterMarkerSegment, ShardingSphereColumn> findColumnsOfParameterMarkersForInsert(final InsertStatement insertStatement, final ShardingSphereSchema schema) {
         ShardingSphereTable table = schema.getTable(insertStatement.getTable().getTableName().getIdentifier().getValue());
         List<String> columnNamesOfInsert = getColumnNamesOfInsertStatement(insertStatement, table);
-        Map<ParameterMarkerSegment, ShardingSphereColumn> result = new LinkedHashMap<>(insertStatement.getParameterMarkerSegments().size(), 1);
+        Map<ParameterMarkerSegment, ShardingSphereColumn> result = new LinkedHashMap<>(insertStatement.getParameterMarkerSegments().size(), 1F);
         for (InsertValuesSegment each : insertStatement.getValues()) {
             ListIterator<ExpressionSegment> listIterator = each.getValues().listIterator();
             for (int columnIndex = listIterator.nextIndex(); listIterator.hasNext(); columnIndex = listIterator.nextIndex()) {
diff --git a/proxy/frontend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/frontend/postgresql/command/query/PostgreSQLCommand.java b/proxy/frontend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/frontend/postgresql/command/query/PostgreSQLCommand.java
index 96fe3a6a368..288fa6f5aee 100644
--- a/proxy/frontend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/frontend/postgresql/command/query/PostgreSQLCommand.java
+++ b/proxy/frontend/type/postgresql/src/main/java/org/apache/shardingsphere/proxy/frontend/postgresql/command/query/PostgreSQLCommand.java
@@ -132,7 +132,7 @@ public enum PostgreSQLCommand {
     CLOSE_CURSOR(CloseStatement.class),
     SUCCESS(DistSQLStatement.class);
     
-    private static final Map<Class<? extends SQLStatement>, CachedResult> COMPUTED_STATEMENTS = new ConcurrentHashMap<>(64, 1);
+    private static final Map<Class<? extends SQLStatement>, CachedResult> COMPUTED_STATEMENTS = new ConcurrentHashMap<>(64);
     
     private final Collection<Class<? extends SQLStatement>> sqlStatementClasses;
     
diff --git a/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/AbstractDriverTest.java b/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/AbstractDriverTest.java
index f67efa2ddf4..1ca34355f13 100644
--- a/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/AbstractDriverTest.java
+++ b/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/AbstractDriverTest.java
@@ -36,7 +36,7 @@ public abstract class AbstractDriverTest {
     
     private static final List<String> ACTUAL_DATA_SOURCE_NAMES = Arrays.asList("jdbc_0", "jdbc_1", "single_jdbc", "shadow_jdbc_0", "shadow_jdbc_1", "encrypt", "test_primary_ds", "test_replica_ds");
     
-    private static final Map<String, DataSource> ACTUAL_DATA_SOURCES = new HashMap<>(ACTUAL_DATA_SOURCE_NAMES.size(), 1);
+    private static final Map<String, DataSource> ACTUAL_DATA_SOURCES = new HashMap<>(ACTUAL_DATA_SOURCE_NAMES.size(), 1F);
     
     @BeforeAll
     static synchronized void initializeDataSource() throws SQLException {
diff --git a/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/fixture/sharding/JDBCStandardShardingAlgorithmFixture.java b/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/fixture/sharding/JDBCStandardShardingAlgorithmFixture.java
index f0a01216237..18fa50db852 100644
--- a/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/fixture/sharding/JDBCStandardShardingAlgorithmFixture.java
+++ b/test/e2e/driver/src/test/java/org/apache/shardingsphere/test/e2e/driver/fixture/sharding/JDBCStandardShardingAlgorithmFixture.java
@@ -48,7 +48,7 @@ public final class JDBCStandardShardingAlgorithmFixture implements StandardShard
     
     @Override
     public Collection<String> doSharding(final Collection<String> availableTargetNames, final RangeShardingValue<Integer> shardingValue) {
-        Collection<String> result = new HashSet<>(2);
+        Collection<String> result = new HashSet<>(2, 1F);
         for (int i = shardingValue.getValueRange().lowerEndpoint(); i <= shardingValue.getValueRange().upperEndpoint(); i++) {
             for (String each : availableTargetNames) {
                 if (each.endsWith(String.valueOf(i % 2))) {
diff --git a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/EmbeddedStorageContainer.java b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/EmbeddedStorageContainer.java
index e89a1e1dd24..09466dc5d0a 100644
--- a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/EmbeddedStorageContainer.java
+++ b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/EmbeddedStorageContainer.java
@@ -56,7 +56,7 @@ public abstract class EmbeddedStorageContainer implements EmbeddedITContainer, S
     @SneakyThrows({IOException.class, JAXBException.class})
     private Map<String, DataSource> createActualDataSourceMap() {
         Collection<String> databaseNames = DatabaseEnvironmentManager.getDatabaseNames(scenario);
-        Map<String, DataSource> result = new LinkedHashMap<>(databaseNames.size(), 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(databaseNames.size(), 1F);
         databaseNames.forEach(each -> result.put(each, StorageContainerUtils.generateDataSource(DataSourceEnvironment.getURL(databaseType, null, 0, scenario + each),
                 "root", "Root@123")));
         return result;
@@ -65,7 +65,7 @@ public abstract class EmbeddedStorageContainer implements EmbeddedITContainer, S
     @SneakyThrows({IOException.class, JAXBException.class})
     private Map<String, DataSource> createExpectedDataSourceMap() {
         Collection<String> databaseNames = DatabaseEnvironmentManager.getExpectedDatabaseNames(scenario);
-        Map<String, DataSource> result = new LinkedHashMap<>(databaseNames.size(), 1);
+        Map<String, DataSource> result = new LinkedHashMap<>(databaseNames.size(), 1F);
         databaseNames.forEach(each -> result.put(each, StorageContainerUtils.generateDataSource(DataSourceEnvironment.getURL(databaseType, null, 0, scenario + each),
                 "root", "Root@123")));
         return result;
diff --git a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/mysql/MySQLContainerConfigurationFactory.java b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/mysql/MySQLContainerConfigurationFactory.java
index e8c8a4f1740..522844d90c8 100644
--- a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/mysql/MySQLContainerConfigurationFactory.java
+++ b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/mysql/MySQLContainerConfigurationFactory.java
@@ -62,7 +62,7 @@ public final class MySQLContainerConfigurationFactory {
     }
     
     private static Map<String, String> getContainerEnvironments() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("LANG", "C.UTF-8");
         result.put("MYSQL_RANDOM_ROOT_PASSWORD", "yes");
         return result;
diff --git a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/opengauss/OpenGaussContainerConfigurationFactory.java b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/opengauss/OpenGaussContainerConfigurationFactory.java
index 223382e5303..c8ef8991607 100644
--- a/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/opengauss/OpenGaussContainerConfigurationFactory.java
+++ b/test/e2e/env/src/test/java/org/apache/shardingsphere/test/e2e/env/container/atomic/storage/config/impl/opengauss/OpenGaussContainerConfigurationFactory.java
@@ -51,7 +51,7 @@ public final class OpenGaussContainerConfigurationFactory {
     }
     
     private static Map<String, String> getMountedResources() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("/env/postgresql/postgresql.conf", OpenGaussContainer.OPENGAUSS_CONF_IN_CONTAINER);
         result.put("/env/opengauss/pg_hba.conf", OpenGaussContainer.OPENGAUSS_HBA_IN_CONF_CONTAINER);
         return result;
diff --git a/test/e2e/fixture/src/test/java/org/apache/shardingsphere/test/e2e/fixture/ITStandardShardingAlgorithmFixture.java b/test/e2e/fixture/src/test/java/org/apache/shardingsphere/test/e2e/fixture/ITStandardShardingAlgorithmFixture.java
index 7cbf60a1a2c..88892b9a046 100644
--- a/test/e2e/fixture/src/test/java/org/apache/shardingsphere/test/e2e/fixture/ITStandardShardingAlgorithmFixture.java
+++ b/test/e2e/fixture/src/test/java/org/apache/shardingsphere/test/e2e/fixture/ITStandardShardingAlgorithmFixture.java
@@ -39,7 +39,7 @@ public final class ITStandardShardingAlgorithmFixture implements StandardShardin
     
     @Override
     public Collection<String> doSharding(final Collection<String> availableTargetNames, final RangeShardingValue<Integer> shardingValue) {
-        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size());
+        Collection<String> result = new LinkedHashSet<>(availableTargetNames.size(), 1F);
         int minValue = shardingValue.getValueRange().hasLowerBound() ? shardingValue.getValueRange().lowerEndpoint() : Integer.MIN_VALUE;
         int maxValue = shardingValue.getValueRange().hasUpperBound() ? shardingValue.getValueRange().upperEndpoint() : Integer.MAX_VALUE;
         long range = BigInteger.valueOf(maxValue).subtract(BigInteger.valueOf(minValue)).longValue();
diff --git a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/DataSourceRecordConsumer.java b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/DataSourceRecordConsumer.java
index 527169011e5..492ec6f2a46 100644
--- a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/DataSourceRecordConsumer.java
+++ b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/cases/cdc/DataSourceRecordConsumer.java
@@ -104,7 +104,7 @@ public final class DataSourceRecordConsumer implements Consumer<List<Record>> {
         try (
                 Connection connection = dataSource.getConnection();
                 PreparedStatement preparedStatement = connection.prepareStatement(sql)) {
-            Map<String, TableColumn> afterMap = new LinkedHashMap<>(record.getBeforeList().size(), 1);
+            Map<String, TableColumn> afterMap = new LinkedHashMap<>(record.getBeforeList().size(), 1F);
             record.getAfterList().forEach(each -> afterMap.put(each.getName(), each));
             switch (record.getDataChangeType()) {
                 case INSERT:
diff --git a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/PipelineProxyClusterContainerConfigurationFactory.java b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/PipelineProxyClusterContainerConfigurationFactory.java
index 3d918b4ac7d..36c34bca563 100644
--- a/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/PipelineProxyClusterContainerConfigurationFactory.java
+++ b/test/e2e/operation/pipeline/src/test/java/org/apache/shardingsphere/test/e2e/data/pipeline/framework/container/config/proxy/PipelineProxyClusterContainerConfigurationFactory.java
@@ -51,7 +51,7 @@ public final class PipelineProxyClusterContainerConfigurationFactory {
     }
     
     private static Map<String, String> getMountedResource(final DatabaseType databaseType, final String storageContainerImage) {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.putAll(ProxyClusterContainerConfigurationFactory.newInstance().getMountedResources());
         if (DatabaseTypeUtils.isMySQL(databaseType)) {
             String majorVersion = DatabaseTypeUtils.parseMajorVersion(storageContainerImage);
diff --git a/test/e2e/operation/showprocesslist/src/test/java/org/apache/shardingsphere/test/e2e/showprocesslist/container/composer/ClusterShowProcessListContainerComposer.java b/test/e2e/operation/showprocesslist/src/test/java/org/apache/shardingsphere/test/e2e/showprocesslist/container/composer/ClusterShowProcessListContainerComposer.java
index d2716e8bd8e..8abbbb2183d 100644
--- a/test/e2e/operation/showprocesslist/src/test/java/org/apache/shardingsphere/test/e2e/showprocesslist/container/composer/ClusterShowProcessListContainerComposer.java
+++ b/test/e2e/operation/showprocesslist/src/test/java/org/apache/shardingsphere/test/e2e/showprocesslist/container/composer/ClusterShowProcessListContainerComposer.java
@@ -73,7 +73,7 @@ public final class ClusterShowProcessListContainerComposer implements AutoClosea
     }
     
     private Map<String, String> getMountedResources(final String scenario, final DatabaseType databaseType, final String runMode, final String governanceCenter) {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put(isClusterMode(runMode) ? String.format("/env/common/cluster/proxy/%s/conf/", governanceCenter.toLowerCase())
                 : "/env/common/standalone/proxy/conf/", ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
         result.put("/env/scenario/" + scenario + "/proxy/conf/" + databaseType.getType().toLowerCase(), ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
diff --git a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/mysql/MySQLContainerConfigurationFactory.java b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/mysql/MySQLContainerConfigurationFactory.java
index 8843b327c92..c37d00b9d4b 100644
--- a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/mysql/MySQLContainerConfigurationFactory.java
+++ b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/mysql/MySQLContainerConfigurationFactory.java
@@ -46,7 +46,7 @@ public final class MySQLContainerConfigurationFactory {
     }
     
     private static Map<String, String> getContainerEnvironments() {
-        Map<String, String> result = new HashMap<>(3, 1);
+        Map<String, String> result = new HashMap<>(3, 1F);
         result.put("LANG", "C.UTF-8");
         result.put("MYSQL_RANDOM_ROOT_PASSWORD", "yes");
         result.put("MYSQL_ROOT_HOST", "%");
diff --git a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/postgresql/PostgreSQLContainerConfigurationFactory.java b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/postgresql/PostgreSQLContainerConfigurationFactory.java
index 9e5303cca5b..1beb49c3bf3 100644
--- a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/postgresql/PostgreSQLContainerConfigurationFactory.java
+++ b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/postgresql/PostgreSQLContainerConfigurationFactory.java
@@ -47,7 +47,7 @@ public final class PostgreSQLContainerConfigurationFactory {
     }
     
     private static Map<String, String> getContainerEnvironments() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("POSTGRES_HOST", StorageContainerConstants.USERNAME);
         result.put("POSTGRES_PASSWORD", StorageContainerConstants.PASSWORD);
         return result;
diff --git a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/proxy/ProxyClusterContainerConfigurationFactory.java b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/proxy/ProxyClusterContainerConfigurationFactory.java
index f35a7135a48..9bf237a3c6f 100644
--- a/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/proxy/ProxyClusterContainerConfigurationFactory.java
+++ b/test/e2e/operation/transaction/src/test/java/org/apache/shardingsphere/test/e2e/transaction/framework/container/config/proxy/ProxyClusterContainerConfigurationFactory.java
@@ -50,7 +50,7 @@ public final class ProxyClusterContainerConfigurationFactory {
     }
     
     private static Map<String, String> getMountedResource(final String scenario, final DatabaseType databaseType) {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put(String.format("/env/%s/server.yaml", databaseType.getType().toLowerCase()), ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER + "server.yaml");
         result.put("/env/scenario/" + scenario + "/proxy/conf/" + databaseType.getType().toLowerCase(), ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
         return result;
diff --git a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/compose/ContainerComposerRegistry.java b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/compose/ContainerComposerRegistry.java
index fc4158b203e..412c8269652 100644
--- a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/compose/ContainerComposerRegistry.java
+++ b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/compose/ContainerComposerRegistry.java
@@ -34,7 +34,7 @@ import java.util.Map;
  */
 public final class ContainerComposerRegistry implements AutoCloseable {
     
-    private final Map<String, ContainerComposer> containerComposers = new HashMap<>(7, 1);
+    private final Map<String, ContainerComposer> containerComposers = new HashMap<>(7, 1F);
     
     /**
      * Get container composer.
diff --git a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyClusterContainerConfigurationFactory.java b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyClusterContainerConfigurationFactory.java
index 94c3dbdcdf4..1e18a7c25c9 100644
--- a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyClusterContainerConfigurationFactory.java
+++ b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyClusterContainerConfigurationFactory.java
@@ -45,7 +45,7 @@ public final class ProxyClusterContainerConfigurationFactory {
     }
     
     private static Map<String, String> getMountedResources(final String scenario, final DatabaseType databaseType) {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("/env/common/cluster/proxy/conf/", ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
         result.put("/env/scenario/" + scenario + "/proxy/conf/" + databaseType.getType().toLowerCase(), ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
         return result;
diff --git a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyStandaloneContainerConfigurationFactory.java b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyStandaloneContainerConfigurationFactory.java
index e7055a71d44..332c52223a1 100644
--- a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyStandaloneContainerConfigurationFactory.java
+++ b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/container/config/ProxyStandaloneContainerConfigurationFactory.java
@@ -45,7 +45,7 @@ public final class ProxyStandaloneContainerConfigurationFactory {
     }
     
     private static Map<String, String> getMountedResources(final String scenario, final DatabaseType databaseType) {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("/env/common/standalone/proxy/conf/", ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
         result.put("/env/scenario/" + scenario + "/proxy/conf/" + databaseType.getType().toLowerCase(), ProxyContainerConstants.CONFIG_PATH_IN_CONTAINER);
         return result;
diff --git a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/env/DataSetEnvironmentManager.java b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/env/DataSetEnvironmentManager.java
index 391d2c630df..bf37607757f 100644
--- a/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/env/DataSetEnvironmentManager.java
+++ b/test/e2e/sql/src/test/java/org/apache/shardingsphere/test/e2e/env/DataSetEnvironmentManager.java
@@ -100,7 +100,7 @@ public final class DataSetEnvironmentManager {
     }
     
     private Map<DataNode, List<DataSetRow>> getDataSetRowMap() {
-        Map<DataNode, List<DataSetRow>> result = new LinkedHashMap<>(dataSet.getRows().size(), 1);
+        Map<DataNode, List<DataSetRow>> result = new LinkedHashMap<>(dataSet.getRows().size(), 1F);
         for (DataSetRow each : dataSet.getRows()) {
             DataNode dataNode = new DataNode(each.getDataNode());
             if (!result.containsKey(dataNode)) {
diff --git a/test/fixture/infra/src/main/java/org/apache/shardingsphere/test/fixture/infra/datasource/pool/metadata/MockedDataSourcePoolMetaData.java b/test/fixture/infra/src/main/java/org/apache/shardingsphere/test/fixture/infra/datasource/pool/metadata/MockedDataSourcePoolMetaData.java
index 8068499261a..bd8f994d481 100644
--- a/test/fixture/infra/src/main/java/org/apache/shardingsphere/test/fixture/infra/datasource/pool/metadata/MockedDataSourcePoolMetaData.java
+++ b/test/fixture/infra/src/main/java/org/apache/shardingsphere/test/fixture/infra/datasource/pool/metadata/MockedDataSourcePoolMetaData.java
@@ -39,7 +39,7 @@ public final class MockedDataSourcePoolMetaData implements DataSourcePoolMetaDat
     
     @Override
     public Map<String, Object> getInvalidProperties() {
-        Map<String, Object> result = new HashMap<>(2, 1);
+        Map<String, Object> result = new HashMap<>(2, 1F);
         result.put("maxPoolSize", -1);
         result.put("minPoolSize", -1);
         return result;
@@ -47,7 +47,7 @@ public final class MockedDataSourcePoolMetaData implements DataSourcePoolMetaDat
     
     @Override
     public Map<String, String> getPropertySynonyms() {
-        Map<String, String> result = new HashMap<>(2, 1);
+        Map<String, String> result = new HashMap<>(2, 1F);
         result.put("maxPoolSize", "maxPoolSize");
         result.put("minPoolSize", "minPoolSize");
         return result;
diff --git a/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/jaxb/RootSQLParserTestCases.java b/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/jaxb/RootSQLParserTestCases.java
index 0fc44915ed5..18468059442 100644
--- a/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/jaxb/RootSQLParserTestCases.java
+++ b/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/jaxb/RootSQLParserTestCases.java
@@ -1691,7 +1691,7 @@ public final class RootSQLParserTestCases {
     }
     
     private Map<String, SQLParserTestCase> getTestCaseMap(final List<? extends SQLParserTestCase> cases) {
-        Map<String, SQLParserTestCase> result = new HashMap<>(cases.size(), 1);
+        Map<String, SQLParserTestCase> result = new HashMap<>(cases.size(), 1F);
         for (SQLParserTestCase each : cases) {
             checkDuplicatedTestCase(each, result);
             result.put(each.getSqlCaseId(), each);
diff --git a/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/loader/SQLParserTestCaseLoaderCallback.java b/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/loader/SQLParserTestCaseLoaderCallback.java
index ec761816f01..cc5277e96cc 100644
--- a/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/loader/SQLParserTestCaseLoaderCallback.java
+++ b/test/it/parser/src/main/java/org/apache/shardingsphere/test/it/sql/parser/internal/cases/parser/loader/SQLParserTestCaseLoaderCallback.java
@@ -42,7 +42,7 @@ public final class SQLParserTestCaseLoaderCallback implements CaseLoaderCallback
     
     @Override
     public Map<String, SQLParserTestCase> loadFromJar(final File jarFile, final String rootDirectory) throws JAXBException {
-        Map<String, SQLParserTestCase> result = new HashMap<>(Short.MAX_VALUE, 1);
+        Map<String, SQLParserTestCase> result = new HashMap<>(Short.MAX_VALUE, 1F);
         for (String each : CaseFileLoader.loadFileNamesFromJar(jarFile, rootDirectory)) {
             Map<String, SQLParserTestCase> testCases = createTestCases(Thread.currentThread().getContextClassLoader().getResourceAsStream(each));
             checkDuplicatedTestCases(testCases, result);
@@ -53,7 +53,7 @@ public final class SQLParserTestCaseLoaderCallback implements CaseLoaderCallback
     
     @Override
     public Map<String, SQLParserTestCase> loadFromDirectory(final String rootDirectory) throws IOException, JAXBException {
-        Map<String, SQLParserTestCase> result = new HashMap<>(Short.MAX_VALUE, 1);
+        Map<String, SQLParserTestCase> result = new HashMap<>(Short.MAX_VALUE, 1F);
         for (File each : CaseFileLoader.loadFilesFromDirectory(rootDirectory)) {
             try (InputStream inputStream = Files.newInputStream(Paths.get(each.toURI()))) {
                 Map<String, SQLParserTestCase> testCases = createTestCases(inputStream);
diff --git a/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/core/util/PipelineContextUtils.java b/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/core/util/PipelineContextUtils.java
index 8635f8435e3..e4bc92a0a5f 100644
--- a/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/core/util/PipelineContextUtils.java
+++ b/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/core/util/PipelineContextUtils.java
@@ -104,7 +104,7 @@ public final class PipelineContextUtils {
     }
     
     private static MetaDataContexts renewMetaDataContexts(final MetaDataContexts old, final MetaDataPersistService persistService) {
-        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1);
+        Map<String, ShardingSphereTable> tables = new HashMap<>(3, 1F);
         tables.put("t_order", new ShardingSphereTable("t_order", Arrays.asList(
                 new ShardingSphereColumn("order_id", Types.INTEGER, true, false, false, true, false),
                 new ShardingSphereColumn("user_id", Types.INTEGER, false, false, false, true, false),
diff --git a/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/scenario/migration/api/impl/MigrationJobAPITest.java b/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/scenario/migration/api/impl/MigrationJobAPITest.java
index 8b1fc05d53d..cc38c103e54 100644
--- a/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/scenario/migration/api/impl/MigrationJobAPITest.java
+++ b/test/it/pipeline/src/test/java/org/apache/shardingsphere/test/it/data/pipeline/scenario/migration/api/impl/MigrationJobAPITest.java
@@ -196,7 +196,7 @@ class MigrationJobAPITest {
         DataConsistencyCountCheckResult equalCountCheckResult = new DataConsistencyCountCheckResult(100, 100);
         DataConsistencyCountCheckResult notEqualCountCheckResult = new DataConsistencyCountCheckResult(100, 95);
         DataConsistencyContentCheckResult equalContentCheckResult = new DataConsistencyContentCheckResult(false);
-        Map<String, DataConsistencyCheckResult> checkResults = new LinkedHashMap<>(2, 1);
+        Map<String, DataConsistencyCheckResult> checkResults = new LinkedHashMap<>(2, 1F);
         checkResults.put("foo_tbl", new DataConsistencyCheckResult(equalCountCheckResult, equalContentCheckResult));
         checkResults.put("bar_tbl", new DataConsistencyCheckResult(notEqualCountCheckResult, equalContentCheckResult));
         assertFalse(jobAPI.aggregateDataConsistencyCheckResults("foo_job", checkResults));
@@ -207,7 +207,7 @@ class MigrationJobAPITest {
         DataConsistencyCountCheckResult equalCountCheckResult = new DataConsistencyCountCheckResult(100, 100);
         DataConsistencyContentCheckResult equalContentCheckResult = new DataConsistencyContentCheckResult(true);
         DataConsistencyContentCheckResult notEqualContentCheckResult = new DataConsistencyContentCheckResult(false);
-        Map<String, DataConsistencyCheckResult> checkResults = new LinkedHashMap<>(2, 1);
+        Map<String, DataConsistencyCheckResult> checkResults = new LinkedHashMap<>(2, 1F);
         checkResults.put("foo_tbl", new DataConsistencyCheckResult(equalCountCheckResult, equalContentCheckResult));
         checkResults.put("bar_tbl", new DataConsistencyCheckResult(equalCountCheckResult, notEqualContentCheckResult));
         assertFalse(jobAPI.aggregateDataConsistencyCheckResults("foo_job", checkResults));
@@ -217,7 +217,7 @@ class MigrationJobAPITest {
     void assertAggregateSameDataConsistencyCheckResults() {
         DataConsistencyCountCheckResult equalCountCheckResult = new DataConsistencyCountCheckResult(100, 100);
         DataConsistencyContentCheckResult equalContentCheckResult = new DataConsistencyContentCheckResult(true);
-        Map<String, DataConsistencyCheckResult> checkResults = new LinkedHashMap<>(2, 1);
+        Map<String, DataConsistencyCheckResult> checkResults = new LinkedHashMap<>(2, 1F);
         checkResults.put("foo_tbl", new DataConsistencyCheckResult(equalCountCheckResult, equalContentCheckResult));
         checkResults.put("bar_tbl", new DataConsistencyCheckResult(equalCountCheckResult, equalContentCheckResult));
         assertTrue(jobAPI.aggregateDataConsistencyCheckResults("foo_job", checkResults));
diff --git a/test/it/rewriter/src/test/java/org/apache/shardingsphere/test/it/rewrite/engine/SQLRewriterIT.java b/test/it/rewriter/src/test/java/org/apache/shardingsphere/test/it/rewrite/engine/SQLRewriterIT.java
index 2d4c227edd6..efc10f2e867 100644
--- a/test/it/rewriter/src/test/java/org/apache/shardingsphere/test/it/rewrite/engine/SQLRewriterIT.java
+++ b/test/it/rewriter/src/test/java/org/apache/shardingsphere/test/it/rewrite/engine/SQLRewriterIT.java
@@ -126,7 +126,7 @@ public abstract class SQLRewriterIT {
         databaseRules.add(sqlParserRule);
         databaseRules.add(timestampServiceRule);
         ShardingSphereDatabase database = new ShardingSphereDatabase(schemaName, databaseType, resourceMetaData, new ShardingSphereRuleMetaData(databaseRules), mockSchemas(schemaName));
-        Map<String, ShardingSphereDatabase> databases = new HashMap<>(2, 1);
+        Map<String, ShardingSphereDatabase> databases = new HashMap<>(2, 1F);
         databases.put(schemaName, database);
         SQLStatementContext sqlStatementContext = SQLStatementContextFactory.newInstance(createShardingSphereMetaData(databases), sqlStatement, schemaName);
         if (sqlStatementContext instanceof ParameterAware) {
@@ -152,7 +152,7 @@ public abstract class SQLRewriterIT {
     }
     
     private Map<String, DatabaseType> createStorageTypes(final DatabaseConfiguration databaseConfig, final DatabaseType databaseType) {
-        Map<String, DatabaseType> result = new LinkedHashMap<>(databaseConfig.getDataSources().size(), 1);
+        Map<String, DatabaseType> result = new LinkedHashMap<>(databaseConfig.getDataSources().size(), 1F);
         for (Entry<String, DataSource> entry : databaseConfig.getDataSources().entrySet()) {
             result.put(entry.getKey(), databaseType);
         }