You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ignite.apache.org by ib...@apache.org on 2022/09/16 06:53:35 UTC

[ignite-3] branch main updated: IGNITE-17693 Unified copyrights - extra spaces removed (#1083)

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

ibessonov pushed a commit to branch main
in repository https://gitbox.apache.org/repos/asf/ignite-3.git


The following commit(s) were added to refs/heads/main by this push:
     new fa79ad532b IGNITE-17693 Unified copyrights - extra spaces removed (#1083)
fa79ad532b is described below

commit fa79ad532b18c3a9cf277d09b4fd0e8cd25775e0
Author: Mikhail <Po...@users.noreply.github.com>
AuthorDate: Fri Sep 16 09:53:28 2022 +0300

    IGNITE-17693 Unified copyrights - extra spaces removed (#1083)
---
 check-rules/LICENSE.txt                                           | 4 ++--
 docs/assets/css/docs.scss                                         | 4 ++--
 docs/assets/css/styles.scss                                       | 4 ++--
 .../java/org/apache/ignite/example/AbstractExamplesTest.java      | 2 +-
 .../java/org/apache/ignite/example/ExampleTestUtils.java          | 2 +-
 .../java/org/apache/ignite/example/sql/ItSqlExamplesTest.java     | 2 +-
 .../ignite/example/storage/ItPageMemoryStorageExampleTest.java    | 2 +-
 .../ignite/example/storage/ItRocksdbStorageExampleTest.java       | 2 +-
 .../java/org/apache/ignite/example/table/ItTableExamplesTest.java | 2 +-
 .../org/apache/ignite/example/tx/ItTransactionsExamplesTest.java  | 2 +-
 .../main/java/org/apache/ignite/example/sql/SqlApiExample.java    | 2 +-
 .../java/org/apache/ignite/example/sql/jdbc/SqlJdbcExample.java   | 4 ++--
 .../example/storage/PersistentPageMemoryStorageExample.java       | 4 ++--
 .../org/apache/ignite/example/storage/RocksDbStorageExample.java  | 4 ++--
 .../org/apache/ignite/example/storage/StorageEngineExample.java   | 2 +-
 .../ignite/example/storage/VolatilePageMemoryStorageExample.java  | 4 ++--
 .../java/org/apache/ignite/example/table/KeyValueViewExample.java | 4 ++--
 .../org/apache/ignite/example/table/KeyValueViewPojoExample.java  | 4 ++--
 .../java/org/apache/ignite/example/table/RecordViewExample.java   | 4 ++--
 .../org/apache/ignite/example/table/RecordViewPojoExample.java    | 4 ++--
 .../java/org/apache/ignite/example/tx/TransactionsExample.java    | 4 ++--
 .../java/org/apache/ignite/internal/affinity/AffinityUtils.java   | 4 ++--
 .../ignite/internal/affinity/RendezvousAffinityFunction.java      | 4 ++--
 .../org/apache/ignite/internal/affinity/AffinityServiceTest.java  | 4 ++--
 .../ignite/internal/affinity/RendezvousAffinityFunctionTest.java  | 4 ++--
 modules/api/src/main/java/org/apache/ignite/Ignite.java           | 4 ++--
 modules/api/src/main/java/org/apache/ignite/Ignition.java         | 4 ++--
 modules/api/src/main/java/org/apache/ignite/IgnitionManager.java  | 4 ++--
 .../api/src/main/java/org/apache/ignite/binary/BinaryObject.java  | 4 ++--
 .../api/src/main/java/org/apache/ignite/binary/package-info.java  | 4 ++--
 .../api/src/main/java/org/apache/ignite/compute/ComputeJob.java   | 4 ++--
 .../src/main/java/org/apache/ignite/compute/IgniteCompute.java    | 4 ++--
 .../main/java/org/apache/ignite/compute/JobExecutionContext.java  | 4 ++--
 .../clientconnector/ClientConnectorConfigurationSchema.java       | 4 ++--
 .../configuration/schemas/clientconnector/package-info.java       | 4 ++--
 .../configuration/schemas/compute/ComputeConfigurationSchema.java | 4 ++--
 .../schemas/network/ClusterMembershipConfigurationSchema.java     | 4 ++--
 .../configuration/schemas/network/InboundConfigurationSchema.java | 4 ++--
 .../configuration/schemas/network/NetworkConfigurationSchema.java | 4 ++--
 .../schemas/network/NodeFinderConfigurationSchema.java            | 4 ++--
 .../ignite/configuration/schemas/network/NodeFinderType.java      | 4 ++--
 .../schemas/network/OutboundConfigurationSchema.java              | 4 ++--
 .../schemas/network/ScaleCubeConfigurationSchema.java             | 4 ++--
 .../apache/ignite/configuration/schemas/network/package-info.java | 4 ++--
 .../configuration/schemas/rest/RestConfigurationSchema.java       | 4 ++--
 .../apache/ignite/configuration/schemas/rest/package-info.java    | 4 ++--
 .../schemas/store/DataStorageConfigurationSchema.java             | 4 ++--
 .../ignite/configuration/schemas/store/ExistingDataStorage.java   | 4 ++--
 .../ignite/configuration/schemas/store/KnownDataStorage.java      | 4 ++--
 .../schemas/store/UnknownDataStorageConfigurationSchema.java      | 4 ++--
 .../configuration/schemas/table/ColumnConfigurationSchema.java    | 4 ++--
 .../schemas/table/ColumnDefaultConfigurationSchema.java           | 4 ++--
 .../schemas/table/ColumnTypeConfigurationSchema.java              | 4 ++--
 .../ignite/configuration/schemas/table/ColumnTypeValidator.java   | 4 ++--
 .../schemas/table/ConstantValueDefaultConfigurationSchema.java    | 4 ++--
 .../schemas/table/EntryCountBudgetConfigurationSchema.java        | 4 ++--
 .../schemas/table/FunctionCallDefaultConfigurationSchema.java     | 4 ++--
 .../configuration/schemas/table/HashIndexConfigurationSchema.java | 2 +-
 .../schemas/table/IndexColumnConfigurationSchema.java             | 4 ++--
 .../schemas/table/LogStorageBudgetConfigurationSchema.java        | 4 ++--
 .../schemas/table/NullValueDefaultConfigurationSchema.java        | 4 ++--
 .../schemas/table/PrimaryKeyConfigurationSchema.java              | 4 ++--
 .../schemas/table/SortedIndexConfigurationSchema.java             | 2 +-
 .../configuration/schemas/table/TableConfigurationSchema.java     | 4 ++--
 .../schemas/table/TableIndexConfigurationSchema.java              | 4 ++--
 .../apache/ignite/configuration/schemas/table/TableValidator.java | 4 ++--
 .../configuration/schemas/table/TablesConfigurationSchema.java    | 4 ++--
 .../schemas/table/UnlimitedBudgetConfigurationSchema.java         | 4 ++--
 .../schemas/table/VolatileRaftConfigurationSchema.java            | 4 ++--
 .../apache/ignite/configuration/schemas/table/package-info.java   | 4 ++--
 .../org/apache/ignite/internal/lang/IgniteExceptionUtils.java     | 4 ++--
 .../main/java/org/apache/ignite/internal/sql/ResultSetImpl.java   | 4 ++--
 .../org/apache/ignite/internal/sql/SqlColumnTypeConverter.java    | 4 ++--
 .../java/org/apache/ignite/lang/ColumnAlreadyExistsException.java | 4 ++--
 .../main/java/org/apache/ignite/lang/ColumnNotFoundException.java | 4 ++--
 .../main/java/org/apache/ignite/lang/IgniteCheckedException.java  | 4 ++--
 .../api/src/main/java/org/apache/ignite/lang/IgniteException.java | 4 ++--
 .../java/org/apache/ignite/lang/IndexAlreadyExistsException.java  | 4 ++--
 .../main/java/org/apache/ignite/lang/IndexNotFoundException.java  | 4 ++--
 .../src/main/java/org/apache/ignite/lang/MarshallerException.java | 4 ++--
 .../api/src/main/java/org/apache/ignite/lang/NullableValue.java   | 4 ++--
 .../java/org/apache/ignite/lang/TableAlreadyExistsException.java  | 4 ++--
 .../main/java/org/apache/ignite/lang/TableNotFoundException.java  | 4 ++--
 .../java/org/apache/ignite/lang/UnexpectedNullValueException.java | 4 ++--
 .../api/src/main/java/org/apache/ignite/lang/package-info.java    | 4 ++--
 .../api/src/main/java/org/apache/ignite/network/ClusterNode.java  | 4 ++--
 .../src/main/java/org/apache/ignite/network/NetworkAddress.java   | 4 ++--
 .../main/java/org/apache/ignite/network/TopologyEventHandler.java | 4 ++--
 .../src/main/java/org/apache/ignite/network/TopologyService.java  | 4 ++--
 modules/api/src/main/java/org/apache/ignite/package-info.java     | 4 ++--
 .../org/apache/ignite/schema/definition/ColumnDefinition.java     | 4 ++--
 .../main/java/org/apache/ignite/schema/definition/ColumnType.java | 4 ++--
 .../apache/ignite/schema/definition/DefaultValueDefinition.java   | 4 ++--
 .../apache/ignite/schema/definition/DefaultValueGenerators.java   | 4 ++--
 .../org/apache/ignite/schema/definition/PrimaryKeyDefinition.java | 4 ++--
 .../java/org/apache/ignite/schema/definition/SchemaObject.java    | 4 ++--
 .../java/org/apache/ignite/schema/definition/TableDefinition.java | 4 ++--
 .../ignite/schema/definition/index/ColumnarIndexDefinition.java   | 4 ++--
 .../ignite/schema/definition/index/HashIndexDefinition.java       | 4 ++--
 .../ignite/schema/definition/index/IndexColumnDefinition.java     | 4 ++--
 .../apache/ignite/schema/definition/index/IndexDefinition.java    | 4 ++--
 .../java/org/apache/ignite/schema/definition/index/SortOrder.java | 4 ++--
 .../schema/definition/index/SortedIndexColumnDefinition.java      | 4 ++--
 .../ignite/schema/definition/index/SortedIndexDefinition.java     | 4 ++--
 .../org/apache/ignite/schema/definition/index/package-info.java   | 4 ++--
 .../java/org/apache/ignite/schema/definition/package-info.java    | 4 ++--
 .../api/src/main/java/org/apache/ignite/sql/BatchedArguments.java | 4 ++--
 .../api/src/main/java/org/apache/ignite/sql/ColumnMetadata.java   | 4 ++--
 .../main/java/org/apache/ignite/sql/CursorClosedException.java    | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/IgniteSql.java    | 4 ++--
 .../java/org/apache/ignite/sql/NoRowSetExpectedException.java     | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/ResultSet.java    | 4 ++--
 .../src/main/java/org/apache/ignite/sql/ResultSetMetadata.java    | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/Session.java      | 4 ++--
 .../src/main/java/org/apache/ignite/sql/SqlBatchException.java    | 4 ++--
 .../api/src/main/java/org/apache/ignite/sql/SqlColumnType.java    | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/SqlException.java | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/SqlRow.java       | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/Statement.java    | 4 ++--
 .../src/main/java/org/apache/ignite/sql/async/AsyncResultSet.java | 4 ++--
 .../src/main/java/org/apache/ignite/sql/async/package-info.java   | 4 ++--
 modules/api/src/main/java/org/apache/ignite/sql/package-info.java | 4 ++--
 .../java/org/apache/ignite/sql/reactive/ReactiveResultSet.java    | 4 ++--
 .../main/java/org/apache/ignite/sql/reactive/package-info.java    | 4 ++--
 .../src/main/java/org/apache/ignite/table/InvocationContext.java  | 4 ++--
 .../src/main/java/org/apache/ignite/table/InvokeProcessor.java    | 4 ++--
 .../java/org/apache/ignite/table/InvokeProcessorException.java    | 4 ++--
 .../api/src/main/java/org/apache/ignite/table/KeyValueView.java   | 4 ++--
 modules/api/src/main/java/org/apache/ignite/table/RecordView.java | 4 ++--
 modules/api/src/main/java/org/apache/ignite/table/Table.java      | 4 ++--
 modules/api/src/main/java/org/apache/ignite/table/Tuple.java      | 4 ++--
 modules/api/src/main/java/org/apache/ignite/table/TupleImpl.java  | 4 ++--
 .../main/java/org/apache/ignite/table/manager/IgniteTables.java   | 4 ++--
 .../main/java/org/apache/ignite/table/manager/package-info.java   | 4 ++--
 .../api/src/main/java/org/apache/ignite/table/mapper/Mapper.java  | 4 ++--
 .../main/java/org/apache/ignite/table/mapper/MapperBuilder.java   | 4 ++--
 .../main/java/org/apache/ignite/table/mapper/OneColumnMapper.java | 4 ++--
 .../java/org/apache/ignite/table/mapper/OneColumnMapperImpl.java  | 4 ++--
 .../src/main/java/org/apache/ignite/table/mapper/PojoMapper.java  | 4 ++--
 .../main/java/org/apache/ignite/table/mapper/PojoMapperImpl.java  | 4 ++--
 .../main/java/org/apache/ignite/table/mapper/TypeConverter.java   | 4 ++--
 .../main/java/org/apache/ignite/table/mapper/package-info.java    | 4 ++--
 .../api/src/main/java/org/apache/ignite/table/package-info.java   | 4 ++--
 .../src/main/java/org/apache/ignite/tx/IgniteTransactions.java    | 4 ++--
 modules/api/src/main/java/org/apache/ignite/tx/Transaction.java   | 4 ++--
 .../src/main/java/org/apache/ignite/tx/TransactionException.java  | 4 ++--
 modules/api/src/main/java/org/apache/ignite/tx/package-info.java  | 4 ++--
 .../test/java/org/apache/ignite/lang/IgniteExceptionArchTest.java | 4 ++--
 .../src/test/java/org/apache/ignite/lang/IgniteExceptionTest.java | 4 ++--
 .../java/org/apache/ignite/internal/baseline/BaselineManager.java | 4 ++--
 .../apache/ignite/internal/binarytuple/BinaryTupleBuilder.java    | 4 ++--
 .../org/apache/ignite/internal/binarytuple/BinaryTupleCommon.java | 4 ++--
 .../ignite/internal/binarytuple/BinaryTupleFormatException.java   | 4 ++--
 .../org/apache/ignite/internal/binarytuple/BinaryTupleParser.java | 4 ++--
 .../org/apache/ignite/internal/binarytuple/BinaryTupleReader.java | 4 ++--
 .../org/apache/ignite/internal/binarytuple/BinaryTupleTest.java   | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/Access.java        | 4 ++--
 .../facebook/presto/bytecode/AddFakeLineNumberClassVisitor.java   | 4 ++--
 .../java/com/facebook/presto/bytecode/AnnotationDefinition.java   | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/ArrayOpCode.java   | 4 ++--
 .../com/facebook/presto/bytecode/ByteCodeTooLargeException.java   | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/BytecodeBlock.java | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/BytecodeNode.java  | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/BytecodeUtils.java | 4 ++--
 .../main/java/com/facebook/presto/bytecode/BytecodeVisitor.java   | 4 ++--
 .../main/java/com/facebook/presto/bytecode/ClassDefinition.java   | 4 ++--
 .../main/java/com/facebook/presto/bytecode/ClassGenerator.java    | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/Comment.java       | 4 ++--
 .../java/com/facebook/presto/bytecode/CompilationException.java   | 4 ++--
 .../java/com/facebook/presto/bytecode/DumpBytecodeVisitor.java    | 4 ++--
 .../java/com/facebook/presto/bytecode/DynamicClassLoader.java     | 4 ++--
 .../main/java/com/facebook/presto/bytecode/FieldDefinition.java   | 4 ++--
 .../main/java/com/facebook/presto/bytecode/MethodDefinition.java  | 4 ++--
 .../com/facebook/presto/bytecode/MethodGenerationContext.java     | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/OpCode.java        | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/Parameter.java     | 4 ++--
 .../main/java/com/facebook/presto/bytecode/ParameterizedType.java | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/Scope.java         | 4 ++--
 .../main/java/com/facebook/presto/bytecode/SmartClassWriter.java  | 4 ++--
 .../src/main/java/com/facebook/presto/bytecode/Variable.java      | 4 ++--
 .../java/com/facebook/presto/bytecode/control/CaseStatement.java  | 4 ++--
 .../java/com/facebook/presto/bytecode/control/DoWhileLoop.java    | 4 ++--
 .../java/com/facebook/presto/bytecode/control/FlowControl.java    | 4 ++--
 .../main/java/com/facebook/presto/bytecode/control/ForLoop.java   | 4 ++--
 .../java/com/facebook/presto/bytecode/control/IfStatement.java    | 4 ++--
 .../com/facebook/presto/bytecode/control/SwitchStatement.java     | 4 ++--
 .../main/java/com/facebook/presto/bytecode/control/TryCatch.java  | 4 ++--
 .../main/java/com/facebook/presto/bytecode/control/WhileLoop.java | 4 ++--
 .../main/java/com/facebook/presto/bytecode/debug/DebugNode.java   | 4 ++--
 .../java/com/facebook/presto/bytecode/debug/LineNumberNode.java   | 4 ++--
 .../com/facebook/presto/bytecode/debug/LocalVariableNode.java     | 4 ++--
 .../presto/bytecode/expression/AndBytecodeExpression.java         | 4 ++--
 .../presto/bytecode/expression/ArithmeticBytecodeExpression.java  | 4 ++--
 .../presto/bytecode/expression/ArrayLengthBytecodeExpression.java | 4 ++--
 .../facebook/presto/bytecode/expression/BytecodeExpression.java   | 4 ++--
 .../facebook/presto/bytecode/expression/BytecodeExpressions.java  | 4 ++--
 .../presto/bytecode/expression/CastBytecodeExpression.java        | 4 ++--
 .../presto/bytecode/expression/ComparisonBytecodeExpression.java  | 4 ++--
 .../presto/bytecode/expression/ConstantBytecodeExpression.java    | 4 ++--
 .../presto/bytecode/expression/GetElementBytecodeExpression.java  | 4 ++--
 .../presto/bytecode/expression/GetFieldBytecodeExpression.java    | 4 ++--
 .../presto/bytecode/expression/InlineIfBytecodeExpression.java    | 4 ++--
 .../presto/bytecode/expression/InstanceOfBytecodeExpression.java  | 4 ++--
 .../presto/bytecode/expression/InvokeBytecodeExpression.java      | 4 ++--
 .../bytecode/expression/InvokeDynamicBytecodeExpression.java      | 4 ++--
 .../presto/bytecode/expression/NegateBytecodeExpression.java      | 4 ++--
 .../presto/bytecode/expression/NewArrayBytecodeExpression.java    | 4 ++--
 .../presto/bytecode/expression/NewInstanceBytecodeExpression.java | 4 ++--
 .../presto/bytecode/expression/NotBytecodeExpression.java         | 4 ++--
 .../facebook/presto/bytecode/expression/OrBytecodeExpression.java | 4 ++--
 .../presto/bytecode/expression/PopBytecodeExpression.java         | 4 ++--
 .../presto/bytecode/expression/ReturnBytecodeExpression.java      | 4 ++--
 .../bytecode/expression/SetArrayElementBytecodeExpression.java    | 4 ++--
 .../presto/bytecode/expression/SetFieldBytecodeExpression.java    | 4 ++--
 .../java/com/facebook/presto/bytecode/instruction/Constant.java   | 4 ++--
 .../facebook/presto/bytecode/instruction/FieldInstruction.java    | 4 ++--
 .../com/facebook/presto/bytecode/instruction/InstructionNode.java | 4 ++--
 .../facebook/presto/bytecode/instruction/InvokeInstruction.java   | 4 ++--
 .../com/facebook/presto/bytecode/instruction/JumpInstruction.java | 4 ++--
 .../java/com/facebook/presto/bytecode/instruction/LabelNode.java  | 4 ++--
 .../com/facebook/presto/bytecode/instruction/TypeInstruction.java | 4 ++--
 .../facebook/presto/bytecode/instruction/VariableInstruction.java | 4 ++--
 .../test/java/com/facebook/presto/bytecode/TestBytecodeUtils.java | 4 ++--
 .../java/com/facebook/presto/bytecode/TestClassGenerator.java     | 4 ++--
 .../presto/bytecode/expression/BytecodeExpressionAssertions.java  | 4 ++--
 .../bytecode/expression/TestArithmeticBytecodeExpression.java     | 4 ++--
 .../presto/bytecode/expression/TestArrayBytecodeExpressions.java  | 4 ++--
 .../presto/bytecode/expression/TestCastBytecodeExpression.java    | 4 ++--
 .../bytecode/expression/TestComparisonBytecodeExpression.java     | 4 ++--
 .../bytecode/expression/TestConstantBytecodeExpression.java       | 4 ++--
 .../bytecode/expression/TestGetFieldBytecodeExpression.java       | 4 ++--
 .../bytecode/expression/TestInlineIfBytecodeExpression.java       | 4 ++--
 .../presto/bytecode/expression/TestInvokeBytecodeExpression.java  | 4 ++--
 .../bytecode/expression/TestInvokeDynamicBytecodeExpression.java  | 4 ++--
 .../presto/bytecode/expression/TestLogicalBytecodeExpression.java | 4 ++--
 .../bytecode/expression/TestNewInstanceBytecodeExpression.java    | 4 ++--
 .../presto/bytecode/expression/TestPopBytecodeExpression.java     | 4 ++--
 .../bytecode/expression/TestSetFieldBytecodeExpression.java       | 4 ++--
 .../bytecode/expression/TestSetVariableBytecodeExpression.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/common/IgniteCommand.java | 4 ++--
 .../src/main/java/org/apache/ignite/cli/common/package-info.java  | 4 ++--
 .../java/org/apache/ignite/cli/IntegrationTestBase.java           | 4 ++--
 .../ignite/cli/call/CallInitializedIntegrationTestBase.java       | 4 ++--
 .../cli/call/configuration/ItShowConfigurationCallTest.java       | 4 ++--
 .../cli/call/configuration/ItUpdateConfigurationCallTest.java     | 4 ++--
 .../cli/commands/CliCommandTestInitializedIntegrationBase.java    | 4 ++--
 .../cli/commands/CliCommandTestNotInitializedIntegrationBase.java | 4 ++--
 .../cluster/config/ItClusterConfigCommandNotInitializedTest.java  | 4 ++--
 .../cluster/status/ItClusterStatusCommandInitializedTest.java     | 4 ++--
 .../cluster/status/ItClusterStatusCommandNotInitializedTest.java  | 4 ++--
 .../cluster/topology/ItTopologyCommandInitializedClusterTest.java | 4 ++--
 .../topology/ItTopologyCommandNotInitializedClusterTest.java      | 4 ++--
 .../ignite/cli/commands/configuration/ItConfigCommandTest.java    | 4 ++--
 .../apache/ignite/cli/commands/connect/ItConnectCommandTest.java  | 4 ++--
 .../ignite/cli/commands/questions/ItConnectToClusterTest.java     | 4 ++--
 .../java/org/apache/ignite/cli/commands/sql/ItSqlCommandTest.java | 4 ++--
 .../apache/ignite/cli/commands/version/ItVersionCommandTest.java  | 4 ++--
 .../apache/ignite/cli/deprecated/AbstractCliIntegrationTest.java  | 4 ++--
 .../org/apache/ignite/cli/deprecated/ItClusterCommandTest.java    | 4 ++--
 .../org/apache/ignite/cli/deprecated/ItConfigCommandTest.java     | 4 ++--
 .../java/org/apache/ignite/rest/ItGeneratedRestClientTest.java    | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/CliVersionInfo.java   | 4 ++--
 modules/cli/src/main/java/org/apache/ignite/cli/Main.java         | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/VersionProvider.java  | 4 ++--
 .../org/apache/ignite/cli/call/cliconfig/CliConfigGetCall.java    | 4 ++--
 .../apache/ignite/cli/call/cliconfig/CliConfigGetCallInput.java   | 4 ++--
 .../org/apache/ignite/cli/call/cliconfig/CliConfigSetCall.java    | 4 ++--
 .../apache/ignite/cli/call/cliconfig/CliConfigSetCallInput.java   | 4 ++--
 .../org/apache/ignite/cli/call/cliconfig/CliConfigShowCall.java   | 4 ++--
 .../cli/call/cliconfig/profile/CliConfigProfileActivateCall.java  | 4 ++--
 .../cli/call/cliconfig/profile/CliConfigProfileCreateCall.java    | 4 ++--
 .../call/cliconfig/profile/CliConfigProfileCreateCallInput.java   | 4 ++--
 .../cli/call/cliconfig/profile/CliConfigProfileListCall.java      | 4 ++--
 .../cli/call/cliconfig/profile/CliConfigProfileShowCall.java      | 4 ++--
 .../org/apache/ignite/cli/call/cliconfig/profile/ProfileList.java | 4 ++--
 .../java/org/apache/ignite/cli/call/cluster/ClusterInitCall.java  | 4 ++--
 .../org/apache/ignite/cli/call/cluster/ClusterInitCallInput.java  | 4 ++--
 .../org/apache/ignite/cli/call/cluster/status/ClusterStatus.java  | 4 ++--
 .../apache/ignite/cli/call/cluster/status/ClusterStatusCall.java  | 4 ++--
 .../ignite/cli/call/cluster/topology/LogicalTopologyCall.java     | 4 ++--
 .../ignite/cli/call/cluster/topology/PhysicalTopologyCall.java    | 4 ++--
 .../ignite/cli/call/cluster/topology/TopologyCallOutput.java      | 4 ++--
 .../ignite/cli/call/configuration/ClusterConfigShowCall.java      | 4 ++--
 .../ignite/cli/call/configuration/ClusterConfigShowCallInput.java | 4 ++--
 .../ignite/cli/call/configuration/ClusterConfigUpdateCall.java    | 4 ++--
 .../cli/call/configuration/ClusterConfigUpdateCallInput.java      | 4 ++--
 .../java/org/apache/ignite/cli/call/configuration/JsonString.java | 4 ++--
 .../apache/ignite/cli/call/configuration/NodeConfigShowCall.java  | 4 ++--
 .../ignite/cli/call/configuration/NodeConfigShowCallInput.java    | 4 ++--
 .../ignite/cli/call/configuration/NodeConfigUpdateCall.java       | 4 ++--
 .../ignite/cli/call/configuration/NodeConfigUpdateCallInput.java  | 4 ++--
 .../main/java/org/apache/ignite/cli/call/connect/ConnectCall.java | 4 ++--
 .../java/org/apache/ignite/cli/call/connect/ConnectCallInput.java | 4 ++--
 .../java/org/apache/ignite/cli/call/connect/DisconnectCall.java   | 4 ++--
 .../java/org/apache/ignite/cli/call/node/status/NodeStatus.java   | 4 ++--
 .../org/apache/ignite/cli/call/node/status/NodeStatusCall.java    | 4 ++--
 .../main/java/org/apache/ignite/cli/call/node/status/State.java   | 4 ++--
 .../main/java/org/apache/ignite/cli/call/sql/SqlQueryCall.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/commands/BaseCommand.java | 4 ++--
 .../java/org/apache/ignite/cli/commands/OptionsConstants.java     | 4 ++--
 .../main/java/org/apache/ignite/cli/commands/ProfileMixin.java    | 4 ++--
 .../java/org/apache/ignite/cli/commands/TopLevelCliCommand.java   | 4 ++--
 .../org/apache/ignite/cli/commands/TopLevelCliReplCommand.java    | 4 ++--
 .../java/org/apache/ignite/cli/commands/cliconfig/CliCommand.java | 4 ++--
 .../apache/ignite/cli/commands/cliconfig/CliConfigCommand.java    | 4 ++--
 .../apache/ignite/cli/commands/cliconfig/CliConfigGetCommand.java | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigGetReplCommand.java    | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigReplCommand.java       | 4 ++--
 .../apache/ignite/cli/commands/cliconfig/CliConfigSetCommand.java | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigSetReplCommand.java    | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigShowCommand.java       | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigShowReplCommand.java   | 4 ++--
 .../org/apache/ignite/cli/commands/cliconfig/CliReplCommand.java  | 4 ++--
 .../cliconfig/profile/CliConfigProfileActivateCommand.java        | 4 ++--
 .../cli/commands/cliconfig/profile/CliConfigProfileCommand.java   | 4 ++--
 .../commands/cliconfig/profile/CliConfigProfileCreateCommand.java | 4 ++--
 .../commands/cliconfig/profile/CliConfigProfileListCommand.java   | 4 ++--
 .../commands/cliconfig/profile/CliConfigProfileShowCommand.java   | 4 ++--
 .../org/apache/ignite/cli/commands/cluster/ClusterCommand.java    | 4 ++--
 .../apache/ignite/cli/commands/cluster/ClusterReplCommand.java    | 4 ++--
 .../org/apache/ignite/cli/commands/cluster/ClusterUrlMixin.java   | 4 ++--
 .../ignite/cli/commands/cluster/ClusterUrlProfileMixin.java       | 4 ++--
 .../ignite/cli/commands/cluster/config/ClusterConfigCommand.java  | 4 ++--
 .../cli/commands/cluster/config/ClusterConfigReplCommand.java     | 4 ++--
 .../cli/commands/cluster/config/ClusterConfigShowCommand.java     | 4 ++--
 .../cli/commands/cluster/config/ClusterConfigShowReplCommand.java | 4 ++--
 .../cli/commands/cluster/config/ClusterConfigUpdateCommand.java   | 4 ++--
 .../commands/cluster/config/ClusterConfigUpdateReplCommand.java   | 4 ++--
 .../ignite/cli/commands/cluster/init/ClusterInitCommand.java      | 4 ++--
 .../ignite/cli/commands/cluster/init/ClusterInitOptions.java      | 4 ++--
 .../ignite/cli/commands/cluster/init/ClusterInitReplCommand.java  | 4 ++--
 .../ignite/cli/commands/cluster/status/ClusterStatusCommand.java  | 4 ++--
 .../cli/commands/cluster/status/ClusterStatusReplCommand.java     | 4 ++--
 .../org/apache/ignite/cli/commands/connect/ConnectCommand.java    | 4 ++--
 .../org/apache/ignite/cli/commands/connect/DisconnectCommand.java | 4 ++--
 .../java/org/apache/ignite/cli/commands/node/NodeCommand.java     | 4 ++--
 .../java/org/apache/ignite/cli/commands/node/NodeReplCommand.java | 4 ++--
 .../java/org/apache/ignite/cli/commands/node/NodeUrlMixin.java    | 4 ++--
 .../org/apache/ignite/cli/commands/node/NodeUrlProfileMixin.java  | 4 ++--
 .../apache/ignite/cli/commands/node/config/NodeConfigCommand.java | 4 ++--
 .../ignite/cli/commands/node/config/NodeConfigReplCommand.java    | 4 ++--
 .../ignite/cli/commands/node/config/NodeConfigShowCommand.java    | 4 ++--
 .../cli/commands/node/config/NodeConfigShowReplCommand.java       | 4 ++--
 .../ignite/cli/commands/node/config/NodeConfigUpdateCommand.java  | 4 ++--
 .../cli/commands/node/config/NodeConfigUpdateReplCommand.java     | 4 ++--
 .../apache/ignite/cli/commands/node/status/NodeStatusCommand.java | 4 ++--
 .../ignite/cli/commands/node/status/NodeStatusReplCommand.java    | 4 ++--
 .../ignite/cli/commands/questions/ConnectToClusterQuestion.java   | 4 ++--
 .../main/java/org/apache/ignite/cli/commands/sql/SqlCommand.java  | 4 ++--
 .../java/org/apache/ignite/cli/commands/sql/SqlCompleter.java     | 4 ++--
 .../main/java/org/apache/ignite/cli/commands/sql/SqlMetaData.java | 4 ++--
 .../java/org/apache/ignite/cli/commands/sql/SqlReplCommand.java   | 4 ++--
 .../apache/ignite/cli/commands/sql/SqlReplTopLevelCliCommand.java | 4 ++--
 .../ignite/cli/commands/topology/LogicalTopologyCommand.java      | 4 ++--
 .../ignite/cli/commands/topology/LogicalTopologyReplCommand.java  | 4 ++--
 .../ignite/cli/commands/topology/PhysicalTopologyCommand.java     | 4 ++--
 .../ignite/cli/commands/topology/PhysicalTopologyReplCommand.java | 4 ++--
 .../org/apache/ignite/cli/commands/topology/TopologyCommand.java  | 4 ++--
 .../apache/ignite/cli/commands/topology/TopologyReplCommand.java  | 4 ++--
 .../org/apache/ignite/cli/commands/version/VersionCommand.java    | 4 ++--
 .../org/apache/ignite/cli/config/CachedConfigManagerProvider.java | 4 ++--
 .../org/apache/ignite/cli/config/CachedStateConfigProvider.java   | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/config/Config.java    | 4 ++--
 .../main/java/org/apache/ignite/cli/config/ConfigConstants.java   | 4 ++--
 .../org/apache/ignite/cli/config/ConfigDefaultValueProvider.java  | 4 ++--
 .../apache/ignite/cli/config/ConfigInitializationException.java   | 4 ++--
 .../src/main/java/org/apache/ignite/cli/config/ConfigManager.java | 4 ++--
 .../java/org/apache/ignite/cli/config/ConfigManagerProvider.java  | 4 ++--
 .../java/org/apache/ignite/cli/config/ConfigStoringException.java | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/config/Profile.java   | 4 ++--
 .../org/apache/ignite/cli/config/ProfileNotFoundException.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/config/StateConfig.java   | 4 ++--
 .../java/org/apache/ignite/cli/config/StateConfigProvider.java    | 4 ++--
 .../java/org/apache/ignite/cli/config/StateFolderProvider.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/config/ini/IniConfig.java | 4 ++--
 .../java/org/apache/ignite/cli/config/ini/IniConfigManager.java   | 4 ++--
 .../src/main/java/org/apache/ignite/cli/config/ini/IniFile.java   | 4 ++--
 .../src/main/java/org/apache/ignite/cli/config/ini/IniParser.java | 4 ++--
 .../main/java/org/apache/ignite/cli/config/ini/IniProfile.java    | 4 ++--
 .../main/java/org/apache/ignite/cli/config/ini/IniSection.java    | 4 ++--
 .../ignite/cli/config/ini/SectionAlreadyExistsException.java      | 4 ++--
 .../org/apache/ignite/cli/core/CallExecutionPipelineProvider.java | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/core/call/Call.java   | 4 ++--
 .../org/apache/ignite/cli/core/call/CallExecutionPipeline.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/core/call/CallInput.java  | 4 ++--
 .../src/main/java/org/apache/ignite/cli/core/call/CallOutput.java | 4 ++--
 .../java/org/apache/ignite/cli/core/call/CallOutputStatus.java    | 4 ++--
 .../java/org/apache/ignite/cli/core/call/DefaultCallOutput.java   | 4 ++--
 .../main/java/org/apache/ignite/cli/core/call/EmptyCallInput.java | 4 ++--
 .../java/org/apache/ignite/cli/core/call/StringCallInput.java     | 4 ++--
 .../ignite/cli/core/converters/NetworkAddressConverter.java       | 4 ++--
 .../java/org/apache/ignite/cli/core/converters/UrlConverter.java  | 4 ++--
 .../main/java/org/apache/ignite/cli/core/decorator/Decorator.java | 4 ++--
 .../org/apache/ignite/cli/core/decorator/DecoratorRegistry.java   | 4 ++--
 .../java/org/apache/ignite/cli/core/decorator/TerminalOutput.java | 4 ++--
 .../ignite/cli/core/exception/CommandExecutionException.java      | 4 ++--
 .../apache/ignite/cli/core/exception/ConnectCommandException.java | 4 ++--
 .../org/apache/ignite/cli/core/exception/ExceptionHandler.java    | 4 ++--
 .../org/apache/ignite/cli/core/exception/ExceptionHandlers.java   | 4 ++--
 .../org/apache/ignite/cli/core/exception/ExceptionWriter.java     | 4 ++--
 .../apache/ignite/cli/core/exception/IgniteCliApiException.java   | 4 ++--
 .../org/apache/ignite/cli/core/exception/WrappedException.java    | 4 ++--
 .../exception/handler/ClusterNotInitializedExceptionHandler.java  | 4 ++--
 .../cli/core/exception/handler/ConfigStoringExceptionHandler.java | 4 ++--
 .../cli/core/exception/handler/DefaultExceptionHandlers.java      | 4 ++--
 .../cli/core/exception/handler/EndOfFileExceptionHandler.java     | 4 ++--
 .../cli/core/exception/handler/FlowInterruptExceptionHandler.java | 4 ++--
 .../cli/core/exception/handler/IgniteCliApiExceptionHandler.java  | 4 ++--
 .../cli/core/exception/handler/IgniteCliExceptionHandler.java     | 4 ++--
 .../core/exception/handler/PicocliExecutionExceptionHandler.java  | 4 ++--
 .../core/exception/handler/ProfileNotFoundExceptionHandler.java   | 4 ++--
 .../ignite/cli/core/exception/handler/ReplExceptionHandlers.java  | 4 ++--
 .../exception/handler/SectionAlreadyExistsExceptionHandler.java   | 4 ++--
 .../ignite/cli/core/exception/handler/SqlExceptionHandler.java    | 4 ++--
 .../cli/core/exception/handler/TimeoutExceptionHandler.java       | 4 ++--
 .../core/exception/handler/UnknownCommandExceptionHandler.java    | 4 ++--
 .../cli/core/exception/handler/UserInterruptExceptionHandler.java | 4 ++--
 .../java/org/apache/ignite/cli/core/flow/DefaultFlowable.java     | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/core/flow/Flow.java   | 4 ++--
 .../org/apache/ignite/cli/core/flow/FlowInterruptException.java   | 4 ++--
 .../src/main/java/org/apache/ignite/cli/core/flow/Flowable.java   | 4 ++--
 .../java/org/apache/ignite/cli/core/flow/builder/FlowBuilder.java | 4 ++--
 .../org/apache/ignite/cli/core/flow/builder/FlowBuilderImpl.java  | 4 ++--
 .../main/java/org/apache/ignite/cli/core/flow/builder/Flows.java  | 4 ++--
 .../ignite/cli/core/flow/question/AcceptedQuestionAnswer.java     | 4 ++--
 .../ignite/cli/core/flow/question/InterruptQuestionAnswer.java    | 4 ++--
 .../ignite/cli/core/flow/question/JlineQuestionWriterReader.java  | 4 ++--
 .../org/apache/ignite/cli/core/flow/question/QuestionAnswer.java  | 4 ++--
 .../org/apache/ignite/cli/core/flow/question/QuestionAsker.java   | 4 ++--
 .../ignite/cli/core/flow/question/QuestionAskerFactory.java       | 4 ++--
 .../ignite/cli/core/flow/question/QuestionWriterReader.java       | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/core/repl/Repl.java   | 4 ++--
 .../main/java/org/apache/ignite/cli/core/repl/ReplBuilder.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/core/repl/Session.java    | 4 ++--
 .../apache/ignite/cli/core/repl/SessionDefaultValueProvider.java  | 4 ++--
 .../apache/ignite/cli/core/repl/completer/CompleterFilter.java    | 4 ++--
 .../apache/ignite/cli/core/repl/completer/DynamicCompleter.java   | 4 ++--
 .../cli/core/repl/completer/DynamicCompleterActivationPoint.java  | 4 ++--
 .../ignite/cli/core/repl/completer/DynamicCompleterFactory.java   | 4 ++--
 .../ignite/cli/core/repl/completer/DynamicCompleterFilter.java    | 4 ++--
 .../ignite/cli/core/repl/completer/DynamicCompleterRegistry.java  | 4 ++--
 .../ignite/cli/core/repl/completer/HoconDynamicCompleter.java     | 4 ++--
 .../ignite/cli/core/repl/completer/LazyDynamicCompleter.java      | 4 ++--
 .../apache/ignite/cli/core/repl/completer/NodeUrlProvider.java    | 4 ++--
 .../apache/ignite/cli/core/repl/config/ClientConnectorConfig.java | 4 ++--
 .../java/org/apache/ignite/cli/core/repl/config/RootConfig.java   | 4 ++--
 .../apache/ignite/cli/core/repl/context/CommandLineContext.java   | 4 ++--
 .../ignite/cli/core/repl/context/CommandLineContextProvider.java  | 4 ++--
 .../ignite/cli/core/repl/executor/IgnitePicocliCommands.java      | 4 ++--
 .../ignite/cli/core/repl/executor/RegistryCommandExecutor.java    | 4 ++--
 .../org/apache/ignite/cli/core/repl/executor/ReplExecutor.java    | 4 ++--
 .../ignite/cli/core/repl/executor/ReplExecutorProvider.java       | 4 ++--
 .../org/apache/ignite/cli/core/repl/expander/NoopExpander.java    | 4 ++--
 .../org/apache/ignite/cli/core/repl/prompt/PromptProvider.java    | 4 ++--
 .../apache/ignite/cli/core/repl/prompt/ReplPromptProvider.java    | 4 ++--
 .../apache/ignite/cli/core/repl/terminal/TerminalCustomizer.java  | 4 ++--
 .../org/apache/ignite/cli/core/repl/terminal/TerminalFactory.java | 4 ++--
 .../java/org/apache/ignite/cli/core/style/AnsiStringSupport.java  | 4 ++--
 .../apache/ignite/cli/core/style/component/ErrorUiComponent.java  | 4 ++--
 .../ignite/cli/core/style/component/MessageUiComponent.java       | 4 ++--
 .../ignite/cli/core/style/component/QuestionUiComponent.java      | 4 ++--
 .../org/apache/ignite/cli/core/style/component/UiComponent.java   | 4 ++--
 .../org/apache/ignite/cli/core/style/element/MarkedUiElement.java | 4 ++--
 .../java/org/apache/ignite/cli/core/style/element/UiElement.java  | 4 ++--
 .../java/org/apache/ignite/cli/core/style/element/UiElements.java | 4 ++--
 .../java/org/apache/ignite/cli/core/style/element/UiString.java   | 4 ++--
 .../org/apache/ignite/cli/decorators/ClusterStatusDecorator.java  | 4 ++--
 .../java/org/apache/ignite/cli/decorators/DefaultDecorator.java   | 4 ++--
 .../apache/ignite/cli/decorators/DefaultDecoratorRegistry.java    | 4 ++--
 .../main/java/org/apache/ignite/cli/decorators/JsonDecorator.java | 4 ++--
 .../org/apache/ignite/cli/decorators/NodeStatusDecorator.java     | 4 ++--
 .../java/org/apache/ignite/cli/decorators/ProfileDecorator.java   | 4 ++--
 .../org/apache/ignite/cli/decorators/ProfileListDecorator.java    | 4 ++--
 .../org/apache/ignite/cli/decorators/SqlQueryResultDecorator.java | 4 ++--
 .../java/org/apache/ignite/cli/decorators/TableDecorator.java     | 4 ++--
 .../java/org/apache/ignite/cli/decorators/TopologyDecorator.java  | 4 ++--
 .../org/apache/ignite/cli/deprecated/CliPathsConfigLoader.java    | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/CommandFactory.java     | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/IgniteCliException.java | 4 ++--
 .../main/java/org/apache/ignite/cli/deprecated/IgnitePaths.java   | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/deprecated/Table.java | 4 ++--
 .../apache/ignite/cli/deprecated/builtins/SystemPathResolver.java | 4 ++--
 .../ignite/cli/deprecated/builtins/init/InitIgniteCommand.java    | 4 ++--
 .../apache/ignite/cli/deprecated/builtins/init/package-info.java  | 4 ++--
 .../cli/deprecated/builtins/module/MavenArtifactResolver.java     | 4 ++--
 .../ignite/cli/deprecated/builtins/module/MavenCoordinates.java   | 4 ++--
 .../ignite/cli/deprecated/builtins/module/ModuleManager.java      | 4 ++--
 .../ignite/cli/deprecated/builtins/module/ModuleRegistry.java     | 4 ++--
 .../ignite/cli/deprecated/builtins/module/ResolveResult.java      | 4 ++--
 .../cli/deprecated/builtins/module/StandardModuleDefinition.java  | 4 ++--
 .../ignite/cli/deprecated/builtins/module/package-info.java       | 4 ++--
 .../apache/ignite/cli/deprecated/builtins/node/NodeManager.java   | 4 ++--
 .../apache/ignite/cli/deprecated/builtins/node/package-info.java  | 4 ++--
 .../org/apache/ignite/cli/deprecated/builtins/package-info.java   | 4 ++--
 .../main/java/org/apache/ignite/cli/deprecated/package-info.java  | 4 ++--
 .../ignite/cli/deprecated/spec/BootstrapIgniteCommandSpec.java    | 4 ++--
 .../org/apache/ignite/cli/deprecated/spec/NodeCommandSpec.java    | 4 ++--
 .../apache/ignite/cli/deprecated/spec/NodeEndpointOptions.java    | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/spec/package-info.java  | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/ui/ProgressBar.java     | 4 ++--
 .../main/java/org/apache/ignite/cli/deprecated/ui/Spinner.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/sql/MetadataSupplier.java | 4 ++--
 .../src/main/java/org/apache/ignite/cli/sql/SchemaProvider.java   | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/sql/SqlManager.java   | 4 ++--
 .../src/main/java/org/apache/ignite/cli/sql/SqlQueryResult.java   | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/sql/SqlSchema.java    | 4 ++--
 .../src/main/java/org/apache/ignite/cli/sql/SqlSchemaLoader.java  | 4 ++--
 .../main/java/org/apache/ignite/cli/sql/SqlSchemaProvider.java    | 4 ++--
 .../cli/src/main/java/org/apache/ignite/cli/sql/table/Table.java  | 4 ++--
 .../src/main/java/org/apache/ignite/cli/sql/table/TableRow.java   | 4 ++--
 .../apache/ignite/cli/call/node/status/NodeStatusCallTest.java    | 4 ++--
 .../java/org/apache/ignite/cli/commands/CliCommandTestBase.java   | 4 ++--
 .../test/java/org/apache/ignite/cli/commands/PicocliBugTest.java  | 4 ++--
 .../java/org/apache/ignite/cli/commands/ProfileMixinTest.java     | 4 ++--
 .../org/apache/ignite/cli/commands/UrlOptionsNegativeTest.java    | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigCommandTestBase.java   | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigGetCommandTest.java    | 4 ++--
 .../commands/cliconfig/CliConfigProfileActivateCommandTest.java   | 4 ++--
 .../cli/commands/cliconfig/CliConfigProfileCreateCommandTest.java | 4 ++--
 .../cli/commands/cliconfig/CliConfigProfileListCommandTest.java   | 4 ++--
 .../cli/commands/cliconfig/CliConfigProfileShowCommandTest.java   | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigSetCommandTest.java    | 4 ++--
 .../ignite/cli/commands/cliconfig/CliConfigShowCommandTest.java   | 4 ++--
 .../apache/ignite/cli/commands/cliconfig/ConfigManagerTest.java   | 4 ++--
 .../ignite/cli/commands/cliconfig/TestConfigManagerHelper.java    | 4 ++--
 .../ignite/cli/commands/cliconfig/TestConfigManagerProvider.java  | 4 ++--
 .../test/java/org/apache/ignite/cli/commands/flow/FlowTest.java   | 4 ++--
 .../test/java/org/apache/ignite/cli/commands/flow/IntCall.java    | 4 ++--
 .../java/org/apache/ignite/cli/commands/flow/IntCallInput.java    | 4 ++--
 .../test/java/org/apache/ignite/cli/commands/flow/StrCall.java    | 4 ++--
 .../java/org/apache/ignite/cli/commands/flow/StrCallInput.java    | 4 ++--
 .../org/apache/ignite/cli/commands/flow/TestExceptionHandler.java | 4 ++--
 .../java/org/apache/ignite/cli/commands/flow/ThrowingStrCall.java | 4 ++--
 .../org/apache/ignite/cli/commands/sql/SchemaProviderMock.java    | 4 ++--
 .../java/org/apache/ignite/cli/commands/sql/SqlCommandTest.java   | 4 ++--
 .../java/org/apache/ignite/cli/commands/sql/SqlCompleterTest.java | 4 ++--
 .../java/org/apache/ignite/cli/config/TestStateConfigHelper.java  | 4 ++--
 .../org/apache/ignite/cli/config/TestStateConfigProvider.java     | 4 ++--
 .../cli/core/repl/completer/DynamicCompleterFilterTest.java       | 4 ++--
 .../cli/core/repl/completer/DynamicCompleterRegistryTest.java     | 4 ++--
 .../ignite/cli/core/repl/completer/HoconDynamicCompleterTest.java | 4 ++--
 .../ignite/cli/core/style/component/ErrorUiComponentTest.java     | 4 ++--
 .../ignite/cli/core/style/component/MessageUiComponentTest.java   | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/AbstractCliTest.java    | 4 ++--
 .../org/apache/ignite/cli/deprecated/IgniteCliInterfaceTest.java  | 4 ++--
 .../cli/deprecated/builtins/init/InitIgniteCommandTest.java       | 4 ++--
 .../apache/ignite/cli/deprecated/builtins/init/package-info.java  | 4 ++--
 .../test/java/org/apache/ignite/cli/deprecated/package-info.java  | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/ui/ProgressBarTest.java | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/ui/SpinnerTest.java     | 4 ++--
 .../java/org/apache/ignite/cli/deprecated/ui/package-info.java    | 4 ++--
 .../java/org/apache/ignite/cli/sql/SqlSchemaProviderTest.java     | 4 ++--
 .../src/test/java/org/apache/ignite/cli/sql/table/TableTest.java  | 4 ++--
 .../ignite/internal/client/proto/ClientBinaryTupleUtils.java      | 4 ++--
 .../org/apache/ignite/internal/client/proto/ClientDataType.java   | 4 ++--
 .../apache/ignite/internal/client/proto/ClientMessageCommon.java  | 4 ++--
 .../apache/ignite/internal/client/proto/ClientMessageDecoder.java | 4 ++--
 .../apache/ignite/internal/client/proto/ClientMessagePacker.java  | 4 ++--
 .../ignite/internal/client/proto/ClientMessageUnpacker.java       | 4 ++--
 .../apache/ignite/internal/client/proto/ClientMsgPackType.java    | 4 ++--
 .../java/org/apache/ignite/internal/client/proto/ClientOp.java    | 4 ++--
 .../internal/client/proto/ClientSqlColumnTypeConverter.java       | 4 ++--
 .../org/apache/ignite/internal/client/proto/ProtocolVersion.java  | 4 ++--
 .../apache/ignite/internal/client/proto/ServerMessageType.java    | 4 ++--
 .../java/org/apache/ignite/internal/client/proto/TuplePart.java   | 4 ++--
 .../org/apache/ignite/internal/client/proto/package-info.java     | 4 ++--
 .../java/org/apache/ignite/internal/jdbc/proto/ClientMessage.java | 4 ++--
 .../apache/ignite/internal/jdbc/proto/IgniteQueryErrorCode.java   | 4 ++--
 .../apache/ignite/internal/jdbc/proto/JdbcQueryCursorHandler.java | 4 ++--
 .../apache/ignite/internal/jdbc/proto/JdbcQueryEventHandler.java  | 4 ++--
 .../org/apache/ignite/internal/jdbc/proto/JdbcStatementType.java  | 4 ++--
 .../java/org/apache/ignite/internal/jdbc/proto/SqlStateCode.java  | 4 ++--
 .../ignite/internal/jdbc/proto/event/ClientMessageUtils.java      | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcBatchExecuteRequest.java | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcBatchExecuteResult.java  | 4 ++--
 .../internal/jdbc/proto/event/JdbcBatchPreparedStmntRequest.java  | 4 ++--
 .../apache/ignite/internal/jdbc/proto/event/JdbcColumnMeta.java   | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcMetaColumnsRequest.java  | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcMetaColumnsResult.java   | 4 ++--
 .../internal/jdbc/proto/event/JdbcMetaPrimaryKeysRequest.java     | 4 ++--
 .../internal/jdbc/proto/event/JdbcMetaPrimaryKeysResult.java      | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcMetaSchemasRequest.java  | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcMetaSchemasResult.java   | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcMetaTablesRequest.java   | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcMetaTablesResult.java    | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcPrimaryKeyMeta.java      | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQueryCloseRequest.java   | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQueryCloseResult.java    | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQueryExecuteRequest.java | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQueryExecuteResult.java  | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQueryFetchRequest.java   | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQueryFetchResult.java    | 4 ++--
 .../internal/jdbc/proto/event/JdbcQueryMetadataRequest.java       | 4 ++--
 .../ignite/internal/jdbc/proto/event/JdbcQuerySingleResult.java   | 4 ++--
 .../apache/ignite/internal/jdbc/proto/event/JdbcTableMeta.java    | 4 ++--
 .../org/apache/ignite/internal/jdbc/proto/event/Response.java     | 4 ++--
 .../org/apache/ignite/internal/jdbc/proto/event/package-info.java | 4 ++--
 .../java/org/apache/ignite/internal/jdbc/proto/package-info.java  | 4 ++--
 .../ignite/internal/client/proto/ClientMessageDecoderTest.java    | 4 ++--
 .../internal/client/proto/ClientMessagePackerBenchmark.java       | 4 ++--
 .../ignite/internal/client/proto/ClientMessagePackerTest.java     | 4 ++--
 .../internal/client/proto/ClientMessagePackerUnpackerTest.java    | 4 ++--
 .../ignite/internal/client/proto/ClientMessageUnpackerTest.java   | 4 ++--
 .../internal/client/proto/ClientSqlColumnTypeConverterTest.java   | 4 ++--
 .../org/apache/ignite/client/handler/ItClientHandlerTest.java     | 4 ++--
 .../main/java/org/apache/ignite/client/handler/ClientContext.java | 4 ++--
 .../org/apache/ignite/client/handler/ClientHandlerModule.java     | 4 ++--
 .../apache/ignite/client/handler/ClientInboundMessageHandler.java | 4 ++--
 .../java/org/apache/ignite/client/handler/ClientResource.java     | 4 ++--
 .../org/apache/ignite/client/handler/ClientResourceRegistry.java  | 4 ++--
 .../apache/ignite/client/handler/JdbcQueryCursorHandlerImpl.java  | 4 ++--
 .../apache/ignite/client/handler/JdbcQueryEventHandlerImpl.java   | 4 ++--
 .../main/java/org/apache/ignite/client/handler/package-info.java  | 4 ++--
 .../handler/requests/cluster/ClientClusterGetNodesRequest.java    | 4 ++--
 .../requests/compute/ClientComputeExecuteColocatedRequest.java    | 4 ++--
 .../handler/requests/compute/ClientComputeExecuteRequest.java     | 4 ++--
 .../client/handler/requests/jdbc/ClientJdbcCloseRequest.java      | 4 ++--
 .../handler/requests/jdbc/ClientJdbcColumnMetadataRequest.java    | 4 ++--
 .../handler/requests/jdbc/ClientJdbcExecuteBatchRequest.java      | 4 ++--
 .../client/handler/requests/jdbc/ClientJdbcExecuteRequest.java    | 4 ++--
 .../client/handler/requests/jdbc/ClientJdbcFetchRequest.java      | 4 ++--
 .../requests/jdbc/ClientJdbcPreparedStmntBatchRequest.java        | 4 ++--
 .../requests/jdbc/ClientJdbcPrimaryKeyMetadataRequest.java        | 4 ++--
 .../handler/requests/jdbc/ClientJdbcQueryMetadataRequest.java     | 4 ++--
 .../handler/requests/jdbc/ClientJdbcSchemasMetadataRequest.java   | 4 ++--
 .../handler/requests/jdbc/ClientJdbcTableMetadataRequest.java     | 4 ++--
 .../ignite/client/handler/requests/jdbc/JdbcMetadataCatalog.java  | 4 ++--
 .../ignite/client/handler/requests/jdbc/JdbcQueryCursor.java      | 4 ++--
 .../apache/ignite/client/handler/requests/jdbc/package-info.java  | 4 ++--
 .../ignite/client/handler/requests/sql/ClientSqlCommon.java       | 4 ++--
 .../client/handler/requests/sql/ClientSqlCursorCloseRequest.java  | 4 ++--
 .../handler/requests/sql/ClientSqlCursorNextPageRequest.java      | 4 ++--
 .../client/handler/requests/sql/ClientSqlExecuteRequest.java      | 4 ++--
 .../ignite/client/handler/requests/sql/ClientSqlResultSet.java    | 4 ++--
 .../client/handler/requests/table/ClientSchemasGetRequest.java    | 4 ++--
 .../ignite/client/handler/requests/table/ClientTableCommon.java   | 4 ++--
 .../client/handler/requests/table/ClientTableGetRequest.java      | 4 ++--
 .../client/handler/requests/table/ClientTablesGetRequest.java     | 4 ++--
 .../handler/requests/table/ClientTupleContainsKeyRequest.java     | 4 ++--
 .../handler/requests/table/ClientTupleDeleteAllExactRequest.java  | 4 ++--
 .../handler/requests/table/ClientTupleDeleteAllRequest.java       | 4 ++--
 .../handler/requests/table/ClientTupleDeleteExactRequest.java     | 4 ++--
 .../client/handler/requests/table/ClientTupleDeleteRequest.java   | 4 ++--
 .../client/handler/requests/table/ClientTupleGetAllRequest.java   | 4 ++--
 .../handler/requests/table/ClientTupleGetAndDeleteRequest.java    | 4 ++--
 .../handler/requests/table/ClientTupleGetAndReplaceRequest.java   | 4 ++--
 .../handler/requests/table/ClientTupleGetAndUpsertRequest.java    | 4 ++--
 .../client/handler/requests/table/ClientTupleGetRequest.java      | 4 ++--
 .../handler/requests/table/ClientTupleInsertAllRequest.java       | 4 ++--
 .../client/handler/requests/table/ClientTupleInsertRequest.java   | 4 ++--
 .../handler/requests/table/ClientTupleReplaceExactRequest.java    | 4 ++--
 .../client/handler/requests/table/ClientTupleReplaceRequest.java  | 4 ++--
 .../handler/requests/table/ClientTupleUpsertAllRequest.java       | 4 ++--
 .../client/handler/requests/table/ClientTupleUpsertRequest.java   | 4 ++--
 .../apache/ignite/client/handler/requests/table/package-info.java | 4 ++--
 .../client/handler/requests/tx/ClientTransactionBeginRequest.java | 4 ++--
 .../handler/requests/tx/ClientTransactionCommitRequest.java       | 4 ++--
 .../handler/requests/tx/ClientTransactionRollbackRequest.java     | 4 ++--
 .../client-handler/src/test/java/ClientResourceRegistryTest.java  | 4 ++--
 .../main/java/org/apache/ignite/client/ClientOperationType.java   | 4 ++--
 .../src/main/java/org/apache/ignite/client/IgniteClient.java      | 4 ++--
 .../java/org/apache/ignite/client/IgniteClientAddressFinder.java  | 4 ++--
 .../apache/ignite/client/IgniteClientAuthenticationException.java | 4 ++--
 .../java/org/apache/ignite/client/IgniteClientConfiguration.java  | 4 ++--
 .../org/apache/ignite/client/IgniteClientConnectionException.java | 4 ++--
 .../client/IgniteClientFeatureNotSupportedByServerException.java  | 4 ++--
 .../src/main/java/org/apache/ignite/client/RetryLimitPolicy.java  | 4 ++--
 .../src/main/java/org/apache/ignite/client/RetryPolicy.java       | 4 ++--
 .../main/java/org/apache/ignite/client/RetryPolicyContext.java    | 4 ++--
 .../src/main/java/org/apache/ignite/client/RetryReadPolicy.java   | 4 ++--
 .../src/main/java/org/apache/ignite/client/package-info.java      | 4 ++--
 .../java/org/apache/ignite/internal/client/ClientChannel.java     | 4 ++--
 .../apache/ignite/internal/client/ClientChannelConfiguration.java | 4 ++--
 .../main/java/org/apache/ignite/internal/client/ClientUtils.java  | 4 ++--
 .../java/org/apache/ignite/internal/client/HostAndPortRange.java  | 4 ++--
 .../ignite/internal/client/IgniteClientConfigurationImpl.java     | 4 ++--
 .../org/apache/ignite/internal/client/PayloadInputChannel.java    | 4 ++--
 .../org/apache/ignite/internal/client/PayloadOutputChannel.java   | 4 ++--
 .../java/org/apache/ignite/internal/client/PayloadReader.java     | 4 ++--
 .../java/org/apache/ignite/internal/client/PayloadWriter.java     | 4 ++--
 .../org/apache/ignite/internal/client/ProtocolBitmaskFeature.java | 4 ++--
 .../java/org/apache/ignite/internal/client/ProtocolContext.java   | 4 ++--
 .../java/org/apache/ignite/internal/client/ReliableChannel.java   | 4 ++--
 .../org/apache/ignite/internal/client/RetryPolicyContextImpl.java | 4 ++--
 .../java/org/apache/ignite/internal/client/TcpClientChannel.java  | 4 ++--
 .../java/org/apache/ignite/internal/client/TcpIgniteClient.java   | 4 ++--
 .../org/apache/ignite/internal/client/compute/ClientCompute.java  | 4 ++--
 .../org/apache/ignite/internal/client/io/ClientConnection.java    | 4 ++--
 .../ignite/internal/client/io/ClientConnectionMultiplexer.java    | 4 ++--
 .../ignite/internal/client/io/ClientConnectionStateHandler.java   | 4 ++--
 .../apache/ignite/internal/client/io/ClientMessageHandler.java    | 4 ++--
 .../ignite/internal/client/io/netty/NettyClientConnection.java    | 4 ++--
 .../client/io/netty/NettyClientConnectionMultiplexer.java         | 4 ++--
 .../internal/client/io/netty/NettyClientMessageHandler.java       | 4 ++--
 .../apache/ignite/internal/client/sql/ClientAsyncResultSet.java   | 4 ++--
 .../apache/ignite/internal/client/sql/ClientColumnMetadata.java   | 4 ++--
 .../org/apache/ignite/internal/client/sql/ClientColumnOrigin.java | 4 ++--
 .../ignite/internal/client/sql/ClientResultSetMetadata.java       | 4 ++--
 .../java/org/apache/ignite/internal/client/sql/ClientSession.java | 4 ++--
 .../apache/ignite/internal/client/sql/ClientSessionBuilder.java   | 4 ++--
 .../java/org/apache/ignite/internal/client/sql/ClientSql.java     | 4 ++--
 .../java/org/apache/ignite/internal/client/sql/ClientSqlRow.java  | 4 ++--
 .../org/apache/ignite/internal/client/sql/ClientStatement.java    | 4 ++--
 .../apache/ignite/internal/client/sql/ClientStatementBuilder.java | 4 ++--
 .../org/apache/ignite/internal/client/table/ClientColumn.java     | 4 ++--
 .../ignite/internal/client/table/ClientKeyValueBinaryView.java    | 4 ++--
 .../apache/ignite/internal/client/table/ClientKeyValueView.java   | 4 ++--
 .../ignite/internal/client/table/ClientRecordBinaryView.java      | 4 ++--
 .../ignite/internal/client/table/ClientRecordSerializer.java      | 4 ++--
 .../org/apache/ignite/internal/client/table/ClientRecordView.java | 4 ++--
 .../org/apache/ignite/internal/client/table/ClientSchema.java     | 4 ++--
 .../java/org/apache/ignite/internal/client/table/ClientTable.java | 4 ++--
 .../org/apache/ignite/internal/client/table/ClientTables.java     | 4 ++--
 .../java/org/apache/ignite/internal/client/table/ClientTuple.java | 4 ++--
 .../ignite/internal/client/table/ClientTupleSerializer.java       | 4 ++--
 .../org/apache/ignite/internal/client/tx/ClientTransaction.java   | 4 ++--
 .../org/apache/ignite/internal/client/tx/ClientTransactions.java  | 4 ++--
 .../org/apache/ignite/internal/jdbc/ConnectionProperties.java     | 4 ++--
 .../org/apache/ignite/internal/jdbc/ConnectionPropertiesImpl.java | 4 ++--
 .../apache/ignite/internal/jdbc/JdbcClientQueryCursorHandler.java | 4 ++--
 .../apache/ignite/internal/jdbc/JdbcClientQueryEventHandler.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/jdbc/JdbcConnection.java | 4 ++--
 .../org/apache/ignite/internal/jdbc/JdbcDatabaseMetadata.java     | 4 ++--
 .../org/apache/ignite/internal/jdbc/JdbcPreparedStatement.java    | 4 ++--
 .../org/apache/ignite/internal/jdbc/JdbcQueryExecuteResponse.java | 4 ++--
 .../main/java/org/apache/ignite/internal/jdbc/JdbcResultSet.java  | 4 ++--
 .../org/apache/ignite/internal/jdbc/JdbcResultSetMetadata.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/jdbc/JdbcStatement.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/jdbc/package-info.java   | 4 ++--
 .../apache/ignite/internal/marshaller/ClientMarshallerReader.java | 4 ++--
 .../apache/ignite/internal/marshaller/ClientMarshallerWriter.java | 4 ++--
 .../src/main/java/org/apache/ignite/jdbc/IgniteJdbcDriver.java    | 4 ++--
 .../client/src/main/java/org/apache/ignite/jdbc/package-info.java | 4 ++--
 .../java/org/apache/ignite/client/AbstractClientTableTest.java    | 4 ++--
 .../test/java/org/apache/ignite/client/AbstractClientTest.java    | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientArchTest.java    | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientComputeTest.java | 4 ++--
 .../org/apache/ignite/client/ClientKeyValueBinaryViewTest.java    | 4 ++--
 .../java/org/apache/ignite/client/ClientKeyValueViewTest.java     | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientLoggingTest.java | 4 ++--
 .../test/java/org/apache/ignite/client/ClientRecordViewTest.java  | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientSqlTest.java     | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientTableTest.java   | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientTablesTest.java  | 4 ++--
 .../src/test/java/org/apache/ignite/client/ClientTupleTest.java   | 4 ++--
 .../src/test/java/org/apache/ignite/client/ConfigurationTest.java | 4 ++--
 .../src/test/java/org/apache/ignite/client/ConnectionTest.java    | 4 ++--
 .../src/test/java/org/apache/ignite/client/CustomTuple.java       | 4 ++--
 .../src/test/java/org/apache/ignite/client/HeartbeatTest.java     | 4 ++--
 .../src/test/java/org/apache/ignite/client/ReconnectTest.java     | 4 ++--
 .../src/test/java/org/apache/ignite/client/RetryPolicyTest.java   | 4 ++--
 .../java/org/apache/ignite/client/TestClientHandlerModule.java    | 4 ++--
 .../src/test/java/org/apache/ignite/client/TestRetryPolicy.java   | 4 ++--
 .../client/src/test/java/org/apache/ignite/client/TestServer.java | 4 ++--
 .../java/org/apache/ignite/client/fakes/FakeAsyncResultSet.java   | 4 ++--
 .../java/org/apache/ignite/client/fakes/FakeColumnMetadata.java   | 4 ++--
 .../src/test/java/org/apache/ignite/client/fakes/FakeCursor.java  | 4 ++--
 .../src/test/java/org/apache/ignite/client/fakes/FakeIgnite.java  | 4 ++--
 .../org/apache/ignite/client/fakes/FakeIgniteQueryProcessor.java  | 4 ++--
 .../test/java/org/apache/ignite/client/fakes/FakeIgniteSql.java   | 4 ++--
 .../java/org/apache/ignite/client/fakes/FakeIgniteTables.java     | 4 ++--
 .../java/org/apache/ignite/client/fakes/FakeInternalTable.java    | 4 ++--
 .../java/org/apache/ignite/client/fakes/FakeSchemaRegistry.java   | 4 ++--
 .../src/test/java/org/apache/ignite/client/fakes/FakeSession.java | 4 ++--
 .../java/org/apache/ignite/client/fakes/FakeSessionBuilder.java   | 4 ++--
 .../org/apache/ignite/internal/client/HostAndPortRangeTest.java   | 4 ++--
 .../ignite/internal/cluster/management/ItClusterManagerTest.java  | 2 +-
 .../org/apache/ignite/internal/cluster/management/MockNode.java   | 2 +-
 .../internal/cluster/management/raft/ItCmgRaftServiceTest.java    | 2 +-
 .../management/rest/ItClusterManagementControllerTest.java        | 4 ++--
 .../ignite/internal/cluster/management/rest/RestTestBase.java     | 4 ++--
 .../ignite/internal/cluster/management/ClusterInitializer.java    | 2 +-
 .../cluster/management/ClusterManagementGroupManager.java         | 2 +-
 .../apache/ignite/internal/cluster/management/ClusterState.java   | 2 +-
 .../org/apache/ignite/internal/cluster/management/ClusterTag.java | 2 +-
 .../apache/ignite/internal/cluster/management/InitException.java  | 2 +-
 .../ignite/internal/cluster/management/InternalInitException.java | 2 +-
 .../ignite/internal/cluster/management/LocalStateStorage.java     | 2 +-
 .../cluster/management/network/CmgMessageHandlerFactory.java      | 2 +-
 .../cluster/management/network/messages/CancelInitMessage.java    | 2 +-
 .../cluster/management/network/messages/ClusterStateMessage.java  | 2 +-
 .../cluster/management/network/messages/CmgInitMessage.java       | 2 +-
 .../cluster/management/network/messages/CmgMessageGroup.java      | 2 +-
 .../cluster/management/network/messages/InitCompleteMessage.java  | 2 +-
 .../cluster/management/network/messages/InitErrorMessage.java     | 2 +-
 .../management/network/messages/SuccessResponseMessage.java       | 2 +-
 .../internal/cluster/management/raft/ClusterStateStorage.java     | 2 +-
 .../internal/cluster/management/raft/CmgRaftGroupListener.java    | 2 +-
 .../ignite/internal/cluster/management/raft/CmgRaftService.java   | 2 +-
 .../cluster/management/raft/IllegalInitArgumentException.java     | 2 +-
 .../internal/cluster/management/raft/JoinDeniedException.java     | 2 +-
 .../internal/cluster/management/raft/RaftStorageManager.java      | 2 +-
 .../cluster/management/raft/RocksDbClusterStateStorage.java       | 2 +-
 .../internal/cluster/management/raft/ValidationManager.java       | 2 +-
 .../ignite/internal/cluster/management/raft/ValidationResult.java | 2 +-
 .../cluster/management/raft/commands/InitCmgStateCommand.java     | 2 +-
 .../cluster/management/raft/commands/JoinReadyCommand.java        | 2 +-
 .../cluster/management/raft/commands/JoinRequestCommand.java      | 2 +-
 .../cluster/management/raft/commands/NodesLeaveCommand.java       | 2 +-
 .../management/raft/commands/ReadLogicalTopologyCommand.java      | 2 +-
 .../cluster/management/raft/commands/ReadStateCommand.java        | 2 +-
 .../management/raft/responses/LogicalTopologyResponse.java        | 2 +-
 .../management/raft/responses/ValidationErrorResponse.java        | 2 +-
 .../cluster/management/rest/ClusterManagementController.java      | 4 ++--
 .../cluster/management/rest/ClusterManagementRestFactory.java     | 4 ++--
 .../internal/cluster/management/rest/TopologyController.java      | 4 ++--
 .../exception/InvalidArgumentClusterInitializationException.java  | 4 ++--
 .../exception/handler/IgniteInternalCheckedExceptionHandler.java  | 4 ++--
 .../rest/exception/handler/IgniteInternalExceptionHandler.java    | 4 ++--
 .../InvalidArgumentClusterInitializationExceptionHandler.java     | 4 ++--
 .../internal/cluster/management/ClusterInitializerTest.java       | 2 +-
 .../management/raft/AbstractClusterStateStorageManagerTest.java   | 2 +-
 .../cluster/management/raft/AbstractClusterStateStorageTest.java  | 2 +-
 .../cluster/management/raft/CmgRaftGroupListenerTest.java         | 2 +-
 .../raft/ConcurrentMapClusterStateStorageManagerTest.java         | 2 +-
 .../management/raft/ConcurrentMapClusterStateStorageTest.java     | 2 +-
 .../management/raft/RocksDbClusterStateStorageManagerTest.java    | 2 +-
 .../cluster/management/raft/RocksDbClusterStateStorageTest.java   | 2 +-
 .../cluster/management/raft/ConcurrentMapClusterStateStorage.java | 2 +-
 .../java/org/apache/ignite/internal/compute/ComputeComponent.java | 4 ++--
 .../org/apache/ignite/internal/compute/ComputeComponentImpl.java  | 4 ++--
 .../org/apache/ignite/internal/compute/ComputeMessageTypes.java   | 4 ++--
 .../org/apache/ignite/internal/compute/IgniteComputeImpl.java     | 4 ++--
 .../apache/ignite/internal/compute/JobExecutionContextImpl.java   | 4 ++--
 .../apache/ignite/internal/compute/message/ExecuteRequest.java    | 4 ++--
 .../apache/ignite/internal/compute/message/ExecuteResponse.java   | 4 ++--
 .../apache/ignite/internal/compute/ComputeComponentImplTest.java  | 4 ++--
 .../org/apache/ignite/internal/compute/IgniteComputeImplTest.java | 4 ++--
 .../ignite/internal/compute/JobExecutionContextImplTest.java      | 4 ++--
 .../internal/configuration/processor/AbstractProcessorTest.java   | 4 ++--
 .../apache/ignite/internal/configuration/processor/ConfigSet.java | 4 ++--
 .../ignite/internal/configuration/processor/HasFieldMatcher.java  | 4 ++--
 .../ignite/internal/configuration/processor/HasMethodMatcher.java | 4 ++--
 .../configuration/processor/ItConfigurationProcessorTest.java     | 4 ++--
 .../ignite/internal/configuration/processor/ParsedClass.java      | 4 ++--
 .../processor/ConfigurationSchemaWithWrongPostfix.java            | 4 ++--
 .../internal/configuration/processor/TestConfigurationSchema.java | 4 ++--
 .../abstractconfig/AbstractConfigConfigurationSchema.java         | 4 ++--
 .../AbstractConfigWithInjectedNameConfigurationSchema.java        | 4 ++--
 .../AbstractConfigWithInternalIdConfigurationSchema.java          | 4 ++--
 .../abstractconfig/AbstractRootConfigConfigurationSchema.java     | 4 ++--
 .../processor/abstractconfig/SimpleConfigConfigurationSchema.java | 4 ++--
 .../abstractconfig/SimpleConfigRootConfigurationSchema.java       | 4 ++--
 ...nfigCanExtendOnlyAbstractConfigurationConfigurationSchema.java | 4 ++--
 ...igConflictFieldNamesWithAbstractConfigConfigurationSchema.java | 4 ++--
 ...tContainInjectedNameWithAbstractConfigConfigurationSchema.java | 4 ++--
 ...NotContainInternalIdWithAbstractConfigConfigurationSchema.java | 4 ++--
 ...RootCanExtendOnlyAbstractConfigurationConfigurationSchema.java | 4 ++--
 ...otConflictFieldNamesWithAbstractConfigConfigurationSchema.java | 4 ++--
 ...NotContainInjectedNameInAbstractConfigConfigurationSchema.java | 4 ++--
 ...stNotContainInternalIdInAbstractConfigConfigurationSchema.java | 4 ++--
 ...NameFromAbstractConfigMustContainsNameConfigurationSchema.java | 4 ++--
 .../IncompatibleSchemaAnnotations0ConfigurationSchema.java        | 4 ++--
 .../IncompatibleSchemaAnnotations1ConfigurationSchema.java        | 4 ++--
 .../IncompatibleSchemaAnnotations2ConfigurationSchema.java        | 4 ++--
 .../IncompatibleSchemaAnnotations3ConfigurationSchema.java        | 4 ++--
 .../IncompatibleSchemaAnnotations4ConfigurationSchema.java        | 4 ++--
 .../validation/MustNotBeSuperClassConfigurationSchema.java        | 4 ++--
 .../MustNotContainPolymorphicIdConfigurationSchema.java           | 4 ++--
 .../injectedname/ErrorInjectedName0ConfigurationSchema.java       | 4 ++--
 .../injectedname/ErrorInjectedName1ConfigurationSchema.java       | 4 ++--
 .../injectedname/ErrorInjectedName2ConfigurationSchema.java       | 4 ++--
 .../injectedname/ErrorInjectedName3ConfigurationSchema.java       | 4 ++--
 .../injectedname/ErrorInjectedName4ConfigurationSchema.java       | 4 ++--
 .../injectedname/ErrorInjectedName5ConfigurationSchema.java       | 4 ++--
 .../processor/injectedname/ErrorName0ConfigurationSchema.java     | 4 ++--
 .../processor/injectedname/ErrorName1ConfigurationSchema.java     | 4 ++--
 .../processor/injectedname/NameConfigurationSchema.java           | 4 ++--
 .../processor/injectedname/PolyConfigurationSchema.java           | 4 ++--
 .../processor/injectedname/SimpleConfigurationSchema.java         | 4 ++--
 .../processor/internal/ErrorInternal0ConfigurationSchema.java     | 4 ++--
 .../processor/internal/ErrorInternal1ConfigurationSchema.java     | 4 ++--
 .../processor/internal/ErrorInternal2ConfigurationSchema.java     | 4 ++--
 .../processor/internal/ErrorInternal3ConfigurationSchema.java     | 4 ++--
 .../processor/internal/ErrorInternal4ConfigurationSchema.java     | 4 ++--
 .../processor/internal/ErrorInternal5ConfigurationSchema.java     | 4 ++--
 .../processor/internal/ExtendedSimpleConfigurationSchema.java     | 4 ++--
 .../processor/internal/ExtendedSimpleRootConfigurationSchema.java | 4 ++--
 .../processor/internal/SimpleConfigurationSchema.java             | 4 ++--
 .../processor/internal/SimpleRootConfigurationSchema.java         | 4 ++--
 .../processor/internal/StaticConstantsConfigurationSchema.java    | 4 ++--
 .../processor/internalid/ErrorInternalId0ConfigurationSchema.java | 4 ++--
 .../internalid/SimpleInternalId0ConfigurationSchema.java          | 4 ++--
 .../polymorphic/ErrorPolymorphic0ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic1ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic2ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic3ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic4ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic5ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic6ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic7ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphic8ConfigurationSchema.java         | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance0ConfigurationSchema.java | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance1ConfigurationSchema.java | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance2ConfigurationSchema.java | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance3ConfigurationSchema.java | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance4ConfigurationSchema.java | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance5ConfigurationSchema.java | 4 ++--
 .../polymorphic/ErrorPolymorphicInstance6ConfigurationSchema.java | 4 ++--
 .../processor/polymorphic/SimpleConfigurationSchema.java          | 4 ++--
 .../polymorphic/SimplePolymorphicConfigurationSchema.java         | 4 ++--
 .../polymorphic/SimplePolymorphicInstanceConfigurationSchema.java | 4 ++--
 .../processor/polymorphic/SimpleRootConfigurationSchema.java      | 4 ++--
 .../internal/configuration/processor/ConfigurationProcessor.java  | 4 ++--
 .../configuration/processor/ConfigurationProcessorException.java  | 4 ++--
 .../configuration/processor/ConfigurationProcessorUtils.java      | 4 ++--
 .../configuration/processor/ConfigurationProcessorUtilsTest.java  | 4 ++--
 .../apache/ignite/configuration/ConfigurationChangeException.java | 4 ++--
 .../ignite/configuration/ConfigurationListenOnlyException.java    | 4 ++--
 .../org/apache/ignite/configuration/ConfigurationProperty.java    | 4 ++--
 .../ignite/configuration/ConfigurationReadOnlyException.java      | 4 ++--
 .../java/org/apache/ignite/configuration/ConfigurationTree.java   | 4 ++--
 .../java/org/apache/ignite/configuration/ConfigurationValue.java  | 4 ++--
 .../ConfigurationWrongPolymorphicTypeIdException.java             | 4 ++--
 .../org/apache/ignite/configuration/NamedConfigurationTree.java   | 4 ++--
 .../java/org/apache/ignite/configuration/NamedListChange.java     | 4 ++--
 .../main/java/org/apache/ignite/configuration/NamedListView.java  | 4 ++--
 .../java/org/apache/ignite/configuration/PolymorphicChange.java   | 4 ++--
 .../src/main/java/org/apache/ignite/configuration/RootKey.java    | 4 ++--
 .../ignite/configuration/annotation/AbstractConfiguration.java    | 4 ++--
 .../java/org/apache/ignite/configuration/annotation/Config.java   | 4 ++--
 .../org/apache/ignite/configuration/annotation/ConfigValue.java   | 4 ++--
 .../apache/ignite/configuration/annotation/ConfigurationRoot.java | 4 ++--
 .../apache/ignite/configuration/annotation/ConfigurationType.java | 4 ++--
 .../org/apache/ignite/configuration/annotation/InjectedName.java  | 4 ++--
 .../ignite/configuration/annotation/InternalConfiguration.java    | 4 ++--
 .../org/apache/ignite/configuration/annotation/InternalId.java    | 2 +-
 .../java/org/apache/ignite/configuration/annotation/Name.java     | 4 ++--
 .../apache/ignite/configuration/annotation/NamedConfigValue.java  | 4 ++--
 .../apache/ignite/configuration/annotation/PolymorphicConfig.java | 4 ++--
 .../configuration/annotation/PolymorphicConfigInstance.java       | 4 ++--
 .../org/apache/ignite/configuration/annotation/PolymorphicId.java | 4 ++--
 .../java/org/apache/ignite/configuration/annotation/Value.java    | 4 ++--
 .../org/apache/ignite/configuration/annotation/package-info.java  | 4 ++--
 .../ignite/configuration/notifications/ConfigurationListener.java | 4 ++--
 .../notifications/ConfigurationNamedListListener.java             | 4 ++--
 .../notifications/ConfigurationNotificationEvent.java             | 4 ++--
 .../apache/ignite/configuration/notifications/package-info.java   | 4 ++--
 .../main/java/org/apache/ignite/configuration/package-info.java   | 4 ++--
 .../validation/ConfigurationValidationException.java              | 4 ++--
 .../org/apache/ignite/configuration/validation/ExceptKeys.java    | 4 ++--
 .../org/apache/ignite/configuration/validation/Immutable.java     | 4 ++--
 .../java/org/apache/ignite/configuration/validation/OneOf.java    | 4 ++--
 .../org/apache/ignite/configuration/validation/PowerOfTwo.java    | 4 ++--
 .../java/org/apache/ignite/configuration/validation/Range.java    | 4 ++--
 .../apache/ignite/configuration/validation/ValidationContext.java | 4 ++--
 .../apache/ignite/configuration/validation/ValidationIssue.java   | 4 ++--
 .../org/apache/ignite/configuration/validation/Validator.java     | 4 ++--
 .../org/apache/ignite/configuration/validation/package-info.java  | 4 ++--
 .../internal/configuration/ComponentNotStartedException.java      | 4 ++--
 .../ignite/internal/configuration/ConfigurationChanger.java       | 4 ++--
 .../internal/configuration/ConfigurationListenerHolder.java       | 4 ++--
 .../ignite/internal/configuration/ConfigurationManager.java       | 4 ++--
 .../apache/ignite/internal/configuration/ConfigurationModule.java | 4 ++--
 .../apache/ignite/internal/configuration/ConfigurationNode.java   | 4 ++--
 .../ignite/internal/configuration/ConfigurationRegistry.java      | 4 ++--
 .../ignite/internal/configuration/ConfigurationTreeWrapper.java   | 4 ++--
 .../ignite/internal/configuration/DynamicConfiguration.java       | 4 ++--
 .../internal/configuration/DynamicConfigurationChanger.java       | 4 ++--
 .../org/apache/ignite/internal/configuration/DynamicProperty.java | 4 ++--
 .../ignite/internal/configuration/NamedListConfiguration.java     | 4 ++--
 .../org/apache/ignite/internal/configuration/RootInnerNode.java   | 4 ++--
 .../java/org/apache/ignite/internal/configuration/SuperRoot.java  | 4 ++--
 .../java/org/apache/ignite/internal/configuration/TypeUtils.java  | 4 ++--
 .../internal/configuration/asm/ConfigurationAsmGenerator.java     | 4 ++--
 .../internal/configuration/asm/DirectProxyAsmGenerator.java       | 4 ++--
 .../ignite/internal/configuration/asm/SchemaClassesInfo.java      | 4 ++--
 .../ignite/internal/configuration/asm/StringSwitchBuilder.java    | 4 ++--
 .../internal/configuration/direct/DirectConfigurationProxy.java   | 4 ++--
 .../internal/configuration/direct/DirectNamedListProxy.java       | 4 ++--
 .../ignite/internal/configuration/direct/DirectPropertyProxy.java | 4 ++--
 .../ignite/internal/configuration/direct/DirectValueProxy.java    | 4 ++--
 .../apache/ignite/internal/configuration/direct/KeyPathNode.java  | 4 ++--
 .../ignite/internal/configuration/hocon/HoconConverter.java       | 4 ++--
 .../configuration/hocon/HoconListConfigurationSource.java         | 4 ++--
 .../configuration/hocon/HoconObjectConfigurationSource.java       | 4 ++--
 .../configuration/hocon/HoconPrimitiveConfigurationSource.java    | 4 ++--
 .../configuration/notifications/ConfigurationContainer.java       | 4 ++--
 .../notifications/ConfigurationNotificationContext.java           | 4 ++--
 .../notifications/ConfigurationNotificationEventImpl.java         | 4 ++--
 .../notifications/ConfigurationNotificationUtils.java             | 4 ++--
 .../configuration/notifications/ConfigurationNotifier.java        | 4 ++--
 .../notifications/ConfigurationStorageRevisionListener.java       | 4 ++--
 .../notifications/ConfigurationStorageRevisionListenerHolder.java | 4 ++--
 .../internal/configuration/notifications/NamedListChanges.java    | 4 ++--
 .../rest/presentation/ConfigurationPresentation.java              | 4 ++--
 .../configuration/rest/presentation/hocon/HoconPresentation.java  | 4 ++--
 .../configuration/rest/presentation/hocon/package-info.java       | 4 ++--
 .../internal/configuration/rest/presentation/package-info.java    | 4 ++--
 .../internal/configuration/storage/ConfigurationStorage.java      | 4 ++--
 .../configuration/storage/ConfigurationStorageListener.java       | 4 ++--
 .../org/apache/ignite/internal/configuration/storage/Data.java    | 4 ++--
 .../ignite/internal/configuration/storage/StorageException.java   | 4 ++--
 .../ignite/internal/configuration/tree/ConfigurationSource.java   | 4 ++--
 .../ignite/internal/configuration/tree/ConfigurationVisitor.java  | 4 ++--
 .../ignite/internal/configuration/tree/ConstructableTreeNode.java | 4 ++--
 .../ignite/internal/configuration/tree/ConverterToMapVisitor.java | 4 ++--
 .../org/apache/ignite/internal/configuration/tree/InnerNode.java  | 4 ++--
 .../apache/ignite/internal/configuration/tree/NamedListNode.java  | 4 ++--
 .../org/apache/ignite/internal/configuration/tree/OrderedMap.java | 4 ++--
 .../ignite/internal/configuration/tree/TraversableTreeNode.java   | 4 ++--
 .../internal/configuration/util/AnyNodeConfigurationVisitor.java  | 4 ++--
 .../internal/configuration/util/ConfigurationFlattener.java       | 4 ++--
 .../configuration/util/ConfigurationSerializationUtil.java        | 4 ++--
 .../ignite/internal/configuration/util/ConfigurationUtil.java     | 4 ++--
 .../ignite/internal/configuration/util/KeyNotFoundException.java  | 4 ++--
 .../configuration/util/KeysTrackingConfigurationVisitor.java      | 4 ++--
 .../configuration/util/WrongPolymorphicTypeIdException.java       | 4 ++--
 .../internal/configuration/validation/ExceptKeysValidator.java    | 4 ++--
 .../internal/configuration/validation/ImmutableValidator.java     | 4 ++--
 .../ignite/internal/configuration/validation/MemberKey.java       | 4 ++--
 .../ignite/internal/configuration/validation/OneOfValidator.java  | 4 ++--
 .../internal/configuration/validation/PowerOfTwoValidator.java    | 4 ++--
 .../ignite/internal/configuration/validation/RangeValidator.java  | 4 ++--
 .../internal/configuration/validation/ValidationContextImpl.java  | 4 ++--
 .../ignite/internal/configuration/validation/ValidationUtil.java  | 4 ++--
 .../rest/configuration/AbstractConfigurationController.java       | 4 ++--
 .../rest/configuration/ClusterConfigurationController.java        | 4 ++--
 .../internal/rest/configuration/NodeConfigurationController.java  | 4 ++--
 .../ignite/internal/rest/configuration/PresentationsFactory.java  | 4 ++--
 .../ignite/internal/configuration/ConfigurationChangerTest.java   | 4 ++--
 .../internal/configuration/ConfigurationListenerHolderTest.java   | 4 ++--
 .../ignite/internal/configuration/ConfigurationRegistryTest.java  | 4 ++--
 .../ignite/internal/configuration/ConfigurationTestUtils.java     | 4 ++--
 .../internal/configuration/asm/ConfigurationAsmGeneratorTest.java | 4 ++--
 .../internal/configuration/direct/DirectPropertiesTest.java       | 4 ++--
 .../ignite/internal/configuration/hocon/HoconConverterTest.java   | 4 ++--
 .../configuration/notifications/ConfigurationAnyListenerTest.java | 4 ++--
 .../configuration/notifications/ConfigurationListenerTest.java    | 4 ++--
 .../notifications/ConfigurationListenerTestUtils.java             | 4 ++--
 .../rest/presentation/ConfigurationPresentationTest.java          | 4 ++--
 .../configuration/sample/AutoAdjustConfigurationSchema.java       | 4 ++--
 .../configuration/sample/BaselineConfigurationSchema.java         | 4 ++--
 .../internal/configuration/sample/CacheConfigurationSchema.java   | 4 ++--
 .../configuration/sample/ClusterWideConfigurationSchema.java      | 4 ++--
 .../configuration/sample/DiscoveryConfigurationSchema.java        | 4 ++--
 .../sample/ExtendedDiscoveryConfigurationSchema.java              | 4 ++--
 .../internal/configuration/sample/LocalConfigurationSchema.java   | 4 ++--
 .../internal/configuration/sample/NetworkConfigurationSchema.java | 4 ++--
 .../internal/configuration/sample/NodeConfigurationSchema.java    | 4 ++--
 .../apache/ignite/internal/configuration/sample/UsageTest.java    | 4 ++--
 .../configuration/testframework/ConfigurationExtensionTest.java   | 4 ++--
 .../internal/configuration/tree/ConfigurationArrayTest.java       | 4 ++--
 .../internal/configuration/tree/ConstructableTreeNodeTest.java    | 4 ++--
 .../apache/ignite/internal/configuration/tree/InternalIdTest.java | 4 ++--
 .../ignite/internal/configuration/tree/NamedListNodeTest.java     | 4 ++--
 .../apache/ignite/internal/configuration/tree/OrderedMapTest.java | 4 ++--
 .../internal/configuration/tree/TraversableTreeNodeTest.java      | 4 ++--
 .../configuration/util/ConfigurationSerializationUtilTest.java    | 4 ++--
 .../ignite/internal/configuration/util/ConfigurationUtilTest.java | 4 ++--
 .../internal/configuration/validation/OneOfValidatorTest.java     | 4 ++--
 .../configuration/validation/PowerOfTwoValidatorTest.java         | 4 ++--
 .../internal/configuration/validation/RangeValidatorTest.java     | 4 ++--
 .../internal/configuration/validation/ValidationUtilTest.java     | 4 ++--
 .../rest/configuration/ClusterConfigurationControllerTest.java    | 4 ++--
 .../rest/configuration/ConfigurationControllerBaseTest.java       | 4 ++--
 .../rest/configuration/NodeConfigurationControllerTest.java       | 4 ++--
 .../apache/ignite/internal/rest/configuration/TestFactory.java    | 4 ++--
 .../internal/rest/configuration/TestRootConfigurationSchema.java  | 4 ++--
 .../internal/rest/configuration/TestSubConfigurationSchema.java   | 4 ++--
 .../ignite/internal/configuration/TestConfigurationChanger.java   | 4 ++--
 .../internal/configuration/storage/TestConfigurationStorage.java  | 4 ++--
 .../configuration/testframework/BasicConfigurationSchema.java     | 4 ++--
 .../configuration/testframework/ConfigurationExtension.java       | 4 ++--
 .../configuration/testframework/ExtendedConfigurationSchema.java  | 4 ++--
 .../internal/configuration/testframework/InjectConfiguration.java | 4 ++--
 .../configuration/testframework/InjectRevisionListenerHolder.java | 4 ++--
 .../internal/configuration/validation/TestValidationUtil.java     | 4 ++--
 modules/core/src/main/java/org/apache/ignite/hlc/HybridClock.java | 4 ++--
 .../core/src/main/java/org/apache/ignite/hlc/HybridTimestamp.java | 2 +-
 .../apache/ignite/internal/causality/OutdatedTokenException.java  | 4 ++--
 .../java/org/apache/ignite/internal/causality/VersionedValue.java | 4 ++--
 .../apache/ignite/internal/components/LongJvmPauseDetector.java   | 4 ++--
 .../java/org/apache/ignite/internal/future/InFlightFutures.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/logger/IgniteLogger.java | 4 ++--
 .../src/main/java/org/apache/ignite/internal/logger/Loggers.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/logger/VoidLogger.java   | 4 ++--
 .../src/main/java/org/apache/ignite/internal/manager/Event.java   | 4 ++--
 .../java/org/apache/ignite/internal/manager/EventListener.java    | 4 ++--
 .../java/org/apache/ignite/internal/manager/EventParameters.java  | 4 ++--
 .../java/org/apache/ignite/internal/manager/IgniteComponent.java  | 4 ++--
 .../apache/ignite/internal/manager/ListenerRemovedException.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/manager/Producer.java    | 4 ++--
 .../apache/ignite/internal/properties/IgniteProductVersion.java   | 2 +-
 .../org/apache/ignite/internal/properties/IgniteProperties.java   | 2 +-
 .../main/java/org/apache/ignite/internal/thread/IgniteThread.java | 4 ++--
 .../ignite/internal/thread/LogUncaughtExceptionHandler.java       | 6 +++---
 .../org/apache/ignite/internal/thread/NamedThreadFactory.java     | 6 +++---
 .../apache/ignite/internal/thread/StripedThreadPoolExecutor.java  | 4 ++--
 .../apache/ignite/internal/tostring/CircularStringBuilder.java    | 4 ++--
 .../java/org/apache/ignite/internal/tostring/ClassDescriptor.java | 4 ++--
 .../java/org/apache/ignite/internal/tostring/FieldDescriptor.java | 4 ++--
 .../apache/ignite/internal/tostring/IgniteToStringBuilder.java    | 4 ++--
 .../apache/ignite/internal/tostring/IgniteToStringExclude.java    | 4 ++--
 .../apache/ignite/internal/tostring/IgniteToStringInclude.java    | 4 ++--
 .../org/apache/ignite/internal/tostring/IgniteToStringOrder.java  | 4 ++--
 .../core/src/main/java/org/apache/ignite/internal/tostring/S.java | 4 ++--
 .../ignite/internal/tostring/SensitiveDataLoggingPolicy.java      | 4 ++--
 .../ignite/internal/tostring/StringBuilderLimitedLength.java      | 4 ++--
 .../main/java/org/apache/ignite/internal/util/ArrayFactory.java   | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/ArrayUtils.java | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/ByteUtils.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/util/Cancellable.java    | 4 ++--
 .../java/org/apache/ignite/internal/util/CollectionUtils.java     | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/Constants.java  | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/Cursor.java     | 4 ++--
 .../main/java/org/apache/ignite/internal/util/ExceptionUtils.java | 2 +-
 .../main/java/org/apache/ignite/internal/util/FastTimestamps.java | 4 ++--
 .../main/java/org/apache/ignite/internal/util/FeatureChecker.java | 4 ++--
 .../java/org/apache/ignite/internal/util/FilteringIterator.java   | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/GridUnsafe.java | 4 ++--
 .../main/java/org/apache/ignite/internal/util/HashCalculator.java | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/HashUtils.java  | 4 ++--
 .../ignite/internal/util/IgniteConcurrentMultiPairQueue.java      | 4 ++--
 .../main/java/org/apache/ignite/internal/util/IgniteCursor.java   | 4 ++--
 .../java/org/apache/ignite/internal/util/IgniteIntIterator.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/util/IgniteIntList.java  | 4 ++--
 .../java/org/apache/ignite/internal/util/IgniteObjectName.java    | 4 ++--
 .../java/org/apache/ignite/internal/util/IgniteSpinBusyLock.java  | 4 ++--
 .../org/apache/ignite/internal/util/IgniteSpinReadWriteLock.java  | 4 ++--
 .../java/org/apache/ignite/internal/util/IgniteStripedLock.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/util/IgniteUtils.java    | 4 ++--
 .../org/apache/ignite/internal/util/OffheapReadWriteLock.java     | 4 ++--
 .../java/org/apache/ignite/internal/util/ReverseIterator.java     | 2 +-
 .../java/org/apache/ignite/internal/util/StringIntrospection.java | 4 ++--
 .../main/java/org/apache/ignite/internal/util/StringUtils.java    | 2 +-
 .../org/apache/ignite/internal/util/TransformingIterator.java     | 4 ++--
 .../java/org/apache/ignite/internal/util/io/IgniteDataInput.java  | 4 ++--
 .../java/org/apache/ignite/internal/util/io/IgniteDataOutput.java | 4 ++--
 .../org/apache/ignite/internal/util/io/IgniteUnsafeDataInput.java | 4 ++--
 .../apache/ignite/internal/util/io/IgniteUnsafeDataOutput.java    | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/io/VarInts.java | 4 ++--
 .../java/org/apache/ignite/internal/util/worker/IgniteWorker.java | 4 ++--
 .../apache/ignite/internal/util/worker/IgniteWorkerListener.java  | 4 ++--
 .../ignite/internal/util/worker/WorkProgressDispatcher.java       | 4 ++--
 modules/core/src/main/java/org/apache/ignite/lang/ByteArray.java  | 4 ++--
 modules/core/src/main/java/org/apache/ignite/lang/ErrorGroup.java | 4 ++--
 .../core/src/main/java/org/apache/ignite/lang/ErrorGroups.java    | 4 ++--
 .../core/src/main/java/org/apache/ignite/lang/IgniteBiTuple.java  | 4 ++--
 .../org/apache/ignite/lang/IgniteInternalCheckedException.java    | 4 ++--
 .../main/java/org/apache/ignite/lang/IgniteInternalException.java | 4 ++--
 .../src/main/java/org/apache/ignite/lang/IgniteStringBuilder.java | 4 ++--
 .../main/java/org/apache/ignite/lang/IgniteStringFormatter.java   | 4 ++--
 .../main/java/org/apache/ignite/lang/IgniteSystemProperties.java  | 4 ++--
 .../src/main/java/org/apache/ignite/lang/IgniteTetraFunction.java | 4 ++--
 .../src/main/java/org/apache/ignite/lang/IgniteTriConsumer.java   | 4 ++--
 .../src/main/java/org/apache/ignite/lang/IgniteTriFunction.java   | 4 ++--
 .../core/src/main/java/org/apache/ignite/lang/IgniteTuple3.java   | 4 ++--
 modules/core/src/main/java/org/apache/ignite/lang/IgniteUuid.java | 4 ++--
 .../src/main/java/org/apache/ignite/lang/IgniteUuidGenerator.java | 4 ++--
 .../src/main/java/org/apache/ignite/lang/JavaLoggerFormatter.java | 4 ++--
 .../core/src/main/java/org/apache/ignite/lang/LoggerFactory.java  | 4 ++--
 .../main/java/org/apache/ignite/lang/NodeStoppingException.java   | 4 ++--
 .../core/src/main/java/org/apache/ignite/lang/package-info.java   | 4 ++--
 .../extensions/communication/MessageCollectionItemType.java       | 4 ++--
 .../ignite/plugin/extensions/communication/package-info.java      | 4 ++--
 .../core/src/test/java/org/apache/ignite/hlc/HybridClockTest.java | 4 ++--
 .../src/test/java/org/apache/ignite/hlc/HybridClockTestUtils.java | 4 ++--
 .../src/test/java/org/apache/ignite/hlc/HybridTimestampTest.java  | 4 ++--
 .../org/apache/ignite/internal/causality/VersionedValueTest.java  | 4 ++--
 .../org/apache/ignite/internal/future/InFlightFuturesTest.java    | 4 ++--
 .../java/org/apache/ignite/internal/manager/ProducerTest.java     | 4 ++--
 .../ignite/internal/properties/IgniteProductVersionTest.java      | 2 +-
 .../apache/ignite/internal/testframework/VariableSourceTest.java  | 2 +-
 .../ignite/internal/testframework/WorkDirectoryExtensionTest.java | 2 +-
 .../ignite/internal/tostring/CircularStringBuilderSelfTest.java   | 4 ++--
 .../ignite/internal/tostring/IgniteToStringBuilderSelfTest.java   | 4 ++--
 .../ignite/internal/tostring/SensitiveDataToStringTest.java       | 4 ++--
 .../java/org/apache/ignite/internal/util/ArrayUtilsSelfTest.java  | 4 ++--
 .../java/org/apache/ignite/internal/util/CollectionUtilsTest.java | 4 ++--
 .../test/java/org/apache/ignite/internal/util/HashUtilsTest.java  | 4 ++--
 .../ignite/internal/util/IgniteConcurrentMultiPairQueueTest.java  | 4 ++--
 .../org/apache/ignite/internal/util/IgniteIntListSelfTest.java    | 4 ++--
 .../ignite/internal/util/IgniteOffheapReadWriteLockSelfTest.java  | 4 ++--
 .../test/java/org/apache/ignite/internal/util/IgniteRandom.java   | 4 ++--
 .../org/apache/ignite/internal/util/IgniteRandomSelfTest.java     | 4 ++--
 .../apache/ignite/internal/util/IgniteSpinReadWriteLockTest.java  | 4 ++--
 .../apache/ignite/internal/util/IgniteStripedLockSelfTest.java    | 4 ++--
 .../java/org/apache/ignite/internal/util/IgniteUtilsTest.java     | 4 ++--
 .../org/apache/ignite/internal/util/StringIntrospectionTest.java  | 8 ++++----
 .../org/apache/ignite/internal/util/io/IgniteTestIoUtils.java     | 4 ++--
 .../util/io/IgniteUnsafeDataInputOutputByteOrderTest.java         | 4 ++--
 .../apache/ignite/internal/util/io/IgniteUnsafeDataInputTest.java | 4 ++--
 .../internal/util/io/IgniteUnsafeDataOutputArraySizingTest.java   | 4 ++--
 .../test/java/org/apache/ignite/internal/util/io/VarIntsTest.java | 4 ++--
 .../org/apache/ignite/internal/util/worker/IgniteWorkerTest.java  | 4 ++--
 .../core/src/test/java/org/apache/ignite/lang/ErrorGroupTest.java | 4 ++--
 .../src/test/java/org/apache/ignite/lang/LoggerHelperTest.java    | 4 ++--
 .../ignite/internal/testframework/BaseIgniteAbstractTest.java     | 4 ++--
 .../apache/ignite/internal/testframework/IgniteAbstractTest.java  | 4 ++--
 .../org/apache/ignite/internal/testframework/IgniteTestUtils.java | 4 ++--
 .../ignite/internal/testframework/JunitExtensionTestUtils.java    | 2 +-
 .../ignite/internal/testframework/SystemPropertiesExtension.java  | 4 ++--
 .../ignite/internal/testframework/SystemPropertiesList.java       | 4 ++--
 .../ignite/internal/testframework/VariableArgumentsProvider.java  | 2 +-
 .../org/apache/ignite/internal/testframework/VariableSource.java  | 2 +-
 .../apache/ignite/internal/testframework/WithSystemProperty.java  | 4 ++--
 .../org/apache/ignite/internal/testframework/WorkDirectory.java   | 4 ++--
 .../ignite/internal/testframework/WorkDirectoryExtension.java     | 4 ++--
 .../org/apache/ignite/internal/testframework/jul/NoOpHandler.java | 4 ++--
 .../internal/testframework/matchers/CompletableFutureMatcher.java | 4 ++--
 .../apache/ignite/internal/testframework/util/DirectExecutor.java | 4 ++--
 .../configuration/schema/ExtendedTableConfigurationSchema.java    | 4 ++--
 .../internal/configuration/schema/SchemaConfigurationSchema.java  | 4 ++--
 .../java/org/apache/ignite/internal/fileio/AbstractFileIo.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/fileio/AsyncFileIo.java  | 4 ++--
 .../org/apache/ignite/internal/fileio/AsyncFileIoFactory.java     | 4 ++--
 .../src/main/java/org/apache/ignite/internal/fileio/FileIo.java   | 4 ++--
 .../java/org/apache/ignite/internal/fileio/FileIoDecorator.java   | 4 ++--
 .../java/org/apache/ignite/internal/fileio/FileIoFactory.java     | 4 ++--
 .../org/apache/ignite/internal/fileio/RandomAccessFileIo.java     | 4 ++--
 .../apache/ignite/internal/fileio/RandomAccessFileIoFactory.java  | 4 ++--
 .../org/apache/ignite/internal/fileio/AbstractFileIoTest.java     | 4 ++--
 .../java/org/apache/ignite/internal/fileio/AsyncFileIoTest.java   | 4 ++--
 .../org/apache/ignite/internal/fileio/FileIoDecoratorTest.java    | 4 ++--
 .../org/apache/ignite/internal/fileio/RandomAccessFileIoTest.java | 4 ++--
 .../java/org/apache/ignite/internal/index/ColumnCollation.java    | 4 ++--
 .../src/main/java/org/apache/ignite/internal/index/HashIndex.java | 4 ++--
 .../src/main/java/org/apache/ignite/internal/index/Index.java     | 4 ++--
 .../java/org/apache/ignite/internal/index/IndexDescriptor.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/index/IndexManager.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/index/SortedIndex.java   | 4 ++--
 .../org/apache/ignite/internal/index/SortedIndexDescriptor.java   | 4 ++--
 .../java/org/apache/ignite/internal/index/SortedIndexImpl.java    | 4 ++--
 .../java/org/apache/ignite/internal/index/event/IndexEvent.java   | 4 ++--
 .../apache/ignite/internal/index/event/IndexEventParameters.java  | 4 ++--
 .../java/org/apache/ignite/internal/index/IndexManagerTest.java   | 4 ++--
 .../java/org/apache/ignite/internal/marshaller/BinaryMode.java    | 4 ++--
 .../java/org/apache/ignite/internal/marshaller/FieldAccessor.java | 4 ++--
 .../java/org/apache/ignite/internal/marshaller/Marshaller.java    | 4 ++--
 .../org/apache/ignite/internal/marshaller/MarshallerColumn.java   | 4 ++--
 .../apache/ignite/internal/marshaller/MarshallerException.java    | 4 ++--
 .../org/apache/ignite/internal/marshaller/MarshallerReader.java   | 4 ++--
 .../org/apache/ignite/internal/marshaller/MarshallerUtil.java     | 4 ++--
 .../org/apache/ignite/internal/marshaller/MarshallerWriter.java   | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/Factory.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/util/ObjectFactory.java  | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/Pair.java       | 4 ++--
 .../org/apache/ignite/internal/marshaller/FieldAccessorTest.java  | 4 ++--
 .../internal/marshaller/testobjects/TestObjectWithAllTypes.java   | 4 ++--
 .../testobjects/TestObjectWithNoDefaultConstructor.java           | 4 ++--
 .../marshaller/testobjects/TestObjectWithPrivateConstructor.java  | 4 ++--
 .../ignite/internal/marshaller/testobjects/TestSimpleObject.java  | 4 ++--
 .../internal/metastorage/client/ItMetaStorageRaftGroupTest.java   | 4 ++--
 .../metastorage/client/ItMetaStorageServicePersistenceTest.java   | 4 ++--
 .../internal/metastorage/client/ItMetaStorageServiceTest.java     | 4 ++--
 .../ignite/internal/metastorage/client/CompactedException.java    | 4 ++--
 .../ignite/internal/metastorage/client/CompoundCondition.java     | 2 +-
 .../org/apache/ignite/internal/metastorage/client/Condition.java  | 4 ++--
 .../org/apache/ignite/internal/metastorage/client/Conditions.java | 4 ++--
 .../org/apache/ignite/internal/metastorage/client/CursorImpl.java | 4 ++--
 .../java/org/apache/ignite/internal/metastorage/client/Entry.java | 4 ++--
 .../org/apache/ignite/internal/metastorage/client/EntryEvent.java | 4 ++--
 .../org/apache/ignite/internal/metastorage/client/EntryImpl.java  | 4 ++--
 .../java/org/apache/ignite/internal/metastorage/client/If.java    | 2 +-
 .../ignite/internal/metastorage/client/MetaStorageService.java    | 4 ++--
 .../internal/metastorage/client/MetaStorageServiceImpl.java       | 4 ++--
 .../org/apache/ignite/internal/metastorage/client/Operation.java  | 4 ++--
 .../internal/metastorage/client/OperationTimeoutException.java    | 4 ++--
 .../org/apache/ignite/internal/metastorage/client/Operations.java | 4 ++--
 .../ignite/internal/metastorage/client/SimpleCondition.java       | 2 +-
 .../org/apache/ignite/internal/metastorage/client/Statement.java  | 2 +-
 .../ignite/internal/metastorage/client/StatementResult.java       | 2 +-
 .../org/apache/ignite/internal/metastorage/client/Update.java     | 2 +-
 .../org/apache/ignite/internal/metastorage/client/WatchEvent.java | 4 ++--
 .../apache/ignite/internal/metastorage/client/WatchListener.java  | 4 ++--
 .../apache/ignite/internal/metastorage/client/package-info.java   | 4 ++--
 .../apache/ignite/internal/metastorage/common/ConditionType.java  | 4 ++--
 .../ignite/internal/metastorage/common/MetaStorageException.java  | 4 ++--
 .../apache/ignite/internal/metastorage/common/OperationType.java  | 4 ++--
 .../apache/ignite/internal/metastorage/common/StatementInfo.java  | 2 +-
 .../ignite/internal/metastorage/common/StatementResultInfo.java   | 2 +-
 .../org/apache/ignite/internal/metastorage/common/UpdateInfo.java | 2 +-
 .../metastorage/common/command/CompoundConditionInfo.java         | 2 +-
 .../metastorage/common/command/CompoundConditionType.java         | 2 +-
 .../ignite/internal/metastorage/common/command/ConditionInfo.java | 4 ++--
 .../ignite/internal/metastorage/common/command/ErrorResponse.java | 4 ++--
 .../ignite/internal/metastorage/common/command/GetAllCommand.java | 4 ++--
 .../internal/metastorage/common/command/GetAndPutAllCommand.java  | 4 ++--
 .../internal/metastorage/common/command/GetAndPutCommand.java     | 4 ++--
 .../metastorage/common/command/GetAndRemoveAllCommand.java        | 4 ++--
 .../internal/metastorage/common/command/GetAndRemoveCommand.java  | 4 ++--
 .../ignite/internal/metastorage/common/command/GetCommand.java    | 4 ++--
 .../apache/ignite/internal/metastorage/common/command/IfInfo.java | 2 +-
 .../ignite/internal/metastorage/common/command/InvokeCommand.java | 4 ++--
 .../internal/metastorage/common/command/MultiInvokeCommand.java   | 2 +-
 .../metastorage/common/command/MultipleEntryResponse.java         | 4 ++--
 .../ignite/internal/metastorage/common/command/OperationInfo.java | 4 ++--
 .../ignite/internal/metastorage/common/command/PutAllCommand.java | 4 ++--
 .../ignite/internal/metastorage/common/command/PutCommand.java    | 4 ++--
 .../ignite/internal/metastorage/common/command/RangeCommand.java  | 4 ++--
 .../internal/metastorage/common/command/RemoveAllCommand.java     | 4 ++--
 .../ignite/internal/metastorage/common/command/RemoveCommand.java | 4 ++--
 .../internal/metastorage/common/command/SimpleConditionInfo.java  | 2 +-
 .../internal/metastorage/common/command/SingleEntryResponse.java  | 4 ++--
 .../metastorage/common/command/WatchExactKeysCommand.java         | 4 ++--
 .../metastorage/common/command/WatchRangeKeysCommand.java         | 4 ++--
 .../metastorage/common/command/cursor/CursorCloseCommand.java     | 4 ++--
 .../metastorage/common/command/cursor/CursorHasNextCommand.java   | 4 ++--
 .../metastorage/common/command/cursor/CursorNextCommand.java      | 4 ++--
 .../metastorage/common/command/cursor/CursorsCloseCommand.java    | 4 ++--
 .../apache/ignite/internal/metastorage/common/package-info.java   | 4 ++--
 .../internal/metastorage/server/AbstractCompoundCondition.java    | 2 +-
 .../internal/metastorage/server/AbstractSimpleCondition.java      | 4 ++--
 .../apache/ignite/internal/metastorage/server/AndCondition.java   | 2 +-
 .../ignite/internal/metastorage/server/CompactedException.java    | 4 ++--
 .../org/apache/ignite/internal/metastorage/server/Condition.java  | 4 ++--
 .../java/org/apache/ignite/internal/metastorage/server/Entry.java | 4 ++--
 .../org/apache/ignite/internal/metastorage/server/EntryEvent.java | 4 ++--
 .../ignite/internal/metastorage/server/ExistenceCondition.java    | 4 ++--
 .../java/org/apache/ignite/internal/metastorage/server/If.java    | 2 +-
 .../ignite/internal/metastorage/server/KeyValueStorage.java       | 4 ++--
 .../org/apache/ignite/internal/metastorage/server/Operation.java  | 4 ++--
 .../apache/ignite/internal/metastorage/server/OrCondition.java    | 2 +-
 .../ignite/internal/metastorage/server/RevisionCondition.java     | 4 ++--
 .../org/apache/ignite/internal/metastorage/server/Statement.java  | 2 +-
 .../ignite/internal/metastorage/server/StatementResult.java       | 2 +-
 .../ignite/internal/metastorage/server/TombstoneCondition.java    | 4 ++--
 .../org/apache/ignite/internal/metastorage/server/Update.java     | 2 +-
 .../java/org/apache/ignite/internal/metastorage/server/Value.java | 4 ++--
 .../apache/ignite/internal/metastorage/server/ValueCondition.java | 4 ++--
 .../org/apache/ignite/internal/metastorage/server/WatchEvent.java | 4 ++--
 .../internal/metastorage/server/persistence/RangeCursor.java      | 4 ++--
 .../metastorage/server/persistence/RocksDbKeyValueStorage.java    | 4 ++--
 .../metastorage/server/persistence/RocksStorageUtils.java         | 4 ++--
 .../metastorage/server/persistence/StorageColumnFamilyType.java   | 4 ++--
 .../internal/metastorage/server/persistence/WatchCursor.java      | 4 ++--
 .../internal/metastorage/server/raft/MetaStorageListener.java     | 4 ++--
 .../internal/metastorage/server/AbstractKeyValueStorageTest.java  | 4 ++--
 .../ignite/internal/metastorage/server/AndConditionTest.java      | 2 +-
 .../internal/metastorage/server/ExistenceConditionTest.java       | 4 ++--
 .../ignite/internal/metastorage/server/OrConditionTest.java       | 2 +-
 .../ignite/internal/metastorage/server/RevisionConditionTest.java | 4 ++--
 .../internal/metastorage/server/RocksDbKeyValueStorageTest.java   | 4 ++--
 .../metastorage/server/SimpleInMemoryKeyValueStorageTest.java     | 4 ++--
 .../internal/metastorage/server/TombstoneConditionTest.java       | 4 ++--
 .../ignite/internal/metastorage/server/ValueConditionTest.java    | 4 ++--
 .../metastorage/server/SimpleInMemoryKeyValueStorage.java         | 4 ++--
 .../apache/ignite/internal/metastorage/MetaStorageManager.java    | 4 ++--
 .../apache/ignite/internal/metastorage/watch/AggregatedWatch.java | 4 ++--
 .../apache/ignite/internal/metastorage/watch/KeyCriterion.java    | 4 ++--
 .../apache/ignite/internal/metastorage/watch/WatchAggregator.java | 4 ++--
 .../ignite/internal/metastorage/MetaStorageRangeCursorTest.java   | 4 ++--
 .../apache/ignite/internal/metastorage/WatchAggregatorTest.java   | 4 ++--
 .../internal/metrics/exporters/MetricExportersLoadingTest.java    | 4 ++--
 .../ignite/internal/metrics/exporters/TestMetricsSource.java      | 4 ++--
 .../ignite/internal/metrics/exporters/TestPullMetricExporter.java | 4 ++--
 .../ignite/internal/metrics/exporters/TestPushMetricExporter.java | 4 ++--
 .../java/org/apache/ignite/internal/metrics/AbstractMetric.java   | 4 ++--
 .../org/apache/ignite/internal/metrics/AbstractMetricSource.java  | 4 ++--
 .../org/apache/ignite/internal/metrics/AtomicDoubleMetric.java    | 4 ++--
 .../java/org/apache/ignite/internal/metrics/AtomicIntMetric.java  | 4 ++--
 .../java/org/apache/ignite/internal/metrics/AtomicLongMetric.java | 4 ++--
 .../apache/ignite/internal/metrics/CompositeAwareIterator.java    | 4 ++--
 .../java/org/apache/ignite/internal/metrics/CompositeMetric.java  | 4 ++--
 .../org/apache/ignite/internal/metrics/DistributionMetric.java    | 4 ++--
 .../org/apache/ignite/internal/metrics/DoubleAdderMetric.java     | 4 ++--
 .../main/java/org/apache/ignite/internal/metrics/DoubleGauge.java | 4 ++--
 .../java/org/apache/ignite/internal/metrics/DoubleMetric.java     | 4 ++--
 .../java/org/apache/ignite/internal/metrics/HitRateMetric.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/metrics/IntGauge.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/metrics/IntMetric.java   | 4 ++--
 .../java/org/apache/ignite/internal/metrics/LongAdderMetric.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/metrics/LongGauge.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/metrics/LongMetric.java  | 4 ++--
 .../src/main/java/org/apache/ignite/internal/metrics/Metric.java  | 4 ++--
 .../java/org/apache/ignite/internal/metrics/MetricManager.java    | 4 ++--
 .../java/org/apache/ignite/internal/metrics/MetricProvider.java   | 4 ++--
 .../java/org/apache/ignite/internal/metrics/MetricRegistry.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/metrics/MetricSet.java   | 4 ++--
 .../java/org/apache/ignite/internal/metrics/MetricSetBuilder.java | 4 ++--
 .../java/org/apache/ignite/internal/metrics/MetricSource.java     | 4 ++--
 .../ignite/internal/metrics/exporters/BasicMetricExporter.java    | 4 ++--
 .../apache/ignite/internal/metrics/exporters/MetricExporter.java  | 4 ++--
 .../ignite/internal/metrics/exporters/PushMetricExporter.java     | 4 ++--
 .../apache/ignite/internal/metrics/AbstractDoubleMetricTest.java  | 4 ++--
 .../org/apache/ignite/internal/metrics/AbstractIntMetricTest.java | 4 ++--
 .../apache/ignite/internal/metrics/AbstractLongMetricTest.java    | 4 ++--
 .../apache/ignite/internal/metrics/AbstractScalarMetricsTest.java | 4 ++--
 .../apache/ignite/internal/metrics/AtomicDoubleMetricTest.java    | 4 ++--
 .../org/apache/ignite/internal/metrics/AtomicIntMetricTest.java   | 4 ++--
 .../org/apache/ignite/internal/metrics/AtomicLongMetricTest.java  | 4 ++--
 .../apache/ignite/internal/metrics/DistributionMetricTest.java    | 4 ++--
 .../org/apache/ignite/internal/metrics/DoubleAdderMetricTest.java | 4 ++--
 .../java/org/apache/ignite/internal/metrics/DoubleGaugeTest.java  | 4 ++--
 .../org/apache/ignite/internal/metrics/HitRateMetricTest.java     | 4 ++--
 .../java/org/apache/ignite/internal/metrics/IntGaugeTest.java     | 4 ++--
 .../org/apache/ignite/internal/metrics/LongAdderMetricTest.java   | 4 ++--
 .../org/apache/ignite/internal/metrics/LongGaugeMetricTest.java   | 4 ++--
 .../org/apache/ignite/internal/metrics/MetricEntitiesTest.java    | 4 ++--
 .../apache/ignite/internal/metrics/ThreadPoolMetricSource.java    | 4 ++--
 .../org/apache/ignite/internal/metrics/ThreadPoolMetricTest.java  | 4 ++--
 .../internal/network/processor/IncrementalCompilationConfig.java  | 4 ++--
 .../apache/ignite/internal/network/processor/MessageClass.java    | 4 ++--
 .../ignite/internal/network/processor/MessageGroupWrapper.java    | 4 ++--
 .../ignite/internal/network/processor/ProcessingException.java    | 4 ++--
 .../internal/network/processor/TransferableObjectProcessor.java   | 4 ++--
 .../org/apache/ignite/internal/network/processor/TypeUtils.java   | 4 ++--
 .../network/processor/messages/MessageBuilderGenerator.java       | 4 ++--
 .../network/processor/messages/MessageFactoryGenerator.java       | 4 ++--
 .../internal/network/processor/messages/MessageImplGenerator.java | 4 ++--
 .../network/processor/serialization/BaseMethodNameResolver.java   | 4 ++--
 .../serialization/MessageCollectionItemTypeConverter.java         | 4 ++--
 .../processor/serialization/MessageDeserializerGenerator.java     | 4 ++--
 .../processor/serialization/MessageReaderMethodResolver.java      | 4 ++--
 .../processor/serialization/MessageSerializerGenerator.java       | 4 ++--
 .../processor/serialization/MessageWriterMethodResolver.java      | 4 ++--
 .../processor/serialization/RegistryInitializerGenerator.java     | 4 ++--
 .../processor/serialization/SerializationFactoryGenerator.java    | 4 ++--
 .../java/org/apache/ignite/network/AbstractClusterService.java    | 4 ++--
 .../java/org/apache/ignite/network/AbstractMessagingService.java  | 4 ++--
 .../java/org/apache/ignite/network/AbstractTopologyService.java   | 4 ++--
 .../java/org/apache/ignite/network/ClusterLocalConfiguration.java | 4 ++--
 .../src/main/java/org/apache/ignite/network/ClusterService.java   | 4 ++--
 .../src/main/java/org/apache/ignite/network/MessagingService.java | 4 ++--
 .../org/apache/ignite/network/NetworkConfigurationException.java  | 4 ++--
 .../src/main/java/org/apache/ignite/network/NetworkMessage.java   | 6 +++---
 .../java/org/apache/ignite/network/NetworkMessageHandler.java     | 4 ++--
 .../src/main/java/org/apache/ignite/network/NodeFinder.java       | 4 ++--
 .../java/org/apache/ignite/network/annotations/Marshallable.java  | 4 ++--
 .../java/org/apache/ignite/network/annotations/MessageGroup.java  | 4 ++--
 .../java/org/apache/ignite/network/annotations/Transferable.java  | 4 ++--
 .../java/org/apache/ignite/network/annotations/package-info.java  | 4 ++--
 .../src/main/java/org/apache/ignite/network/package-info.java     | 4 ++--
 .../apache/ignite/network/serialization/MessageDeserializer.java  | 4 ++--
 .../ignite/network/serialization/MessageMappingException.java     | 4 ++--
 .../org/apache/ignite/network/serialization/MessageReader.java    | 4 ++--
 .../ignite/network/serialization/MessageSerializationFactory.java | 4 ++--
 .../network/serialization/MessageSerializationRegistry.java       | 4 ++--
 .../serialization/MessageSerializationRegistryInitializer.java    | 4 ++--
 .../apache/ignite/network/serialization/MessageSerializer.java    | 4 ++--
 .../org/apache/ignite/network/serialization/MessageWriter.java    | 4 ++--
 .../org/apache/ignite/network/serialization/package-info.java     | 4 ++--
 .../java/org/apache/ignite/network/util/ClusterServiceUtils.java  | 2 +-
 .../test/java/org/apache/ignite/network/NetworkAddressTest.java   | 4 ++--
 .../ignite/internal/network/netty/ItConnectionManagerTest.java    | 4 ++--
 .../internal/network/processor/InMemoryJavaFileManager.java       | 4 ++--
 .../processor/ItTransferableObjectProcessorIncrementalTest.java   | 4 ++--
 .../network/processor/ItTransferableObjectProcessorTest.java      | 4 ++--
 .../org/apache/ignite/network/scalecube/ItClusterServiceTest.java | 2 +-
 .../org/apache/ignite/network/scalecube/ItNodeRestartsTest.java   | 4 ++--
 .../ignite/network/scalecube/ItScaleCubeNetworkMessagingTest.java | 4 ++--
 .../java/org/apache/ignite/network/scalecube/package-info.java    | 4 ++--
 .../apache/ignite/internal/network/processor/AllTypesMessage.java | 4 ++--
 .../ignite/internal/network/processor/ConflictingTypeMessage.java | 4 ++--
 .../ignite/internal/network/processor/InheritedMessageClash.java  | 4 ++--
 .../internal/network/processor/InvalidAnnotatedTypeMessage.java   | 4 ++--
 .../internal/network/processor/InvalidParameterGetterMessage.java | 4 ++--
 .../network/processor/InvalidReturnTypeGetterMessage.java         | 4 ++--
 .../ignite/internal/network/processor/ItTestMessageGroup.java     | 4 ++--
 .../org/apache/ignite/internal/network/processor/SecondGroup.java | 4 ++--
 .../ignite/internal/network/processor/TransitiveMessage.java      | 4 ++--
 .../internal/network/processor/UnmarshallableTypeMessage.java     | 4 ++--
 .../processor/UnmarshallableTypeNonSerializableMessage.java       | 4 ++--
 .../org/apache/ignite/internal/network/NetworkMessageTypes.java   | 4 ++--
 .../ignite/internal/network/direct/DirectMarshallingUtils.java    | 4 ++--
 .../ignite/internal/network/direct/DirectMessageReader.java       | 4 ++--
 .../ignite/internal/network/direct/DirectMessageWriter.java       | 4 ++--
 .../ignite/internal/network/direct/state/DirectMessageState.java  | 4 ++--
 .../internal/network/direct/state/DirectMessageStateItem.java     | 4 ++--
 .../internal/network/direct/stream/DirectByteBufferStream.java    | 4 ++--
 .../network/direct/stream/DirectByteBufferStreamImplV1.java       | 4 ++--
 .../apache/ignite/internal/network/handshake/HandshakeAction.java | 4 ++--
 .../ignite/internal/network/handshake/HandshakeException.java     | 4 ++--
 .../ignite/internal/network/handshake/HandshakeManager.java       | 4 ++--
 .../apache/ignite/internal/network/handshake/HandshakeResult.java | 4 ++--
 .../internal/network/message/ClassDescriptorListMessage.java      | 4 ++--
 .../ignite/internal/network/message/ClassDescriptorMessage.java   | 4 ++--
 .../ignite/internal/network/message/FieldDescriptorMessage.java   | 4 ++--
 .../org/apache/ignite/internal/network/message/InvokeRequest.java | 4 ++--
 .../apache/ignite/internal/network/message/InvokeResponse.java    | 4 ++--
 .../apache/ignite/internal/network/message/ScaleCubeMessage.java  | 4 ++--
 .../apache/ignite/internal/network/netty/ConnectionManager.java   | 4 ++--
 .../internal/network/netty/DefaultRecoveryDescriptorProvider.java | 4 ++--
 .../apache/ignite/internal/network/netty/HandshakeHandler.java    | 4 ++--
 .../org/apache/ignite/internal/network/netty/InNetworkObject.java | 4 ++--
 .../org/apache/ignite/internal/network/netty/InboundDecoder.java  | 4 ++--
 .../ignite/internal/network/netty/InboundRecoveryHandler.java     | 4 ++--
 .../internal/network/netty/IoExceptionSuppressingHandler.java     | 4 ++--
 .../org/apache/ignite/internal/network/netty/MessageHandler.java  | 4 ++--
 .../ignite/internal/network/netty/NamedNioEventLoopGroup.java     | 4 ++--
 .../org/apache/ignite/internal/network/netty/NettyClient.java     | 4 ++--
 .../org/apache/ignite/internal/network/netty/NettySender.java     | 4 ++--
 .../org/apache/ignite/internal/network/netty/NettyServer.java     | 4 ++--
 .../java/org/apache/ignite/internal/network/netty/NettyUtils.java | 4 ++--
 .../org/apache/ignite/internal/network/netty/OutboundEncoder.java | 4 ++--
 .../ignite/internal/network/netty/OutboundRecoveryHandler.java    | 4 ++--
 .../org/apache/ignite/internal/network/netty/PipelineUtils.java   | 4 ++--
 .../internal/network/recovery/RecoveryClientHandshakeManager.java | 4 ++--
 .../ignite/internal/network/recovery/RecoveryDescriptor.java      | 4 ++--
 .../internal/network/recovery/RecoveryDescriptorProvider.java     | 4 ++--
 .../internal/network/recovery/RecoveryServerHandshakeManager.java | 4 ++--
 .../internal/network/recovery/message/AcknowledgementMessage.java | 4 ++--
 .../internal/network/recovery/message/HandshakeFinishMessage.java | 4 ++--
 .../internal/network/recovery/message/HandshakeStartMessage.java  | 4 ++--
 .../network/recovery/message/HandshakeStartResponseMessage.java   | 4 ++--
 .../ignite/internal/network/recovery/message/InternalMessage.java | 4 ++--
 .../internal/network/serialization/BrokenFieldAccessor.java       | 4 ++--
 .../network/serialization/BrokenSerializationMethods.java         | 4 ++--
 .../apache/ignite/internal/network/serialization/BuiltInType.java | 6 ++++--
 .../ignite/internal/network/serialization/BuiltInTypeIds.java     | 4 ++--
 .../ignite/internal/network/serialization/ClassDescriptor.java    | 4 ++--
 .../internal/network/serialization/ClassDescriptorFactory.java    | 4 ++--
 .../internal/network/serialization/ClassDescriptorMerger.java     | 4 ++--
 .../internal/network/serialization/ClassDescriptorRegistry.java   | 4 ++--
 .../internal/network/serialization/ClassIndexedDescriptors.java   | 4 ++--
 .../serialization/ClassNameMapBackedClassIndexedDescriptors.java  | 4 ++--
 .../org/apache/ignite/internal/network/serialization/Classes.java | 4 ++--
 .../network/serialization/CompositeDescriptorRegistry.java        | 4 ++--
 .../ignite/internal/network/serialization/DeclaredType.java       | 4 ++--
 .../ignite/internal/network/serialization/DescriptorRegistry.java | 4 ++--
 .../ignite/internal/network/serialization/FieldAccessor.java      | 4 ++--
 .../ignite/internal/network/serialization/FieldDescriptor.java    | 4 ++--
 .../internal/network/serialization/IdIndexedDescriptors.java      | 4 ++--
 .../network/serialization/MapBackedIdIndexedDescriptors.java      | 4 ++--
 .../apache/ignite/internal/network/serialization/MergedField.java | 4 ++--
 .../apache/ignite/internal/network/serialization/MergedLayer.java | 4 ++--
 .../org/apache/ignite/internal/network/serialization/Null.java    | 4 ++--
 .../network/serialization/PerSessionSerializationService.java     | 4 ++--
 .../apache/ignite/internal/network/serialization/Primitives.java  | 4 ++--
 .../internal/network/serialization/ReflectionException.java       | 4 ++--
 .../ignite/internal/network/serialization/Serialization.java      | 4 ++--
 .../internal/network/serialization/SerializationException.java    | 4 ++--
 .../internal/network/serialization/SerializationResult.java       | 4 ++--
 .../internal/network/serialization/SerializationService.java      | 4 ++--
 .../ignite/internal/network/serialization/SerializationType.java  | 4 ++--
 .../network/serialization/SpecialMethodInvocationException.java   | 4 ++--
 .../network/serialization/SpecialSerializationMethods.java        | 4 ++--
 .../network/serialization/SpecialSerializationMethodsImpl.java    | 4 ++--
 .../internal/network/serialization/UnsafeFieldAccessor.java       | 4 ++--
 .../network/serialization/UserObjectSerializationContext.java     | 4 ++--
 .../network/serialization/UserObjectSerializationException.java   | 4 ++--
 .../network/serialization/marshal/BestEffortInstantiation.java    | 4 ++--
 .../serialization/marshal/BuiltInContainerMarshallers.java        | 4 ++--
 .../network/serialization/marshal/BuiltInMarshalling.java         | 4 ++--
 .../serialization/marshal/BuiltInNonContainerMarshallers.java     | 4 ++--
 .../network/serialization/marshal/DefaultFieldsReaderWriter.java  | 4 ++--
 .../network/serialization/marshal/DefaultNullsBitsetWriter.java   | 4 ++--
 .../serialization/marshal/DefaultSchemaMismatchHandler.java       | 4 ++--
 .../serialization/marshal/DefaultUserObjectMarshaller.java        | 4 ++--
 .../internal/network/serialization/marshal/DescribedObject.java   | 4 ++--
 .../network/serialization/marshal/ExternalizableMarshaller.java   | 4 ++--
 .../internal/network/serialization/marshal/FlaggedObjectIds.java  | 4 ++--
 .../internal/network/serialization/marshal/Instantiation.java     | 4 ++--
 .../network/serialization/marshal/InstantiationException.java     | 4 ++--
 .../internal/network/serialization/marshal/LittleEndianBits.java  | 4 ++--
 .../internal/network/serialization/marshal/LocalDescriptors.java  | 4 ++--
 .../internal/network/serialization/marshal/MarshalException.java  | 4 ++--
 .../internal/network/serialization/marshal/MarshalledObject.java  | 4 ++--
 .../network/serialization/marshal/MarshallingContext.java         | 4 ++--
 .../serialization/marshal/MarshallingNotSupportedException.java   | 4 ++--
 .../network/serialization/marshal/MarshallingValidations.java     | 4 ++--
 .../serialization/marshal/NoArgConstructorInstantiation.java      | 4 ++--
 .../internal/network/serialization/marshal/NullsBitsetReader.java | 4 ++--
 .../internal/network/serialization/marshal/NullsBitsetWriter.java | 4 ++--
 .../internal/network/serialization/marshal/ObjectClass.java       | 4 ++--
 .../network/serialization/marshal/ProtocolMarshalling.java        | 4 ++--
 .../internal/network/serialization/marshal/ProxyMarshaller.java   | 4 ++--
 .../internal/network/serialization/marshal/ReadResolver.java      | 4 ++--
 .../network/serialization/marshal/SchemaMismatchEventSource.java  | 4 ++--
 .../network/serialization/marshal/SchemaMismatchException.java    | 4 ++--
 .../network/serialization/marshal/SchemaMismatchHandler.java      | 4 ++--
 .../network/serialization/marshal/SchemaMismatchHandlers.java     | 4 ++--
 .../network/serialization/marshal/SerializableInstantiation.java  | 4 ++--
 .../network/serialization/marshal/StructuredObjectMarshaller.java | 4 ++--
 .../internal/network/serialization/marshal/TypedValueReader.java  | 4 ++--
 .../internal/network/serialization/marshal/TypedValueWriter.java  | 4 ++--
 .../network/serialization/marshal/UncheckedMarshalException.java  | 4 ++--
 .../serialization/marshal/UncheckedUnmarshalException.java        | 4 ++--
 .../network/serialization/marshal/UnmarshalException.java         | 4 ++--
 .../network/serialization/marshal/UnmarshallingContext.java       | 4 ++--
 .../network/serialization/marshal/UnsafeInstantiation.java        | 4 ++--
 .../network/serialization/marshal/UosIgniteOutputStream.java      | 4 ++--
 .../network/serialization/marshal/UosObjectInputStream.java       | 4 ++--
 .../network/serialization/marshal/UosObjectOutputStream.java      | 4 ++--
 .../network/serialization/marshal/UserObjectMarshaller.java       | 4 ++--
 .../internal/network/serialization/marshal/ValueReader.java       | 4 ++--
 .../internal/network/serialization/marshal/ValueWriter.java       | 4 ++--
 .../internal/network/serialization/marshal/WriteReplacer.java     | 4 ++--
 .../java/org/apache/ignite/network/DefaultMessagingService.java   | 4 ++--
 .../apache/ignite/network/MessageSerializationRegistryImpl.java   | 4 ++--
 .../java/org/apache/ignite/network/NettyBootstrapFactory.java     | 4 ++--
 .../main/java/org/apache/ignite/network/NodeFinderFactory.java    | 4 ++--
 .../src/main/java/org/apache/ignite/network/OutNetworkObject.java | 4 ++--
 .../src/main/java/org/apache/ignite/network/StaticNodeFinder.java | 4 ++--
 .../src/main/java/org/apache/ignite/network/package-info.java     | 4 ++--
 .../ignite/network/scalecube/ScaleCubeClusterServiceFactory.java  | 4 ++--
 .../network/scalecube/ScaleCubeDirectMarshallerTransport.java     | 4 ++--
 .../apache/ignite/network/scalecube/ScaleCubeTopologyService.java | 4 ++--
 .../java/org/apache/ignite/network/scalecube/package-info.java    | 4 ++--
 .../java/org/apache/ignite/internal/network/AllTypesMessage.java  | 4 ++--
 .../apache/ignite/internal/network/AllTypesMessageGenerator.java  | 4 ++--
 .../org/apache/ignite/internal/network/AllTypesMessageTest.java   | 4 ++--
 .../org/apache/ignite/internal/network/NestedMessageMessage.java  | 4 ++--
 .../ignite/internal/network/SerializationMicroBenchmark.java      | 4 ++--
 .../org/apache/ignite/internal/network/UosProfilerTarget.java     | 4 ++--
 .../apache/ignite/internal/network/netty/InboundDecoderTest.java  | 4 ++--
 .../internal/network/netty/IoExceptionSuppressingHandlerTest.java | 4 ++--
 .../org/apache/ignite/internal/network/netty/NettyClientTest.java | 4 ++--
 .../org/apache/ignite/internal/network/netty/NettyServerTest.java | 4 ++--
 .../ignite/internal/network/netty/RecoveryHandshakeTest.java      | 4 ++--
 .../apache/ignite/internal/network/processor/EmptyMessage.java    | 4 ++--
 .../ignite/internal/network/processor/EmptyMessageTest.java       | 4 ++--
 .../ignite/internal/network/processor/InheritedMessage.java       | 4 ++--
 .../ignite/internal/network/processor/InheritedMessageTest.java   | 4 ++--
 .../apache/ignite/internal/network/processor/NetworkMessage1.java | 4 ++--
 .../apache/ignite/internal/network/processor/NetworkMessage2.java | 4 ++--
 .../internal/network/processor/SerializationOrderMessage.java     | 4 ++--
 .../ignite/internal/network/processor/SerializationOrderTest.java | 4 ++--
 .../internal/network/serialization/BuiltInDescriptorsTest.java    | 4 ++--
 .../ignite/internal/network/serialization/BuiltInTypeTest.java    | 4 ++--
 .../network/serialization/ClassDescriptorFactoryTest.java         | 4 ++--
 .../internal/network/serialization/ClassDescriptorMergerTest.java | 4 ++--
 .../ClassNameMapBackedClassIndexedDescriptorsTest.java            | 4 ++--
 .../apache/ignite/internal/network/serialization/ClassesTest.java | 4 ++--
 .../network/serialization/MapBackedIdIndexedDescriptorsTest.java  | 4 ++--
 .../ignite/internal/network/serialization/MarshallableTest.java   | 4 ++--
 .../internal/network/serialization/MessageWithMarshallable.java   | 4 ++--
 .../ignite/internal/network/serialization/PrimitivesTest.java     | 4 ++--
 .../internal/network/serialization/SimpleSerializableObject.java  | 4 ++--
 .../serialization/marshal/BestEffortInstantiationTest.java        | 4 ++--
 .../network/serialization/marshal/BuiltInMarshallingTest.java     | 4 ++--
 .../serialization/marshal/ContextBasedIdIndexedDescriptors.java   | 4 ++--
 .../serialization/marshal/DefaultSchemaMismatchHandlerTest.java   | 4 ++--
 .../marshal/DefaultUserObjectMarshallerCommonTest.java            | 4 ++--
 ...ObjectMarshallerConcreteTypesKnownUpfrontOptimizationTest.java | 4 ++--
 .../DefaultUserObjectMarshallerWithArbitraryObjectsTest.java      | 4 ++--
 .../marshal/DefaultUserObjectMarshallerWithBuiltinsTest.java      | 4 ++--
 .../DefaultUserObjectMarshallerWithExternalizableTest.java        | 4 ++--
 .../marshal/DefaultUserObjectMarshallerWithSchemaChangeTest.java  | 4 ++--
 ...ltUserObjectMarshallerWithSerializableOverrideStreamsTest.java | 4 ++--
 .../marshal/DefaultUserObjectMarshallerWithSerializableTest.java  | 4 ++--
 .../serialization/marshal/EnumWithAnonClassesForMembers.java      | 4 ++--
 .../network/serialization/marshal/FlaggedObjectIdsTest.java       | 4 ++--
 .../ignite/internal/network/serialization/marshal/IntHolder.java  | 4 ++--
 .../network/serialization/marshal/MarshallingContextTest.java     | 4 ++--
 .../serialization/marshal/NoArgConstructorInstantiationTest.java  | 4 ++--
 .../marshal/NonSerializableWithoutNoArgConstructor.java           | 4 ++--
 .../network/serialization/marshal/ProtocolMarshallingTest.java    | 4 ++--
 .../serialization/marshal/SerializableInstantiationTest.java      | 4 ++--
 .../ignite/internal/network/serialization/marshal/SimpleEnum.java | 4 ++--
 .../internal/network/serialization/marshal/TestDescriptors.java   | 4 ++--
 .../ignite/internal/network/serialization/marshal/Throwables.java | 4 ++--
 .../network/serialization/marshal/UnsafeInstantiationTest.java    | 4 ++--
 .../serialization/marshal/WithAccessibleNoArgConstructor.java     | 4 ++--
 .../serialization/marshal/WithPrivateNoArgConstructor.java        | 4 ++--
 .../org/apache/ignite/network/AbstractMessagingServiceTest.java   | 4 ++--
 .../ignite/network/MessageSerializationRegistryImplTest.java      | 4 ++--
 .../src/test/java/org/apache/ignite/network/TestMessage.java      | 4 ++--
 .../ignite/network/TestMessageSerializationRegistryImpl.java      | 4 ++--
 .../src/test/java/org/apache/ignite/network/TestMessageTypes.java | 4 ++--
 .../network/scalecube/TestScaleCubeClusterServiceFactory.java     | 4 ++--
 .../java/org/apache/ignite/utils/ClusterServiceTestUtils.java     | 4 ++--
 .../internal/pagememory/tree/AbstractBplusTreePageMemoryTest.java | 4 ++--
 .../pagememory/tree/AbstractBplusTreeReusePageMemoryTest.java     | 4 ++--
 .../pagememory/tree/ItBplusTreeReplaceRemoveRaceTest.java         | 4 ++--
 .../tree/inmemory/ItBplusTreeFakeReuseVolatilePageMemoryTest.java | 4 ++--
 .../tree/inmemory/ItBplusTreeReuseListVolatilePageMemoryTest.java | 4 ++--
 .../tree/inmemory/ItBplusTreeVolatilePageMemoryTest.java          | 4 ++--
 .../tree/persistence/ItBplusTreePersistentPageMemoryTest.java     | 4 ++--
 .../persistence/ItBplusTreeReuseListPersistentPageMemoryTest.java | 4 ++--
 .../internal/pagememory/CorruptedDataStructureException.java      | 4 ++--
 .../java/org/apache/ignite/internal/pagememory/DataRegion.java    | 4 ++--
 .../java/org/apache/ignite/internal/pagememory/FullPageId.java    | 4 ++--
 .../org/apache/ignite/internal/pagememory/PageIdAllocator.java    | 4 ++--
 .../java/org/apache/ignite/internal/pagememory/PageMemory.java    | 4 ++--
 .../org/apache/ignite/internal/pagememory/PageMemoryIoModule.java | 4 ++--
 .../java/org/apache/ignite/internal/pagememory/PageSupport.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/pagememory/Storable.java | 4 ++--
 .../schema/BasePageMemoryDataRegionConfigurationSchema.java       | 4 ++--
 .../configuration/schema/MemoryAllocatorConfigurationSchema.java  | 4 ++--
 .../schema/PageMemoryCheckpointConfigurationSchema.java           | 4 ++--
 .../schema/PersistentPageMemoryDataRegionConfigurationSchema.java | 4 ++--
 .../schema/UnsafeMemoryAllocatorConfigurationSchema.java          | 4 ++--
 .../schema/VolatilePageMemoryDataRegionConfigurationSchema.java   | 4 ++--
 .../ignite/internal/pagememory/datapage/DataPageReader.java       | 4 ++--
 .../pagememory/datapage/NonFragmentableDataPageReader.java        | 4 ++--
 .../ignite/internal/pagememory/datapage/PageMemoryTraversal.java  | 4 ++--
 .../internal/pagememory/datapage/ReadPageMemoryRowValue.java      | 4 ++--
 .../ignite/internal/pagememory/datastructure/DataStructure.java   | 4 ++--
 .../ignite/internal/pagememory/evict/PageEvictionTracker.java     | 4 ++--
 .../ignite/internal/pagememory/evict/PageEvictionTrackerNoOp.java | 4 ++--
 .../ignite/internal/pagememory/freelist/AbstractFreeList.java     | 4 ++--
 .../internal/pagememory/freelist/CorruptedFreeListException.java  | 4 ++--
 .../org/apache/ignite/internal/pagememory/freelist/FreeList.java  | 4 ++--
 .../org/apache/ignite/internal/pagememory/freelist/PagesList.java | 4 ++--
 .../ignite/internal/pagememory/freelist/io/PagesListMetaIo.java   | 4 ++--
 .../ignite/internal/pagememory/freelist/io/PagesListNodeIo.java   | 4 ++--
 .../ignite/internal/pagememory/inmemory/VolatilePageMemory.java   | 4 ++--
 .../apache/ignite/internal/pagememory/io/AbstractDataPageIo.java  | 4 ++--
 .../org/apache/ignite/internal/pagememory/io/DataPagePayload.java | 4 ++--
 .../java/org/apache/ignite/internal/pagememory/io/IoVersions.java | 4 ++--
 .../java/org/apache/ignite/internal/pagememory/io/PageIo.java     | 4 ++--
 .../org/apache/ignite/internal/pagememory/io/PageIoModule.java    | 4 ++--
 .../org/apache/ignite/internal/pagememory/io/PageIoRegistry.java  | 4 ++--
 .../ignite/internal/pagememory/mem/DirectMemoryProvider.java      | 4 ++--
 .../apache/ignite/internal/pagememory/mem/DirectMemoryRegion.java | 4 ++--
 .../internal/pagememory/mem/IgniteOutOfMemoryException.java       | 4 ++--
 .../apache/ignite/internal/pagememory/mem/MemoryAllocator.java    | 4 ++--
 .../apache/ignite/internal/pagememory/mem/unsafe/UnsafeChunk.java | 4 ++--
 .../internal/pagememory/mem/unsafe/UnsafeMemoryAllocator.java     | 4 ++--
 .../internal/pagememory/mem/unsafe/UnsafeMemoryProvider.java      | 4 ++--
 .../ignite/internal/pagememory/metric/IoStatisticsHolder.java     | 5 ++---
 .../ignite/internal/pagememory/metric/IoStatisticsHolderNoOp.java | 4 ++--
 .../apache/ignite/internal/pagememory/persistence/FastCrc.java    | 4 ++--
 .../ignite/internal/pagememory/persistence/GroupPartitionId.java  | 4 ++--
 .../IgniteInternalDataIntegrityViolationException.java            | 4 ++--
 .../ignite/internal/pagememory/persistence/LoadedPagesMap.java    | 4 ++--
 .../apache/ignite/internal/pagememory/persistence/PageHeader.java | 4 ++--
 .../apache/ignite/internal/pagememory/persistence/PagePool.java   | 4 ++--
 .../internal/pagememory/persistence/PageReadWriteManager.java     | 4 ++--
 .../ignite/internal/pagememory/persistence/PageStoreWriter.java   | 4 ++--
 .../ignite/internal/pagememory/persistence/PartitionMeta.java     | 4 ++--
 .../internal/pagememory/persistence/PartitionMetaManager.java     | 4 ++--
 .../internal/pagememory/persistence/PersistentPageMemory.java     | 4 ++--
 .../ignite/internal/pagememory/persistence/ReplaceCandidate.java  | 4 ++--
 .../pagememory/persistence/RobinHoodBackwardShiftHashMap.java     | 4 ++--
 .../ignite/internal/pagememory/persistence/WriteDirtyPage.java    | 4 ++--
 .../persistence/checkpoint/AwaitTasksCompletionExecutor.java      | 4 ++--
 .../internal/pagememory/persistence/checkpoint/Checkpoint.java    | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointDirtyPages.java   | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointListener.java     | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointManager.java      | 4 ++--
 .../persistence/checkpoint/CheckpointMetricsTracker.java          | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointPages.java        | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointPagesWriter.java  | 4 ++--
 .../persistence/checkpoint/CheckpointPagesWriterFactory.java      | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointProgress.java     | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointProgressImpl.java | 4 ++--
 .../checkpoint/CheckpointReadLockTimeoutException.java            | 4 ++--
 .../persistence/checkpoint/CheckpointReadWriteLock.java           | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointState.java        | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointTimeoutLock.java  | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointWorkflow.java     | 4 ++--
 .../internal/pagememory/persistence/checkpoint/Checkpointer.java  | 4 ++--
 .../pagememory/persistence/checkpoint/DataRegionDirtyPages.java   | 4 ++--
 .../pagememory/persistence/checkpoint/DataRegionsDirtyPages.java  | 4 ++--
 .../checkpoint/ReentrantReadWriteLockWithTracking.java            | 4 ++--
 .../internal/pagememory/persistence/compaction/Compactor.java     | 4 ++--
 .../internal/pagememory/persistence/io/PartitionMetaIo.java       | 4 ++--
 .../persistence/replacement/ClockPageReplacementFlags.java        | 4 ++--
 .../persistence/replacement/ClockPageReplacementPolicy.java       | 4 ++--
 .../replacement/ClockPageReplacementPolicyFactory.java            | 4 ++--
 .../pagememory/persistence/replacement/DelayedDirtyPageWrite.java | 4 ++--
 .../persistence/replacement/DelayedPageReplacementTracker.java    | 4 ++--
 .../pagememory/persistence/replacement/PageReplacementPolicy.java | 4 ++--
 .../persistence/replacement/PageReplacementPolicyFactory.java     | 4 ++--
 .../persistence/replacement/RandomLruPageReplacementPolicy.java   | 4 ++--
 .../replacement/RandomLruPageReplacementPolicyFactory.java        | 4 ++--
 .../pagememory/persistence/replacement/SegmentedLruPageList.java  | 4 ++--
 .../replacement/SegmentedLruPageReplacementPolicy.java            | 4 ++--
 .../replacement/SegmentedLruPageReplacementPolicyFactory.java     | 4 ++--
 .../pagememory/persistence/store/AbstractFilePageStoreIo.java     | 4 ++--
 .../pagememory/persistence/store/DeltaFilePageStoreIo.java        | 4 ++--
 .../pagememory/persistence/store/DeltaFilePageStoreIoHeader.java  | 4 ++--
 .../internal/pagememory/persistence/store/FilePageStore.java      | 4 ++--
 .../pagememory/persistence/store/FilePageStoreFactory.java        | 4 ++--
 .../pagememory/persistence/store/FilePageStoreHeader.java         | 4 ++--
 .../internal/pagememory/persistence/store/FilePageStoreIo.java    | 4 ++--
 .../pagememory/persistence/store/FilePageStoreManager.java        | 4 ++--
 .../internal/pagememory/persistence/store/GroupPageStoresMap.java | 4 ++--
 .../pagememory/persistence/store/LongOperationAsyncExecutor.java  | 4 ++--
 .../pagememory/persistence/store/PageAllocationListener.java      | 4 ++--
 .../ignite/internal/pagememory/persistence/store/PageStore.java   | 4 ++--
 .../internal/pagememory/persistence/store/PageStoreUtils.java     | 4 ++--
 .../apache/ignite/internal/pagememory/reuse/LongListReuseBag.java | 4 ++--
 .../org/apache/ignite/internal/pagememory/reuse/ReuseBag.java     | 4 ++--
 .../org/apache/ignite/internal/pagememory/reuse/ReuseList.java    | 4 ++--
 .../apache/ignite/internal/pagememory/reuse/ReuseListImpl.java    | 4 ++--
 .../org/apache/ignite/internal/pagememory/tree/BplusTree.java     | 4 ++--
 .../internal/pagememory/tree/BplusTreeRuntimeException.java       | 4 ++--
 .../ignite/internal/pagememory/tree/CorruptedTreeException.java   | 4 ++--
 .../org/apache/ignite/internal/pagememory/tree/IgniteTree.java    | 4 ++--
 .../apache/ignite/internal/pagememory/tree/IgniteTreePrinter.java | 4 ++--
 .../apache/ignite/internal/pagememory/tree/io/BplusInnerIo.java   | 4 ++--
 .../org/apache/ignite/internal/pagememory/tree/io/BplusIo.java    | 4 ++--
 .../apache/ignite/internal/pagememory/tree/io/BplusLeafIo.java    | 4 ++--
 .../apache/ignite/internal/pagememory/tree/io/BplusMetaIo.java    | 4 ++--
 .../org/apache/ignite/internal/pagememory/util/PageHandler.java   | 4 ++--
 .../org/apache/ignite/internal/pagememory/util/PageIdUtils.java   | 4 ++--
 .../apache/ignite/internal/pagememory/util/PageLockListener.java  | 4 ++--
 .../ignite/internal/pagememory/util/PageLockListenerNoOp.java     | 4 ++--
 .../org/apache/ignite/internal/pagememory/util/PageUtils.java     | 4 ++--
 .../ignite/internal/pagememory/util/PartitionlessLinks.java       | 4 ++--
 .../internal/pagememory/AbstractPageMemoryNoLoadSelfTest.java     | 4 ++--
 .../org/apache/ignite/internal/pagememory/PageIoRegistryTest.java | 4 ++--
 .../org/apache/ignite/internal/pagememory/TestPageIoModule.java   | 4 ++--
 .../org/apache/ignite/internal/pagememory/TestPageIoRegistry.java | 4 ++--
 .../ignite/internal/pagememory/freelist/AbstractFreeListTest.java | 4 ++--
 .../ignite/internal/pagememory/freelist/TestDataPageIo.java       | 4 ++--
 .../apache/ignite/internal/pagememory/freelist/TestDataRow.java   | 4 ++--
 .../pagememory/inmemory/VolatilePageMemoryNoLoadSelfTest.java     | 4 ++--
 .../ignite/internal/pagememory/persistence/FastCrcTest.java       | 4 ++--
 .../internal/pagememory/persistence/PartitionMetaManagerTest.java | 4 ++--
 .../ignite/internal/pagememory/persistence/PartitionMetaTest.java | 4 ++--
 .../pagememory/persistence/PersistentPageMemoryNoLoadTest.java    | 4 ++--
 .../internal/pagememory/persistence/TestPageReadWriteManager.java | 4 ++--
 .../persistence/checkpoint/AwaitTasksCompletionExecutorTest.java  | 4 ++--
 .../persistence/checkpoint/CheckpointDirtyPagesTest.java          | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointManagerTest.java  | 4 ++--
 .../persistence/checkpoint/CheckpointMetricsTrackerTest.java      | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointPagesTest.java    | 4 ++--
 .../persistence/checkpoint/CheckpointPagesWriterTest.java         | 4 ++--
 .../persistence/checkpoint/CheckpointProgressImplTest.java        | 4 ++--
 .../persistence/checkpoint/CheckpointReadWriteLockTest.java       | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointTest.java         | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointTestUtils.java    | 4 ++--
 .../persistence/checkpoint/CheckpointTimeoutLockTest.java         | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointWorkflowTest.java | 4 ++--
 .../pagememory/persistence/checkpoint/CheckpointerTest.java       | 4 ++--
 .../checkpoint/ReentrantReadWriteLockWithTrackingTest.java        | 4 ++--
 .../internal/pagememory/persistence/compaction/CompactorTest.java | 4 ++--
 .../pagememory/persistence/store/AbstractFilePageStoreIoTest.java | 4 ++--
 .../persistence/store/DeltaFilePageStoreIoHeaderTest.java         | 4 ++--
 .../pagememory/persistence/store/DeltaFilePageStoreIoTest.java    | 4 ++--
 .../pagememory/persistence/store/FilePageStoreFactoryTest.java    | 4 ++--
 .../pagememory/persistence/store/FilePageStoreHeaderTest.java     | 4 ++--
 .../pagememory/persistence/store/FilePageStoreIoTest.java         | 4 ++--
 .../pagememory/persistence/store/FilePageStoreManagerTest.java    | 4 ++--
 .../internal/pagememory/persistence/store/FilePageStoreTest.java  | 4 ++--
 .../pagememory/persistence/store/GroupPageStoresMapTest.java      | 4 ++--
 .../persistence/store/LongOperationAsyncExecutorTest.java         | 4 ++--
 .../internal/pagememory/persistence/store/PageStoreUtilsTest.java | 4 ++--
 .../internal/pagememory/persistence/store/TestPageStoreUtils.java | 4 ++--
 .../apache/ignite/internal/pagememory/util/PageIdUtilsTest.java   | 4 ++--
 .../org/apache/ignite/internal/pagememory/util/PageUtilsTest.java | 4 ++--
 modules/platforms/cpp/common/Types.h                              | 4 ++--
 modules/platforms/cpp/schema/BinaryTupleBuilder.cpp               | 4 ++--
 modules/platforms/cpp/schema/BinaryTupleBuilder.h                 | 4 ++--
 modules/platforms/cpp/schema/BinaryTupleHeader.h                  | 4 ++--
 modules/platforms/cpp/schema/BinaryTupleParser.cpp                | 4 ++--
 modules/platforms/cpp/schema/BinaryTupleParser.h                  | 4 ++--
 modules/platforms/cpp/schema/BinaryTupleSchema.h                  | 4 ++--
 modules/platforms/cpp/schema/ColumnInfo.h                         | 4 ++--
 modules/platforms/cpp/schema/DataType.cpp                         | 4 ++--
 modules/platforms/cpp/schema/DataType.h                           | 4 ++--
 .../src/main/java/org/apache/ignite/raft/client/Command.java      | 6 +++---
 .../main/java/org/apache/ignite/raft/client/ElectionPriority.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/client/Peer.java         | 6 +++---
 .../src/main/java/org/apache/ignite/raft/client/ReadCommand.java  | 6 +++---
 .../src/main/java/org/apache/ignite/raft/client/WriteCommand.java | 6 +++---
 .../org/apache/ignite/raft/client/service/CommandClosure.java     | 6 +++---
 .../org/apache/ignite/raft/client/service/RaftGroupListener.java  | 4 ++--
 .../org/apache/ignite/raft/client/service/RaftGroupService.java   | 4 ++--
 .../java/org/apache/ignite/internal/raft/ItLozaTest.java          | 4 ++--
 .../org/apache/ignite/internal/raft/ItRaftGroupServiceTest.java   | 2 +-
 .../raft/client/service/ItAbstractListenerSnapshotTest.java       | 4 ++--
 .../java/org/apache/ignite/raft/jraft/core/ItCliServiceTest.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/ItNodeTest.java        | 6 +++---
 .../java/org/apache/ignite/raft/server/CounterListener.java       | 6 +++---
 .../java/org/apache/ignite/raft/server/CounterSnapshotFile.java   | 6 +++---
 .../java/org/apache/ignite/raft/server/GetValueCommand.java       | 6 +++---
 .../org/apache/ignite/raft/server/IncrementAndGetCommand.java     | 6 +++---
 .../org/apache/ignite/raft/server/ItJraftCounterServerTest.java   | 4 ++--
 .../org/apache/ignite/raft/server/ItSimpleCounterServerTest.java  | 4 ++--
 .../org/apache/ignite/raft/server/RaftServerAbstractTest.java     | 4 ++--
 .../apache/ignite/internal/raft/CoreLogStorageBudgetsModule.java  | 4 ++--
 .../raft/src/main/java/org/apache/ignite/internal/raft/Loza.java  | 4 ++--
 .../ignite/internal/raft/server/RaftGroupEventsListener.java      | 6 +++---
 .../org/apache/ignite/internal/raft/server/RaftGroupOptions.java  | 6 +++---
 .../java/org/apache/ignite/internal/raft/server/RaftServer.java   | 6 +++---
 .../apache/ignite/internal/raft/server/impl/JraftServerImpl.java  | 6 +++---
 .../apache/ignite/internal/raft/storage/LogStorageFactory.java    | 2 +-
 .../ignite/internal/raft/storage/RaftMetaStorageFactory.java      | 2 +-
 .../ignite/internal/raft/storage/SnapshotStorageFactory.java      | 2 +-
 .../internal/raft/storage/impl/DefaultLogStorageFactory.java      | 2 +-
 .../internal/raft/storage/impl/IgniteJraftServiceFactory.java     | 2 +-
 .../ignite/internal/raft/storage/impl/LocalLogStorageFactory.java | 6 +++---
 .../internal/raft/storage/impl/LogStorageFactoryCreator.java      | 6 +++---
 .../internal/raft/storage/impl/RocksDbSharedLogStorage.java       | 2 +-
 .../internal/raft/storage/impl/VolatileLogStorageFactory.java     | 2 +-
 .../raft/storage/impl/VolatileLogStorageFactoryCreator.java       | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/CliService.java    | 6 +++---
 .../raft/src/main/java/org/apache/ignite/raft/jraft/Closure.java  | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/FSMCaller.java     | 6 +++---
 .../raft/src/main/java/org/apache/ignite/raft/jraft/Iterator.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/JRaftServiceFactory.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/JRaftUtils.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/Lifecycle.java     | 6 +++---
 modules/raft/src/main/java/org/apache/ignite/raft/jraft/Node.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/NodeManager.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/RaftGroupService.java  | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/RaftMessageGroup.java  | 4 ++--
 .../main/java/org/apache/ignite/raft/jraft/ReadOnlyService.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/ReplicatorGroup.java   | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/StateMachine.java  | 6 +++---
 .../raft/src/main/java/org/apache/ignite/raft/jraft/Status.java   | 6 +++---
 .../apache/ignite/raft/jraft/ThreadPoolMetricsSignalHandler.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/closure/CatchUpClosure.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/closure/ClosureQueue.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/ClosureQueueImpl.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/JoinableClosure.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/LoadSnapshotClosure.java | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/ReadIndexClosure.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/SaveSnapshotClosure.java | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/SynchronizedClosure.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/closure/TaskClosure.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/conf/Configuration.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/conf/ConfigurationEntry.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/conf/ConfigurationManager.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/core/BallotBox.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/CliServiceImpl.java    | 6 +++---
 .../apache/ignite/raft/jraft/core/DefaultJRaftServiceFactory.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/ElectionPriority.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/FSMCallerImpl.java     | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/core/IteratorImpl.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/IteratorWrapper.java   | 6 +++---
 .../apache/ignite/raft/jraft/core/LogStorageBudgetFactory.java    | 4 ++--
 .../apache/ignite/raft/jraft/core/LogStorageBudgetsModule.java    | 4 ++--
 .../src/main/java/org/apache/ignite/raft/jraft/core/NodeImpl.java | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/core/NodeMetrics.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/core/ReadOnlyServiceImpl.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/core/Replicator.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/core/ReplicatorGroupImpl.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/ReplicatorType.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/core/Scheduler.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/core/State.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/core/StateMachineAdapter.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/core/TimerManager.java | 6 +++---
 .../org/apache/ignite/raft/jraft/disruptor/DisruptorBuilder.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/disruptor/GroupAware.java   | 4 ++--
 .../org/apache/ignite/raft/jraft/disruptor/StripedDisruptor.java  | 4 ++--
 .../src/main/java/org/apache/ignite/raft/jraft/entity/Ballot.java | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/entity/Checksum.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/entity/EnumOutter.java | 6 +++---
 .../org/apache/ignite/raft/jraft/entity/LeaderChangeContext.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/entity/LocalFileMetaOutter.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/entity/LocalStorageOutter.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/entity/LogEntry.java   | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/entity/LogId.java  | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/entity/NodeId.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/entity/PeerId.java | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/entity/RaftOutter.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/entity/ReadIndexState.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/entity/ReadIndexStatus.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/entity/Task.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/entity/UserLog.java    | 6 +++---
 .../apache/ignite/raft/jraft/entity/codec/AutoDetectDecoder.java  | 6 +++---
 .../raft/jraft/entity/codec/DefaultLogEntryCodecFactory.java      | 6 +++---
 .../ignite/raft/jraft/entity/codec/LogEntryCodecFactory.java      | 6 +++---
 .../apache/ignite/raft/jraft/entity/codec/LogEntryDecoder.java    | 6 +++---
 .../apache/ignite/raft/jraft/entity/codec/LogEntryEncoder.java    | 6 +++---
 .../ignite/raft/jraft/entity/codec/v1/LogEntryV1CodecFactory.java | 6 +++---
 .../org/apache/ignite/raft/jraft/entity/codec/v1/V1Decoder.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/entity/codec/v1/V1Encoder.java   | 6 +++---
 .../apache/ignite/raft/jraft/error/InvokeTimeoutException.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/error/JRaftException.java   | 6 +++---
 .../ignite/raft/jraft/error/LogEntryCorruptedException.java       | 6 +++---
 .../ignite/raft/jraft/error/LogIndexOutOfBoundsException.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/error/LogNotFoundException.java  | 6 +++---
 .../ignite/raft/jraft/error/MessageClassNotFoundException.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/error/RaftError.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/error/RaftException.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/error/RemotingException.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/error/RetryAgainException.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/option/BallotBoxOptions.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/option/BootstrapOptions.java     | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/option/CliOptions.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/option/CopyOptions.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/option/FSMCallerOptions.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/option/LogManagerOptions.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/option/LogStorageOptions.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/option/NodeOptions.java     | 6 +++---
 .../apache/ignite/raft/jraft/option/RaftMetaStorageOptions.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/option/RaftOptions.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/option/ReadOnlyOption.java  | 6 +++---
 .../apache/ignite/raft/jraft/option/ReadOnlyServiceOptions.java   | 6 +++---
 .../apache/ignite/raft/jraft/option/ReplicatorGroupOptions.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/option/ReplicatorOptions.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/option/RpcOptions.java | 6 +++---
 .../apache/ignite/raft/jraft/option/SnapshotCopierOptions.java    | 6 +++---
 .../apache/ignite/raft/jraft/option/SnapshotExecutorOptions.java  | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/ActionRequest.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/ActionResponse.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/CliClientService.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/CliRequests.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/ClientService.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/InvokeCallback.java     | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/InvokeContext.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/rpc/Message.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/RaftClientService.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/RaftRpcFactory.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/RaftServerService.java  | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/rpc/RpcClient.java | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/RpcClientEx.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/RpcContext.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/RpcProcessor.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/RpcRequestClosure.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/RpcRequestProcessor.java     | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/rpc/RpcRequests.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/RpcResponseClosure.java | 6 +++---
 .../apache/ignite/raft/jraft/rpc/RpcResponseClosureAdapter.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/RpcResponseFactory.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/rpc/RpcServer.java | 6 +++---
 .../apache/ignite/raft/jraft/rpc/impl/AbstractClientService.java  | 6 +++---
 .../apache/ignite/raft/jraft/rpc/impl/ActionRequestProcessor.java | 6 +++---
 .../ignite/raft/jraft/rpc/impl/ConnectionClosedEventListener.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/impl/FutureImpl.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/impl/IgniteRpcClient.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/impl/IgniteRpcServer.java    | 6 +++---
 .../apache/ignite/raft/jraft/rpc/impl/PingRequestProcessor.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/impl/RaftException.java | 6 +++---
 .../apache/ignite/raft/jraft/rpc/impl/RaftGroupServiceImpl.java   | 4 ++--
 .../apache/ignite/raft/jraft/rpc/impl/SMCompactedThrowable.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/impl/SMFullThrowable.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/impl/SMThrowable.java   | 6 +++---
 .../raft/jraft/rpc/impl/cli/AddLearnersRequestProcessor.java      | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/AddPeerRequestProcessor.java   | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/BaseCliRequestProcessor.java   | 6 +++---
 .../raft/jraft/rpc/impl/cli/ChangePeersAsyncRequestProcessor.java | 6 +++---
 .../raft/jraft/rpc/impl/cli/ChangePeersRequestProcessor.java      | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/CliClientServiceImpl.java      | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/GetLeaderRequestProcessor.java | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/GetPeersRequestProcessor.java  | 6 +++---
 .../raft/jraft/rpc/impl/cli/IgniteCliRpcRequestClosure.java       | 4 ++--
 .../raft/jraft/rpc/impl/cli/RemoveLearnersRequestProcessor.java   | 6 +++---
 .../raft/jraft/rpc/impl/cli/RemovePeerRequestProcessor.java       | 6 +++---
 .../raft/jraft/rpc/impl/cli/ResetLearnersRequestProcessor.java    | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/ResetPeerRequestProcessor.java | 6 +++---
 .../ignite/raft/jraft/rpc/impl/cli/SnapshotRequestProcessor.java  | 6 +++---
 .../raft/jraft/rpc/impl/cli/TransferLeaderRequestProcessor.java   | 6 +++---
 .../raft/jraft/rpc/impl/core/AppendEntriesRequestProcessor.java   | 6 +++---
 .../ignite/raft/jraft/rpc/impl/core/DefaultRaftClientService.java | 6 +++---
 .../ignite/raft/jraft/rpc/impl/core/GetFileRequestProcessor.java  | 6 +++---
 .../raft/jraft/rpc/impl/core/InstallSnapshotRequestProcessor.java | 6 +++---
 .../ignite/raft/jraft/rpc/impl/core/NodeRequestProcessor.java     | 6 +++---
 .../raft/jraft/rpc/impl/core/ReadIndexRequestProcessor.java       | 6 +++---
 .../raft/jraft/rpc/impl/core/RequestVoteRequestProcessor.java     | 6 +++---
 .../raft/jraft/rpc/impl/core/TimeoutNowRequestProcessor.java      | 6 +++---
 .../java/org/apache/ignite/raft/jraft/storage/FileService.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/storage/LogManager.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/storage/LogStorage.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/RaftMetaStorage.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/SnapshotExecutor.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/SnapshotStorage.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/SnapshotThrottle.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/storage/Storage.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/VolatileStorage.java     | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/EntryCountBudget.java   | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/LocalLogStorage.java    | 6 +++---
 .../ignite/raft/jraft/storage/impl/LocalRaftMetaStorage.java      | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/impl/LogManagerImpl.java | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/LogStorageBudget.java   | 6 +++---
 .../ignite/raft/jraft/storage/impl/LogStorageException.java       | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/storage/impl/Logs.java | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/impl/OnHeapLogs.java     | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/RocksDBLogStorage.java  | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/RocksDbSpillout.java    | 2 +-
 .../apache/ignite/raft/jraft/storage/impl/UnlimitedBudget.java    | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/VolatileLogStorage.java | 6 +++---
 .../ignite/raft/jraft/storage/impl/VolatileRaftMetaStorage.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/storage/io/FileReader.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/io/LocalDirReader.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/storage/io/MessageFile.java | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/snapshot/Snapshot.java   | 6 +++---
 .../apache/ignite/raft/jraft/storage/snapshot/SnapshotCopier.java | 6 +++---
 .../ignite/raft/jraft/storage/snapshot/SnapshotExecutorImpl.java  | 6 +++---
 .../apache/ignite/raft/jraft/storage/snapshot/SnapshotReader.java | 6 +++---
 .../apache/ignite/raft/jraft/storage/snapshot/SnapshotWriter.java | 6 +++---
 .../raft/jraft/storage/snapshot/ThroughputSnapshotThrottle.java   | 6 +++---
 .../ignite/raft/jraft/storage/snapshot/local/LocalSnapshot.java   | 6 +++---
 .../raft/jraft/storage/snapshot/local/LocalSnapshotCopier.java    | 6 +++---
 .../raft/jraft/storage/snapshot/local/LocalSnapshotMetaTable.java | 6 +++---
 .../raft/jraft/storage/snapshot/local/LocalSnapshotReader.java    | 6 +++---
 .../raft/jraft/storage/snapshot/local/LocalSnapshotStorage.java   | 6 +++---
 .../raft/jraft/storage/snapshot/local/LocalSnapshotWriter.java    | 6 +++---
 .../raft/jraft/storage/snapshot/local/SnapshotFileReader.java     | 6 +++---
 .../ignite/raft/jraft/storage/snapshot/remote/CopySession.java    | 6 +++---
 .../raft/jraft/storage/snapshot/remote/RemoteFileCopier.java      | 6 +++---
 .../apache/ignite/raft/jraft/storage/snapshot/remote/Session.java | 6 +++---
 .../org/apache/ignite/raft/jraft/util/AdaptiveBufAllocator.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/ArrayDeque.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/AsciiStringUtil.java   | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Bits.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/util/ByteBufferCollector.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/ByteString.java   | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Bytes.java    | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/BytesUtil.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/CRC64.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Copiable.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/CountDownEvent.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/CrcUtil.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/DebugStatistics.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/Describer.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/DirectExecutor.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/util/DisruptorMetricSet.java     | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Endpoint.java | 6 +++---
 .../org/apache/ignite/raft/jraft/util/ExecutorServiceHelper.java  | 6 +++---
 .../ignite/raft/jraft/util/ExponentialBackoffTimeoutStrategy.java | 4 ++--
 .../apache/ignite/raft/jraft/util/FileOutputSignalHandler.java    | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Ints.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/JDKMarshaller.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/util/JRaftSignalHandler.java     | 6 +++---
 .../ignite/raft/jraft/util/LogScheduledThreadPoolExecutor.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/util/LogThreadPoolExecutor.java  | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/Marshaller.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/MetricReporter.java    | 6 +++---
 .../ignite/raft/jraft/util/MetricScheduledThreadPoolExecutor.java | 6 +++---
 .../apache/ignite/raft/jraft/util/MetricThreadPoolExecutor.java   | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Mpsc.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/NonReentrantLock.java  | 2 +-
 .../org/apache/ignite/raft/jraft/util/NoopTimeoutStrategy.java    | 4 ++--
 .../main/java/org/apache/ignite/raft/jraft/util/OnlyForTest.java  | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Platform.java | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/Recyclable.java   | 6 +++---
 .../apache/ignite/raft/jraft/util/RecyclableByteBufferList.java   | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/RecycleUtil.java  | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/Recyclers.java    | 2 +-
 .../java/org/apache/ignite/raft/jraft/util/RepeatedTimer.java     | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/Requires.java | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/SegmentList.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/util/StorageOptionsFactory.java  | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/StringUtils.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/util/SystemPropertyUtil.java     | 6 +++---
 .../main/java/org/apache/ignite/raft/jraft/util/ThreadHelper.java | 6 +++---
 .../src/main/java/org/apache/ignite/raft/jraft/util/ThreadId.java | 6 +++---
 .../apache/ignite/raft/jraft/util/ThreadPoolMetricRegistry.java   | 6 +++---
 .../org/apache/ignite/raft/jraft/util/ThreadPoolMetricSet.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/ThreadPoolUtil.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/TimeoutStrategy.java   | 4 ++--
 .../src/main/java/org/apache/ignite/raft/jraft/util/Utils.java    | 6 +++---
 .../ignite/raft/jraft/util/concurrent/AdjustableSemaphore.java    | 6 +++---
 .../ignite/raft/jraft/util/concurrent/ConcurrentHashSet.java      | 6 +++---
 .../raft/jraft/util/concurrent/DefaultExecutorChooserFactory.java | 6 +++---
 .../jraft/util/concurrent/DefaultFixedThreadsExecutorGroup.java   | 6 +++---
 .../util/concurrent/DefaultFixedThreadsExecutorGroupFactory.java  | 6 +++---
 .../raft/jraft/util/concurrent/DefaultSingleThreadExecutor.java   | 6 +++---
 .../ignite/raft/jraft/util/concurrent/ExecutorChooserFactory.java | 6 +++---
 .../raft/jraft/util/concurrent/FixedThreadsExecutorGroup.java     | 6 +++---
 .../jraft/util/concurrent/FixedThreadsExecutorGroupFactory.java   | 6 +++---
 .../jraft/util/concurrent/LongHeldDetectingReadWriteLock.java     | 6 +++---
 .../raft/jraft/util/concurrent/MpscSingleThreadExecutor.java      | 6 +++---
 .../raft/jraft/util/concurrent/RejectedExecutionHandler.java      | 6 +++---
 .../raft/jraft/util/concurrent/RejectedExecutionHandlers.java     | 6 +++---
 .../ignite/raft/jraft/util/concurrent/SingleThreadExecutor.java   | 6 +++---
 .../ignite/raft/jraft/util/internal/IntegerFieldUpdater.java      | 6 +++---
 .../apache/ignite/raft/jraft/util/internal/LongFieldUpdater.java  | 6 +++---
 .../ignite/raft/jraft/util/internal/ReferenceFieldUpdater.java    | 6 +++---
 .../raft/jraft/util/internal/ReflectionIntegerFieldUpdater.java   | 6 +++---
 .../raft/jraft/util/internal/ReflectionLongFieldUpdater.java      | 6 +++---
 .../raft/jraft/util/internal/ReflectionReferenceFieldUpdater.java | 6 +++---
 .../org/apache/ignite/raft/jraft/util/internal/ThrowUtil.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/util/internal/UnsafeUtil.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/internal/Updaters.java | 6 +++---
 .../ignite/raft/jraft/util/timer/DefaultRaftTimerFactory.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/util/timer/DefaultTimer.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/util/timer/HashedWheelTimer.java | 6 +++---
 .../org/apache/ignite/raft/jraft/util/timer/RaftTimerFactory.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/timer/Timeout.java     | 2 +-
 .../main/java/org/apache/ignite/raft/jraft/util/timer/Timer.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/timer/TimerTask.java   | 2 +-
 .../java/org/apache/ignite/disruptor/StripedDisruptorTest.java    | 6 +++---
 .../ignite/internal/raft/CoreLogStorageBudgetsModuleTest.java     | 4 ++--
 .../src/test/java/org/apache/ignite/internal/raft/LozaTest.java   | 6 +++---
 .../apache/ignite/internal/raft/server/impl/RaftServerImpl.java   | 6 +++---
 .../raft/storage/impl/RocksDbSharedLogStorageAdvancedTest.java    | 2 +-
 .../internal/raft/storage/impl/RocksDbSharedLogStorageTest.java   | 2 +-
 .../raft/storage/impl/SharedVsNonSharedLogStorageBenchmark.java   | 2 +-
 .../src/test/java/org/apache/ignite/raft/jraft/StatusTest.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/closure/ClosureQueueTest.java    | 6 +++---
 .../apache/ignite/raft/jraft/closure/SynchronizedClosureTest.java | 6 +++---
 .../org/apache/ignite/raft/jraft/conf/ConfigurationEntryTest.java | 6 +++---
 .../apache/ignite/raft/jraft/conf/ConfigurationManagerTest.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/conf/ConfigurationTest.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/BallotBoxTest.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/ExpectClosure.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/FSMCallerTest.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/IteratorImplTest.java  | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/core/IteratorTest.java | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/core/MockClosure.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/MockStateMachine.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/core/RaftGroupServiceTest.java   | 4 ++--
 .../org/apache/ignite/raft/jraft/core/ReadOnlyServiceTest.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/core/ReplicatorGroupTest.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/core/ReplicatorTest.java    | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/core/TestCluster.java  | 6 +++---
 .../apache/ignite/raft/jraft/core/TestJRaftServiceFactory.java    | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/entity/BallotTest.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/entity/LogEntryTest.java    | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/entity/LogIdTest.java  | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/entity/PeerIdTest.java | 6 +++---
 .../raft/jraft/entity/codec/BaseLogEntryCodecFactoryTest.java     | 6 +++---
 .../ignite/raft/jraft/entity/codec/LogEntryCodecPerfTest.java     | 6 +++---
 .../raft/jraft/entity/codec/v1/LogEntryV1CodecFactoryTest.java    | 6 +++---
 .../apache/ignite/raft/jraft/rpc/AbstractClientServiceTest.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/AbstractRpcTest.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/AppendEntriesBenchmark.java  | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/rpc/IgniteRpcTest.java | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/RpcResponseFactoryTest.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/rpc/TestIgniteRpcServer.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/rpc/TestMessageGroup.java   | 4 ++--
 .../java/org/apache/ignite/raft/jraft/rpc/impl/FutureTest.java    | 6 +++---
 .../ignite/raft/jraft/rpc/impl/PingRequestProcessorTest.java      | 6 +++---
 .../raft/jraft/rpc/impl/cli/AbstractCliRequestProcessorTest.java  | 6 +++---
 .../raft/jraft/rpc/impl/cli/AddLearnersRequestProcessorTest.java  | 6 +++---
 .../raft/jraft/rpc/impl/cli/AddPeerRequestProcessorTest.java      | 6 +++---
 .../raft/jraft/rpc/impl/cli/BaseCliRequestProcessorTest.java      | 6 +++---
 .../jraft/rpc/impl/cli/ChangePeersAsyncRequestProcessorTest.java  | 6 +++---
 .../raft/jraft/rpc/impl/cli/ChangePeersRequestProcessorTest.java  | 6 +++---
 .../raft/jraft/rpc/impl/cli/GetPeersRequestProcessorTest.java     | 6 +++---
 .../jraft/rpc/impl/cli/RemoveLearnersRequestProcessorTest.java    | 6 +++---
 .../raft/jraft/rpc/impl/cli/RemovePeerRequestProcessorTest.java   | 6 +++---
 .../jraft/rpc/impl/cli/ResetLearnersRequestProcessorTest.java     | 6 +++---
 .../raft/jraft/rpc/impl/cli/ResetPeersRequestProcessorTest.java   | 6 +++---
 .../raft/jraft/rpc/impl/cli/SnapshotRequestProcessorTest.java     | 6 +++---
 .../rpc/impl/cli/TransferLeadershipRequestProcessorTest.java      | 6 +++---
 .../jraft/rpc/impl/core/AppendEntriesRequestProcessorTest.java    | 6 +++---
 .../raft/jraft/rpc/impl/core/BaseNodeRequestProcessorTest.java    | 6 +++---
 .../jraft/rpc/impl/core/InstallSnapshotRequestProcessorTest.java  | 6 +++---
 .../ignite/raft/jraft/rpc/impl/core/NodeRequestProcessorTest.java | 6 +++---
 .../raft/jraft/rpc/impl/core/PreVoteRequestProcessorTest.java     | 6 +++---
 .../raft/jraft/rpc/impl/core/ReadIndexRequestProcessorTest.java   | 6 +++---
 .../raft/jraft/rpc/impl/core/RequestVoteRequestProcessorTest.java | 6 +++---
 .../raft/jraft/rpc/impl/core/TimeoutNowRequestProcessorTest.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/BaseStorageTest.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/FileServiceTest.java     | 6 +++---
 .../apache/ignite/raft/jraft/storage/SnapshotExecutorTest.java    | 6 +++---
 .../apache/ignite/raft/jraft/storage/impl/BaseLogStorageTest.java | 6 +++---
 .../ignite/raft/jraft/storage/impl/EntryCountBudgetTest.java      | 6 +++---
 .../ignite/raft/jraft/storage/impl/LocalLogStorageTest.java       | 6 +++---
 .../ignite/raft/jraft/storage/impl/LocalRaftMetaStorageTest.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/impl/LogManagerTest.java | 6 +++---
 .../ignite/raft/jraft/storage/impl/LogStorageBenchmark.java       | 6 +++---
 .../ignite/raft/jraft/storage/impl/RocksDBLogManagerTest.java     | 6 +++---
 .../ignite/raft/jraft/storage/impl/RocksDBLogStorageTest.java     | 6 +++---
 .../ignite/raft/jraft/storage/impl/UnlimitedBudgetTest.java       | 6 +++---
 .../raft/jraft/storage/impl/VolatileLogStorageBudgetingTest.java  | 6 +++---
 .../raft/jraft/storage/impl/VolatileLogStorageSpecificsTest.java  | 6 +++---
 .../ignite/raft/jraft/storage/impl/VolatileLogStorageTest.java    | 6 +++---
 .../raft/jraft/storage/impl/VolatileRaftMetaStorageTest.java      | 6 +++---
 .../apache/ignite/raft/jraft/storage/io/LocalFileReaderTest.java  | 6 +++---
 .../org/apache/ignite/raft/jraft/storage/io/MessageFileTest.java  | 6 +++---
 .../jraft/storage/snapshot/ThroughputSnapshotThrottleTest.java    | 6 +++---
 .../jraft/storage/snapshot/local/LocalSnapshotCopierTest.java     | 6 +++---
 .../jraft/storage/snapshot/local/LocalSnapshotMetaTableTest.java  | 6 +++---
 .../jraft/storage/snapshot/local/LocalSnapshotReaderTest.java     | 6 +++---
 .../jraft/storage/snapshot/local/LocalSnapshotStorageTest.java    | 6 +++---
 .../jraft/storage/snapshot/local/LocalSnapshotWriterTest.java     | 6 +++---
 .../raft/jraft/storage/snapshot/local/SnapshotFileReaderTest.java | 6 +++---
 .../raft/jraft/storage/snapshot/remote/CopySessionTest.java       | 6 +++---
 .../raft/jraft/storage/snapshot/remote/RemoteFileCopierTest.java  | 6 +++---
 .../java/org/apache/ignite/raft/jraft/test/MockAsyncContext.java  | 6 +++---
 .../apache/ignite/raft/jraft/util/AdaptiveBufAllocatorTest.java   | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/ArrayDequeTest.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/util/AsciiCodecBenchmark.java    | 6 +++---
 .../org/apache/ignite/raft/jraft/util/AsciiStringUtilTest.java    | 6 +++---
 .../src/test/java/org/apache/ignite/raft/jraft/util/BitsTest.java | 6 +++---
 .../apache/ignite/raft/jraft/util/ByteBufferCollectorTest.java    | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/BytesUtilTest.java     | 6 +++---
 .../org/apache/ignite/raft/jraft/util/CountDownEventTest.java     | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/util/CrcUtilTest.java  | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/util/EndpointTest.java | 6 +++---
 .../raft/jraft/util/ExponentialBackoffTimeoutStrategyTest.java    | 6 +++---
 .../ignite/raft/jraft/util/FileOutputSignalHandlerTest.java       | 6 +++---
 .../ignite/raft/jraft/util/RecyclableByteBufferListTest.java      | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/RecyclersTest.java     | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/RepeatedTimerTest.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/util/SegmentListTest.java   | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/util/ThreadIdTest.java | 6 +++---
 .../org/apache/ignite/raft/jraft/util/Utf8CodecBenchmark.java     | 6 +++---
 .../test/java/org/apache/ignite/raft/jraft/util/UtilsTest.java    | 6 +++---
 .../raft/jraft/util/concurrent/AdjustableSemaphoreTest.java       | 6 +++---
 .../jraft/util/concurrent/LongHeldDetectingReadWriteLockTest.java | 6 +++---
 .../raft/jraft/util/concurrent/MpscSingleThreadExecutorTest.java  | 6 +++---
 .../raft/jraft/util/concurrent/SingleThreadExecutorBenchmark.java | 6 +++---
 .../java/org/apache/ignite/raft/jraft/test/TestUtils.java         | 6 +++---
 .../main/java/org/apache/ignite/internal/rest/RestFactory.java    | 4 ++--
 .../java/org/apache/ignite/internal/rest/api/InvalidParam.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/rest/api/Problem.java    | 4 ++--
 .../ignite/internal/rest/api/cluster/ClusterManagementApi.java    | 4 ++--
 .../apache/ignite/internal/rest/api/cluster/ClusterNodeDto.java   | 4 ++--
 .../apache/ignite/internal/rest/api/cluster/ClusterStateDto.java  | 4 ++--
 .../apache/ignite/internal/rest/api/cluster/ClusterTagDto.java    | 4 ++--
 .../ignite/internal/rest/api/cluster/IgniteProductVersionDto.java | 4 ++--
 .../org/apache/ignite/internal/rest/api/cluster/InitCommand.java  | 4 ++--
 .../ignite/internal/rest/api/cluster/NetworkAddressDto.java       | 4 ++--
 .../org/apache/ignite/internal/rest/api/cluster/TopologyApi.java  | 4 ++--
 .../internal/rest/api/configuration/ClusterConfigurationApi.java  | 4 ++--
 .../internal/rest/api/configuration/NodeConfigurationApi.java     | 4 ++--
 .../apache/ignite/internal/rest/api/node/NodeManagementApi.java   | 4 ++--
 .../java/org/apache/ignite/internal/rest/api/node/NodeState.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/rest/api/node/State.java | 4 ++--
 .../java/org/apache/ignite/internal/rest/api/package-info.java    | 4 ++--
 .../java/org/apache/ignite/internal/rest/constants/HttpCode.java  | 4 ++--
 .../java/org/apache/ignite/internal/rest/constants/MediaType.java | 4 ++--
 .../internal/rest/exception/ClusterNotInitializedException.java   | 4 ++--
 .../exception/handler/ClusterNotInitializedExceptionHandler.java  | 4 ++--
 .../internal/rest/exception/handler/IgniteExceptionHandler.java   | 4 ++--
 .../internal/rest/exception/handler/JavaExceptionHandler.java     | 4 ++--
 .../java/org/apache/ignite/internal/rest/problem/Builder.java     | 4 ++--
 .../apache/ignite/internal/rest/problem/HttpProblemResponse.java  | 4 ++--
 .../rest/exception/handler/IgniteExceptionHandlerTest.java        | 4 ++--
 .../main/java/org/apache/ignite/internal/rest/RestComponent.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/rest/package-info.java   | 4 ++--
 .../apache/ignite/internal/rocksdb/BusyRocksIteratorAdapter.java  | 2 +-
 .../java/org/apache/ignite/internal/rocksdb/ColumnFamily.java     | 4 ++--
 .../java/org/apache/ignite/internal/rocksdb/RocksBiConsumer.java  | 4 ++--
 .../java/org/apache/ignite/internal/rocksdb/RocksBiPredicate.java | 4 ++--
 .../org/apache/ignite/internal/rocksdb/RocksIteratorAdapter.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/rocksdb/RocksUtils.java  | 4 ++--
 .../ignite/internal/rocksdb/flush/RocksDbFlushListener.java       | 2 +-
 .../org/apache/ignite/internal/rocksdb/flush/RocksDbFlusher.java  | 2 +-
 .../ignite/internal/rocksdb/snapshot/ColumnFamilyRange.java       | 2 +-
 .../ignite/internal/rocksdb/snapshot/RocksSnapshotManager.java    | 2 +-
 .../apache/ignite/internal/AbstractClusterIntegrationTest.java    | 4 ++--
 .../java/org/apache/ignite/internal/ItNoSyncMetadataTest.java     | 4 ++--
 .../ignite/internal/cluster/management/ItClusterInitTest.java     | 2 +-
 .../java/org/apache/ignite/internal/compute/ItComputeTest.java    | 4 ++--
 .../configuration/ItDistributedConfigurationPropertiesTest.java   | 2 +-
 .../storage/ItDistributedConfigurationStorageTest.java            | 4 ++--
 .../configuration/storage/ItRebalanceDistributedTest.java         | 4 ++--
 .../java/org/apache/ignite/internal/index/ItIndexManagerTest.java | 2 +-
 .../ignite/internal/inmemory/ItRaftStorageVolatilityTest.java     | 6 +++---
 .../org/apache/ignite/internal/rest/AbstractRestTestBase.java     | 4 ++--
 .../apache/ignite/internal/rest/ItInitializedClusterRestTest.java | 4 ++--
 .../ignite/internal/rest/ItNotInitializedClusterRestTest.java     | 4 ++--
 .../ignite/internal/runner/app/AbstractSchemaChangeTest.java      | 4 ++--
 .../apache/ignite/internal/runner/app/IgniteCliRunnerTest.java    | 4 ++--
 .../apache/ignite/internal/runner/app/ItDataSchemaSyncTest.java   | 4 ++--
 .../ignite/internal/runner/app/ItDynamicTableCreationTest.java    | 4 ++--
 .../internal/runner/app/ItIgniteInMemoryNodeRestartTest.java      | 4 ++--
 .../ignite/internal/runner/app/ItIgniteNodeRestartTest.java       | 4 ++--
 .../org/apache/ignite/internal/runner/app/ItIgnitionTest.java     | 4 ++--
 .../apache/ignite/internal/runner/app/ItNoThreadsLeftTest.java    | 4 ++--
 .../ignite/internal/runner/app/ItSchemaChangeKvViewTest.java      | 4 ++--
 .../ignite/internal/runner/app/ItSchemaChangeTableViewTest.java   | 4 ++--
 .../apache/ignite/internal/runner/app/ItTableApiContractTest.java | 4 ++--
 .../apache/ignite/internal/runner/app/ItTableCreationTest.java    | 4 ++--
 .../org/apache/ignite/internal/runner/app/ItTablesApiTest.java    | 4 ++--
 .../apache/ignite/internal/runner/app/PlatformTestNodeRunner.java | 4 ++--
 .../internal/runner/app/client/ItAbstractThinClientTest.java      | 4 ++--
 .../internal/runner/app/client/ItThinClientComputeTest.java       | 4 ++--
 .../internal/runner/app/client/ItThinClientConnectionTest.java    | 4 ++--
 .../ignite/internal/runner/app/client/ItThinClientSqlTest.java    | 4 ++--
 .../internal/runner/app/client/ItThinClientTransactionsTest.java  | 4 ++--
 .../ignite/internal/runner/app/jdbc/AbstractJdbcSelfTest.java     | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcAbstractStatementSelfTest.java | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcBatchSelfTest.java      | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcComplexDmlDdlSelfTest.java     | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcComplexQuerySelfTest.java      | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcConnectionPropertiesTest.java  | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcConnectionSelfTest.java | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcDeleteStatementSelfTest.java   | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcErrorsAbstractSelfTest.java    | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcErrorsSelfTest.java     | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcInsertStatementSelfTest.java   | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcJoinsSelfTest.java      | 4 ++--
 .../runner/app/jdbc/ItJdbcMetadataPrimaryKeysSelfTest.java        | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcMetadataSelfTest.java   | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcMultiStatementSelfTest.java    | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcResultSetSelfTest.java  | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcSelectAfterAlterTable.java     | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcStatementCancelSelfTest.java   | 4 ++--
 .../ignite/internal/runner/app/jdbc/ItJdbcStatementSelfTest.java  | 4 ++--
 .../internal/runner/app/jdbc/ItJdbcUpdateStatementSelfTest.java   | 4 ++--
 .../java/org/apache/ignite/internal/sql/api/ItCommonApiTest.java  | 4 ++--
 .../apache/ignite/internal/sql/api/ItSqlAsynchronousApiTest.java  | 4 ++--
 .../ignite/internal/sql/api/ItSqlClientAsynchronousApiTest.java   | 4 ++--
 .../ignite/internal/sql/api/ItSqlClientSynchronousApiTest.java    | 4 ++--
 .../apache/ignite/internal/sql/api/ItSqlSynchronousApiTest.java   | 4 ++--
 .../ignite/internal/sql/engine/AbstractBasicIntegrationTest.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItAggregatesTest.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItCorrelatesTest.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/ItCreateTableDdlTest.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItDataTypesTest.java    | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/ItDmlTest.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItFunctionsTest.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItHashSpoolTest.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItIndexSpoolTest.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItIntervalTest.java     | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/ItJoinTest.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItMetadataTest.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItMixedQueriesTest.java | 4 ++--
 .../apache/ignite/internal/sql/engine/ItOrToUnionRuleTest.java    | 4 ++--
 .../ignite/internal/sql/engine/ItProjectScanMergeRuleTest.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/ItSecondaryIndexTest.java   | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/ItSetOpTest.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/ItSortAggregateTest.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/ItSqlOperatorsTest.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/util/CursorUtils.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/util/MetadataMatcher.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/util/QueryChecker.java  | 4 ++--
 .../java/org/apache/ignite/internal/sqllogic/ItSqlLogicTest.java  | 4 ++--
 .../apache/ignite/internal/sqllogic/SqlLogicTestEnvironment.java  | 4 ++--
 .../java/org/apache/ignite/internal/sqllogic/SqlScriptRunner.java | 4 ++--
 .../apache/ignite/internal/table/ItPublicApiColocationTest.java   | 4 ++--
 .../org/apache/ignite/internal/test/WatchListenerInhibitor.java   | 4 ++--
 .../src/main/java/org/apache/ignite/app/IgniteCliRunner.java      | 4 ++--
 .../src/main/java/org/apache/ignite/internal/app/IgniteImpl.java  | 5 +++--
 .../main/java/org/apache/ignite/internal/app/IgnitionImpl.java    | 4 ++--
 .../java/org/apache/ignite/internal/app/LifecycleManager.java     | 2 +-
 .../org/apache/ignite/internal/configuration/CompoundModule.java  | 4 ++--
 .../ignite/internal/configuration/ConfigurationModules.java       | 4 ++--
 .../configuration/CoreDistributedConfigurationModule.java         | 4 ++--
 .../internal/configuration/CoreLocalConfigurationModule.java      | 4 ++--
 .../internal/configuration/ServiceLoaderModulesProvider.java      | 4 ++--
 .../configuration/storage/DistributedConfigurationStorage.java    | 4 ++--
 .../internal/configuration/storage/LocalConfigurationStorage.java | 4 ++--
 .../ignite/internal/recovery/ConfigurationCatchUpListener.java    | 4 ++--
 .../ignite/internal/recovery/RecoveryCompletionFutureFactory.java | 4 ++--
 .../java/org/apache/ignite/internal/rest/node/NameProvider.java   | 4 ++--
 .../ignite/internal/rest/node/NodeManagementController.java       | 4 ++--
 .../ignite/internal/rest/node/NodeManagementRestFactory.java      | 4 ++--
 .../java/org/apache/ignite/internal/rest/node/StateProvider.java  | 4 ++--
 .../apache/ignite/internal/configuration/CompoundModuleTest.java  | 4 ++--
 .../ignite/internal/configuration/ConfigurationModulesTest.java   | 4 ++--
 .../configuration/CoreDistributedConfigurationModuleTest.java     | 4 ++--
 .../internal/configuration/CoreLocalConfigurationModuleTest.java  | 4 ++--
 .../internal/configuration/ServiceLoaderModulesProviderTest.java  | 4 ++--
 .../ignite/internal/configuration/TestConfigurationModule.java    | 4 ++--
 .../internal/configuration/storage/ConfigurationStorageTest.java  | 2 +-
 .../storage/DistributedConfigurationCatchUpTest.java              | 2 +-
 .../storage/DistributedConfigurationStorageTest.java              | 2 +-
 .../configuration/storage/LocalConfigurationStorageTest.java      | 2 +-
 .../java/org/apache/ignite/internal/schema/AssemblyException.java | 4 ++--
 .../java/org/apache/ignite/internal/schema/BinaryConverter.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/BinaryRow.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/BinaryRowEx.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/BinaryTuple.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/BinaryTupleSchema.java | 4 ++--
 .../java/org/apache/ignite/internal/schema/BitmaskNativeType.java | 4 ++--
 .../java/org/apache/ignite/internal/schema/ByteBufferRow.java     | 4 ++--
 .../src/main/java/org/apache/ignite/internal/schema/Column.java   | 4 ++--
 .../src/main/java/org/apache/ignite/internal/schema/Columns.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/DecimalNativeType.java | 4 ++--
 .../org/apache/ignite/internal/schema/DefaultValueGenerator.java  | 4 ++--
 .../org/apache/ignite/internal/schema/DefaultValueProvider.java   | 4 ++--
 .../org/apache/ignite/internal/schema/InvalidTypeException.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/NativeType.java   | 4 ++--
 .../java/org/apache/ignite/internal/schema/NativeTypeSpec.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/NativeTypes.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/NumberNativeType.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/SchemaAware.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/SchemaDescriptor.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/SchemaException.java   | 4 ++--
 .../java/org/apache/ignite/internal/schema/SchemaManager.java     | 4 ++--
 .../apache/ignite/internal/schema/SchemaMismatchException.java    | 4 ++--
 .../ignite/internal/schema/SchemaModificationException.java       | 4 ++--
 .../java/org/apache/ignite/internal/schema/SchemaRegistry.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/SchemaUtils.java  | 4 ++--
 .../org/apache/ignite/internal/schema/TemporalNativeType.java     | 4 ++--
 .../java/org/apache/ignite/internal/schema/VarlenNativeType.java  | 4 ++--
 .../internal/schema/configuration/ColumnTypeValidatorImpl.java    | 4 ++--
 .../internal/schema/configuration/KnownDataStorageValidator.java  | 4 ++--
 .../schema/configuration/SchemaConfigurationConverter.java        | 4 ++--
 .../internal/schema/configuration/SchemaDescriptorConverter.java  | 4 ++--
 .../configuration/SchemaDistributedConfigurationModule.java       | 4 ++--
 .../ignite/internal/schema/configuration/TableValidatorImpl.java  | 4 ++--
 .../ignite/internal/schema/definition/AbstractSchemaObject.java   | 4 ++--
 .../ignite/internal/schema/definition/ColumnDefinitionImpl.java   | 4 ++--
 .../ignite/internal/schema/definition/SchemaValidationUtils.java  | 4 ++--
 .../ignite/internal/schema/definition/TableDefinitionImpl.java    | 4 ++--
 .../internal/schema/definition/index/HashIndexDefinitionImpl.java | 4 ++--
 .../schema/definition/index/IndexColumnDefinitionImpl.java        | 4 ++--
 .../schema/definition/index/PrimaryKeyDefinitionImpl.java         | 4 ++--
 .../schema/definition/index/SortedIndexColumnDefinitionImpl.java  | 4 ++--
 .../schema/definition/index/SortedIndexDefinitionImpl.java        | 4 ++--
 .../java/org/apache/ignite/internal/schema/event/SchemaEvent.java | 4 ++--
 .../ignite/internal/schema/event/SchemaEventParameters.java       | 4 ++--
 .../org/apache/ignite/internal/schema/mapping/ColumnMapper.java   | 4 ++--
 .../apache/ignite/internal/schema/mapping/ColumnMapperImpl.java   | 4 ++--
 .../org/apache/ignite/internal/schema/mapping/ColumnMapping.java  | 4 ++--
 .../org/apache/ignite/internal/schema/marshaller/BinaryMode.java  | 4 ++--
 .../apache/ignite/internal/schema/marshaller/KvMarshaller.java    | 4 ++--
 .../ignite/internal/schema/marshaller/MarshallerException.java    | 4 ++--
 .../ignite/internal/schema/marshaller/MarshallerFactory.java      | 4 ++--
 .../apache/ignite/internal/schema/marshaller/MarshallerUtil.java  | 4 ++--
 .../ignite/internal/schema/marshaller/RecordMarshaller.java       | 4 ++--
 .../internal/schema/marshaller/asm/AsmMarshallerGenerator.java    | 4 ++--
 .../internal/schema/marshaller/asm/ColumnAccessCodeGenerator.java | 4 ++--
 .../schema/marshaller/asm/IdentityMarshallerCodeGenerator.java    | 4 ++--
 .../internal/schema/marshaller/asm/MarshallerCodeGenerator.java   | 4 ++--
 .../schema/marshaller/asm/ObjectMarshallerCodeGenerator.java      | 4 ++--
 .../internal/schema/marshaller/reflection/ColumnBinding.java      | 4 ++--
 .../internal/schema/marshaller/reflection/KvMarshallerImpl.java   | 4 ++--
 .../ignite/internal/schema/marshaller/reflection/Marshaller.java  | 4 ++--
 .../schema/marshaller/reflection/RecordMarshallerImpl.java        | 4 ++--
 .../schema/marshaller/reflection/ReflectionMarshallerFactory.java | 4 ++--
 .../schema/marshaller/schema/AbstractSchemaSerializer.java        | 4 ++--
 .../internal/schema/marshaller/schema/SchemaSerializer.java       | 4 ++--
 .../internal/schema/marshaller/schema/SchemaSerializerImpl.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/schema/package-info.java | 4 ++--
 .../schema/registry/SchemaRegistrationConflictException.java      | 4 ++--
 .../ignite/internal/schema/registry/SchemaRegistryException.java  | 4 ++--
 .../ignite/internal/schema/registry/SchemaRegistryImpl.java       | 4 ++--
 .../ignite/internal/schema/registry/UpgradingRowAdapter.java      | 4 ++--
 .../org/apache/ignite/internal/schema/registry/package-info.java  | 4 ++--
 .../org/apache/ignite/internal/schema/row/ExpandableByteBuf.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/row/InternalTuple.java | 2 +-
 .../src/main/java/org/apache/ignite/internal/schema/row/Row.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/row/RowAssembler.java  | 4 ++--
 .../apache/ignite/internal/schema/row/TemporalTypesHelper.java    | 4 ++--
 .../org/apache/ignite/internal/schema/row/VarTableFormat.java     | 4 ++--
 .../java/org/apache/ignite/internal/util/ColocationUtils.java     | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/Factory.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/util/ObjectFactory.java  | 4 ++--
 .../src/main/java/org/apache/ignite/internal/util/Pair.java       | 4 ++--
 .../ignite/internal/benchmarks/SerializerBenchmarkTest.java       | 4 ++--
 .../org/apache/ignite/internal/schema/ColumnDefinitionTest.java   | 4 ++--
 .../test/java/org/apache/ignite/internal/schema/ColumnsTest.java  | 4 ++--
 .../org/apache/ignite/internal/schema/ExpandableByteBufTest.java  | 4 ++--
 .../java/org/apache/ignite/internal/schema/NativeTypeTest.java    | 4 ++--
 .../ignite/internal/schema/RowAssemblerAdvancedSchemaTest.java    | 4 ++--
 .../ignite/internal/schema/RowAssemblerSimpleSchemaTest.java      | 4 ++--
 .../src/test/java/org/apache/ignite/internal/schema/RowTest.java  | 4 ++--
 .../apache/ignite/internal/schema/SchemaConfigurationTest.java    | 4 ++--
 .../org/apache/ignite/internal/schema/SchemaDescriptorTest.java   | 4 ++--
 .../java/org/apache/ignite/internal/schema/TemporalTypesTest.java | 4 ++--
 .../internal/schema/builder/ColumnDefinitionBuilderTest.java      | 4 ++--
 .../internal/schema/builder/HashIndexDefinitionBuilderTest.java   | 4 ++--
 .../schema/builder/PrimaryKeyDefinitionDefinitionBuilderTest.java | 4 ++--
 .../internal/schema/builder/SortedIndexDefinitionBuilderTest.java | 4 ++--
 .../internal/schema/builder/TableDefinitionBuilderTest.java       | 4 ++--
 .../schema/configuration/AbstractSchemaConverterTest.java         | 4 ++--
 .../schema/configuration/KnownDataStorageValidatorTest.java       | 4 ++--
 .../schema/configuration/SchemaConfigurationConverterTest.java    | 4 ++--
 .../schema/configuration/SchemaDescriptorConverterTest.java       | 4 ++--
 .../configuration/SchemaDistributedConfigurationModuleTest.java   | 4 ++--
 .../internal/schema/configuration/TableValidatorImplTest.java     | 4 ++--
 .../configuration/schema/TestDataStorageConfigurationSchema.java  | 4 ++--
 .../ignite/internal/schema/marshaller/KvMarshallerTest.java       | 4 ++--
 .../org/apache/ignite/internal/schema/marshaller/MapperTest.java  | 4 ++--
 .../schema/marshaller/RecordMarshallerValidationsTest.java        | 4 ++--
 .../internal/schema/marshaller/reflection/ColumnBindingTest.java  | 4 ++--
 .../schema/marshaller/reflection/SerializingConverter.java        | 4 ++--
 .../ignite/internal/schema/registry/SchemaRegistryImplTest.java   | 4 ++--
 .../ignite/internal/schema/registry/UpgradingRowAdapterTest.java  | 4 ++--
 .../ignite/internal/schema/serializer/AbstractSerializerTest.java | 4 ++--
 .../java/org/apache/ignite/internal/schema/SchemaTestUtils.java   | 4 ++--
 .../ignite/internal/schema/marshaller/RecordMarshallerTest.java   | 4 ++--
 .../internal/schema/testobjects/TestObjectWithAllTypes.java       | 4 ++--
 .../schema/testobjects/TestObjectWithNoDefaultConstructor.java    | 4 ++--
 .../schema/testobjects/TestObjectWithPrivateConstructor.java      | 4 ++--
 .../ignite/internal/schema/testobjects/TestOuterObject.java       | 4 ++--
 .../ignite/internal/schema/testobjects/TestSimpleObject.java      | 4 ++--
 .../internal/schema/testutils/builder/AbstractIndexBuilder.java   | 4 ++--
 .../schema/testutils/builder/ColumnDefinitionBuilder.java         | 4 ++--
 .../schema/testutils/builder/ColumnDefinitionBuilderImpl.java     | 4 ++--
 .../schema/testutils/builder/HashIndexDefinitionBuilder.java      | 4 ++--
 .../schema/testutils/builder/HashIndexDefinitionBuilderImpl.java  | 4 ++--
 .../schema/testutils/builder/PrimaryKeyDefinitionBuilder.java     | 4 ++--
 .../schema/testutils/builder/PrimaryKeyDefinitionBuilderImpl.java | 4 ++--
 .../ignite/internal/schema/testutils/builder/SchemaBuilders.java  | 4 ++--
 .../internal/schema/testutils/builder/SchemaObjectBuilder.java    | 4 ++--
 .../schema/testutils/builder/SortedIndexDefinitionBuilder.java    | 4 ++--
 .../testutils/builder/SortedIndexDefinitionBuilderImpl.java       | 4 ++--
 .../internal/schema/testutils/builder/TableDefinitionBuilder.java | 4 ++--
 .../schema/testutils/builder/TableDefinitionBuilderImpl.java      | 4 ++--
 .../main/java/org/apache/calcite/plan/volcano/VolcanoUtils.java   | 4 ++--
 .../main/java/org/apache/calcite/plan/volcano/package-info.java   | 4 ++--
 .../org/apache/ignite/internal/sql/api/AsyncResultSetImpl.java    | 4 ++--
 .../org/apache/ignite/internal/sql/api/ColumnMetadataImpl.java    | 4 ++--
 .../java/org/apache/ignite/internal/sql/api/IgniteSqlImpl.java    | 4 ++--
 .../org/apache/ignite/internal/sql/api/ResultSetMetadataImpl.java | 4 ++--
 .../org/apache/ignite/internal/sql/api/SessionBuilderImpl.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/sql/api/SessionImpl.java | 4 ++--
 .../org/apache/ignite/internal/sql/api/StatementBuilderImpl.java  | 4 ++--
 .../java/org/apache/ignite/internal/sql/api/StatementImpl.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/AsyncCloseable.java     | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/AsyncCursor.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/AsyncSqlCursor.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/AsyncSqlCursorImpl.java | 4 ++--
 .../apache/ignite/internal/sql/engine/CurrentTimeProvider.java    | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/QueryCancel.java   | 4 ++--
 .../ignite/internal/sql/engine/QueryCancelledException.java       | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/QueryContext.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/QueryProcessor.java     | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/QueryProperty.java | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/QueryState.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/QueryValidator.java     | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/SqlCursor.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/SqlQueryProcessor.java  | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/SqlQueryType.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/sql/engine/Stubs.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/AbstractIndexScan.java | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/ArrayRowHandler.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/AsyncWrapper.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/ExchangeService.java   | 4 ++--
 .../ignite/internal/sql/engine/exec/ExchangeServiceImpl.java      | 4 ++--
 .../internal/sql/engine/exec/ExecutionCancelledException.java     | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/ExecutionContext.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/ExecutionService.java  | 4 ++--
 .../ignite/internal/sql/engine/exec/ExecutionServiceImpl.java     | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/LifecycleAware.java    | 4 ++--
 .../ignite/internal/sql/engine/exec/LogicalRelImplementor.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/MailboxRegistry.java   | 4 ++--
 .../ignite/internal/sql/engine/exec/MailboxRegistryImpl.java      | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/QueryTaskExecutor.java | 4 ++--
 .../ignite/internal/sql/engine/exec/QueryTaskExecutorImpl.java    | 4 ++--
 .../ignite/internal/sql/engine/exec/QueryValidationException.java | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/RemoteFragmentKey.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/RowHandler.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/RuntimeHashIndex.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/RuntimeIndex.java  | 4 ++--
 .../ignite/internal/sql/engine/exec/RuntimeSortedIndex.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/TableFunctionScan.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/TreeIndex.java     | 4 ++--
 .../ignite/internal/sql/engine/exec/ddl/DdlCommandHandler.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/exp/BiScalar.java  | 8 ++++----
 .../ignite/internal/sql/engine/exec/exp/CallImplementor.java      | 8 ++++----
 .../ignite/internal/sql/engine/exec/exp/ConverterUtils.java       | 8 ++++----
 .../ignite/internal/sql/engine/exec/exp/ExpressionFactory.java    | 4 ++--
 .../internal/sql/engine/exec/exp/ExpressionFactoryImpl.java       | 4 ++--
 .../ignite/internal/sql/engine/exec/exp/IgniteSqlFunctions.java   | 8 ++++----
 .../internal/sql/engine/exec/exp/ImplementableFunction.java       | 8 ++++----
 .../ignite/internal/sql/engine/exec/exp/NotNullImplementor.java   | 8 ++++----
 .../sql/engine/exec/exp/ReflectiveCallNotNullImplementor.java     | 8 ++++----
 .../ignite/internal/sql/engine/exec/exp/RexExecutorImpl.java      | 8 ++++----
 .../apache/ignite/internal/sql/engine/exec/exp/RexImpTable.java   | 8 ++++----
 .../ignite/internal/sql/engine/exec/exp/RexToLixTranslator.java   | 8 ++++----
 .../org/apache/ignite/internal/sql/engine/exec/exp/Scalar.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/exp/SingleScalar.java  | 4 ++--
 .../ignite/internal/sql/engine/exec/exp/agg/Accumulator.java      | 4 ++--
 .../internal/sql/engine/exec/exp/agg/AccumulatorWrapper.java      | 4 ++--
 .../ignite/internal/sql/engine/exec/exp/agg/Accumulators.java     | 4 ++--
 .../internal/sql/engine/exec/exp/agg/AccumulatorsFactory.java     | 4 ++--
 .../ignite/internal/sql/engine/exec/exp/agg/AggregateType.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/exp/agg/GroupKey.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/AbstractNode.java  | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/AbstractSetOpNode.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/AsyncRootNode.java | 4 ++--
 .../sql/engine/exec/rel/CorrelatedNestedLoopJoinNode.java         | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/Downstream.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/FilterNode.java    | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/HashAggregateNode.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/Inbox.java     | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/IndexSpoolNode.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/IntersectNode.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/LimitNode.java | 8 ++++----
 .../org/apache/ignite/internal/sql/engine/exec/rel/Mailbox.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/MergeJoinNode.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/MinusNode.java | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/ModifyNode.java    | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/NestedLoopJoinNode.java   | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/exec/rel/Node.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/Outbox.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/ProjectNode.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/RootNode.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/ScanNode.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/SingleNode.java    | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/SortAggregateNode.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/exec/rel/SortNode.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/TableScanNode.java | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/TableSpoolNode.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/UnionAllNode.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/externalize/RelInputEx.java | 8 ++++----
 .../apache/ignite/internal/sql/engine/externalize/RelJson.java    | 8 ++++----
 .../ignite/internal/sql/engine/externalize/RelJsonReader.java     | 8 ++++----
 .../ignite/internal/sql/engine/externalize/RelJsonWriter.java     | 8 ++++----
 .../apache/ignite/internal/sql/engine/message/ErrorMessage.java   | 4 ++--
 .../internal/sql/engine/message/ExecutionContextAwareMessage.java | 4 ++--
 .../ignite/internal/sql/engine/message/InboxCloseMessage.java     | 4 ++--
 .../ignite/internal/sql/engine/message/MessageListener.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/message/MessageService.java | 4 ++--
 .../ignite/internal/sql/engine/message/MessageServiceImpl.java    | 4 ++--
 .../internal/sql/engine/message/QueryBatchAcknowledgeMessage.java | 4 ++--
 .../ignite/internal/sql/engine/message/QueryBatchMessage.java     | 4 ++--
 .../ignite/internal/sql/engine/message/QueryCloseMessage.java     | 4 ++--
 .../ignite/internal/sql/engine/message/QueryStartRequest.java     | 4 ++--
 .../ignite/internal/sql/engine/message/QueryStartResponse.java    | 4 ++--
 .../ignite/internal/sql/engine/message/SqlQueryMessageGroup.java  | 4 ++--
 .../ignite/internal/sql/engine/metadata/AffinityService.java      | 4 ++--
 .../ignite/internal/sql/engine/metadata/ColocationGroup.java      | 4 ++--
 .../internal/sql/engine/metadata/ColocationMappingException.java  | 4 ++--
 .../ignite/internal/sql/engine/metadata/FragmentDescription.java  | 4 ++--
 .../ignite/internal/sql/engine/metadata/FragmentMapping.java      | 4 ++--
 .../internal/sql/engine/metadata/FragmentMappingException.java    | 4 ++--
 .../ignite/internal/sql/engine/metadata/IgniteMdCollation.java    | 4 ++--
 .../internal/sql/engine/metadata/IgniteMdCumulativeCost.java      | 4 ++--
 .../internal/sql/engine/metadata/IgniteMdDistinctRowCount.java    | 4 ++--
 .../ignite/internal/sql/engine/metadata/IgniteMdDistribution.java | 4 ++--
 .../internal/sql/engine/metadata/IgniteMdFragmentMapping.java     | 4 ++--
 .../internal/sql/engine/metadata/IgniteMdNonCumulativeCost.java   | 4 ++--
 .../sql/engine/metadata/IgniteMdPercentageOriginalRows.java       | 4 ++--
 .../ignite/internal/sql/engine/metadata/IgniteMdPredicates.java   | 4 ++--
 .../ignite/internal/sql/engine/metadata/IgniteMdRowCount.java     | 4 ++--
 .../ignite/internal/sql/engine/metadata/IgniteMdSelectivity.java  | 4 ++--
 .../ignite/internal/sql/engine/metadata/IgniteMetadata.java       | 4 ++--
 .../ignite/internal/sql/engine/metadata/MappingService.java       | 4 ++--
 .../ignite/internal/sql/engine/metadata/MappingServiceImpl.java   | 4 ++--
 .../ignite/internal/sql/engine/metadata/NodeMappingException.java | 4 ++--
 .../ignite/internal/sql/engine/metadata/RelMetadataQueryEx.java   | 4 ++--
 .../ignite/internal/sql/engine/metadata/RemoteException.java      | 4 ++--
 .../ignite/internal/sql/engine/metadata/cost/IgniteCost.java      | 4 ++--
 .../internal/sql/engine/metadata/cost/IgniteCostFactory.java      | 4 ++--
 .../ignite/internal/sql/engine/prepare/AbstractMultiStepPlan.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/prepare/CacheKey.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/prepare/Cloner.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/prepare/DdlPlan.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/ExecutionPlan.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/ExplainPlan.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/prepare/Fragment.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/FragmentPlan.java   | 4 ++--
 .../ignite/internal/sql/engine/prepare/FragmentSplitter.java      | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/IdGenerator.java    | 4 ++--
 .../ignite/internal/sql/engine/prepare/IgniteConvertletTable.java | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/IgnitePlanner.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/IgnitePrograms.java | 4 ++--
 .../ignite/internal/sql/engine/prepare/IgniteRelShuttle.java      | 4 ++--
 .../internal/sql/engine/prepare/IgniteSqlToRelConvertor.java      | 4 ++--
 .../ignite/internal/sql/engine/prepare/IgniteSqlValidator.java    | 4 ++--
 .../ignite/internal/sql/engine/prepare/IgniteTypeCoercion.java    | 4 ++--
 .../ignite/internal/sql/engine/prepare/LazyResultSetMetadata.java | 4 ++--
 .../ignite/internal/sql/engine/prepare/MappingQueryContext.java   | 4 ++--
 .../ignite/internal/sql/engine/prepare/MultiStepDmlPlan.java      | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/MultiStepPlan.java  | 4 ++--
 .../ignite/internal/sql/engine/prepare/MultiStepQueryPlan.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/PlannerHelper.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/PlannerPhase.java   | 4 ++--
 .../ignite/internal/sql/engine/prepare/PlanningContext.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/PrepareService.java | 4 ++--
 .../ignite/internal/sql/engine/prepare/PrepareServiceImpl.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/prepare/QueryPlan.java  | 4 ++--
 .../ignite/internal/sql/engine/prepare/QueryPlanFactory.java      | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/QueryTemplate.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/prepare/Splitter.java   | 4 ++--
 .../ignite/internal/sql/engine/prepare/ValidationResult.java      | 4 ++--
 .../internal/sql/engine/prepare/ddl/AbstractTableDdlCommand.java  | 4 ++--
 .../internal/sql/engine/prepare/ddl/AlterTableAddCommand.java     | 4 ++--
 .../internal/sql/engine/prepare/ddl/AlterTableDropCommand.java    | 4 ++--
 .../ignite/internal/sql/engine/prepare/ddl/ColumnDefinition.java  | 4 ++--
 .../internal/sql/engine/prepare/ddl/CreateIndexCommand.java       | 4 ++--
 .../internal/sql/engine/prepare/ddl/CreateTableCommand.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/prepare/ddl/DdlCommand.java | 4 ++--
 .../internal/sql/engine/prepare/ddl/DdlSqlToCommandConverter.java | 4 ++--
 .../internal/sql/engine/prepare/ddl/DefaultValueDefinition.java   | 4 ++--
 .../ignite/internal/sql/engine/prepare/ddl/DropIndexCommand.java  | 4 ++--
 .../ignite/internal/sql/engine/prepare/ddl/DropTableCommand.java  | 4 ++--
 .../ignite/internal/sql/engine/prepare/ddl/TableOptionInfo.java   | 4 ++--
 .../ignite/internal/sql/engine/property/PropertiesHelper.java     | 4 ++--
 .../ignite/internal/sql/engine/property/PropertiesHolder.java     | 4 ++--
 .../ignite/internal/sql/engine/property/PropertiesHolderImpl.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/property/Property.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/AbstractIgniteJoin.java | 4 ++--
 .../ignite/internal/sql/engine/rel/AbstractIgniteSpool.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/AbstractIndexScan.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteAggregate.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteConvention.java   | 4 ++--
 .../internal/sql/engine/rel/IgniteCorrelatedNestedLoopJoin.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteExchange.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteFilter.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteGateway.java  | 4 ++--
 .../ignite/internal/sql/engine/rel/IgniteHashIndexSpool.java      | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteIndexScan.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteLimit.java    | 8 ++++----
 .../apache/ignite/internal/sql/engine/rel/IgniteMergeJoin.java    | 4 ++--
 .../ignite/internal/sql/engine/rel/IgniteNestedLoopJoin.java      | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteProject.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteReceiver.java | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/rel/IgniteRel.java | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteRelVisitor.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteSender.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteSort.java     | 4 ++--
 .../ignite/internal/sql/engine/rel/IgniteSortedIndexSpool.java    | 4 ++--
 .../ignite/internal/sql/engine/rel/IgniteTableFunctionScan.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteTableModify.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteTableScan.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteTableSpool.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/IgniteTrimExchange.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteUnionAll.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/rel/IgniteValues.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/InternalIgniteRel.java  | 8 ++++----
 .../internal/sql/engine/rel/ProjectableFilterableTableScan.java   | 4 ++--
 .../ignite/internal/sql/engine/rel/SourceAwareIgniteRel.java      | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteHashAggregateBase.java      | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteMapAggregateBase.java       | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteMapHashAggregate.java       | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteMapSortAggregate.java       | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteReduceAggregateBase.java    | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteReduceHashAggregate.java    | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteReduceSortAggregate.java    | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteSingleAggregateBase.java    | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteSingleHashAggregate.java    | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteSingleSortAggregate.java    | 4 ++--
 .../internal/sql/engine/rel/agg/IgniteSortAggregateBase.java      | 4 ++--
 .../internal/sql/engine/rel/logical/IgniteLogicalIndexScan.java   | 8 ++++----
 .../internal/sql/engine/rel/logical/IgniteLogicalTableScan.java   | 8 ++++----
 .../ignite/internal/sql/engine/rel/set/IgniteIntersect.java       | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteMapIntersect.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/set/IgniteMapMinus.java | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/set/IgniteMapSetOp.java | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/set/IgniteMinus.java    | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteMinusBase.java       | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteReduceIntersect.java | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteReduceMinus.java     | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteReduceSetOp.java     | 4 ++--
 .../apache/ignite/internal/sql/engine/rel/set/IgniteSetOp.java    | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteSingleIntersect.java | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteSingleMinus.java     | 4 ++--
 .../ignite/internal/sql/engine/rel/set/IgniteSingleSetOp.java     | 4 ++--
 .../internal/sql/engine/rule/AbstractIgniteConverterRule.java     | 4 ++--
 .../internal/sql/engine/rule/CorrelateToNestedLoopRule.java       | 4 ++--
 .../internal/sql/engine/rule/CorrelatedNestedLoopJoinRule.java    | 4 ++--
 .../ignite/internal/sql/engine/rule/FilterConverterRule.java      | 4 ++--
 .../sql/engine/rule/FilterSpoolMergeToHashIndexSpoolRule.java     | 4 ++--
 .../sql/engine/rule/FilterSpoolMergeToSortedIndexSpoolRule.java   | 4 ++--
 .../internal/sql/engine/rule/HashAggregateConverterRule.java      | 4 ++--
 .../ignite/internal/sql/engine/rule/LogicalScanConverterRule.java | 8 ++++----
 .../ignite/internal/sql/engine/rule/MergeJoinConverterRule.java   | 4 ++--
 .../ignite/internal/sql/engine/rule/MinusConverterRule.java       | 4 ++--
 .../internal/sql/engine/rule/NestedLoopJoinConverterRule.java     | 4 ++--
 .../ignite/internal/sql/engine/rule/ProjectConverterRule.java     | 4 ++--
 .../ignite/internal/sql/engine/rule/SetOpConverterRule.java       | 4 ++--
 .../internal/sql/engine/rule/SortAggregateConverterRule.java      | 4 ++--
 .../apache/ignite/internal/sql/engine/rule/SortConverterRule.java | 4 ++--
 .../internal/sql/engine/rule/TableFunctionScanConverterRule.java  | 8 ++++----
 .../ignite/internal/sql/engine/rule/TableModifyConverterRule.java | 4 ++--
 .../ignite/internal/sql/engine/rule/UnionConverterRule.java       | 4 ++--
 .../ignite/internal/sql/engine/rule/ValuesConverterRule.java      | 4 ++--
 .../ignite/internal/sql/engine/rule/logical/ExposeIndexRule.java  | 4 ++--
 .../internal/sql/engine/rule/logical/FilterScanMergeRule.java     | 4 ++--
 .../internal/sql/engine/rule/logical/LogicalOrToUnionRule.java    | 4 ++--
 .../internal/sql/engine/rule/logical/ProjectScanMergeRule.java    | 8 ++++----
 .../internal/sql/engine/rule/logical/RuleFactoryConfig.java       | 8 ++++----
 .../org/apache/ignite/internal/sql/engine/rule/package-info.java  | 4 ++--
 .../ignite/internal/sql/engine/schema/ColumnDescriptor.java       | 4 ++--
 .../ignite/internal/sql/engine/schema/ColumnDescriptorImpl.java   | 4 ++--
 .../ignite/internal/sql/engine/schema/DefaultValueStrategy.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/schema/IgniteIndex.java | 4 ++--
 .../apache/ignite/internal/sql/engine/schema/IgniteSchema.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/schema/IgniteTable.java | 4 ++--
 .../apache/ignite/internal/sql/engine/schema/IgniteTableImpl.java | 4 ++--
 .../ignite/internal/sql/engine/schema/InternalIgniteTable.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/schema/ModifyRow.java   | 4 ++--
 .../ignite/internal/sql/engine/schema/SchemaUpdateListener.java   | 4 ++--
 .../ignite/internal/sql/engine/schema/SqlSchemaManager.java       | 4 ++--
 .../ignite/internal/sql/engine/schema/SqlSchemaManagerImpl.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/schema/TableDescriptor.java | 4 ++--
 .../ignite/internal/sql/engine/schema/TableDescriptorImpl.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/session/Session.java    | 4 ++--
 .../org/apache/ignite/internal/sql/engine/session/SessionId.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/session/SessionInfo.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/session/SessionManager.java | 4 ++--
 .../internal/sql/engine/sql/IgniteAbstractSqlAlterTable.java      | 8 ++++----
 .../internal/sql/engine/sql/IgniteSqlAlterTableAddColumn.java     | 8 ++++----
 .../internal/sql/engine/sql/IgniteSqlAlterTableDropColumn.java    | 8 ++++----
 .../ignite/internal/sql/engine/sql/IgniteSqlConformance.java      | 8 ++++----
 .../ignite/internal/sql/engine/sql/IgniteSqlCreateIndex.java      | 8 ++++----
 .../ignite/internal/sql/engine/sql/IgniteSqlCreateTable.java      | 8 ++++----
 .../internal/sql/engine/sql/IgniteSqlCreateTableOption.java       | 4 ++--
 .../apache/ignite/internal/sql/engine/sql/IgniteSqlDropIndex.java | 8 ++++----
 .../apache/ignite/internal/sql/engine/sql/IgniteSqlIndexType.java | 8 ++++----
 .../internal/sql/engine/sql/IgniteSqlIntervalTypeNameSpec.java    | 4 ++--
 .../internal/sql/engine/sql/fun/IgniteSqlOperatorTable.java       | 8 ++++----
 .../internal/sql/engine/sql/fun/SqlSystemRangeFunction.java       | 8 ++++----
 .../apache/ignite/internal/sql/engine/trait/AffinityAdapter.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/trait/AllNodes.java     | 4 ++--
 .../apache/ignite/internal/sql/engine/trait/CorrelationTrait.java | 4 ++--
 .../ignite/internal/sql/engine/trait/CorrelationTraitDef.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/trait/Destination.java  | 4 ++--
 .../ignite/internal/sql/engine/trait/DistributionFunction.java    | 4 ++--
 .../ignite/internal/sql/engine/trait/DistributionTrait.java       | 4 ++--
 .../ignite/internal/sql/engine/trait/DistributionTraitDef.java    | 4 ++--
 .../ignite/internal/sql/engine/trait/IgniteDistribution.java      | 4 ++--
 .../ignite/internal/sql/engine/trait/IgniteDistributions.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/trait/Partitioned.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/trait/RandomNode.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/trait/RelFactory.java   | 4 ++--
 .../ignite/internal/sql/engine/trait/RewindabilityTrait.java      | 4 ++--
 .../ignite/internal/sql/engine/trait/RewindabilityTraitDef.java   | 4 ++--
 .../org/apache/ignite/internal/sql/engine/trait/TraitUtils.java   | 4 ++--
 .../ignite/internal/sql/engine/trait/TraitsAwareIgniteRel.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/type/IgniteTypeFactory.java | 4 ++--
 .../apache/ignite/internal/sql/engine/type/IgniteTypeSystem.java  | 4 ++--
 .../ignite/internal/sql/engine/util/AbstractQueryContext.java     | 4 ++--
 .../apache/ignite/internal/sql/engine/util/BaseQueryContext.java  | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/util/Commons.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/util/HintUtils.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/util/IgniteMethod.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/util/IgniteResource.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/util/IndexConditions.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/util/NodeLeaveHandler.java  | 4 ++--
 .../org/apache/ignite/internal/sql/engine/util/Primitives.java    | 4 ++--
 .../java/org/apache/ignite/internal/sql/engine/util/RexUtils.java | 4 ++--
 .../org/apache/ignite/internal/sql/engine/util/TypeUtils.java     | 4 ++--
 .../org/apache/ignite/internal/sql/engine/IgniteSqlApiTest.java   | 4 ++--
 .../apache/ignite/internal/sql/engine/StopCalciteModuleTest.java  | 4 ++--
 .../test/java/org/apache/ignite/internal/sql/engine/TestRow.java  | 4 ++--
 .../ignite/internal/sql/engine/exec/AsyncWrapperSelfTest.java     | 4 ++--
 .../ignite/internal/sql/engine/exec/ExecutionServiceImplTest.java | 4 ++--
 .../ignite/internal/sql/engine/exec/MockedStructuresTest.java     | 4 ++--
 .../ignite/internal/sql/engine/exec/RuntimeSortedIndexTest.java   | 4 ++--
 .../internal/sql/engine/exec/exp/ExpressionFactoryImplTest.java   | 4 ++--
 .../internal/sql/engine/exec/exp/IgniteSqlFunctionsTest.java      | 4 ++--
 .../internal/sql/engine/exec/rel/AbstractExecutionTest.java       | 4 ++--
 .../internal/sql/engine/exec/rel/AbstractSetOpExecutionTest.java  | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/BaseAggregateTest.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/exec/rel/ExecutionTest.java | 4 ++--
 .../internal/sql/engine/exec/rel/HashAggregateExecutionTest.java  | 4 ++--
 .../engine/exec/rel/HashAggregateSingleGroupExecutionTest.java    | 4 ++--
 .../internal/sql/engine/exec/rel/HashIndexSpoolExecutionTest.java | 4 ++--
 .../internal/sql/engine/exec/rel/IntersectExecutionTest.java      | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/LimitExecutionTest.java   | 4 ++--
 .../internal/sql/engine/exec/rel/MergeJoinExecutionTest.java      | 4 ++--
 .../ignite/internal/sql/engine/exec/rel/MinusExecutionTest.java   | 4 ++--
 .../internal/sql/engine/exec/rel/NestedLoopJoinExecutionTest.java | 4 ++--
 .../internal/sql/engine/exec/rel/SortAggregateExecutionTest.java  | 4 ++--
 .../sql/engine/exec/rel/SortedIndexSpoolExecutionTest.java        | 4 ++--
 .../internal/sql/engine/exec/rel/TableSpoolExecutionTest.java     | 4 ++--
 .../internal/sql/engine/exec/schema/SqlSchemaManagerTest.java     | 4 ++--
 .../ignite/internal/sql/engine/externalize/RelJsonReaderTest.java | 4 ++--
 .../internal/sql/engine/planner/AbstractAggregatePlannerTest.java | 4 ++--
 .../ignite/internal/sql/engine/planner/AbstractPlannerTest.java   | 4 ++--
 .../internal/sql/engine/planner/AggregateDistinctPlannerTest.java | 4 ++--
 .../ignite/internal/sql/engine/planner/AggregatePlannerTest.java  | 4 ++--
 .../sql/engine/planner/CorrelatedNestedLoopJoinPlannerTest.java   | 4 ++--
 .../sql/engine/planner/CorrelatedSubqueryPlannerTest.java         | 6 +++---
 .../internal/sql/engine/planner/HashAggregatePlannerTest.java     | 4 ++--
 .../ignite/internal/sql/engine/planner/HashIndexPlannerTest.java  | 4 ++--
 .../internal/sql/engine/planner/HashIndexSpoolPlannerTest.java    | 4 ++--
 .../internal/sql/engine/planner/JoinColocationPlannerTest.java    | 4 ++--
 .../internal/sql/engine/planner/JoinCommutePlannerTest.java       | 8 ++++----
 .../internal/sql/engine/planner/JoinWithUsingPlannerTest.java     | 4 ++--
 .../internal/sql/engine/planner/LimitOffsetPlannerTest.java       | 4 ++--
 .../ignite/internal/sql/engine/planner/MergeJoinPlannerTest.java  | 4 ++--
 .../apache/ignite/internal/sql/engine/planner/PlannerTest.java    | 4 ++--
 .../sql/engine/planner/ProjectFilterScanMergePlannerTest.java     | 4 ++--
 .../ignite/internal/sql/engine/planner/SetOpPlannerTest.java      | 4 ++--
 .../internal/sql/engine/planner/SortAggregatePlannerTest.java     | 4 ++--
 .../internal/sql/engine/planner/SortedIndexSpoolPlannerTest.java  | 4 ++--
 .../internal/sql/engine/planner/TableFunctionPlannerTest.java     | 4 ++--
 .../ignite/internal/sql/engine/planner/TableSpoolPlannerTest.java | 4 ++--
 .../ignite/internal/sql/engine/planner/UnionPlannerTest.java      | 4 ++--
 .../sql/engine/prepare/ddl/DdlSqlToCommandConverterTest.java      | 4 ++--
 .../ignite/internal/sql/engine/property/PropertiesHelperTest.java | 4 ++--
 .../ignite/internal/sql/engine/session/SessionManagerTest.java    | 4 ++--
 .../apache/ignite/internal/sql/engine/sql/SqlDdlParserTest.java   | 4 ++--
 .../src/main/java/org/apache/ignite/internal/storage/DataRow.java | 4 ++--
 .../org/apache/ignite/internal/storage/DataStorageManager.java    | 4 ++--
 .../org/apache/ignite/internal/storage/DataStorageModule.java     | 4 ++--
 .../org/apache/ignite/internal/storage/DataStorageModules.java    | 4 ++--
 .../java/org/apache/ignite/internal/storage/InvokeClosure.java    | 4 ++--
 .../org/apache/ignite/internal/storage/MvPartitionStorage.java    | 2 +-
 .../java/org/apache/ignite/internal/storage/OperationType.java    | 4 ++--
 .../java/org/apache/ignite/internal/storage/PartitionStorage.java | 4 ++--
 .../src/main/java/org/apache/ignite/internal/storage/RowId.java   | 2 +-
 .../main/java/org/apache/ignite/internal/storage/SearchRow.java   | 4 ++--
 .../java/org/apache/ignite/internal/storage/StorageException.java | 4 ++--
 .../org/apache/ignite/internal/storage/TxIdMismatchException.java | 2 +-
 .../org/apache/ignite/internal/storage/basic/BinarySearchRow.java | 2 +-
 .../apache/ignite/internal/storage/basic/DelegatingDataRow.java   | 4 ++--
 .../ignite/internal/storage/basic/DeleteExactInvokeClosure.java   | 4 ++--
 .../ignite/internal/storage/basic/GetAndRemoveInvokeClosure.java  | 4 ++--
 .../ignite/internal/storage/basic/GetAndReplaceInvokeClosure.java | 4 ++--
 .../apache/ignite/internal/storage/basic/InsertInvokeClosure.java | 4 ++--
 .../ignite/internal/storage/basic/ReplaceExactInvokeClosure.java  | 4 ++--
 .../org/apache/ignite/internal/storage/basic/SimpleDataRow.java   | 4 ++--
 .../ignite/internal/storage/basic/SimpleReadInvokeClosure.java    | 4 ++--
 .../ignite/internal/storage/basic/SimpleRemoveInvokeClosure.java  | 4 ++--
 .../ignite/internal/storage/basic/SimpleWriteInvokeClosure.java   | 4 ++--
 .../storage/configuration/ExistingDataStorageValidator.java       | 4 ++--
 .../StorageEngineDistributedConfigurationModule.java              | 4 ++--
 .../org/apache/ignite/internal/storage/engine/MvTableStorage.java | 2 +-
 .../org/apache/ignite/internal/storage/engine/StorageEngine.java  | 4 ++--
 .../org/apache/ignite/internal/storage/engine/TableStorage.java   | 4 ++--
 .../apache/ignite/internal/storage/index/HashIndexDescriptor.java | 2 +-
 .../apache/ignite/internal/storage/index/HashIndexStorage.java    | 2 +-
 .../java/org/apache/ignite/internal/storage/index/IndexRow.java   | 2 +-
 .../org/apache/ignite/internal/storage/index/IndexRowImpl.java    | 2 +-
 .../ignite/internal/storage/index/SortedIndexDescriptor.java      | 2 +-
 .../apache/ignite/internal/storage/index/SortedIndexStorage.java  | 2 +-
 .../internal/storage/ConcurrentHashMapMvTableStorageTest.java     | 2 +-
 .../apache/ignite/internal/storage/DataStorageManagerTest.java    | 4 ++--
 .../apache/ignite/internal/storage/DataStorageModulesTest.java    | 4 ++--
 .../ignite/internal/storage/TestMvPartitionStorageTest.java       | 2 +-
 .../storage/configuration/ExistingDataStorageValidatorTest.java   | 4 ++--
 .../internal/storage/index/AbstractSortedIndexStorageTest.java    | 2 +-
 .../ignite/internal/storage/index/TestHashIndexStorageTest.java   | 2 +-
 .../ignite/internal/storage/index/TestSortedIndexStorageTest.java | 2 +-
 .../apache/ignite/internal/storage/index/impl/TestIndexRow.java   | 2 +-
 .../ignite/internal/storage/AbstractMvPartitionStorageTest.java   | 2 +-
 .../ignite/internal/storage/AbstractMvTableStorageTest.java       | 2 +-
 .../ignite/internal/storage/AbstractPartitionStorageTest.java     | 4 ++--
 .../org/apache/ignite/internal/storage/BaseMvStoragesTest.java    | 2 +-
 .../storage/chm/TestConcurrentHashMapDataStorageModule.java       | 4 ++--
 .../storage/chm/TestConcurrentHashMapMvPartitionStorage.java      | 8 ++++----
 .../internal/storage/chm/TestConcurrentHashMapMvTableStorage.java | 2 +-
 .../internal/storage/chm/TestConcurrentHashMapStorageEngine.java  | 4 ++--
 ...currentHashMapStorageEngineDistributedConfigurationModule.java | 4 ++--
 .../TestConcurrentHashMapDataStorageConfigurationSchema.java      | 4 ++--
 .../internal/storage/index/AbstractHashIndexStorageTest.java      | 2 +-
 .../ignite/internal/storage/index/impl/BinaryTupleComparator.java | 2 +-
 .../internal/storage/index/impl/BinaryTupleRowSerializer.java     | 2 +-
 .../apache/ignite/internal/storage/index/impl/IndexRowImpl.java   | 2 +-
 .../ignite/internal/storage/index/impl/TestHashIndexStorage.java  | 2 +-
 .../internal/storage/index/impl/TestSortedIndexStorage.java       | 2 +-
 .../storage/pagememory/AbstractPageMemoryTableStorage.java        | 4 ++--
 .../storage/pagememory/PersistentPageMemoryDataRegion.java        | 4 ++--
 .../storage/pagememory/PersistentPageMemoryDataStorageModule.java | 4 ++--
 .../storage/pagememory/PersistentPageMemoryStorageEngine.java     | 4 ++--
 .../storage/pagememory/PersistentPageMemoryTableStorage.java      | 4 ++--
 .../internal/storage/pagememory/VolatilePageMemoryDataRegion.java | 4 ++--
 .../storage/pagememory/VolatilePageMemoryDataStorageModule.java   | 4 ++--
 .../storage/pagememory/VolatilePageMemoryStorageEngine.java       | 4 ++--
 .../storage/pagememory/VolatilePageMemoryTableStorage.java        | 4 ++--
 .../pagememory/configuration/PageMemoryDataRegionName.java        | 4 ++--
 .../configuration/PageMemoryDataRegionValidatorImpl.java          | 4 ++--
 .../PageMemoryStorageEngineDistributedConfigurationModule.java    | 4 ++--
 .../schema/BasePageMemoryStorageEngineConfigurationSchema.java    | 4 ++--
 .../PersistentPageMemoryDataStorageConfigurationSchema.java       | 4 ++--
 .../PersistentPageMemoryStorageEngineConfigurationSchema.java     | 4 ++--
 .../schema/VolatilePageMemoryDataStorageConfigurationSchema.java  | 4 ++--
 .../VolatilePageMemoryStorageEngineConfigurationSchema.java       | 4 ++--
 .../internal/storage/pagememory/index/IndexPageIoModule.java      | 4 ++--
 .../ignite/internal/storage/pagememory/index/IndexPageTypes.java  | 2 +-
 .../internal/storage/pagememory/index/freelist/IndexColumns.java  | 2 +-
 .../storage/pagememory/index/freelist/IndexColumnsFreeList.java   | 2 +-
 .../storage/pagememory/index/freelist/ReadIndexColumnsValue.java  | 4 ++--
 .../storage/pagememory/index/freelist/io/IndexColumnsDataIo.java  | 4 ++--
 .../internal/storage/pagememory/index/hash/HashIndexRow.java      | 4 ++--
 .../internal/storage/pagememory/index/hash/HashIndexRowKey.java   | 4 ++--
 .../internal/storage/pagememory/index/hash/HashIndexTree.java     | 4 ++--
 .../pagememory/index/hash/InsertHashIndexRowInvokeClosure.java    | 2 +-
 .../storage/pagememory/index/hash/PageMemoryHashIndexStorage.java | 2 +-
 .../pagememory/index/hash/RemoveHashIndexRowInvokeClosure.java    | 2 +-
 .../storage/pagememory/index/hash/io/HashIndexTreeInnerIo.java    | 2 +-
 .../storage/pagememory/index/hash/io/HashIndexTreeIo.java         | 4 ++--
 .../storage/pagememory/index/hash/io/HashIndexTreeLeafIo.java     | 2 +-
 .../storage/pagememory/index/hash/io/HashIndexTreeMetaIo.java     | 4 ++--
 .../ignite/internal/storage/pagememory/index/meta/IndexMeta.java  | 4 ++--
 .../internal/storage/pagememory/index/meta/IndexMetaTree.java     | 4 ++--
 .../storage/pagememory/index/meta/io/IndexMetaInnerIo.java        | 4 ++--
 .../internal/storage/pagememory/index/meta/io/IndexMetaIo.java    | 4 ++--
 .../storage/pagememory/index/meta/io/IndexMetaLeafIo.java         | 4 ++--
 .../storage/pagememory/index/meta/io/IndexMetaTreeMetaIo.java     | 4 ++--
 .../pagememory/mv/AbstractPageMemoryMvPartitionStorage.java       | 4 ++--
 .../ignite/internal/storage/pagememory/mv/HybridTimestamps.java   | 4 ++--
 .../ignite/internal/storage/pagememory/mv/MvPageIoModule.java     | 4 ++--
 .../pagememory/mv/PersistentPageMemoryMvPartitionStorage.java     | 4 ++--
 .../ignite/internal/storage/pagememory/mv/ReadRowVersion.java     | 4 ++--
 .../internal/storage/pagememory/mv/ReadRowVersionValue.java       | 4 ++--
 .../apache/ignite/internal/storage/pagememory/mv/RowVersion.java  | 4 ++--
 .../ignite/internal/storage/pagememory/mv/RowVersionFreeList.java | 4 ++--
 .../storage/pagememory/mv/ScanVersionChainByTimestamp.java        | 4 ++--
 .../ignite/internal/storage/pagememory/mv/VersionChain.java       | 4 ++--
 .../ignite/internal/storage/pagememory/mv/VersionChainKey.java    | 4 ++--
 .../ignite/internal/storage/pagememory/mv/VersionChainTree.java   | 4 ++--
 .../pagememory/mv/VolatilePageMemoryMvPartitionStorage.java       | 4 ++--
 .../internal/storage/pagememory/mv/io/RowVersionDataIo.java       | 4 ++--
 .../internal/storage/pagememory/mv/io/VersionChainInnerIo.java    | 4 ++--
 .../ignite/internal/storage/pagememory/mv/io/VersionChainIo.java  | 4 ++--
 .../internal/storage/pagememory/mv/io/VersionChainLeafIo.java     | 4 ++--
 .../internal/storage/pagememory/mv/io/VersionChainMetaIo.java     | 4 ++--
 .../internal/storage/pagememory/util/TreeCursorAdapter.java       | 2 +-
 .../storage/pagememory/PersistentPageMemoryDataRegionTest.java    | 4 ++--
 .../configuration/PageMemoryDataRegionValidatorImplTest.java      | 4 ++--
 .../index/PersistentPageMemoryHashIndexStorageTest.java           | 2 +-
 .../pagememory/index/VolatilePageMemoryHashIndexStorageTest.java  | 2 +-
 .../pagememory/mv/AbstractPageMemoryMvPartitionStorageTest.java   | 4 ++--
 .../pagememory/mv/PersistentPageMemoryMvPartitionStorageTest.java | 4 ++--
 .../pagememory/mv/VolatilePageMemoryMvPartitionStorageTest.java   | 4 ++--
 .../apache/ignite/internal/storage/rocksdb/ColumnFamilyUtils.java | 2 +-
 .../org/apache/ignite/internal/storage/rocksdb/HashIndices.java   | 2 +-
 .../apache/ignite/internal/storage/rocksdb/RocksDbDataRegion.java | 4 ++--
 .../ignite/internal/storage/rocksdb/RocksDbDataStorageModule.java | 4 ++--
 .../ignite/internal/storage/rocksdb/RocksDbMetaStorage.java       | 2 +-
 .../internal/storage/rocksdb/RocksDbMvPartitionStorage.java       | 2 +-
 .../ignite/internal/storage/rocksdb/RocksDbStorageEngine.java     | 4 ++--
 .../ignite/internal/storage/rocksdb/RocksDbTableStorage.java      | 4 ++--
 .../storage/rocksdb/configuration/RocksDbDataRegionName.java      | 4 ++--
 .../rocksdb/configuration/RocksDbDataRegionValidatorImpl.java     | 4 ++--
 .../RocksDbStorageEngineDistributedConfigurationModule.java       | 4 ++--
 .../schema/RocksDbDataRegionConfigurationSchema.java              | 4 ++--
 .../schema/RocksDbDataStorageConfigurationSchema.java             | 4 ++--
 .../schema/RocksDbStorageEngineConfigurationSchema.java           | 4 ++--
 .../internal/storage/rocksdb/index/RocksDbHashIndexStorage.java   | 2 +-
 .../internal/storage/rocksdb/RocksDbMvPartitionStorageTest.java   | 2 +-
 .../internal/storage/rocksdb/RocksDbMvTableStorageTest.java       | 2 +-
 .../ignite/internal/storage/rocksdb/RocksDbStorageEngineTest.java | 2 +-
 .../rocksdb/configuration/RocksDbDataRegionValidatorImplTest.java | 4 ++--
 .../storage/rocksdb/index/RocksDbHashIndexStorageTest.java        | 2 +-
 .../org/apache/ignite/distributed/ItInternalTableScanTest.java    | 4 ++--
 .../org/apache/ignite/distributed/ItTablePersistenceTest.java     | 4 ++--
 .../apache/ignite/distributed/ItTxDistributedTestSingleNode.java  | 4 ++--
 .../distributed/ItTxDistributedTestSingleNodeCollocated.java      | 4 ++--
 .../distributed/ItTxDistributedTestThreeNodesThreeReplicas.java   | 4 ++--
 .../ItTxDistributedTestThreeNodesThreeReplicasCollocated.java     | 4 ++--
 .../java/org/apache/ignite/internal/table/ItColocationTest.java   | 4 ++--
 .../src/main/java/org/apache/ignite/binary/BinaryObjects.java     | 4 ++--
 .../src/main/java/org/apache/ignite/binary/package-info.java      | 4 ++--
 .../configuration/TableDistributedConfigurationModule.java        | 4 ++--
 .../apache/ignite/internal/schema/marshaller/TupleMarshaller.java | 4 ++--
 .../internal/schema/marshaller/TupleMarshallerException.java      | 4 ++--
 .../ignite/internal/schema/marshaller/TupleMarshallerImpl.java    | 4 ++--
 .../org/apache/ignite/internal/table/AbstractRowTupleAdapter.java | 4 ++--
 .../java/org/apache/ignite/internal/table/AbstractTableView.java  | 4 ++--
 .../org/apache/ignite/internal/table/IgniteTablesInternal.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/table/InternalTable.java | 4 ++--
 .../org/apache/ignite/internal/table/KeyValueBinaryViewImpl.java  | 4 ++--
 .../java/org/apache/ignite/internal/table/KeyValueViewImpl.java   | 4 ++--
 .../org/apache/ignite/internal/table/MutableRowTupleAdapter.java  | 4 ++--
 .../org/apache/ignite/internal/table/RecordBinaryViewImpl.java    | 4 ++--
 .../java/org/apache/ignite/internal/table/RecordViewImpl.java     | 4 ++--
 .../src/main/java/org/apache/ignite/internal/table/TableImpl.java | 4 ++--
 .../src/main/java/org/apache/ignite/internal/table/TableRow.java  | 4 ++--
 .../apache/ignite/internal/table/distributed/TableManager.java    | 4 ++--
 .../ignite/internal/table/distributed/TableTxManagerImpl.java     | 4 ++--
 .../ignite/internal/table/distributed/command/CommandUtils.java   | 4 ++--
 .../internal/table/distributed/command/DeleteAllCommand.java      | 4 ++--
 .../ignite/internal/table/distributed/command/DeleteCommand.java  | 4 ++--
 .../internal/table/distributed/command/DeleteExactAllCommand.java | 4 ++--
 .../internal/table/distributed/command/DeleteExactCommand.java    | 4 ++--
 .../internal/table/distributed/command/FinishTxCommand.java       | 4 ++--
 .../ignite/internal/table/distributed/command/GetAllCommand.java  | 4 ++--
 .../internal/table/distributed/command/GetAndDeleteCommand.java   | 4 ++--
 .../internal/table/distributed/command/GetAndReplaceCommand.java  | 4 ++--
 .../internal/table/distributed/command/GetAndUpsertCommand.java   | 4 ++--
 .../ignite/internal/table/distributed/command/GetCommand.java     | 4 ++--
 .../internal/table/distributed/command/InsertAllCommand.java      | 4 ++--
 .../ignite/internal/table/distributed/command/InsertCommand.java  | 4 ++--
 .../internal/table/distributed/command/MultiKeyCommand.java       | 4 ++--
 .../ignite/internal/table/distributed/command/ReplaceCommand.java | 4 ++--
 .../internal/table/distributed/command/ReplaceIfExistCommand.java | 4 ++--
 .../internal/table/distributed/command/SingleKeyCommand.java      | 4 ++--
 .../internal/table/distributed/command/TransactionalCommand.java  | 4 ++--
 .../internal/table/distributed/command/UpsertAllCommand.java      | 4 ++--
 .../ignite/internal/table/distributed/command/UpsertCommand.java  | 4 ++--
 .../table/distributed/command/response/MultiRowsResponse.java     | 4 ++--
 .../table/distributed/command/response/SingleRowResponse.java     | 4 ++--
 .../internal/table/distributed/command/scan/ScanCloseCommand.java | 4 ++--
 .../internal/table/distributed/command/scan/ScanInitCommand.java  | 4 ++--
 .../table/distributed/command/scan/ScanRetrieveBatchCommand.java  | 4 ++--
 .../ignite/internal/table/distributed/raft/PartitionListener.java | 4 ++--
 .../table/distributed/raft/RebalanceRaftGroupEventsListener.java  | 4 ++--
 .../distributed/raft/snapshot/InitPartitionSnapshotReader.java    | 2 +-
 .../internal/table/distributed/raft/snapshot/PartitionAccess.java | 2 +-
 .../table/distributed/raft/snapshot/PartitionSnapshotStorage.java | 2 +-
 .../raft/snapshot/PartitionSnapshotStorageFactory.java            | 2 +-
 .../table/distributed/raft/snapshot/PartitionSnapshotWriter.java  | 2 +-
 .../internal/table/distributed/storage/InternalTableImpl.java     | 4 ++--
 .../internal/table/distributed/storage/VersionedRowStore.java     | 4 ++--
 .../java/org/apache/ignite/internal/table/event/TableEvent.java   | 4 ++--
 .../apache/ignite/internal/table/event/TableEventParameters.java  | 4 ++--
 .../org/apache/ignite/internal/table/message/HasDataRequest.java  | 4 ++--
 .../org/apache/ignite/internal/table/message/HasDataResponse.java | 4 ++--
 .../apache/ignite/internal/table/message/TableMessageGroup.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/table/package-info.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/utils/RebalanceUtil.java | 4 ++--
 .../internal/benchmarks/TupleMarshallerFixlenOnlyBenchmark.java   | 4 ++--
 .../internal/benchmarks/TupleMarshallerVarlenOnlyBenchmark.java   | 4 ++--
 .../configuration/TableDistributedConfigurationModuleTest.java    | 4 ++--
 .../ignite/internal/table/ColocationHashCalculationTest.java      | 4 ++--
 .../src/test/java/org/apache/ignite/internal/table/Example.java   | 4 ++--
 .../org/apache/ignite/internal/table/InteropOperationsTest.java   | 4 ++--
 .../ignite/internal/table/KeyValueBinaryViewOperationsTest.java   | 4 ++--
 .../internal/table/KeyValueViewOperationsSimpleSchemaTest.java    | 4 ++--
 .../apache/ignite/internal/table/KeyValueViewOperationsTest.java  | 4 ++--
 .../apache/ignite/internal/table/MessagingServiceTestUtils.java   | 2 +-
 .../apache/ignite/internal/table/MutableRowTupleAdapterTest.java  | 4 ++--
 .../ignite/internal/table/RecordBinaryViewOperationsTest.java     | 4 ++--
 .../apache/ignite/internal/table/RecordViewOperationsTest.java    | 4 ++--
 .../org/apache/ignite/internal/table/SchemaValidationTest.java    | 4 ++--
 .../java/org/apache/ignite/internal/table/TxAbstractTest.java     | 4 ++--
 .../test/java/org/apache/ignite/internal/table/TxLocalTest.java   | 4 ++--
 .../ignite/internal/table/distributed/TableManagerTest.java       | 4 ++--
 .../table/distributed/raft/PartitionCommandListenerTest.java      | 4 ++--
 .../distributed/raft/RebalanceRaftGroupEventsListenerTest.java    | 4 ++--
 .../apache/ignite/internal/table/impl/DummyInternalTableImpl.java | 4 ++--
 .../apache/ignite/internal/table/impl/DummySchemaManagerImpl.java | 4 ++--
 .../org/apache/ignite/internal/table/impl/TestTupleBuilder.java   | 4 ++--
 .../ignite/internal/table/type/NumericTypesSerializerTest.java    | 4 ++--
 .../src/test/java/org/apache/ignite/table/TupleImplTest.java      | 4 ++--
 .../java/org/apache/ignite/internal/tx/InternalTransaction.java   | 4 ++--
 .../main/java/org/apache/ignite/internal/tx/LockException.java    | 4 ++--
 .../src/main/java/org/apache/ignite/internal/tx/LockManager.java  | 4 ++--
 .../src/main/java/org/apache/ignite/internal/tx/Timestamp.java    | 4 ++--
 .../src/main/java/org/apache/ignite/internal/tx/TxManager.java    | 4 ++--
 .../src/main/java/org/apache/ignite/internal/tx/TxMeta.java       | 4 ++--
 .../src/main/java/org/apache/ignite/internal/tx/TxState.java      | 4 ++--
 .../src/main/java/org/apache/ignite/internal/tx/Waiter.java       | 4 ++--
 .../java/org/apache/ignite/internal/tx/impl/HeapLockManager.java  | 4 ++--
 .../apache/ignite/internal/tx/impl/IgniteTransactionsImpl.java    | 4 ++--
 .../java/org/apache/ignite/internal/tx/impl/TransactionImpl.java  | 4 ++--
 .../java/org/apache/ignite/internal/tx/impl/TxManagerImpl.java    | 4 ++--
 .../org/apache/ignite/internal/tx/message/TxFinishRequest.java    | 6 +++---
 .../org/apache/ignite/internal/tx/message/TxFinishResponse.java   | 6 +++---
 .../org/apache/ignite/internal/tx/message/TxMessageGroup.java     | 4 ++--
 .../apache/ignite/internal/tx/storage/state/TxStateStorage.java   | 4 ++--
 .../internal/tx/storage/state/rocksdb/TxStateRocksDbStorage.java  | 4 ++--
 .../org/apache/ignite/internal/tx/AbstractLockManagerTest.java    | 4 ++--
 .../java/org/apache/ignite/internal/tx/HeapLockManagerTest.java   | 4 ++--
 .../test/java/org/apache/ignite/internal/tx/TxManagerTest.java    | 4 ++--
 .../ignite/internal/tx/storage/state/TxStateStorageTest.java      | 4 ++--
 .../persistence/ItPersistencePropertiesVaultServiceTest.java      | 4 ++--
 .../internal/vault/persistence/ItPersistentVaultServiceTest.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/vault/VaultEntry.java    | 4 ++--
 .../main/java/org/apache/ignite/internal/vault/VaultManager.java  | 4 ++--
 .../main/java/org/apache/ignite/internal/vault/VaultService.java  | 4 ++--
 .../ignite/internal/vault/persistence/PersistentVaultService.java | 4 ++--
 .../java/org/apache/ignite/internal/vault/VaultManagerTest.java   | 4 ++--
 .../java/org/apache/ignite/internal/vault/VaultServiceTest.java   | 4 ++--
 .../ignite/internal/vault/inmemory/InMemoryVaultServiceTest.java  | 4 ++--
 .../ignite/internal/vault/inmemory/InMemoryVaultService.java      | 2 +-
 settings.gradle                                                   | 4 ++--
 3194 files changed, 6685 insertions(+), 6683 deletions(-)

diff --git a/check-rules/LICENSE.txt b/check-rules/LICENSE.txt
index f974c9ac4f..d5031011a7 100644
--- a/check-rules/LICENSE.txt
+++ b/check-rules/LICENSE.txt
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/docs/assets/css/docs.scss b/docs/assets/css/docs.scss
index 2e05a98f90..6e273c19ad 100644
--- a/docs/assets/css/docs.scss
+++ b/docs/assets/css/docs.scss
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/docs/assets/css/styles.scss b/docs/assets/css/styles.scss
index f23e7046cf..4da6f4af60 100644
--- a/docs/assets/css/styles.scss
+++ b/docs/assets/css/styles.scss
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/AbstractExamplesTest.java b/examples/src/integrationTest/java/org/apache/ignite/example/AbstractExamplesTest.java
index 1f4db33da6..bfee9463ab 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/AbstractExamplesTest.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/AbstractExamplesTest.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/ExampleTestUtils.java b/examples/src/integrationTest/java/org/apache/ignite/example/ExampleTestUtils.java
index b2ce8927fe..55f3256a8b 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/ExampleTestUtils.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/ExampleTestUtils.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/sql/ItSqlExamplesTest.java b/examples/src/integrationTest/java/org/apache/ignite/example/sql/ItSqlExamplesTest.java
index 1dd8d32817..7d47c049ad 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/sql/ItSqlExamplesTest.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/sql/ItSqlExamplesTest.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItPageMemoryStorageExampleTest.java b/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItPageMemoryStorageExampleTest.java
index a1299cd2f5..a1a838af8f 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItPageMemoryStorageExampleTest.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItPageMemoryStorageExampleTest.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItRocksdbStorageExampleTest.java b/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItRocksdbStorageExampleTest.java
index ffc1f483e4..a9fc15b2d6 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItRocksdbStorageExampleTest.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/storage/ItRocksdbStorageExampleTest.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/table/ItTableExamplesTest.java b/examples/src/integrationTest/java/org/apache/ignite/example/table/ItTableExamplesTest.java
index 36267c91df..e0959ea1d2 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/table/ItTableExamplesTest.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/table/ItTableExamplesTest.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/integrationTest/java/org/apache/ignite/example/tx/ItTransactionsExamplesTest.java b/examples/src/integrationTest/java/org/apache/ignite/example/tx/ItTransactionsExamplesTest.java
index a845affa0c..58a2f895c8 100644
--- a/examples/src/integrationTest/java/org/apache/ignite/example/tx/ItTransactionsExamplesTest.java
+++ b/examples/src/integrationTest/java/org/apache/ignite/example/tx/ItTransactionsExamplesTest.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/sql/SqlApiExample.java b/examples/src/main/java/org/apache/ignite/example/sql/SqlApiExample.java
index 502de66e66..a5ad4cfb3c 100644
--- a/examples/src/main/java/org/apache/ignite/example/sql/SqlApiExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/sql/SqlApiExample.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/sql/jdbc/SqlJdbcExample.java b/examples/src/main/java/org/apache/ignite/example/sql/jdbc/SqlJdbcExample.java
index a82a81c120..51db41fdba 100644
--- a/examples/src/main/java/org/apache/ignite/example/sql/jdbc/SqlJdbcExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/sql/jdbc/SqlJdbcExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/storage/PersistentPageMemoryStorageExample.java b/examples/src/main/java/org/apache/ignite/example/storage/PersistentPageMemoryStorageExample.java
index a975762d08..0e89447fe3 100644
--- a/examples/src/main/java/org/apache/ignite/example/storage/PersistentPageMemoryStorageExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/storage/PersistentPageMemoryStorageExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/storage/RocksDbStorageExample.java b/examples/src/main/java/org/apache/ignite/example/storage/RocksDbStorageExample.java
index 83c5172362..8536cc3b51 100644
--- a/examples/src/main/java/org/apache/ignite/example/storage/RocksDbStorageExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/storage/RocksDbStorageExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/storage/StorageEngineExample.java b/examples/src/main/java/org/apache/ignite/example/storage/StorageEngineExample.java
index 51c0639f81..9226f87906 100644
--- a/examples/src/main/java/org/apache/ignite/example/storage/StorageEngineExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/storage/StorageEngineExample.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/storage/VolatilePageMemoryStorageExample.java b/examples/src/main/java/org/apache/ignite/example/storage/VolatilePageMemoryStorageExample.java
index 1c4c5d4e71..1848086317 100644
--- a/examples/src/main/java/org/apache/ignite/example/storage/VolatilePageMemoryStorageExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/storage/VolatilePageMemoryStorageExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewExample.java b/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewExample.java
index a33bb4d7d7..dcf8da03e0 100644
--- a/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewPojoExample.java b/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewPojoExample.java
index e217d3048a..e9b124e532 100644
--- a/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewPojoExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/table/KeyValueViewPojoExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/table/RecordViewExample.java b/examples/src/main/java/org/apache/ignite/example/table/RecordViewExample.java
index 12cba8e3a3..28e987b25d 100644
--- a/examples/src/main/java/org/apache/ignite/example/table/RecordViewExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/table/RecordViewExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/table/RecordViewPojoExample.java b/examples/src/main/java/org/apache/ignite/example/table/RecordViewPojoExample.java
index 78bdd157b5..be606c3b52 100644
--- a/examples/src/main/java/org/apache/ignite/example/table/RecordViewPojoExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/table/RecordViewPojoExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/examples/src/main/java/org/apache/ignite/example/tx/TransactionsExample.java b/examples/src/main/java/org/apache/ignite/example/tx/TransactionsExample.java
index 0200895aae..c6ee4b4739 100644
--- a/examples/src/main/java/org/apache/ignite/example/tx/TransactionsExample.java
+++ b/examples/src/main/java/org/apache/ignite/example/tx/TransactionsExample.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/AffinityUtils.java b/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/AffinityUtils.java
index 58dbbc4eeb..d0c1335bae 100644
--- a/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/AffinityUtils.java
+++ b/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/AffinityUtils.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunction.java b/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunction.java
index 0a60caa22a..91adae62fd 100644
--- a/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunction.java
+++ b/modules/affinity/src/main/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/AffinityServiceTest.java b/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/AffinityServiceTest.java
index bd1641e3ce..d93a3663f9 100644
--- a/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/AffinityServiceTest.java
+++ b/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/AffinityServiceTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunctionTest.java b/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunctionTest.java
index 23ffaf7d93..6866d9a0fb 100644
--- a/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunctionTest.java
+++ b/modules/affinity/src/test/java/org/apache/ignite/internal/affinity/RendezvousAffinityFunctionTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/Ignite.java b/modules/api/src/main/java/org/apache/ignite/Ignite.java
index ad0a1434b6..f01f8779da 100644
--- a/modules/api/src/main/java/org/apache/ignite/Ignite.java
+++ b/modules/api/src/main/java/org/apache/ignite/Ignite.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/Ignition.java b/modules/api/src/main/java/org/apache/ignite/Ignition.java
index 56e7c614a2..b389303a47 100644
--- a/modules/api/src/main/java/org/apache/ignite/Ignition.java
+++ b/modules/api/src/main/java/org/apache/ignite/Ignition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/IgnitionManager.java b/modules/api/src/main/java/org/apache/ignite/IgnitionManager.java
index ec02f92b32..b34e0182f7 100644
--- a/modules/api/src/main/java/org/apache/ignite/IgnitionManager.java
+++ b/modules/api/src/main/java/org/apache/ignite/IgnitionManager.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/binary/BinaryObject.java b/modules/api/src/main/java/org/apache/ignite/binary/BinaryObject.java
index 3eee5ff2e5..e6165113b5 100644
--- a/modules/api/src/main/java/org/apache/ignite/binary/BinaryObject.java
+++ b/modules/api/src/main/java/org/apache/ignite/binary/BinaryObject.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/binary/package-info.java b/modules/api/src/main/java/org/apache/ignite/binary/package-info.java
index c3375ccf23..ed3bfcb675 100644
--- a/modules/api/src/main/java/org/apache/ignite/binary/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/binary/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/compute/ComputeJob.java b/modules/api/src/main/java/org/apache/ignite/compute/ComputeJob.java
index 4ce517ad51..6ca13b49d5 100644
--- a/modules/api/src/main/java/org/apache/ignite/compute/ComputeJob.java
+++ b/modules/api/src/main/java/org/apache/ignite/compute/ComputeJob.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/compute/IgniteCompute.java b/modules/api/src/main/java/org/apache/ignite/compute/IgniteCompute.java
index 9005f9f614..930b876aac 100644
--- a/modules/api/src/main/java/org/apache/ignite/compute/IgniteCompute.java
+++ b/modules/api/src/main/java/org/apache/ignite/compute/IgniteCompute.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/compute/JobExecutionContext.java b/modules/api/src/main/java/org/apache/ignite/compute/JobExecutionContext.java
index eade5e1884..6ac66ad8a4 100644
--- a/modules/api/src/main/java/org/apache/ignite/compute/JobExecutionContext.java
+++ b/modules/api/src/main/java/org/apache/ignite/compute/JobExecutionContext.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/ClientConnectorConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/ClientConnectorConfigurationSchema.java
index cb774ec5e9..91ca20931a 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/ClientConnectorConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/ClientConnectorConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/package-info.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/package-info.java
index c845912fd6..0b9bfb5b27 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/clientconnector/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/compute/ComputeConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/compute/ComputeConfigurationSchema.java
index 604cd534e9..e6839bb197 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/compute/ComputeConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/compute/ComputeConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ClusterMembershipConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ClusterMembershipConfigurationSchema.java
index 8baaceec12..4cbf806a7b 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ClusterMembershipConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ClusterMembershipConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/InboundConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/InboundConfigurationSchema.java
index 95c536f0ab..0b8467ea84 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/InboundConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/InboundConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NetworkConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NetworkConfigurationSchema.java
index 69679a64e8..bf082f8e7f 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NetworkConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NetworkConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderConfigurationSchema.java
index 7647cad4ba..618f8ea0b5 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderType.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderType.java
index c8c4e27498..05cf9a292f 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderType.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/NodeFinderType.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/OutboundConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/OutboundConfigurationSchema.java
index dd0d591b82..07952a86bf 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/OutboundConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/OutboundConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ScaleCubeConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ScaleCubeConfigurationSchema.java
index 8b23c21594..080de4bb0c 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ScaleCubeConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/ScaleCubeConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/package-info.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/package-info.java
index 5e482fa1d3..f39ea4b04f 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/network/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/RestConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/RestConfigurationSchema.java
index 39bd3691bf..849c51ea50 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/RestConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/RestConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/package-info.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/package-info.java
index c294a49a59..034f8dfa85 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/rest/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/DataStorageConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/DataStorageConfigurationSchema.java
index 5aa80e9d63..7b3f484286 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/DataStorageConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/DataStorageConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/ExistingDataStorage.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/ExistingDataStorage.java
index 572491db11..0ae3d5563d 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/ExistingDataStorage.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/ExistingDataStorage.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/KnownDataStorage.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/KnownDataStorage.java
index bf9cd42c8b..9c9dda421f 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/KnownDataStorage.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/KnownDataStorage.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/UnknownDataStorageConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/UnknownDataStorageConfigurationSchema.java
index 54f742d4e6..69b7a14198 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/UnknownDataStorageConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/store/UnknownDataStorageConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnConfigurationSchema.java
index 5d47a44f24..5b67032112 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnDefaultConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnDefaultConfigurationSchema.java
index ab884f7f02..eeb466c252 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnDefaultConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnDefaultConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeConfigurationSchema.java
index f0edbe7aa0..9c0d79e629 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeValidator.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeValidator.java
index 0893e07692..7b34a0c327 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeValidator.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ColumnTypeValidator.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ConstantValueDefaultConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ConstantValueDefaultConfigurationSchema.java
index 50d1655fdc..636d0a4f59 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ConstantValueDefaultConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/ConstantValueDefaultConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/EntryCountBudgetConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/EntryCountBudgetConfigurationSchema.java
index 1483affc0e..29ba23126d 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/EntryCountBudgetConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/EntryCountBudgetConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/FunctionCallDefaultConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/FunctionCallDefaultConfigurationSchema.java
index 5e8c8f7d1c..bc0d2f1f89 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/FunctionCallDefaultConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/FunctionCallDefaultConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/HashIndexConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/HashIndexConfigurationSchema.java
index ce1a1e5c29..5ccd1ade36 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/HashIndexConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/HashIndexConfigurationSchema.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/IndexColumnConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/IndexColumnConfigurationSchema.java
index 846c59c3a2..8f9de8b72e 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/IndexColumnConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/IndexColumnConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/LogStorageBudgetConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/LogStorageBudgetConfigurationSchema.java
index 0461b8bf02..fe71ba61b7 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/LogStorageBudgetConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/LogStorageBudgetConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/NullValueDefaultConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/NullValueDefaultConfigurationSchema.java
index 234782d3f7..200d5dbaad 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/NullValueDefaultConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/NullValueDefaultConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/PrimaryKeyConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/PrimaryKeyConfigurationSchema.java
index 414874c0f8..f2f1c285c9 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/PrimaryKeyConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/PrimaryKeyConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/SortedIndexConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/SortedIndexConfigurationSchema.java
index 328692af15..863eb380c1 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/SortedIndexConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/SortedIndexConfigurationSchema.java
@@ -4,7 +4,7 @@
  * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableConfigurationSchema.java
index b943c207e4..b74fe1006f 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableIndexConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableIndexConfigurationSchema.java
index ae9043f064..d08fdac13c 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableIndexConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableIndexConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableValidator.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableValidator.java
index dea0db195c..9a9ded14bb 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableValidator.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TableValidator.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TablesConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TablesConfigurationSchema.java
index fbc928e703..3ce5460336 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TablesConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/TablesConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/UnlimitedBudgetConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/UnlimitedBudgetConfigurationSchema.java
index 0866baf6ae..09a6c9a7ca 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/UnlimitedBudgetConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/UnlimitedBudgetConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/VolatileRaftConfigurationSchema.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/VolatileRaftConfigurationSchema.java
index 9eb32eac07..63d547ed37 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/VolatileRaftConfigurationSchema.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/VolatileRaftConfigurationSchema.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/package-info.java b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/package-info.java
index 4c1335cb8d..913d7dec29 100644
--- a/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/configuration/schemas/table/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/internal/lang/IgniteExceptionUtils.java b/modules/api/src/main/java/org/apache/ignite/internal/lang/IgniteExceptionUtils.java
index e77cde70a2..2ff18f7e02 100644
--- a/modules/api/src/main/java/org/apache/ignite/internal/lang/IgniteExceptionUtils.java
+++ b/modules/api/src/main/java/org/apache/ignite/internal/lang/IgniteExceptionUtils.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/internal/sql/ResultSetImpl.java b/modules/api/src/main/java/org/apache/ignite/internal/sql/ResultSetImpl.java
index 2eaef7a2d2..af7ad4e6ad 100644
--- a/modules/api/src/main/java/org/apache/ignite/internal/sql/ResultSetImpl.java
+++ b/modules/api/src/main/java/org/apache/ignite/internal/sql/ResultSetImpl.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/internal/sql/SqlColumnTypeConverter.java b/modules/api/src/main/java/org/apache/ignite/internal/sql/SqlColumnTypeConverter.java
index dadf62d4db..b10b4d06f4 100644
--- a/modules/api/src/main/java/org/apache/ignite/internal/sql/SqlColumnTypeConverter.java
+++ b/modules/api/src/main/java/org/apache/ignite/internal/sql/SqlColumnTypeConverter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/ColumnAlreadyExistsException.java b/modules/api/src/main/java/org/apache/ignite/lang/ColumnAlreadyExistsException.java
index 9153267459..a52986d9d6 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/ColumnAlreadyExistsException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/ColumnAlreadyExistsException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/ColumnNotFoundException.java b/modules/api/src/main/java/org/apache/ignite/lang/ColumnNotFoundException.java
index 42509a4ab6..8522725b68 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/ColumnNotFoundException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/ColumnNotFoundException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/IgniteCheckedException.java b/modules/api/src/main/java/org/apache/ignite/lang/IgniteCheckedException.java
index 80bc7f8a35..be2e18ff0b 100755
--- a/modules/api/src/main/java/org/apache/ignite/lang/IgniteCheckedException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/IgniteCheckedException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/IgniteException.java b/modules/api/src/main/java/org/apache/ignite/lang/IgniteException.java
index 59497c2613..d2e737f8e0 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/IgniteException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/IgniteException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/IndexAlreadyExistsException.java b/modules/api/src/main/java/org/apache/ignite/lang/IndexAlreadyExistsException.java
index 28b39c6d49..2b32391036 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/IndexAlreadyExistsException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/IndexAlreadyExistsException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/IndexNotFoundException.java b/modules/api/src/main/java/org/apache/ignite/lang/IndexNotFoundException.java
index 343e42ec91..2ba00f0aa8 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/IndexNotFoundException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/IndexNotFoundException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/MarshallerException.java b/modules/api/src/main/java/org/apache/ignite/lang/MarshallerException.java
index b5be90a223..5ec3140b7f 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/MarshallerException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/MarshallerException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/NullableValue.java b/modules/api/src/main/java/org/apache/ignite/lang/NullableValue.java
index e6c5893392..483abdd3fa 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/NullableValue.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/NullableValue.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/TableAlreadyExistsException.java b/modules/api/src/main/java/org/apache/ignite/lang/TableAlreadyExistsException.java
index 6cbf28c5a9..8845397375 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/TableAlreadyExistsException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/TableAlreadyExistsException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/TableNotFoundException.java b/modules/api/src/main/java/org/apache/ignite/lang/TableNotFoundException.java
index c81b91edd9..8a92ba6e31 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/TableNotFoundException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/TableNotFoundException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/UnexpectedNullValueException.java b/modules/api/src/main/java/org/apache/ignite/lang/UnexpectedNullValueException.java
index 25c36f95dd..b657a69091 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/UnexpectedNullValueException.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/UnexpectedNullValueException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/lang/package-info.java b/modules/api/src/main/java/org/apache/ignite/lang/package-info.java
index fa1e94b076..8e3e3ee364 100644
--- a/modules/api/src/main/java/org/apache/ignite/lang/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/lang/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/network/ClusterNode.java b/modules/api/src/main/java/org/apache/ignite/network/ClusterNode.java
index f9e8088602..d0bc6d7a9a 100644
--- a/modules/api/src/main/java/org/apache/ignite/network/ClusterNode.java
+++ b/modules/api/src/main/java/org/apache/ignite/network/ClusterNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/network/NetworkAddress.java b/modules/api/src/main/java/org/apache/ignite/network/NetworkAddress.java
index fdeff7ac8a..a90877952b 100644
--- a/modules/api/src/main/java/org/apache/ignite/network/NetworkAddress.java
+++ b/modules/api/src/main/java/org/apache/ignite/network/NetworkAddress.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/network/TopologyEventHandler.java b/modules/api/src/main/java/org/apache/ignite/network/TopologyEventHandler.java
index debf8a8b95..9a4f89906d 100644
--- a/modules/api/src/main/java/org/apache/ignite/network/TopologyEventHandler.java
+++ b/modules/api/src/main/java/org/apache/ignite/network/TopologyEventHandler.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/network/TopologyService.java b/modules/api/src/main/java/org/apache/ignite/network/TopologyService.java
index 482d1d0be3..bd6b442276 100644
--- a/modules/api/src/main/java/org/apache/ignite/network/TopologyService.java
+++ b/modules/api/src/main/java/org/apache/ignite/network/TopologyService.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/package-info.java b/modules/api/src/main/java/org/apache/ignite/package-info.java
index 70dac2fe82..82741b7186 100644
--- a/modules/api/src/main/java/org/apache/ignite/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnDefinition.java
index b4737d26fb..0d1670a481 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnType.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnType.java
index 5be9f736b1..9efc5200cf 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnType.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/ColumnType.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueDefinition.java
index 6705e06b7b..852f68cc10 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueGenerators.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueGenerators.java
index efb46090f6..56add2f3a6 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueGenerators.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/DefaultValueGenerators.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/PrimaryKeyDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/PrimaryKeyDefinition.java
index 9554f5ffbb..ab98023f16 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/PrimaryKeyDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/PrimaryKeyDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/SchemaObject.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/SchemaObject.java
index 9ca8920c99..ab517286de 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/SchemaObject.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/SchemaObject.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/TableDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/TableDefinition.java
index a9774c7d9e..867c5ffbb5 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/TableDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/TableDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/ColumnarIndexDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/ColumnarIndexDefinition.java
index 669787e031..ec2819c975 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/ColumnarIndexDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/ColumnarIndexDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/HashIndexDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/HashIndexDefinition.java
index aac94aa8b9..9d17d582c0 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/HashIndexDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/HashIndexDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexColumnDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexColumnDefinition.java
index 14fe672d67..b7127f5494 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexColumnDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexColumnDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexDefinition.java
index fd69267c3d..6421f04934 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/IndexDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortOrder.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortOrder.java
index 47843cb4c2..1636ee8c20 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortOrder.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortOrder.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexColumnDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexColumnDefinition.java
index d897b9dc23..32837b3015 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexColumnDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexColumnDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexDefinition.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexDefinition.java
index 4ab099ec22..fb7c4ceba1 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexDefinition.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/SortedIndexDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/package-info.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/package-info.java
index fde4f7eb41..1f2dd3f4e2 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/index/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/index/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/schema/definition/package-info.java b/modules/api/src/main/java/org/apache/ignite/schema/definition/package-info.java
index 3a4c042981..17a0ede46c 100644
--- a/modules/api/src/main/java/org/apache/ignite/schema/definition/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/schema/definition/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/BatchedArguments.java b/modules/api/src/main/java/org/apache/ignite/sql/BatchedArguments.java
index e991c49dba..a8046bfe35 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/BatchedArguments.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/BatchedArguments.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/ColumnMetadata.java b/modules/api/src/main/java/org/apache/ignite/sql/ColumnMetadata.java
index 06af352412..9b04e09993 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/ColumnMetadata.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/ColumnMetadata.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/CursorClosedException.java b/modules/api/src/main/java/org/apache/ignite/sql/CursorClosedException.java
index 8e1e46d84c..65958fb138 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/CursorClosedException.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/CursorClosedException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/IgniteSql.java b/modules/api/src/main/java/org/apache/ignite/sql/IgniteSql.java
index 1bb5184e63..179bb1dbda 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/IgniteSql.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/IgniteSql.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/NoRowSetExpectedException.java b/modules/api/src/main/java/org/apache/ignite/sql/NoRowSetExpectedException.java
index 6813b12813..1360ddbf13 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/NoRowSetExpectedException.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/NoRowSetExpectedException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/ResultSet.java b/modules/api/src/main/java/org/apache/ignite/sql/ResultSet.java
index 4fc75a7bd2..41640149f9 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/ResultSet.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/ResultSet.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/ResultSetMetadata.java b/modules/api/src/main/java/org/apache/ignite/sql/ResultSetMetadata.java
index 9d41ebaced..a9bff6b34f 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/ResultSetMetadata.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/ResultSetMetadata.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/Session.java b/modules/api/src/main/java/org/apache/ignite/sql/Session.java
index 8cab66cc22..62a31da88b 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/Session.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/Session.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/SqlBatchException.java b/modules/api/src/main/java/org/apache/ignite/sql/SqlBatchException.java
index 7a031c8ec7..5deadd3e7b 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/SqlBatchException.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/SqlBatchException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/SqlColumnType.java b/modules/api/src/main/java/org/apache/ignite/sql/SqlColumnType.java
index ec33f6151b..19fafd1101 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/SqlColumnType.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/SqlColumnType.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/SqlException.java b/modules/api/src/main/java/org/apache/ignite/sql/SqlException.java
index c28e3a0c3a..4d6f790f7a 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/SqlException.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/SqlException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/SqlRow.java b/modules/api/src/main/java/org/apache/ignite/sql/SqlRow.java
index fe416c05cd..18221a8d28 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/SqlRow.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/SqlRow.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/Statement.java b/modules/api/src/main/java/org/apache/ignite/sql/Statement.java
index 2be06e8f29..a3f2e38436 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/Statement.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/Statement.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/async/AsyncResultSet.java b/modules/api/src/main/java/org/apache/ignite/sql/async/AsyncResultSet.java
index e5671f6c47..9ff9e262c1 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/async/AsyncResultSet.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/async/AsyncResultSet.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/async/package-info.java b/modules/api/src/main/java/org/apache/ignite/sql/async/package-info.java
index b8c56e71b6..6fba61841d 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/async/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/async/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/package-info.java b/modules/api/src/main/java/org/apache/ignite/sql/package-info.java
index 184f803287..aa6d71a759 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/reactive/ReactiveResultSet.java b/modules/api/src/main/java/org/apache/ignite/sql/reactive/ReactiveResultSet.java
index 525a5422b2..47aafcb46c 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/reactive/ReactiveResultSet.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/reactive/ReactiveResultSet.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/sql/reactive/package-info.java b/modules/api/src/main/java/org/apache/ignite/sql/reactive/package-info.java
index 4fef2107ae..f15abf6cd8 100644
--- a/modules/api/src/main/java/org/apache/ignite/sql/reactive/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/sql/reactive/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/InvocationContext.java b/modules/api/src/main/java/org/apache/ignite/table/InvocationContext.java
index 9ecd60ca67..89a8cc5ff1 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/InvocationContext.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/InvocationContext.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessor.java b/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessor.java
index 3f4e75dec9..4266556983 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessor.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessor.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessorException.java b/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessorException.java
index 810290ad38..c96981b4ef 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessorException.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/InvokeProcessorException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/KeyValueView.java b/modules/api/src/main/java/org/apache/ignite/table/KeyValueView.java
index a191c51523..fdac15af32 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/KeyValueView.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/KeyValueView.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/RecordView.java b/modules/api/src/main/java/org/apache/ignite/table/RecordView.java
index 57b946fc3e..e0e3ccec20 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/RecordView.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/RecordView.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/Table.java b/modules/api/src/main/java/org/apache/ignite/table/Table.java
index 4148eab33a..e492bbc23f 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/Table.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/Table.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/Tuple.java b/modules/api/src/main/java/org/apache/ignite/table/Tuple.java
index ef0579c091..cecaed4f8c 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/Tuple.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/Tuple.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/TupleImpl.java b/modules/api/src/main/java/org/apache/ignite/table/TupleImpl.java
index 0a0d2c26e3..77db7b3269 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/TupleImpl.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/TupleImpl.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/manager/IgniteTables.java b/modules/api/src/main/java/org/apache/ignite/table/manager/IgniteTables.java
index d88f2e75e5..52a77d4aa4 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/manager/IgniteTables.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/manager/IgniteTables.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/manager/package-info.java b/modules/api/src/main/java/org/apache/ignite/table/manager/package-info.java
index bfaf4e4bbe..c37a239834 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/manager/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/manager/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/Mapper.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/Mapper.java
index 49ef95d851..925a2a0b2f 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/Mapper.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/Mapper.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/MapperBuilder.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/MapperBuilder.java
index e6a54d9e97..839cdf759c 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/MapperBuilder.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/MapperBuilder.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapper.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapper.java
index d3e750cc04..baaa46742a 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapper.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapper.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapperImpl.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapperImpl.java
index ef16cea3bb..2e3eaf6a93 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapperImpl.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/OneColumnMapperImpl.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapper.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapper.java
index 04d54f2269..ecd85ba2b6 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapper.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapper.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapperImpl.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapperImpl.java
index ccf893c2ae..f9993b2c8f 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapperImpl.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/PojoMapperImpl.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/TypeConverter.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/TypeConverter.java
index 316bdc20f7..ba1e0fe078 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/TypeConverter.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/TypeConverter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/mapper/package-info.java b/modules/api/src/main/java/org/apache/ignite/table/mapper/package-info.java
index 64e3e981e2..235921be85 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/mapper/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/mapper/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/table/package-info.java b/modules/api/src/main/java/org/apache/ignite/table/package-info.java
index 2c5dff1053..43bacaa0f4 100644
--- a/modules/api/src/main/java/org/apache/ignite/table/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/table/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/tx/IgniteTransactions.java b/modules/api/src/main/java/org/apache/ignite/tx/IgniteTransactions.java
index 21ccff2c24..770892b5a7 100644
--- a/modules/api/src/main/java/org/apache/ignite/tx/IgniteTransactions.java
+++ b/modules/api/src/main/java/org/apache/ignite/tx/IgniteTransactions.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/tx/Transaction.java b/modules/api/src/main/java/org/apache/ignite/tx/Transaction.java
index f80260e869..8086ae4fb3 100644
--- a/modules/api/src/main/java/org/apache/ignite/tx/Transaction.java
+++ b/modules/api/src/main/java/org/apache/ignite/tx/Transaction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/tx/TransactionException.java b/modules/api/src/main/java/org/apache/ignite/tx/TransactionException.java
index 85afee8bdd..49196b3ad1 100644
--- a/modules/api/src/main/java/org/apache/ignite/tx/TransactionException.java
+++ b/modules/api/src/main/java/org/apache/ignite/tx/TransactionException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/main/java/org/apache/ignite/tx/package-info.java b/modules/api/src/main/java/org/apache/ignite/tx/package-info.java
index 133fceb701..e10bbef468 100644
--- a/modules/api/src/main/java/org/apache/ignite/tx/package-info.java
+++ b/modules/api/src/main/java/org/apache/ignite/tx/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionArchTest.java b/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionArchTest.java
index e5c14ba93f..83d5ff1c54 100644
--- a/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionArchTest.java
+++ b/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionArchTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionTest.java b/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionTest.java
index 399400f8e1..0daf396fd9 100644
--- a/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionTest.java
+++ b/modules/api/src/test/java/org/apache/ignite/lang/IgniteExceptionTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/baseline/src/main/java/org/apache/ignite/internal/baseline/BaselineManager.java b/modules/baseline/src/main/java/org/apache/ignite/internal/baseline/BaselineManager.java
index a4d952085d..ec6b2240ae 100644
--- a/modules/baseline/src/main/java/org/apache/ignite/internal/baseline/BaselineManager.java
+++ b/modules/baseline/src/main/java/org/apache/ignite/internal/baseline/BaselineManager.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleBuilder.java b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleBuilder.java
index 59b246aaa8..873ba1d3f4 100644
--- a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleBuilder.java
+++ b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleBuilder.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleCommon.java b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleCommon.java
index bb5ec098fe..5d5e3eb409 100644
--- a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleCommon.java
+++ b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleCommon.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleFormatException.java b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleFormatException.java
index f1ac0f0a71..eb09be2933 100644
--- a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleFormatException.java
+++ b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleFormatException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleParser.java b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleParser.java
index 534ee52da7..f96d4451ec 100644
--- a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleParser.java
+++ b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleParser.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleReader.java b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleReader.java
index 0b30537b03..e269433ded 100644
--- a/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleReader.java
+++ b/modules/binary-tuple/src/main/java/org/apache/ignite/internal/binarytuple/BinaryTupleReader.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/binary-tuple/src/test/java/org/apache/ignite/internal/binarytuple/BinaryTupleTest.java b/modules/binary-tuple/src/test/java/org/apache/ignite/internal/binarytuple/BinaryTupleTest.java
index 76cca3ddf1..95b50bf8b7 100644
--- a/modules/binary-tuple/src/test/java/org/apache/ignite/internal/binarytuple/BinaryTupleTest.java
+++ b/modules/binary-tuple/src/test/java/org/apache/ignite/internal/binarytuple/BinaryTupleTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Access.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Access.java
index 430b05d081..40d32336d0 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Access.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Access.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AddFakeLineNumberClassVisitor.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AddFakeLineNumberClassVisitor.java
index 2558a273ac..1ea9c6907f 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AddFakeLineNumberClassVisitor.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AddFakeLineNumberClassVisitor.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AnnotationDefinition.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AnnotationDefinition.java
index 464f5810c4..210d869486 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AnnotationDefinition.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/AnnotationDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ArrayOpCode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ArrayOpCode.java
index 8205a84bcc..73b2fdb8cc 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ArrayOpCode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ArrayOpCode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ByteCodeTooLargeException.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ByteCodeTooLargeException.java
index 4471c69e25..91af7cd32a 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ByteCodeTooLargeException.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ByteCodeTooLargeException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeBlock.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeBlock.java
index 7aaa0be383..d678a55cdd 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeBlock.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeBlock.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeNode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeNode.java
index 936b65566c..6c9e4ba264 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeNode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeUtils.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeUtils.java
index 40e567cfd9..cf99fb541f 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeUtils.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeUtils.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeVisitor.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeVisitor.java
index fbcf1b81ab..0a0d4d46ab 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeVisitor.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/BytecodeVisitor.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassDefinition.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassDefinition.java
index 74363b6774..5e7c4a803e 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassDefinition.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassGenerator.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassGenerator.java
index 612a5fd125..8a9321eadd 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassGenerator.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ClassGenerator.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Comment.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Comment.java
index 703ef3b920..a2c97b316a 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Comment.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Comment.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/CompilationException.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/CompilationException.java
index 9f6fa89d71..5fb1b10de8 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/CompilationException.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/CompilationException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DumpBytecodeVisitor.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DumpBytecodeVisitor.java
index cf5e19f61c..fc92b3a2aa 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DumpBytecodeVisitor.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DumpBytecodeVisitor.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DynamicClassLoader.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DynamicClassLoader.java
index 98fd45c6c0..b2fa715e7b 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DynamicClassLoader.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/DynamicClassLoader.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/FieldDefinition.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/FieldDefinition.java
index baf70bc713..01ac47011a 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/FieldDefinition.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/FieldDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodDefinition.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodDefinition.java
index f82052845d..d91928ef02 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodDefinition.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodDefinition.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodGenerationContext.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodGenerationContext.java
index ccebb2b5df..1fe3bbbf76 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodGenerationContext.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/MethodGenerationContext.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/OpCode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/OpCode.java
index 8ea05db7bb..df47a63c2d 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/OpCode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/OpCode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Parameter.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Parameter.java
index c8df6c52dd..bfe85c02db 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Parameter.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Parameter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ParameterizedType.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ParameterizedType.java
index da7c8b6c81..b894d3c2e5 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ParameterizedType.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/ParameterizedType.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Scope.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Scope.java
index 8d409ee608..fcc0613735 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Scope.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Scope.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/SmartClassWriter.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/SmartClassWriter.java
index b727775463..d6c4cd763f 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/SmartClassWriter.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/SmartClassWriter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Variable.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Variable.java
index b35b8e3131..9a71cd2ec8 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Variable.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/Variable.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/CaseStatement.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/CaseStatement.java
index b7d1e7fd81..2c77deb67a 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/CaseStatement.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/CaseStatement.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/DoWhileLoop.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/DoWhileLoop.java
index b49fd0dfb0..96bb8d0d2c 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/DoWhileLoop.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/DoWhileLoop.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/FlowControl.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/FlowControl.java
index d8a45639b8..95711982bf 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/FlowControl.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/FlowControl.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/ForLoop.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/ForLoop.java
index bd75eb6c84..299057d032 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/ForLoop.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/ForLoop.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/IfStatement.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/IfStatement.java
index bcaeb8e106..60e2dbf400 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/IfStatement.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/IfStatement.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/SwitchStatement.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/SwitchStatement.java
index 24812ab967..1d70eabe10 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/SwitchStatement.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/SwitchStatement.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/TryCatch.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/TryCatch.java
index 8ad891e58d..3df8572a7c 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/TryCatch.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/TryCatch.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/WhileLoop.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/WhileLoop.java
index be1e0e90ed..023e093bbd 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/WhileLoop.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/control/WhileLoop.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/DebugNode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/DebugNode.java
index a70a4998c0..eb1c00becf 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/DebugNode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/DebugNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LineNumberNode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LineNumberNode.java
index 6e9bfe29ae..3cb815f002 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LineNumberNode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LineNumberNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LocalVariableNode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LocalVariableNode.java
index b693ba5114..d50cb1b298 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LocalVariableNode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/debug/LocalVariableNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/AndBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/AndBytecodeExpression.java
index 047538e7d4..e783104e2d 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/AndBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/AndBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArithmeticBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArithmeticBytecodeExpression.java
index fe853dcdb5..0218989046 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArithmeticBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArithmeticBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArrayLengthBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArrayLengthBytecodeExpression.java
index 55b03fe2e4..12161a2e9d 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArrayLengthBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ArrayLengthBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpression.java
index eb936e1a7f..62f4e9e738 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpressions.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpressions.java
index 64993c1a99..e81fb559c3 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpressions.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/BytecodeExpressions.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/CastBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/CastBytecodeExpression.java
index 21eb24d7a6..f423ff90aa 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/CastBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/CastBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ComparisonBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ComparisonBytecodeExpression.java
index 4f9ac6e274..a2379ddc9b 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ComparisonBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ComparisonBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ConstantBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ConstantBytecodeExpression.java
index eee384084b..3227a22bb8 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ConstantBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ConstantBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetElementBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetElementBytecodeExpression.java
index 65516f0931..3d94ffe88c 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetElementBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetElementBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetFieldBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetFieldBytecodeExpression.java
index 7a5e60d99e..7ec9ac7fd1 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetFieldBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/GetFieldBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InlineIfBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InlineIfBytecodeExpression.java
index a5bec79143..106e1407b7 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InlineIfBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InlineIfBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InstanceOfBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InstanceOfBytecodeExpression.java
index da0f0192de..11e1c4d110 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InstanceOfBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InstanceOfBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeBytecodeExpression.java
index fc4b6a0627..9c5fc3aef5 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeDynamicBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeDynamicBytecodeExpression.java
index 634a403fb4..226d67d74d 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeDynamicBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/InvokeDynamicBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NegateBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NegateBytecodeExpression.java
index 5e9153d00b..3fc326294c 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NegateBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NegateBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewArrayBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewArrayBytecodeExpression.java
index 3261761eb5..334fbd85de 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewArrayBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewArrayBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewInstanceBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewInstanceBytecodeExpression.java
index 9aba9d0556..9653471e0a 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewInstanceBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NewInstanceBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NotBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NotBytecodeExpression.java
index a87fbbb543..a8ba01da0c 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NotBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/NotBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/OrBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/OrBytecodeExpression.java
index cf3200811a..2eb507c98e 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/OrBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/OrBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/PopBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/PopBytecodeExpression.java
index 7b8b004fc9..0d459a5885 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/PopBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/PopBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ReturnBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ReturnBytecodeExpression.java
index 08b48dd479..bdab7f823d 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ReturnBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/ReturnBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetArrayElementBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetArrayElementBytecodeExpression.java
index d9edf465f7..e2aaefbe43 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetArrayElementBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetArrayElementBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetFieldBytecodeExpression.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetFieldBytecodeExpression.java
index 6965e04dc8..7fddd8d116 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetFieldBytecodeExpression.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/expression/SetFieldBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/Constant.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/Constant.java
index 5f5ffd958a..e1d75bcc09 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/Constant.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/Constant.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/FieldInstruction.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/FieldInstruction.java
index 8145c257dd..f693038c7d 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/FieldInstruction.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/FieldInstruction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InstructionNode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InstructionNode.java
index a12ae7e1a1..73a3dac840 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InstructionNode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InstructionNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InvokeInstruction.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InvokeInstruction.java
index 689c87e664..49348c86b1 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InvokeInstruction.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/InvokeInstruction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/JumpInstruction.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/JumpInstruction.java
index 378317ec2f..9c02d43396 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/JumpInstruction.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/JumpInstruction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/LabelNode.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/LabelNode.java
index 4cca8e70cc..d7a22764cc 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/LabelNode.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/LabelNode.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/TypeInstruction.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/TypeInstruction.java
index 4c0d0e2baf..e3e3a511b4 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/TypeInstruction.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/TypeInstruction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/VariableInstruction.java b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/VariableInstruction.java
index 150a248f8e..76d3f42bc1 100644
--- a/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/VariableInstruction.java
+++ b/modules/bytecode/src/main/java/com/facebook/presto/bytecode/instruction/VariableInstruction.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestBytecodeUtils.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestBytecodeUtils.java
index a62b7eb480..62279b0a55 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestBytecodeUtils.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestBytecodeUtils.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestClassGenerator.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestClassGenerator.java
index b0ffa0fa5b..fb88dd8a93 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestClassGenerator.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/TestClassGenerator.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/BytecodeExpressionAssertions.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/BytecodeExpressionAssertions.java
index 2eaddf9cd5..673c954dce 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/BytecodeExpressionAssertions.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/BytecodeExpressionAssertions.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArithmeticBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArithmeticBytecodeExpression.java
index 51531c65a2..474032e820 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArithmeticBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArithmeticBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArrayBytecodeExpressions.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArrayBytecodeExpressions.java
index 6f0eb00fc7..5d8e09b199 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArrayBytecodeExpressions.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestArrayBytecodeExpressions.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestCastBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestCastBytecodeExpression.java
index 6e6c2b0ab5..bc37a3479d 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestCastBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestCastBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestComparisonBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestComparisonBytecodeExpression.java
index f5d7a5359f..42460a36f0 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestComparisonBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestComparisonBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestConstantBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestConstantBytecodeExpression.java
index 701c7b93c1..c4713ddb35 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestConstantBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestConstantBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestGetFieldBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestGetFieldBytecodeExpression.java
index 375bedd07b..29563500a0 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestGetFieldBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestGetFieldBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInlineIfBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInlineIfBytecodeExpression.java
index 2e25f8b8eb..2f2d1a7572 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInlineIfBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInlineIfBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeBytecodeExpression.java
index 7ee0f40982..8928ba6708 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeDynamicBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeDynamicBytecodeExpression.java
index 4e85276f72..038a66b5cc 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeDynamicBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestInvokeDynamicBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestLogicalBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestLogicalBytecodeExpression.java
index 71e4c26c94..6d5edc4550 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestLogicalBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestLogicalBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestNewInstanceBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestNewInstanceBytecodeExpression.java
index 363f7ea66d..36c0313134 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestNewInstanceBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestNewInstanceBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestPopBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestPopBytecodeExpression.java
index aa93a5d7dc..39d6208295 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestPopBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestPopBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetFieldBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetFieldBytecodeExpression.java
index 51d6033bea..db7fdaaa94 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetFieldBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetFieldBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetVariableBytecodeExpression.java b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetVariableBytecodeExpression.java
index ad749fb64c..39c1fceda3 100644
--- a/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetVariableBytecodeExpression.java
+++ b/modules/bytecode/src/test/java/com/facebook/presto/bytecode/expression/TestSetVariableBytecodeExpression.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli-common/src/main/java/org/apache/ignite/cli/common/IgniteCommand.java b/modules/cli-common/src/main/java/org/apache/ignite/cli/common/IgniteCommand.java
index 4306ba19aa..796814ece8 100644
--- a/modules/cli-common/src/main/java/org/apache/ignite/cli/common/IgniteCommand.java
+++ b/modules/cli-common/src/main/java/org/apache/ignite/cli/common/IgniteCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli-common/src/main/java/org/apache/ignite/cli/common/package-info.java b/modules/cli-common/src/main/java/org/apache/ignite/cli/common/package-info.java
index 65acbf061e..3f08897660 100644
--- a/modules/cli-common/src/main/java/org/apache/ignite/cli/common/package-info.java
+++ b/modules/cli-common/src/main/java/org/apache/ignite/cli/common/package-info.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/IntegrationTestBase.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/IntegrationTestBase.java
index 894dd9536a..535dc1bcd5 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/IntegrationTestBase.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/IntegrationTestBase.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/CallInitializedIntegrationTestBase.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/CallInitializedIntegrationTestBase.java
index 483246698f..2f44d7f808 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/CallInitializedIntegrationTestBase.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/CallInitializedIntegrationTestBase.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItShowConfigurationCallTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItShowConfigurationCallTest.java
index 7551955bf4..3c9407b19f 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItShowConfigurationCallTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItShowConfigurationCallTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItUpdateConfigurationCallTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItUpdateConfigurationCallTest.java
index b1d0ec09fe..b2ce90f556 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItUpdateConfigurationCallTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/call/configuration/ItUpdateConfigurationCallTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestInitializedIntegrationBase.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestInitializedIntegrationBase.java
index 0933f75ba1..28d408cba8 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestInitializedIntegrationBase.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestInitializedIntegrationBase.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestNotInitializedIntegrationBase.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestNotInitializedIntegrationBase.java
index 13abe5780f..dcfbd9faab 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestNotInitializedIntegrationBase.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/CliCommandTestNotInitializedIntegrationBase.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/config/ItClusterConfigCommandNotInitializedTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/config/ItClusterConfigCommandNotInitializedTest.java
index ef41dc195f..c5c57b81ef 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/config/ItClusterConfigCommandNotInitializedTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/config/ItClusterConfigCommandNotInitializedTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandInitializedTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandInitializedTest.java
index cf4de03042..6a0ddcc13e 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandInitializedTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandInitializedTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandNotInitializedTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandNotInitializedTest.java
index 35d9d17a41..ff70efbce5 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandNotInitializedTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/status/ItClusterStatusCommandNotInitializedTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandInitializedClusterTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandInitializedClusterTest.java
index e4c155f03b..26acbc9baa 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandInitializedClusterTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandInitializedClusterTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandNotInitializedClusterTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandNotInitializedClusterTest.java
index 6d659ef365..96071d37c2 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandNotInitializedClusterTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/cluster/topology/ItTopologyCommandNotInitializedClusterTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/configuration/ItConfigCommandTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/configuration/ItConfigCommandTest.java
index 9a1be43af1..380a1eb122 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/configuration/ItConfigCommandTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/configuration/ItConfigCommandTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/connect/ItConnectCommandTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/connect/ItConnectCommandTest.java
index c1fc2ba388..1be2bd8afd 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/connect/ItConnectCommandTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/connect/ItConnectCommandTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/questions/ItConnectToClusterTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/questions/ItConnectToClusterTest.java
index 6e8216b2cb..e373a3620f 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/questions/ItConnectToClusterTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/questions/ItConnectToClusterTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/sql/ItSqlCommandTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/sql/ItSqlCommandTest.java
index ecf746b239..6aa1fcee34 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/sql/ItSqlCommandTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/sql/ItSqlCommandTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/version/ItVersionCommandTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/version/ItVersionCommandTest.java
index b22ccba13a..57b64680bb 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/version/ItVersionCommandTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/commands/version/ItVersionCommandTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/AbstractCliIntegrationTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/AbstractCliIntegrationTest.java
index 1d4637e807..9da087be5f 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/AbstractCliIntegrationTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/AbstractCliIntegrationTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItClusterCommandTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItClusterCommandTest.java
index 9ca94bad23..fde6576e48 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItClusterCommandTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItClusterCommandTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItConfigCommandTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItConfigCommandTest.java
index ea2c4ca0cc..88b58a56ee 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItConfigCommandTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/cli/deprecated/ItConfigCommandTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/integrationTest/java/org/apache/ignite/rest/ItGeneratedRestClientTest.java b/modules/cli/src/integrationTest/java/org/apache/ignite/rest/ItGeneratedRestClientTest.java
index 5f2619cff6..c738aa686d 100644
--- a/modules/cli/src/integrationTest/java/org/apache/ignite/rest/ItGeneratedRestClientTest.java
+++ b/modules/cli/src/integrationTest/java/org/apache/ignite/rest/ItGeneratedRestClientTest.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/CliVersionInfo.java b/modules/cli/src/main/java/org/apache/ignite/cli/CliVersionInfo.java
index 5852a6cdfc..98f2345e3c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/CliVersionInfo.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/CliVersionInfo.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/Main.java b/modules/cli/src/main/java/org/apache/ignite/cli/Main.java
index 57a17cb0de..46d93d0777 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/Main.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/Main.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/VersionProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/VersionProvider.java
index adf175ab9c..6e1ff63ead 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/VersionProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/VersionProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCall.java
index 3e99abd9a0..fcbc9b7122 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCallInput.java
index 7c1e4da403..bbc7e83bac 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigGetCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCall.java
index 5bbf6623eb..1504e29aca 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCallInput.java
index 89a60d3371..f775cc4d09 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigSetCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigShowCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigShowCall.java
index d90eb668f7..b6f7fab0c2 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigShowCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/CliConfigShowCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileActivateCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileActivateCall.java
index 8bd6e2b96c..4d50cf4359 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileActivateCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileActivateCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCall.java
index 4b5bfd08d9..9929d97b11 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCallInput.java
index 9e88e8f55e..de201ecf82 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileCreateCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileListCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileListCall.java
index 0b5cb63778..4be27251ee 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileListCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileListCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileShowCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileShowCall.java
index 71e024ee2e..a19b8986da 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileShowCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/CliConfigProfileShowCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/ProfileList.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/ProfileList.java
index e63be0c2a1..7cb861ca6a 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/ProfileList.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cliconfig/profile/ProfileList.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCall.java
index dbdc0474fc..8d80eecc92 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCallInput.java
index e11a154b47..55a29731b1 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/ClusterInitCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatus.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatus.java
index 01ebc8e0b4..28c9fbd292 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatus.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatus.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatusCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatusCall.java
index 7a4848bbc4..9257d04200 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatusCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/status/ClusterStatusCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/LogicalTopologyCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/LogicalTopologyCall.java
index 2ac6f08bdd..e2657f4d3e 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/LogicalTopologyCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/LogicalTopologyCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/PhysicalTopologyCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/PhysicalTopologyCall.java
index b890c8deab..b58e9896e4 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/PhysicalTopologyCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/PhysicalTopologyCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/TopologyCallOutput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/TopologyCallOutput.java
index 525d0aa3e1..ffc0104bf7 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/TopologyCallOutput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/cluster/topology/TopologyCallOutput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCall.java
index 686dd94303..86deaa4820 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCallInput.java
index 687d8d97d5..dc38312409 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigShowCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCall.java
index 0481c872e0..49f334695f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCallInput.java
index 2ebbe7efa7..d818548aac 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/ClusterConfigUpdateCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/JsonString.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/JsonString.java
index ca3f264097..00f83b8377 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/JsonString.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/JsonString.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCall.java
index 86c6aae24b..a178cb9358 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCallInput.java
index c3b83acd4a..6e77fde5ac 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigShowCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCall.java
index a568bcf9ed..5021524dd7 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCallInput.java
index dae58ac935..f4cffaa3d1 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/configuration/NodeConfigUpdateCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCall.java
index 6aaf320516..2d766a5d91 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCallInput.java
index 6d5c98ba75..ec6573fdfb 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/ConnectCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/DisconnectCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/DisconnectCall.java
index bb60ee059e..9de8e6919f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/DisconnectCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/connect/DisconnectCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatus.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatus.java
index 0dacc7840b..d410ec1e52 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatus.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatus.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatusCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatusCall.java
index be40786e53..833e59978c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatusCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/NodeStatusCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/State.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/State.java
index d664246b39..6f3b3e5b50 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/State.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/node/status/State.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/call/sql/SqlQueryCall.java b/modules/cli/src/main/java/org/apache/ignite/cli/call/sql/SqlQueryCall.java
index 8c1ea89264..41475b6d4b 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/call/sql/SqlQueryCall.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/call/sql/SqlQueryCall.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/BaseCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/BaseCommand.java
index 8e05a2dc54..5266c488e0 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/BaseCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/BaseCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/OptionsConstants.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/OptionsConstants.java
index afa2e09de4..bacc5f4dcd 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/OptionsConstants.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/OptionsConstants.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/ProfileMixin.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/ProfileMixin.java
index f178493a17..dec1160b40 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/ProfileMixin.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/ProfileMixin.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliCommand.java
index 5e6d5af92d..6973d2ae58 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliReplCommand.java
index e673ac9526..e2dc79799c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/TopLevelCliReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliCommand.java
index c262abaf49..0c9484f0b4 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigCommand.java
index c2ff7aba00..1f444064fc 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetCommand.java
index a0af4fc678..47fc56d9ea 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetReplCommand.java
index 1c47477e86..8be4a03612 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigGetReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigReplCommand.java
index 9cf6ad599f..9da6d7934c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetCommand.java
index 3c7c2171c2..c8a2fb5a1c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetReplCommand.java
index 64ee82dd3d..6064874bce 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigSetReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowCommand.java
index 7e6f87dfd9..f37e2974ea 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowReplCommand.java
index e1f3c29908..8ffcfd3ae2 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliConfigShowReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliReplCommand.java
index 012035306f..637a7b852e 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/CliReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileActivateCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileActivateCommand.java
index f5f807e1b5..d7a1032e2f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileActivateCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileActivateCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCommand.java
index 59de1d03d5..fcc178e3a3 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCreateCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCreateCommand.java
index 7bd481d828..a290965305 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCreateCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileCreateCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileListCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileListCommand.java
index 57c12aa501..9694575c36 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileListCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileListCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileShowCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileShowCommand.java
index 34bd9ab51c..fcb64f280d 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileShowCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cliconfig/profile/CliConfigProfileShowCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterCommand.java
index 2db38c46c2..72d51e3cae 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterReplCommand.java
index fa0a9e2116..ddf9cb8893 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlMixin.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlMixin.java
index f0da3fd436..82c2a9a939 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlMixin.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlMixin.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlProfileMixin.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlProfileMixin.java
index 0a2fe15dd2..8fd00df46d 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlProfileMixin.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/ClusterUrlProfileMixin.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigCommand.java
index 7e1c48a61f..2db71a6834 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigReplCommand.java
index a990039ad6..0455671bc7 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowCommand.java
index 16d42b002f..f2c8cfda07 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowReplCommand.java
index 8fc5e0d65e..5dbd1a7072 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigShowReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateCommand.java
index 855ec1458f..6b2041c040 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateReplCommand.java
index 09772a536f..62fa2bc3a7 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/config/ClusterConfigUpdateReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitCommand.java
index 1a74c814a6..28674fa271 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitOptions.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitOptions.java
index 6d003d5129..169307771f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitOptions.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitOptions.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitReplCommand.java
index a186d6a0fc..623420c7bc 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/init/ClusterInitReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusCommand.java
index aef83ec43b..5ddf36aebc 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusReplCommand.java
index ec42e7c00b..cdb354e94d 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/cluster/status/ClusterStatusReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/ConnectCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/ConnectCommand.java
index 9712bd7143..ff93fe891c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/ConnectCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/ConnectCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/DisconnectCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/DisconnectCommand.java
index e383f915ec..099d089ef5 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/DisconnectCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/connect/DisconnectCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeCommand.java
index c513fd8a6e..4fadfdf32c 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeReplCommand.java
index a476d7d563..ae32a891df 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlMixin.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlMixin.java
index db61d279e9..118e3af76d 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlMixin.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlMixin.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlProfileMixin.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlProfileMixin.java
index 62f3261e8a..a85ff63c38 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlProfileMixin.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/NodeUrlProfileMixin.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigCommand.java
index 3a6dedea0e..7d6ecd2771 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigReplCommand.java
index 064a8ad3b8..45263af87a 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowCommand.java
index fe3615dd1d..2c57db5700 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowReplCommand.java
index 8e281aae7a..2f95473668 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigShowReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateCommand.java
index e34d1d3a8d..b0bc3862f0 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateReplCommand.java
index 64952fde92..05adccccba 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/config/NodeConfigUpdateReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusCommand.java
index 848c9eb47d..0dc2c158b2 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusReplCommand.java
index eb6331be81..7363a4b8ac 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/node/status/NodeStatusReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/questions/ConnectToClusterQuestion.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/questions/ConnectToClusterQuestion.java
index 145da5e0ea..1e2c692ef9 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/questions/ConnectToClusterQuestion.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/questions/ConnectToClusterQuestion.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCommand.java
index c16142c235..8746e5f3ca 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCompleter.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCompleter.java
index 23fa9768d8..0fa0e344ef 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCompleter.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlCompleter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlMetaData.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlMetaData.java
index 70b227a45c..315f76d4f0 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlMetaData.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlMetaData.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplCommand.java
index fe4c820b5e..981a2b1465 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplTopLevelCliCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplTopLevelCliCommand.java
index 0e977bb795..495ff5e9c5 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplTopLevelCliCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/sql/SqlReplTopLevelCliCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyCommand.java
index 8b1b31406f..803b5e7bc4 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyReplCommand.java
index dd51bf9091..fa5527c363 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/LogicalTopologyReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyCommand.java
index 9ed92adc25..69ee0b2a26 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyReplCommand.java
index 2f1c6df5dd..6aa5edb0c0 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/PhysicalTopologyReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyCommand.java
index df289b5d86..bf50691516 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyReplCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyReplCommand.java
index 29a74334f9..9ff4b1a18a 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyReplCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/topology/TopologyReplCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/commands/version/VersionCommand.java b/modules/cli/src/main/java/org/apache/ignite/cli/commands/version/VersionCommand.java
index 465209ea92..b142511de1 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/commands/version/VersionCommand.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/commands/version/VersionCommand.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedConfigManagerProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedConfigManagerProvider.java
index 3c364d3c1b..088468a576 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedConfigManagerProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedConfigManagerProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedStateConfigProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedStateConfigProvider.java
index 4caaf03758..4b82b68c44 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedStateConfigProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/CachedStateConfigProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/Config.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/Config.java
index cc9e078a3c..3a01630bf7 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/Config.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/Config.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigConstants.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigConstants.java
index 976a06c63c..87a97c3c35 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigConstants.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigConstants.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigDefaultValueProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigDefaultValueProvider.java
index 37e2fefd0e..d6c6b57aac 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigDefaultValueProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigDefaultValueProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigInitializationException.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigInitializationException.java
index b8a95af4b8..2ce6410732 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigInitializationException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigInitializationException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManager.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManager.java
index 673b27c979..d7d48716c0 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManager.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManager.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManagerProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManagerProvider.java
index c7fe47923d..4602b91bdb 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManagerProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigManagerProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigStoringException.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigStoringException.java
index f7149dc499..ae931d0eed 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigStoringException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ConfigStoringException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/Profile.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/Profile.java
index 24036e9dce..7a04624aa2 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/Profile.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/Profile.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ProfileNotFoundException.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ProfileNotFoundException.java
index a1e0b671de..765dc0f4a8 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ProfileNotFoundException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ProfileNotFoundException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfig.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfig.java
index 16dfba0363..d664c0fd11 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfig.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfig.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfigProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfigProvider.java
index db0a07b74a..da8d844a28 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfigProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/StateConfigProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/StateFolderProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/StateFolderProvider.java
index 24d408a4d0..7d011083a2 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/StateFolderProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/StateFolderProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfig.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfig.java
index 8d8e2ed219..23fdae84f3 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfig.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfig.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfigManager.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfigManager.java
index a188309ceb..4fab2cdbe6 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfigManager.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniConfigManager.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniFile.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniFile.java
index 5deae3effd..4998470352 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniFile.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniFile.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniParser.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniParser.java
index fd475040b9..e81b4e3390 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniParser.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniParser.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniProfile.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniProfile.java
index 127f820d86..380c233ad9 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniProfile.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniProfile.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniSection.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniSection.java
index c55c428de9..9499a1d975 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniSection.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/IniSection.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/SectionAlreadyExistsException.java b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/SectionAlreadyExistsException.java
index 84def57b7f..d30c933b61 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/SectionAlreadyExistsException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/config/ini/SectionAlreadyExistsException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/CallExecutionPipelineProvider.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/CallExecutionPipelineProvider.java
index 0c02411745..df25cea7a9 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/CallExecutionPipelineProvider.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/CallExecutionPipelineProvider.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/Call.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/Call.java
index 6becdbb4c4..f00bcc8538 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/Call.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/Call.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallExecutionPipeline.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallExecutionPipeline.java
index c9f43dd28f..d7829a3a79 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallExecutionPipeline.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallExecutionPipeline.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallInput.java
index 46e4b36afd..a88bf97f04 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutput.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutput.java
index d4326864ce..3f8e23261a 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutputStatus.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutputStatus.java
index 8d9b182abb..0780cf8ad3 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutputStatus.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/CallOutputStatus.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/DefaultCallOutput.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/DefaultCallOutput.java
index b522726343..dd05c5baaf 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/DefaultCallOutput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/DefaultCallOutput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/EmptyCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/EmptyCallInput.java
index 3e866543e7..a023ca1396 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/EmptyCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/EmptyCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/StringCallInput.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/StringCallInput.java
index 767e82a097..79526e4f56 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/call/StringCallInput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/call/StringCallInput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/NetworkAddressConverter.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/NetworkAddressConverter.java
index 9dd4a852f9..b381af879d 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/NetworkAddressConverter.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/NetworkAddressConverter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/UrlConverter.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/UrlConverter.java
index e8d8403d3c..2e39379a7f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/UrlConverter.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/converters/UrlConverter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/Decorator.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/Decorator.java
index 835d355a92..933237090a 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/Decorator.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/Decorator.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/DecoratorRegistry.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/DecoratorRegistry.java
index ca22a3bcd9..cd329c0fb8 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/DecoratorRegistry.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/DecoratorRegistry.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/TerminalOutput.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/TerminalOutput.java
index 0c686f19fe..2e41f8e4af 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/TerminalOutput.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/decorator/TerminalOutput.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/CommandExecutionException.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/CommandExecutionException.java
index a15f76abf4..240e16ae00 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/CommandExecutionException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/CommandExecutionException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ConnectCommandException.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ConnectCommandException.java
index 140ddbe1ab..87379b9d5f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ConnectCommandException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ConnectCommandException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandler.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandler.java
index c65de68999..fa960f1fbe 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandler.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandler.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandlers.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandlers.java
index 776fe4aa8c..ece95d07fc 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandlers.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionHandlers.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionWriter.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionWriter.java
index b95e135895..f3d624df4e 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionWriter.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/ExceptionWriter.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/IgniteCliApiException.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/IgniteCliApiException.java
index e247be9d69..3cf556185f 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/IgniteCliApiException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/IgniteCliApiException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/WrappedException.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/WrappedException.java
index 0fd46f1a07..e33eba8487 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/WrappedException.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/WrappedException.java
@@ -1,10 +1,10 @@
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
+ * 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
+ * the License. You may obtain a copy of the License at
  *
  *      http://www.apache.org/licenses/LICENSE-2.0
  *
diff --git a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/handler/ClusterNotInitializedExceptionHandler.java b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/handler/ClusterNotInitializedExceptionHandler.java
index 82ec8cdc55..18fcae0f8e 100644
--- a/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/handler/ClusterNotInitializedExceptionHandler.java
+++ b/modules/cli/src/main/java/org/apache/ignite/cli/core/exception/handler/ClusterNotInitializedExceptionHandler.java
... 48177 lines suppressed ...