This is an automated email from the ASF dual-hosted git repository. zhonghongsheng 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 482fa3517ef Change unnecessary ArrayList to LinkedList (#17246) 482fa3517ef is described below commit 482fa3517efc2f1515549a0dd9cda85dc6240e05 Author: Liang Zhang <zhangli...@apache.org> AuthorDate: Sun May 1 12:23:05 2022 +0800 Change unnecessary ArrayList to LinkedList (#17246) --- .../advice/ComposeConstructorAdviceTest.java | 107 ++++++++++----------- ...eateReadwriteSplittingRuleStatementUpdater.java | 4 +- .../type/complex/ShardingComplexRoutingEngine.java | 4 +- .../yaml/config/YamlShardingRuleConfiguration.java | 6 +- .../DropShardingTableRuleStatementUpdater.java | 6 +- .../segment/projection/ProjectionsConverter.java | 3 +- ...DataMatchDataConsistencyCalculateAlgorithm.java | 6 +- .../data/pipeline/core/task/IncrementalTask.java | 4 +- .../rulealtered/prepare/InventoryTaskSplitter.java | 3 +- .../datasource/OpenGaussDataSourcePreparer.java | 3 +- .../ProcessRegistrySubscriberTestNoMock.java | 4 +- .../text/query/MySQLMultiStatementsHandler.java | 3 +- .../spi/ShardingSphereServiceLoader.java | 3 +- .../test/opentelemetry/OpenTelemetryPluginIT.java | 4 +- 14 files changed, 78 insertions(+), 82 deletions(-) diff --git a/shardingsphere-agent/shardingsphere-agent-core/src/test/java/org/apache/shardingsphere/agent/core/bytebuddy/transformer/advice/ComposeConstructorAdviceTest.java b/shardingsphere-agent/shardingsphere-agent-core/src/test/java/org/apache/shardingsphere/agent/core/bytebuddy/transformer/advice/ComposeConstructorAdviceTest.java index 333b49abde1..3b0756a6c24 100644 --- a/shardingsphere-agent/shardingsphere-agent-core/src/test/java/org/apache/shardingsphere/agent/core/bytebuddy/transformer/advice/ComposeConstructorAdviceTest.java +++ b/shardingsphere-agent/shardingsphere-agent-core/src/test/java/org/apache/shardingsphere/agent/core/bytebuddy/transformer/advice/ComposeConstructorAdviceTest.java @@ -1,54 +1,53 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with - * this work for additional information regarding copyright ownership. - * The ASF licenses this file to You under the Apache License, Version 2.0 - * (the "License"); you may not use this file except in compliance with - * the License. You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, - * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. - * See the License for the specific language governing permissions and - * limitations under the License. - */ - -package org.apache.shardingsphere.agent.core.bytebuddy.transformer.advice; - -import org.apache.shardingsphere.agent.api.advice.AdviceTargetObject; -import org.apache.shardingsphere.agent.api.advice.ConstructorAdvice; -import org.junit.Before; -import org.junit.Test; -import org.junit.runner.RunWith; -import org.mockito.Mock; -import org.mockito.junit.MockitoJUnitRunner; - -import java.util.ArrayList; -import java.util.Collections; - -import static org.mockito.Mockito.mock; -import static org.mockito.Mockito.verify; - -@RunWith(MockitoJUnitRunner.class) -public final class ComposeConstructorAdviceTest { - - @Mock - private ConstructorAdvice constructorAdvice; - - private ComposeConstructorAdvice actual; - - @Before - public void setUp() { - actual = new ComposeConstructorAdvice(new ArrayList<>(Collections.singletonList(constructorAdvice))); - } - - @Test - public void assertOnConstructor() { - AdviceTargetObject adviceTargetObject = mock(AdviceTargetObject.class); - Object[] args = new Object[2]; - actual.onConstructor(adviceTargetObject, args); - verify(constructorAdvice).onConstructor(adviceTargetObject, args); - } -} +/* + * Licensed to the Apache Software Foundation (ASF) under one or more + * contributor license agreements. See the NOTICE file distributed with + * this work for additional information regarding copyright ownership. + * The ASF licenses this file to You under the Apache License, Version 2.0 + * (the "License"); you may not use this file except in compliance with + * the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, software + * distributed under the License is distributed on an "AS IS" BASIS, + * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. + * See the License for the specific language governing permissions and + * limitations under the License. + */ + +package org.apache.shardingsphere.agent.core.bytebuddy.transformer.advice; + +import org.apache.shardingsphere.agent.api.advice.AdviceTargetObject; +import org.apache.shardingsphere.agent.api.advice.ConstructorAdvice; +import org.junit.Before; +import org.junit.Test; +import org.junit.runner.RunWith; +import org.mockito.Mock; +import org.mockito.junit.MockitoJUnitRunner; + +import java.util.Collections; + +import static org.mockito.Mockito.mock; +import static org.mockito.Mockito.verify; + +@RunWith(MockitoJUnitRunner.class) +public final class ComposeConstructorAdviceTest { + + @Mock + private ConstructorAdvice constructorAdvice; + + private ComposeConstructorAdvice actual; + + @Before + public void setUp() { + actual = new ComposeConstructorAdvice(Collections.singleton(constructorAdvice)); + } + + @Test + public void assertOnConstructor() { + AdviceTargetObject adviceTargetObject = mock(AdviceTargetObject.class); + Object[] args = new Object[2]; + actual.onConstructor(adviceTargetObject, args); + verify(constructorAdvice).onConstructor(adviceTargetObject, args); + } +} diff --git a/shardingsphere-features/shardingsphere-readwrite-splitting/shardingsphere-readwrite-splitting-distsql/shardingsphere-readwrite-splitting-distsql-handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/update/CreateReadwriteSplittingRuleStatementUpdater.java b/shardingsphere-features/shardingsphere-readwrite-splitting/shardingsphere-readwrite-splitting-distsql/shardingsphere-readwrite-splitting-distsql-handler/src/main/java/org/apache/shardingsphere/ [...] index 128446b2236..c33aa03a7ac 100644 --- a/shardingsphere-features/shardingsphere-readwrite-splitting/shardingsphere-readwrite-splitting-distsql/shardingsphere-readwrite-splitting-distsql-handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/update/CreateReadwriteSplittingRuleStatementUpdater.java +++ b/shardingsphere-features/shardingsphere-readwrite-splitting/shardingsphere-readwrite-splitting-distsql/shardingsphere-readwrite-splitting-distsql-handler/src/main/java/org/apache/shardingsphere/readwritesplitting/distsql/handler/update/CreateReadwriteSplittingRuleStatementUpdater.java @@ -35,10 +35,10 @@ import org.apache.shardingsphere.readwritesplitting.distsql.parser.segment.Readw import org.apache.shardingsphere.readwritesplitting.distsql.parser.statement.CreateReadwriteSplittingRuleStatement; import org.apache.shardingsphere.readwritesplitting.factory.ReplicaLoadBalanceAlgorithmFactory; -import java.util.ArrayList; import java.util.Collection; import java.util.Collections; import java.util.LinkedHashSet; +import java.util.LinkedList; import java.util.Map; import java.util.Objects; import java.util.Optional; @@ -61,7 +61,7 @@ public final class CreateReadwriteSplittingRuleStatementUpdater implements RuleD private void checkDuplicateRuleNames(final String databaseName, final CreateReadwriteSplittingRuleStatement sqlStatement, final ReadwriteSplittingRuleConfiguration currentRuleConfig, final ShardingSphereResource resource) throws DistSQLException { - Collection<String> currentRuleNames = new ArrayList<>(); + Collection<String> currentRuleNames = new LinkedList<>(); if (null != resource && null != resource.getDataSources()) { currentRuleNames.addAll(resource.getDataSources().keySet()); } diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingComplexRoutingEngine.java b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingComplexRoutingEngine.java index 1d09eb939b2..bd5462e7990 100644 --- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingComplexRoutingEngine.java +++ b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/route/engine/type/complex/ShardingComplexRoutingEngine.java @@ -27,8 +27,8 @@ import org.apache.shardingsphere.sharding.route.engine.type.standard.ShardingSta import org.apache.shardingsphere.sharding.rule.ShardingRule; import org.apache.shardingsphere.sharding.rule.TableRule; -import java.util.ArrayList; import java.util.Collection; +import java.util.LinkedList; import java.util.Optional; import java.util.TreeSet; @@ -48,7 +48,7 @@ public final class ShardingComplexRoutingEngine implements ShardingRouteEngine { public RouteContext route(final ShardingRule shardingRule) { RouteContext result = new RouteContext(); Collection<String> bindingTableNames = new TreeSet<>(String.CASE_INSENSITIVE_ORDER); - Collection<RouteContext> routeContexts = new ArrayList<>(logicTables.size()); + Collection<RouteContext> routeContexts = new LinkedList<>(); for (String each : logicTables) { Optional<TableRule> tableRule = shardingRule.findTableRule(each); if (tableRule.isPresent()) { diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/yaml/config/YamlShardingRuleConfiguration.java b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/yaml/config/YamlShardingRuleConfiguration.java index 7a831569475..1351c8e932d 100644 --- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/yaml/config/YamlShardingRuleConfiguration.java +++ b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-core/src/main/java/org/apache/shardingsphere/sharding/yaml/config/YamlShardingRuleConfiguration.java @@ -28,9 +28,9 @@ import org.apache.shardingsphere.sharding.yaml.config.rule.YamlTableRuleConfigur import org.apache.shardingsphere.sharding.yaml.config.strategy.keygen.YamlKeyGenerateStrategyConfiguration; import org.apache.shardingsphere.sharding.yaml.config.strategy.sharding.YamlShardingStrategyConfiguration; -import java.util.ArrayList; import java.util.Collection; import java.util.LinkedHashMap; +import java.util.LinkedList; import java.util.Map; /** @@ -44,9 +44,9 @@ public final class YamlShardingRuleConfiguration implements YamlRuleConfiguratio private Map<String, YamlShardingAutoTableRuleConfiguration> autoTables = new LinkedHashMap<>(); - private Collection<String> bindingTables = new ArrayList<>(); + private Collection<String> bindingTables = new LinkedList<>(); - private Collection<String> broadcastTables = new ArrayList<>(); + private Collection<String> broadcastTables = new LinkedList<>(); private YamlShardingStrategyConfiguration defaultDatabaseStrategy; diff --git a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-distsql/shardingsphere-sharding-distsql-handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/update/DropShardingTableRuleStatementUpdater.java b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-distsql/shardingsphere-sharding-distsql-handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/update/DropShardingTableRuleStatementUpdater.java index b74f4e1d505..6bb67b938d3 100644 --- a/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-distsql/shardingsphere-sharding-distsql-handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/update/DropShardingTableRuleStatementUpdater.java +++ b/shardingsphere-features/shardingsphere-sharding/shardingsphere-sharding-distsql/shardingsphere-sharding-distsql-handler/src/main/java/org/apache/shardingsphere/sharding/distsql/handler/update/DropShardingTableRuleStatementUpdater.java @@ -29,7 +29,6 @@ import org.apache.shardingsphere.sharding.api.config.rule.ShardingTableRuleConfi import org.apache.shardingsphere.sharding.api.config.strategy.sharding.ShardingStrategyConfiguration; import org.apache.shardingsphere.sharding.distsql.parser.statement.DropShardingTableRuleStatement; -import java.util.ArrayList; import java.util.Arrays; import java.util.Collection; import java.util.LinkedHashSet; @@ -102,11 +101,10 @@ public final class DropShardingTableRuleStatementUpdater implements RuleDefiniti if (null == currentRuleConfig) { return false; } - Collection<String> currentTableNames = new ArrayList<>(currentRuleConfig.getTables().size() + currentRuleConfig.getAutoTables().size()); + Collection<String> currentTableNames = new LinkedList<>(); currentTableNames.addAll(currentRuleConfig.getTables().stream().map(ShardingTableRuleConfiguration::getLogicTable).collect(Collectors.toSet())); currentTableNames.addAll(currentRuleConfig.getAutoTables().stream().map(ShardingAutoTableRuleConfiguration::getLogicTable).collect(Collectors.toSet())); - return !getIdenticalData(currentTableNames, - sqlStatement.getTableNames().stream().map(each -> each.getIdentifier().getValue()).collect(Collectors.toSet())).isEmpty(); + return !getIdenticalData(currentTableNames, sqlStatement.getTableNames().stream().map(each -> each.getIdentifier().getValue()).collect(Collectors.toSet())).isEmpty(); } @Override diff --git a/shardingsphere-infra/shardingsphere-infra-federation/shardingsphere-infra-federation-optimizer/src/main/java/org/apache/shardingsphere/infra/federation/optimizer/converter/segment/projection/ProjectionsConverter.java b/shardingsphere-infra/shardingsphere-infra-federation/shardingsphere-infra-federation-optimizer/src/main/java/org/apache/shardingsphere/infra/federation/optimizer/converter/segment/projection/ProjectionsConverter.java index e1571636322..b52a2bfae10 100644 --- a/shardingsphere-infra/shardingsphere-infra-federation/shardingsphere-infra-federation-optimizer/src/main/java/org/apache/shardingsphere/infra/federation/optimizer/converter/segment/projection/ProjectionsConverter.java +++ b/shardingsphere-infra/shardingsphere-infra-federation/shardingsphere-infra-federation-optimizer/src/main/java/org/apache/shardingsphere/infra/federation/optimizer/converter/segment/projection/ProjectionsConverter.java @@ -44,6 +44,7 @@ import org.apache.shardingsphere.sql.parser.sql.common.segment.dml.item.Subquery import java.util.ArrayList; import java.util.Collection; +import java.util.LinkedList; import java.util.List; import java.util.Optional; @@ -54,7 +55,7 @@ public final class ProjectionsConverter implements SQLSegmentConverter<Projectio @Override public Optional<SqlNodeList> convertToSQLNode(final ProjectionsSegment segment) { - Collection<SqlNode> projectionSQLNodes = new ArrayList<>(segment.getProjections().size()); + Collection<SqlNode> projectionSQLNodes = new LinkedList<>(); for (ProjectionSegment each : segment.getProjections()) { getProjectionSQLNode(each).ifPresent(projectionSQLNodes::add); } diff --git a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/check/consistency/algorithm/DataMatchDataConsistencyCalculateAlgorithm.java b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/check/consistency/algorithm/DataMatchDataConsistencyCalculateAlgorithm.java index dce36b57c3f..0450bd517a0 100644 --- a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/check/consistency/algorithm/DataMatchDataConsistencyCalculateAlgorithm.java +++ b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/check/consistency/algorithm/DataMatchDataConsistencyCalculateAlgorithm.java @@ -38,9 +38,9 @@ import java.sql.ResultSet; import java.sql.ResultSetMetaData; import java.sql.SQLException; import java.sql.SQLXML; -import java.util.ArrayList; import java.util.Collection; import java.util.Iterator; +import java.util.LinkedList; import java.util.Optional; import java.util.Properties; @@ -97,13 +97,13 @@ public final class DataMatchDataConsistencyCalculateAlgorithm extends AbstractSt PreparedStatement preparedStatement = connection.prepareStatement(sql)) { preparedStatement.setObject(1, startUniqueKeyValue); preparedStatement.setInt(2, chunkSize); - Collection<Collection<Object>> records = new ArrayList<>(chunkSize); + Collection<Collection<Object>> records = new LinkedList<>(); Number maxUniqueKeyValue = null; try (ResultSet resultSet = preparedStatement.executeQuery()) { while (resultSet.next()) { ResultSetMetaData resultSetMetaData = resultSet.getMetaData(); int columnCount = resultSetMetaData.getColumnCount(); - Collection<Object> record = new ArrayList<>(columnCount); + Collection<Object> record = new LinkedList<>(); for (int columnIndex = 1; columnIndex <= columnCount; columnIndex++) { record.add(resultSet.getObject(columnIndex)); } diff --git a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java index a40065efeb5..2b2c4639b88 100644 --- a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java +++ b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/core/task/IncrementalTask.java @@ -39,8 +39,8 @@ import org.apache.shardingsphere.data.pipeline.spi.ingest.dumper.Dumper; import org.apache.shardingsphere.scaling.core.job.dumper.DumperFactory; import org.apache.shardingsphere.scaling.core.job.importer.ImporterFactory; -import java.util.ArrayList; import java.util.Collection; +import java.util.LinkedList; import java.util.concurrent.ExecutionException; import java.util.concurrent.Future; @@ -87,7 +87,7 @@ public final class IncrementalTask extends AbstractLifecycleExecutor implements } private Collection<Importer> createImporters(final int concurrency, final ImporterConfiguration importerConfig, final PipelineDataSourceManager dataSourceManager, final PipelineChannel channel) { - Collection<Importer> result = new ArrayList<>(concurrency); + Collection<Importer> result = new LinkedList<>(); for (int i = 0; i < concurrency; i++) { result.add(ImporterFactory.createImporter(importerConfig, dataSourceManager, channel)); } diff --git a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/rulealtered/prepare/InventoryTaskSplitter.java b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/rulealtered/prepare/InventoryTaskSplitter.java index 9ed950d09dd..6bbafec78de 100644 --- a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/rulealtered/prepare/InventoryTaskSplitter.java +++ b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-core/src/main/java/org/apache/shardingsphere/data/pipeline/scenario/rulealtered/prepare/InventoryTaskSplitter.java @@ -49,7 +49,6 @@ import java.sql.PreparedStatement; import java.sql.ResultSet; import java.sql.SQLException; import java.sql.Types; -import java.util.ArrayList; import java.util.Collection; import java.util.LinkedList; import java.util.List; @@ -178,7 +177,7 @@ public final class InventoryTaskSplitter { } private Collection<IngestPosition<?>> getPositionByPrimaryKeyRange(final RuleAlteredJobContext jobContext, final DataSource dataSource, final InventoryDumperConfiguration dumperConfig) { - Collection<IngestPosition<?>> result = new ArrayList<>(); + Collection<IngestPosition<?>> result = new LinkedList<>(); RuleAlteredJobConfiguration jobConfig = jobContext.getJobConfig(); String sql = PipelineSQLBuilderFactory.newInstance(jobConfig.getSourceDatabaseType()) .buildSplitByPrimaryKeyRangeSQL(dumperConfig.getActualTableName(), dumperConfig.getPrimaryKey()); diff --git a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-dialect/shardingsphere-data-pipeline-opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussDataSourcePreparer.java b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-dialect/shardingsphere-data-pipeline-opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussDataSourcePreparer.java index 86b9234f20f..19552851150 100644 --- a/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-dialect/shardingsphere-data-pipeline-opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussDataSourcePreparer.java +++ b/shardingsphere-kernel/shardingsphere-data-pipeline/shardingsphere-data-pipeline-dialect/shardingsphere-data-pipeline-opengauss/src/main/java/org/apache/shardingsphere/data/pipeline/opengauss/prepare/datasource/OpenGaussDataSourcePreparer.java @@ -38,6 +38,7 @@ import java.sql.Statement; import java.util.ArrayList; import java.util.Collection; import java.util.HashMap; +import java.util.LinkedList; import java.util.List; import java.util.Map; import java.util.Map.Entry; @@ -73,7 +74,7 @@ public final class OpenGaussDataSourcePreparer extends AbstractDataSourcePrepare } private Collection<ActualTableDefinition> getActualTableDefinitions(final PrepareTargetTablesParameter parameter) throws SQLException { - Collection<ActualTableDefinition> result = new ArrayList<>(); + Collection<ActualTableDefinition> result = new LinkedList<>(); ShardingSpherePipelineDataSourceConfiguration sourceDataSourceConfig = (ShardingSpherePipelineDataSourceConfiguration) PipelineDataSourceConfigurationFactory.newInstance( parameter.getJobConfig().getSource().getType(), parameter.getJobConfig().getSource().getParameter()); // TODO reuse PipelineDataSourceManager diff --git a/shardingsphere-mode/shardingsphere-mode-type/shardingsphere-cluster-mode/shardingsphere-cluster-mode-core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/process/subscriber/ProcessRegistrySubscriberTestNoMock.java b/shardingsphere-mode/shardingsphere-mode-type/shardingsphere-cluster-mode/shardingsphere-cluster-mode-core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/process/subscriber/ProcessRegistrySubscrib [...] index 85452d1d36c..be9bfc12ac8 100644 --- a/shardingsphere-mode/shardingsphere-mode-type/shardingsphere-cluster-mode/shardingsphere-cluster-mode-core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/process/subscriber/ProcessRegistrySubscriberTestNoMock.java +++ b/shardingsphere-mode/shardingsphere-mode-type/shardingsphere-cluster-mode/shardingsphere-cluster-mode-core/src/test/java/org/apache/shardingsphere/mode/manager/cluster/coordinator/registry/process/subscriber/ProcessRegistrySubscriberTestNoMock.java @@ -39,9 +39,9 @@ import org.junit.Test; import org.junit.runner.RunWith; import org.mockito.junit.MockitoJUnitRunner; -import java.util.ArrayList; import java.util.Collection; import java.util.Collections; +import java.util.LinkedList; import static org.hamcrest.CoreMatchers.is; import static org.junit.Assert.assertNotNull; @@ -57,7 +57,7 @@ public final class ProcessRegistrySubscriberTestNoMock { private ExecuteProcessContext createExecuteProcessContext() { ExecutionUnit executionUnit = createExecuteUnit(); - Collection<ExecutionGroup<JDBCExecutionUnit>> inputGroups = new ArrayList<>(); + Collection<ExecutionGroup<JDBCExecutionUnit>> inputGroups = new LinkedList<>(); inputGroups.add(new ExecutionGroup<>(Collections.singletonList(new JDBCExecutionUnit(executionUnit, ConnectionMode.MEMORY_STRICTLY, null)))); ExecutionGroupContext<JDBCExecutionUnit> executionGroupContext = new ExecutionGroupContext<>(inputGroups); executionGroupContext.setSchemaName("sharding_db"); diff --git a/shardingsphere-proxy/shardingsphere-proxy-frontend/shardingsphere-proxy-frontend-mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandler.java b/shardingsphere-proxy/shardingsphere-proxy-frontend/shardingsphere-proxy-frontend-mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandler.java index 41edd3184f3..1089ba65ea7 100644 --- a/shardingsphere-proxy/shardingsphere-proxy-frontend/shardingsphere-proxy-frontend-mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandler.java +++ b/shardingsphere-proxy/shardingsphere-proxy-frontend/shardingsphere-proxy-frontend-mysql/src/main/java/org/apache/shardingsphere/proxy/frontend/mysql/command/query/text/query/MySQLMultiStatementsHandler.java @@ -56,7 +56,6 @@ import org.apache.shardingsphere.sql.parser.sql.common.statement.dml.UpdateState import java.sql.Connection; import java.sql.SQLException; import java.sql.Statement; -import java.util.ArrayList; import java.util.Arrays; import java.util.Collection; import java.util.Collections; @@ -146,7 +145,7 @@ public final class MySQLMultiStatementsHandler implements TextProtocolBackendHan } private Collection<ExecutionUnit> samplingExecutionUnit() { - Collection<ExecutionUnit> result = new ArrayList<>(dataSourcesToExecutionUnits.size()); + Collection<ExecutionUnit> result = new LinkedList<>(); for (List<ExecutionUnit> each : dataSourcesToExecutionUnits.values()) { result.add(each.get(0)); } diff --git a/shardingsphere-spi/src/main/java/org/apache/shardingsphere/spi/ShardingSphereServiceLoader.java b/shardingsphere-spi/src/main/java/org/apache/shardingsphere/spi/ShardingSphereServiceLoader.java index 9fcd2324dce..fefef89a50e 100644 --- a/shardingsphere-spi/src/main/java/org/apache/shardingsphere/spi/ShardingSphereServiceLoader.java +++ b/shardingsphere-spi/src/main/java/org/apache/shardingsphere/spi/ShardingSphereServiceLoader.java @@ -22,7 +22,6 @@ import lombok.NoArgsConstructor; import org.apache.shardingsphere.spi.annotation.SingletonSPI; import org.apache.shardingsphere.spi.exception.ServiceLoaderInstantiationException; -import java.util.ArrayList; import java.util.Collection; import java.util.Collections; import java.util.LinkedList; @@ -96,7 +95,7 @@ public final class ShardingSphereServiceLoader { if (services.isEmpty()) { return Collections.emptyList(); } - Collection<T> result = new ArrayList<>(services.size()); + Collection<T> result = new LinkedList<>(); for (Object each : services) { result.add((T) newServiceInstance(each.getClass())); } diff --git a/shardingsphere-test/shardingsphere-integration-agent-test/shardingsphere-integration-agent-test-plugins/shardingsphere-integration-agent-test-opentelemetry/src/test/java/org/apache/shardingsphere/integration/agent/test/opentelemetry/OpenTelemetryPluginIT.java b/shardingsphere-test/shardingsphere-integration-agent-test/shardingsphere-integration-agent-test-plugins/shardingsphere-integration-agent-test-opentelemetry/src/test/java/org/apache/shardingsphere/integration/agent/test [...] index 9c88d846d6f..259bb1c0bc9 100644 --- a/shardingsphere-test/shardingsphere-integration-agent-test/shardingsphere-integration-agent-test-plugins/shardingsphere-integration-agent-test-opentelemetry/src/test/java/org/apache/shardingsphere/integration/agent/test/opentelemetry/OpenTelemetryPluginIT.java +++ b/shardingsphere-test/shardingsphere-integration-agent-test/shardingsphere-integration-agent-test-plugins/shardingsphere-integration-agent-test-opentelemetry/src/test/java/org/apache/shardingsphere/integration/agent/test/opentelemetry/OpenTelemetryPluginIT.java @@ -28,8 +28,8 @@ import org.apache.shardingsphere.integration.agent.test.opentelemetry.result.Tra import org.junit.Test; import java.io.IOException; -import java.util.ArrayList; import java.util.Collection; +import java.util.LinkedList; import java.util.Map; import java.util.Properties; @@ -65,7 +65,7 @@ public final class OpenTelemetryPluginIT extends BasePluginIT { assertNotNull(response); JsonArray array = new JsonParser().parse(response).getAsJsonArray().get(0).getAsJsonArray(); Gson gson = new Gson(); - Collection<TracingResult> traces = new ArrayList<>(); + Collection<TracingResult> traces = new LinkedList<>(); array.forEach(element -> traces.add(gson.fromJson(element, TracingResult.class))); assertTraces(traces); }