You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@doris.apache.org by mo...@apache.org on 2022/05/26 08:56:25 UTC

[incubator-doris] branch master updated: [style](fe) wrap and whitespace rules (#9764)

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

morningman pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/incubator-doris.git


The following commit(s) were added to refs/heads/master by this push:
     new e701c057dc [style](fe) wrap and whitespace rules (#9764)
e701c057dc is described below

commit e701c057dc675babe7a859e151287fea7cd5c850
Author: morrySnow <10...@users.noreply.github.com>
AuthorDate: Thu May 26 16:56:20 2022 +0800

    [style](fe) wrap and whitespace rules (#9764)
    
    change below rules' severity to error and fix original code error:
    
    - EmptyBlock
    - EmptyCatchBlock
    - LeftCurly
    - RightCurly
    - IllegalTokenText
    - MultipleVariableDeclarations
    - OneStatementPerLine
    - StringLiteralEquality
    - UnusedLocalVariable
    - Indentation
    - OuterTypeFilename
    - MethodParamPad
    - GenericWhitespace
    - NoWhitespaceBefore
    - OperatorWrap
    - ParenPad
    - WhitespaceAfter
    - WhitespaceAround
---
 fe/check/checkstyle/checkstyle.xml                 |   40 +-
 .../org/apache/doris/common/io/BitmapValue.java    |   20 +-
 .../doris/common/io/CountingDataOutputStream.java  |    4 +-
 .../main/java/org/apache/doris/common/io/Hll.java  |   34 +-
 .../java/org/apache/doris/common/io/IOUtils.java   |    2 +
 .../apache/doris/common/io/LimitOutputStream.java  |   54 +-
 .../main/java/org/apache/doris/common/io/Text.java |  144 +-
 .../org/apache/doris/common/jmockit/AutoType.java  |    4 +-
 .../common/jmockit/ConstructorReflection.java      |   14 +-
 .../doris/common/jmockit/Deencapsulation.java      |   12 +-
 .../doris/common/jmockit/FieldReflection.java      |   25 +-
 .../doris/common/jmockit/MethodReflection.java     |   23 +-
 .../doris/common/jmockit/ParameterReflection.java  |   14 +-
 .../doris/common/property/PropertiesSet.java       |    4 +-
 .../doris/common/property/PropertySchema.java      |    6 +-
 .../apache/doris/common/io/BitmapValueTest.java    |   10 +-
 .../java/org/apache/doris/common/io/HllTest.java   |   40 +-
 .../src/main/java/org/apache/doris/PaloFe.java     |    2 +-
 .../java/org/apache/doris/alter/AlterJobV2.java    |   25 +-
 .../doris/alter/MaterializedViewHandler.java       |    8 +-
 .../apache/doris/alter/SchemaChangeHandler.java    |   35 +-
 .../org/apache/doris/alter/SchemaChangeJobV2.java  |    2 +-
 .../org/apache/doris/analysis/AddColumnClause.java |    4 +-
 .../org/apache/doris/analysis/AggregateInfo.java   |   64 +-
 .../apache/doris/analysis/AggregateInfoBase.java   |   46 +-
 .../doris/analysis/AlterColumnStatsStmt.java       |    2 +-
 .../doris/analysis/AlterDatabaseQuotaStmt.java     |    4 +-
 .../apache/doris/analysis/AlterTableStatsStmt.java |    2 +-
 .../org/apache/doris/analysis/AlterTableStmt.java  |   18 +-
 .../org/apache/doris/analysis/AlterViewStmt.java   |    2 +-
 .../org/apache/doris/analysis/AnalyticExpr.java    |   83 +-
 .../org/apache/doris/analysis/AnalyticInfo.java    |   42 +-
 .../org/apache/doris/analysis/AnalyticWindow.java  |   16 +-
 .../java/org/apache/doris/analysis/Analyzer.java   |  156 +-
 .../org/apache/doris/analysis/ArrayLiteral.java    |    2 +-
 .../apache/doris/analysis/BetweenPredicate.java    |   35 +-
 .../org/apache/doris/analysis/BinaryPredicate.java |   54 +-
 .../doris/analysis/BuiltinAggregateFunction.java   |   11 +-
 .../doris/analysis/CancelAlterTableStmt.java       |    4 +-
 .../java/org/apache/doris/analysis/CastExpr.java   |   49 +-
 .../java/org/apache/doris/analysis/ColumnDef.java  |   64 +-
 .../apache/doris/analysis/CompoundPredicate.java   |   35 +-
 .../doris/analysis/CreateEncryptKeyStmt.java       |    2 +-
 .../doris/analysis/CreateRoutineLoadStmt.java      |    4 +-
 .../apache/doris/analysis/CreateTableLikeStmt.java |    6 +-
 .../org/apache/doris/analysis/CreateTableStmt.java |   12 +-
 .../org/apache/doris/analysis/DataSortInfo.java    |    6 +-
 .../org/apache/doris/analysis/DateLiteral.java     |    2 +-
 .../org/apache/doris/analysis/DecimalLiteral.java  |    1 -
 .../org/apache/doris/analysis/DescriptorTable.java |    4 +-
 .../apache/doris/analysis/DropFunctionStmt.java    |    9 +-
 .../org/apache/doris/analysis/ExistsPredicate.java |   11 +-
 .../java/org/apache/doris/analysis/ExportStmt.java |   22 +-
 .../main/java/org/apache/doris/analysis/Expr.java  |  226 +-
 .../java/org/apache/doris/analysis/ExprId.java     |    9 +-
 .../apache/doris/analysis/ExprSubstitutionMap.java |   13 +-
 .../apache/doris/analysis/ExpressionFunctions.java |    2 +-
 .../org/apache/doris/analysis/FloatLiteral.java    |    4 +-
 .../java/org/apache/doris/analysis/FromClause.java |   67 +-
 .../org/apache/doris/analysis/FunctionArgsDef.java |   13 +-
 .../apache/doris/analysis/FunctionCallExpr.java    |   56 +-
 .../org/apache/doris/analysis/FunctionName.java    |   14 +-
 .../java/org/apache/doris/analysis/GrantStmt.java  |    2 +-
 .../org/apache/doris/analysis/GroupingInfo.java    |    2 +-
 .../org/apache/doris/analysis/InPredicate.java     |   30 +-
 .../java/org/apache/doris/analysis/IndexDef.java   |    4 +-
 .../apache/doris/analysis/InformationFunction.java |    4 +-
 .../org/apache/doris/analysis/InlineViewRef.java   |   29 +-
 .../java/org/apache/doris/analysis/InsertStmt.java |    8 +-
 .../org/apache/doris/analysis/IsNullPredicate.java |   14 +-
 .../org/apache/doris/analysis/JoinOperator.java    |   10 +-
 .../java/org/apache/doris/analysis/LoadStmt.java   |    8 +-
 .../org/apache/doris/analysis/LockTablesStmt.java  |    3 +-
 .../doris/analysis/MVColumnHLLUnionPattern.java    |    2 +-
 .../org/apache/doris/analysis/MVColumnItem.java    |    2 +-
 .../apache/doris/analysis/ModifyColumnClause.java  |    4 +-
 .../org/apache/doris/analysis/NullLiteral.java     |    4 +-
 .../org/apache/doris/analysis/OrderByElement.java  |   10 +-
 .../org/apache/doris/analysis/OutFileClause.java   |   14 +-
 .../apache/doris/analysis/PartitionKeyDesc.java    |    2 +-
 .../doris/analysis/PauseRoutineLoadStmt.java       |    2 +-
 .../java/org/apache/doris/analysis/Predicate.java  |    3 +-
 .../java/org/apache/doris/analysis/QueryStmt.java  |   12 +-
 .../apache/doris/analysis/RangePartitionDesc.java  |    4 +-
 .../doris/analysis/ResumeRoutineLoadStmt.java      |    2 +-
 .../analysis/RoutineLoadDataSourceProperties.java  |   15 +-
 .../org/apache/doris/analysis/SelectListItem.java  |    6 +-
 .../java/org/apache/doris/analysis/SelectStmt.java |   44 +-
 .../java/org/apache/doris/analysis/Separator.java  |    2 +-
 .../apache/doris/analysis/SetOperationStmt.java    |  137 +-
 .../java/org/apache/doris/analysis/SetVar.java     |   12 +-
 .../org/apache/doris/analysis/ShowAlterStmt.java   |   30 +-
 .../apache/doris/analysis/ShowBackendsStmt.java    |    8 +-
 .../doris/analysis/ShowCreateFunctionStmt.java     |    8 +-
 .../org/apache/doris/analysis/ShowDataStmt.java    |   38 +-
 .../apache/doris/analysis/ShowEncryptKeysStmt.java |    2 +-
 .../org/apache/doris/analysis/ShowExportStmt.java  |    4 +-
 .../apache/doris/analysis/ShowFunctionsStmt.java   |    6 +-
 .../apache/doris/analysis/ShowPartitionsStmt.java  |   14 +-
 .../doris/analysis/ShowRepositoriesStmt.java       |    6 +-
 .../apache/doris/analysis/ShowResourcesStmt.java   |    2 +-
 .../doris/analysis/ShowRoutineLoadTaskStmt.java    |    4 +-
 .../apache/doris/analysis/ShowSmallFilesStmt.java  |    4 +-
 .../apache/doris/analysis/ShowStreamLoadStmt.java  |    2 +
 .../org/apache/doris/analysis/ShowTabletStmt.java  |   60 +-
 .../apache/doris/analysis/ShowTransactionStmt.java |    4 +-
 .../org/apache/doris/analysis/SlotDescriptor.java  |   29 +-
 .../java/org/apache/doris/analysis/SlotId.java     |    9 +-
 .../java/org/apache/doris/analysis/SlotRef.java    |    6 +-
 .../java/org/apache/doris/analysis/SortInfo.java   |   63 +-
 .../org/apache/doris/analysis/StatementBase.java   |    8 +-
 .../org/apache/doris/analysis/StmtRewriter.java    |   14 +-
 .../org/apache/doris/analysis/StorageDesc.java     |    8 +-
 .../java/org/apache/doris/analysis/Subquery.java   |   24 +-
 .../java/org/apache/doris/analysis/SyncStmt.java   |    7 +-
 .../java/org/apache/doris/analysis/TableRef.java   |    9 +-
 .../java/org/apache/doris/analysis/ToSqlUtils.java |    2 +-
 .../org/apache/doris/analysis/TupleDescriptor.java |   25 +-
 .../java/org/apache/doris/analysis/TupleId.java    |    9 +-
 .../doris/analysis/TupleIsNullPredicate.java       |    6 +-
 .../java/org/apache/doris/analysis/TypeDef.java    |  263 +--
 .../java/org/apache/doris/analysis/ValueList.java  |   14 +-
 .../java/org/apache/doris/analysis/WithClause.java |   18 +-
 .../org/apache/doris/backup/BackupHandler.java     |    4 +-
 .../java/org/apache/doris/backup/BackupJob.java    |    3 +-
 .../org/apache/doris/backup/BackupJobInfo.java     |    2 +-
 .../org/apache/doris/backup/BrokerStorage.java     |   46 +-
 .../java/org/apache/doris/backup/RestoreJob.java   |    8 +-
 .../apache/doris/blockrule/SqlBlockRuleMgr.java    |   16 +-
 .../apache/doris/catalog/AggregateFunction.java    |   98 +-
 .../java/org/apache/doris/catalog/Catalog.java     |   69 +-
 .../main/java/org/apache/doris/catalog/Column.java |   26 +-
 .../java/org/apache/doris/catalog/ColumnStats.java |   48 +-
 .../java/org/apache/doris/catalog/DiskInfo.java    |   10 +-
 .../doris/catalog/DynamicPartitionProperty.java    |   24 +-
 .../java/org/apache/doris/catalog/EsTable.java     |    4 +-
 .../java/org/apache/doris/catalog/Function.java    |   19 +-
 .../apache/doris/catalog/FunctionSearchDesc.java   |   14 +-
 .../java/org/apache/doris/catalog/FunctionSet.java |  689 +++---
 .../doris/catalog/HiveMetaStoreClientHelper.java   |    2 +-
 .../java/org/apache/doris/catalog/HiveTable.java   |    2 +-
 .../apache/doris/catalog/ListPartitionInfo.java    |   10 +-
 .../org/apache/doris/catalog/MetadataViewer.java   |    2 +-
 .../apache/doris/catalog/OdbcCatalogResource.java  |    2 +-
 .../java/org/apache/doris/catalog/OdbcTable.java   |    6 +-
 .../java/org/apache/doris/catalog/OlapTable.java   |   20 +-
 .../org/apache/doris/catalog/PartitionInfo.java    |    2 +-
 .../org/apache/doris/catalog/PartitionItem.java    |    2 +-
 .../org/apache/doris/catalog/PrimitiveType.java    |    2 +-
 .../apache/doris/catalog/RangePartitionInfo.java   |   11 +-
 .../org/apache/doris/catalog/ScalarFunction.java   |   38 +-
 .../java/org/apache/doris/catalog/ScalarType.java  |   45 +-
 .../java/org/apache/doris/catalog/SchemaTable.java |    2 +-
 .../main/java/org/apache/doris/catalog/Table.java  |    2 +-
 .../main/java/org/apache/doris/catalog/Tablet.java |   10 +-
 .../apache/doris/catalog/TabletInvertedIndex.java  |    4 +-
 .../main/java/org/apache/doris/catalog/Type.java   |   56 +-
 .../main/java/org/apache/doris/catalog/View.java   |   10 +-
 .../apache/doris/clone/BackendLoadStatistic.java   |   12 +-
 .../clone/ColocateTableCheckerAndBalancer.java     |    4 +-
 .../doris/clone/DynamicPartitionScheduler.java     |    2 +-
 .../apache/doris/clone/PartitionRebalancer.java    |   10 +-
 .../java/org/apache/doris/clone/TabletChecker.java |   16 +-
 .../org/apache/doris/clone/TabletSchedCtx.java     |    9 +-
 .../org/apache/doris/clone/TabletScheduler.java    |    7 +-
 .../clone/TwoDimensionalGreedyRebalanceAlgo.java   |   25 +-
 .../main/java/org/apache/doris/common/CIDR.java    |    8 +-
 .../java/org/apache/doris/common/ConfigBase.java   |    6 +-
 .../java/org/apache/doris/common/ErrorCode.java    | 2270 ++++++++++----------
 .../doris/common/LabelAlreadyUsedException.java    |   28 +-
 .../java/org/apache/doris/common/Log4jConfig.java  |  142 +-
 .../apache/doris/common/MarkedCountDownLatch.java  |    2 +-
 .../java/org/apache/doris/common/MetaFooter.java   |    4 +-
 .../java/org/apache/doris/common/MetaHeader.java   |    7 +-
 .../java/org/apache/doris/common/MetaReader.java   |    2 +-
 .../java/org/apache/doris/common/MetaWriter.java   |    2 +-
 .../java/org/apache/doris/common/ThriftServer.java |   21 +-
 .../java/org/apache/doris/common/TreeNode.java     |   43 +-
 .../apache/doris/common/parquet/ParquetReader.java |    1 -
 .../doris/common/proc/BdbjeDatabaseProcDir.java    |    2 +-
 .../common/proc/CurrentQueryInfoProvider.java      |    2 +-
 .../proc/CurrentQueryStatementsProcNode.java       |    3 -
 .../doris/common/proc/EsPartitionsProcDir.java     |    3 +-
 .../apache/doris/common/proc/ExportProcNode.java   |    3 +-
 .../doris/common/proc/PartitionsProcDir.java       |    6 +-
 .../apache/doris/common/proc/RollupProcDir.java    |    4 +-
 .../doris/common/proc/SchemaChangeProcDir.java     |    6 +-
 .../doris/common/proc/StatisticProcNode.java       |    4 -
 .../doris/common/proc/TabletHealthProcDir.java     |    4 +-
 .../org/apache/doris/common/proc/TrashProcDir.java |    1 -
 .../common/profile/MultiProfileTreeBuilder.java    |    5 +-
 .../doris/common/profile/ProfileTreeBuilder.java   |    4 +-
 .../org/apache/doris/common/util/BrokerUtil.java   |   14 +-
 .../java/org/apache/doris/common/util/Counter.java |    2 +-
 .../java/org/apache/doris/common/util/Daemon.java  |    4 +-
 .../org/apache/doris/common/util/DebugUtil.java    |    2 +-
 .../apache/doris/common/util/DigitalVersion.java   |    8 +-
 .../doris/common/util/DynamicPartitionUtil.java    |   48 +-
 .../org/apache/doris/common/util/KafkaUtil.java    |   10 +-
 .../org/apache/doris/common/util/ListUtil.java     |    4 +-
 .../org/apache/doris/common/util/NetUtils.java     |   11 +-
 .../org/apache/doris/common/util/PlatformName.java |    6 +-
 .../apache/doris/common/util/ProfileManager.java   |    7 +-
 .../apache/doris/common/util/PropertyAnalyzer.java |   16 +-
 .../org/apache/doris/common/util/RangeUtils.java   |    2 +-
 .../apache/doris/common/util/ReflectionUtils.java  |   14 +-
 .../org/apache/doris/common/util/SmallFileMgr.java |    3 +-
 .../org/apache/doris/common/util/SqlBlockUtil.java |   11 +-
 .../java/org/apache/doris/common/util/Util.java    |   10 +-
 .../doris/consistency/ConsistencyChecker.java      |    2 +-
 .../org/apache/doris/deploy/DeployManager.java     |    2 +-
 .../external/elasticsearch/EsMajorVersion.java     |    7 +-
 .../doris/external/elasticsearch/EsNodeInfo.java   |   26 +-
 .../external/elasticsearch/EsShardRouting.java     |   16 +-
 .../doris/external/iceberg/IcebergCatalogMgr.java  |    4 +-
 .../src/main/java/org/apache/doris/ha/BDBHA.java   |    2 +-
 .../org/apache/doris/httpv2/HttpAuthManager.java   |    2 +-
 .../java/org/apache/doris/httpv2/HttpServer.java   |   20 +-
 .../apache/doris/httpv2/IllegalArgException.java   |   20 +-
 .../apache/doris/httpv2/config/WebConfigurer.java  |    2 +-
 .../httpv2/controller/HardwareInfoController.java  |    7 +-
 .../doris/httpv2/controller/SystemController.java  |    3 +-
 .../org/apache/doris/httpv2/entity/RestResult.java |    2 +-
 .../httpv2/interceptor/ServletTraceIterceptor.java |    8 +-
 .../org/apache/doris/httpv2/rest/LoadAction.java   |    3 +-
 .../doris/httpv2/rest/RestBaseController.java      |    9 +-
 .../apache/doris/httpv2/rest/SetConfigAction.java  |    4 +-
 .../org/apache/doris/httpv2/rest/ShowAction.java   |    4 +-
 .../doris/httpv2/rest/manager/NodeAction.java      |    8 +-
 .../doris/httpv2/restv2/MetaInfoActionV2.java      |    6 +-
 .../org/apache/doris/httpv2/util/HttpUtil.java     |    8 +-
 .../apache/doris/httpv2/util/LoadSubmitter.java    |    2 +-
 .../doris/httpv2/util/StatementSubmitter.java      |    2 +-
 .../org/apache/doris/httpv2/util/TmpFileMgr.java   |    4 +-
 .../org/apache/doris/journal/JournalEntity.java    |    2 +-
 .../apache/doris/journal/bdbje/BDBEnvironment.java |    7 +-
 .../apache/doris/journal/bdbje/BDBJEJournal.java   |    4 +-
 .../org/apache/doris/ldap/LdapAuthenticate.java    |    4 +-
 .../org/apache/doris/load/BrokerFileGroup.java     |   16 +-
 .../apache/doris/load/BrokerFileGroupAggInfo.java  |    4 +-
 .../java/org/apache/doris/load/DeleteHandler.java  |   19 +-
 .../main/java/org/apache/doris/load/EtlStatus.java |   20 +-
 .../main/java/org/apache/doris/load/ExportJob.java |    4 +-
 .../src/main/java/org/apache/doris/load/Load.java  |    8 +-
 .../main/java/org/apache/doris/load/LoadJob.java   |   17 +-
 .../org/apache/doris/load/MysqlLoadErrorHub.java   |    2 +-
 .../org/apache/doris/load/StreamLoadRecordMgr.java |   63 +-
 .../doris/load/loadv2/BrokerLoadPendingTask.java   |    4 +-
 .../doris/load/loadv2/LoadJobFinalOperation.java   |   18 +-
 .../apache/doris/load/loadv2/LoadJobScheduler.java |    8 +-
 .../doris/load/loadv2/SparkEtlJobHandler.java      |    2 +-
 .../doris/load/loadv2/SparkLauncherMonitor.java    |    6 +-
 .../doris/load/loadv2/SparkLoadAppHandle.java      |   38 +-
 .../org/apache/doris/load/loadv2/SparkLoadJob.java |   14 +-
 .../load/loadv2/SparkPendingTaskAttachment.java    |    8 +-
 .../apache/doris/load/loadv2/SparkRepository.java  |   34 +-
 .../doris/load/loadv2/SparkYarnConfigFiles.java    |    2 +-
 .../load/routineload/KafkaRoutineLoadJob.java      |    6 +-
 .../doris/load/routineload/RoutineLoadJob.java     |   51 +-
 .../doris/load/routineload/RoutineLoadManager.java |    5 +-
 .../load/routineload/RoutineLoadTaskScheduler.java |    4 +-
 .../doris/load/routineload/ScheduleRule.java       |   16 +-
 .../org/apache/doris/load/sync/SyncChecker.java    |    2 +-
 .../org/apache/doris/load/sync/SyncJobManager.java |    2 +-
 .../doris/load/sync/canal/CanalDestination.java    |    8 +-
 .../doris/load/sync/canal/CanalSyncChannel.java    |   46 +-
 .../apache/doris/load/sync/canal/CanalSyncJob.java |    2 +-
 .../apache/doris/load/sync/canal/CanalUtils.java   |    3 +-
 .../doris/load/sync/position/EntryPosition.java    |    4 +-
 .../apache/doris/load/update/UpdatePlanner.java    |    4 +-
 .../java/org/apache/doris/master/MasterImpl.java   |    7 +-
 .../org/apache/doris/master/ReportHandler.java     |    9 +-
 .../org/apache/doris/metric/JsonMetricVisitor.java |    2 +-
 .../java/org/apache/doris/metric/MetricRepo.java   |    4 +-
 .../org/apache/doris/metric/SystemMetrics.java     |    2 +-
 .../java/org/apache/doris/monitor/jvm/JvmInfo.java |   25 +-
 .../apache/doris/monitor/jvm/JvmPauseMonitor.java  |   11 +-
 .../org/apache/doris/monitor/jvm/JvmStats.java     |   27 +-
 .../org/apache/doris/monitor/unit/TimeValue.java   |    2 +-
 .../apache/doris/mysql/MysqlHandshakePacket.java   |    2 +-
 .../java/org/apache/doris/mysql/MysqlPassword.java |    5 +-
 .../java/org/apache/doris/mysql/MysqlProto.java    |    4 +-
 .../org/apache/doris/mysql/MysqlSerializer.java    |    6 -
 .../org/apache/doris/mysql/privilege/PaloAuth.java |    2 +-
 .../doris/mysql/privilege/PaloPrivilege.java       |   16 +-
 .../apache/doris/mysql/privilege/UserProperty.java |    6 +-
 .../apache/doris/mysql/privilege/UserResource.java |    2 +-
 .../org/apache/doris/persist/AlterViewInfo.java    |    6 +-
 .../apache/doris/persist/BackendTabletsInfo.java   |    4 +-
 .../java/org/apache/doris/persist/DropInfo.java    |    2 +-
 .../apache/doris/persist/ModifyPartitionInfo.java  |    4 +-
 .../apache/doris/persist/ReplicaPersistInfo.java   |    8 +-
 .../java/org/apache/doris/persist/Storage.java     |    2 +-
 .../apache/doris/persist/TablePropertyInfo.java    |    1 -
 .../org/apache/doris/persist/gson/GsonUtils.java   |   13 +-
 .../org/apache/doris/planner/AggregationNode.java  |   14 +-
 .../org/apache/doris/planner/AnalyticEvalNode.java |   16 +-
 .../org/apache/doris/planner/AnalyticPlanner.java  |   53 +-
 .../org/apache/doris/planner/BrokerScanNode.java   |    1 -
 .../org/apache/doris/planner/DataPartition.java    |    9 +-
 .../java/org/apache/doris/planner/DataSink.java    |   11 +-
 .../org/apache/doris/planner/DataStreamSink.java   |    2 +-
 .../apache/doris/planner/DistributedPlanner.java   |    6 +-
 .../org/apache/doris/planner/EmptySetNode.java     |    2 +-
 .../org/apache/doris/planner/ExchangeNode.java     |    4 +-
 .../org/apache/doris/planner/HashJoinNode.java     |    8 +-
 .../org/apache/doris/planner/HiveScanNode.java     |    8 +-
 .../apache/doris/planner/JoinCostEvaluation.java   |    2 +-
 .../apache/doris/planner/ListPartitionPruner.java  |    1 -
 .../doris/planner/ListPartitionPrunerV2.java       |   29 +-
 .../doris/planner/MaterializedViewSelector.java    |    4 +-
 .../org/apache/doris/planner/OdbcScanNode.java     |    7 +-
 .../org/apache/doris/planner/OdbcTableSink.java    |    2 +-
 .../org/apache/doris/planner/OlapScanNode.java     |   18 +-
 .../org/apache/doris/planner/OlapTableSink.java    |    2 +-
 .../doris/planner/PartitionColumnFilter.java       |    8 +-
 .../doris/planner/PartitionPrunerV2Base.java       |    9 +-
 .../org/apache/doris/planner/PlanFragment.java     |    4 +-
 .../org/apache/doris/planner/PlanFragmentId.java   |    9 +-
 .../java/org/apache/doris/planner/PlanNode.java    |   27 +-
 .../java/org/apache/doris/planner/PlanNodeId.java  |    9 +-
 .../java/org/apache/doris/planner/Planner.java     |    8 +-
 .../org/apache/doris/planner/PlannerContext.java   |   33 +-
 .../doris/planner/RangePartitionPrunerV2.java      |   32 +-
 .../org/apache/doris/planner/ResultFileSink.java   |    4 +-
 .../org/apache/doris/planner/RollupSelector.java   |    8 +-
 .../org/apache/doris/planner/RuntimeFilter.java    |  106 +-
 .../doris/planner/RuntimeFilterGenerator.java      |   20 +-
 .../java/org/apache/doris/planner/ScanNode.java    |   10 +-
 .../org/apache/doris/planner/SetOperationNode.java |    8 +-
 .../apache/doris/planner/StreamLoadPlanner.java    |    2 +-
 .../apache/doris/planner/StreamLoadScanNode.java   |    4 +-
 .../apache/doris/plugin/DynamicPluginLoader.java   |    2 +-
 .../java/org/apache/doris/plugin/PluginInfo.java   |   18 +-
 .../java/org/apache/doris/plugin/PluginZip.java    |    4 +-
 .../java/org/apache/doris/qe/AuditLogBuilder.java  |   26 +-
 .../java/org/apache/doris/qe/ConnectContext.java   |    1 -
 .../java/org/apache/doris/qe/ConnectProcessor.java |    4 +-
 .../java/org/apache/doris/qe/ConnectScheduler.java |    4 +-
 .../main/java/org/apache/doris/qe/Coordinator.java |   15 +-
 .../main/java/org/apache/doris/qe/DdlExecutor.java |    4 +-
 .../java/org/apache/doris/qe/GlobalVariable.java   |    4 +-
 .../main/java/org/apache/doris/qe/HelpModule.java  |    2 +-
 .../org/apache/doris/qe/JournalObservable.java     |    2 +-
 .../java/org/apache/doris/qe/MasterOpExecutor.java |    2 +-
 .../java/org/apache/doris/qe/MultiLoadMgr.java     |    8 +-
 .../java/org/apache/doris/qe/QeProcessorImpl.java  |    8 +-
 .../java/org/apache/doris/qe/QueryDetailQueue.java |    2 +-
 .../org/apache/doris/qe/QueryStatisticsItem.java   |    2 +-
 .../apache/doris/qe/RuntimeFilterTypeHelper.java   |    7 +-
 .../java/org/apache/doris/qe/SessionVariable.java  |   18 +-
 .../main/java/org/apache/doris/qe/SetExecutor.java |    2 +-
 .../java/org/apache/doris/qe/ShowExecutor.java     |   14 +-
 .../java/org/apache/doris/qe/ShowResultSet.java    |    8 +-
 .../java/org/apache/doris/qe/SimpleScheduler.java  |    8 +-
 .../java/org/apache/doris/qe/SqlModeHelper.java    |   27 +-
 .../java/org/apache/doris/qe/StmtExecutor.java     |   25 +-
 .../org/apache/doris/qe/cache/CacheAnalyzer.java   |   15 +-
 .../org/apache/doris/qe/cache/CacheBeProxy.java    |    2 +-
 .../org/apache/doris/qe/cache/PartitionRange.java  |    1 +
 .../org/apache/doris/rewrite/ExprRewriter.java     |   18 +-
 .../doris/rewrite/ExtractCommonFactorsRule.java    |   12 +-
 .../java/org/apache/doris/rewrite/FEFunctions.java |    2 +-
 .../apache/doris/rewrite/FoldConstantsRule.java    |    6 +-
 .../org/apache/doris/rewrite/InferFiltersRule.java |   75 +-
 .../doris/rewrite/RewriteAliasFunctionRule.java    |    2 +-
 .../apache/doris/rewrite/mvrewrite/NDVToHll.java   |    2 +-
 .../apache/doris/service/FrontendServiceImpl.java  |    1 +
 .../doris/statistics/OlapScanStatsDerive.java      |    4 +-
 .../org/apache/doris/statistics/StatisticsJob.java |    8 +-
 .../doris/statistics/StatisticsJobManager.java     |    4 +-
 .../apache/doris/statistics/StatisticsTask.java    |    8 +-
 .../doris/statistics/StatisticsTaskScheduler.java  |    2 +-
 .../java/org/apache/doris/system/Diagnoser.java    |    6 +-
 .../apache/doris/task/ClearTransactionTask.java    |    2 +-
 .../org/apache/doris/task/CreateReplicaTask.java   |    2 +-
 .../apache/doris/task/HadoopLoadPendingTask.java   |    2 +-
 .../main/java/org/apache/doris/task/PushTask.java  |   14 +-
 .../doris/transaction/DatabaseTransactionMgr.java  |   38 +-
 .../doris/transaction/GlobalTransactionMgr.java    |    9 +-
 .../transaction/TabletQuorumFailedException.java   |    5 +-
 .../apache/doris/transaction/TransactionState.java |    6 +-
 .../org/apache/doris/alter/AlterJobV2Test.java     |   84 +-
 .../java/org/apache/doris/alter/AlterTest.java     |  624 +++---
 .../doris/alter/MaterializedViewHandlerTest.java   |    1 -
 .../apache/doris/alter/SchemaChangeJobV2Test.java  |    7 +-
 .../org/apache/doris/analysis/AccessTestUtil.java  |    6 +-
 .../analysis/AdminCancelRebalanceDiskStmtTest.java |    2 +-
 .../doris/analysis/AdminRebalanceDiskStmtTest.java |    2 +-
 .../doris/analysis/AdminSetConfigStmtTest.java     |    6 +-
 .../doris/analysis/AdminShowReplicaTest.java       |   17 +-
 .../org/apache/doris/analysis/AggregateTest.java   |   44 +-
 .../doris/analysis/AlterRoutineLoadStmtTest.java   |   28 +-
 .../apache/doris/analysis/AlterTableStmtTest.java  |    5 +-
 .../doris/analysis/BetweenPredicateTest.java       |    1 +
 .../org/apache/doris/analysis/ColumnDefTest.java   |   10 +-
 .../doris/analysis/ComparisonPredicateTest.java    |    3 +
 .../doris/analysis/CreateDataSyncJobStmtTest.java  |    1 +
 .../apache/doris/analysis/CreateDbStmtTest.java    |   10 +-
 .../analysis/CreateMaterializedViewStmtTest.java   |   10 +-
 .../doris/analysis/CreateRoutineLoadStmtTest.java  |    6 +-
 .../apache/doris/analysis/CreateTableStmtTest.java |   12 +-
 .../apache/doris/analysis/DataDescriptionTest.java |    6 +-
 .../org/apache/doris/analysis/DateLiteralTest.java |   12 +-
 .../org/apache/doris/analysis/ExplainTest.java     |   48 +-
 .../apache/doris/analysis/GroupByClauseTest.java   |   12 +-
 .../apache/doris/analysis/InsertArrayStmtTest.java |   14 +-
 .../org/apache/doris/analysis/InsertStmtTest.java  |   34 +-
 .../doris/analysis/InstallPluginStmtTest.java      |    4 +-
 .../doris/analysis/ListPartitionPrunerTest.java    |   82 +-
 .../doris/analysis/LiteralExprCompareTest.java     |    4 +-
 .../org/apache/doris/analysis/LoadStmtTest.java    |    8 +-
 .../doris/analysis/PartitionPruneTestBase.java     |    5 +-
 .../org/apache/doris/analysis/QueryStmtTest.java   |  360 ++--
 .../apache/doris/analysis/RangeCompareTest.java    |    4 +-
 .../doris/analysis/RangePartitionPruneTest.java    |  142 +-
 .../RoutineLoadDataSourcePropertiesTest.java       |   10 +-
 .../org/apache/doris/analysis/SelectStmtTest.java  |  653 +++---
 .../apache/doris/analysis/ShowAlterStmtTest.java   |    6 +-
 .../doris/analysis/ShowPartitionsStmtTest.java     |    4 +-
 .../apache/doris/analysis/ShowViewStmtTest.java    |  116 +-
 .../apache/doris/analysis/StmtRewriterTest.java    |   37 +-
 .../analysis/TableNameComparedLowercaseTest.java   |   44 +-
 .../analysis/TableNameStoredLowercaseTest.java     |   48 +-
 .../org/apache/doris/backup/BrokerStorageTest.java |   34 +-
 .../org/apache/doris/backup/CatalogMocker.java     |    2 +-
 .../org/apache/doris/backup/RestoreJobTest.java    |    2 +-
 .../org/apache/doris/backup/S3StorageTest.java     |   28 +-
 .../doris/blockrule/SqlBlockRuleMgrTest.java       |   58 +-
 .../org/apache/doris/catalog/AdminStmtTest.java    |   18 +-
 .../apache/doris/catalog/CatalogOperationTest.java |   68 +-
 .../java/org/apache/doris/catalog/CatalogTest.java |    2 +-
 .../org/apache/doris/catalog/CatalogTestUtil.java  |    1 -
 .../apache/doris/catalog/ColocateTableTest.java    |  273 +--
 .../java/org/apache/doris/catalog/ColumnTest.java  |    4 +-
 .../apache/doris/catalog/CreateEncryptKeyTest.java |    2 +-
 .../apache/doris/catalog/CreateFunctionTest.java   |   36 +-
 .../org/apache/doris/catalog/CreateTableTest.java  |  222 +-
 .../org/apache/doris/catalog/CreateViewTest.java   |    4 +-
 .../org/apache/doris/catalog/DatabaseTest.java     |    2 +-
 .../doris/catalog/DynamicPartitionTableTest.java   | 1987 ++++++++---------
 .../apache/doris/catalog/ModifyBackendTest.java    |   77 +-
 .../org/apache/doris/catalog/PartitionKeyTest.java |    2 +-
 .../java/org/apache/doris/catalog/RecoverTest.java |  104 +-
 .../doris/catalog/ReplicaAllocationTest.java       |    4 +-
 .../org/apache/doris/catalog/S3ResourceTest.java   |    2 +-
 .../java/org/apache/doris/catalog/TableTest.java   |    3 +-
 .../apache/doris/catalog/TempPartitionTest.java    |   85 +-
 .../apache/doris/catalog/TruncateTableTest.java    |   54 +-
 .../org/apache/doris/clone/DiskRebalanceTest.java  |    3 +-
 .../java/org/apache/doris/clone/RebalanceTest.java |   10 +-
 .../org/apache/doris/clone/RebalancerTestUtil.java |    4 +-
 .../doris/clone/TabletRepairAndBalanceTest.java    |  160 +-
 .../doris/clone/TabletReplicaTooSlowTest.java      |   14 +-
 .../TwoDimensionalGreedyRebalanceAlgoTest.java     |    8 +-
 .../java/org/apache/doris/common/CidrTest.java     |   12 +-
 .../apache/doris/common/MarkDownParserTest.java    |    2 +-
 .../apache/doris/common/PatternMatcherTest.java    |    8 +-
 .../apache/doris/common/PropertyAnalyzerTest.java  |    8 +-
 .../doris/common/parquet/ParquetReaderTest.java    |    2 +-
 .../doris/common/proc/BackendsProcDirTest.java     |    5 +-
 .../apache/doris/common/proc/DbsProcDirTest.java   |    5 +-
 .../apache/doris/common/util/BrokerUtilTest.java   |   17 +-
 .../org/apache/doris/common/util/ListUtilTest.java |    6 +-
 .../external/elasticsearch/EsNodeInfoTest.java     |    4 +-
 .../external/elasticsearch/MappingPhaseTest.java   |    2 +-
 .../org/apache/doris/http/DorisHttpTestCase.java   |    1 +
 .../org/apache/doris/http/HttpAuthManagerTest.java |    4 +-
 .../org/apache/doris/load/DeleteHandlerTest.java   |   12 +-
 .../org/apache/doris/load/DppSchedulerTest.java    |    5 -
 .../java/org/apache/doris/load/LoadJobTest.java    |    8 +-
 .../doris/load/loadv2/BrokerLoadJobTest.java       |    4 +-
 .../org/apache/doris/load/loadv2/LoadJobTest.java  |    1 +
 .../apache/doris/load/loadv2/LoadManagerTest.java  |    4 +-
 .../doris/load/loadv2/SparkEtlJobHandlerTest.java  |   95 +-
 .../load/loadv2/SparkLauncherMonitorTest.java      |    1 +
 .../load/loadv2/SparkLoadPendingTaskTest.java      |    2 -
 .../doris/load/loadv2/SparkRepositoryTest.java     |   55 +-
 .../load/loadv2/YarnApplicationReportTest.java     |   28 +-
 .../doris/load/routineload/KafkaProducerTest.java  |    4 +-
 .../load/routineload/KafkaRoutineLoadJobTest.java  |   13 +-
 .../doris/load/routineload/RoutineLoadJobTest.java |   58 +-
 .../load/routineload/RoutineLoadManagerTest.java   |   14 +-
 .../load/routineload/RoutineLoadSchedulerTest.java |   13 +-
 .../doris/load/sync/canal/CanalTestUtil.java       |    2 +-
 .../org/apache/doris/mysql/MysqlChannelTest.java   |    4 +-
 .../apache/doris/persist/CreateTableInfoTest.java  |    2 +-
 .../org/apache/doris/persist/FsBrokerTest.java     |    1 -
 .../persist/ReplaceTableOperationLogTest.java      |    2 +-
 .../doris/persist/ReplicaPersistInfoTest.java      |    2 +-
 .../apache/doris/planner/ConstantExpressTest.java  |    3 +-
 .../planner/MaterializedViewFunctionTest.java      |  186 +-
 .../org/apache/doris/planner/OlapScanNodeTest.java |   39 +-
 .../apache/doris/planner/OlapTableSinkTest.java    |   80 +-
 .../java/org/apache/doris/planner/PlannerTest.java |  180 +-
 .../org/apache/doris/planner/QueryPlanTest.java    | 1128 +++++-----
 .../apache/doris/planner/ResourceTagQueryTest.java |   18 +-
 .../doris/planner/RuntimeFilterGeneratorTest.java  |  224 +-
 .../doris/planner/StreamLoadScanNodeTest.java      |  179 +-
 .../doris/planner/TableFunctionPlanTest.java       |    4 +-
 .../apache/doris/planner/UpdatePlannerTest.java    |    4 +-
 .../org/apache/doris/plugin/PluginZipTest.java     |    2 +-
 .../org/apache/doris/qe/ConnectProcessorTest.java  |   20 +-
 .../java/org/apache/doris/qe/CoordinatorTest.java  |   27 +-
 .../org/apache/doris/qe/JournalObservableTest.java |   32 +-
 .../org/apache/doris/qe/PartitionCacheTest.java    |  174 +-
 .../java/org/apache/doris/qe/ShowExecutorTest.java |    9 +-
 .../java/org/apache/doris/qe/StmtExecutorTest.java |    4 +-
 .../java/org/apache/doris/qe/VariableMgrTest.java  |    5 +-
 .../doris/resource/TagSerializationTest.java       |    2 +-
 .../java/org/apache/doris/resource/TagTest.java    |    4 +-
 .../ExtractCommonFactorsRuleFunctionTest.java      |   90 +-
 .../org/apache/doris/rewrite/FEFunctionsTest.java  |    4 +-
 .../doris/rewrite/RewriteDateLiteralRuleTest.java  |    1 -
 .../rewrite/mvrewrite/CountFieldToSumTest.java     |    2 +-
 .../org/apache/doris/service/ExecuteEnvTest.java   |    4 +-
 .../java/org/apache/doris/task/AgentTaskTest.java  |    2 +-
 .../org/apache/doris/task/LoadEtlTaskTest.java     |    1 -
 .../doris/task/SerialExecutorServiceTest.java      |    1 +
 .../transaction/GlobalTransactionMgrTest.java      |    9 +-
 .../doris/utframe/DemoMultiBackendsTest.java       |    5 +-
 .../java/org/apache/doris/utframe/DorisAssert.java |    2 +-
 .../apache/doris/utframe/MockedBackendFactory.java |   11 +-
 .../org/apache/doris/utframe/UtFrameUtils.java     |    4 +-
 .../org/apache/doris/common/BitmapValueUtil.java   |    2 +-
 .../java/org/apache/doris/udf/BitmapAndUDF.java    |    6 +-
 .../java/org/apache/doris/udf/BitmapCountUDF.java  |    6 +-
 .../java/org/apache/doris/udf/BitmapOrUDF.java     |    6 +-
 .../java/org/apache/doris/udf/BitmapUnionUDAF.java |    4 +-
 .../java/org/apache/doris/udf/BitmapXorUDF.java    |    6 +-
 .../java/org/apache/doris/udf/ToBitmapUDAF.java    |    4 +-
 .../java/org/apache/doris/udf/JMXJsonUtil.java     |    1 -
 .../main/java/org/apache/doris/udf/JniUtil.java    |   16 +-
 .../java/org/apache/doris/udf/UdfExecutor.java     |   10 +-
 .../java/org/apache/doris/udf/SimpleAddUdf.java    |    2 +-
 .../java/org/apache/doris/udf/StringConcatUdf.java |    2 +-
 .../java/org/apache/doris/udf/UdfExecutorTest.java |   24 +-
 .../load/loadv2/dpp/DorisRangePartitioner.java     |   12 +-
 .../apache/doris/load/loadv2/dpp/DppColumns.java   |   28 +-
 .../org/apache/doris/load/loadv2/dpp/DppUtils.java |   10 +-
 .../doris/load/loadv2/dpp/GlobalDictBuilder.java   |   29 +-
 .../dpp/MinimumCoverageRollupTreeBuilder.java      |    4 +-
 .../org/apache/doris/load/loadv2/dpp/SparkDpp.java |  194 +-
 .../doris/load/loadv2/dpp/SparkRDDAggregator.java  |   24 +-
 .../doris/load/loadv2/dpp/StringAccumulator.java   |    2 +-
 .../apache/doris/load/loadv2/etl/EtlJobConfig.java |  138 +-
 .../apache/doris/load/loadv2/etl/SparkEtlJob.java  |    8 +-
 .../load/loadv2/dpp/DorisRangePartitionerTest.java |    2 -
 .../apache/doris/load/loadv2/dpp/DppUtilsTest.java |    2 +-
 549 files changed, 9229 insertions(+), 8692 deletions(-)

diff --git a/fe/check/checkstyle/checkstyle.xml b/fe/check/checkstyle/checkstyle.xml
index 1bd1436b66..b941c376b7 100644
--- a/fe/check/checkstyle/checkstyle.xml
+++ b/fe/check/checkstyle/checkstyle.xml
@@ -94,16 +94,17 @@ under the License.
         <module name="MissingOverride">
             <property name="severity" value="error"/>
         </module>
-        <module name="MissingDeprecated"/>
 
         <!-- Block Checks -->
         <module name="EmptyBlock">
             <property name="option" value="TEXT"/>
             <property name="tokens"
                       value="LITERAL_TRY, LITERAL_FINALLY, LITERAL_IF, LITERAL_ELSE, LITERAL_SWITCH"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="EmptyCatchBlock">
             <property name="exceptionVariableName" value="expected"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="NeedBraces">
             <property name="tokens"
@@ -117,12 +118,14 @@ under the License.
                     LITERAL_DO, LITERAL_ELSE, LITERAL_FINALLY, LITERAL_FOR, LITERAL_IF,
                     LITERAL_SWITCH, LITERAL_SYNCHRONIZED, LITERAL_TRY, LITERAL_WHILE, METHOD_DEF,
                     OBJBLOCK, STATIC_INIT, RECORD_DEF, COMPACT_CTOR_DEF"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="RightCurly">
             <property name="id" value="RightCurlySame"/>
             <property name="tokens"
                       value="LITERAL_TRY, LITERAL_CATCH, LITERAL_FINALLY, LITERAL_IF, LITERAL_ELSE,
                     LITERAL_DO"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="RightCurly">
             <property name="id" value="RightCurlyAlone"/>
@@ -131,6 +134,7 @@ under the License.
                       value="CLASS_DEF, METHOD_DEF, CTOR_DEF, LITERAL_FOR, LITERAL_WHILE, STATIC_INIT,
                     INSTANCE_INIT, ANNOTATION_DEF, ENUM_DEF, INTERFACE_DEF, RECORD_DEF,
                     COMPACT_CTOR_DEF"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="SuppressionXpathSingleFilter">
             <!-- suppresion is required till https://github.com/checkstyle/checkstyle/issues/7541 -->
@@ -153,18 +157,27 @@ under the License.
                       value="\\u00(09|0(a|A)|0(c|C)|0(d|D)|22|27|5(C|c))|\\(0(10|11|12|14|15|42|47)|134)"/>
             <property name="message"
                       value="Consider using special escape sequence instead of octal value or Unicode escaped value."/>
+            <property name="severity" value="error"/>
         </module>
         <module name="MissingSwitchDefault">
             <property name="severity" value="error"/>
         </module>
-        <module name="MultipleVariableDeclarations"/>
+        <module name="MultipleVariableDeclarations">
+            <property name="severity" value="error"/>
+        </module>
         <module name="NoFinalizer">
             <property name="severity" value="error"/>
         </module>
-        <module name="OneStatementPerLine"/>
+        <module name="OneStatementPerLine">
+            <property name="severity" value="error"/>
+        </module>
         <module name="OverloadMethodsDeclarationOrder"/>
-        <module name="StringLiteralEquality"/>
-        <module name="UnusedLocalVariable"/>
+        <module name="StringLiteralEquality">
+            <property name="severity" value="error"/>
+        </module>
+        <module name="UnusedLocalVariable">
+            <property name="severity" value="error"/>
+        </module>
         <module name="VariableDeclarationUsageDistance"/>
 
         <!-- Headers -->
@@ -244,6 +257,7 @@ under the License.
         </module>
         <module name="CommentsIndentation">
             <property name="tokens" value="SINGLE_LINE_COMMENT, BLOCK_COMMENT_BEGIN"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="Indentation">
             <property name="basicOffset" value="4"/>
@@ -252,8 +266,11 @@ under the License.
             <property name="throwsIndent" value="8"/>
             <property name="lineWrappingIndentation" value="8"/>
             <property name="arrayInitIndent" value="4"/>
+            <property name="severity" value="error"/>
+        </module>
+        <module name="OuterTypeFilename">
+            <property name="severity" value="error"/>
         </module>
-        <module name="OuterTypeFilename"/>
         <module name="UpperEll">
             <property name="severity" value="error"/>
         </module>
@@ -376,11 +393,13 @@ under the License.
                      value="GenericWhitespace ''{0}'' should followed by whitespace."/>
             <message key="ws.notPreceded"
                      value="GenericWhitespace ''{0}'' is not preceded with whitespace."/>
+            <property name="severity" value="error"/>
         </module>
         <module name="MethodParamPad">
             <property name="tokens"
                       value="CTOR_DEF, LITERAL_NEW, METHOD_CALL, METHOD_DEF,
                     SUPER_CTOR_CALL, ENUM_CONSTANT_DEF, RECORD_DEF"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="NoLineWrap">
             <property name="tokens" value="PACKAGE_DEF, IMPORT, STATIC_IMPORT"/>
@@ -391,14 +410,18 @@ under the License.
                       value="COMMA, SEMI, POST_INC, POST_DEC, DOT,
                     LABELED_STAT, METHOD_REF"/>
             <property name="allowLineBreaks" value="true"/>
+            <property name="severity" value="error"/>
+        </module>
+        <module name="NoWhitespaceBeforeCaseDefaultColon">
+            <property name="severity" value="error"/>
         </module>
-        <module name="NoWhitespaceBeforeCaseDefaultColon"/>
         <module name="OperatorWrap">
             <property name="option" value="NL"/>
             <property name="tokens"
                       value="BAND, BOR, BSR, BXOR, DIV, EQUAL, GE, GT, LAND, LE, LITERAL_INSTANCEOF, LOR,
                     LT, MINUS, MOD, NOT_EQUAL, PLUS, QUESTION, SL, SR, STAR, METHOD_REF,
                     TYPE_EXTENSION_AND "/>
+            <property name="severity" value="error"/>
         </module>
         <module name="ParenPad">
             <property name="tokens"
@@ -407,6 +430,7 @@ under the License.
                     LITERAL_SWITCH, LITERAL_SYNCHRONIZED, LITERAL_WHILE, METHOD_CALL,
                     METHOD_DEF, QUESTION, RESOURCE_SPECIFICATION, SUPER_CTOR_CALL, LAMBDA,
                     RECORD_DEF"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="SeparatorWrap">
             <property name="id" value="SeparatorWrapDot"/>
@@ -439,6 +463,7 @@ under the License.
             <property name="tokens"
                       value="COMMA, SEMI, TYPECAST, LITERAL_IF, LITERAL_ELSE,
                     LITERAL_WHILE, LITERAL_DO, LITERAL_FOR, DO_WHILE"/>
+            <property name="severity" value="error"/>
         </module>
         <module name="WhitespaceAround">
             <property name="allowEmptyConstructors" value="true"/>
@@ -455,6 +480,7 @@ under the License.
                     LITERAL_TRY, LITERAL_WHILE, LOR, LT, MINUS, MINUS_ASSIGN, MOD, MOD_ASSIGN,
                     NOT_EQUAL, PLUS, PLUS_ASSIGN, QUESTION, RCURLY, SL, SLIST, SL_ASSIGN, SR,
                     SR_ASSIGN, STAR, STAR_ASSIGN, LITERAL_ASSERT, TYPE_EXTENSION_AND"/>
+            <property name="severity" value="error"/>
             <message key="ws.notFollowed"
                      value="WhitespaceAround: ''{0}'' is not followed by whitespace. Empty blocks may only be represented as '{}' when not part of a multi-block statement (4.1.3)"/>
             <message key="ws.notPreceded"
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/io/BitmapValue.java b/fe/fe-common/src/main/java/org/apache/doris/common/io/BitmapValue.java
index bef2fba4f4..cd6de7b3de 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/io/BitmapValue.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/io/BitmapValue.java
@@ -116,7 +116,7 @@ public class BitmapValue {
                 // FE is big end but BE is little end.
                 if (isLongValue32bitEnough(singleValue)) {
                     output.write(SINGLE32);
-                    output.writeInt(Integer.reverseBytes((int)singleValue));
+                    output.writeInt(Integer.reverseBytes((int) singleValue));
                 } else {
                     output.writeByte(SINGLE64);
                     output.writeLong(Long.reverseBytes(singleValue));
@@ -227,12 +227,12 @@ public class BitmapValue {
         }
     }
 
-    public void remove(long value){
+    public void remove(long value) {
         switch (this.bitmapType) { // CHECKSTYLE IGNORE THIS LINE: missing switch default
             case EMPTY:
                 break;
             case SINGLE_VALUE:
-                if(this.singleValue == value) {
+                if (this.singleValue == value) {
                     clear();
                 }
                 break;
@@ -256,7 +256,7 @@ public class BitmapValue {
                     case EMPTY:
                         break;
                     case SINGLE_VALUE:
-                        if(other.bitmap.contains(this.singleValue)){
+                        if (other.bitmap.contains(this.singleValue)) {
                             clear();
                         }
                         break;
@@ -280,16 +280,16 @@ public class BitmapValue {
                         add(other.singleValue);
                         break;
                     case SINGLE_VALUE:
-                        if(this.singleValue != other.singleValue){
+                        if (this.singleValue != other.singleValue) {
                             add(other.singleValue);
-                        }else{
+                        } else {
                             clear();
                         }
                         break;
                     case BITMAP_VALUE:
-                        if(!this.bitmap.contains(other.singleValue)){
+                        if (!this.bitmap.contains(other.singleValue)) {
                             this.bitmap.add(other.singleValue);
-                        }else{
+                        } else {
                             this.bitmap.removeLong(other.singleValue);
                             convertToSmallerType();
                         }
@@ -305,9 +305,9 @@ public class BitmapValue {
                     case SINGLE_VALUE:
                         this.bitmap = other.bitmap;
                         this.bitmapType = BITMAP_VALUE;
-                        if(this.bitmap.contains(this.singleValue)){
+                        if (this.bitmap.contains(this.singleValue)) {
                             this.bitmap.removeLong(this.singleValue);
-                        }else{
+                        } else {
                             this.bitmap.add(this.bitmapType);
                         }
                         break;
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/io/CountingDataOutputStream.java b/fe/fe-common/src/main/java/org/apache/doris/common/io/CountingDataOutputStream.java
index eea57f0900..bb770bea52 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/io/CountingDataOutputStream.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/io/CountingDataOutputStream.java
@@ -38,7 +38,7 @@ public class CountingDataOutputStream extends DataOutputStream {
     }
 
     public long getCount() {
-        return ((CountingOutputStream)this.out).getCount();
+        return ((CountingOutputStream) this.out).getCount();
     }
 
     public void close() throws IOException {
@@ -59,7 +59,7 @@ public class CountingDataOutputStream extends DataOutputStream {
 
         public void write(byte[] b, int off, int len) throws IOException {
             this.out.write(b, off, len);
-            this.count += (long)len;
+            this.count += len;
         }
 
         public void write(int b) throws IOException {
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/io/Hll.java b/fe/fe-common/src/main/java/org/apache/doris/common/io/Hll.java
index ed02b0a489..b00912598d 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/io/Hll.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/io/Hll.java
@@ -83,7 +83,7 @@ public class Hll {
         hashValue >>>= HLL_COLUMN_PRECISION;
         hashValue |= (1L << HLL_ZERO_COUNT_BITS);
         byte firstOneBit = (byte) (getLongTailZeroNum(hashValue) + 1);
-        registers[idx] = registers[idx] > firstOneBit ? registers[idx] : firstOneBit ;
+        registers[idx] = registers[idx] > firstOneBit ? registers[idx] : firstOneBit;
     }
 
     private void mergeRegisters(byte[] other) {
@@ -217,7 +217,7 @@ public class Hll {
                     output.writeInt(Integer.reverseBytes(nonZeroRegisterNum));
                     for (int i = 0; i < HLL_REGISTERS_COUNT; i++) {
                         if (registers[i] != 0) {
-                            output.writeShort(Short.reverseBytes((short)i));
+                            output.writeShort(Short.reverseBytes((short) i));
                             output.writeByte(registers[i]);
                         }
                     }
@@ -303,20 +303,20 @@ public class Hll {
         double estimate = alpha * numStreams * numStreams * harmonicMean;
 
         if (estimate <= numStreams * 2.5 && numZeroRegisters != 0) {
-            estimate = numStreams * Math.log(((float)numStreams) / ((float)numZeroRegisters));
+            estimate = numStreams * Math.log(((float) numStreams) / ((float) numZeroRegisters));
         } else if (numStreams == 16384 && estimate < 72000) {
             double bias = 5.9119 * 1.0e-18 * (estimate * estimate * estimate * estimate)
-                    - 1.4253 * 1.0e-12 * (estimate * estimate * estimate) +
-                    1.2940 * 1.0e-7 * (estimate * estimate)
-                    - 5.2921 * 1.0e-3 * estimate +
-                    83.3216;
+                    - 1.4253 * 1.0e-12 * (estimate * estimate * estimate)
+                    + 1.2940 * 1.0e-7 * (estimate * estimate)
+                    - 5.2921 * 1.0e-3 * estimate
+                    + 83.3216;
             estimate -= estimate * (bias / 100);
         }
 
-        return (long)(estimate + 0.5);
+        return (long) (estimate + 0.5);
     }
 
-    public int maxSerializedSize () {
+    public int maxSerializedSize() {
         switch (type) {
             case HLL_DATA_EMPTY:
             default:
@@ -335,14 +335,14 @@ public class Hll {
 
 
     private static long getLittleEndianLong(final byte[] data, final int index) {
-        return (((long) data[index    ] & 0xff)      ) |
-                (((long) data[index + 1] & 0xff) <<  8) |
-                (((long) data[index + 2] & 0xff) << 16) |
-                (((long) data[index + 3] & 0xff) << 24) |
-                (((long) data[index + 4] & 0xff) << 32) |
-                (((long) data[index + 5] & 0xff) << 40) |
-                (((long) data[index + 6] & 0xff) << 48) |
-                (((long) data[index + 7] & 0xff) << 56);
+        return (((long) data[index    ] & 0xff))
+                | (((long) data[index + 1] & 0xff) <<  8)
+                | (((long) data[index + 2] & 0xff) << 16)
+                | (((long) data[index + 3] & 0xff) << 24)
+                | (((long) data[index + 4] & 0xff) << 32)
+                | (((long) data[index + 5] & 0xff) << 40)
+                | (((long) data[index + 6] & 0xff) << 48)
+                | (((long) data[index + 7] & 0xff) << 56);
     }
 
     public static long hash64(final byte[] data, final int length, final int seed) {
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/io/IOUtils.java b/fe/fe-common/src/main/java/org/apache/doris/common/io/IOUtils.java
index 137315eddf..ffd2330bd3 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/io/IOUtils.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/io/IOUtils.java
@@ -100,6 +100,7 @@ public class IOUtils {
                         try {
                             Thread.sleep(sleepTime);
                         } catch (InterruptedException ie) {
+                            // CHECKSTYLE IGNORE THIS LINE
                         }
                     }
                 }
@@ -250,6 +251,7 @@ public class IOUtils {
             try {
                 sock.close();
             } catch (IOException ignored) {
+                // CHECKSTYLE IGNORE THIS LINE
             }
         }
     }
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/io/LimitOutputStream.java b/fe/fe-common/src/main/java/org/apache/doris/common/io/LimitOutputStream.java
index 648f2e49ee..e71af2dbbd 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/io/LimitOutputStream.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/io/LimitOutputStream.java
@@ -72,39 +72,35 @@ public class LimitOutputStream extends OutputStream {
     public void write(byte[] b, int off, int len) throws IOException {
         long sleepTime = 0;
         long curTime = 0;
-        try {
-            if ((off | len | (off + len) | (b.length - (off + len))) < 0) {
-                throw new IndexOutOfBoundsException();
-            } else if (len == 0) {
-                return;
-            }
+        if ((off | len | (off + len) | (b.length - (off + len))) < 0) {
+            throw new IndexOutOfBoundsException();
+        } else if (len == 0) {
+            return;
+        }
 
-            if (speed > 0 && !bstart) {
-                startTime = System.currentTimeMillis();
-                bstart = true;
-            }
-            long resetTime = System.currentTimeMillis();
-            if (resetTime - startTime > 1000) {
-                bytesWriteTotal = 0;
-                startTime = resetTime;
-            }
-            out.write(b, off, len);
-            if (len >= 0) {
-                bytesWriteTotal += len;
-                if (speed > 0) {
-                    curTime = System.currentTimeMillis();
-                    sleepTime = bytesWriteTotal / speed * 1000
-                            - (curTime - startTime);
-                    if (sleepTime > 0) {
-                        try {
-                            Thread.sleep(sleepTime);
-                        } catch (InterruptedException ie) {
-                            LOG.warn("Thread sleep is interrupted");
-                        }
+        if (speed > 0 && !bstart) {
+            startTime = System.currentTimeMillis();
+            bstart = true;
+        }
+        long resetTime = System.currentTimeMillis();
+        if (resetTime - startTime > 1000) {
+            bytesWriteTotal = 0;
+            startTime = resetTime;
+        }
+        out.write(b, off, len);
+        if (len >= 0) {
+            bytesWriteTotal += len;
+            if (speed > 0) {
+                curTime = System.currentTimeMillis();
+                sleepTime = bytesWriteTotal / speed * 1000 - (curTime - startTime);
+                if (sleepTime > 0) {
+                    try {
+                        Thread.sleep(sleepTime);
+                    } catch (InterruptedException ie) {
+                        LOG.warn("Thread sleep is interrupted");
                     }
                 }
             }
-        } finally {
         }
     }
 
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/io/Text.java b/fe/fe-common/src/main/java/org/apache/doris/common/io/Text.java
index a8977e5ed7..7331195d32 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/io/Text.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/io/Text.java
@@ -470,65 +470,65 @@ public class Text implements Writable {
             int aByte = ((int) utf8[count] & 0xFF);
 
             switch (state) { // CHECKSTYLE IGNORE THIS LINE: missing switch default
-            case LEAD_BYTE:
-                leadByte = aByte;
-                length = bytesFromUTF8[aByte];
+                case LEAD_BYTE:
+                    leadByte = aByte;
+                    length = bytesFromUTF8[aByte];
+
+                    switch (length) {
+                        case 0: // check for ASCII
+                            if (leadByte > 0x7F) {
+                                throw new MalformedInputException(count);
+                            }
+                            break;
+                        case 1:
+                            if (leadByte < 0xC2 || leadByte > 0xDF) {
+                                throw new MalformedInputException(count);
+                            }
+                            state = TRAIL_BYTE_1;
+                            break;
+                        case 2:
+                            if (leadByte < 0xE0 || leadByte > 0xEF) {
+                                throw new MalformedInputException(count);
+                            }
+                            state = TRAIL_BYTE_1;
+                            break;
+                        case 3:
+                            if (leadByte < 0xF0 || leadByte > 0xF4) {
+                                throw new MalformedInputException(count);
+                            }
+                            state = TRAIL_BYTE_1;
+                            break;
+                        default:
+                            // too long! Longest valid UTF-8 is 4 bytes (lead + three)
+                            // or if < 0 we got a trail byte in the lead byte position
+                            throw new MalformedInputException(count);
+                    } // switch (length)
+                    break;
 
-                switch (length) {
-                case 0: // check for ASCII
-                    if (leadByte > 0x7F) {
+                case TRAIL_BYTE_1:
+                    if (leadByte == 0xF0 && aByte < 0x90) {
                         throw new MalformedInputException(count);
                     }
-                    break;
-                case 1:
-                    if (leadByte < 0xC2 || leadByte > 0xDF) {
+                    if (leadByte == 0xF4 && aByte > 0x8F) {
                         throw new MalformedInputException(count);
                     }
-                    state = TRAIL_BYTE_1;
-                    break;
-                case 2:
-                    if (leadByte < 0xE0 || leadByte > 0xEF) {
+                    if (leadByte == 0xE0 && aByte < 0xA0) {
                         throw new MalformedInputException(count);
                     }
-                    state = TRAIL_BYTE_1;
-                    break;
-                case 3:
-                    if (leadByte < 0xF0 || leadByte > 0xF4) {
+                    if (leadByte == 0xED && aByte > 0x9F) {
+                        throw new MalformedInputException(count);
+                    }
+                    // falls through to regular trail-byte test!!
+                case TRAIL_BYTE:
+                    if (aByte < 0x80 || aByte > 0xBF) {
                         throw new MalformedInputException(count);
                     }
-                    state = TRAIL_BYTE_1;
+                    if (--length == 0) {
+                        state = LEAD_BYTE;
+                    } else {
+                        state = TRAIL_BYTE;
+                    }
                     break;
-                default:
-                    // too long! Longest valid UTF-8 is 4 bytes (lead + three)
-                    // or if < 0 we got a trail byte in the lead byte position
-                    throw new MalformedInputException(count);
-                } // switch (length)
-                break;
-
-            case TRAIL_BYTE_1:
-                if (leadByte == 0xF0 && aByte < 0x90) {
-                    throw new MalformedInputException(count);
-                }
-                if (leadByte == 0xF4 && aByte > 0x8F) {
-                    throw new MalformedInputException(count);
-                }
-                if (leadByte == 0xE0 && aByte < 0xA0) {
-                    throw new MalformedInputException(count);
-                }
-                if (leadByte == 0xED && aByte > 0x9F) {
-                    throw new MalformedInputException(count);
-                }
-                // falls through to regular trail-byte test!!
-            case TRAIL_BYTE:
-                if (aByte < 0x80 || aByte > 0xBF) {
-                    throw new MalformedInputException(count);
-                }
-                if (--length == 0) {
-                    state = LEAD_BYTE;
-                } else {
-                    state = TRAIL_BYTE;
-                }
-                break;
             } // switch (state)
             count++;
         }
@@ -577,29 +577,29 @@ public class Text implements Writable {
         int ch = 0;
 
         switch (extraBytesToRead) { // CHECKSTYLE IGNORE THIS LINE: missing switch default
-        case 5:
-            ch += (bytes.get() & 0xFF);
-            ch <<= 6; /* remember, illegal UTF-8 */
-            // CHECKSTYLE IGNORE THIS LINE: fall through
-        case 4:
-            ch += (bytes.get() & 0xFF);
-            ch <<= 6; /* remember, illegal UTF-8 */
-            // CHECKSTYLE IGNORE THIS LINE: fall through
-        case 3:
-            ch += (bytes.get() & 0xFF);
-            ch <<= 6;
-            // CHECKSTYLE IGNORE THIS LINE: fall through
-        case 2:
-            ch += (bytes.get() & 0xFF);
-            ch <<= 6;
-            // CHECKSTYLE IGNORE THIS LINE: fall through
-        case 1:
-            ch += (bytes.get() & 0xFF);
-            ch <<= 6;
-            // CHECKSTYLE IGNORE THIS LINE: fall through
-        case 0:
-            ch += (bytes.get() & 0xFF);
-            // CHECKSTYLE IGNORE THIS LINE: fall through, missing switch default
+            case 5:
+                ch += (bytes.get() & 0xFF);
+                ch <<= 6; /* remember, illegal UTF-8 */
+                // CHECKSTYLE IGNORE THIS LINE: fall through
+            case 4:
+                ch += (bytes.get() & 0xFF);
+                ch <<= 6; /* remember, illegal UTF-8 */
+                // CHECKSTYLE IGNORE THIS LINE: fall through
+            case 3:
+                ch += (bytes.get() & 0xFF);
+                ch <<= 6;
+                // CHECKSTYLE IGNORE THIS LINE: fall through
+            case 2:
+                ch += (bytes.get() & 0xFF);
+                ch <<= 6;
+                // CHECKSTYLE IGNORE THIS LINE: fall through
+            case 1:
+                ch += (bytes.get() & 0xFF);
+                ch <<= 6;
+                // CHECKSTYLE IGNORE THIS LINE: fall through
+            case 0:
+                ch += (bytes.get() & 0xFF);
+                // CHECKSTYLE IGNORE THIS LINE: fall through, missing switch default
         }
         ch -= offsetsFromUTF8[extraBytesToRead];
 
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/AutoType.java b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/AutoType.java
index 3b30b04c85..eeebc76e7e 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/AutoType.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/AutoType.java
@@ -31,11 +31,11 @@ public class AutoType {
     }
 
     public static Class<?> getPrimitiveType(Class<?> wrapperType) {
-        return (Class)WRAPPER_TO_PRIMITIVE.get(wrapperType);
+        return WRAPPER_TO_PRIMITIVE.get(wrapperType);
     }
 
     public static Class<?> getWrapperType(Class<?> primitiveType) {
-        return (Class)PRIMITIVE_TO_WRAPPER.get(primitiveType);
+        return PRIMITIVE_TO_WRAPPER.get(primitiveType);
     }
 
     static {
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ConstructorReflection.java b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ConstructorReflection.java
index e270078739..1636554fbc 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ConstructorReflection.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ConstructorReflection.java
@@ -36,9 +36,9 @@ public final class ConstructorReflection {
         } catch (InvocationTargetException e) {
             Throwable cause = e.getCause();
             if (cause instanceof Error) {
-                throw (Error)cause;
+                throw (Error) cause;
             } else if (cause instanceof RuntimeException) {
-                throw (RuntimeException)cause;
+                throw (RuntimeException) cause;
             } else {
                 throw new IllegalStateException("Should never get here", cause);
             }
@@ -62,7 +62,7 @@ public final class ConstructorReflection {
      * invoke the constructor with no parameters of {@aClass Class<T>}.
      */
     private static <T> T newInstance(Class<T> aClass) {
-        return (T) newInstance((Class)aClass, ParameterReflection.NO_PARAMETERS);
+        return (T) newInstance((Class) aClass, ParameterReflection.NO_PARAMETERS);
     }
 
     /**
@@ -124,12 +124,12 @@ public final class ConstructorReflection {
         Constructor<?>[] declaredConstructors = theClass.getDeclaredConstructors();
         Constructor[] declaredConstructorsArray = declaredConstructors;
 
-        for(Constructor<?> declaredConstructor : declaredConstructorsArray) {
+        for (Constructor<?> declaredConstructor : declaredConstructorsArray) {
             Class<?>[] declaredParamTypes = declaredConstructor.getParameterTypes();
             int gap = declaredParamTypes.length - argTypes.length;
-            if (gap == 0 && (ParameterReflection.matchesParameterTypes(declaredParamTypes, argTypes) ||
-                    ParameterReflection.acceptsArgumentTypes(declaredParamTypes, argTypes) ) &&
-                    (found == null || ParameterReflection.hasMoreSpecificTypes(declaredParamTypes, foundParameters))) {
+            if (gap == 0 && (ParameterReflection.matchesParameterTypes(declaredParamTypes, argTypes)
+                    || ParameterReflection.acceptsArgumentTypes(declaredParamTypes, argTypes))
+                    && (found == null || ParameterReflection.hasMoreSpecificTypes(declaredParamTypes, foundParameters))) {
                 found = (Constructor<T>) declaredConstructor;
                 foundParameters = declaredParamTypes;
             }
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/Deencapsulation.java b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/Deencapsulation.java
index 4aa1e988af..5fb33717e0 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/Deencapsulation.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/Deencapsulation.java
@@ -21,11 +21,11 @@ public final class Deencapsulation {
     }
 
     public static <T> T getField(Class<?> classWithStaticField, String fieldName) {
-        return FieldReflection.getField(classWithStaticField, fieldName, (Object)null);
+        return FieldReflection.getField(classWithStaticField, fieldName, null);
     }
 
     public static <T> T getField(Class<?> classWithStaticField, Class<T> fieldType) {
-        return FieldReflection.getField(classWithStaticField, fieldType, (Object)null);
+        return FieldReflection.getField(classWithStaticField, fieldType, null);
     }
 
     public static void setField(Object objectWithField, String fieldName, Object fieldValue) {
@@ -33,15 +33,15 @@ public final class Deencapsulation {
     }
 
     public static void setField(Object objectWithField, Object fieldValue) {
-        FieldReflection.setField(objectWithField.getClass(), objectWithField, (String)null, fieldValue);
+        FieldReflection.setField(objectWithField.getClass(), objectWithField, null, fieldValue);
     }
 
     public static void setField(Class<?> classWithStaticField, String fieldName, Object fieldValue) {
-        FieldReflection.setField(classWithStaticField, (Object)null, fieldName, fieldValue);
+        FieldReflection.setField(classWithStaticField, null, fieldName, fieldValue);
     }
 
     public static void setField(Class<?> classWithStaticField, Object fieldValue) {
-        FieldReflection.setField(classWithStaticField, (Object)null, (String)null, fieldValue);
+        FieldReflection.setField(classWithStaticField, null, null, fieldValue);
     }
 
     public static <T> T invoke(Object objectWithMethod, String methodName, Object... nonNullArgs) {
@@ -50,7 +50,7 @@ public final class Deencapsulation {
     }
 
     public static <T> T invoke(Class<?> classWithStaticMethod, String methodName, Object... nonNullArgs) {
-        return MethodReflection.invoke(classWithStaticMethod, (Object)null, methodName, nonNullArgs);
+        return MethodReflection.invoke(classWithStaticMethod, null, methodName, nonNullArgs);
     }
 
     public static <T> T newInstance(Class<? extends T> classToInstantiate, Object... nonNullArgs) {
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/FieldReflection.java b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/FieldReflection.java
index e7aaae6daf..1974d4f53b 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/FieldReflection.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/FieldReflection.java
@@ -140,7 +140,7 @@ public final class FieldReflection {
         Field found = null;
         Field[] fields = theClass.getDeclaredFields();
 
-        for(Field field : fields) {
+        for (Field field : fields) {
             if (!field.isSynthetic()) {
                 Type fieldType = field.getGenericType();
                 if (instanceField != Modifier.isStatic(field.getModifiers()) && isCompatibleFieldType(fieldType, desiredType, forAssignment)) {
@@ -178,9 +178,10 @@ public final class FieldReflection {
     }
 
     private static String errorMessageForMoreThanOneFieldFound(Type desiredFieldType, boolean instanceField, boolean forAssignment, Field firstField, Field secondField) {
-        return "More than one " + (instanceField ? "instance" : "static") + " field " + (forAssignment ? "to" : "from") + " which a value of type " +
-                getTypeName(desiredFieldType) + (forAssignment ? " can be assigned" : " can be read") + " exists in " +
-                secondField.getDeclaringClass() + ": " + firstField.getName() + ", " + secondField.getName();
+        return "More than one " + (instanceField ? "instance" : "static") + " field " + (forAssignment ? "to" : "from")
+                + " which a value of type "
+                + getTypeName(desiredFieldType) + (forAssignment ? " can be assigned" : " can be read") + " exists in "
+                + secondField.getDeclaringClass() + ": " + firstField.getName() + ", " + secondField.getName();
     }
 
     private static String getTypeName(Type type) {
@@ -207,7 +208,7 @@ public final class FieldReflection {
         makeAccessible(field);
 
         try {
-            return (T)field.get(targetObject);
+            return (T) field.get(targetObject);
         } catch (IllegalAccessException e) {
             throw new RuntimeException(e);
         }
@@ -254,19 +255,19 @@ public final class FieldReflection {
     */
 
     public static Class<?> getClassType(Type declaredType) {
-        while(!(declaredType instanceof Class)) {
+        while (!(declaredType instanceof Class)) {
             if (declaredType instanceof ParameterizedType) {
-                return (Class)((ParameterizedType)declaredType).getRawType();
+                return (Class) ((ParameterizedType) declaredType).getRawType();
             }
 
             if (!(declaredType instanceof TypeVariable)) {
                 throw new IllegalArgumentException("Type of unexpected kind: " + declaredType);
             }
 
-            declaredType = ((TypeVariable)declaredType).getBounds()[0];
+            declaredType = ((TypeVariable) declaredType).getBounds()[0];
         }
 
-        return (Class)declaredType;
+        return (Class) declaredType;
     }
 
     // ensure that field is accessible
@@ -278,9 +279,9 @@ public final class FieldReflection {
 
     // return true if the two types are same type.
     private static boolean isSameType(Class<?> firstType, Class<?> secondType) {
-        return firstType == secondType ||
-                firstType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType) ||
-                secondType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType);
+        return firstType == secondType
+                || firstType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType)
+                || secondType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType);
     }
 
 }
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/MethodReflection.java b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/MethodReflection.java
index f81e957a06..47bd5e5f2a 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/MethodReflection.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/MethodReflection.java
@@ -48,11 +48,11 @@ public final class MethodReflection {
         } catch (InvocationTargetException e) {
             Throwable cause = e.getCause();
             if (cause instanceof Error) {
-                throw (Error)cause;
+                throw (Error) cause;
             } else if (cause instanceof RuntimeException) {
-                throw (RuntimeException)cause;
+                throw (RuntimeException) cause;
             } else {
-                ThrowOfCheckedException.doThrow((Exception)cause);
+                ThrowOfCheckedException.doThrow((Exception) cause);
                 return null;
             }
         }
@@ -103,13 +103,14 @@ public final class MethodReflection {
         Class<?>[] foundParamTypes = null;
         Method[] methods = theClass.getDeclaredMethods();
 
-        for(Method declaredMethod : methods) {
+        for (Method declaredMethod : methods) {
             if (declaredMethod.getName().equals(methodName)) {
                 Class<?>[] declaredParamTypes = declaredMethod.getParameterTypes();
                 int gap = declaredParamTypes.length - argTypes.length;
-                if (gap == 0 && (ParameterReflection.matchesParameterTypes(declaredParamTypes, argTypes) ||
-                        ParameterReflection.acceptsArgumentTypes(declaredParamTypes, argTypes) ) &&
-                    (foundParamTypes == null || ParameterReflection.hasMoreSpecificTypes(declaredParamTypes, foundParamTypes))) {
+                if (gap == 0 && (ParameterReflection.matchesParameterTypes(declaredParamTypes, argTypes)
+                        || ParameterReflection.acceptsArgumentTypes(declaredParamTypes, argTypes))
+                        && (foundParamTypes == null
+                            || ParameterReflection.hasMoreSpecificTypes(declaredParamTypes, foundParamTypes))) {
                     found = declaredMethod;
                     foundParamTypes = declaredParamTypes;
                 }
@@ -129,7 +130,7 @@ public final class MethodReflection {
         }
         Method methodFound = null;
 
-        while(true) {
+        while (true) {
             Method compatibleMethod = findCompatibleMethodInClass(theClass, methodName, argTypes);
             if (compatibleMethod != null && (methodFound == null || ParameterReflection.hasMoreSpecificTypes(compatibleMethod.getParameterTypes(), methodFound.getParameterTypes()))) {
                 methodFound = compatibleMethod;
@@ -155,8 +156,8 @@ public final class MethodReflection {
 
     // return true if the two types are same type.
     private static boolean isSameType(Class<?> firstType, Class<?> secondType) {
-        return firstType == secondType ||
-                firstType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType) ||
-                secondType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType);
+        return firstType == secondType
+                || firstType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType)
+                || secondType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType);
     }
 }
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ParameterReflection.java b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ParameterReflection.java
index f97195305a..9c47ffe5d8 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ParameterReflection.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/jmockit/ParameterReflection.java
@@ -26,7 +26,7 @@ public final class ParameterReflection {
         if (declaredTypes == null || specifiedTypes == null) {
             throw new IllegalArgumentException();
         }
-        for(int i = 0; i < declaredTypes.length; ++i) {
+        for (int i = 0; i < declaredTypes.length; ++i) {
             Class<?> declaredType = declaredTypes[i];
             Class<?> specifiedType = specifiedTypes[i];
             if (!isSameType(declaredType, specifiedType)) {
@@ -44,7 +44,7 @@ public final class ParameterReflection {
         if (paramTypes == null || argTypes == null) {
             throw new IllegalArgumentException();
         }
-        for(int i = 0; i < paramTypes.length; ++i) {
+        for (int i = 0; i < paramTypes.length; ++i) {
             Class<?> parType = paramTypes[i];
             Class<?> argType = argTypes[i];
             if (!isSameType(parType, argType) && !parType.isAssignableFrom(argType)) {
@@ -67,7 +67,7 @@ public final class ParameterReflection {
         } else {
             Class<?>[] argTypes = new Class[args.length];
 
-            for(int i = 0; i < args.length; ++i) {
+            for (int i = 0; i < args.length; ++i) {
                 argTypes[i] = getArgumentTypeFromArgumentValue(i, args);
             }
 
@@ -102,7 +102,7 @@ public final class ParameterReflection {
         if (currentTypes == null || previousTypes == null) {
             throw new IllegalArgumentException();
         }
-        for(int i = 0; i < currentTypes.length; ++i) {
+        for (int i = 0; i < currentTypes.length; ++i) {
             Class<?> current = wrappedIfPrimitive(currentTypes[i]);
             Class<?> previous = wrappedIfPrimitive(previousTypes[i]);
             if (current != previous && previous.isAssignableFrom(current)) {
@@ -160,9 +160,9 @@ public final class ParameterReflection {
 
     // return true if the two types are same type.
     private static boolean isSameType(Class<?> firstType, Class<?> secondType) {
-        return firstType == secondType ||
-                firstType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType) ||
-                secondType.isPrimitive() && secondType == AutoType.getPrimitiveType(firstType);
+        return firstType == secondType
+                || firstType.isPrimitive() && firstType == AutoType.getPrimitiveType(secondType)
+                || secondType.isPrimitive() && secondType == AutoType.getPrimitiveType(firstType);
     }
 }
 
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertiesSet.java b/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertiesSet.java
index 0eb32c6ad7..5a0fd62a51 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertiesSet.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertiesSet.java
@@ -44,8 +44,8 @@ public class PropertiesSet<T extends PropertySchema.SchemaGroup> {
 
     @SuppressWarnings("unchecked")
     public <U> U get(PropertySchema<U> prop) throws NoSuchElementException {
-        return properties.containsKey(prop.getName()) ?
-                (U) properties.get(prop.getName()) : prop.getDefaultValue().get();
+        return properties.containsKey(prop.getName())
+                ? (U) properties.get(prop.getName()) : prop.getDefaultValue().get();
     }
 
     public List<PropertySchema> getModifiedSchemas() {
diff --git a/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertySchema.java b/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertySchema.java
index af61642ac1..b68d2072bf 100644
--- a/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertySchema.java
+++ b/fe/fe-common/src/main/java/org/apache/doris/common/property/PropertySchema.java
@@ -31,7 +31,7 @@ import java.util.Arrays;
 import java.util.Date;
 import java.util.Optional;
 
-@SuppressWarnings({"unchecked","rawtypes"})
+@SuppressWarnings({"unchecked", "rawtypes"})
 public abstract class PropertySchema<T> {
     private final String name;
     private final boolean required;
@@ -190,8 +190,8 @@ public abstract class PropertySchema<T> {
 
         @Override
         public Boolean read(String rawVal) {
-            if (rawVal == null ||
-                    (!rawVal.equalsIgnoreCase("true") && !rawVal.equalsIgnoreCase("false"))) {
+            if (rawVal == null || (!rawVal.equalsIgnoreCase("true")
+                    && !rawVal.equalsIgnoreCase("false"))) {
                 throw new IllegalArgumentException(String.format("Invalid boolean : %s, use true or false", rawVal));
             }
 
diff --git a/fe/fe-common/src/test/java/org/apache/doris/common/io/BitmapValueTest.java b/fe/fe-common/src/test/java/org/apache/doris/common/io/BitmapValueTest.java
index 8c802da3ee..785574981d 100644
--- a/fe/fe-common/src/test/java/org/apache/doris/common/io/BitmapValueTest.java
+++ b/fe/fe-common/src/test/java/org/apache/doris/common/io/BitmapValueTest.java
@@ -117,7 +117,7 @@ public class BitmapValueTest {
 
         // empty and bitmap
         BitmapValue bitmapValue3 = new BitmapValue();
-        BitmapValue bitmapValue3Dot1 =new BitmapValue();
+        BitmapValue bitmapValue3Dot1 = new BitmapValue();
         bitmapValue3Dot1.add(1);
         bitmapValue3Dot1.add(2);
         bitmapValue3.and(bitmapValue3Dot1);
@@ -267,7 +267,7 @@ public class BitmapValueTest {
         BitmapValue bitmapValue7 = new BitmapValue();
         bitmapValue7.add(1);
         bitmapValue7.add(2);
-        BitmapValue bitmapValue7Dot1 =new BitmapValue();
+        BitmapValue bitmapValue7Dot1 = new BitmapValue();
         bitmapValue7.or(bitmapValue7Dot1);
         Assert.assertTrue(bitmapValue7.getBitmapType() == BitmapValue.BITMAP_VALUE);
 
@@ -275,7 +275,7 @@ public class BitmapValueTest {
         BitmapValue bitmapValue8 = new BitmapValue();
         bitmapValue8.add(1);
         bitmapValue8.add(2);
-        BitmapValue bitmapValue8Dot1 =new BitmapValue();
+        BitmapValue bitmapValue8Dot1 = new BitmapValue();
         bitmapValue8Dot1.add(1);
         bitmapValue8.or(bitmapValue8Dot1);
         Assert.assertTrue(bitmapValue8.getBitmapType() == BitmapValue.BITMAP_VALUE);
@@ -284,7 +284,7 @@ public class BitmapValueTest {
         BitmapValue bitmapValue9 = new BitmapValue();
         bitmapValue9.add(1);
         bitmapValue9.add(2);
-        BitmapValue bitmapValue9Dot1 =new BitmapValue();
+        BitmapValue bitmapValue9Dot1 = new BitmapValue();
         bitmapValue9.or(bitmapValue9Dot1);
         Assert.assertTrue(bitmapValue9.getBitmapType() == BitmapValue.BITMAP_VALUE);
     }
@@ -459,7 +459,7 @@ public class BitmapValueTest {
 
 
     @Test
-    public void testBitmapOrDeepCopy(){
+    public void testBitmapOrDeepCopy() {
         // this test is added for issue #6452
         // baseIndex bitmap type == Roaring64Map
         BitmapValue baseIndex1 = new BitmapValue();
diff --git a/fe/fe-common/src/test/java/org/apache/doris/common/io/HllTest.java b/fe/fe-common/src/test/java/org/apache/doris/common/io/HllTest.java
index 78ba33b692..fabc7c1f8d 100644
--- a/fe/fe-common/src/test/java/org/apache/doris/common/io/HllTest.java
+++ b/fe/fe-common/src/test/java/org/apache/doris/common/io/HllTest.java
@@ -76,8 +76,8 @@ public class HllTest {
         }
         Assert.assertTrue(sparseHll.getType() == Hll.HLL_DATA_FULL);
         // 2% error rate
-        Assert.assertTrue(sparseHll.estimateCardinality() > Hll.HLL_SPARSE_THRESHOLD * (1 - 0.02) &&
-                sparseHll.estimateCardinality() < Hll.HLL_SPARSE_THRESHOLD * (1 + 0.02));
+        Assert.assertTrue(sparseHll.estimateCardinality() > Hll.HLL_SPARSE_THRESHOLD * (1 - 0.02)
+                && sparseHll.estimateCardinality() < Hll.HLL_SPARSE_THRESHOLD * (1 + 0.02));
 
         ByteArrayOutputStream sparseOutputStream = new ByteArrayOutputStream();
         DataOutput sparseOutput = new DataOutputStream(sparseOutputStream);
@@ -97,8 +97,8 @@ public class HllTest {
         Assert.assertTrue(fullHll.getType() == Hll.HLL_DATA_FULL);
         // the result 32748 is consistent with C++ 's implementation
         Assert.assertTrue(fullHll.estimateCardinality() == 32748);
-        Assert.assertTrue(fullHll.estimateCardinality() > Short.MAX_VALUE * (1 - 0.02) &&
-                fullHll.estimateCardinality() < Short.MAX_VALUE * (1 + 0.02));
+        Assert.assertTrue(fullHll.estimateCardinality() > Short.MAX_VALUE * (1 - 0.02)
+                && fullHll.estimateCardinality() < Short.MAX_VALUE * (1 + 0.02));
 
         ByteArrayOutputStream fullHllOutputStream = new ByteArrayOutputStream();
         DataOutput fullHllOutput = new DataOutputStream(fullHllOutputStream);
@@ -116,18 +116,18 @@ public class HllTest {
     @Test
     public void testCompareEstimateValueWithBe() throws IOException {
         //empty
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             Hll hll = new Hll();
             long estimateValue = hll.estimateCardinality();
             byte[] serializedByte = serializeHll(hll);
             hll = deserializeHll(serializedByte);
 
             Assert.assertTrue(estimateValue == hll.estimateCardinality());
-        }
+        } // CHECKSTYLE IGNORE THIS LINE
 
         // explicit [0. 100)
         Hll explicitHll = new Hll();
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             for (int i = 0; i < 100; i++) {
                 explicitHll.updateWithHash(i);
             }
@@ -144,11 +144,11 @@ public class HllTest {
             explicitHll.merge(otherHll);
             // compare with C++ version result
             Assert.assertTrue(explicitHll.estimateCardinality() == 100);
-        }
+        } // CHECKSTYLE IGNORE THIS LINE
 
         // sparse [1024, 2048)
         Hll sparseHll = new Hll();
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             for (int i = 0; i < 1024; i++) {
                 sparseHll.updateWithHash(i + 1024);
             }
@@ -174,11 +174,11 @@ public class HllTest {
             Assert.assertTrue(cardinality > 1000 && cardinality < 1045);
             // compare with C++ version result
             Assert.assertTrue(cardinality == 1023);
-        }
+        } // CHECKSTYLE IGNORE THIS LINE
 
         // full [64 * 1024, 128 * 1024)
         Hll fullHll = new Hll();
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             for (int i = 0; i < 64 * 1024; i++) {
                 fullHll.updateWithHash(64 * 1024 + i);
             }
@@ -195,16 +195,16 @@ public class HllTest {
 
             // compare with C++ version result
             Assert.assertTrue(preValue == 66112);
-        }
+        } // CHECKSTYLE IGNORE THIS LINE
 
         // merge explicit to empty_hll
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             Hll newExplicit = new Hll();
             newExplicit.merge(explicitHll);
             Assert.assertTrue(newExplicit.estimateCardinality() == 100);
 
             // merge another explicit
-            {
+            { // CHECKSTYLE IGNORE THIS LINE
                 Hll otherHll = new Hll();
                 for (int i = 100; i < 200; i++) {
                     otherHll.updateWithHash(i);
@@ -214,18 +214,18 @@ public class HllTest {
                 Assert.assertTrue(otherHll.estimateCardinality() > 190);
                 // compare with C++ version result
                 Assert.assertTrue(otherHll.estimateCardinality() == 201);
-            }
+            } // CHECKSTYLE IGNORE THIS LINE
             // merge full
-            {
+            { // CHECKSTYLE IGNORE THIS LINE
                 newExplicit.merge(fullHll);
                 Assert.assertTrue(newExplicit.estimateCardinality() > fullHll.estimateCardinality());
                 // compare with C++ version result
                 Assert.assertTrue(newExplicit.estimateCardinality() == 66250);
-            }
-        }
+            } // CHECKSTYLE IGNORE THIS LINE
+        } // CHECKSTYLE IGNORE THIS LINE
 
         // merge sparse into empty
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             Hll newSparseHll = new Hll();
             newSparseHll.merge(sparseHll);
             Assert.assertTrue(sparseHll.estimateCardinality() == newSparseHll.estimateCardinality());
@@ -243,7 +243,7 @@ public class HllTest {
             Assert.assertTrue(newSparseHll.estimateCardinality() > fullHll.estimateCardinality());
             // compare with C++ version result
             Assert.assertTrue(newSparseHll.estimateCardinality() == 67316);
-        }
+        } // CHECKSTYLE IGNORE THIS LINE
 
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java b/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java
index 612c978937..32ebb5d691 100755
--- a/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/PaloFe.java
@@ -145,7 +145,7 @@ public class PaloFe {
             httpServer.setWorkers(Config.jetty_server_workers);
             httpServer.setMaxThreads(Config.jetty_threadPool_maxThreads);
             httpServer.setMinThreads(Config.jetty_threadPool_minThreads);
-            httpServer.setMaxHttpHeaderSize (Config.jetty_server_max_http_header_size);
+            httpServer.setMaxHttpHeaderSize(Config.jetty_server_max_http_header_size);
             httpServer.start();
 
             qeService.start();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/alter/AlterJobV2.java b/fe/fe-core/src/main/java/org/apache/doris/alter/AlterJobV2.java
index 34fc631f2e..cb58707c1a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/alter/AlterJobV2.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/alter/AlterJobV2.java
@@ -45,8 +45,7 @@ public abstract class AlterJobV2 implements Writable {
 
     public enum JobState {
         PENDING, // Job is created
-        WAITING_TXN, // New replicas are created and Shadow catalog object is visible for incoming txns,
-                     // waiting for previous txns to be finished
+        WAITING_TXN, // New replicas are created and Shadow catalog object is visible for incoming txns, waiting for previous txns to be finished
         RUNNING, // alter tasks are sent to BE, and waiting for them finished.
         FINISHED, // job is done
         CANCELLED; // job is cancelled(failed or be cancelled by user)
@@ -159,17 +158,17 @@ public abstract class AlterJobV2 implements Writable {
 
         try {
             switch (jobState) {
-            case PENDING:
-                runPendingJob();
-                break;
-            case WAITING_TXN:
-                runWaitingTxnJob();
-                break;
-            case RUNNING:
-                runRunningJob();
-                break;
-            default:
-                break;
+                case PENDING:
+                    runPendingJob();
+                    break;
+                case WAITING_TXN:
+                    runWaitingTxnJob();
+                    break;
+                case RUNNING:
+                    runRunningJob();
+                    break;
+                default:
+                    break;
             }
         } catch (AlterCancelException e) {
             cancelImpl(e.getMessage());
diff --git a/fe/fe-core/src/main/java/org/apache/doris/alter/MaterializedViewHandler.java b/fe/fe-core/src/main/java/org/apache/doris/alter/MaterializedViewHandler.java
index 4d7eb8f5a5..2c8e3dc550 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/alter/MaterializedViewHandler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/alter/MaterializedViewHandler.java
@@ -246,8 +246,8 @@ public class MaterializedViewHandler extends AlterHandler {
                     Map<String, String> properties = addRollupClause.getProperties();
                     if (properties == null || !properties.containsKey(PropertyAnalyzer.PROPERTIES_STORAGE_FORMAT)
                             || !properties.get(PropertyAnalyzer.PROPERTIES_STORAGE_FORMAT).equalsIgnoreCase("v2")) {
-                        throw new DdlException("Table[" + olapTable.getName() + "] can not " +
-                                "add segment v2 rollup index without setting storage format to v2.");
+                        throw new DdlException("Table[" + olapTable.getName() + "] can not "
+                                + "add segment v2 rollup index without setting storage format to v2.");
                     }
                     rollupIndexName = NEW_STORAGE_FORMAT_INDEX_NAME_PREFIX + olapTable.getName();
                     changeStorageFormat = true;
@@ -461,8 +461,8 @@ public class MaterializedViewHandler extends AlterHandler {
                 }
                 if (baseAggregationType != mvAggregationType) {
                     throw new DdlException(
-                            "The aggregation type of column[" + mvColumnName + "] must be same as the aggregate " +
-                                    "type of base column in aggregate table");
+                            "The aggregation type of column[" + mvColumnName + "] must be same as the aggregate "
+                                    + "type of base column in aggregate table");
                 }
                 if (baseAggregationType != null && baseAggregationType.isReplaceFamily() && olapTable
                         .getKeysNum() != numOfKeys) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeHandler.java b/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeHandler.java
index 89b40db88b..46c65acf21 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeHandler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeHandler.java
@@ -255,8 +255,8 @@ public class SchemaChangeHandler extends AlterHandler {
                 for (Column column : baseSchema) {
                     if (column.isKey() && column.getName().equalsIgnoreCase(dropColName)) {
                         isKey = true;
-                    } else if (AggregateType.REPLACE == column.getAggregationType() ||
-                            AggregateType.REPLACE_IF_NOT_NULL == column.getAggregationType()) {
+                    } else if (AggregateType.REPLACE == column.getAggregationType()
+                            || AggregateType.REPLACE_IF_NOT_NULL == column.getAggregationType()) {
                         hasReplaceColumn = true;
                     }
                 }
@@ -273,8 +273,8 @@ public class SchemaChangeHandler extends AlterHandler {
                 for (Column column : targetIndexSchema) {
                     if (column.isKey() && column.getName().equalsIgnoreCase(dropColName)) {
                         isKey = true;
-                    } else if (AggregateType.REPLACE == column.getAggregationType() ||
-                            AggregateType.REPLACE_IF_NOT_NULL == column.getAggregationType()) {
+                    } else if (AggregateType.REPLACE == column.getAggregationType()
+                            || AggregateType.REPLACE_IF_NOT_NULL == column.getAggregationType()) {
                         hasReplaceColumn = true;
                     }
                 }
@@ -360,7 +360,6 @@ public class SchemaChangeHandler extends AlterHandler {
         String newColName = modColumn.getName();
         boolean hasColPos = (columnPos != null && !columnPos.isFirst());
         boolean found = false;
-        boolean typeChanged = false;
 
         int modColIndex = -1;
         int lastColIndex = -1;
@@ -369,9 +368,6 @@ public class SchemaChangeHandler extends AlterHandler {
             if (col.getName().equalsIgnoreCase(newColName)) {
                 modColIndex = i;
                 found = true;
-                if (!col.equals(modColumn)) {
-                    typeChanged = true;
-                }
             }
             if (hasColPos) {
                 if (col.getName().equalsIgnoreCase(columnPos.getLastCol())) {
@@ -781,8 +777,8 @@ public class SchemaChangeHandler extends AlterHandler {
                 throw new DdlException("Can not assign aggregation method on column in Duplicate data model table: " + newColName);
             }
             if (!newColumn.isKey()) {
-                if (targetIndexId != -1L &&
-                        olapTable.getIndexMetaByIndexId(targetIndexId).getKeysType() == KeysType.AGG_KEYS) {
+                if (targetIndexId != -1L
+                        && olapTable.getIndexMetaByIndexId(targetIndexId).getKeysType() == KeysType.AGG_KEYS) {
                     throw new DdlException("Please add non-key column on base table directly");
                 }
                 newColumn.setAggregationType(AggregateType.NONE, true);
@@ -1402,8 +1398,8 @@ public class SchemaChangeHandler extends AlterHandler {
     private void runAlterJobV2() {
         runnableSchemaChangeJobV2.values().forEach(
                 alterJobsV2 -> {
-                    if (!alterJobsV2.isDone() && !activeSchemaChangeJobsV2.containsKey(alterJobsV2.getJobId()) &&
-                            activeSchemaChangeJobsV2.size() < MAX_ACTIVE_SCHEMA_CHANGE_JOB_V2_SIZE) {
+                    if (!alterJobsV2.isDone() && !activeSchemaChangeJobsV2.containsKey(alterJobsV2.getJobId())
+                            && activeSchemaChangeJobsV2.size() < MAX_ACTIVE_SCHEMA_CHANGE_JOB_V2_SIZE) {
                         if (FeConstants.runningUnitTest) {
                             alterJobsV2.run();
                         } else {
@@ -1494,9 +1490,10 @@ public class SchemaChangeHandler extends AlterHandler {
                                 DynamicPartitionUtil.checkInputDynamicPartitionProperties(properties, olapTable.getPartitionInfo());
                             } catch (DdlException e) {
                                 // This table is not a dynamic partition table and didn't supply all dynamic partition properties
-                                throw new DdlException("Table " + db.getFullName() + "." +
-                                        olapTable.getName() + " is not a dynamic partition table. Use command `HELP ALTER TABLE` " +
-                                        "to see how to change a normal table to a dynamic partition table.");
+                                throw new DdlException("Table " + db.getFullName() + "."
+                                        + olapTable.getName() + " is not a dynamic partition table."
+                                        + " Use command `HELP ALTER TABLE` "
+                                        + "to see how to change a normal table to a dynamic partition table.");
                             }
                         }
                         Catalog.getCurrentCatalog().modifyTableDynamicPartition(db, olapTable, properties);
@@ -1662,8 +1659,8 @@ public class SchemaChangeHandler extends AlterHandler {
             try {
                 updatePartitionInMemoryMeta(db, olapTable.getName(), partitionName, isInMemory);
             } catch (Exception e) {
-                String errMsg = "Failed to update partition[" + partitionName + "]'s 'in_memory' property. " +
-                        "The reason is [" + e.getMessage() + "]";
+                String errMsg = "Failed to update partition[" + partitionName + "]'s 'in_memory' property. "
+                        + "The reason is [" + e.getMessage() + "]";
                 throw new DdlException(errMsg);
             }
         }
@@ -1765,8 +1762,8 @@ public class SchemaChangeHandler extends AlterHandler {
         OlapTable olapTable = db.getOlapTableOrDdlException(tableName);
         olapTable.writeLockOrDdlException();
         try {
-            if (olapTable.getState() != OlapTableState.SCHEMA_CHANGE &&
-                    olapTable.getState() != OlapTableState.WAITING_STABLE) {
+            if (olapTable.getState() != OlapTableState.SCHEMA_CHANGE
+                    && olapTable.getState() != OlapTableState.WAITING_STABLE) {
                 throw new DdlException("Table[" + tableName + "] is not under SCHEMA_CHANGE.");
             }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeJobV2.java b/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeJobV2.java
index 605df4cb96..2d55523d75 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeJobV2.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/alter/SchemaChangeJobV2.java
@@ -273,7 +273,7 @@ public class SchemaChangeJobV2 extends AlterJobV2 {
             AgentTaskQueue.addBatchTask(batchTask);
             AgentTaskExecutor.submit(batchTask);
             long timeout = Math.min(Config.tablet_create_timeout_second * 1000L * totalReplicaNum,
-                Config.max_create_table_timeout_second * 1000L);
+                    Config.max_create_table_timeout_second * 1000L);
             boolean ok = false;
             try {
                 ok = countDownLatch.await(timeout, TimeUnit.MILLISECONDS);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AddColumnClause.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AddColumnClause.java
index f92ee18ba0..03afe36ed5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AddColumnClause.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AddColumnClause.java
@@ -42,7 +42,9 @@ public class AddColumnClause extends AlterTableClause {
     // set in analyze
     private Column column;
 
-    public Column getColumn() { return column; }
+    public Column getColumn() {
+        return column;
+    }
 
     public ColumnPosition getColPos() {
         return colPos;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfo.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfo.java
index 988dff5584..d2ea7443e9 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfo.java
@@ -77,7 +77,9 @@ public final class AggregateInfo extends AggregateInfoBase {
         SECOND,
         SECOND_MERGE;
 
-        public boolean isMerge() { return this == FIRST_MERGE || this == SECOND_MERGE; }
+        public boolean isMerge() {
+            return this == FIRST_MERGE || this == SECOND_MERGE;
+        }
     };
 
     // created by createMergeAggInfo()
@@ -153,8 +155,13 @@ public final class AggregateInfo extends AggregateInfoBase {
                 (other.partitionExprs != null) ? Expr.cloneList(other.partitionExprs) : null;
     }
 
-    public List<Expr> getPartitionExprs() { return partitionExprs; }
-    public void setPartitionExprs(List<Expr> exprs) { partitionExprs = exprs; }
+    public List<Expr> getPartitionExprs() {
+        return partitionExprs;
+    }
+
+    public void setPartitionExprs(List<Expr> exprs) {
+        partitionExprs = exprs;
+    }
 
     /**
      * Creates complete AggregateInfo for groupingExprs and aggExprs, including
@@ -189,9 +196,8 @@ public final class AggregateInfo extends AggregateInfoBase {
         // 1: if aggExprs don't have distinct or have multi distinct , create aggregate info for
         // one stage aggregation.
         // 2: if aggExprs have one distinct , create aggregate info for two stage aggregation
-        boolean isMultiDistinct = result.estimateIfContainsMultiDistinct(distinctAggExprs);
-        if (distinctAggExprs.isEmpty()
-               || isMultiDistinct) {
+        boolean isMultiDistinct = estimateIfContainsMultiDistinct(distinctAggExprs);
+        if (distinctAggExprs.isEmpty() || isMultiDistinct) {
             // It is used to map new aggr expr to old expr to help create an external
             // reference to the aggregation node tuple
             result.setIsMultiDistinct(isMultiDistinct);
@@ -225,7 +231,7 @@ public final class AggregateInfo extends AggregateInfoBase {
      * @return
      */
     public static boolean estimateIfContainsMultiDistinct(List<FunctionCallExpr> distinctAggExprs)
-      throws AnalysisException {
+            throws AnalysisException {
 
         if (distinctAggExprs == null || distinctAggExprs.size() <= 0) {
             return false;
@@ -330,8 +336,8 @@ public final class AggregateInfo extends AggregateInfoBase {
 
     public ArrayList<FunctionCallExpr> getMaterializedAggregateExprs() {
         ArrayList<FunctionCallExpr> result = Lists.newArrayList();
-        for (Integer i: materializedSlots) {
-          result.add(aggregateExprs.get(i));
+        for (Integer i : materializedSlots) {
+            result.add(aggregateExprs.get(i));
         }
         return result;
     }
@@ -340,18 +346,30 @@ public final class AggregateInfo extends AggregateInfoBase {
         return mergeAggInfo;
     }
 
-    public boolean isMerge() { return aggPhase.isMerge(); }
-    public boolean isDistinctAgg() { return secondPhaseDistinctAggInfo != null; }
-    public ExprSubstitutionMap getIntermediateSmap() { return intermediateTupleSmap; }
-    public ExprSubstitutionMap getOutputSmap() { return outputTupleSmap; }
+    public boolean isMerge() {
+        return aggPhase.isMerge();
+    }
+
+    public boolean isDistinctAgg() {
+        return secondPhaseDistinctAggInfo != null;
+    }
+
+    public ExprSubstitutionMap getIntermediateSmap() {
+        return intermediateTupleSmap;
+    }
+
+    public ExprSubstitutionMap getOutputSmap() {
+        return outputTupleSmap;
+    }
+
     public ExprSubstitutionMap getOutputToIntermediateSmap() {
         return outputToIntermediateTupleSmap;
     }
 
     public boolean hasAggregateExprs() {
-        return !aggregateExprs.isEmpty() ||
-                (secondPhaseDistinctAggInfo != null &&
-                        !secondPhaseDistinctAggInfo.getAggregateExprs().isEmpty());
+        return !aggregateExprs.isEmpty()
+                || (secondPhaseDistinctAggInfo != null
+                && !secondPhaseDistinctAggInfo.getAggregateExprs().isEmpty());
     }
 
     public void setIsMultiDistinct(boolean value) {
@@ -419,10 +437,9 @@ public final class AggregateInfo extends AggregateInfoBase {
 
         // The smap in this case should not substitute the aggs themselves, only
         // their subexpressions.
-        List<Expr> substitutedAggs =
-            Expr.substituteList(aggregateExprs, smap, analyzer, false);
+        List<Expr> substitutedAggs = Expr.substituteList(aggregateExprs, smap, analyzer, false);
         aggregateExprs.clear();
-        for (Expr substitutedAgg: substitutedAggs) {
+        for (Expr substitutedAgg : substitutedAggs) {
             aggregateExprs.add((FunctionCallExpr) substitutedAgg);
         }
 
@@ -461,8 +478,8 @@ public final class AggregateInfo extends AggregateInfoBase {
             List<Expr> paramExprs = new ArrayList<>();
             // TODO(zhannngchen), change intermediate argument to a list, and remove this
             // ad-hoc logic
-            if (inputExpr.fn.functionName().equals("max_by") ||
-                    inputExpr.fn.functionName().equals("min_by")) {
+            if (inputExpr.fn.functionName().equals("max_by")
+                    || inputExpr.fn.functionName().equals("min_by")) {
                 paramExprs.addAll(inputExpr.getFnParams().exprs());
             } else {
                 paramExprs.add(new SlotRef(inputDesc.getSlots().get(i + getGroupingExprs().size())));
@@ -541,7 +558,6 @@ public final class AggregateInfo extends AggregateInfoBase {
         // construct agg exprs for original DISTINCT aggregate functions
         // (these aren't part of this.aggExprs)
         ArrayList<FunctionCallExpr> secondPhaseAggExprs = Lists.newArrayList();
-        int distinctExprPos = 0;
         for (FunctionCallExpr inputExpr : distinctAggExprs) {
             Preconditions.checkState(inputExpr.isAggregateFunction());
             FunctionCallExpr aggExpr = null;
@@ -638,8 +654,8 @@ public final class AggregateInfo extends AggregateInfoBase {
 
         int numOrigGroupingExprs = inputAggInfo.getGroupingExprs().size() - numDistinctParams;
         Preconditions.checkState(
-                slotDescs.size() == numOrigGroupingExprs + distinctAggExprs.size() +
-                        inputAggInfo.getAggregateExprs().size());
+                slotDescs.size() == numOrigGroupingExprs + distinctAggExprs.size()
+                        + inputAggInfo.getAggregateExprs().size());
 
         // original grouping exprs -> first m slots
         for (int i = 0; i < numOrigGroupingExprs; ++i, ++slotIdx) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfoBase.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfoBase.java
index 7fa14b758d..b44dc45589 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfoBase.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AggregateInfoBase.java
@@ -129,8 +129,8 @@ public abstract class AggregateInfoBase {
         int aggregateExprStartIndex = groupingExprs.size();
         // if agg is grouping set, so we should set all groupingExpr unless last groupingExpr
         // must set be be nullable
-        boolean isGroupingSet = !groupingExprs.isEmpty() &&
-                groupingExprs.get(groupingExprs.size() - 1) instanceof VirtualSlotRef;
+        boolean isGroupingSet = !groupingExprs.isEmpty()
+                && groupingExprs.get(groupingExprs.size() - 1) instanceof VirtualSlotRef;
 
         for (int i = 0; i < exprs.size(); ++i) {
             Expr expr = exprs.get(i);
@@ -150,7 +150,7 @@ public abstract class AggregateInfoBase {
                 }
             } else {
                 Preconditions.checkArgument(expr instanceof FunctionCallExpr);
-                FunctionCallExpr aggExpr = (FunctionCallExpr)expr;
+                FunctionCallExpr aggExpr = (FunctionCallExpr) expr;
                 if (aggExpr.isMergeAggFn()) {
                     slotDesc.setLabel(aggExpr.getChild(0).toSql());
                     slotDesc.setSourceExpr(aggExpr.getChild(0));
@@ -159,13 +159,13 @@ public abstract class AggregateInfoBase {
                     slotDesc.setSourceExpr(aggExpr);
                 }
 
-                if (isOutputTuple && aggExpr.getFn().getNullableMode().equals(Function.NullableMode.DEPEND_ON_ARGUMENT) &&
-                        groupingExprs.size() == 0) {
+                if (isOutputTuple && aggExpr.getFn().getNullableMode().equals(Function.NullableMode.DEPEND_ON_ARGUMENT)
+                        && groupingExprs.size() == 0) {
                     slotDesc.setIsNullable(true);
                 }
 
                 if (!isOutputTuple) {
-                    Type intermediateType = ((AggregateFunction)aggExpr.fn).getIntermediateType();
+                    Type intermediateType = ((AggregateFunction) aggExpr.fn).getIntermediateType();
                     if (intermediateType != null) {
                         // Use the output type as intermediate if the function has a wildcard decimal.
                         if (!intermediateType.isWildcardDecimal()) {
@@ -193,12 +193,30 @@ public abstract class AggregateInfoBase {
     public abstract void materializeRequiredSlots(Analyzer analyzer,
                                                   ExprSubstitutionMap smap);
 
-    public ArrayList<Expr> getGroupingExprs() { return groupingExprs; }
-    public ArrayList<FunctionCallExpr> getAggregateExprs() { return aggregateExprs; }
-    public TupleDescriptor getOutputTupleDesc() { return outputTupleDesc; }
-    public TupleDescriptor getIntermediateTupleDesc() { return intermediateTupleDesc; }
-    public TupleId getIntermediateTupleId() { return intermediateTupleDesc.getId(); }
-    public TupleId getOutputTupleId() { return outputTupleDesc.getId(); }
+    public ArrayList<Expr> getGroupingExprs() {
+        return groupingExprs;
+    }
+
+    public ArrayList<FunctionCallExpr> getAggregateExprs() {
+        return aggregateExprs;
+    }
+
+    public TupleDescriptor getOutputTupleDesc() {
+        return outputTupleDesc;
+    }
+
+    public TupleDescriptor getIntermediateTupleDesc() {
+        return intermediateTupleDesc;
+    }
+
+    public TupleId getIntermediateTupleId() {
+        return intermediateTupleDesc.getId();
+    }
+
+    public TupleId getOutputTupleId() {
+        return outputTupleDesc.getId();
+    }
+
     public boolean requiresIntermediateTuple() {
         Preconditions.checkNotNull(intermediateTupleDesc);
         Preconditions.checkNotNull(outputTupleDesc);
@@ -211,7 +229,7 @@ public abstract class AggregateInfoBase {
      * its output type.
      */
     public static <T extends Expr> boolean requiresIntermediateTuple(List<T> aggExprs) {
-        for (Expr aggExpr: aggExprs) {
+        for (Expr aggExpr : aggExprs) {
             Type intermediateType = ((AggregateFunction) aggExpr.fn).getIntermediateType();
             if (intermediateType != null) {
                 return true;
@@ -225,7 +243,7 @@ public abstract class AggregateInfoBase {
      * is depend on argument
      */
     public static <T extends Expr> boolean requiresIntermediateTuple(List<T> aggExprs, boolean noGrouping) {
-        for (Expr aggExpr: aggExprs) {
+        for (Expr aggExpr : aggExprs) {
             Type intermediateType = ((AggregateFunction) aggExpr.fn).getIntermediateType();
             if (intermediateType != null) {
                 return true;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterColumnStatsStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterColumnStatsStmt.java
index 17d631a1a4..b5627c2565 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterColumnStatsStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterColumnStatsStmt.java
@@ -62,7 +62,7 @@ public class AlterColumnStatsStmt extends DdlStmt {
         tableName.analyze(analyzer);
         // check properties
         Optional<StatsType> optional = properties.keySet().stream().map(StatsType::fromString)
-            .filter(statsType -> !CONFIGURABLE_PROPERTIES_SET.contains(statsType)).findFirst();
+                .filter(statsType -> !CONFIGURABLE_PROPERTIES_SET.contains(statsType)).findFirst();
         if (optional.isPresent()) {
             throw new AnalysisException(optional.get() + " is invalid statistic");
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterDatabaseQuotaStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterDatabaseQuotaStmt.java
index a45ff28f3d..daacdadb91 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterDatabaseQuotaStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterDatabaseQuotaStmt.java
@@ -80,6 +80,8 @@ public class AlterDatabaseQuotaStmt extends DdlStmt {
 
     @Override
     public String toSql() {
-        return "ALTER DATABASE " + dbName + " SET " + (quotaType == QuotaType.DATA ? "DATA" : "REPLICA") +" QUOTA " + quotaValue;
+        return "ALTER DATABASE " + dbName + " SET "
+                + (quotaType == QuotaType.DATA ? "DATA" : "REPLICA")
+                + " QUOTA " + quotaValue;
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStatsStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStatsStmt.java
index 6d8ea6027e..42661b7bdd 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStatsStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStatsStmt.java
@@ -56,7 +56,7 @@ public class AlterTableStatsStmt extends DdlStmt {
         tableName.analyze(analyzer);
         // check properties
         Optional<StatsType> optional = properties.keySet().stream().map(StatsType::fromString)
-            .filter(statsType -> !CONFIGURABLE_PROPERTIES_SET.contains(statsType)).findFirst();
+                .filter(statsType -> !CONFIGURABLE_PROPERTIES_SET.contains(statsType)).findFirst();
         if (optional.isPresent()) {
             throw new AnalysisException(optional.get() + " is invalid statistic");
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStmt.java
index 6f7cd7f257..1085197b12 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterTableStmt.java
@@ -152,17 +152,17 @@ public class AlterTableStmt extends DdlStmt {
     public void checkExternalTableOperationAllow(Table table) throws UserException {
         List<AlterClause> clauses = new ArrayList<>();
         for (AlterClause alterClause : ops) {
-            if (alterClause instanceof TableRenameClause ||
-                    alterClause instanceof AddColumnClause ||
-                    alterClause instanceof AddColumnsClause ||
-                    alterClause instanceof DropColumnClause ||
-                    alterClause instanceof ModifyColumnClause ||
-                    alterClause instanceof ReorderColumnsClause ||
-                    alterClause instanceof ModifyEngineClause) {
+            if (alterClause instanceof TableRenameClause
+                    || alterClause instanceof AddColumnClause
+                    || alterClause instanceof AddColumnsClause
+                    || alterClause instanceof DropColumnClause
+                    || alterClause instanceof ModifyColumnClause
+                    || alterClause instanceof ReorderColumnsClause
+                    || alterClause instanceof ModifyEngineClause) {
                 clauses.add(alterClause);
             } else {
-                throw new AnalysisException(table.getType().toString() + " [" + table.getName() + "] " +
-                        "do not support " + alterClause.getOpType().toString() + " clause now");
+                throw new AnalysisException(table.getType().toString() + " [" + table.getName() + "] "
+                        + "do not support " + alterClause.getOpType().toString() + " clause now");
             }
         }
         ops = clauses;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterViewStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterViewStmt.java
index 91ed2c65c5..124b7cc850 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterViewStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AlterViewStmt.java
@@ -80,7 +80,7 @@ public class AlterViewStmt extends BaseViewStmt {
         sb.append(tableName.toSql()).append("\n");
         if (cols != null) {
             sb.append("(\n");
-            for (int i = 0 ; i < cols.size(); i++) {
+            for (int i = 0; i < cols.size(); i++) {
                 if (i != 0) {
                     sb.append(",\n");
                 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticExpr.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticExpr.java
index bb3cf7730f..55169443e4 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticExpr.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticExpr.java
@@ -154,7 +154,7 @@ public class AnalyticExpr extends Expr {
             return false;
         }
 
-        AnalyticExpr o = (AnalyticExpr)obj;
+        AnalyticExpr o = (AnalyticExpr) obj;
 
         if (!fnCall.equals(o.getFnCall())) {
             return false;
@@ -177,7 +177,9 @@ public class AnalyticExpr extends Expr {
      * Analytic exprs cannot be constant.
      */
     @Override
-    protected boolean isConstantImpl() { return false; }
+    protected boolean isConstantImpl() {
+        return false;
+    }
 
     @Override
     public Expr clone() {
@@ -245,32 +247,11 @@ public class AnalyticExpr extends Expr {
         return fn.functionName().equalsIgnoreCase(HLL_UNION_AGG);
     }
 
-    /**
-     * Rewrite the following analytic functions:
-     * percent_rank(), cume_dist() and ntile()
-     *
-     * Returns a new Expr if the analytic expr is rewritten, returns null if it's not one
-     * that we want to equal.
-     */
-    public static Expr rewrite(AnalyticExpr analyticExpr) {
-        Function fn = analyticExpr.getFnCall().getFn();
-        // TODO(zc)
-        // if (AnalyticExpr.isPercentRankFn(fn)) {
-        //     return createPercentRank(analyticExpr);
-        // } else if (AnalyticExpr.isCumeDistFn(fn)) {
-        //     return createCumeDist(analyticExpr);
-        // } else if (AnalyticExpr.isNtileFn(fn)) {
-        //     return createNtile(analyticExpr);
-        // }
-        return null;
-    }
-
     /**
      * Checks that the value expr of an offset boundary of a RANGE window is compatible
      * with orderingExprs (and that there's only a single ordering expr).
      */
-    private void checkRangeOffsetBoundaryExpr(AnalyticWindow.Boundary boundary)
-    throws AnalysisException {
+    private void checkRangeOffsetBoundaryExpr(AnalyticWindow.Boundary boundary) throws AnalysisException {
         Preconditions.checkState(boundary.getType().isOffset());
 
         if (orderByElements.size() > 1) {
@@ -332,12 +313,12 @@ public class AnalyticExpr extends Expr {
                 out = true;
             }
         } else {
-            return ;
+            return;
         }
 
         if (out) {
             throw new AnalysisException("Column type="
-                                        + getFnCall().getChildren().get(0).getType() + ", value is out of range ") ;
+                    + getFnCall().getChildren().get(0).getType() + ", value is out of range ");
         }
     }
 
@@ -365,10 +346,10 @@ public class AnalyticExpr extends Expr {
             double value = 0;
 
             if (offset instanceof IntLiteral) {
-                IntLiteral intl = (IntLiteral)offset;
+                IntLiteral intl = (IntLiteral) offset;
                 value = intl.getDoubleValue();
             } else if (offset instanceof LargeIntLiteral) {
-                LargeIntLiteral intl = (LargeIntLiteral)offset;
+                LargeIntLiteral intl = (LargeIntLiteral) offset;
                 value = intl.getDoubleValue();
             }
 
@@ -490,8 +471,8 @@ public class AnalyticExpr extends Expr {
         if (!VectorizedUtil.isVectorized()) {
             // min/max is not currently supported on sliding windows (i.e. start bound is not
             // unbounded).
-            if (window != null && isMinMax(fn) &&
-                    window.getLeftBoundary().getType() != BoundaryType.UNBOUNDED_PRECEDING) {
+            if (window != null && isMinMax(fn)
+                    && window.getLeftBoundary().getType() != BoundaryType.UNBOUNDED_PRECEDING) {
                 throw new AnalysisException(
                     "'" + getFnCall().toSql() + "' is only supported with an "
                     + "UNBOUNDED PRECEDING start bound.");
@@ -585,10 +566,10 @@ public class AnalyticExpr extends Expr {
             try {
                 getFnCall().uncheckedCastChild(getFnCall().getChildren().get(0).getType(), 2);
             }  catch (Exception e) {
-                LOG.warn("" , e);
+                LOG.warn("", e);
                 throw new AnalysisException("Convert type error in offset fn(default value); old_type="
                                             + getFnCall().getChildren().get(2).getType() + " new_type="
-                                            + getFnCall().getChildren().get(0).getType()) ;
+                                            + getFnCall().getChildren().get(0).getType());
             }
 
             if (getFnCall().getChildren().get(2) instanceof CastExpr) {
@@ -602,7 +583,7 @@ public class AnalyticExpr extends Expr {
             try {
                 getFnCall().uncheckedCastChild(Type.BIGINT, 1);
             }  catch (Exception e) {
-                LOG.warn("" , e);
+                LOG.warn("", e);
                 throw new AnalysisException("Convert type error in offset fn(default offset); type="
                                             + getFnCall().getChildren().get(1).getType());
             }
@@ -646,26 +627,24 @@ public class AnalyticExpr extends Expr {
             } else {
                 //TODO: Now we don't want to first_value to rewrite in vectorized mode;
                 //if have to rewrite in future, could exec this rule;
-                if(!VectorizedUtil.isVectorized()) {
-                List<Expr> paramExprs = Expr.cloneList(getFnCall().getParams().exprs());
-
-                if (window.getRightBoundary().getType() == BoundaryType.PRECEDING) {
-                    // The number of rows preceding for the end bound determines the number of
-                    // rows at the beginning of each partition that should have a NULL value.
-                    paramExprs.add(window.getRightBoundary().getExpr());
-                } else {
-                    // -1 indicates that no NULL values are inserted even though we set the end
-                    // bound to the start bound (which is PRECEDING) below; this is different from
-                    // the default behavior of windows with an end bound PRECEDING.
-                    paramExprs.add(new IntLiteral(-1, Type.BIGINT));
-                }
+                if (!VectorizedUtil.isVectorized()) {
+                    List<Expr> paramExprs = Expr.cloneList(getFnCall().getParams().exprs());
+
+                    if (window.getRightBoundary().getType() == BoundaryType.PRECEDING) {
+                        // The number of rows preceding for the end bound determines the number of
+                        // rows at the beginning of each partition that should have a NULL value.
+                        paramExprs.add(window.getRightBoundary().getExpr());
+                    } else {
+                        // -1 indicates that no NULL values are inserted even though we set the end
+                        // bound to the start bound (which is PRECEDING) below; this is different from
+                        // the default behavior of windows with an end bound PRECEDING.
+                        paramExprs.add(new IntLiteral(-1, Type.BIGINT));
+                    }
 
-                window = new AnalyticWindow(window.getType(),
-                                            new Boundary(BoundaryType.UNBOUNDED_PRECEDING, null),
-                                            window.getLeftBoundary());
-                fnCall = new FunctionCallExpr("FIRST_VALUE_REWRITE",
-                                              new FunctionParams(paramExprs));
-                //        fnCall_.setIsInternalFnCall(true);
+                    window = new AnalyticWindow(window.getType(),
+                            new Boundary(BoundaryType.UNBOUNDED_PRECEDING, null),
+                            window.getLeftBoundary());
+                    fnCall = new FunctionCallExpr("FIRST_VALUE_REWRITE", new FunctionParams(paramExprs));
                 }
             }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticInfo.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticInfo.java
index 0b3cf4f1bc..8b88f4c4fc 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticInfo.java
@@ -53,7 +53,7 @@ public final class AnalyticInfo extends AggregateInfoBase {
         super(new ArrayList<Expr>(), new ArrayList<FunctionCallExpr>());
         this.analyticExprs = Expr.cloneList(analyticExprs);
         // Extract the analytic function calls for each analytic expr.
-        for (Expr analyticExpr: analyticExprs) {
+        for (Expr analyticExpr : analyticExprs) {
             aggregateExprs.add(((AnalyticExpr) analyticExpr).getFnCall());
         }
         analyticTupleSmap = new ExprSubstitutionMap();
@@ -71,16 +71,23 @@ public final class AnalyticInfo extends AggregateInfoBase {
         commonPartitionExprs = Expr.cloneList(other.commonPartitionExprs);
     }
 
-    public ArrayList<Expr> getAnalyticExprs() { return analyticExprs; }
-    public ExprSubstitutionMap getSmap() { return analyticTupleSmap; }
-    public List<Expr> getCommonPartitionExprs() { return commonPartitionExprs; }
+    public ArrayList<Expr> getAnalyticExprs() {
+        return analyticExprs;
+    }
+
+    public ExprSubstitutionMap getSmap() {
+        return analyticTupleSmap;
+    }
+
+    public List<Expr> getCommonPartitionExprs() {
+        return commonPartitionExprs;
+    }
 
     /**
      * Creates complete AnalyticInfo for analyticExprs, including tuple descriptors and
      * smaps.
      */
-    static public AnalyticInfo create(
-        ArrayList<Expr> analyticExprs, Analyzer analyzer) {
+    static public AnalyticInfo create(ArrayList<Expr> analyticExprs, Analyzer analyzer) {
         Preconditions.checkState(analyticExprs != null && !analyticExprs.isEmpty());
         Expr.removeDuplicates(analyticExprs);
         AnalyticInfo result = new AnalyticInfo(analyticExprs);
@@ -113,7 +120,7 @@ public final class AnalyticInfo extends AggregateInfoBase {
      */
     private List<Expr> computeCommonPartitionExprs() {
         List<Expr> result = Lists.newArrayList();
-        for (Expr analyticExpr: analyticExprs) {
+        for (Expr analyticExpr : analyticExprs) {
             Preconditions.checkState(analyticExpr.isAnalyzed());
             List<Expr> partitionExprs = ((AnalyticExpr) analyticExpr).getPartitionExprs();
             if (partitionExprs == null) {
@@ -159,23 +166,20 @@ public final class AnalyticInfo extends AggregateInfoBase {
 
         // Check materialized slots.
         int numMaterializedSlots = 0;
-        for (SlotDescriptor slotDesc: slots) {
+        for (SlotDescriptor slotDesc : slots) {
             if (slotDesc.isMaterialized()) {
                 ++numMaterializedSlots;
             }
         }
-        Preconditions.checkState(numMaterializedSlots ==
-                materializedSlots.size());
+        Preconditions.checkState(numMaterializedSlots == materializedSlots.size());
 
         // Check that analytic expr return types match the slot descriptors.
         int slotIdx = 0;
-        for (int i = 0; i < analyticExprs.size(); ++i) {
-            Expr analyticExpr = analyticExprs.get(i);
+        for (Expr analyticExpr : analyticExprs) {
             Type slotType = slots.get(slotIdx).getType();
             Preconditions.checkState(analyticExpr.getType().equals(slotType),
-                    String.format("Analytic expr %s returns type %s but its analytic tuple " +
-                                    "slot has type %s", analyticExpr.toSql(),
-                            analyticExpr.getType().toString(), slotType.toString()));
+                    String.format("Analytic expr %s returns type %s but its analytic tuple " + "slot has type %s",
+                            analyticExpr.toSql(), analyticExpr.getType().toString(), slotType.toString()));
             ++slotIdx;
         }
     }
@@ -191,8 +195,12 @@ public final class AnalyticInfo extends AggregateInfoBase {
     }
 
     @Override
-    protected String tupleDebugName() { return "analytic-tuple"; }
+    protected String tupleDebugName() {
+        return "analytic-tuple";
+    }
 
     @Override
-    public AnalyticInfo clone() { return new AnalyticInfo(this); }
+    public AnalyticInfo clone() {
+        return new AnalyticInfo(this);
+    }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticWindow.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticWindow.java
index 53265089b4..b6bc06d3bb 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticWindow.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/AnalyticWindow.java
@@ -206,7 +206,7 @@ public class AnalyticWindow {
                 return false;
             }
 
-            Boundary o = (Boundary)obj;
+            Boundary o = (Boundary) obj;
             boolean exprEqual = (expr == null) == (o.expr == null);
 
             if (exprEqual && expr != null) {
@@ -360,9 +360,8 @@ public class AnalyticWindow {
             return false;
         }
 
-        AnalyticWindow o = (AnalyticWindow)obj;
-        boolean rightBoundaryEqual =
-            (rightBoundary == null) == (o.rightBoundary == null);
+        AnalyticWindow o = (AnalyticWindow) obj;
+        boolean rightBoundaryEqual = (rightBoundary == null) == (o.rightBoundary == null);
 
         if (rightBoundaryEqual && rightBoundary != null) {
             rightBoundaryEqual = rightBoundary.equals(o.rightBoundary);
@@ -382,7 +381,7 @@ public class AnalyticWindow {
      * Semantic analysis for expr of a PRECEDING/FOLLOWING clause.
      */
     private void checkOffsetExpr(Analyzer analyzer, Boundary boundary)
-    throws AnalysisException {
+            throws AnalysisException {
         Preconditions.checkState(boundary.getType().isOffset());
         Expr e = boundary.getExpr();
         Preconditions.checkNotNull(e);
@@ -392,9 +391,6 @@ public class AnalyticWindow {
         if (e.isConstant() && e.getType().isNumericType()) {
             try {
                 val = Expr.getConstFromExpr(e);
-//                val = TColumnValueUtil.getNumericVal(
-//                        FeSupport.EvalConstExpr(e, analyzer.getQueryGlobals()));
-
                 if (val <= 0) {
                     isPos = false;
                 }
@@ -428,7 +424,7 @@ public class AnalyticWindow {
      * Check that b1 <= b2.
      */
     private void checkOffsetBoundaries(Analyzer analyzer, Boundary b1, Boundary b2)
-    throws AnalysisException {
+            throws AnalysisException {
         Preconditions.checkState(b1.getType().isOffset());
         Preconditions.checkState(b2.getType().isOffset());
         Expr e1 = b1.getExpr();
@@ -439,8 +435,6 @@ public class AnalyticWindow {
                 e2 != null && e2.isConstant() && e2.getType().isNumericType());
 
         try {
-//            TColumnValue val1 = FeSupport.EvalConstExpr(e1, analyzer.getQueryGlobals());
-//            TColumnValue val2 = FeSupport.EvalConstExpr(e2, analyzer.getQueryGlobals());
             double left = Expr.getConstFromExpr(e1);
             double right = Expr.getConstFromExpr(e2);
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/Analyzer.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/Analyzer.java
index a5a18d0d3c..cebd197fd5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/Analyzer.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/Analyzer.java
@@ -167,19 +167,50 @@ public class Analyzer {
         isSubquery = true;
         globalState.containsSubquery = true;
     }
-    public boolean setHasPlanHints() { return globalState.hasPlanHints = true; }
-    public boolean hasPlanHints() { return globalState.hasPlanHints; }
-    public void setIsWithClause() { isWithClause = true; }
-    public boolean isWithClause() { return isWithClause; }
 
-    public void setUDFAllowed(boolean val) { this.isUDFAllowed = val; }
-    public boolean isUDFAllowed() { return this.isUDFAllowed; }
-    public void setTimezone(String timezone) { this.timezone = timezone; }
-    public String getTimezone() { return timezone; }
+    public boolean setHasPlanHints() {
+        return globalState.hasPlanHints = true;
+    }
+
+    public boolean hasPlanHints() {
+        return globalState.hasPlanHints;
+    }
+
+    public void setIsWithClause() {
+        isWithClause = true;
+    }
+
+    public boolean isWithClause() {
+        return isWithClause;
+    }
+
+    public void setUDFAllowed(boolean val) {
+        this.isUDFAllowed = val;
+    }
 
-    public void putAssignedRuntimeFilter(RuntimeFilter rf) { assignedRuntimeFilters.add(rf); }
-    public List<RuntimeFilter> getAssignedRuntimeFilter() { return assignedRuntimeFilters; }
-    public void clearAssignedRuntimeFilters() { assignedRuntimeFilters.clear(); }
+    public boolean isUDFAllowed() {
+        return this.isUDFAllowed;
+    }
+
+    public void setTimezone(String timezone) {
+        this.timezone = timezone;
+    }
+
+    public String getTimezone() {
+        return timezone;
+    }
+
+    public void putAssignedRuntimeFilter(RuntimeFilter rf) {
+        assignedRuntimeFilters.add(rf);
+    }
+
+    public List<RuntimeFilter> getAssignedRuntimeFilter() {
+        return assignedRuntimeFilters;
+    }
+
+    public void clearAssignedRuntimeFilters() {
+        assignedRuntimeFilters.clear();
+    }
 
     public long getAutoBroadcastJoinThreshold() {
         return globalState.autoBroadcastJoinThreshold;
@@ -428,8 +459,13 @@ public class Analyzer {
         return new Analyzer(parentAnalyzer, globalState);
     }
 
-    public void setIsExplain() { globalState.isExplain = true; }
-    public boolean isExplain() { return globalState.isExplain; }
+    public void setIsExplain() {
+        globalState.isExplain = true;
+    }
+
+    public boolean isExplain() {
+        return globalState.isExplain;
+    }
 
     public int incrementCallDepth() {
         return ++callDepth;
@@ -454,10 +490,10 @@ public class Analyzer {
             List<String> viewLabels = view.getColLabels();
             List<String> queryStmtLabels = view.getQueryStmt().getColLabels();
             if (viewLabels.size() > queryStmtLabels.size()) {
-                throw new AnalysisException("WITH-clause view '" + view.getName() +
-                        "' returns " + queryStmtLabels.size() + " columns, but " +
-                        viewLabels.size() + " labels were specified. The number of column " +
-                        "labels must be smaller or equal to the number of returned columns.");
+                throw new AnalysisException("WITH-clause view '" + view.getName()
+                        + "' returns " + queryStmtLabels.size() + " columns, but "
+                        + viewLabels.size() + " labels were specified. The number of column "
+                        + "labels must be smaller or equal to the number of returned columns.");
             }
         }
         if (localViews.put(view.getName(), view) != null) {
@@ -627,7 +663,7 @@ public class Analyzer {
                     partition -> partition.getState() == PartitionState.RESTORE
             ).collect(Collectors.toList()).isEmpty();
 
-            if(!isNotRestoring){
+            if (!isNotRestoring) {
                 // if doing restore with partitions, the status check push down to OlapScanNode::computePartitionInfo to
                 // support query that partitions is not restoring.
             } else {
@@ -791,7 +827,7 @@ public class Analyzer {
             //result = desc;
             if (!colName.equalsIgnoreCase(Column.DELETE_SIGN) && !isVisible(desc.getId())) {
                 ErrorReport.reportAnalysisException(ErrorCode.ERR_ILLEGAL_COLUMN_REFERENCE_ERROR,
-                        Joiner.on(".").join(tblName.getTbl(),colName));
+                        Joiner.on(".").join(tblName.getTbl(), colName));
             }
             Column col = desc.getTable().getColumn(colName);
             if (col != null) {
@@ -862,7 +898,7 @@ public class Analyzer {
                 !globalState.fullOuterJoinedConjuncts.containsKey(e.getId()));
         List<TupleId> tids = Lists.newArrayList();
         e.getIds(tids, null);
-        for (TupleId tid: tids) {
+        for (TupleId tid : tids) {
             if (!globalState.fullOuterJoinedTupleIds.containsKey(tid)) {
                 continue;
             }
@@ -871,8 +907,7 @@ public class Analyzer {
             break;
         }
         if (LOG.isDebugEnabled()) {
-            LOG.debug("registerFullOuterJoinedConjunct: " +
-                    globalState.fullOuterJoinedConjuncts.toString());
+            LOG.debug("registerFullOuterJoinedConjunct: " + globalState.fullOuterJoinedConjuncts);
         }
     }
 
@@ -881,12 +916,11 @@ public class Analyzer {
      * rhsRef.
      */
     public void registerFullOuterJoinedTids(List<TupleId> tids, TableRef rhsRef) {
-        for (TupleId tid: tids) {
+        for (TupleId tid : tids) {
             globalState.fullOuterJoinedTupleIds.put(tid, rhsRef);
         }
         if (LOG.isTraceEnabled()) {
-            LOG.trace("registerFullOuterJoinedTids: " +
-                    globalState.fullOuterJoinedTupleIds.toString());
+            LOG.trace("registerFullOuterJoinedTids: " + globalState.fullOuterJoinedTupleIds);
         }
     }
 
@@ -895,12 +929,11 @@ public class Analyzer {
      * All tuple of outer join should be null in slot desc
      */
     public void registerOuterJoinedTids(List<TupleId> tids, TableRef rhsRef) {
-        for (TupleId tid: tids) {
+        for (TupleId tid : tids) {
             globalState.outerJoinedTupleIds.put(tid, rhsRef);
         }
         if (LOG.isDebugEnabled()) {
-            LOG.debug("registerOuterJoinedTids: " +
-                    globalState.outerJoinedTupleIds.toString());
+            LOG.debug("registerOuterJoinedTids: " + globalState.outerJoinedTupleIds);
         }
     }
 
@@ -983,7 +1016,7 @@ public class Analyzer {
         globalState.onSlotToLiteralExpr.add(expr);
     }
 
-    public void registerOnSlotToLiteralDeDuplication(Pair<Expr,Expr> pair) {
+    public void registerOnSlotToLiteralDeDuplication(Pair<Expr, Expr> pair) {
         globalState.onSlotToLiteralDeDuplication.add(pair);
     }
 
@@ -1046,7 +1079,7 @@ public class Analyzer {
 
     // Register all conjuncts and handle constant conjuncts with ids
     public void registerConjuncts(Expr e, boolean fromHavingClause, List<TupleId> ids) throws AnalysisException {
-        for (Expr conjunct: e.getConjuncts()) {
+        for (Expr conjunct : e.getConjuncts()) {
             registerConjunct(conjunct);
             if (ids != null) {
                 for (TupleId id : ids) {
@@ -1263,10 +1296,9 @@ public class Analyzer {
     public List<Expr> getAllUnassignedConjuncts(List<TupleId> tupleIds) {
         List<Expr> result = Lists.newArrayList();
         for (Expr e : globalState.conjuncts.values()) {
-            if (!e.isAuxExpr()
-                && e.isBoundByTupleIds(tupleIds)
-                && !globalState.assignedConjuncts.contains(e.getId())
-                && !globalState.ojClauseByConjunct.containsKey(e.getId())) {
+            if (!e.isAuxExpr() && e.isBoundByTupleIds(tupleIds)
+                    && !globalState.assignedConjuncts.contains(e.getId())
+                    && !globalState.ojClauseByConjunct.containsKey(e.getId())) {
                 result.add(e);
             }
         }
@@ -1384,7 +1416,7 @@ public class Analyzer {
     }
 
     public boolean containsOuterJoinedTid(List<TupleId> tids) {
-        for (TupleId tid: tids) {
+        for (TupleId tid : tids) {
             if (isOuterJoined(tid)) {
                 return true;
             }
@@ -1427,7 +1459,7 @@ public class Analyzer {
     public List<Expr> getRemainConjuncts(List<TupleId> tupleIds) {
         Set<ExprId> remainConjunctIds = Sets.newHashSet();
         for (TupleId tupleId : tupleIds) {
-            if (tuplePredicates.get(tupleId) !=null) {
+            if (tuplePredicates.get(tupleId) != null) {
                 remainConjunctIds.addAll(tuplePredicates.get(tupleId));
             }
         }
@@ -1448,7 +1480,7 @@ public class Analyzer {
         return new ArrayList<>(globalState.onSlotEqSlotExpr);
     }
 
-    public Set<Pair<Expr,Expr>> getOnSlotEqSlotDeDuplication() {
+    public Set<Pair<Expr, Expr>> getOnSlotEqSlotDeDuplication() {
         return Sets.newHashSet(globalState.onSlotEqSlotDeDuplication);
     }
 
@@ -1498,9 +1530,14 @@ public class Analyzer {
      * Return true if this analyzer has no ancestors. (i.e. false for the analyzer created
      * for inline views/ union operands, etc.)
      */
-    public boolean isRootAnalyzer() { return ancestors.isEmpty(); }
+    public boolean isRootAnalyzer() {
+        return ancestors.isEmpty();
+    }
+
+    public boolean hasAncestors() {
+        return !ancestors.isEmpty();
+    }
 
-    public boolean hasAncestors() { return !ancestors.isEmpty(); }
     public Analyzer getParentAnalyzer() {
         return hasAncestors() ? ancestors.get(0) : null;
     }
@@ -1510,10 +1547,17 @@ public class Analyzer {
      * to return an empty result set, e.g., due to a limit 0 or a constant predicate
      * that evaluates to false.
      */
-    public boolean hasEmptyResultSet() { return hasEmptyResultSet; }
-    public void setHasEmptyResultSet() { hasEmptyResultSet = true; }
+    public boolean hasEmptyResultSet() {
+        return hasEmptyResultSet;
+    }
+
+    public void setHasEmptyResultSet() {
+        hasEmptyResultSet = true;
+    }
 
-    public boolean hasEmptySpjResultSet() { return hasEmptySpjResultSet; }
+    public boolean hasEmptySpjResultSet() {
+        return hasEmptySpjResultSet;
+    }
 
     public void setHasLimitOffsetClause(boolean hasLimitOffset) {
         this.hasLimitOffsetClause = hasLimitOffset;
@@ -1538,7 +1582,7 @@ public class Analyzer {
                 globalState.conjunctsByOjClause.put(rhsRef.getId(), ojConjuncts);
             }
         }
-        for (Expr conjunct: conjuncts) {
+        for (Expr conjunct : conjuncts) {
             conjunct.setIsOnClauseConjunct(true);
             registerConjunct(conjunct);
             if (rhsRef.getJoinOp().isOuterJoin()) {
@@ -1631,7 +1675,7 @@ public class Analyzer {
         return globalState.ojClauseByConjunct.get(e.getId());
     }
 
-   /**
+    /**
      * Returns false if 'e' originates from an outer-join On-clause and it is incorrect to
      * evaluate 'e' at a node materializing 'tids'. Returns true otherwise.
      */
@@ -1655,12 +1699,12 @@ public class Analyzer {
         // Contains all equi-join conjuncts that have one child fully bound by one of the
         // rhs table ref ids (the other child is not bound by that rhs table ref id).
         List<ExprId> conjunctIds = Lists.newArrayList();
-        for (TupleId rhsId: rhsTblRefIds) {
+        for (TupleId rhsId : rhsTblRefIds) {
             List<ExprId> cids = globalState.eqJoinConjuncts.get(rhsId);
             if (cids == null) {
                 continue;
             }
-            for (ExprId eid: cids) {
+            for (ExprId eid : cids) {
                 if (!conjunctIds.contains(eid)) {
                     conjunctIds.add(eid);
                 }
@@ -1679,12 +1723,12 @@ public class Analyzer {
         List<TupleId> nodeTblRefIds = Lists.newArrayList(lhsTblRefIds);
         nodeTblRefIds.addAll(rhsTblRefIds);
         List<Expr> result = Lists.newArrayList();
-        for (ExprId conjunctId: conjunctIds) {
+        for (ExprId conjunctId : conjunctIds) {
             Expr e = globalState.conjuncts.get(conjunctId);
             Preconditions.checkState(e != null);
-            if (!canEvalFullOuterJoinedConjunct(e, nodeTblRefIds) ||
-                    !canEvalAntiJoinedConjunct(e, nodeTblRefIds) ||
-                    !canEvalOuterJoinedConjunct(e, nodeTblRefIds)) {
+            if (!canEvalFullOuterJoinedConjunct(e, nodeTblRefIds)
+                    || !canEvalAntiJoinedConjunct(e, nodeTblRefIds)
+                    || !canEvalOuterJoinedConjunct(e, nodeTblRefIds)) {
                 continue;
             }
 
@@ -2065,7 +2109,7 @@ public class Analyzer {
             }
         }
 
-        for (TupleId tid: tids) {
+        for (TupleId tid : tids) {
             TableRef rhsRef = getLastOjClause(tid);
             // this is not outer-joined; ignore
             if (rhsRef == null) {
@@ -2145,13 +2189,13 @@ public class Analyzer {
     public void materializeSlots(List<Expr> exprs) {
         List<SlotId> slotIds = Lists.newArrayList();
 
-        for (Expr e: exprs) {
+        for (Expr e : exprs) {
             Preconditions.checkState(e.isAnalyzed);
             e.getIds(null, slotIds);
         }
 
-        for (TupleDescriptor tupleDesc: this.getDescTbl().getTupleDescs()) {
-            for (SlotDescriptor slotDesc: tupleDesc.getSlots()) {
+        for (TupleDescriptor tupleDesc : this.getDescTbl().getTupleDescs()) {
+            for (SlotDescriptor slotDesc : tupleDesc.getSlots()) {
                 if (slotIds.contains(slotDesc.getId())) {
                     slotDesc.setIsMaterialized(true);
                 }
@@ -2159,7 +2203,9 @@ public class Analyzer {
         }
     }
 
-    public Map<String, View> getLocalViews() { return localViews; }
+    public Map<String, View> getLocalViews() {
+        return localViews;
+    }
 
     public boolean isOuterJoined(TupleId tid) {
         return globalState.outerJoinedTupleIds.containsKey(tid);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ArrayLiteral.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ArrayLiteral.java
index 7e06d1b7aa..d9024de807 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ArrayLiteral.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ArrayLiteral.java
@@ -132,7 +132,7 @@ public class ArrayLiteral extends LiteralExpr {
         ArrayLiteral literal = new ArrayLiteral(this);
         for (int i = 0; i < children.size(); ++ i) {
             Expr child = children.get(i);
-            literal.children.set(i, child.uncheckedCastTo(((ArrayType)targetType).getItemType()));
+            literal.children.set(i, child.uncheckedCastTo(((ArrayType) targetType).getItemType()));
         }
         literal.setType(targetType);
         return literal;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/BetweenPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/BetweenPredicate.java
index 5dc2e4c5a9..84fe311237 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/BetweenPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/BetweenPredicate.java
@@ -49,13 +49,6 @@ public class BetweenPredicate extends Predicate {
         isNotBetween = other.isNotBetween;
     }
 
-//    @Override
-//    public Expr reset() {
-//      super.reset();
-//      originalChildren = Expr.resetList(originalChildren);
-//      return this;
-//    }
-
     @Override
     public Expr clone() {
         return new BetweenPredicate(this);
@@ -68,10 +61,10 @@ public class BetweenPredicate extends Predicate {
     @Override
     public void analyzeImpl(Analyzer analyzer) throws AnalysisException {
         super.analyzeImpl(analyzer);
-        if (children.get(0) instanceof Subquery &&
-                (children.get(1) instanceof Subquery || children.get(2) instanceof Subquery)) {
-            throw new AnalysisException("Comparison between subqueries is not " +
-                    "supported in a BETWEEN predicate: " + toSql());
+        if (children.get(0) instanceof Subquery
+                && (children.get(1) instanceof Subquery || children.get(2) instanceof Subquery)) {
+            throw new AnalysisException("Comparison between subqueries is not "
+                    + "supported in a BETWEEN predicate: " + toSql());
         }
         // if children has subquery, it will be written and reanalyzed in the future.
         if (children.get(0) instanceof Subquery
@@ -82,10 +75,10 @@ public class BetweenPredicate extends Predicate {
         analyzer.castAllToCompatibleType(children);
     }
 
-   @Override
-   public boolean isVectorized() {
-       return false;
-   }
+    @Override
+    public boolean isVectorized() {
+        return false;
+    }
 
     @Override
     protected void toThrift(TExprNode msg) {
@@ -96,19 +89,21 @@ public class BetweenPredicate extends Predicate {
     @Override
     public String toSqlImpl() {
         String notStr = (isNotBetween) ? "NOT " : "";
-        return children.get(0).toSql() + " " + notStr + "BETWEEN " +
-                children.get(1).toSql() + " AND " + children.get(2).toSql();
+        return children.get(0).toSql() + " " + notStr + "BETWEEN "
+                + children.get(1).toSql() + " AND " + children.get(2).toSql();
     }
 
     @Override
     public String toDigestImpl() {
         String notStr = (isNotBetween) ? "NOT " : "";
-        return children.get(0).toDigest() + " " + notStr + "BETWEEN " +
-                children.get(1).toDigest() + " AND " + children.get(2).toDigest();
+        return children.get(0).toDigest() + " " + notStr + "BETWEEN "
+                + children.get(1).toDigest() + " AND " + children.get(2).toDigest();
     }
 
     @Override
-    public Expr clone(ExprSubstitutionMap sMap) { return new BetweenPredicate(this); }
+    public Expr clone(ExprSubstitutionMap sMap) {
+        return new BetweenPredicate(this);
+    }
 
     @Override
     public boolean equals(Object o) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/BinaryPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/BinaryPredicate.java
index 271c8d2260..12d6aa7b24 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/BinaryPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/BinaryPredicate.java
@@ -134,11 +134,17 @@ public class BinaryPredicate extends Predicate implements Writable {
             }
         }
 
-        public boolean isEquivalence() { return this == EQ || this == EQ_FOR_NULL; };
+        public boolean isEquivalence() {
+            return this == EQ || this == EQ_FOR_NULL;
+        }
 
-        public boolean isUnNullSafeEquivalence() { return this == EQ; };
+        public boolean isUnNullSafeEquivalence() {
+            return this == EQ;
+        }
 
-        public boolean isUnequivalence() { return this == NE; }
+        public boolean isUnequivalence() {
+            return this == NE;
+        }
     }
 
     private Operator op;
@@ -163,15 +169,20 @@ public class BinaryPredicate extends Predicate implements Writable {
     protected BinaryPredicate(BinaryPredicate other) {
         super(other);
         op = other.op;
-        slotIsleft= other.slotIsleft;
+        slotIsleft = other.slotIsleft;
         isInferred = other.isInferred;
     }
 
-    public boolean isInferred() { return isInferred; }
-    public void setIsInferred() { isInferred = true; }
+    public boolean isInferred() {
+        return isInferred;
+    }
+
+    public void setIsInferred() {
+        isInferred = true;
+    }
 
     public static void initBuiltins(FunctionSet functionSet) {
-        for (Type t: Type.getSupportedTypes()) {
+        for (Type t : Type.getSupportedTypes()) {
             if (t.isNull()) {
                 continue; // NULL is handled through type promotion.
             }
@@ -201,7 +212,9 @@ public class BinaryPredicate extends Predicate implements Writable {
         return op;
     }
 
-    public void setOp(Operator op) { this.op = op; }
+    public void setOp(Operator op) {
+        this.op = op;
+    }
 
     @Override
     public Expr negate() {
@@ -339,17 +352,17 @@ public class BinaryPredicate extends Predicate implements Writable {
         // When int column compares with string, Mysql will convert string to int.
         // So it is also compatible with Mysql.
 
-        if (t1 == PrimitiveType.BIGINT && (t2 == PrimitiveType.VARCHAR || t2 ==PrimitiveType.STRING)) {
+        if (t1 == PrimitiveType.BIGINT && (t2 == PrimitiveType.VARCHAR || t2 == PrimitiveType.STRING)) {
             Expr rightChild = getChild(1);
             Long parsedLong = Type.tryParseToLong(rightChild);
-            if(parsedLong != null) {
+            if (parsedLong != null) {
                 return Type.BIGINT;
             }
         }
-        if ((t1 == PrimitiveType.VARCHAR || t1 ==PrimitiveType.STRING) && t2 == PrimitiveType.BIGINT) {
+        if ((t1 == PrimitiveType.VARCHAR || t1 == PrimitiveType.STRING) && t2 == PrimitiveType.BIGINT) {
             Expr leftChild = getChild(0);
             Long parsedLong = Type.tryParseToLong(leftChild);
-            if(parsedLong != null) {
+            if (parsedLong != null) {
                 return Type.BIGINT;
             }
         }
@@ -404,8 +417,8 @@ public class BinaryPredicate extends Predicate implements Writable {
 
         // determine selectivity
         Reference<SlotRef> slotRefRef = new Reference<SlotRef>();
-        if (op == Operator.EQ && isSingleColumnPredicate(slotRefRef,
-          null) && slotRefRef.getRef().getNumDistinctValues() > 0) {
+        if (op == Operator.EQ && isSingleColumnPredicate(slotRefRef, null)
+                && slotRefRef.getRef().getNumDistinctValues() > 0) {
             Preconditions.checkState(slotRefRef.getRef() != null);
             selectivity = 1.0 / slotRefRef.getRef().getNumDistinctValues();
             selectivity = Math.max(0, Math.min(1, selectivity));
@@ -604,11 +617,11 @@ public class BinaryPredicate extends Predicate implements Writable {
         recursiveResetChildrenResult();
         final Expr leftChildValue = getChild(0);
         final Expr rightChildValue = getChild(1);
-        if(!(leftChildValue instanceof LiteralExpr)
+        if (!(leftChildValue instanceof LiteralExpr)
                 || !(rightChildValue instanceof LiteralExpr)) {
             return this;
         }
-        return compareLiteral((LiteralExpr)leftChildValue, (LiteralExpr)rightChildValue);
+        return compareLiteral((LiteralExpr) leftChildValue, (LiteralExpr) rightChildValue);
     }
 
     private Expr compareLiteral(LiteralExpr first, LiteralExpr second) throws AnalysisException {
@@ -621,13 +634,13 @@ public class BinaryPredicate extends Predicate implements Writable {
                 return new BoolLiteral(false);
             }
         } else  {
-            if (isFirstNull || isSecondNull){
+            if (isFirstNull || isSecondNull) {
                 return new NullLiteral();
             }
         }
 
         final int compareResult = first.compareLiteral(second);
-        switch(op) {
+        switch (op) {
             case EQ:
             case EQ_FOR_NULL:
                 return new BoolLiteral(compareResult == 0);
@@ -649,7 +662,7 @@ public class BinaryPredicate extends Predicate implements Writable {
 
     @Override
     public void setSelectivity() {
-        switch(op) {
+        switch (op) {
             case EQ:
             case EQ_FOR_NULL: {
                 Reference<SlotRef> slotRefRef = new Reference<SlotRef>();
@@ -661,7 +674,8 @@ public class BinaryPredicate extends Predicate implements Writable {
                     }
                 }
                 break;
-            } default: {
+            }
+            default: {
                 // Reference hive
                 selectivity = 1.0 / 3.0;
                 break;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/BuiltinAggregateFunction.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/BuiltinAggregateFunction.java
index ff66fb29e4..3ccb85f0ae 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/BuiltinAggregateFunction.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/BuiltinAggregateFunction.java
@@ -20,7 +20,6 @@ package org.apache.doris.analysis;
 import org.apache.doris.catalog.Function;
 import org.apache.doris.catalog.ScalarType;
 import org.apache.doris.catalog.Type;
-import org.apache.doris.common.AnalysisException;
 import org.apache.doris.thrift.TAggregateFunction;
 import org.apache.doris.thrift.TAggregationOp;
 import org.apache.doris.thrift.TFunction;
@@ -50,10 +49,8 @@ public class BuiltinAggregateFunction extends Function {
     }
 
     public BuiltinAggregateFunction(Operator op, ArrayList<Type> argTypes,
-      Type retType, org.apache.doris.catalog.Type intermediateType, boolean isAnalyticFn)
-      throws AnalysisException {
-        super(FunctionName.createBuiltinName(op.toString()), argTypes,
-          retType, false);
+            Type retType, org.apache.doris.catalog.Type intermediateType, boolean isAnalyticFn) {
+        super(FunctionName.createBuiltinName(op.toString()), argTypes, retType, false);
         Preconditions.checkState(intermediateType != null);
         Preconditions.checkState(op != null);
         // may be no need to analyze
@@ -128,8 +125,8 @@ public class BuiltinAggregateFunction extends Function {
         // The intermediate type for this function if it is constant regardless of
         // input type. Set to null if it can only be determined during analysis.
         private final org.apache.doris.catalog.Type intermediateType;
-        private Operator(String description, TAggregationOp thriftOp,
-          org.apache.doris.catalog.Type intermediateType) {
+        Operator(String description, TAggregationOp thriftOp,
+                org.apache.doris.catalog.Type intermediateType) {
             this.description = description;
             this.thriftOp = thriftOp;
             this.intermediateType = intermediateType;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CancelAlterTableStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CancelAlterTableStmt.java
index d49c68fd1e..8f88a8580a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CancelAlterTableStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CancelAlterTableStmt.java
@@ -88,8 +88,8 @@ public class CancelAlterTableStmt extends CancelStmt {
         stringBuilder.append("CANCEL ALTER " + this.alterType);
         stringBuilder.append(" FROM " + dbTableName.toSql());
         if (!CollectionUtils.isEmpty(alterJobIdList)) {
-            stringBuilder.append(" (")
-            .append(String.join(",",alterJobIdList.stream().map(String::valueOf).collect(Collectors.toList())));
+            stringBuilder.append(" (").append(String.join(",", alterJobIdList.stream()
+                    .map(String::valueOf).collect(Collectors.toList())));
             stringBuilder.append(")");
         }
         return stringBuilder.toString();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CastExpr.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CastExpr.java
index d2e9691bf2..10cd2d065c 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CastExpr.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CastExpr.java
@@ -65,11 +65,11 @@ public class CastExpr extends Expr {
 
     static {
         TYPE_NULLABLE_MODE = Maps.newHashMap();
-        for (ScalarType fromType: Type.getSupportedTypes()) {
+        for (ScalarType fromType : Type.getSupportedTypes()) {
             if (fromType.isNull()) {
                 continue;
             }
-            for (ScalarType toType: Type.getSupportedTypes()) {
+            for (ScalarType toType : Type.getSupportedTypes()) {
                 if (fromType.isNull()) {
                     continue;
                 }
@@ -138,9 +138,8 @@ public class CastExpr extends Expr {
 
     private static boolean disableRegisterCastingFunction(Type fromType, Type toType) {
         // Disable casting from boolean to decimal or datetime or date
-        if (fromType.isBoolean() &&
-                (toType.equals(Type.DECIMALV2) ||
-                        toType.equals(Type.DATETIME) || toType.equals(Type.DATE))) {
+        if (fromType.isBoolean()
+                && (toType.equals(Type.DECIMALV2) || toType.equals(Type.DATETIME) || toType.equals(Type.DATE))) {
             return true;
         }
 
@@ -173,7 +172,7 @@ public class CastExpr extends Expr {
                         + typeName;
                 functionSet.addBuiltinBothScalaAndVectorized(ScalarFunction.createBuiltin(getFnName(toType),
                         toType, TYPE_NULLABLE_MODE.get(new Pair<>(fromType, toType)),
-                        Lists.newArrayList(fromType), false ,
+                        Lists.newArrayList(fromType), false,
                         beSymbol, null, null, true));
             }
         }
@@ -186,11 +185,11 @@ public class CastExpr extends Expr {
 
     @Override
     public String toSqlImpl() {
-        boolean isVerbose = ConnectContext.get() != null &&
-                ConnectContext.get().getExecutor() != null &&
-                ConnectContext.get().getExecutor().getParsedStmt() != null &&
-                ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions() != null &&
-                ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions().isVerbose();
+        boolean isVerbose = ConnectContext.get() != null
+                && ConnectContext.get().getExecutor() != null
+                && ConnectContext.get().getExecutor().getParsedStmt() != null
+                && ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions() != null
+                && ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions().isVerbose();
         if (isImplicit && !isVerbose) {
             return getChild(0).toSql();
         }
@@ -207,11 +206,11 @@ public class CastExpr extends Expr {
 
     @Override
     public String toDigestImpl() {
-        boolean isVerbose = ConnectContext.get() != null &&
-                ConnectContext.get().getExecutor() != null &&
-                ConnectContext.get().getExecutor().getParsedStmt() != null &&
-                ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions() != null &&
-                ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions().isVerbose();
+        boolean isVerbose = ConnectContext.get() != null
+                && ConnectContext.get().getExecutor() != null
+                && ConnectContext.get().getExecutor().getParsedStmt() != null
+                && ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions() != null
+                && ConnectContext.get().getExecutor().getParsedStmt().getExplainOptions().isVerbose();
         if (isImplicit && !isVerbose) {
             return getChild(0).toDigest();
         }
@@ -278,10 +277,10 @@ public class CastExpr extends Expr {
                 fn = Catalog.getCurrentCatalog().getFunction(
                         searchDesc, Function.CompareMode.IS_IDENTICAL);
             }
-        } else if (type.isArrayType()){
+        } else if (type.isArrayType()) {
             fn = ScalarFunction.createBuiltin(getFnName(Type.ARRAY),
                     type, Function.NullableMode.ALWAYS_NULLABLE,
-                    Lists.newArrayList(Type.VARCHAR), false ,
+                    Lists.newArrayList(Type.VARCHAR), false,
                     "doris::CastFunctions::cast_to_array_val", null, null, true);
         }
 
@@ -334,8 +333,8 @@ public class CastExpr extends Expr {
     public Expr ignoreImplicitCast() {
         if (isImplicit) {
             // we don't expect to see to consecutive implicit casts
-            Preconditions.checkState(
-              !(getChild(0) instanceof CastExpr) || !((CastExpr) getChild(0)).isImplicit());
+            Preconditions.checkState(!(getChild(0) instanceof CastExpr)
+                    || !((CastExpr) getChild(0)).isImplicit());
             return getChild(0);
         } else {
             return this;
@@ -361,7 +360,7 @@ public class CastExpr extends Expr {
         }
         Expr targetExpr;
         try {
-            targetExpr = castTo((LiteralExpr)value);
+            targetExpr = castTo((LiteralExpr) value);
         } catch (AnalysisException ae) {
             targetExpr = this;
         } catch (NumberFormatException nfe) {
@@ -493,7 +492,7 @@ public class CastExpr extends Expr {
         if (index != -1) {
             Expr expr = inputParamsExprs.get(index);
             if (expr.getType().isIntegerType()) {
-                return ((Long)((IntLiteral) expr).getRealValue()).intValue();
+                return ((Long) ((IntLiteral) expr).getRealValue()).intValue();
             }
         }
         return -1;
@@ -501,8 +500,8 @@ public class CastExpr extends Expr {
 
     @Override
     public boolean isNullable() {
-        return children.get(0).isNullable() ||
-                (children.get(0).getType().isStringType() && !getType().isStringType()) ||
-                (!children.get(0).getType().isDateType() && getType().isDateType());
+        return children.get(0).isNullable()
+                || (children.get(0).getType().isStringType() && !getType().isStringType())
+                || (!children.get(0).getType().isDateType() && getType().isDateType());
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ColumnDef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ColumnDef.java
index 86a818ff8e..d3831f2de6 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ColumnDef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ColumnDef.java
@@ -131,15 +131,41 @@ public class ColumnDef {
                 "sequence column hidden column", false);
     }
 
-    public boolean isAllowNull() { return isAllowNull; }
-    public String getDefaultValue() { return defaultValue.value; }
-    public String getName() { return name; }
-    public AggregateType getAggregateType() { return aggregateType; }
-    public void setAggregateType(AggregateType aggregateType) { this.aggregateType = aggregateType; }
-    public boolean isKey() { return isKey; }
-    public void setIsKey(boolean isKey) { this.isKey = isKey; }
-    public TypeDef getTypeDef() { return typeDef; }
-    public Type getType() { return typeDef.getType(); }
+    public boolean isAllowNull() {
+        return isAllowNull;
+    }
+
+    public String getDefaultValue() {
+        return defaultValue.value;
+    }
+
+    public String getName() {
+        return name;
+    }
+
+    public AggregateType getAggregateType() {
+        return aggregateType;
+    }
+
+    public void setAggregateType(AggregateType aggregateType) {
+        this.aggregateType = aggregateType;
+    }
+
+    public boolean isKey() {
+        return isKey;
+    }
+
+    public void setIsKey(boolean isKey) {
+        this.isKey = isKey;
+    }
+
+    public TypeDef getTypeDef() {
+        return typeDef;
+    }
+
+    public Type getType() {
+        return typeDef.getType();
+    }
 
     public String getComment() {
         return comment;
@@ -168,9 +194,9 @@ public class ColumnDef {
 
         Type type = typeDef.getType();
 
-        if(!Config.enable_quantile_state_type && type.isQuantileStateType()) {
-            throw new AnalysisException("quantile_state is disabled" +
-                    "Set config 'enable_quantile_state_type' = 'true' to enable this column type.");
+        if (!Config.enable_quantile_state_type && type.isQuantileStateType()) {
+            throw new AnalysisException("quantile_state is disabled"
+                    + "Set config 'enable_quantile_state_type' = 'true' to enable this column type.");
         }
 
         // disable Bitmap Hll type in keys, values without aggregate function.
@@ -270,10 +296,10 @@ public class ColumnDef {
             case SMALLINT:
             case INT:
             case BIGINT:
-                IntLiteral intLiteral = new IntLiteral(defaultValue, type);
+                new IntLiteral(defaultValue, type);
                 break;
             case LARGEINT:
-                LargeIntLiteral largeIntLiteral = new LargeIntLiteral(defaultValue);
+                new LargeIntLiteral(defaultValue);
                 break;
             case FLOAT:
                 FloatLiteral floatLiteral = new FloatLiteral(defaultValue);
@@ -282,7 +308,7 @@ public class ColumnDef {
                 }
                 break;
             case DOUBLE:
-                FloatLiteral doubleLiteral = new FloatLiteral(defaultValue);
+                new FloatLiteral(defaultValue);
                 break;
             case DECIMALV2:
                 DecimalLiteral decimalLiteral = new DecimalLiteral(defaultValue);
@@ -290,7 +316,7 @@ public class ColumnDef {
                 break;
             case DATE:
             case DATETIME:
-                DateLiteral dateLiteral = new DateLiteral(defaultValue, type);
+                new DateLiteral(defaultValue, type);
                 break;
             case CHAR:
             case VARCHAR:
@@ -309,7 +335,7 @@ public class ColumnDef {
             case STRUCT:
                 break;
             case BOOLEAN:
-                BoolLiteral boolLiteral = new BoolLiteral(defaultValue);
+                new BoolLiteral(defaultValue);
                 break;
             default:
                 throw new AnalysisException("Unsupported type: " + type);
@@ -346,5 +372,7 @@ public class ColumnDef {
     }
 
     @Override
-    public String toString() { return toSql(); }
+    public String toString() {
+        return toSql();
+    }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CompoundPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CompoundPredicate.java
index 87b0dfd883..d2175117a0 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CompoundPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CompoundPredicate.java
@@ -57,8 +57,7 @@ public class CompoundPredicate extends Predicate {
         this.op = op;
         Preconditions.checkNotNull(e1);
         children.add(e1);
-        Preconditions.checkArgument(
-          op == Operator.NOT && e2 == null || op != Operator.NOT && e2 != null);
+        Preconditions.checkArgument(op == Operator.NOT && e2 == null || op != Operator.NOT && e2 != null);
         if (e2 != null) {
             children.add(e2);
         }
@@ -121,14 +120,13 @@ public class CompoundPredicate extends Predicate {
         for (Expr e : children) {
             if (!e.getType().equals(Type.BOOLEAN) && !e.getType().isNull()) {
                 throw new AnalysisException(String.format(
-                  "Operand '%s' part of predicate " + "'%s' should return type 'BOOLEAN' but " +
-                    "returns type '%s'.",
+                  "Operand '%s' part of predicate " + "'%s' should return type 'BOOLEAN' but "
+                          + "returns type '%s'.",
                   e.toSql(), toSql(), e.getType()));
             }
         }
 
-        if (getChild(0).selectivity == -1 || children.size() == 2 && getChild(
-          1).selectivity == -1) {
+        if (getChild(0).selectivity == -1 || children.size() == 2 && getChild(1).selectivity == -1) {
             // give up if we're missing an input
             selectivity = -1;
             return;
@@ -205,37 +203,36 @@ public class CompoundPredicate extends Predicate {
      */
     public static Expr createConjunctivePredicate(List<Expr> conjuncts) {
         Expr conjunctivePred = null;
-        for (Expr expr: conjuncts) {
-          if (conjunctivePred == null) {
-            conjunctivePred = expr;
-            continue;
-          }
-          conjunctivePred = new CompoundPredicate(CompoundPredicate.Operator.AND,
-              expr, conjunctivePred);
+        for (Expr expr : conjuncts) {
+            if (conjunctivePred == null) {
+                conjunctivePred = expr;
+                continue;
+            }
+            conjunctivePred = new CompoundPredicate(CompoundPredicate.Operator.AND, expr, conjunctivePred);
         }
         return conjunctivePred;
     }
 
-   @Override
+    @Override
     public Expr getResultValue() throws AnalysisException {
         recursiveResetChildrenResult();
         boolean compoundResult = false;
         if (op == Operator.NOT) {
             final Expr childValue = getChild(0);
-            if(!(childValue instanceof BoolLiteral)) {
+            if (!(childValue instanceof BoolLiteral)) {
                 return this;
             }
-            final BoolLiteral boolChild = (BoolLiteral)childValue;
+            final BoolLiteral boolChild = (BoolLiteral) childValue;
             compoundResult = !boolChild.getValue();
         } else {
             final Expr leftChildValue = getChild(0);
             final Expr rightChildValue = getChild(1);
-            if(!(leftChildValue instanceof BoolLiteral)
+            if (!(leftChildValue instanceof BoolLiteral)
                     || !(rightChildValue instanceof BoolLiteral)) {
                 return this;
             }
-            final BoolLiteral leftBoolValue = (BoolLiteral)leftChildValue;
-            final BoolLiteral rightBoolValue = (BoolLiteral)rightChildValue;
+            final BoolLiteral leftBoolValue = (BoolLiteral) leftChildValue;
+            final BoolLiteral rightBoolValue = (BoolLiteral) rightChildValue;
             switch (op) {
                 case AND:
                     compoundResult = leftBoolValue.getValue() && rightBoolValue.getValue();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateEncryptKeyStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateEncryptKeyStmt.java
index ad694ad8ca..626cef29b6 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateEncryptKeyStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateEncryptKeyStmt.java
@@ -40,7 +40,7 @@ import com.google.common.base.Strings;
  * for example:
  *     CREATE ENCRYPTKEY test.key1 AS "beijing";
  */
-public class CreateEncryptKeyStmt extends DdlStmt{
+public class CreateEncryptKeyStmt extends DdlStmt {
     private final EncryptKeyName encryptKeyName;
     private final String keyString;
     private EncryptKey encryptKey;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateRoutineLoadStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateRoutineLoadStmt.java
index 45a0a7ff42..eff6a8bb7c 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateRoutineLoadStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateRoutineLoadStmt.java
@@ -97,7 +97,7 @@ public class CreateRoutineLoadStmt extends DdlStmt {
     public static final String MAX_BATCH_SIZE_PROPERTY = "max_batch_size";
     public static final String EXEC_MEM_LIMIT_PROPERTY = "exec_mem_limit";
 
-    public static final String FORMAT = "format";// the value is csv or json, default is csv
+    public static final String FORMAT = "format"; // the value is csv or json, default is csv
     public static final String STRIP_OUTER_ARRAY = "strip_outer_array";
     public static final String JSONPATHS = "jsonpaths";
     public static final String JSONROOT = "json_root";
@@ -338,7 +338,7 @@ public class CreateRoutineLoadStmt extends DdlStmt {
             throw new AnalysisException("load by MERGE or DELETE is only supported in unique tables.");
         }
         if (mergeType != LoadTask.MergeType.APPEND
-                && !(table.getType() == Table.TableType.OLAP && ((OlapTable) table).hasDeleteSign()) ) {
+                && !(table.getType() == Table.TableType.OLAP && ((OlapTable) table).hasDeleteSign())) {
             throw new AnalysisException("load by MERGE or DELETE need to upgrade table to support batch delete.");
         }
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableLikeStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableLikeStmt.java
index 70223c87cc..b65aaa4d28 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableLikeStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableLikeStmt.java
@@ -51,7 +51,7 @@ public class CreateTableLikeStmt extends DdlStmt {
         this.ifNotExists = ifNotExists;
         this.tableName = tableName;
         this.existedTableName = existedTableName;
-        if (!CollectionUtils.isEmpty(rollupNames) && withAllRollup){
+        if (!CollectionUtils.isEmpty(rollupNames) && withAllRollup) {
             throw new DdlException("Either all or part of the rollup can be copied, not both");
         }
         this.rollupNames = rollupNames;
@@ -108,10 +108,10 @@ public class CreateTableLikeStmt extends DdlStmt {
     public String toSql() {
         StringBuilder sb = new StringBuilder();
         sb.append("CREATE TABLE ").append(tableName.toSql()).append(" LIKE ").append(existedTableName.toSql());
-        if (withAllRollup && CollectionUtils.isEmpty(rollupNames)){
+        if (withAllRollup && CollectionUtils.isEmpty(rollupNames)) {
             sb.append(" WITH ROLLUP");
         }
-        if (!withAllRollup && !CollectionUtils.isEmpty(rollupNames)){
+        if (!withAllRollup && !CollectionUtils.isEmpty(rollupNames)) {
             sb.append(" WITH ROLLUP (").append(Joiner.on(",").join(rollupNames)).append(")");
         }
         return sb.toString();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableStmt.java
index 5c2db118bb..44de0d27f9 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/CreateTableStmt.java
@@ -183,9 +183,13 @@ public class CreateTableStmt extends DdlStmt {
         this.comment = Strings.nullToEmpty(comment);
     }
 
-    public void addColumnDef(ColumnDef columnDef) { columnDefs.add(columnDef); }
+    public void addColumnDef(ColumnDef columnDef) {
+        columnDefs.add(columnDef);
+    }
 
-    public void setIfNotExists(boolean ifNotExists) { this.ifNotExists = ifNotExists; }
+    public void setIfNotExists(boolean ifNotExists) {
+        this.ifNotExists = ifNotExists;
+    }
 
     public boolean isSetIfNotExists() {
         return ifNotExists;
@@ -380,8 +384,8 @@ public class CreateTableStmt extends DdlStmt {
                     throw new AnalysisException("Array column can't support aggregation " + columnDef.getAggregateType());
                 }
                 if (columnDef.isKey()) {
-                    throw new AnalysisException("Array can only be used in the non-key column of" +
-                            " the duplicate table at present.");
+                    throw new AnalysisException("Array can only be used in the non-key column of"
+                            + " the duplicate table at present.");
                 }
             }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/DataSortInfo.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/DataSortInfo.java
index 783ccde0ec..4393dc162c 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/DataSortInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/DataSortInfo.java
@@ -54,7 +54,7 @@ public class DataSortInfo implements Writable {
         }
     }
 
-    public DataSortInfo (TSortType sortType, int colNum) {
+    public DataSortInfo(TSortType sortType, int colNum) {
         this.sortType = sortType;
         this.colNum = colNum;
     }
@@ -97,8 +97,8 @@ public class DataSortInfo implements Writable {
     }
 
     public String toSql() {
-        String res = ",\n\"" + DATA_SORT_TYPE + "\" = \"" + this.sortType + "\"" +
-                ",\n\"" + DATA_SORT_COL_NUM + "\" = \"" + this.colNum + "\"";
+        String res = ",\n\"" + DATA_SORT_TYPE + "\" = \"" + this.sortType + "\""
+                + ",\n\"" + DATA_SORT_COL_NUM + "\" = \"" + this.colNum + "\"";
         return res;
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/DateLiteral.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/DateLiteral.java
index 75fcb05f2a..a59952f55e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/DateLiteral.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/DateLiteral.java
@@ -1054,7 +1054,7 @@ public class DateLiteral extends LiteralExpr {
                 || microsecond > MAX_MICROSECOND;
     }
     private boolean checkDate() {
-        if (month != 0 && day > DAYS_IN_MONTH[((int) month)]){
+        if (month != 0 && day > DAYS_IN_MONTH[((int) month)]) {
             if (month == 2 && day == 29 && Year.isLeap(year)) {
                 return false;
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/DecimalLiteral.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/DecimalLiteral.java
index 07abe74bed..b2b1278d5d 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/DecimalLiteral.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/DecimalLiteral.java
@@ -193,7 +193,6 @@ public class DecimalLiteral extends LiteralExpr {
     protected void toThrift(TExprNode msg) {
         // TODO(hujie01) deal with loss information
         msg.node_type = TExprNodeType.DECIMAL_LITERAL;
-        BigDecimal v = new BigDecimal(value.toBigInteger());
         msg.decimal_literal = new TDecimalLiteral(value.toPlainString());
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/DescriptorTable.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/DescriptorTable.java
index e2f933291f..526c6e4806 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/DescriptorTable.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/DescriptorTable.java
@@ -82,7 +82,7 @@ public class DescriptorTable {
         tupleDescs.put(d.getId(), d);
         // create copies of slots
         TupleDescriptor src = tupleDescs.get(srcId);
-        for (SlotDescriptor slot: src.getSlots()) {
+        for (SlotDescriptor slot : src.getSlots()) {
             copySlotDescriptor(d, slot);
         }
         d.computeStatAndMemLayout();
@@ -119,7 +119,7 @@ public class DescriptorTable {
      * Marks all slots in list as materialized.
      */
     public void markSlotsMaterialized(List<SlotId> ids) {
-        for (SlotId id: ids) {
+        for (SlotId id : ids) {
             getSlotDesc(id).setIsMaterialized(true);
         }
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/DropFunctionStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/DropFunctionStmt.java
index da90e1c0f4..4e88751ede 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/DropFunctionStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/DropFunctionStmt.java
@@ -37,8 +37,13 @@ public class DropFunctionStmt extends DdlStmt {
         this.argsDef = argsDef;
     }
 
-    public FunctionName getFunctionName() { return functionName; }
-    public FunctionSearchDesc getFunction() { return function; }
+    public FunctionName getFunctionName() {
+        return functionName;
+    }
+
+    public FunctionSearchDesc getFunction() {
+        return function;
+    }
 
     @Override
     public void analyze(Analyzer analyzer) throws UserException {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExistsPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExistsPredicate.java
index bdb2fbee06..b061b19e2f 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExistsPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExistsPredicate.java
@@ -27,11 +27,12 @@ import org.slf4j.LoggerFactory;
  * Class representing a [NOT] EXISTS predicate.
  */
 public class ExistsPredicate extends Predicate {
-    private static final Logger LOG = LoggerFactory.getLogger(
-        ExistsPredicate.class);
+    private static final Logger LOG = LoggerFactory.getLogger(ExistsPredicate.class);
     private boolean notExists = false;
 
-    public boolean isNotExists() { return notExists; }
+    public boolean isNotExists() {
+        return notExists;
+    }
 
     public ExistsPredicate(Subquery subquery, boolean notExists) {
         Preconditions.checkNotNull(subquery);
@@ -56,7 +57,9 @@ public class ExistsPredicate extends Predicate {
     }
 
     @Override
-    public Expr clone() { return new ExistsPredicate(this); }
+    public Expr clone() {
+        return new ExistsPredicate(this);
+    }
 
     @Override
     public String toSqlImpl() {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExportStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExportStmt.java
index a77d151168..6df62c42f4 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExportStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExportStmt.java
@@ -72,7 +72,7 @@ public class ExportStmt extends StatementBase {
     private Map<String, String> properties = Maps.newHashMap();
     private String columnSeparator;
     private String lineDelimiter;
-    private String columns ;
+    private String columns;
 
     private TableRef tableRef;
 
@@ -243,17 +243,17 @@ public class ExportStmt extends StatementBase {
             if (schema == null || !schema.equalsIgnoreCase("s3")) {
                 throw new AnalysisException("Invalid export path. please use valid 'S3://' path.");
             }
-            } else if (type == StorageBackend.StorageType.HDFS) {
-                if (schema == null || !schema.equalsIgnoreCase("hdfs")) {
-                    throw new AnalysisException("Invalid export path. please use valid 'HDFS://' path.");
-                }
-            } else if (type == StorageBackend.StorageType.LOCAL) {
-                if (schema != null && !schema.equalsIgnoreCase("file")) {
-                    throw new AnalysisException("Invalid export path. please use valid '"
-                            + OutFileClause.LOCAL_FILE_PREFIX + "' path.");
-                }
-                path = path.substring(OutFileClause.LOCAL_FILE_PREFIX.length() - 1);
+        } else if (type == StorageBackend.StorageType.HDFS) {
+            if (schema == null || !schema.equalsIgnoreCase("hdfs")) {
+                throw new AnalysisException("Invalid export path. please use valid 'HDFS://' path.");
             }
+        } else if (type == StorageBackend.StorageType.LOCAL) {
+            if (schema != null && !schema.equalsIgnoreCase("file")) {
+                throw new AnalysisException(
+                        "Invalid export path. please use valid '" + OutFileClause.LOCAL_FILE_PREFIX + "' path.");
+            }
+            path = path.substring(OutFileClause.LOCAL_FILE_PREFIX.length() - 1);
+        }
         return path;
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/Expr.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/Expr.java
index 8213063965..2bf7e5929f 100755
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/Expr.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/Expr.java
@@ -48,7 +48,6 @@ import org.apache.logging.log4j.Logger;
 import java.io.DataInput;
 import java.io.DataOutput;
 import java.io.IOException;
-import java.lang.reflect.Method;
 import java.util.ArrayList;
 import java.util.Arrays;
 import java.util.HashMap;
@@ -77,8 +76,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
     private final static com.google.common.base.Predicate<Expr> IS_AGGREGATE_PREDICATE =
             new com.google.common.base.Predicate<Expr>() {
                 public boolean apply(Expr arg) {
-                    return arg instanceof FunctionCallExpr &&
-                            ((FunctionCallExpr)arg).isAggregateFunction();
+                    return arg instanceof FunctionCallExpr
+                            && ((FunctionCallExpr) arg).isAggregateFunction();
                 }
             };
 
@@ -87,8 +86,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             new com.google.common.base.Predicate<Expr>() {
                 @Override
                 public boolean apply(Expr arg) {
-                    return arg instanceof CompoundPredicate &&
-                            ((CompoundPredicate)arg).getOp() == CompoundPredicate.Operator.NOT;
+                    return arg instanceof CompoundPredicate
+                            && ((CompoundPredicate) arg).getOp() == CompoundPredicate.Operator.NOT;
                 }
             };
 
@@ -97,8 +96,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             new com.google.common.base.Predicate<Expr>() {
                 @Override
                 public boolean apply(Expr arg) {
-                    return arg instanceof CompoundPredicate &&
-                            ((CompoundPredicate)arg).getOp() == CompoundPredicate.Operator.OR;
+                    return arg instanceof CompoundPredicate
+                            && ((CompoundPredicate) arg).getOp() == CompoundPredicate.Operator.OR;
                 }
             };
 
@@ -113,33 +112,21 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
 
     // Returns true if an Expr is an aggregate function that returns non-null on
     // an empty set (e.g. count).
-    public final static com.google.common.base.Predicate<Expr>
-            NON_NULL_EMPTY_AGG = new com.google.common.base.Predicate<Expr>() {
-        @Override
-        public boolean apply(Expr arg) {
-            return arg instanceof FunctionCallExpr &&
-                    ((FunctionCallExpr)arg).returnsNonNullOnEmpty();
-        }
-    };
-
-    /* TODO(zc)
-    // Returns true if an Expr is a builtin aggregate function.
-    public final static com.google.common.base.Predicate<Expr> IS_BUILTIN_AGG_FN =
+    public final static com.google.common.base.Predicate<Expr> NON_NULL_EMPTY_AGG =
             new com.google.common.base.Predicate<Expr>() {
                 @Override
                 public boolean apply(Expr arg) {
-                    return arg instanceof FunctionCallExpr &&
-                            ((FunctionCallExpr)arg).getFnName().isBuiltin();
+                    return arg instanceof FunctionCallExpr && ((FunctionCallExpr) arg).returnsNonNullOnEmpty();
                 }
             };
-    */
+
     // Returns true if an Expr is a builtin aggregate function.
     public final static com.google.common.base.Predicate<Expr> CORRELATED_SUBQUERY_SUPPORT_AGG_FN =
             new com.google.common.base.Predicate<Expr>() {
                 @Override
                 public boolean apply(Expr arg) {
                     if (arg instanceof FunctionCallExpr) {
-                        String fnName = ((FunctionCallExpr)arg).getFnName().getFunction();
+                        String fnName = ((FunctionCallExpr) arg).getFnName().getFunction();
                         return  (fnName.equalsIgnoreCase("sum")
                                 || fnName.equalsIgnoreCase("max")
                                 || fnName.equalsIgnoreCase("min")
@@ -156,7 +143,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             new com.google.common.base.Predicate<Expr>() {
                 @Override
                 public boolean apply(Expr arg) {
-                    return arg instanceof BoolLiteral && ((BoolLiteral)arg).getValue();
+                    return arg instanceof BoolLiteral && ((BoolLiteral) arg).getValue();
                 }
             };
 
@@ -164,26 +151,32 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             new com.google.common.base.Predicate<Expr>() {
                 @Override
                 public boolean apply(Expr arg) {
-                    return arg instanceof BoolLiteral && !((BoolLiteral)arg).getValue();
+                    return arg instanceof BoolLiteral && !((BoolLiteral) arg).getValue();
                 }
             };
 
     public final static com.google.common.base.Predicate<Expr> IS_EQ_BINARY_PREDICATE =
             new com.google.common.base.Predicate<Expr>() {
                 @Override
-                public boolean apply(Expr arg) { return BinaryPredicate.getEqSlots(arg) != null; }
+                public boolean apply(Expr arg) {
+                    return BinaryPredicate.getEqSlots(arg) != null;
+                }
             };
 
     public final static com.google.common.base.Predicate<Expr> IS_BINARY_PREDICATE =
             new com.google.common.base.Predicate<Expr>() {
                 @Override
-                public boolean apply(Expr arg) { return arg instanceof BinaryPredicate; }
+                public boolean apply(Expr arg) {
+                    return arg instanceof BinaryPredicate;
+                }
             };
 
     public static final com.google.common.base.Predicate<Expr> IS_NULL_LITERAL =
             new com.google.common.base.Predicate<Expr>() {
                 @Override
-                public boolean apply(Expr arg) { return arg instanceof NullLiteral; }
+                public boolean apply(Expr arg) {
+                    return arg instanceof NullLiteral;
+                }
             };
 
     public static final com.google.common.base.Predicate<Expr> IS_VARCHAR_SLOT_REF_IMPLICIT_CAST =
@@ -302,7 +295,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         return isAnalyzed;
     }
 
-    public void checkValueValid() throws AnalysisException {}
+    public void checkValueValid() throws AnalysisException {
+    }
 
     public ExprId getId() {
         return id;
@@ -329,7 +323,9 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         return selectivity;
     }
 
-    public boolean hasSelectivity() { return selectivity >= 0; }
+    public boolean hasSelectivity() {
+        return selectivity >= 0;
+    }
 
     public long getNumDistinctValues() {
         return numDistinctValues;
@@ -353,14 +349,22 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         return isFilter;
     }
 
-    public void setIsFilter(boolean v) {
-        isFilter = v;
+    public boolean isOnClauseConjunct() {
+        return isOnClauseConjunct;
+    }
+
+    public void setIsOnClauseConjunct(boolean b) {
+        isOnClauseConjunct = b;
+    }
+
+    public boolean isAuxExpr() {
+        return isAuxExpr;
+    }
+
+    public void setIsAuxExpr() {
+        isAuxExpr = true;
     }
 
-    public boolean isOnClauseConjunct() { return isOnClauseConjunct; }
-    public void setIsOnClauseConjunct(boolean b) { isOnClauseConjunct = b; }
-    public boolean isAuxExpr() { return isAuxExpr; }
-    public void setIsAuxExpr() { isAuxExpr = true; }
     public Function getFn() {
         return fn;
     }
@@ -384,8 +388,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
 
         // Check the expr child limit.
         if (children.size() > Config.expr_children_limit) {
-            throw new AnalysisException(String.format("Exceeded the maximum number of child " +
-                    "expressions (%d).", Config.expr_children_limit));
+            throw new AnalysisException(String.format("Exceeded the maximum number of child "
+                    + "expressions (%d).", Config.expr_children_limit));
         }
 
         // analyzer may be null for certain literal constructions (e.g. IntLiteral).
@@ -393,14 +397,14 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             analyzer.incrementCallDepth();
             // Check the expr depth limit. Do not print the toSql() to not overflow the stack.
             if (analyzer.getCallDepth() > Config.expr_depth_limit) {
-                throw new AnalysisException(String.format("Exceeded the maximum depth of an " +
-                        "expression tree (%s).", Config.expr_depth_limit));
+                throw new AnalysisException(String.format("Exceeded the maximum depth of an "
+                        + "expression tree (%s).", Config.expr_depth_limit));
             }
         } else {
             throw new AnalysisException("analyzer is null.");
         }
 
-        for (Expr child: children) {
+        for (Expr child : children) {
             child.analyze(analyzer);
         }
         if (analyzer != null) {
@@ -443,7 +447,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             List<SlotRef> slotRefs = Lists.newArrayList();
             this.collect(SlotRef.class, slotRefs);
             numDistinctValues = -1;
-            for (SlotRef slotRef: slotRefs) {
+            for (SlotRef slotRef : slotRefs) {
                 numDistinctValues = Math.max(numDistinctValues, slotRef.numDistinctValues);
             }
         }
@@ -547,14 +551,14 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
     }
 
     public static <C extends Expr> HashMap<C, Integer> toCountMap(List<C> list) {
-        HashMap countMap = new HashMap<C,Integer>();
+        HashMap countMap = new HashMap<C, Integer>();
         for (int i = 0; i < list.size(); i++) {
             C obj = list.get(i);
             Integer count = (Integer) countMap.get(obj);
             if (count == null) {
                 countMap.put(obj, 1);
             } else {
-                countMap.put(obj, count+1);
+                countMap.put(obj, count + 1);
             }
         }
         return countMap;
@@ -609,22 +613,13 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
      * This can't go into TreeNode<>, because we'd be using the template param
      * NodeType.
      */
-    public static <C extends Expr> void collectList(List<? extends Expr> input, Class<C> cl,
-      List<C> output) {
+    public static <C extends Expr> void collectList(List<? extends Expr> input, Class<C> cl, List<C> output) {
         Preconditions.checkNotNull(input);
         for (Expr e : input) {
             e.collect(cl, output);
         }
     }
 
-    public static <C extends Expr> void collectAggregateExprs(List<? extends Expr> input,
-      List<C> output) {
-        Preconditions.checkNotNull(input);
-        for (Expr e : input) {
-            e.collectAggregateExprs(output);
-        }
-    }
-
     /**
      * get the expr which in l1 and l2 in the same time.
      * Return the intersection of l1 and l2
@@ -632,7 +627,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
     public static <C extends Expr> List<C> intersect(List<C> l1, List<C> l2) {
         List<C> result = new ArrayList<C>();
 
-        for (C element: l1) {
+        for (C element : l1) {
             if (l2.contains(element)) {
                 result.add(element);
             }
@@ -728,14 +723,14 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         }
     }
 
-    public static ArrayList<Expr> trySubstituteList(Iterable <? extends Expr > exprs,
+    public static ArrayList<Expr> trySubstituteList(Iterable<? extends Expr> exprs,
             ExprSubstitutionMap smap, Analyzer analyzer, boolean preserveRootTypes)
             throws AnalysisException {
         if (exprs == null) {
             return null;
         }
         ArrayList<Expr> result = new ArrayList<Expr>();
-        for (Expr e: exprs) {
+        for (Expr e : exprs) {
             result.add(e.trySubstitute(smap, analyzer, preserveRootTypes));
         }
         return result;
@@ -819,7 +814,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
     }
 
     public static <C extends Expr> void getIds(List<? extends Expr> exprs, List<TupleId> tupleIds,
-      List<SlotId> slotIds) {
+            List<SlotId> slotIds) {
         if (exprs == null) {
             return;
         }
@@ -838,22 +833,22 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
      * the exprs have an invalid number of distinct values.
      */
     public static long getNumDistinctValues(List<Expr> exprs) {
-      if (exprs == null || exprs.isEmpty()) {
-          return 0;
-      }
-      long numDistinctValues = 1;
-      for (Expr expr: exprs) {
-        if (expr.getNumDistinctValues() == -1) {
-          numDistinctValues = -1;
-          break;
+        if (exprs == null || exprs.isEmpty()) {
+            return 0;
         }
-        numDistinctValues *= expr.getNumDistinctValues();
-      }
-      return numDistinctValues;
+        long numDistinctValues = 1;
+        for (Expr expr : exprs) {
+            if (expr.getNumDistinctValues() == -1) {
+                numDistinctValues = -1;
+                break;
+            }
+            numDistinctValues *= expr.getNumDistinctValues();
+        }
+        return numDistinctValues;
     }
 
     public void vectorizedAnalyze(Analyzer analyzer) {
-        for (Expr child: children) {
+        for (Expr child : children) {
             child.vectorizedAnalyze(analyzer);
         }
     }
@@ -869,31 +864,6 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             getIds(tupleIds, null);
             Preconditions.checkArgument(tupleIds.size() == 1);
 
-            //List<Expr> reuseExprs = analyzer.getBufferReuseConjuncts(tupleIds.get(0));
-            //for (Expr child : children) {
-                //if (child instanceof SlotRef) {
-                    //if (!((SlotRef) child).getDesc().isMultiRef()) {
-                        //LOG.debug("add " + child.debugString() + " to reuse exprs.");
-                        //reuseExprs.add(child);
-                    //}
-                //} else {
-                    //LOG.debug("add " + child.debugString() + " to reuse exprs.");
-                    //reuseExprs.add(child);
-                //}
-            //}
-
-            //for (Expr reuseExpr : reuseExprs) {
-                //if (reuseExpr.getType() == PrimitiveType.getAssignmentCompatibleType(getType(),
-                  //reuseExpr.getType())) {
-                    //LOG.debug(
-                      //"reuse " + reuseExpr.debugString() + " buffer for " + this.debugString());
-                    //outputColumn = reuseExpr.getOutputColumn();
-                    //Preconditions.checkArgument(outputColumn >= 0);
-                    //reuseExprs.remove(reuseExpr);
-                    //return;
-                //}
-            //}
-
             int currentOutputColumn = analyzer.getCurrentOutputColumn(tupleIds.get(0));
             this.outputColumn = currentOutputColumn;
             LOG.info(debugString() + " outputColumn: " + this.outputColumn);
@@ -1022,27 +992,29 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
      * Resets the internal state of this expr produced by analyze().
      * Only modifies this expr, and not its child exprs.
      */
-    protected void resetAnalysisState() { isAnalyzed = false; }
+    protected void resetAnalysisState() {
+        isAnalyzed = false;
+    }
 
     /**
      * Resets the internal analysis state of this expr tree. Removes implicit casts.
      */
     public Expr reset() {
-      if (isImplicitCast()) {
-          return getChild(0).reset();
-      }
-      for (int i = 0; i < children.size(); ++i) {
-        children.set(i, children.get(i).reset());
-      }
-      resetAnalysisState();
-      return this;
+        if (isImplicitCast()) {
+            return getChild(0).reset();
+        }
+        for (int i = 0; i < children.size(); ++i) {
+            children.set(i, children.get(i).reset());
+        }
+        resetAnalysisState();
+        return this;
     }
 
     public static ArrayList<Expr> resetList(ArrayList<Expr> l) {
-      for (int i = 0; i < l.size(); ++i) {
-        l.set(i, l.get(i).reset());
-      }
-      return l;
+        for (int i = 0; i < l.size(); ++i) {
+            l.set(i, l.get(i).reset());
+        }
+        return l;
     }
 
     /**
@@ -1101,8 +1073,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
      */
     public List<Expr> getConjuncts() {
         List<Expr> list = Lists.newArrayList();
-        if (this instanceof CompoundPredicate && ((CompoundPredicate) this).getOp() ==
-          CompoundPredicate.Operator.AND) {
+        if (this instanceof CompoundPredicate
+                && ((CompoundPredicate) this).getOp() == CompoundPredicate.Operator.AND) {
             // TODO: we have to convert CompoundPredicate.AND to two expr trees for
             // conjuncts because NULLs are handled differently for CompoundPredicate.AND
             // and conjunct evaluation.  This is not optimal for jitted exprs because it
@@ -1189,7 +1161,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
      * Returns true if expr is fully bound by tids, otherwise false.
      */
     public boolean isBoundByTupleIds(List<TupleId> tids) {
-        for (Expr child: children) {
+        for (Expr child : children) {
             if (!child.isBoundByTupleIds(tids)) {
                 return false;
             }
@@ -1317,8 +1289,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
     }
 
     public Expr checkTypeCompatibility(Type targetType) throws AnalysisException {
-        if (targetType.getPrimitiveType() != PrimitiveType.ARRAY &&
-                targetType.getPrimitiveType() == type.getPrimitiveType()) {
+        if (targetType.getPrimitiveType() != PrimitiveType.ARRAY
+                && targetType.getPrimitiveType() == type.getPrimitiveType()) {
             return this;
         }
         // bitmap must match exactly
@@ -1350,8 +1322,8 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             }
         } else if (this instanceof FunctionCallExpr) {
             final FunctionCallExpr functionExpr = (FunctionCallExpr) this;
-            if (!functionExpr.getFnName().getFunction().equalsIgnoreCase("hll_hash") &&
-                    !functionExpr.getFnName().getFunction().equalsIgnoreCase("hll_empty")) {
+            if (!functionExpr.getFnName().getFunction().equalsIgnoreCase("hll_hash")
+                    && !functionExpr.getFnName().getFunction().equalsIgnoreCase("hll_empty")) {
                 throw new AnalysisException(hllMismatchLog);
             }
         } else {
@@ -1379,7 +1351,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         }
 
         if ((targetType.isStringType() || targetType.isHllType())
-               && (this.type.isStringType() || this.type.isHllType())) {
+                && (this.type.isStringType() || this.type.isHllType())) {
             return this;
         }
         // Preconditions.checkState(PrimitiveType.isImplicitCast(type, targetType), "cast %s to %s", this.type, targetType);
@@ -1582,14 +1554,14 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         return null;
     }
 
-    public static double getConstFromExpr(Expr e) throws AnalysisException{
+    public static double getConstFromExpr(Expr e) throws AnalysisException {
         Preconditions.checkState(e.isConstant());
         double value = 0;
-        if( e instanceof LiteralExpr){
-            LiteralExpr lit = (LiteralExpr)e;
+        if (e instanceof LiteralExpr) {
+            LiteralExpr lit = (LiteralExpr) e;
             value = lit.getDoubleValue();
         } else {
-            throw new AnalysisException("To const value not a LiteralExpr " );
+            throw new AnalysisException("To const value not a LiteralExpr ");
         }
         return value;
     }
@@ -1675,7 +1647,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             try {
                 // Make sure we call function 'negate' only on classes that support it,
                 // otherwise we may recurse infinitely.
-                Method m = root.getChild(0).getClass().getDeclaredMethod(NEGATE_FN);
+                root.getChild(0).getClass().getDeclaredMethod(NEGATE_FN);
                 return pushNegationToOperands(root.getChild(0).negate());
             } catch (NoSuchMethodException e) {
                 // The 'negate' function is not implemented. Break the recursion.
@@ -1687,7 +1659,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             Expr left = pushNegationToOperands(root.getChild(0));
             Expr right = pushNegationToOperands(root.getChild(1));
             CompoundPredicate compoundPredicate =
-                    new CompoundPredicate(((CompoundPredicate)root).getOp(), left, right);
+                    new CompoundPredicate(((CompoundPredicate) root).getOp(), left, right);
             compoundPredicate.setPrintSqlInParens(root.getPrintSqlInParens());
             return compoundPredicate;
         }
@@ -1806,9 +1778,9 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
             output.writeInt(ExprSerCode.FUNCTION_CALL.getCode());
         } else if (expr instanceof ArrayLiteral) {
             output.writeInt(ExprSerCode.ARRAY_LITERAL.getCode());
-        } else if (expr instanceof CastExpr){
+        } else if (expr instanceof CastExpr) {
             output.writeInt(ExprSerCode.CAST_EXPR.getCode());
-        }else {
+        } else {
             throw new IOException("Unknown class " + expr.getClass().getName());
         }
         expr.write(output);
@@ -1895,7 +1867,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
     }
 
     public static Expr getFirstBoundChild(Expr expr, List<TupleId> tids) {
-        for (Expr child: expr.getChildren()) {
+        for (Expr child : expr.getChildren()) {
             if (child.isBoundByTupleIds(tids)) {
                 return child;
             }
@@ -1913,7 +1885,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         if (fn.functionName().equalsIgnoreCase(functionName))  {
             return true;
         }
-        for (Expr child: children) {
+        for (Expr child : children) {
             if (child.isContainsFunction(functionName)) {
                 return true;
             }
@@ -1928,7 +1900,7 @@ abstract public class Expr extends TreeNode<Expr> implements ParseNode, Cloneabl
         if (this.getClass().getName().equalsIgnoreCase(className)) {
             return true;
         }
-        for (Expr child: children) {
+        for (Expr child : children) {
             if (child.isContainsClass(className)) {
                 return true;
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprId.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprId.java
index 8507fd26a5..79b2fc721e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprId.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprId.java
@@ -37,9 +37,14 @@ public class ExprId extends Id<ExprId> {
     public static IdGenerator<ExprId> createGenerator() {
         return new IdGenerator<ExprId>() {
             @Override
-            public ExprId getNextId() { return new ExprId(nextId++); }
+            public ExprId getNextId() {
+                return new ExprId(nextId++);
+            }
+
             @Override
-            public ExprId getMaxId() { return new ExprId(nextId - 1); }
+            public ExprId getMaxId() {
+                return new ExprId(nextId - 1);
+            }
         };
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprSubstitutionMap.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprSubstitutionMap.java
index b7d44fe501..46b9caa0fa 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprSubstitutionMap.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExprSubstitutionMap.java
@@ -157,10 +157,17 @@ public final class ExprSubstitutionMap {
         lhs = Expr.substituteList(lhs, lhsSmap, analyzer, false);
     }
 
-    public List<Expr> getLhs() { return lhs; }
-    public List<Expr> getRhs() { return rhs; }
+    public List<Expr> getLhs() {
+        return lhs;
+    }
+
+    public List<Expr> getRhs() {
+        return rhs;
+    }
 
-    public int size() { return lhs.size(); }
+    public int size() {
+        return lhs.size();
+    }
 
     public String debugString() {
         Preconditions.checkState(lhs.size() == rhs.size());
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExpressionFunctions.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExpressionFunctions.java
index 7789202e88..220fe55299 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ExpressionFunctions.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ExpressionFunctions.java
@@ -192,7 +192,7 @@ public enum ExpressionFunctions {
         public LiteralExpr invoke(List<Expr> args) throws AnalysisException {
             final List<Object> invokeArgs = createInvokeArgs(args);
             try {
-                return (LiteralExpr)method.invoke(null, invokeArgs.toArray());
+                return (LiteralExpr) method.invoke(null, invokeArgs.toArray());
             } catch (InvocationTargetException | IllegalAccessException | IllegalArgumentException e) {
                 throw new AnalysisException(e.getLocalizedMessage());
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/FloatLiteral.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/FloatLiteral.java
index 1bceef48de..ea1322835d 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/FloatLiteral.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/FloatLiteral.java
@@ -201,7 +201,7 @@ public class FloatLiteral extends LiteralExpr {
         return 31 * super.hashCode() + Double.hashCode(value);
     }
 
-    private String timeStrFromFloat (double time) {
+    private String timeStrFromFloat(double time) {
         String timeStr = "";
 
         if (time < 0) {
@@ -209,7 +209,7 @@ public class FloatLiteral extends LiteralExpr {
             time = -time;
         }
         int hour = (int) (time / 60 / 60);
-        int minute = (int)((time / 60)) % 60;
+        int minute = (int) ((time / 60)) % 60;
         int second = (int) (time) % 60;
 
         return "'" + timeStr + String.format("%02d:%02d:%02d", hour, minute, second) + "'";
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/FromClause.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/FromClause.java
index 4906de085a..dfb247a7c4 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/FromClause.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/FromClause.java
@@ -22,7 +22,6 @@ package org.apache.doris.analysis;
 
 
 import org.apache.doris.catalog.Database;
-import org.apache.doris.catalog.Table;
 import org.apache.doris.cluster.ClusterNamespace;
 import org.apache.doris.common.AnalysisException;
 import org.apache.doris.common.ErrorCode;
@@ -59,8 +58,14 @@ public class FromClause implements ParseNode, Iterable<TableRef> {
         }
     }
 
-    public FromClause() { tablerefs = Lists.newArrayList(); }
-    public List<TableRef> getTableRefs() { return tablerefs; }
+    public FromClause() {
+        tablerefs = Lists.newArrayList();
+    }
+
+    public List<TableRef> getTableRefs() {
+        return tablerefs;
+    }
+
     public void setNeedToSql(boolean needToSql) {
         this.needToSql = needToSql;
     }
@@ -84,7 +89,7 @@ public class FromClause implements ParseNode, Iterable<TableRef> {
 
             Database db = analyzer.getCatalog().getDbOrAnalysisException(dbName);
             String tblName = tableName.getTbl();
-            Table table = db.getTableOrAnalysisException(tblName);
+            db.getTableOrAnalysisException(tblName);
         }
     }
 
@@ -158,7 +163,7 @@ public class FromClause implements ParseNode, Iterable<TableRef> {
 
     public FromClause clone() {
         ArrayList<TableRef> clone = Lists.newArrayList();
-        for (TableRef tblRef: tablerefs) {
+        for (TableRef tblRef : tablerefs) {
             clone.add(tblRef.clone());
         }
         return new FromClause(clone);
@@ -166,20 +171,6 @@ public class FromClause implements ParseNode, Iterable<TableRef> {
 
     public void reset() {
         for (int i = 0; i < size(); ++i) {
-            TableRef origTblRef = get(i);
-            // TODO(zc):
-            // if (origTblRef.isResolved() && !(origTblRef instanceof InlineViewRef)) {
-            //     // Replace resolved table refs with unresolved ones.
-            //     TableRef newTblRef = new TableRef(origTblRef);
-            //     // Use the fully qualified raw path to preserve the original resolution.
-            //     // Otherwise, non-fully qualified paths might incorrectly match a local view.
-            //     // TODO for 2.3: This full qualification preserves analysis state which is
-            //     // contrary to the intended semantics of reset(). We could address this issue by
-            //     // changing the WITH-clause analysis to register local views that have
-            //     // fully-qualified table refs, and then remove the full qualification here.
-            //     newTblRef.rawPath_ = origTblRef.getResolvedPath().getFullyQualifiedRawPath();
-            //     set(i, newTblRef);
-            // }
             get(i).reset();
         }
         this.analyzed = false;
@@ -208,14 +199,36 @@ public class FromClause implements ParseNode, Iterable<TableRef> {
         return builder.toString();
     }
 
-    public boolean isEmpty() { return tablerefs.isEmpty(); }
+    public boolean isEmpty() {
+        return tablerefs.isEmpty();
+    }
 
     @Override
-    public Iterator<TableRef> iterator() { return tablerefs.iterator(); }
-    public int size() { return tablerefs.size(); }
-    public TableRef get(int i) { return tablerefs.get(i); }
-    public void set(int i, TableRef tableRef) { tablerefs.set(i, tableRef); }
-    public void add(TableRef t) { tablerefs.add(t); }
-    public void addAll(List<TableRef> t) { tablerefs.addAll(t); }
-    public void clear() { tablerefs.clear(); }
+    public Iterator<TableRef> iterator() {
+        return tablerefs.iterator();
+    }
+
+    public int size() {
+        return tablerefs.size();
+    }
+
+    public TableRef get(int i) {
+        return tablerefs.get(i);
+    }
+
+    public void set(int i, TableRef tableRef) {
+        tablerefs.set(i, tableRef);
+    }
+
+    public void add(TableRef t) {
+        tablerefs.add(t);
+    }
+
+    public void addAll(List<TableRef> t) {
+        tablerefs.addAll(t);
+    }
+
+    public void clear() {
+        tablerefs.clear();
+    }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionArgsDef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionArgsDef.java
index d0b07e9bea..cdc6c62d68 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionArgsDef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionArgsDef.java
@@ -37,8 +37,13 @@ public class FunctionArgsDef {
         this.isVariadic = isVariadic;
     }
 
-    public Type[] getArgTypes() { return argTypes; }
-    public boolean isVariadic() { return isVariadic; }
+    public Type[] getArgTypes() {
+        return argTypes;
+    }
+
+    public boolean isVariadic() {
+        return isVariadic;
+    }
 
     public void analyze(Analyzer analyzer) throws AnalysisException {
         argTypes = new Type[argTypeDefs.size()];
@@ -71,5 +76,7 @@ public class FunctionArgsDef {
     }
 
     @Override
-    public String toString() { return toSql(); }
+    public String toString() {
+        return toSql();
+    }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionCallExpr.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionCallExpr.java
index e5f45317bd..75d9800dbc 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionCallExpr.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionCallExpr.java
@@ -248,21 +248,21 @@ public class FunctionCallExpr extends Expr {
         }
         int len = children.size();
         List<String> result = Lists.newArrayList();
-        if (fnName.getFunction().equalsIgnoreCase("json_array") ||
-                fnName.getFunction().equalsIgnoreCase("json_object")) {
+        if (fnName.getFunction().equalsIgnoreCase("json_array")
+                || fnName.getFunction().equalsIgnoreCase("json_object")) {
             len = len - 1;
         }
-        if (fnName.getFunction().equalsIgnoreCase("aes_decrypt") ||
-                fnName.getFunction().equalsIgnoreCase("aes_encrypt") ||
-                fnName.getFunction().equalsIgnoreCase("sm4_decrypt") ||
-                fnName.getFunction().equalsIgnoreCase("sm4_encrypt")) {
+        if (fnName.getFunction().equalsIgnoreCase("aes_decrypt")
+                || fnName.getFunction().equalsIgnoreCase("aes_encrypt")
+                || fnName.getFunction().equalsIgnoreCase("sm4_decrypt")
+                || fnName.getFunction().equalsIgnoreCase("sm4_encrypt")) {
             len = len - 1;
         }
         for (int i = 0; i < len; ++i) {
-            if (i == 1 && (fnName.getFunction().equalsIgnoreCase("aes_decrypt") ||
-                    fnName.getFunction().equalsIgnoreCase("aes_encrypt") ||
-                    fnName.getFunction().equalsIgnoreCase("sm4_decrypt") ||
-                    fnName.getFunction().equalsIgnoreCase("sm4_encrypt"))) {
+            if (i == 1 && (fnName.getFunction().equalsIgnoreCase("aes_decrypt")
+                    || fnName.getFunction().equalsIgnoreCase("aes_encrypt")
+                    || fnName.getFunction().equalsIgnoreCase("sm4_decrypt")
+                    || fnName.getFunction().equalsIgnoreCase("sm4_encrypt"))) {
                 result.add("\'***\'");
             } else {
                 result.add(children.get(i).toSql());
@@ -283,9 +283,9 @@ public class FunctionCallExpr extends Expr {
         StringBuilder sb = new StringBuilder();
         sb.append(((FunctionCallExpr) expr).fnName);
         sb.append(paramsToSql());
-        if (fnName.getFunction().equalsIgnoreCase("json_quote") ||
-            fnName.getFunction().equalsIgnoreCase("json_array") ||
-            fnName.getFunction().equalsIgnoreCase("json_object")) {
+        if (fnName.getFunction().equalsIgnoreCase("json_quote")
+                || fnName.getFunction().equalsIgnoreCase("json_array")
+                || fnName.getFunction().equalsIgnoreCase("json_object")) {
             return forJSON(sb.toString());
         }
         return sb.toString();
@@ -303,21 +303,21 @@ public class FunctionCallExpr extends Expr {
         }
         int len = children.size();
         List<String> result = Lists.newArrayList();
-        if (fnName.getFunction().equalsIgnoreCase("json_array") ||
-                fnName.getFunction().equalsIgnoreCase("json_object")) {
+        if (fnName.getFunction().equalsIgnoreCase("json_array")
+                || fnName.getFunction().equalsIgnoreCase("json_object")) {
             len = len - 1;
         }
-        if (fnName.getFunction().equalsIgnoreCase("aes_decrypt") ||
-                fnName.getFunction().equalsIgnoreCase("aes_encrypt") ||
-                fnName.getFunction().equalsIgnoreCase("sm4_decrypt") ||
-                fnName.getFunction().equalsIgnoreCase("sm4_encrypt")) {
+        if (fnName.getFunction().equalsIgnoreCase("aes_decrypt")
+                || fnName.getFunction().equalsIgnoreCase("aes_encrypt")
+                || fnName.getFunction().equalsIgnoreCase("sm4_decrypt")
+                || fnName.getFunction().equalsIgnoreCase("sm4_encrypt")) {
             len = len - 1;
         }
         for (int i = 0; i < len; ++i) {
-            if (i == 1 && (fnName.getFunction().equalsIgnoreCase("aes_decrypt") ||
-                    fnName.getFunction().equalsIgnoreCase("aes_encrypt") ||
-                    fnName.getFunction().equalsIgnoreCase("sm4_decrypt") ||
-                    fnName.getFunction().equalsIgnoreCase("sm4_encrypt"))) {
+            if (i == 1 && (fnName.getFunction().equalsIgnoreCase("aes_decrypt")
+                    || fnName.getFunction().equalsIgnoreCase("aes_encrypt")
+                    || fnName.getFunction().equalsIgnoreCase("sm4_decrypt")
+                    || fnName.getFunction().equalsIgnoreCase("sm4_encrypt"))) {
                 result.add("\'***\'");
             } else {
                 result.add(children.get(i).toDigest());
@@ -338,9 +338,9 @@ public class FunctionCallExpr extends Expr {
         StringBuilder sb = new StringBuilder();
         sb.append(((FunctionCallExpr) expr).fnName);
         sb.append(paramsToDigest());
-        if (fnName.getFunction().equalsIgnoreCase("json_quote") ||
-                fnName.getFunction().equalsIgnoreCase("json_array") ||
-                fnName.getFunction().equalsIgnoreCase("json_object")) {
+        if (fnName.getFunction().equalsIgnoreCase("json_quote")
+                || fnName.getFunction().equalsIgnoreCase("json_array")
+                || fnName.getFunction().equalsIgnoreCase("json_object")) {
             return forJSON(sb.toString());
         }
         return sb.toString();
@@ -560,8 +560,8 @@ public class FunctionCallExpr extends Expr {
 
         if (fnName.getFunction().equalsIgnoreCase(FunctionSet.INTERSECT_COUNT)) {
             if (children.size() <= 2) {
-                throw new AnalysisException("intersect_count(bitmap_column, column_to_filter, filter_values) " +
-                        "function requires at least three parameters");
+                throw new AnalysisException("intersect_count(bitmap_column, column_to_filter, filter_values) "
+                        + "function requires at least three parameters");
             }
 
             Type inputType = getChild(0).getType();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionName.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionName.java
index 754a9cf924..58cf458f94 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionName.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/FunctionName.java
@@ -144,9 +144,8 @@ public class FunctionName implements Writable {
         }
         for (int i = 0; i < fn.length(); ++i) {
             if (!isValidCharacter(fn.charAt(i))) {
-                throw new AnalysisException(
-                  "Function names must be all alphanumeric or underscore. " +
-                    "Invalid name: " + fn);
+                throw new AnalysisException("Function names must be all alphanumeric or underscore. "
+                          + "Invalid name: " + fn);
             }
         }
         if (Character.isDigit(fn.charAt(0))) {
@@ -163,13 +162,6 @@ public class FunctionName implements Writable {
             }
             db = ClusterNamespace.getFullName(analyzer.getClusterName(), db);
         }
-
-        // If the function name is not fully qualified, it must not be the same as a builtin
-//        if (!isFullyQualified() && OpcodeRegistry.instance().getFunctionOperator(
-//          getFunction()) != FunctionOperator.INVALID_OPERATOR) {
-//            throw new AnalysisException(
-//              "Function cannot have the same name as a builtin: " + getFunction());
-//        }
     }
 
     private boolean isValidCharacter(char c) {
@@ -201,7 +193,7 @@ public class FunctionName implements Writable {
         fn = Text.readString(in);
     }
 
-    public static FunctionName read(DataInput in) throws IOException{
+    public static FunctionName read(DataInput in) throws IOException {
         FunctionName functionName = new FunctionName();
         functionName.readFields(in);
         return functionName;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/GrantStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/GrantStmt.java
index be915b9d27..c137b31a19 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/GrantStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/GrantStmt.java
@@ -159,7 +159,7 @@ public class GrantStmt extends DdlStmt {
                 if (!Catalog.getCurrentCatalog().getAuth().checkGlobalPriv(ConnectContext.get(), PrivPredicate.GRANT)) {
                     ErrorReport.reportAnalysisException(ErrorCode.ERR_SPECIFIC_ACCESS_DENIED_ERROR, "GRANT");
                 }
-            } else if (tblPattern.getPrivLevel() == PrivLevel.DATABASE){
+            } else if (tblPattern.getPrivLevel() == PrivLevel.DATABASE) {
                 if (!Catalog.getCurrentCatalog().getAuth().checkDbPriv(ConnectContext.get(), tblPattern.getQualifiedDb(), PrivPredicate.GRANT)) {
                     ErrorReport.reportAnalysisException(ErrorCode.ERR_SPECIFIC_ACCESS_DENIED_ERROR, "GRANT");
                 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/GroupingInfo.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/GroupingInfo.java
index 7968fb305d..3387d17dcb 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/GroupingInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/GroupingInfo.java
@@ -179,7 +179,7 @@ public class GroupingInfo {
     public void substituteGroupingFn(Expr expr, Analyzer analyzer) throws AnalysisException {
         if (expr instanceof GroupingFunctionCallExpr) {
             // TODO(yangzhengguo) support expression in grouping functions
-            for (Expr child: expr.getChildren()) {
+            for (Expr child : expr.getChildren()) {
                 if (!(child instanceof SlotRef)) {
                     throw new AnalysisException("grouping functions only support column in current version.");
                     // expr from inline view
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/InPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/InPredicate.java
index de9d7ffad7..32f9bd5ffb 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/InPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/InPredicate.java
@@ -50,7 +50,7 @@ public class InPredicate extends Predicate {
 
     private static final String IN_SET_LOOKUP = "in_set_lookup";
     private static final String NOT_IN_SET_LOOKUP = "not_in_set_lookup";
-    private static final String IN_ITERATE= "in_iterate";
+    private static final String IN_ITERATE = "in_iterate";
     private static final String NOT_IN_ITERATE = "not_in_iterate";
     private final boolean isNotIn;
     private static final String IN = "in";
@@ -59,7 +59,7 @@ public class InPredicate extends Predicate {
     private static final NullLiteral NULL_LITERAL = new NullLiteral();
 
     public static void initBuiltins(FunctionSet functionSet) {
-        for (Type t: Type.getSupportedTypes()) {
+        for (Type t : Type.getSupportedTypes()) {
             if (t.isNull()) {
                 continue;
             }
@@ -129,8 +129,7 @@ public class InPredicate extends Predicate {
      */
     @Override
     public Expr negate() {
-      return new InPredicate(getChild(0), children.subList(1, children.size()),
-          !isNotIn);
+        return new InPredicate(getChild(0), children.subList(1, children.size()), !isNotIn);
     }
 
     public List<Expr> getListChildren() {
@@ -150,19 +149,10 @@ public class InPredicate extends Predicate {
         return true;
     }
 
-   @Override
-   public void vectorizedAnalyze(Analyzer analyzer) {
+    @Override
+    public void vectorizedAnalyze(Analyzer analyzer) {
         super.vectorizedAnalyze(analyzer);
-
-       PrimitiveType type = getChild(0).getType().getPrimitiveType();
-
-//       OpcodeRegistry.BuiltinFunction match = OpcodeRegistry.instance().getFunctionInfo(
-//               FunctionOperator.FILTER_IN, true, true, type);
-//       Preconditions.checkState(match != null);
-//       Preconditions.checkState(match.getReturnType().equals(Type.BOOLEAN));
-//       this.vectorOpcode = match.opcode;
-//       LOG.info(debugString() + " opcode: " + vectorOpcode);
-   }
+    }
 
     @Override
     public void analyzeImpl(Analyzer analyzer) throws AnalysisException {
@@ -172,13 +162,11 @@ public class InPredicate extends Predicate {
             // An [NOT] IN predicate with a subquery must contain two children, the second of
             // which is a Subquery.
             if (children.size() != 2 || !(getChild(1) instanceof Subquery)) {
-                throw new AnalysisException("Unsupported IN predicate with a subquery: " +
-                    toSql());
+                throw new AnalysisException("Unsupported IN predicate with a subquery: " + toSql());
             }
-            Subquery subquery = (Subquery)getChild(1);
+            Subquery subquery = (Subquery) getChild(1);
             if (!subquery.returnsScalarColumn()) {
-                throw new AnalysisException("Subquery must return a single column: " +
-                subquery.toSql());
+                throw new AnalysisException("Subquery must return a single column: " + subquery.toSql());
             }
 
             // Ensure that the column in the lhs of the IN predicate and the result of
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/IndexDef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/IndexDef.java
index 8624bb3fe3..fd67d085c5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/IndexDef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/IndexDef.java
@@ -133,8 +133,8 @@ public class IndexDef {
         if (indexType == IndexType.BITMAP) {
             String indexColName = column.getName();
             PrimitiveType colType = column.getDataType();
-            if (!(colType.isDateType() || colType.isDecimalV2Type() || colType.isFixedPointType() ||
-                          colType.isStringType() || colType == PrimitiveType.BOOLEAN)) {
+            if (!(colType.isDateType() || colType.isDecimalV2Type() || colType.isFixedPointType()
+                    || colType.isStringType() || colType == PrimitiveType.BOOLEAN)) {
                 throw new AnalysisException(colType + " is not supported in bitmap index. "
                         + "invalid column: " + indexColName);
             } else if ((keysType == KeysType.AGG_KEYS && !column.isKey())) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/InformationFunction.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/InformationFunction.java
index a9fd4a3f6e..6ae4588f5f 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/InformationFunction.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/InformationFunction.java
@@ -50,7 +50,9 @@ public class InformationFunction extends Expr {
         return String.valueOf(intValue);
     }
 
-    public String getFuncType() {return funcType; }
+    public String getFuncType() {
+        return funcType;
+    }
 
     @Override
     public Expr clone() {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/InlineViewRef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/InlineViewRef.java
index 835fd21f5e..53689a4052 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/InlineViewRef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/InlineViewRef.java
@@ -136,7 +136,9 @@ public class InlineViewRef extends TableRef {
         baseTblSmap = other.baseTblSmap.clone();
     }
 
-    public List<String> getExplicitColLabels() { return explicitColLabels; }
+    public List<String> getExplicitColLabels() {
+        return explicitColLabels;
+    }
 
     public List<String> getColLabels() {
         if (explicitColLabels != null) {
@@ -148,12 +150,12 @@ public class InlineViewRef extends TableRef {
 
     @Override
     public void reset() {
-      super.reset();
-      queryStmt.reset();
-      inlineViewAnalyzer = null;
-      materializedTupleIds.clear();
-      sMap.clear();
-      baseTblSmap.clear();
+        super.reset();
+        queryStmt.reset();
+        inlineViewAnalyzer = null;
+        materializedTupleIds.clear();
+        sMap.clear();
+        baseTblSmap.clear();
     }
 
     @Override
@@ -378,19 +380,6 @@ public class InlineViewRef extends TableRef {
             return true;
         }
         return true;
-
-//        // Replace all SlotRefs in expr with NullLiterals, and wrap the result
-//        // into an IS NOT NULL predicate.
-//        Expr isNotNullLiteralPred = new IsNullPredicate(expr.clone(nullSMap), true);
-//        Preconditions.checkState(isNotNullLiteralPred.isConstant());
-//        // analyze to insert casts, etc.
-//        try {
-//            isNotNullLiteralPred.analyze(analyzer);
-//        } catch (AnalysisException e) {
-//            // this should never happen
-//            throw new InternalException("couldn't analyze predicate " + isNotNullLiteralPred.toSql(), e);
-//        }
-//        return FeSupport.EvalPredicate(isNotNullLiteralPred, analyzer.getQueryGlobals());
     }
 
     @Override
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/InsertStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/InsertStmt.java
index 3c41381576..ff0fbd71d3 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/InsertStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/InsertStmt.java
@@ -419,7 +419,8 @@ public class InsertStmt extends DdlStmt {
             // hll column mush in mentionedColumns
             for (Column col : targetTable.getBaseSchema()) {
                 if (col.getType().isObjectStored() && !mentionedColumns.contains(col.getName())) {
-                    throw new AnalysisException (" object-stored column " + col.getName() + " mush in insert into columns");
+                    throw new AnalysisException(" object-stored column " + col.getName()
+                            + " mush in insert into columns");
                 }
             }
         }
@@ -483,7 +484,7 @@ public class InsertStmt extends DdlStmt {
         }
 
         // Check if all columns mentioned is enough
-        checkColumnCoverage(mentionedColumns, targetTable.getBaseSchema()) ;
+        checkColumnCoverage(mentionedColumns, targetTable.getBaseSchema());
 
         // handle VALUES() or SELECT constant list
         if (isValuesOrConstantSelect) {
@@ -686,8 +687,7 @@ public class InsertStmt extends DdlStmt {
                      */
                     Preconditions.checkState(col.isAllowNull());
                     resultExprs.add(NullLiteral.create(col.getType()));
-                }
-                else {
+                } else {
                     StringLiteral defaultValueExpr = new StringLiteral(col.getDefaultValue());
                     resultExprs.add(defaultValueExpr.checkTypeCompatibility(col.getType()));
                 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/IsNullPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/IsNullPredicate.java
index 619fe484e0..a196c89f55 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/IsNullPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/IsNullPredicate.java
@@ -39,19 +39,19 @@ public class IsNullPredicate extends Predicate {
     private static final String IS_NOT_NULL = "is_not_null_pred";
 
     public static void initBuiltins(FunctionSet functionSet) {
-        for (Type t: Type.getSupportedTypes()) {
+        for (Type t : Type.getSupportedTypes()) {
             if (t.isNull()) {
                 continue;
             }
             String isNullSymbol;
             if (t == Type.BOOLEAN) {
-                isNullSymbol = "_ZN5doris15IsNullPredicate7is_nullIN9doris_udf10BooleanValE" +
-                        "EES3_PNS2_15FunctionContextERKT_";
+                isNullSymbol = "_ZN5doris15IsNullPredicate7is_nullIN9doris_udf10BooleanValE"
+                        + "EES3_PNS2_15FunctionContextERKT_";
             } else {
                 String udfType = Function.getUdfType(t.getPrimitiveType());
-                isNullSymbol = "_ZN5doris15IsNullPredicate7is_nullIN9doris_udf" +
-                        udfType.length() + udfType +
-                        "EEENS2_10BooleanValEPNS2_15FunctionContextERKT_";
+                isNullSymbol = "_ZN5doris15IsNullPredicate7is_nullIN9doris_udf"
+                        + udfType.length() + udfType
+                        + "EEENS2_10BooleanValEPNS2_15FunctionContextERKT_";
             }
 
             functionSet.addBuiltinBothScalaAndVectorized(ScalarFunction.createBuiltinOperator(
@@ -150,7 +150,7 @@ public class IsNullPredicate extends Predicate {
     public Expr getResultValue() throws AnalysisException {
         recursiveResetChildrenResult();
         final Expr childValue = getChild(0);
-        if(!(childValue instanceof LiteralExpr)) {
+        if (!(childValue instanceof LiteralExpr)) {
             return this;
         }
         return childValue instanceof NullLiteral ? new BoolLiteral(!isNotNull) : new BoolLiteral(isNotNull);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/JoinOperator.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/JoinOperator.java
index c7e532465e..f0f6356ff2 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/JoinOperator.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/JoinOperator.java
@@ -66,9 +66,9 @@ public enum JoinOperator {
     }
 
     public boolean isSemiJoin() {
-        return this == JoinOperator.LEFT_SEMI_JOIN || this == JoinOperator.LEFT_ANTI_JOIN ||
-                this == JoinOperator.RIGHT_SEMI_JOIN || this == JoinOperator.RIGHT_ANTI_JOIN ||
-                this == JoinOperator.NULL_AWARE_LEFT_ANTI_JOIN;
+        return this == JoinOperator.LEFT_SEMI_JOIN || this == JoinOperator.LEFT_ANTI_JOIN
+                || this == JoinOperator.RIGHT_SEMI_JOIN || this == JoinOperator.RIGHT_ANTI_JOIN
+                || this == JoinOperator.NULL_AWARE_LEFT_ANTI_JOIN;
     }
 
     public boolean isLeftSemiJoin() {
@@ -80,8 +80,8 @@ public enum JoinOperator {
     }
 
     public boolean isAntiJoin() {
-        return this == JoinOperator.LEFT_ANTI_JOIN || this == JoinOperator.RIGHT_ANTI_JOIN ||
-                this == JoinOperator.NULL_AWARE_LEFT_ANTI_JOIN;
+        return this == JoinOperator.LEFT_ANTI_JOIN || this == JoinOperator.RIGHT_ANTI_JOIN
+                || this == JoinOperator.NULL_AWARE_LEFT_ANTI_JOIN;
     }
 
     public boolean isCrossJoin() {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/LoadStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/LoadStmt.java
index 99162b4084..1c12ad69e5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/LoadStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/LoadStmt.java
@@ -89,8 +89,8 @@ public class LoadStmt extends DdlStmt {
 
     // mini load params
     public static final String KEY_IN_PARAM_COLUMNS = "columns";
-    public static final String KEY_IN_PARAM_SET= "set";
-    public static final String KEY_IN_PARAM_HLL= "hll";
+    public static final String KEY_IN_PARAM_SET = "set";
+    public static final String KEY_IN_PARAM_HLL = "hll";
     public static final String KEY_IN_PARAM_COLUMN_SEPARATOR = "column_separator";
     public static final String KEY_IN_PARAM_LINE_DELIMITER = "line_delimiter";
     public static final String KEY_IN_PARAM_PARTITIONS = "partitions";
@@ -346,9 +346,9 @@ public class LoadStmt extends DdlStmt {
             if (brokerDesc != null && !brokerDesc.isMultiLoadBroker()) {
                 for (int i = 0; i < dataDescription.getFilePaths().size(); i++) {
                     dataDescription.getFilePaths().set(i,
-                        brokerDesc.convertPathToS3(dataDescription.getFilePaths().get(i)));
+                            brokerDesc.convertPathToS3(dataDescription.getFilePaths().get(i)));
                     dataDescription.getFilePaths().set(i,
-                        ExportStmt.checkPath(dataDescription.getFilePaths().get(i), brokerDesc.getStorageType()));
+                            ExportStmt.checkPath(dataDescription.getFilePaths().get(i), brokerDesc.getStorageType()));
                 }
             }
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/LockTablesStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/LockTablesStmt.java
index d62921ca2c..924187ba90 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/LockTablesStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/LockTablesStmt.java
@@ -19,7 +19,6 @@ package org.apache.doris.analysis;
 
 import org.apache.doris.catalog.Catalog;
 import org.apache.doris.catalog.Database;
-import org.apache.doris.catalog.Table;
 import org.apache.doris.cluster.ClusterNamespace;
 import org.apache.doris.common.ErrorCode;
 import org.apache.doris.common.ErrorReport;
@@ -61,7 +60,7 @@ public class LockTablesStmt extends StatementBase {
                 ErrorReport.reportAnalysisException(ErrorCode.ERR_UNKNOWN_TABLE, tableName, dbName);
             }
             Database db = analyzer.getCatalog().getDbOrAnalysisException(dbName);
-            Table table = db.getTableOrAnalysisException(tableName);
+            db.getTableOrAnalysisException(tableName);
 
             // check auth
             if (!Catalog.getCurrentCatalog().getAuth().checkTblPriv(ConnectContext.get(), dbName,
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnHLLUnionPattern.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnHLLUnionPattern.java
index f6f6c7364c..eb867e500a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnHLLUnionPattern.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnHLLUnionPattern.java
@@ -32,7 +32,7 @@ public class MVColumnHLLUnionPattern implements MVColumnPattern {
             return false;
         }
         String fnNameString = fnExpr.getFnName().getFunction();
-        if (!fnNameString.equalsIgnoreCase(FunctionSet.HLL_UNION)){
+        if (!fnNameString.equalsIgnoreCase(FunctionSet.HLL_UNION)) {
             return false;
         }
         if (fnExpr.getChild(0) instanceof SlotRef) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnItem.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnItem.java
index dea62f68fe..fabf5b1020 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnItem.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/MVColumnItem.java
@@ -114,7 +114,7 @@ public class MVColumnItem {
             result.setIsKey(isKey);
             // If the mv column type is inconsistent with the base column type, the daily test will core.
             // So, I comment this line firstly.
-//            result.setType(type);
+            // result.setType(type);
             result.setAggregationType(aggregationType, isAggregationTypeImplicit);
             return result;
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ModifyColumnClause.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ModifyColumnClause.java
index 9783396a58..afa369f089 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ModifyColumnClause.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ModifyColumnClause.java
@@ -37,7 +37,9 @@ public class ModifyColumnClause extends AlterTableClause {
     // set in analyze
     private Column column;
 
-    public Column getColumn() { return column; }
+    public Column getColumn() {
+        return column;
+    }
 
     public ColumnPosition getColPos() {
         return colPos;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/NullLiteral.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/NullLiteral.java
index 144915fabb..db2413fd8e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/NullLiteral.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/NullLiteral.java
@@ -61,8 +61,8 @@ public class NullLiteral extends LiteralExpr {
 
     @Override
     protected void resetAnalysisState() {
-      super.resetAnalysisState();
-      type = Type.NULL;
+        super.resetAnalysisState();
+        type = Type.NULL;
     }
 
     @Override
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/OrderByElement.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/OrderByElement.java
index 3743f055e5..c9d96ed043 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/OrderByElement.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/OrderByElement.java
@@ -75,8 +75,8 @@ public class OrderByElement {
         for (int i = 0; i < src.size(); ++i) {
             OrderByElement element = src.get(i);
             OrderByElement reverseElement =
-                new OrderByElement(element.getExpr().clone(), !element.isAsc,
-                       Boolean.valueOf(!nullsFirst(element.nullsFirstParam, element.isAsc)));
+                    new OrderByElement(element.getExpr().clone(), !element.isAsc,
+                            !nullsFirst(element.nullsFirstParam, element.isAsc));
             result.add(reverseElement);
         }
 
@@ -88,7 +88,7 @@ public class OrderByElement {
     public static List<Expr> getOrderByExprs(List<OrderByElement> src) {
         List<Expr> result = Lists.newArrayListWithCapacity(src.size());
 
-        for (OrderByElement element: src) {
+        for (OrderByElement element : src) {
             result.add(element.getExpr());
         }
 
@@ -104,7 +104,7 @@ public class OrderByElement {
             ExprSubstitutionMap smap, Analyzer analyzer) throws AnalysisException {
         ArrayList<OrderByElement> result = Lists.newArrayListWithCapacity(src.size());
 
-        for (OrderByElement element: src) {
+        for (OrderByElement element : src) {
             result.add(new OrderByElement(element.getExpr().substitute(smap, analyzer, false),
                     element.isAsc, element.nullsFirstParam));
         }
@@ -164,7 +164,7 @@ public class OrderByElement {
             return false;
         }
 
-        OrderByElement o = (OrderByElement)obj;
+        OrderByElement o = (OrderByElement) obj;
         return expr.equals(o.expr) && isAsc == o.isAsc  && nullsFirstParam == o.nullsFirstParam;
     }
     /**
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java
index 9aa8253dab..20d552cd4f 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/OutFileClause.java
@@ -240,8 +240,8 @@ public class OutFileClause {
                 case DATE:
                 case DATETIME:
                     if (!type.equals("int64")) {
-                        throw new AnalysisException("project field type is BIGINT/DATE/DATETIME, should use int64, " +
-                                "but the definition type of column " + i + " is " + type);
+                        throw new AnalysisException("project field type is BIGINT/DATE/DATETIME, should use int64, "
+                                + "but the definition type of column " + i + " is " + type);
                     }
                     break;
                 case FLOAT:
@@ -261,16 +261,16 @@ public class OutFileClause {
                 case STRING:
                 case DECIMALV2:
                     if (!type.equals("byte_array")) {
-                        throw new AnalysisException("project field type is CHAR/VARCHAR/STRING/DECIMAL, should use byte_array, " +
-                                "but the definition type of column " + i + " is " + type);
+                        throw new AnalysisException("project field type is CHAR/VARCHAR/STRING/DECIMAL, should use byte_array, "
+                                + "but the definition type of column " + i + " is " + type);
                     }
                     break;
                 case HLL:
                 case BITMAP:
                     if (ConnectContext.get() != null && ConnectContext.get().getSessionVariable().isReturnObjectDataAsBinary()) {
                         if (!type.equals("byte_array")) {
-                            throw new AnalysisException("project field type is HLL/BITMAP, should use byte_array, " +
-                                    "but the definition type of column " + i + " is " + type);
+                            throw new AnalysisException("project field type is HLL/BITMAP, should use byte_array, "
+                                    + "but the definition type of column " + i + " is " + type);
                         }
                     } else {
                         throw new AnalysisException("Parquet format does not support column type: " + resultType.getPrimitiveType());
@@ -490,7 +490,7 @@ public class OutFileClause {
                 throw new AnalysisException("currently only support required type");
             }
             if (!PARQUET_DATA_TYPES.contains(properties[1])) {
-                throw new AnalysisException("data type is not supported:"+properties[1]);
+                throw new AnalysisException("data type is not supported:" + properties[1]);
             }
             List<String> column = new ArrayList<>();
             column.addAll(Arrays.asList(properties));
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/PartitionKeyDesc.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/PartitionKeyDesc.java
index da019d716b..767e3626b4 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/PartitionKeyDesc.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/PartitionKeyDesc.java
@@ -151,7 +151,7 @@ public class PartitionKeyDesc {
                     valueStr = valueStr.substring(1, valueStr.length() - 1);
                 }
                 sb.append(valueStr);
-                if (i < inValues.size() -1) {
+                if (i < inValues.size() - 1) {
                     sb.append(",");
                 }
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/PauseRoutineLoadStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/PauseRoutineLoadStmt.java
index 49f07f917f..f359685900 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/PauseRoutineLoadStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/PauseRoutineLoadStmt.java
@@ -47,7 +47,7 @@ public class PauseRoutineLoadStmt extends DdlStmt {
         return labelName.getLabelName();
     }
 
-    public String getDbFullName(){
+    public String getDbFullName() {
         return db;
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/Predicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/Predicate.java
index a9cfed1f86..c34e9f7728 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/Predicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/Predicate.java
@@ -62,8 +62,7 @@ public abstract class Predicate extends Expr {
      * This will pick up something like "col = 5", but not "2 * col = 10", which is
      * what we want.
      */
-    public boolean isSingleColumnPredicate(Reference<SlotRef> slotRefRef,
-      Reference<Integer> idxRef) {
+    public boolean isSingleColumnPredicate(Reference<SlotRef> slotRefRef, Reference<Integer> idxRef) {
         // find slotref
         SlotRef slotRef = null;
         int i = 0;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/QueryStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/QueryStmt.java
index 7e767a994f..5ca6044214 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/QueryStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/QueryStmt.java
@@ -186,8 +186,8 @@ public abstract class QueryStmt extends StatementBase {
     private void analyzeLimit(Analyzer analyzer) throws AnalysisException {
         // TODO chenhao
         if (limitElement.getOffset() > 0 && !hasOrderByClause()) {
-            throw new AnalysisException("OFFSET requires an ORDER BY clause: " +
-                    limitElement.toSql().trim());
+            throw new AnalysisException("OFFSET requires an ORDER BY clause: "
+                    + limitElement.toSql().trim());
         }
         limitElement.analyze(analyzer);
     }
@@ -241,8 +241,8 @@ public abstract class QueryStmt extends StatementBase {
             }*/
             if (correlatedRef != null && absoluteRef != null) {
                 throw new AnalysisException(String.format(
-                        "Nested query is illegal because it contains a table reference '%s' " +
-                                "correlated with an outer block as well as an uncorrelated one '%s':\n%s",
+                        "Nested query is illegal because it contains a table reference '%s' "
+                                + "correlated with an outer block as well as an uncorrelated one '%s':\n%s",
                         correlatedRef.tableRefToSql(), absoluteRef.tableRefToSql(), toSql()));
             }
             tblRefIds.add(tblRef.getId());
@@ -314,8 +314,8 @@ public abstract class QueryStmt extends StatementBase {
         }
 
         if (!analyzer.isRootAnalyzer() && hasOffset() && !hasLimit()) {
-            throw new AnalysisException("Order-by with offset without limit not supported" +
-                    " in nested queries.");
+            throw new AnalysisException("Order-by with offset without limit not supported"
+                    + " in nested queries.");
         }
 
         sortInfo = new SortInfo(orderingExprs, isAscOrder, nullsFirstParams);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/RangePartitionDesc.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/RangePartitionDesc.java
index a95ff31a77..ebcee3c319 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/RangePartitionDesc.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/RangePartitionDesc.java
@@ -39,8 +39,8 @@ public class RangePartitionDesc extends PartitionDesc {
 
     @Override
     public void checkPartitionKeyValueType(PartitionKeyDesc partitionKeyDesc) throws AnalysisException {
-        if (partitionKeyDesc.getPartitionType() != PartitionKeyValueType.FIXED &&
-                partitionKeyDesc.getPartitionType() != PartitionKeyValueType.LESS_THAN) {
+        if (partitionKeyDesc.getPartitionType() != PartitionKeyValueType.FIXED
+                && partitionKeyDesc.getPartitionType() != PartitionKeyValueType.LESS_THAN) {
             throw new AnalysisException("You can only use fixed or less than values to create range partitions");
         }
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ResumeRoutineLoadStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ResumeRoutineLoadStmt.java
index 888d0327ab..4ed739e8f6 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ResumeRoutineLoadStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ResumeRoutineLoadStmt.java
@@ -30,7 +30,7 @@ import com.google.common.base.Strings;
   syntax:
       RESUME ROUTINE LOAD [database.]name
  */
-public class ResumeRoutineLoadStmt extends DdlStmt{
+public class ResumeRoutineLoadStmt extends DdlStmt {
 
     private final LabelName labelName;
     private String db;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/RoutineLoadDataSourceProperties.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/RoutineLoadDataSourceProperties.java
index ea0b20d7b2..d7dbfab53e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/RoutineLoadDataSourceProperties.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/RoutineLoadDataSourceProperties.java
@@ -161,9 +161,10 @@ public class RoutineLoadDataSourceProperties {
      */
     private void checkKafkaProperties() throws UserException {
         ImmutableSet<String> propertySet = isAlter ? CONFIGURABLE_DATA_SOURCE_PROPERTIES_SET : DATA_SOURCE_PROPERTIES_SET;
-        Optional<String> optional = properties.keySet().stream().filter(
-                entity -> !propertySet.contains(entity)).filter(
-                entity -> !entity.startsWith("property.")).findFirst();
+        Optional<String> optional = properties.keySet().stream()
+                .filter(entity -> !propertySet.contains(entity))
+                .filter(entity -> !entity.startsWith("property."))
+                .findFirst();
         if (optional.isPresent()) {
             throw new AnalysisException(optional.get() + " is invalid kafka property or can not be set");
         }
@@ -219,8 +220,8 @@ public class RoutineLoadDataSourceProperties {
         String kafkaOffsetsString = properties.get(CreateRoutineLoadStmt.KAFKA_OFFSETS_PROPERTY);
         String kafkaDefaultOffsetString = customKafkaProperties.get(CreateRoutineLoadStmt.KAFKA_DEFAULT_OFFSETS);
         if (kafkaOffsetsString != null && kafkaDefaultOffsetString != null) {
-            throw new AnalysisException("Only one of " + CreateRoutineLoadStmt.KAFKA_OFFSETS_PROPERTY +
-                    " and " + CreateRoutineLoadStmt.KAFKA_DEFAULT_OFFSETS + " can be set.");
+            throw new AnalysisException("Only one of " + CreateRoutineLoadStmt.KAFKA_OFFSETS_PROPERTY
+                    + " and " + CreateRoutineLoadStmt.KAFKA_DEFAULT_OFFSETS + " can be set.");
         }
         if (isAlter && kafkaPartitionsString != null && kafkaOffsetsString == null && kafkaDefaultOffsetString == null) {
             // if this is an alter operation, the partition and (default)offset must be set together.
@@ -328,8 +329,8 @@ public class RoutineLoadDataSourceProperties {
             }
         }
         if (foundTime && foundOffset) {
-            throw new AnalysisException("The offset of the partition cannot be specified by the timestamp " +
-                    "and the offset at the same time");
+            throw new AnalysisException("The offset of the partition cannot be specified by the timestamp "
+                    + "and the offset at the same time");
         }
 
         if (foundTime) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectListItem.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectListItem.java
index 2c5bd245f5..db2e688b6a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectListItem.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectListItem.java
@@ -77,7 +77,11 @@ public class SelectListItem {
     public Expr getExpr() {
         return expr;
     }
-    public void setExpr(Expr expr) { this.expr = expr; }
+
+    public void setExpr(Expr expr) {
+        this.expr = expr;
+    }
+
     public String getAlias() {
         return alias;
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java
index d861d63d2b..8e7a56598d 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SelectStmt.java
@@ -421,8 +421,8 @@ public class SelectStmt extends QueryStmt {
                 // Analyze the resultExpr before generating a label to ensure enforcement
                 // of expr child and depth limits (toColumn() label may call toSql()).
                 item.getExpr().analyze(analyzer);
-                if (!(item.getExpr() instanceof CaseExpr) &&
-                        item.getExpr().contains(Predicates.instanceOf(Subquery.class))) {
+                if (!(item.getExpr() instanceof CaseExpr)
+                        && item.getExpr().contains(Predicates.instanceOf(Subquery.class))) {
                     throw new AnalysisException("Subquery is not supported in the select list.");
                 }
                 Expr expr = rewriteQueryExprByMvColumnExpr(item.getExpr(), analyzer);
@@ -998,8 +998,7 @@ public class SelectStmt extends QueryStmt {
         // disallow '*' and explicit GROUP BY (we can't group by '*', and if you need to
         // name all star-expanded cols in the group by clause you might as well do it
         // in the select list)
-        if (groupByClause != null ||
-                TreeNode.contains(resultExprs, Expr.isAggregatePredicate())) {
+        if (groupByClause != null || TreeNode.contains(resultExprs, Expr.isAggregatePredicate())) {
             for (SelectListItem item : selectList.getItems()) {
                 if (item.isStar()) {
                     throw new AnalysisException(
@@ -1047,13 +1046,6 @@ public class SelectStmt extends QueryStmt {
             }
             groupByClause.genGroupingExprs();
             if (groupingInfo != null) {
-                GroupByClause.GroupingType groupingType = groupByClause.getGroupingType();
-                if ((groupingType == GroupByClause.GroupingType.GROUPING_SETS && CollectionUtils
-                        .isNotEmpty(groupByClause.getGroupingSetList()))
-                        || groupingType == GroupByClause.GroupingType.CUBE
-                        || groupingType == GroupByClause.GroupingType.ROLLUP) {
-
-                }
                 groupingInfo.buildRepeat(groupByClause.getGroupingExprs(), groupByClause.getGroupingSetList());
             }
             substituteOrdinalsAliases(groupByClause.getGroupingExprs(), "GROUP BY", analyzer);
@@ -1116,8 +1108,8 @@ public class SelectStmt extends QueryStmt {
         if (sortInfo != null) {
             sortInfo.substituteOrderingExprs(combinedSmap, analyzer);
             if (LOG.isDebugEnabled()) {
-                LOG.debug("post-agg orderingExprs: " +
-                        Expr.debugString(sortInfo.getOrderingExprs()));
+                LOG.debug("post-agg orderingExprs: "
+                        + Expr.debugString(sortInfo.getOrderingExprs()));
             }
         }
 
@@ -1125,16 +1117,16 @@ public class SelectStmt extends QueryStmt {
         for (int i = 0; i < selectList.getItems().size(); ++i) {
             if (!resultExprs.get(i).isBoundByTupleIds(groupingByTupleIds)) {
                 throw new AnalysisException(
-                        "select list expression not produced by aggregation output " + "(missing from " +
-                                "GROUP BY clause?): " + selectList.getItems().get(i).getExpr().toSql());
+                        "select list expression not produced by aggregation output " + "(missing from "
+                                + "GROUP BY clause?): " + selectList.getItems().get(i).getExpr().toSql());
             }
         }
         if (orderByElements != null) {
             for (int i = 0; i < orderByElements.size(); ++i) {
                 if (!sortInfo.getOrderingExprs().get(i).isBoundByTupleIds(groupingByTupleIds)) {
                     throw new AnalysisException(
-                            "ORDER BY expression not produced by aggregation output " + "(missing from " +
-                                    "GROUP BY clause?): " + orderByElements.get(i).getExpr().toSql());
+                            "ORDER BY expression not produced by aggregation output " + "(missing from "
+                                    + "GROUP BY clause?): " + orderByElements.get(i).getExpr().toSql());
                 }
 
                 if (sortInfo.getOrderingExprs().get(i).type.isObjectStored()) {
@@ -1145,8 +1137,8 @@ public class SelectStmt extends QueryStmt {
         if (havingPred != null) {
             if (!havingPred.isBoundByTupleIds(groupingByTupleIds)) {
                 throw new AnalysisException(
-                        "HAVING clause not produced by aggregation output " + "(missing from GROUP BY " +
-                                "clause?): " + havingClause.toSql());
+                        "HAVING clause not produced by aggregation output " + "(missing from GROUP BY "
+                                + "clause?): " + havingClause.toSql());
             }
         }
     }
@@ -1285,16 +1277,6 @@ public class SelectStmt extends QueryStmt {
             return;
         }
         ExprSubstitutionMap rewriteSmap = new ExprSubstitutionMap();
-        for (Expr expr : analyticExprs) {
-            AnalyticExpr toRewrite = (AnalyticExpr) expr;
-            Expr newExpr = AnalyticExpr.rewrite(toRewrite);
-            if (newExpr != null) {
-                newExpr.analyze(analyzer);
-                if (!rewriteSmap.containsMappingFor(toRewrite)) {
-                    rewriteSmap.put(toRewrite, newExpr);
-                }
-            }
-        }
         if (rewriteSmap.size() > 0) {
             // Substitute the exprs with their rewritten versions.
             ArrayList<Expr> updatedAnalyticExprs =
@@ -1322,8 +1304,8 @@ public class SelectStmt extends QueryStmt {
         if (sortInfo != null) {
             sortInfo.substituteOrderingExprs(smap, analyzer);
             if (LOG.isDebugEnabled()) {
-                LOG.debug("post-analytic orderingExprs: " +
-                        Expr.debugString(sortInfo.getOrderingExprs()));
+                LOG.debug("post-analytic orderingExprs: "
+                        + Expr.debugString(sortInfo.getOrderingExprs()));
             }
         }
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/Separator.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/Separator.java
index 217c06f230..c8c096d081 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/Separator.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/Separator.java
@@ -126,7 +126,7 @@ public class Separator implements ParseNode {
                     case 'n':
                         sb.append('\n');
                         break;
-                    default :
+                    default:
                         sb.append('\\').append(ch);
                         break;
                 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SetOperationStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SetOperationStmt.java
index 5ffac6a0b7..2062bf26df 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SetOperationStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SetOperationStmt.java
@@ -114,16 +114,16 @@ public class SetOperationStmt extends QueryStmt {
                 (other.limitElement == null) ? null : other.limitElement.clone());
         operands = Lists.newArrayList();
         if (analyzer != null) {
-            for (SetOperand o: other.distinctOperands) {
+            for (SetOperand o : other.distinctOperands) {
                 distinctOperands.add(o.clone());
             }
-            for (SetOperand o: other.allOperands) {
+            for (SetOperand o : other.allOperands) {
                 allOperands.add(o.clone());
             }
             operands.addAll(distinctOperands);
             operands.addAll(allOperands);
         } else {
-            for (SetOperand operand: other.operands) {
+            for (SetOperand operand : other.operands) {
                 operands.add(operand.clone());
             }
         }
@@ -138,7 +138,9 @@ public class SetOperationStmt extends QueryStmt {
     }
 
     @Override
-    public SetOperationStmt clone() { return new SetOperationStmt(this); }
+    public SetOperationStmt clone() {
+        return new SetOperationStmt(this);
+    }
 
     /**
      * Undoes all changes made by analyze() except distinct propagation and unnesting.
@@ -150,7 +152,7 @@ public class SetOperationStmt extends QueryStmt {
     @Override
     public void reset() {
         super.reset();
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             op.reset();
         }
         distinctOperands.clear();
@@ -169,21 +171,46 @@ public class SetOperationStmt extends QueryStmt {
         }
     }
 
-    public List<SetOperand> getOperands() { return operands; }
-    public List<SetOperand> getDistinctOperands() { return distinctOperands; }
-    public boolean hasDistinctOps() { return !distinctOperands.isEmpty(); }
-    public List<SetOperand> getAllOperands() { return allOperands; }
-    public boolean hasAllOps() { return !allOperands.isEmpty(); }
-    public AggregateInfo getDistinctAggInfo() { return distinctAggInfo; }
-    public boolean hasAnalyticExprs() { return hasAnalyticExprs; }
-    public TupleId getTupleId() { return tupleId; }
+    public List<SetOperand> getOperands() {
+        return operands;
+    }
+
+    public List<SetOperand> getDistinctOperands() {
+        return distinctOperands;
+    }
+
+    public boolean hasDistinctOps() {
+        return !distinctOperands.isEmpty();
+    }
+
+    public List<SetOperand> getAllOperands() {
+        return allOperands;
+    }
+
+    public boolean hasAllOps() {
+        return !allOperands.isEmpty();
+    }
+
+    public AggregateInfo getDistinctAggInfo() {
+        return distinctAggInfo;
+    }
+
+    public boolean hasAnalyticExprs() {
+        return hasAnalyticExprs;
+    }
+
+    public TupleId getTupleId() {
+        return tupleId;
+    }
 
     public void removeAllOperands() {
         operands.removeAll(allOperands);
         allOperands.clear();
     }
 
-    public List<Expr> getSetOpsResultExprs() { return setOpsResultExprs; }
+    public List<Expr> getSetOpsResultExprs() {
+        return setOpsResultExprs;
+    }
 
     @Override
     public void getTables(Analyzer analyzer, Map<Long, Table> tableMap, Set<String> parentViewNameSet) throws AnalysisException {
@@ -236,7 +263,7 @@ public class SetOperationStmt extends QueryStmt {
 
         // Compute hasAnalyticExprs_
         hasAnalyticExprs = false;
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             if (op.hasAnalyticExprs()) {
                 hasAnalyticExprs = true;
                 break;
@@ -245,7 +272,7 @@ public class SetOperationStmt extends QueryStmt {
 
         // Collect all result expr lists and cast the exprs as necessary.
         List<List<Expr>> resultExprLists = Lists.newArrayList();
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             resultExprLists.add(op.getQueryStmt().getResultExprs());
         }
         analyzer.castToSetOpsCompatibleTypes(resultExprLists);
@@ -256,7 +283,7 @@ public class SetOperationStmt extends QueryStmt {
         createSortInfo(analyzer);
 
         // Create unnested operands' smaps.
-        for (SetOperand operand: operands) {
+        for (SetOperand operand : operands) {
             setOperandSmap(operand, analyzer);
         }
 
@@ -297,10 +324,10 @@ public class SetOperationStmt extends QueryStmt {
             QueryStmt query = operands.get(i).getQueryStmt();
             List<Expr> exprs = query.getResultExprs();
             if (firstExprs.size() != exprs.size()) {
-                throw new AnalysisException("Operands have unequal number of columns:\n" +
-                        "'" + queryStmtToSql(firstQuery) + "' has " +
-                        firstExprs.size() + " column(s)\n" +
-                        "'" + queryStmtToSql(query) + "' has " + exprs.size() + " column(s)");
+                throw new AnalysisException("Operands have unequal number of columns:\n"
+                        +    "'" + queryStmtToSql(firstQuery) + "' has "
+                        +    firstExprs.size() + " column(s)\n"
+                        + "'" + queryStmtToSql(query) + "' has " + exprs.size() + " column(s)");
             }
         }
     }
@@ -340,10 +367,10 @@ public class SetOperationStmt extends QueryStmt {
             unnestOperand(allOperands, Qualifier.ALL, operands.get(i));
         }
 
-        for (SetOperand op: distinctOperands) {
+        for (SetOperand op : distinctOperands) {
             op.setQualifier(Qualifier.DISTINCT);
         }
-        for (SetOperand op: allOperands) {
+        for (SetOperand op : allOperands) {
             op.setQualifier(Qualifier.ALL);
         }
 
@@ -500,7 +527,7 @@ public class SetOperationStmt extends QueryStmt {
             // to operands' result exprs (if those happen to be slotrefs);
             // don't do that if the operand computes analytic exprs
             // (see Planner.createInlineViewPlan() for the reasoning)
-            for (SetOperand op: operands) {
+            for (SetOperand op : operands) {
                 Expr resultExpr = op.getQueryStmt().getResultExprs().get(i);
                 slotDesc.addSourceExpr(resultExpr);
                 SlotRef slotRef = resultExpr.unwrapSlotRef(false);
@@ -552,7 +579,7 @@ public class SetOperationStmt extends QueryStmt {
             if (!slotDesc.isMaterialized()) {
                 continue;
             }
-            for (SetOperand op: operands) {
+            for (SetOperand op : operands) {
                 exprs.add(op.getQueryStmt().getBaseTblResultExprs().get(i));
             }
             if (distinctAggInfo != null) {
@@ -563,7 +590,7 @@ public class SetOperationStmt extends QueryStmt {
         }
         materializeSlots(analyzer, exprs);
 
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             op.getQueryStmt().materializeRequiredSlots(analyzer);
         }
     }
@@ -606,11 +633,11 @@ public class SetOperationStmt extends QueryStmt {
 
     @Override
     public void rewriteExprs(ExprRewriter rewriter) throws AnalysisException {
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             op.getQueryStmt().rewriteExprs(rewriter);
         }
         if (orderByElements != null) {
-            for (OrderByElement orderByElem: orderByElements) {
+            for (OrderByElement orderByElem : orderByElements) {
                 orderByElem.setExpr(rewriter.rewrite(orderByElem.getExpr(), analyzer));
             }
         }
@@ -628,7 +655,7 @@ public class SetOperationStmt extends QueryStmt {
 
     @Override
     public void collectTableRefs(List<TableRef> tblRefs) {
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             op.getQueryStmt().collectTableRefs(tblRefs);
         }
     }
@@ -636,7 +663,7 @@ public class SetOperationStmt extends QueryStmt {
     @Override
     public List<TupleId> collectTupleIds() {
         List<TupleId> result = Lists.newArrayList();
-        for (SetOperand op: operands) {
+        for (SetOperand op : operands) {
             result.addAll(op.getQueryStmt().collectTupleIds());
         }
         return result;
@@ -655,9 +682,9 @@ public class SetOperationStmt extends QueryStmt {
         Preconditions.checkState(operands.size() > 0);
         strBuilder.append(operands.get(0).getQueryStmt().toSql());
         for (int i = 1; i < operands.size() - 1; ++i) {
-            strBuilder.append(
-              " " + operands.get(i).getOperation().toString() + " "
-                      + ((operands.get(i).getQualifier() == Qualifier.ALL) ? "ALL " : ""));
+            strBuilder.append(" "
+                    + operands.get(i).getOperation().toString() + " "
+                    + ((operands.get(i).getQualifier() == Qualifier.ALL) ? "ALL " : ""));
             if (operands.get(i).getQueryStmt() instanceof SetOperationStmt) {
                 strBuilder.append("(");
             }
@@ -671,9 +698,9 @@ public class SetOperationStmt extends QueryStmt {
         QueryStmt lastQueryStmt = lastOperand.getQueryStmt();
         strBuilder.append(" " + lastOperand.getOperation().toString() + " "
                 + ((lastOperand.getQualifier() == Qualifier.ALL) ? "ALL " : ""));
-        if (lastQueryStmt instanceof SetOperationStmt || ((hasOrderByClause() || hasLimitClause()) &&
-                !lastQueryStmt.hasLimitClause() &&
-                !lastQueryStmt.hasOrderByClause())) {
+        if (lastQueryStmt instanceof SetOperationStmt || ((hasOrderByClause() || hasLimitClause())
+                && !lastQueryStmt.hasLimitClause()
+                && !lastQueryStmt.hasOrderByClause())) {
             strBuilder.append("(");
             strBuilder.append(lastQueryStmt.toSql());
             strBuilder.append(")");
@@ -722,9 +749,9 @@ public class SetOperationStmt extends QueryStmt {
         QueryStmt lastQueryStmt = lastOperand.getQueryStmt();
         strBuilder.append(" " + lastOperand.getOperation().toString() + " "
                 + ((lastOperand.getQualifier() == Qualifier.ALL) ? "ALL " : ""));
-        if (lastQueryStmt instanceof SetOperationStmt || ((hasOrderByClause() || hasLimitClause()) &&
-                !lastQueryStmt.hasLimitClause() &&
-                !lastQueryStmt.hasOrderByClause())) {
+        if (lastQueryStmt instanceof SetOperationStmt || ((hasOrderByClause() || hasLimitClause())
+                && !lastQueryStmt.hasLimitClause()
+                && !lastQueryStmt.hasOrderByClause())) {
             strBuilder.append("(");
             strBuilder.append(lastQueryStmt.toDigest());
             strBuilder.append(")");
@@ -844,23 +871,41 @@ public class SetOperationStmt extends QueryStmt {
             queryStmt.analyze(analyzer);
         }
 
-        public boolean isAnalyzed() { return analyzer != null; }
-        public QueryStmt getQueryStmt() { return queryStmt; }
-        public Qualifier getQualifier() { return qualifier; }
+        public boolean isAnalyzed() {
+            return analyzer != null;
+        }
+
+        public QueryStmt getQueryStmt() {
+            return queryStmt;
+        }
+
+        public Qualifier getQualifier() {
+            return qualifier;
+        }
+
         public Operation getOperation() {
             return operation;
         }
         // Used for propagating DISTINCT.
-        public void setQualifier(Qualifier qualifier) { this.qualifier = qualifier; }
+        public void setQualifier(Qualifier qualifier) {
+            this.qualifier = qualifier;
+        }
 
         public void setOperation(Operation operation) {
-            this.operation =operation;
+            this.operation = operation;
         }
+
         public void setQueryStmt(QueryStmt queryStmt) {
             this.queryStmt = queryStmt;
         }
-        public Analyzer getAnalyzer() { return analyzer; }
-        public ExprSubstitutionMap getSmap() { return smap; }
+
+        public Analyzer getAnalyzer() {
+            return analyzer;
+        }
+
+        public ExprSubstitutionMap getSmap() {
+            return smap;
+        }
 
         public boolean hasAnalyticExprs() {
             if (queryStmt instanceof SelectStmt) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SetVar.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SetVar.java
index 2ff1fe7e43..3b1eeec8e9 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SetVar.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SetVar.java
@@ -49,7 +49,7 @@ public class SetVar {
         this.variable = variable;
         this.value = value;
         if (value instanceof LiteralExpr) {
-            this.result = (LiteralExpr)value;
+            this.result = (LiteralExpr) value;
         }
     }
 
@@ -58,7 +58,7 @@ public class SetVar {
         this.variable = variable;
         this.value = value;
         if (value instanceof LiteralExpr) {
-            this.result = (LiteralExpr)value;
+            this.result = (LiteralExpr) value;
         }
     }
 
@@ -114,7 +114,7 @@ public class SetVar {
             throw new AnalysisException("Set statement does't support computing expr:" + literalExpr.toSql());
         }
 
-        result = (LiteralExpr)literalExpr;
+        result = (LiteralExpr) literalExpr;
 
         // Need to check if group is valid
         if (variable.equalsIgnoreCase(SessionVariable.RESOURCE_VARIABLE)) {
@@ -153,9 +153,9 @@ public class SetVar {
         if (getVariable().equalsIgnoreCase(SessionVariable.PARTITION_PRUNE_ALGORITHM_VERSION)) {
             String value = getValue().getStringValue();
             if (!"1".equals(value) && !"2".equals(value)) {
-                throw new AnalysisException("Value of " +
-                    SessionVariable.PARTITION_PRUNE_ALGORITHM_VERSION + " should be " +
-                    "either 1 or 2, but meet " + value);
+                throw new AnalysisException("Value of "
+                        + SessionVariable.PARTITION_PRUNE_ALGORITHM_VERSION + " should be "
+                        + "either 1 or 2, but meet " + value);
             }
         }
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowAlterStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowAlterStmt.java
index 49ea6c839c..8bfc5ed59d 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowAlterStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowAlterStmt.java
@@ -65,11 +65,25 @@ public class ShowAlterStmt extends ShowStmt {
 
     private ProcNodeInterface node;
 
-    public AlterType getType() { return type; }
-    public String getDbName() { return dbName; }
-    public HashMap<String, Expr> getFilterMap() { return filterMap; }
-    public LimitElement getLimitElement(){ return limitElement; }
-    public ArrayList<OrderByPair> getOrderPairs(){ return orderByPairs; }
+    public AlterType getType() {
+        return type;
+    }
+
+    public String getDbName() {
+        return dbName;
+    }
+
+    public HashMap<String, Expr> getFilterMap() {
+        return filterMap;
+    }
+
+    public LimitElement getLimitElement() {
+        return limitElement;
+    }
+
+    public ArrayList<OrderByPair> getOrderPairs() {
+        return orderByPairs;
+    }
 
     public ProcNodeInterface getNode() {
         return this.node;
@@ -95,8 +109,8 @@ public class ShowAlterStmt extends ShowStmt {
         }
         String leftKey = ((SlotRef) subExpr.getChild(0)).getColumnName().toLowerCase();
         if (leftKey.equals("tablename") || leftKey.equals("state")) {
-            if (!(subExpr.getChild(1) instanceof StringLiteral) ||
-                    binaryPredicate.getOp() != BinaryPredicate.Operator.EQ) {
+            if (!(subExpr.getChild(1) instanceof StringLiteral)
+                    || binaryPredicate.getOp() != BinaryPredicate.Operator.EQ) {
                 throw new AnalysisException("Where clause : TableName = \"table1\" or "
                     + "State = \"FINISHED|CANCELLED|RUNNING|PENDING|WAITING_TXN\"");
             }
@@ -105,7 +119,7 @@ public class ShowAlterStmt extends ShowStmt {
                 throw new AnalysisException("Where clause : CreateTime/FinishTime =|>=|<=|>|<|!= "
                     + "\"2019-12-02|2019-12-02 14:54:00\"");
             }
-            subExpr.setChild(1,((StringLiteral) subExpr.getChild(1)).castTo(Type.DATETIME));
+            subExpr.setChild(1, ((StringLiteral) subExpr.getChild(1)).castTo(Type.DATETIME));
         } else {
             throw new AnalysisException("The columns of TableName/CreateTime/FinishTime/State are supported.");
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowBackendsStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowBackendsStmt.java
index 12b037eec4..bf9b8676d1 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowBackendsStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowBackendsStmt.java
@@ -44,12 +44,12 @@ public class ShowBackendsStmt extends ShowStmt {
 
     @Override
     public ShowResultSetMetaData getMetaData() {
-         ShowResultSetMetaData.Builder builder = ShowResultSetMetaData.builder();
-         for (String title : BackendsProcDir.TITLE_NAMES) {
+        ShowResultSetMetaData.Builder builder = ShowResultSetMetaData.builder();
+        for (String title : BackendsProcDir.TITLE_NAMES) {
             // hide hostname for SHOW BACKENDS stmt
             if (title.equals("HostName")) {
-                 continue;
-             }
+                continue;
+            }
             builder.addColumn(new Column(title, ScalarType.createVarchar(30)));
         }
         return builder.build();
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowCreateFunctionStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowCreateFunctionStmt.java
index a7d9db8c1d..e9bc7e86c1 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowCreateFunctionStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowCreateFunctionStmt.java
@@ -54,9 +54,13 @@ public class ShowCreateFunctionStmt extends ShowStmt {
         return dbName;
     }
 
-    public FunctionName getFunctionName() { return functionName; }
+    public FunctionName getFunctionName() {
+        return functionName;
+    }
 
-    public FunctionSearchDesc getFunction() { return function; }
+    public FunctionSearchDesc getFunction() {
+        return function;
+    }
 
     @Override
     public void analyze(Analyzer analyzer) throws UserException {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowDataStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowDataStmt.java
index 0422bbbe2b..3f8637b762 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowDataStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowDataStmt.java
@@ -70,13 +70,12 @@ public class ShowDataStmt extends ShowStmt {
                     .addColumn(new Column("ReplicaCount", ScalarType.createVarchar(20)))
                     .addColumn(new Column("RowCount", ScalarType.createVarchar(20)))
                     .build();
-    public static final ImmutableList<String> SHOW_TABLE_DATA_META_DATA_ORIGIN = new ImmutableList.Builder<String>()
-        .add("TableName").add("Size").add("ReplicaCount")
-        .build();
+    public static final ImmutableList<String> SHOW_TABLE_DATA_META_DATA_ORIGIN =
+            new ImmutableList.Builder<String>().add("TableName").add("Size").add("ReplicaCount").build();
 
-    public static final ImmutableList<String> SHOW_INDEX_DATA_META_DATA_ORIGIN = new ImmutableList.Builder<String>()
-        .add("TableName").add("IndexName").add("Size").add("ReplicaCount").add("RowCount")
-        .build();
+    public static final ImmutableList<String> SHOW_INDEX_DATA_META_DATA_ORIGIN =
+            new ImmutableList.Builder<String>().add("TableName").add("IndexName").add("Size").add("ReplicaCount")
+                    .add("RowCount").build();
 
     private String dbName;
     private String tableName;
@@ -115,8 +114,8 @@ public class ShowDataStmt extends ShowStmt {
                 if (!(orderByElement.getExpr() instanceof SlotRef)) {
                     throw new AnalysisException("Should order by column");
                 }
-                SlotRef slotRef = (SlotRef)orderByElement.getExpr();
-                int index = analyzeColumn(slotRef.getColumnName(),tableName);
+                SlotRef slotRef = (SlotRef) orderByElement.getExpr();
+                int index = analyzeColumn(slotRef.getColumnName(), tableName);
                 OrderByPair orderByPair = new OrderByPair(index, !orderByElement.getIsAsc());
                 orderByPairs.add(orderByPair);
             }
@@ -183,11 +182,11 @@ public class ShowDataStmt extends ShowStmt {
                 // for output
                 for (List<Object> row : totalRowsObject) {
                     //|TableName|Size|ReplicaCount|
-                    Pair<Double, String> tableSizePair = DebugUtil.getByteUint((long)row.get(1));
+                    Pair<Double, String> tableSizePair = DebugUtil.getByteUint((long) row.get(1));
                     String readableSize = DebugUtil.DECIMAL_FORMAT_SCALE_3.format(tableSizePair.first) + " "
-                        + tableSizePair.second;
-                    List<String> result = Arrays.asList(String.valueOf(row.get(0)), readableSize,
-                        String.valueOf(row.get(2)));
+                            + tableSizePair.second;
+                    List<String> result = Arrays.asList(String.valueOf(row.get(0)),
+                            readableSize, String.valueOf(row.get(2)));
                     totalRows.add(result);
                 }
 
@@ -229,7 +228,6 @@ public class ShowDataStmt extends ShowStmt {
             }
 
             OlapTable olapTable = db.getTableOrMetaException(tableName, TableType.OLAP);
-            int i = 0;
             long totalSize = 0;
             long totalReplicaCount = 0;
 
@@ -260,8 +258,6 @@ public class ShowDataStmt extends ShowStmt {
 
                     totalSize += indexSize;
                     totalReplicaCount += indexReplicaCount;
-
-                    i++;
                 } // end for indices
 
                 // sort by
@@ -276,13 +272,13 @@ public class ShowDataStmt extends ShowStmt {
                 }
 
                 // for output
-                for (int index = 0;index<= totalRowsObject.size() -1;index++) {
+                for (int index = 0; index <= totalRowsObject.size() - 1; index++) {
                     //| TableName| IndexName | Size | ReplicaCount | RowCount |
                     List<Object> row = totalRowsObject.get(index);
                     List<String> result;
-                    Pair<Double, String> tableSizePair = DebugUtil.getByteUint((long)row.get(2));
-                    String readableSize = DebugUtil.DECIMAL_FORMAT_SCALE_3.format(tableSizePair.first) + " "
-                        + tableSizePair.second;
+                    Pair<Double, String> tableSizePair = DebugUtil.getByteUint((long) row.get(2));
+                    String readableSize = DebugUtil.DECIMAL_FORMAT_SCALE_3.format(tableSizePair.first)
+                            + " " + tableSizePair.second;
                     if (index == 0) {
                         result = Arrays.asList(tableName, String.valueOf(row.get(1)),
                                 readableSize, String.valueOf(row.get(3)),
@@ -306,9 +302,9 @@ public class ShowDataStmt extends ShowStmt {
         }
     }
 
-    public static int analyzeColumn(String columnName,String tableName) throws AnalysisException {
+    public static int analyzeColumn(String columnName, String tableName) throws AnalysisException {
         ImmutableList<String> titles = SHOW_TABLE_DATA_META_DATA_ORIGIN;
-        if(tableName != null){
+        if (tableName != null) {
             titles = SHOW_INDEX_DATA_META_DATA_ORIGIN;
         }
         for (String title : titles) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowEncryptKeysStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowEncryptKeysStmt.java
index 9aa45192dd..17d94aefa8 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowEncryptKeysStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowEncryptKeysStmt.java
@@ -31,7 +31,7 @@ import org.apache.doris.qe.ShowResultSetMetaData;
 
 import com.google.common.base.Strings;
 
-public class ShowEncryptKeysStmt extends ShowStmt{
+public class ShowEncryptKeysStmt extends ShowStmt {
     private static final ShowResultSetMetaData META_DATA =
             ShowResultSetMetaData.builder()
                     .addColumn(new Column("EncryptKey Name", ScalarType.createVarchar(20)))
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowExportStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowExportStmt.java
index b6f04f979e..481550ab29 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowExportStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowExportStmt.java
@@ -175,8 +175,8 @@ public class ShowExportStmt extends ShowStmt {
 
         if (!valid) {
             throw new AnalysisException("Where clause should looks like below: "
-                    + " ID = $your_job_id, or STATE = \"PENDING|EXPORTING|FINISHED|CANCELLED\", " +
-                    "or LABEL = \"xxx\" or LABEL like \"xxx%\"");
+                    + " ID = $your_job_id, or STATE = \"PENDING|EXPORTING|FINISHED|CANCELLED\", "
+                    + "or LABEL = \"xxx\" or LABEL like \"xxx%\"");
         }
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowFunctionsStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowFunctionsStmt.java
index ba26148472..837a74c00c 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowFunctionsStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowFunctionsStmt.java
@@ -59,7 +59,9 @@ public class ShowFunctionsStmt extends ShowStmt {
         this.expr = expr;
     }
 
-    public String getDbName() { return dbName; }
+    public String getDbName() {
+        return dbName;
+    }
 
     public boolean getIsBuiltin() {
         return isBuiltin;
@@ -97,7 +99,7 @@ public class ShowFunctionsStmt extends ShowStmt {
 
         if (!Catalog.getCurrentCatalog().getAuth().checkDbPriv(ConnectContext.get(), dbName, PrivPredicate.SHOW)) {
             ErrorReport.reportAnalysisException(
-                ErrorCode.ERR_DBACCESS_DENIED_ERROR, ConnectContext.get().getQualifiedUser(), dbName);
+                    ErrorCode.ERR_DBACCESS_DENIED_ERROR, ConnectContext.get().getQualifiedUser(), dbName);
         }
 
         if (expr != null) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowPartitionsStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowPartitionsStmt.java
index 3091112cfd..7b2bf92fa8 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowPartitionsStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowPartitionsStmt.java
@@ -90,7 +90,7 @@ public class ShowPartitionsStmt extends ShowStmt {
     }
 
     public Map<String, Expr> getFilterMap() {
-      return filterMap;
+        return filterMap;
     }
 
     public ProcNodeInterface getNode() {
@@ -191,18 +191,18 @@ public class ShowPartitionsStmt extends ShowStmt {
             BinaryPredicate binaryPredicate = (BinaryPredicate) subExpr;
             if (leftKey.equalsIgnoreCase(FILTER_PARTITION_NAME) || leftKey.equalsIgnoreCase(FILTER_STATE)) {
                 if (binaryPredicate.getOp() != BinaryPredicate.Operator.EQ) {
-                  throw new AnalysisException(String.format("Only operator =|like are supported for %s", leftKey));
+                    throw new AnalysisException(String.format("Only operator =|like are supported for %s", leftKey));
                 }
             } else if (leftKey.equalsIgnoreCase(FILTER_LAST_CONSISTENCY_CHECK_TIME)) {
                 if (!(subExpr.getChild(1) instanceof StringLiteral)) {
                     throw new AnalysisException("Where clause : LastConsistencyCheckTime =|>=|<=|>|<|!= "
                         + "\"2019-12-22|2019-12-22 22:22:00\"");
                 }
-                subExpr.setChild(1,(subExpr.getChild(1)).castTo(Type.DATETIME));
-            } else if (!leftKey.equalsIgnoreCase(FILTER_PARTITION_ID) && !leftKey.equalsIgnoreCase(FILTER_BUCKETS) &&
-                !leftKey.equalsIgnoreCase(FILTER_REPLICATION_NUM)) {
-                throw new AnalysisException("Only the columns of PartitionId/PartitionName/" +
-                    "State/Buckets/ReplicationNum/LastConsistencyCheckTime are supported.");
+                subExpr.setChild(1, (subExpr.getChild(1)).castTo(Type.DATETIME));
+            } else if (!leftKey.equalsIgnoreCase(FILTER_PARTITION_ID) && !leftKey.equalsIgnoreCase(FILTER_BUCKETS)
+                    && !leftKey.equalsIgnoreCase(FILTER_REPLICATION_NUM)) {
+                throw new AnalysisException("Only the columns of PartitionId/PartitionName/"
+                        + "State/Buckets/ReplicationNum/LastConsistencyCheckTime are supported.");
             }
         } else if (subExpr instanceof LikePredicate) {
             LikePredicate likePredicate = (LikePredicate) subExpr;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRepositoriesStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRepositoriesStmt.java
index 73f8977690..dbbd5d7b36 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRepositoriesStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRepositoriesStmt.java
@@ -37,9 +37,9 @@ public class ShowRepositoriesStmt extends ShowStmt {
     public ShowResultSetMetaData getMetaData() {
         ShowResultSetMetaData.Builder builder = ShowResultSetMetaData.builder();
         for (String title : TITLE_NAMES) {
-           builder.addColumn(new Column(title, ScalarType.createVarchar(30)));
-       }
-       return builder.build();
+            builder.addColumn(new Column(title, ScalarType.createVarchar(30)));
+        }
+        return builder.build();
     }
 
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowResourcesStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowResourcesStmt.java
index df11a77f5e..f009b8d687 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowResourcesStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowResourcesStmt.java
@@ -53,7 +53,7 @@ public class ShowResourcesStmt extends ShowStmt {
 
     private ArrayList<OrderByPair> orderByPairs;
 
-   public ShowResourcesStmt() {
+    public ShowResourcesStmt() {
     }
 
     public ShowResourcesStmt(Expr labelExpr, List<OrderByElement> orderByElements, LimitElement limitElement) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRoutineLoadTaskStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRoutineLoadTaskStmt.java
index 6a7dccca06..553151165b 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRoutineLoadTaskStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowRoutineLoadTaskStmt.java
@@ -95,7 +95,7 @@ public class ShowRoutineLoadTaskStmt extends ShowStmt {
 
         boolean valid = true;
         CHECK:
-        {
+        { // CHECKSTYLE IGNORE THIS LINE
             // check predicate
             if (!(jobNameExpr instanceof BinaryPredicate)) {
                 valid = false;
@@ -125,7 +125,7 @@ public class ShowRoutineLoadTaskStmt extends ShowStmt {
             }
             StringLiteral stringLiteral = (StringLiteral) binaryPredicate.getChild(1);
             jobName = stringLiteral.getValue().toLowerCase();
-        }
+        } // CHECKSTYLE IGNORE THIS LINE
 
         if (!valid) {
             throw new AnalysisException("show routine load job only support one equal expr which is sames like JobName=\"ILoveDoris\"");
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowSmallFilesStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowSmallFilesStmt.java
index e83328bf2a..359f284a97 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowSmallFilesStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowSmallFilesStmt.java
@@ -48,7 +48,9 @@ public class ShowSmallFilesStmt extends ShowStmt {
         this.dbName = dbName;
     }
 
-    public String getDbName() { return dbName; }
+    public String getDbName() {
+        return dbName;
+    }
 
     @Override
     public void analyze(Analyzer analyzer) throws UserException {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowStreamLoadStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowStreamLoadStmt.java
index d9bc8ac25f..1ecfa5e060 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowStreamLoadStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowStreamLoadStmt.java
@@ -93,6 +93,7 @@ public class ShowStreamLoadStmt extends ShowStmt {
         try {
             index = analyzeColumn("FinishTime");
         } catch (AnalysisException e) {
+            // CHECKSTYLE IGNORE THIS LINE
         }
         OrderByPair orderByPair = new OrderByPair(index, false);
         orderByFinishTime.add(orderByPair);
@@ -126,6 +127,7 @@ public class ShowStreamLoadStmt extends ShowStmt {
         try {
             state = StreamLoadState.valueOf(stateValue);
         } catch (Exception e) {
+            // CHECKSTYLE IGNORE THIS LINE
         }
         return state;
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTabletStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTabletStmt.java
index 5cc10e741d..927c075ee6 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTabletStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTabletStmt.java
@@ -55,7 +55,7 @@ public class ShowTabletStmt extends ShowStmt {
     private boolean isShowSingleTablet;
 
     public ShowTabletStmt(TableName dbTableName, long tabletId) {
-        this(dbTableName, tabletId, null, null, null,null);
+        this(dbTableName, tabletId, null, null, null, null);
     }
 
     public ShowTabletStmt(TableName dbTableName, long tabletId, PartitionNames partitionNames,
@@ -100,27 +100,49 @@ public class ShowTabletStmt extends ShowStmt {
         return isShowSingleTablet;
     }
 
-    public boolean hasOffset() { return limitElement != null && limitElement.hasOffset(); }
+    public boolean hasOffset() {
+        return limitElement != null && limitElement.hasOffset();
+    }
 
-    public long getOffset() { return limitElement.getOffset(); }
+    public long getOffset() {
+        return limitElement.getOffset();
+    }
 
-    public boolean hasPartition() { return partitionNames != null; }
+    public boolean hasPartition() {
+        return partitionNames != null;
+    }
 
-    public PartitionNames getPartitionNames() { return partitionNames; }
+    public PartitionNames getPartitionNames() {
+        return partitionNames;
+    }
 
-    public boolean hasLimit() { return limitElement != null && limitElement.hasLimit(); }
+    public boolean hasLimit() {
+        return limitElement != null && limitElement.hasLimit();
+    }
 
-    public long getLimit() { return  limitElement.getLimit(); }
+    public long getLimit() {
+        return limitElement.getLimit();
+    }
 
-    public long getVersion() { return version; }
+    public long getVersion() {
+        return version;
+    }
 
-    public long getBackendId() { return backendId; }
+    public long getBackendId() {
+        return backendId;
+    }
 
-    public String getIndexName() { return indexName; }
+    public String getIndexName() {
+        return indexName;
+    }
 
-    public List<OrderByPair> getOrderByPairs() { return orderByPairs; }
+    public List<OrderByPair> getOrderByPairs() {
+        return orderByPairs;
+    }
 
-    public Replica.ReplicaState getReplicaState() { return  replicaState; }
+    public Replica.ReplicaState getReplicaState() {
+        return replicaState;
+    }
 
     @Override
     public void analyze(Analyzer analyzer) throws UserException {
@@ -209,11 +231,11 @@ public class ShowTabletStmt extends ShowStmt {
             }
             String leftKey = ((SlotRef) subExpr.getChild(0)).getColumnName();
             if (leftKey.equalsIgnoreCase("version")) {
-                 if (!(subExpr.getChild(1) instanceof IntLiteral) || version > -1) {
-                     valid = false;
-                     break;
-                 }
-                 version = ((IntLiteral) subExpr.getChild(1)).getValue();
+                if (!(subExpr.getChild(1) instanceof IntLiteral) || version > -1) {
+                    valid = false;
+                    break;
+                }
+                version = ((IntLiteral) subExpr.getChild(1)).getValue();
             } else if (leftKey.equalsIgnoreCase("backendid")) {
                 if (!(subExpr.getChild(1) instanceof IntLiteral) || backendId > -1) {
                     valid = false;
@@ -243,7 +265,7 @@ public class ShowTabletStmt extends ShowStmt {
                 valid = false;
                 break;
             }
-        } while(false);
+        } while (false);
 
         if (!valid) {
             throw new AnalysisException("Where clause should looks like: Version = \"version\","
@@ -264,7 +286,7 @@ public class ShowTabletStmt extends ShowStmt {
         if (limitElement != null) {
             if (limitElement.hasOffset() && limitElement.hasLimit()) {
                 sb.append(" ").append(limitElement.getOffset()).append(",").append(limitElement.getLimit());
-            } else if (limitElement.hasLimit()){
+            } else if (limitElement.hasLimit()) {
                 sb.append(" ").append(limitElement.getLimit());
             }
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTransactionStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTransactionStmt.java
index d0bcba502a..0766df2082 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTransactionStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ShowTransactionStmt.java
@@ -129,8 +129,8 @@ public class ShowTransactionStmt extends ShowStmt {
         }
 
         if (!valid) {
-            throw new AnalysisException("Where clause should looks like one of them: id = 123 or label = 'label' " +
-                    "or status = 'prepare/precommitted/committed/visible/aborted'");
+            throw new AnalysisException("Where clause should looks like one of them: id = 123 or label = 'label' "
+                    + "or status = 'prepare/precommitted/committed/visible/aborted'");
         }
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotDescriptor.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotDescriptor.java
index e516894eda..9cdd0b23b7 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotDescriptor.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotDescriptor.java
@@ -213,12 +213,29 @@ public class SlotDescriptor {
         return slotOffset;
     }
 
-    public String getLabel() { return label; }
-    public void setLabel(String label) { this.label = label; }
-    public void setSourceExprs(List<Expr> exprs) { sourceExprs = exprs; }
-    public void setSourceExpr(Expr expr) { sourceExprs = Collections.singletonList(expr); }
-    public void addSourceExpr(Expr expr) { sourceExprs.add(expr); }
-    public List<Expr> getSourceExprs() { return sourceExprs; }
+    public String getLabel() {
+        return label;
+    }
+
+    public void setLabel(String label) {
+        this.label = label;
+    }
+
+    public void setSourceExprs(List<Expr> exprs) {
+        sourceExprs = exprs;
+    }
+
+    public void setSourceExpr(Expr expr) {
+        sourceExprs = Collections.singletonList(expr);
+    }
+
+    public void addSourceExpr(Expr expr) {
+        sourceExprs.add(expr);
+    }
+
+    public List<Expr> getSourceExprs() {
+        return sourceExprs;
+    }
 
 
     /**
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotId.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotId.java
index 6854fe2d71..0ecaf4965e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotId.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotId.java
@@ -31,9 +31,14 @@ public class SlotId extends Id<SlotId> {
     public static IdGenerator<SlotId> createGenerator() {
         return new IdGenerator<SlotId>() {
             @Override
-            public SlotId getNextId() { return new SlotId(nextId++); }
+            public SlotId getNextId() {
+                return new SlotId(nextId++);
+            }
+
             @Override
-            public SlotId getMaxId() { return new SlotId(nextId - 1); }
+            public SlotId getMaxId() {
+                return new SlotId(nextId - 1);
+            }
         };
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotRef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotRef.java
index 636fbc991e..6e8017e3bd 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotRef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SlotRef.java
@@ -312,12 +312,14 @@ public class SlotRef extends Expr {
     }
 
     @Override
-    protected boolean isConstantImpl() { return false; }
+    protected boolean isConstantImpl() {
+        return false;
+    }
 
     @Override
     public boolean isBoundByTupleIds(List<TupleId> tids) {
         Preconditions.checkState(desc != null);
-        for (TupleId tid: tids) {
+        for (TupleId tid : tids) {
             if (tid.equals(desc.getParent().getId())) {
                 return true;
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SortInfo.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SortInfo.java
index 09a2b2b3b1..d57856b08b 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SortInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SortInfo.java
@@ -103,12 +103,29 @@ public class SortInfo {
         }
     }
 
-    public List<Expr> getOrderingExprs() { return orderingExprs; }
-    public List<Boolean> getIsAscOrder() { return isAscOrder; }
-    public List<Boolean> getNullsFirstParams() { return nullsFirstParams; }
-    public List<Expr> getMaterializedOrderingExprs() { return materializedOrderingExprs; }
-    public List<Expr> getSortTupleSlotExprs() { return sortTupleSlotExprs; }
-    public TupleDescriptor getSortTupleDescriptor() { return sortTupleDesc; }
+    public List<Expr> getOrderingExprs() {
+        return orderingExprs;
+    }
+
+    public List<Boolean> getIsAscOrder() {
+        return isAscOrder;
+    }
+
+    public List<Boolean> getNullsFirstParams() {
+        return nullsFirstParams;
+    }
+
+    public List<Expr> getMaterializedOrderingExprs() {
+        return materializedOrderingExprs;
+    }
+
+    public List<Expr> getSortTupleSlotExprs() {
+        return sortTupleSlotExprs;
+    }
+
+    public TupleDescriptor getSortTupleDescriptor() {
+        return sortTupleDesc;
+    }
 
     /**
      * Gets the list of booleans indicating whether nulls come first or last, independent
@@ -154,13 +171,15 @@ public class SortInfo {
      * Asserts that all ordering exprs are bound by the sort tuple.
      */
     public void checkConsistency() {
-        for (Expr orderingExpr: orderingExprs) {
+        for (Expr orderingExpr : orderingExprs) {
             Preconditions.checkState(orderingExpr.isBound(sortTupleDesc.getId()));
         }
     }
 
     @Override
-    public SortInfo clone() { return new SortInfo(this); }
+    public SortInfo clone() {
+        return new SortInfo(this);
+    }
 
     /**
      * Create a tuple descriptor for the single tuple that is materialized, sorted, and
@@ -195,7 +214,7 @@ public class SortInfo {
                 Predicates.instanceOf(SlotRef.class), sourceSlots);
         TreeNode.collect(Expr.substituteList(orderingExprs, substOrderBy, analyzer, false),
                 Predicates.instanceOf(SlotRef.class), sourceSlots);
-        for (SlotRef origSlotRef: sourceSlots) {
+        for (SlotRef origSlotRef : sourceSlots) {
             // Don't rematerialize slots that are already in the sort tuple.
             if (origSlotRef.getDesc().getParent().getId() != sortTupleDesc.getId()) {
                 SlotDescriptor origSlotDesc = origSlotRef.getDesc();
@@ -232,26 +251,12 @@ public class SortInfo {
             TupleDescriptor sortTupleDesc, Analyzer analyzer) {
         ExprSubstitutionMap substOrderBy = new ExprSubstitutionMap();
         for (Expr origOrderingExpr : orderingExprs) {
-            // TODO(zc): support materialized order exprs
-            // if (!origOrderingExpr.hasCost()
-            //         || origOrderingExpr.getCost() > SORT_MATERIALIZATION_COST_THRESHOLD
-            //         || origOrderingExpr.contains(Expr.IS_NONDETERMINISTIC_BUILTIN_FN_PREDICATE)
-            //         || origOrderingExpr.contains(Expr.IS_UDF_PREDICATE)) {
-            //     SlotDescriptor materializedDesc = analyzer.addSlotDescriptor(sortTupleDesc);
-            //     materializedDesc.initFromExpr(origOrderingExpr);
-            //     materializedDesc.setIsMaterialized(true);
-            //     SlotRef materializedRef = new SlotRef(materializedDesc);
-            //     substOrderBy.put(origOrderingExpr, materializedRef);
-            //     materializedOrderingExprs_.add(origOrderingExpr);
-            // }
-            {
-                SlotDescriptor materializedDesc = analyzer.addSlotDescriptor(sortTupleDesc);
-                materializedDesc.initFromExpr(origOrderingExpr);
-                materializedDesc.setIsMaterialized(true);
-                SlotRef materializedRef = new SlotRef(materializedDesc);
-                substOrderBy.put(origOrderingExpr, materializedRef);
-                materializedOrderingExprs.add(origOrderingExpr);
-            }
+            SlotDescriptor materializedDesc = analyzer.addSlotDescriptor(sortTupleDesc);
+            materializedDesc.initFromExpr(origOrderingExpr);
+            materializedDesc.setIsMaterialized(true);
+            SlotRef materializedRef = new SlotRef(materializedDesc);
+            substOrderBy.put(origOrderingExpr, materializedRef);
+            materializedOrderingExprs.add(origOrderingExpr);
         }
         return substOrderBy;
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/StatementBase.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/StatementBase.java
index 92ffaa6bbf..eb174cfcc7 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/StatementBase.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/StatementBase.java
@@ -123,7 +123,9 @@ public abstract class StatementBase implements ParseNode {
      * if not applicable (not all statements produce an output result set).
      * Subclasses must override this as necessary.
      */
-    public List<String> getColLabels() { return Collections.<String>emptyList();  }
+    public List<String> getColLabels() {
+        return Collections.<String>emptyList();
+    }
 
     /**
      * Sets the column labels of this statement, if applicable. No-op of the statement does
@@ -143,7 +145,9 @@ public abstract class StatementBase implements ParseNode {
      * empty list if not applicable (not all statements produce an output result set).
      * Subclasses must override this as necessary.
      */
-    public List<Expr> getResultExprs() { return Collections.<Expr>emptyList(); }
+    public List<Expr> getResultExprs() {
+        return Collections.<Expr>emptyList();
+    }
 
     /**
      * Casts the result expressions and derived members (e.g., destination column types for
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/StmtRewriter.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/StmtRewriter.java
index 64695fd6bb..1700c64ae8 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/StmtRewriter.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/StmtRewriter.java
@@ -718,8 +718,6 @@ public class StmtRewriter {
         if (!hasEqJoinPred && !inlineView.isCorrelated()) {
             // TODO: Remove this when independent subquery evaluation is implemented.
             // TODO: Requires support for non-equi joins.
-            boolean hasGroupBy = ((SelectStmt) inlineView.getViewStmt()).hasGroupByClause();
-            // boolean hasGroupBy = false;
             if (!expr.getSubquery().returnsScalarColumn()) {
                 throw new AnalysisException("Unsupported predicate with subquery: "
                         + expr.toSql());
@@ -728,8 +726,8 @@ public class StmtRewriter {
             // TODO: Requires support for null-aware anti-join mode in nested-loop joins
             if (expr.getSubquery().isScalarSubquery() && expr instanceof InPredicate
                     && ((InPredicate) expr).isNotIn()) {
-                throw new AnalysisException("Unsupported NOT IN predicate with subquery: " +
-                        expr.toSql());
+                throw new AnalysisException("Unsupported NOT IN predicate with subquery: "
+                        + expr.toSql());
             }
 
             // We can equal the aggregate subquery using a cross join. All conjuncts
@@ -798,8 +796,8 @@ public class StmtRewriter {
             // tbl1,...,tbln are the visible tableRefs in stmt.
             for (int j = 0; j < tableIdx; ++j) {
                 TableRef tableRef = stmt.fromClause.get(j);
-                if (tableRef.getJoinOp() == JoinOperator.LEFT_SEMI_JOIN ||
-                        tableRef.getJoinOp() == JoinOperator.LEFT_ANTI_JOIN) {
+                if (tableRef.getJoinOp() == JoinOperator.LEFT_SEMI_JOIN
+                        || tableRef.getJoinOp() == JoinOperator.LEFT_ANTI_JOIN) {
                     continue;
                 }
                 newItems.add(SelectListItem.createStarItem(tableRef.getAliasAsName()));
@@ -978,8 +976,8 @@ public class StmtRewriter {
                 && (!stmt.hasAggInfo()
                 || !Iterables.all(correlatedPredicates,
                 Predicates.or(Expr.IS_EQ_BINARY_PREDICATE, isSingleSlotRef)))) {
-            throw new AnalysisException("Unsupported correlated EXISTS subquery with a " +
-                    "HAVING clause: " + stmt.toSql());
+            throw new AnalysisException(
+                    "Unsupported correlated EXISTS subquery with a " + "HAVING clause: " + stmt.toSql());
         }
 
         // The following correlated subqueries with a limit clause are supported:
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/StorageDesc.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/StorageDesc.java
index 914e085473..2a6475d6c1 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/StorageDesc.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/StorageDesc.java
@@ -63,9 +63,9 @@ public abstract class StorageDesc {
         }
         CaseInsensitiveMap ciProperties = new CaseInsensitiveMap();
         ciProperties.putAll(properties);
-        if (StringUtils.isNotEmpty(ciProperties.get(BOS_ENDPOINT).toString()) &&
-            StringUtils.isNotEmpty(ciProperties.get(BOS_ACCESS_KEY).toString()) &&
-            StringUtils.isNotEmpty(ciProperties.get(BOS_SECRET_ACCESS_KEY).toString())) {
+        if (StringUtils.isNotEmpty(ciProperties.get(BOS_ENDPOINT).toString())
+                && StringUtils.isNotEmpty(ciProperties.get(BOS_ACCESS_KEY).toString())
+                && StringUtils.isNotEmpty(ciProperties.get(BOS_SECRET_ACCESS_KEY).toString())) {
             // bos endpoint like http[s]://gz.bcebos.com, we want to extract region gz,
             // and convert to s3 endpoint http[s]://s3.gz.bcebos.com
             String bosEndpiont = ciProperties.get(BOS_ENDPOINT).toString();
@@ -99,7 +99,7 @@ public abstract class StorageDesc {
         try {
             URI orig = new URI(path);
             URI s3url = new URI("s3", orig.getRawAuthority(),
-                orig.getRawPath(), orig.getRawQuery(), orig.getRawFragment());
+                    orig.getRawPath(), orig.getRawQuery(), orig.getRawFragment());
             return s3url.toString();
         } catch (URISyntaxException e) {
             return path;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/Subquery.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/Subquery.java
index 8365bbbc16..d3056bbe2f 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/Subquery.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/Subquery.java
@@ -48,11 +48,18 @@ public class Subquery extends Expr {
     // A subquery has its own analysis context
     protected Analyzer analyzer;
 
-    public Analyzer getAnalyzer() { return analyzer; }
-    public QueryStmt getStatement() { return stmt; }
+    public Analyzer getAnalyzer() {
+        return analyzer;
+    }
+
+    public QueryStmt getStatement() {
+        return stmt;
+    }
 
     @Override
-    public String toSqlImpl() { return "(" + stmt.toSql() + ")"; }
+    public String toSqlImpl() {
+        return "(" + stmt.toSql() + ")";
+    }
 
     @Override
     public String toDigestImpl() {
@@ -84,8 +91,7 @@ public class Subquery extends Expr {
     @Override
     public void analyzeImpl(Analyzer parentAnalyzer) throws AnalysisException {
         if (!(stmt instanceof SelectStmt)) {
-            throw new AnalysisException("A subquery must contain a single select block: " +
-                    toSql());
+            throw new AnalysisException("A subquery must contain a single select block: " + toSql());
         }
         // The subquery is analyzed with its own analyzer.
         analyzer = new Analyzer(parentAnalyzer);
@@ -109,7 +115,7 @@ public class Subquery extends Expr {
         }
 
         // If the subquery returns many rows, set its type to MultiRowType.
-        if (!((SelectStmt)stmt).returnsSingleRow()) {
+        if (!((SelectStmt) stmt).returnsSingleRow()) {
             type = new MultiRowType(type);
         }
 
@@ -118,7 +124,9 @@ public class Subquery extends Expr {
     }
 
     @Override
-    protected boolean isConstantImpl() { return false; }
+    protected boolean isConstantImpl() {
+        return false;
+    }
 
     /**
      * Check if the subquery's SelectStmt returns a single column of scalar type.
@@ -189,7 +197,7 @@ public class Subquery extends Expr {
         if (!super.equals(o)) {
             return false;
         }
-        return stmt.toSql().equals(((Subquery)o).stmt.toSql());
+        return stmt.toSql().equals(((Subquery) o).stmt.toSql());
     }
 
     @Override
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/SyncStmt.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/SyncStmt.java
index cdafe07c97..59b9d3cd8a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/SyncStmt.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/SyncStmt.java
@@ -17,15 +17,12 @@
 
 package org.apache.doris.analysis;
 
-import org.apache.doris.common.AnalysisException;
 import org.apache.doris.common.UserException;
 
 public class SyncStmt extends DdlStmt {
     @Override
-    public void analyze(Analyzer analyzer) throws AnalysisException, UserException {
-//         if (analyzer.getCatalog().isMaster()) {
-//             throw new AnalysisException("No need to Sync, for you are master");
-//         }
+    public void analyze(Analyzer analyzer) throws UserException {
+
     }
 
     @Override
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java
index af8463e95d..429fc808c0 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/TableRef.java
@@ -460,8 +460,8 @@ public class TableRef implements ParseNode, Writable {
                             + " (in" + " \"" + this.toSql() + "\")");
                 }
                 if (desc.getTable().getColumn(colName) == null) {
-                    throw new AnalysisException("Unknown column " + colName + " for alias " + getAlias() + " (in \"" +
-                            this.toSql() + "\")");
+                    throw new AnalysisException("Unknown column " + colName + " for alias " + getAlias() + " (in \""
+                            + this.toSql() + "\")");
                 }
 
                 // create predicate "<left>.colName = <right>.colName"
@@ -476,11 +476,6 @@ public class TableRef implements ParseNode, Writable {
             }
         }
 
-        // at this point, both 'this' and leftTblRef have been analyzed
-        // and registered
-        boolean lhsIsNullable = false;
-        boolean rhsIsNullable = false;
-
         //
         if (leftTblRef != null) {
             for (TupleId tupleId : leftTblRef.getAllTableRefIds()) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ToSqlUtils.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ToSqlUtils.java
index d474cacaaf..01f18d87df 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ToSqlUtils.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ToSqlUtils.java
@@ -48,7 +48,7 @@ public class ToSqlUtils {
 
     public static List<String> getIdentSqlList(List<String> identList) {
         List<String> identSqlList = Lists.newArrayList();
-        for (String ident: identList) {
+        for (String ident : identList) {
             identSqlList.add(getIdentSql(ident));
         }
         return identSqlList;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleDescriptor.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleDescriptor.java
index d5fc90ff10..5bfc261713 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleDescriptor.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleDescriptor.java
@@ -167,7 +167,10 @@ public class TupleDescriptor {
         return isMaterialized;
     }
 
-    public boolean isMaterialized() { return isMaterialized; }
+    public boolean isMaterialized() {
+        return isMaterialized;
+    }
+
     public void setIsMaterialized(boolean value) {
         isMaterialized = value;
     }
@@ -180,8 +183,15 @@ public class TupleDescriptor {
         this.aliases = aliases;
         this.hasExplicitAlias = hasExplicitAlias;
     }
-    public boolean hasExplicitAlias() { return hasExplicitAlias; }
-    public String getAlias() { return (aliases != null) ? aliases[0] : null; }
+
+    public boolean hasExplicitAlias() {
+        return hasExplicitAlias;
+    }
+
+    public String getAlias() {
+        return (aliases != null) ? aliases[0] : null;
+    }
+
     public TableName getAliasAsName() {
         return (aliases != null) ? new TableName(null, aliases[0]) : null;
     }
@@ -220,7 +230,7 @@ public class TupleDescriptor {
      * In order to ensure that even if it is wrongly called a second time, no error will occur,
      * so it will be initialized again at the beginning of the function.
      *
-     * In the future this function will be changed to a private function.
+     * @deprecated In the future this function will be changed to a private function.
      */
     @Deprecated
     public void computeStat() {
@@ -230,7 +240,7 @@ public class TupleDescriptor {
         // compute stat
         for (SlotDescriptor d : slots) {
             if (!d.isMaterialized()) {
-               continue;
+                continue;
             }
             ColumnStats stats = d.getStats();
             if (stats.hasAvgSerializedSize()) {
@@ -243,7 +253,7 @@ public class TupleDescriptor {
     }
 
     /**
-     * In the future this function will be changed to a private function.
+     * @deprecated In the future this function will be changed to a private function.
      */
     @Deprecated
     public void computeMemLayout() {
@@ -256,7 +266,6 @@ public class TupleDescriptor {
         // populate slotsBySize; also compute avgSerializedSize
         numNullableSlots = 0;
         for (SlotDescriptor d : slots) {
-            ColumnStats stats = d.getStats();
             if (d.isMaterialized()) {
                 slotsBySize.get(d.getType().getSlotSize()).add(d);
                 if (d.getIsNullable()) {
@@ -330,7 +339,7 @@ public class TupleDescriptor {
      * Materialize all slots.
      */
     public void materializeSlots() {
-        for (SlotDescriptor slot: slots) {
+        for (SlotDescriptor slot : slots) {
             slot.setIsMaterialized(true);
         }
     }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleId.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleId.java
index a3424ea467..f962a32005 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleId.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleId.java
@@ -34,9 +34,14 @@ public class TupleId extends Id<TupleId> {
     public static IdGenerator<TupleId> createGenerator() {
         return new IdGenerator<TupleId>() {
             @Override
-            public TupleId getNextId() { return new TupleId(nextId++); }
+            public TupleId getNextId() {
+                return new TupleId(nextId++);
+            }
+
             @Override
-            public TupleId getMaxId() { return new TupleId(nextId - 1); }
+            public TupleId getMaxId() {
+                return new TupleId(nextId - 1);
+            }
         };
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleIsNullPredicate.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleIsNullPredicate.java
index 9b67d4cd1a..7e9e422d4e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleIsNullPredicate.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/TupleIsNullPredicate.java
@@ -182,9 +182,9 @@ public class TupleIsNullPredicate extends Predicate {
         if (expr instanceof FunctionCallExpr) {
             FunctionCallExpr fnCallExpr = (FunctionCallExpr) expr;
             List<Expr> params = fnCallExpr.getParams().exprs();
-            if (fnCallExpr.getFnName().getFunction().equals("if") &&
-                    params.get(0) instanceof TupleIsNullPredicate &&
-                    Expr.IS_NULL_LITERAL.apply(params.get(1))) {
+            if (fnCallExpr.getFnName().getFunction().equals("if")
+                    && params.get(0) instanceof TupleIsNullPredicate
+                    && Expr.IS_NULL_LITERAL.apply(params.get(1))) {
                 return unwrapExpr(params.get(2));
             }
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/TypeDef.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/TypeDef.java
index 0f25cafd4f..9f82878d76 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/TypeDef.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/TypeDef.java
@@ -38,157 +38,158 @@ import java.util.ArrayList;
  * Represents an anonymous type definition, e.g., used in DDL and CASTs.
  */
 public class TypeDef implements ParseNode {
-  private boolean isAnalyzed;
-  private final Type parsedType;
+    private boolean isAnalyzed;
+    private final Type parsedType;
 
-  public TypeDef(Type parsedType) {
-    this.parsedType = parsedType;
-  }
-
-  public static TypeDef create(PrimitiveType type) {
-    return new TypeDef(ScalarType.createType(type));
-  }
-
-  public static TypeDef createDecimal(int precision, int scale) {
-    return new TypeDef(ScalarType.createDecimalV2Type(precision, scale));
-  }
-
-  public static TypeDef createVarchar(int len) {
-    return new TypeDef(ScalarType.createVarchar(len));
-  }
-
-  public static TypeDef createChar(int len) {
-    return new TypeDef(ScalarType.createChar(len));
-  }
+    public TypeDef(Type parsedType) {
+        this.parsedType = parsedType;
+    }
 
-  @Override
-  public void analyze(Analyzer analyzer) throws AnalysisException {
-    if (isAnalyzed) {
-      return;
+    public static TypeDef create(PrimitiveType type) {
+        return new TypeDef(ScalarType.createType(type));
     }
-    // Check the max nesting depth before calling the recursive analyze() to avoid
-    // a stack overflow.
-    if (parsedType.exceedsMaxNestingDepth()) {
-      throw new AnalysisException(String.format(
-              "Type exceeds the maximum nesting depth of %s:\n%s",
-              Type.MAX_NESTING_DEPTH, parsedType.toSql()));
+
+    public static TypeDef createDecimal(int precision, int scale) {
+        return new TypeDef(ScalarType.createDecimalV2Type(precision, scale));
     }
-    analyze(parsedType);
-    isAnalyzed = true;
-  }
 
-  private void analyze(Type type) throws AnalysisException {
-    if (!type.isSupported()) {
-      throw new AnalysisException("Unsupported data type: " + type.toSql());
+    public static TypeDef createVarchar(int len) {
+        return new TypeDef(ScalarType.createVarchar(len));
     }
-    if (type.isScalarType()) {
-      analyzeScalarType((ScalarType) type);
+
+    public static TypeDef createChar(int len) {
+        return new TypeDef(ScalarType.createChar(len));
     }
 
-    if (type.isComplexType()) {
-      if (!Config.enable_complex_type_support) {
-        throw new AnalysisException("Unsupported data type: " + type.toSql());
-      }
-      if (type.isArrayType()) {
-        Type itemType = ((ArrayType) type).getItemType();
-        if (itemType instanceof ScalarType) {
-          analyzeNestedType((ScalarType) itemType);
+    @Override
+    public void analyze(Analyzer analyzer) throws AnalysisException {
+        if (isAnalyzed) {
+            return;
         }
-      }
-      if (type.isMapType()) {
-        ScalarType keyType = (ScalarType) ((MapType) type).getKeyType();
-        ScalarType valueType = (ScalarType) ((MapType) type).getKeyType();
-        analyzeNestedType(keyType);
-        analyzeNestedType(valueType);
-      }
-      if (type.isStructType()) {
-        ArrayList<StructField> fields = ((StructType) type).getFields();
-        for (int i = 0; i < fields.size(); i++) {
-          ScalarType filedType = (ScalarType) fields.get(i).getType();
-          analyzeNestedType(filedType);
+        // Check the max nesting depth before calling the recursive analyze() to avoid
+        // a stack overflow.
+        if (parsedType.exceedsMaxNestingDepth()) {
+            throw new AnalysisException(
+                    String.format("Type exceeds the maximum nesting depth of %s:\n%s", Type.MAX_NESTING_DEPTH,
+                            parsedType.toSql()));
         }
-      }
+        analyze(parsedType);
+        isAnalyzed = true;
     }
-  }
 
-  private void analyzeNestedType(ScalarType type) throws AnalysisException {
-    if (type.isNull()) {
-      throw new AnalysisException("Unsupported data type: " + type.toSql());
-    }
-    if (type.getPrimitiveType().isStringType()
-            && !type.isAssignedStrLenInColDefinition()) {
-      type.setLength(1);
-    }
-    analyze(type);
-  }
-
-  private void analyzeScalarType(ScalarType scalarType)
-          throws AnalysisException {
-    PrimitiveType type = scalarType.getPrimitiveType();
-    switch (type) {
-      case CHAR:
-      case VARCHAR: {
-        String name;
-        int maxLen;
-        if (type == PrimitiveType.VARCHAR) {
-          name = "VARCHAR";
-          maxLen = ScalarType.MAX_VARCHAR_LENGTH;
-        } else if (type == PrimitiveType.CHAR) {
-          name = "CHAR";
-          maxLen = ScalarType.MAX_CHAR_LENGTH;
-        } else {
-          Preconditions.checkState(false);
-          return;
+    private void analyze(Type type) throws AnalysisException {
+        if (!type.isSupported()) {
+            throw new AnalysisException("Unsupported data type: " + type.toSql());
         }
-        int len = scalarType.getLength();
-        // len is decided by child, when it is -1.
-
-        if (len <= 0) {
-          throw new AnalysisException(name + " size must be > 0: " + len);
+        if (type.isScalarType()) {
+            analyzeScalarType((ScalarType) type);
         }
-        if (scalarType.getLength() > maxLen) {
-          throw new AnalysisException(
-                  name + " size must be <= " + maxLen + ": " + len);
+
+        if (type.isComplexType()) {
+            if (!Config.enable_complex_type_support) {
+                throw new AnalysisException("Unsupported data type: " + type.toSql());
+            }
+            if (type.isArrayType()) {
+                Type itemType = ((ArrayType) type).getItemType();
+                if (itemType instanceof ScalarType) {
+                    analyzeNestedType((ScalarType) itemType);
+                }
+            }
+            if (type.isMapType()) {
+                ScalarType keyType = (ScalarType) ((MapType) type).getKeyType();
+                ScalarType valueType = (ScalarType) ((MapType) type).getKeyType();
+                analyzeNestedType(keyType);
+                analyzeNestedType(valueType);
+            }
+            if (type.isStructType()) {
+                ArrayList<StructField> fields = ((StructType) type).getFields();
+                for (int i = 0; i < fields.size(); i++) {
+                    ScalarType filedType = (ScalarType) fields.get(i).getType();
+                    analyzeNestedType(filedType);
+                }
+            }
         }
-        break;
-      }
-      case DECIMALV2: {
-        int precision = scalarType.decimalPrecision();
-        int scale = scalarType.decimalScale();
-        // precision: [1, 27]
-        if (precision < 1 || precision > 27) {
-          throw new AnalysisException("Precision of decimal must between 1 and 27."
-                  + " Precision was set to: " + precision + ".");
+    }
+
+    private void analyzeNestedType(ScalarType type) throws AnalysisException {
+        if (type.isNull()) {
+            throw new AnalysisException("Unsupported data type: " + type.toSql());
         }
-        // scale: [0, 9]
-        if (scale < 0 || scale > 9) {
-          throw new AnalysisException("Scale of decimal must between 0 and 9."
-                  + " Scale was set to: " + scale + ".");
+        if (type.getPrimitiveType().isStringType()
+                && !type.isAssignedStrLenInColDefinition()) {
+            type.setLength(1);
         }
-        // scale < precision
-        if (scale >= precision) {
-          throw new AnalysisException("Scale of decimal must be smaller than precision."
-                  + " Scale is " + scale + " and precision is " + precision);
+        analyze(type);
+    }
+
+    private void analyzeScalarType(ScalarType scalarType)
+            throws AnalysisException {
+        PrimitiveType type = scalarType.getPrimitiveType();
+        switch (type) {
+            case CHAR:
+            case VARCHAR: {
+                String name;
+                int maxLen;
+                if (type == PrimitiveType.VARCHAR) {
+                    name = "VARCHAR";
+                    maxLen = ScalarType.MAX_VARCHAR_LENGTH;
+                } else if (type == PrimitiveType.CHAR) {
+                    name = "CHAR";
+                    maxLen = ScalarType.MAX_CHAR_LENGTH;
+                } else {
+                    Preconditions.checkState(false);
+                    return;
+                }
+                int len = scalarType.getLength();
+                // len is decided by child, when it is -1.
+
+                if (len <= 0) {
+                    throw new AnalysisException(name + " size must be > 0: " + len);
+                }
+                if (scalarType.getLength() > maxLen) {
+                    throw new AnalysisException(
+                            name + " size must be <= " + maxLen + ": " + len);
+                }
+                break;
+            }
+            case DECIMALV2: {
+                int precision = scalarType.decimalPrecision();
+                int scale = scalarType.decimalScale();
+                // precision: [1, 27]
+                if (precision < 1 || precision > 27) {
+                    throw new AnalysisException("Precision of decimal must between 1 and 27."
+                            + " Precision was set to: " + precision + ".");
+                }
+                // scale: [0, 9]
+                if (scale < 0 || scale > 9) {
+                    throw new AnalysisException("Scale of decimal must between 0 and 9."
+                            + " Scale was set to: " + scale + ".");
+                }
+                // scale < precision
+                if (scale >= precision) {
+                    throw new AnalysisException("Scale of decimal must be smaller than precision."
+                            + " Scale is " + scale + " and precision is " + precision);
+                }
+                break;
+            }
+            case INVALID_TYPE:
+                throw new AnalysisException("Invalid type.");
+            default:
+                break;
         }
-        break;
-      }
-      case INVALID_TYPE:
-        throw new AnalysisException("Invalid type.");
-      default: break;
     }
-  }
 
-  public Type getType() {
-    return parsedType;
-  }
+    public Type getType() {
+        return parsedType;
+    }
 
-  @Override
-  public String toString() {
-    return parsedType.toSql();
-  }
+    @Override
+    public String toString() {
+        return parsedType.toSql();
+    }
 
-  @Override
-  public String toSql() {
-    return parsedType.toSql();
-  }
+    @Override
+    public String toSql() {
+        return parsedType.toSql();
+    }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/ValueList.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/ValueList.java
index 03e36c201e..a9f3951bff 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/ValueList.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/ValueList.java
@@ -36,9 +36,17 @@ public class ValueList {
         this.rows = rows;
     }
 
-    public List<ArrayList<Expr>> getRows() { return rows; }
-    public void addRow(ArrayList<Expr> row) { rows.add(row); }
-    public ArrayList<Expr> getFirstRow() { return rows.get(0); }
+    public List<ArrayList<Expr>> getRows() {
+        return rows;
+    }
+
+    public void addRow(ArrayList<Expr> row) {
+        rows.add(row);
+    }
+
+    public ArrayList<Expr> getFirstRow() {
+        return rows.get(0);
+    }
 
     public void analyzeForSelect(Analyzer analyzer) throws AnalysisException {
         if (rows.isEmpty()) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/analysis/WithClause.java b/fe/fe-core/src/main/java/org/apache/doris/analysis/WithClause.java
index eb631146dc..44ab177c25 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/analysis/WithClause.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/analysis/WithClause.java
@@ -83,14 +83,14 @@ public class WithClause implements ParseNode {
         if (analyzer.isExplain()) {
             withClauseAnalyzer.setIsExplain();
         }
-        for (View view: views) {
+        for (View view : views) {
             Analyzer viewAnalyzer = new Analyzer(withClauseAnalyzer);
             view.getQueryStmt().analyze(viewAnalyzer);
             // Register this view so that the next view can reference it.
             withClauseAnalyzer.registerLocalView(view);
         }
         // Register all local views with the analyzer.
-        for (View localView: withClauseAnalyzer.getLocalViews().values()) {
+        for (View localView : withClauseAnalyzer.getLocalViews().values()) {
             analyzer.registerLocalView(localView);
         }
     }
@@ -101,14 +101,14 @@ public class WithClause implements ParseNode {
     private WithClause(WithClause other) {
         Preconditions.checkNotNull(other);
         views = Lists.newArrayList();
-        for (View view: other.views) {
+        for (View view : other.views) {
             views.add(new View(view.getName(), view.getQueryStmt().clone(),
                     view.getOriginalColLabels()));
         }
     }
 
     public void reset() {
-        for (View view: views) {
+        for (View view : views) {
             view.getQueryStmt().reset();
         }
     }
@@ -130,12 +130,14 @@ public class WithClause implements ParseNode {
     }
 
     @Override
-    public WithClause clone() { return new WithClause(this); }
+    public WithClause clone() {
+        return new WithClause(this);
+    }
 
     @Override
     public String toSql() {
         List<String> viewStrings = Lists.newArrayList();
-        for (View view: views) {
+        for (View view : views) {
             // Enclose the view alias and explicit labels in quotes if Hive cannot parse it
             // without quotes. This is needed for view compatibility between Impala and Hive.
             String aliasSql = ToSqlUtils.getIdentSql(view.getName());
@@ -163,5 +165,7 @@ public class WithClause implements ParseNode {
         return "WITH " + Joiner.on(",").join(viewStrings);
     }
 
-    public List<View> getViews() { return views; }
+    public List<View> getViews() {
+        return views;
+    }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/backup/BackupHandler.java b/fe/fe-core/src/main/java/org/apache/doris/backup/BackupHandler.java
index d6a0824788..8215e6c1d4 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/backup/BackupHandler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/backup/BackupHandler.java
@@ -191,11 +191,11 @@ public class BackupHandler extends MasterDaemon implements Writable {
     // handle create repository stmt
     public void createRepository(CreateRepositoryStmt stmt) throws DdlException {
         if (!catalog.getBrokerMgr().containsBroker(stmt.getBrokerName())
-            && stmt.getStorageType() == StorageBackend.StorageType.BROKER) {
+                && stmt.getStorageType() == StorageBackend.StorageType.BROKER) {
             ErrorReport.reportDdlException(ErrorCode.ERR_COMMON_ERROR, "broker does not exist: " + stmt.getBrokerName());
         }
 
-        BlobStorage storage = BlobStorage.create(stmt.getBrokerName(),stmt.getStorageType(), stmt.getProperties());
+        BlobStorage storage = BlobStorage.create(stmt.getBrokerName(), stmt.getStorageType(), stmt.getProperties());
         long repoId = catalog.getNextId();
         Repository repo = new Repository(repoId, stmt.getName(), stmt.isReadOnly(), stmt.getLocation(), storage);
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJob.java b/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJob.java
index 9e48700fd3..69b638a3cd 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJob.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJob.java
@@ -91,7 +91,6 @@ public class BackupJob extends AbstractJob {
 
     // all objects which need backup
     private List<TableRef> tableRefs = Lists.newArrayList();
-//    private BackupContent content = BackupContent.ALL;
 
     private BackupJobState state;
 
@@ -364,7 +363,7 @@ public class BackupJob extends AbstractJob {
                 status = new Status(ErrCode.NOT_FOUND, "table " + tblName + " does not exist");
                 return;
             }
-            switch (tbl.getType()){
+            switch (tbl.getType()) {
                 case OLAP:
                     checkOlapTable((OlapTable) tbl, tableRef);
                     if (getContent() == BackupContent.ALL) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJobInfo.java b/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJobInfo.java
index c871412978..2c32005d0a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJobInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/backup/BackupJobInfo.java
@@ -521,7 +521,7 @@ public class BackupJobInfo implements Writable {
                         partitionInfo.indexes.put(olapTbl.getIndexNameById(index.getId()), idxInfo);
                         // tablets
                         if (content == BackupContent.METADATA_ONLY) {
-                            for (Tablet tablet: index.getTablets()) {
+                            for (Tablet tablet : index.getTablets()) {
                                 idxInfo.tablets.put(tablet.getId(), Lists.newArrayList());
                             }
                         } else {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/backup/BrokerStorage.java b/fe/fe-core/src/main/java/org/apache/doris/backup/BrokerStorage.java
index e1edd61a57..9295095f40 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/backup/BrokerStorage.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/backup/BrokerStorage.java
@@ -87,8 +87,7 @@ public class BrokerStorage extends BlobStorage {
 
     @Override
     public Status downloadWithFileSize(String remoteFilePath, String localFilePath, long fileSize) {
-        LOG.debug("download from {} to {}, file size: {}.",
-            remoteFilePath, localFilePath, fileSize);
+        LOG.debug("download from {} to {}, file size: {}.", remoteFilePath, localFilePath, fileSize);
 
         long start = System.currentTimeMillis();
 
@@ -104,7 +103,7 @@ public class BrokerStorage extends BlobStorage {
         TBrokerFD fd;
         try {
             TBrokerOpenReaderRequest req = new TBrokerOpenReaderRequest(TBrokerVersion.VERSION_ONE, remoteFilePath,
-                0, clientId(), getProperties());
+                    0, clientId(), getProperties());
             TBrokerOpenReaderResponse rep = client.openReader(req);
             TBrokerOperationStatus opst = rep.getOpStatus();
             if (opst.getStatusCode() != TBrokerOperationStatusCode.OK) {
@@ -115,7 +114,7 @@ public class BrokerStorage extends BlobStorage {
 
             fd = rep.getFd();
             LOG.info("finished to open reader. fd: {}. download {} to {}.",
-                fd, remoteFilePath, localFilePath);
+                    fd, remoteFilePath, localFilePath);
         } catch (TException e) {
             return new Status(Status.ErrCode.COMMON_ERROR,
                 "failed to open reader on broker " + BrokerUtil.printBroker(getName(), address)
@@ -159,7 +158,7 @@ public class BrokerStorage extends BlobStorage {
                 while (tryTimes < 3) {
                     try {
                         TBrokerPReadRequest req = new TBrokerPReadRequest(TBrokerVersion.VERSION_ONE,
-                            fd, readOffset, readLen);
+                                fd, readOffset, readLen);
                         rep = client.pread(req);
                         if (rep.getOpStatus().getStatusCode() != TBrokerOperationStatusCode.OK) {
                             // pread return failure.
@@ -175,7 +174,7 @@ public class BrokerStorage extends BlobStorage {
                         }
                         if (rep.opStatus.statusCode != TBrokerOperationStatusCode.END_OF_FILE) {
                             LOG.debug("download. readLen: {}, read data len: {}, left size:{}. total size: {}",
-                                readLen, rep.getData().length, leftSize, fileSize);
+                                    readLen, rep.getData().length, leftSize, fileSize);
                         } else {
                             LOG.debug("read eof: " + remoteFilePath);
                         }
@@ -223,9 +222,9 @@ public class BrokerStorage extends BlobStorage {
                     // I don't know why, but have to adapt to it.
                     if (rep.getData().length != readLen) {
                         LOG.warn("the actual read length does not equal to "
-                                + "the expected read length: {} vs. {}, file: {}, broker: {}",
-                            rep.getData().length, readLen, remoteFilePath,
-                            BrokerUtil.printBroker(getName(), address));
+                                        + "the expected read length: {} vs. {}, file: {}, broker: {}",
+                                rep.getData().length, readLen, remoteFilePath,
+                                BrokerUtil.printBroker(getName(), address));
                     }
 
                     out.write(rep.getData());
@@ -237,8 +236,8 @@ public class BrokerStorage extends BlobStorage {
                 }
             } // end of reading remote file
         } catch (IOException e) {
-            return new Status(Status.ErrCode.COMMON_ERROR, "Got exception: " + e.getMessage() + ", broker: " +
-                BrokerUtil.printBroker(getName(), address));
+            return new Status(Status.ErrCode.COMMON_ERROR, "Got exception: " + e.getMessage() + ", broker: "
+                    + BrokerUtil.printBroker(getName(), address));
         } finally {
             // close broker reader
             Status closeStatus = closeReader(client, address, fd);
@@ -254,8 +253,8 @@ public class BrokerStorage extends BlobStorage {
             }
         }
 
-        LOG.info("finished to download from {} to {} with size: {}. cost {} ms", remoteFilePath, localFilePath,
-            fileSize, (System.currentTimeMillis() - start));
+        LOG.info("finished to download from {} to {} with size: {}. cost {} ms",
+                remoteFilePath, localFilePath, fileSize, (System.currentTimeMillis() - start));
         return status;
     }
 
@@ -421,7 +420,7 @@ public class BrokerStorage extends BlobStorage {
 
         if (status.ok()) {
             LOG.info("finished to upload {} to remote path {}. cost: {} ms",
-                localPath, remotePath, (System.currentTimeMillis() - start));
+                    localPath, remotePath, (System.currentTimeMillis() - start));
         }
         return status;
     }
@@ -440,8 +439,8 @@ public class BrokerStorage extends BlobStorage {
         // 2. rename
         boolean needReturn = true;
         try {
-            TBrokerRenamePathRequest req = new TBrokerRenamePathRequest(TBrokerVersion.VERSION_ONE, origFilePath,
-                destFilePath, getProperties());
+            TBrokerRenamePathRequest req = new TBrokerRenamePathRequest(TBrokerVersion.VERSION_ONE,
+                    origFilePath, destFilePath, getProperties());
             TBrokerOperationStatus ost = client.renamePath(req);
             if (ost.getStatusCode() != TBrokerOperationStatusCode.OK) {
                 return new Status(Status.ErrCode.COMMON_ERROR,
@@ -462,7 +461,7 @@ public class BrokerStorage extends BlobStorage {
         }
 
         LOG.info("finished to rename {} to  {}. cost: {} ms",
-            origFilePath, destFilePath, (System.currentTimeMillis() - start));
+                origFilePath, destFilePath, (System.currentTimeMillis() - start));
         return Status.OK;
     }
 
@@ -479,8 +478,8 @@ public class BrokerStorage extends BlobStorage {
         // delete
         boolean needReturn = true;
         try {
-            TBrokerDeletePathRequest req = new TBrokerDeletePathRequest(TBrokerVersion.VERSION_ONE, remotePath,
-                getProperties());
+            TBrokerDeletePathRequest req = new TBrokerDeletePathRequest(TBrokerVersion.VERSION_ONE,
+                    remotePath, getProperties());
             TBrokerOperationStatus opst = client.deletePath(req);
             if (opst.getStatusCode() != TBrokerOperationStatusCode.OK) {
                 return new Status(Status.ErrCode.COMMON_ERROR,
@@ -521,7 +520,7 @@ public class BrokerStorage extends BlobStorage {
         boolean needReturn = true;
         try {
             TBrokerListPathRequest req = new TBrokerListPathRequest(TBrokerVersion.VERSION_ONE, remotePath,
-                false /* not recursive */, getProperties());
+                    false /* not recursive */, getProperties());
             req.setFileNameOnly(true);
             TBrokerListResponse rep = client.listPath(req);
             TBrokerOperationStatus opst = rep.getOpStatus();
@@ -572,7 +571,7 @@ public class BrokerStorage extends BlobStorage {
         boolean needReturn = true;
         try {
             TBrokerCheckPathExistRequest req = new TBrokerCheckPathExistRequest(TBrokerVersion.VERSION_ONE,
-                remotePath, getProperties());
+                    remotePath, getProperties());
             TBrokerCheckPathExistResponse rep = client.checkPathExist(req);
             TBrokerOperationStatus opst = rep.getOpStatus();
             if (opst.getStatusCode() != TBrokerOperationStatusCode.OK) {
@@ -636,7 +635,7 @@ public class BrokerStorage extends BlobStorage {
                               TBrokerFD fd) {
         try {
             TBrokerOpenWriterRequest req = new TBrokerOpenWriterRequest(TBrokerVersion.VERSION_ONE,
-                remoteFile, TBrokerOpenMode.APPEND, clientId(), getProperties());
+                    remoteFile, TBrokerOpenMode.APPEND, clientId(), getProperties());
             TBrokerOpenWriterResponse rep = client.openWriter(req);
             TBrokerOperationStatus opst = rep.getOpStatus();
             if (opst.getStatusCode() != TBrokerOperationStatusCode.OK) {
@@ -647,8 +646,7 @@ public class BrokerStorage extends BlobStorage {
 
             fd.setHigh(rep.getFd().getHigh());
             fd.setLow(rep.getFd().getLow());
-            LOG.info("finished to open writer. fd: {}. directly upload to remote path {}.",
-                fd, remoteFile);
+            LOG.info("finished to open writer. fd: {}. directly upload to remote path {}.", fd, remoteFile);
         } catch (TException e) {
             return new Status(Status.ErrCode.BAD_CONNECTION,
                 "failed to open writer on broker " + BrokerUtil.printBroker(getName(), address)
diff --git a/fe/fe-core/src/main/java/org/apache/doris/backup/RestoreJob.java b/fe/fe-core/src/main/java/org/apache/doris/backup/RestoreJob.java
index e638909045..9445f74413 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/backup/RestoreJob.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/backup/RestoreJob.java
@@ -99,6 +99,7 @@ import java.util.stream.Collectors;
 public class RestoreJob extends AbstractJob {
     private static final Logger LOG = LogManager.getLogger(RestoreJob.class);
 
+    // CHECKSTYLE OFF
     public enum RestoreJobState {
         PENDING, // Job is newly created. Check and prepare meta in catalog. Create replica if necessary.
                  // Waiting for replica creation finished synchronously, then sending snapshot tasks.
@@ -112,6 +113,7 @@ public class RestoreJob extends AbstractJob {
         FINISHED,
         CANCELLED
     }
+    // CHECKSTYLE ON
 
     private String backupTimestamp;
 
@@ -1438,7 +1440,7 @@ public class RestoreJob extends AbstractJob {
                     for (MaterializedIndex idx : part.getMaterializedIndices(IndexExtState.VISIBLE)) {
                         for (Tablet tablet : idx.getTablets()) {
                             for (Replica replica : tablet.getReplicas()) {
-                                if (!replica.checkVersionCatchUp(part.getVisibleVersion(),false)) {
+                                if (!replica.checkVersionCatchUp(part.getVisibleVersion(), false)) {
                                     replica.updateVersionInfo(part.getVisibleVersion(),
                                             replica.getDataSize(), replica.getRowCount());
                                 }
@@ -1759,7 +1761,7 @@ public class RestoreJob extends AbstractJob {
         }
 
         out.writeInt(restoredResources.size());
-        for (Resource resource: restoredResources) {
+        for (Resource resource : restoredResources) {
             resource.write(out);
         }
 
@@ -1818,7 +1820,7 @@ public class RestoreJob extends AbstractJob {
                 long partId = in.readLong();
                 long version = in.readLong();
                 // Useless but read it to compatible with meta
-                long versionHash = in.readLong();
+                long versionHash = in.readLong(); // CHECKSTYLE IGNORE THIS LINE
                 restoredVersionInfo.put(tblId, partId, version);
             }
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/blockrule/SqlBlockRuleMgr.java b/fe/fe-core/src/main/java/org/apache/doris/blockrule/SqlBlockRuleMgr.java
index 207930b18b..49cd7ab9f1 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/blockrule/SqlBlockRuleMgr.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/blockrule/SqlBlockRuleMgr.java
@@ -80,13 +80,13 @@ public class SqlBlockRuleMgr implements Writable {
 
     // check limitation's  effectiveness of a sql_block_rule
     public static void verifyLimitations(SqlBlockRule sqlBlockRule) throws DdlException {
-        if (sqlBlockRule.getPartitionNum() < 0){
+        if (sqlBlockRule.getPartitionNum() < 0) {
             throw new DdlException("the value of partition_num can't be a negative");
         }
-        if (sqlBlockRule.getTabletNum() < 0){
+        if (sqlBlockRule.getTabletNum() < 0) {
             throw new DdlException("the value of tablet_num can't be a negative");
         }
-        if (sqlBlockRule.getCardinality() < 0){
+        if (sqlBlockRule.getCardinality() < 0) {
             throw new DdlException("the value of cardinality can't be a negative");
         }
     }
@@ -210,12 +210,14 @@ public class SqlBlockRuleMgr implements Writable {
 
     public void matchSql(SqlBlockRule rule, String originSql, String sqlHash) throws AnalysisException {
         if (rule.getEnable()) {
-            if (StringUtils.isNotEmpty(rule.getSqlHash()) &&
-                    (!CreateSqlBlockRuleStmt.STRING_NOT_SET.equals(rule.getSqlHash()) && rule.getSqlHash().equals(sqlHash))) {
+            if (StringUtils.isNotEmpty(rule.getSqlHash())
+                    && (!CreateSqlBlockRuleStmt.STRING_NOT_SET.equals(rule.getSqlHash())
+                    && rule.getSqlHash().equals(sqlHash))) {
                 MetricRepo.COUNTER_HIT_SQL_BLOCK_RULE.increase(1L);
                 throw new AnalysisException("sql match hash sql block rule: " + rule.getName());
-            } else if (StringUtils.isNotEmpty(rule.getSql()) &&
-                    (!CreateSqlBlockRuleStmt.STRING_NOT_SET.equals(rule.getSql()) && rule.getSqlPattern().matcher(originSql).find())) {
+            } else if (StringUtils.isNotEmpty(rule.getSql())
+                    && (!CreateSqlBlockRuleStmt.STRING_NOT_SET.equals(rule.getSql())
+                    && rule.getSqlPattern().matcher(originSql).find())) {
                 MetricRepo.COUNTER_HIT_SQL_BLOCK_RULE.increase(1L);
                 throw new AnalysisException("sql match regex sql block rule: " + rule.getName());
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/AggregateFunction.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/AggregateFunction.java
index 9230fae4b8..8e1c0631ac 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/AggregateFunction.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/AggregateFunction.java
@@ -405,31 +405,89 @@ public class AggregateFunction extends Function {
         }
     }
 
-    public String getUpdateFnSymbol() { return updateFnSymbol; }
-    public String getInitFnSymbol() { return initFnSymbol; }
-    public String getSerializeFnSymbol() { return serializeFnSymbol; }
-    public String getMergeFnSymbol() { return mergeFnSymbol; }
-    public String getGetValueFnSymbol() { return getValueFnSymbol; }
-    public String getRemoveFnSymbol() { return removeFnSymbol; }
-    public String getFinalizeFnSymbol() { return finalizeFnSymbol; }
-    public boolean ignoresDistinct() { return ignoresDistinct; }
-    public boolean isAnalyticFn() { return isAnalyticFn; }
-    public boolean isAggregateFn() { return isAggregateFn; }
-    public boolean returnsNonNullOnEmpty() { return returnsNonNullOnEmpty; }
+    public String getUpdateFnSymbol() {
+        return updateFnSymbol;
+    }
+
+    public String getInitFnSymbol() {
+        return initFnSymbol;
+    }
+
+    public String getSerializeFnSymbol() {
+        return serializeFnSymbol;
+    }
+
+    public String getMergeFnSymbol() {
+        return mergeFnSymbol;
+    }
+
+    public String getGetValueFnSymbol() {
+        return getValueFnSymbol;
+    }
+
+    public String getRemoveFnSymbol() {
+        return removeFnSymbol;
+    }
+
+    public String getFinalizeFnSymbol() {
+        return finalizeFnSymbol;
+    }
+
+    public boolean ignoresDistinct() {
+        return ignoresDistinct;
+    }
+
+    public boolean isAnalyticFn() {
+        return isAnalyticFn;
+    }
+
+    public boolean isAggregateFn() {
+        return isAggregateFn;
+    }
+
+    public boolean returnsNonNullOnEmpty() {
+        return returnsNonNullOnEmpty;
+    }
 
     /**
      * Returns the intermediate type of this aggregate function or null
      * if it is identical to the return type.
      */
-    public Type getIntermediateType() { return intermediateType; }
-    public void setUpdateFnSymbol(String fn) { updateFnSymbol = fn; }
-    public void setInitFnSymbol(String fn) { initFnSymbol = fn; }
-    public void setSerializeFnSymbol(String fn) { serializeFnSymbol = fn; }
-    public void setMergeFnSymbol(String fn) { mergeFnSymbol = fn; }
-    public void setGetValueFnSymbol(String fn) { getValueFnSymbol = fn; }
-    public void setRemoveFnSymbol(String fn) { removeFnSymbol = fn; }
-    public void setFinalizeFnSymbol(String fn) { finalizeFnSymbol = fn; }
-    public void setIntermediateType(Type t) { intermediateType = t; }
+    public Type getIntermediateType() {
+        return intermediateType;
+    }
+
+    public void setUpdateFnSymbol(String fn) {
+        updateFnSymbol = fn;
+    }
+
+    public void setInitFnSymbol(String fn) {
+        initFnSymbol = fn;
+    }
+
+    public void setSerializeFnSymbol(String fn) {
+        serializeFnSymbol = fn;
+    }
+
+    public void setMergeFnSymbol(String fn) {
+        mergeFnSymbol = fn;
+    }
+
+    public void setGetValueFnSymbol(String fn) {
+        getValueFnSymbol = fn;
+    }
+
+    public void setRemoveFnSymbol(String fn) {
+        removeFnSymbol = fn;
+    }
+
+    public void setFinalizeFnSymbol(String fn) {
+        finalizeFnSymbol = fn;
+    }
+
+    public void setIntermediateType(Type t) {
+        intermediateType = t;
+    }
 
     @Override
     public String toSql(boolean ifNotExists) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Catalog.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Catalog.java
index 1458f63c38..50c3c40e78 100755
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Catalog.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Catalog.java
@@ -948,9 +948,10 @@ public class Catalog {
                     // But is metadata_failure_recovery is true, we will not check it because this may be a FE migration.
                     String[] split = nodeName.split("_");
                     if (Config.metadata_failure_recovery.equals("false") && !selfNode.first.equalsIgnoreCase(split[0])) {
-                        throw new IOException("the self host " + selfNode.first + " does not equal to the host in ROLE" +
-                                " file " + split[0] + ". You need to set 'priority_networks' config in fe.conf to match" +
-                                " the host " + split[0]);
+                        throw new IOException("the self host " + selfNode.first
+                                + " does not equal to the host in ROLE"
+                                + " file " + split[0] + ". You need to set 'priority_networks' config"
+                                + " in fe.conf to match the host " + split[0]);
                     }
                 }
             }
@@ -960,8 +961,7 @@ public class Catalog {
 
             if (!versionFile.exists()) {
                 clusterId = Config.cluster_id == -1 ? Storage.newClusterID() : Config.cluster_id;
-                token = Strings.isNullOrEmpty(Config.auth_token) ?
-                        Storage.newToken() : Config.auth_token;
+                token = Strings.isNullOrEmpty(Config.auth_token) ? Storage.newToken() : Config.auth_token;
                 storage = new Storage(clusterId, token, this.imageDir);
                 storage.writeClusterIdAndToken();
 
@@ -974,8 +974,7 @@ public class Catalog {
             } else {
                 clusterId = storage.getClusterID();
                 if (storage.getToken() == null) {
-                    token = Strings.isNullOrEmpty(Config.auth_token) ?
-                            Storage.newToken() : Config.auth_token;
+                    token = Strings.isNullOrEmpty(Config.auth_token) ? Storage.newToken() : Config.auth_token;
                     LOG.info("new token={}", token);
                     storage.setToken(token);
                     storage.writeClusterIdAndToken();
@@ -1488,8 +1487,8 @@ public class Catalog {
             }
         }
         if (Config.lower_case_table_names != GlobalVariable.lowerCaseTableNames) {
-            LOG.error("The configuration of \'lower_case_table_names\' does not support modification, " +
-                            "the expected value is {}, but the actual value is {}",
+            LOG.error("The configuration of \'lower_case_table_names\' does not support modification, "
+                            + "the expected value is {}, but the actual value is {}",
                     GlobalVariable.lowerCaseTableNames, Config.lower_case_table_names);
             System.exit(-1);
         }
@@ -1508,8 +1507,8 @@ public class Catalog {
 
         Frontend fe = checkFeExist(selfNode.first, selfNode.second);
         if (fe == null) {
-            LOG.error("current node {}:{} is not added to the cluster, will exit." +
-                            " Your FE IP maybe changed, please set 'priority_networks' config in fe.conf properly.",
+            LOG.error("current node {}:{} is not added to the cluster, will exit."
+                            + " Your FE IP maybe changed, please set 'priority_networks' config in fe.conf properly.",
                     selfNode.first, selfNode.second);
             System.exit(-1);
         } else if (fe.getRole() != role) {
@@ -2681,9 +2680,9 @@ public class Catalog {
             try {
                 if (!stmt.isForceDrop()) {
                     if (Catalog.getCurrentCatalog().getGlobalTransactionMgr().existCommittedTxns(db.getId(), null, null)) {
-                        throw new DdlException("There are still some transactions in the COMMITTED state waiting to be completed. " +
-                                "The database [" + dbName + "] cannot be dropped. If you want to forcibly drop(cannot be recovered)," +
-                                " please use \"DROP database FORCE\".");
+                        throw new DdlException("There are still some transactions in the COMMITTED state waiting to be completed. "
+                                + "The database [" + dbName + "] cannot be dropped. If you want to forcibly drop(cannot be recovered),"
+                                + " please use \"DROP database FORCE\".");
                     }
                 }
                 if (db.getDbState() == DbState.LINK && dbName.equals(db.getAttachDb())) {
@@ -2729,9 +2728,9 @@ public class Catalog {
                             if (table.getType() == TableType.OLAP) {
                                 OlapTable olapTable = (OlapTable) table;
                                 if (olapTable.getState() != OlapTableState.NORMAL) {
-                                    throw new DdlException("The table [" + olapTable.getState() + "]'s state is " + olapTable.getState() + ", cannot be dropped." +
-                                            " please cancel the operation on olap table firstly. If you want to forcibly drop(cannot be recovered)," +
-                                            " please use \"DROP table FORCE\".");
+                                    throw new DdlException("The table [" + olapTable.getState() + "]'s state is " + olapTable.getState() + ", cannot be dropped."
+                                            + " please cancel the operation on olap table firstly. If you want to forcibly drop(cannot be recovered),"
+                                            + " please use \"DROP table FORCE\".");
                                 }
                             }
                         }
@@ -3486,9 +3485,9 @@ public class Catalog {
                 Partition partition = olapTable.getPartition(partitionName);
                 if (partition != null) {
                     if (Catalog.getCurrentCatalog().getGlobalTransactionMgr().existCommittedTxns(db.getId(), olapTable.getId(), partition.getId())) {
-                        throw new DdlException("There are still some transactions in the COMMITTED state waiting to be completed." +
-                                " The partition [" + partitionName + "] cannot be dropped. If you want to forcibly drop(cannot be recovered)," +
-                                " please use \"DROP partition FORCE\".");
+                        throw new DdlException("There are still some transactions in the COMMITTED state waiting to be completed."
+                                + " The partition [" + partitionName + "] cannot be dropped. If you want to forcibly drop(cannot be recovered),"
+                                + " please use \"DROP partition FORCE\".");
                     }
                 }
             }
@@ -4472,8 +4471,8 @@ public class Catalog {
 
         // 2. add partition
         if (separatePartition && (table instanceof OlapTable) && ((OlapTable) table).getPartitions().size() > 1) {
-            if (((OlapTable) table).getPartitionInfo().getType() == PartitionType.RANGE ||
-                    ((OlapTable) table).getPartitionInfo().getType() == PartitionType.LIST) {
+            if (((OlapTable) table).getPartitionInfo().getType() == PartitionType.RANGE
+                    || ((OlapTable) table).getPartitionInfo().getType() == PartitionType.LIST) {
                 OlapTable olapTable = (OlapTable) table;
                 PartitionInfo partitionInfo = olapTable.getPartitionInfo();
                 boolean first = true;
@@ -4687,9 +4686,9 @@ public class Catalog {
 
             if (!stmt.isForceDrop()) {
                 if (Catalog.getCurrentCatalog().getGlobalTransactionMgr().existCommittedTxns(db.getId(), table.getId(), null)) {
-                    throw new DdlException("There are still some transactions in the COMMITTED state waiting to be completed. " +
-                            "The table [" + tableName + "] cannot be dropped. If you want to forcibly drop(cannot be recovered)," +
-                            " please use \"DROP table FORCE\".");
+                    throw new DdlException("There are still some transactions in the COMMITTED state waiting to be completed. "
+                            + "The table [" + tableName + "] cannot be dropped. If you want to forcibly drop(cannot be recovered),"
+                            + " please use \"DROP table FORCE\".");
                 }
             }
             DropInfo info = new DropInfo(db.getId(), table.getId(), -1L, stmt.isForceDrop());
@@ -4698,9 +4697,9 @@ public class Catalog {
                 if (table instanceof OlapTable && !stmt.isForceDrop()) {
                     OlapTable olapTable = (OlapTable) table;
                     if ((olapTable.getState() != OlapTableState.NORMAL)) {
-                        throw new DdlException("The table [" + tableName + "]'s state is " + olapTable.getState() + ", cannot be dropped." +
-                                " please cancel the operation on olap table firstly. If you want to forcibly drop(cannot be recovered)," +
-                                " please use \"DROP table FORCE\".");
+                        throw new DdlException("The table [" + tableName + "]'s state is " + olapTable.getState() + ", cannot be dropped."
+                                + " please cancel the operation on olap table firstly. If you want to forcibly drop(cannot be recovered),"
+                                + " please use \"DROP table FORCE\".");
                     }
                 }
                 unprotectDropTable(db, table, stmt.isForceDrop(), false);
@@ -4928,8 +4927,8 @@ public class Catalog {
         return Optional.ofNullable(getDbNullable(dbId));
     }
 
-    public <E extends Exception> Database
-    getDbOrException(String dbName, java.util.function.Function<String, E> e) throws E {
+    public <E extends Exception> Database getDbOrException(
+            String dbName, java.util.function.Function<String, E> e) throws E {
         Database db = getDbNullable(dbName);
         if (db == null) {
             throw e.apply(dbName);
@@ -4937,8 +4936,7 @@ public class Catalog {
         return db;
     }
 
-    public <E extends Exception> Database
-    getDbOrException(long dbId, java.util.function.Function<Long, E> e) throws E {
+    public <E extends Exception> Database getDbOrException(long dbId, java.util.function.Function<Long, E> e) throws E {
         Database db = getDbNullable(dbId);
         if (db == null) {
             throw e.apply(dbId);
@@ -5781,9 +5779,10 @@ public class Catalog {
         String defaultReplicationNumName = "default." + PropertyAnalyzer.PROPERTIES_REPLICATION_NUM;
         PartitionInfo partitionInfo = table.getPartitionInfo();
         if (partitionInfo.getType() == PartitionType.RANGE || partitionInfo.getType() == PartitionType.LIST) {
-            throw new DdlException("This is a partitioned table, you should specify partitions with MODIFY PARTITION clause." +
-                    " If you want to set default replication number, please use '" + defaultReplicationNumName +
-                    "' instead of '" + PropertyAnalyzer.PROPERTIES_REPLICATION_NUM + "' to escape misleading.");
+            throw new DdlException("This is a partitioned table, you should specify partitions"
+                    + " with MODIFY PARTITION clause."
+                    + " If you want to set default replication number, please use '" + defaultReplicationNumName
+                    + "' instead of '" + PropertyAnalyzer.PROPERTIES_REPLICATION_NUM + "' to escape misleading.");
         }
         String partitionName = table.getName();
         Partition partition = table.getPartition(partitionName);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Column.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Column.java
index 9d6144fede..81eb14af0b 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Column.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Column.java
@@ -231,7 +231,9 @@ public class Column implements Writable {
         return !visible && aggregationType == AggregateType.REPLACE && nameEquals(SEQUENCE_COL, true);
     }
 
-    public PrimitiveType getDataType() { return type.getPrimitiveType(); }
+    public PrimitiveType getDataType() {
+        return type.getPrimitiveType();
+    }
 
     public Type getType() {
         return type;
@@ -241,11 +243,21 @@ public class Column implements Writable {
         this.type = type;
     }
 
-    public Type getOriginType() { return type; }
+    public Type getOriginType() {
+        return type;
+    }
+
+    public int getStrLen() {
+        return type.getLength();
+    }
+
+    public int getPrecision() {
+        return type instanceof ScalarType ? ((ScalarType) type).getScalarPrecision() : -1;
+    }
 
-    public int getStrLen() { return type.getLength(); }
-    public int getPrecision() { return type instanceof ScalarType ? ((ScalarType) type).getScalarPrecision() : -1; }
-    public int getScale() { return type instanceof ScalarType ? ((ScalarType) type).getScalarScale() : -1; }
+    public int getScale() {
+        return type instanceof ScalarType ? ((ScalarType) type).getScalarScale() : -1;
+    }
 
     public AggregateType getAggregationType() {
         return this.aggregationType;
@@ -397,8 +409,8 @@ public class Column implements Writable {
             Integer lSize = type.getColumnStringRepSize();
             Integer rSize = other.type.getColumnStringRepSize();
             if (rSize < lSize) {
-                throw new DdlException("Can not change from wider type " + type.toSql() +
-                                        " to narrower type " + other.type.toSql());
+                throw new DdlException("Can not change from wider type " + type.toSql()
+                        + " to narrower type " + other.type.toSql());
             }
         }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/ColumnStats.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/ColumnStats.java
index 6a7a852946..995d1603d5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/ColumnStats.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/ColumnStats.java
@@ -163,35 +163,35 @@ public class ColumnStats implements Writable {
      * the slot they occupy), sets avgSerializedSize and maxSize to their slot size.
      */
     public ColumnStats(PrimitiveType colType) {
-      avgSerializedSize = -1;
-      maxSize = -1;
-      numDistinctValues = -1;
-      numNulls = -1;
-      if (colType.isNumericType() || colType.isDateType()) {
-        avgSerializedSize = colType.getSlotSize();
-        maxSize = colType.getSlotSize();
-      }
+        avgSerializedSize = -1;
+        maxSize = -1;
+        numDistinctValues = -1;
+        numNulls = -1;
+        if (colType.isNumericType() || colType.isDateType()) {
+            avgSerializedSize = colType.getSlotSize();
+            maxSize = colType.getSlotSize();
+        }
     }
     /**
      * Creates ColumnStats from the given expr. Sets numDistinctValues and if the expr
      * is a SlotRef also numNulls.
      */
     public static ColumnStats fromExpr(Expr expr) {
-      Preconditions.checkNotNull(expr);
-      Preconditions.checkState(expr.getType().isValid());
-      ColumnStats stats = new ColumnStats(expr.getType().getPrimitiveType());
-      stats.setNumDistinctValues(expr.getNumDistinctValues());
-      SlotRef slotRef = expr.unwrapSlotRef();
-      if (slotRef == null) {
-          return stats;
-      }
-      ColumnStats slotStats = slotRef.getDesc().getStats();
-      if (slotStats == null) {
-          return stats;
-      }
-      stats.numNulls = slotStats.getNumNulls();
-      stats.avgSerializedSize = slotStats.getAvgSerializedSize();
-      stats.maxSize = slotStats.getMaxSize();
-      return stats;
+        Preconditions.checkNotNull(expr);
+        Preconditions.checkState(expr.getType().isValid());
+        ColumnStats stats = new ColumnStats(expr.getType().getPrimitiveType());
+        stats.setNumDistinctValues(expr.getNumDistinctValues());
+        SlotRef slotRef = expr.unwrapSlotRef();
+        if (slotRef == null) {
+            return stats;
+        }
+        ColumnStats slotStats = slotRef.getDesc().getStats();
+        if (slotStats == null) {
+            return stats;
+        }
+        stats.numNulls = slotStats.getNumNulls();
+        stats.avgSerializedSize = slotStats.getAvgSerializedSize();
+        stats.maxSize = slotStats.getMaxSize();
+        return stats;
     }
 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/DiskInfo.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/DiskInfo.java
index 6c415acb15..0f8b1c5454 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/DiskInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/DiskInfo.java
@@ -147,11 +147,13 @@ public class DiskInfo implements Writable {
         LOG.debug("flood stage: {}, diskAvailableCapacityB: {}, totalCapacityB: {}",
                 floodStage, diskAvailableCapacityB, totalCapacityB);
         if (floodStage) {
-            return diskAvailableCapacityB < Config.storage_flood_stage_left_capacity_bytes &&
-                    (double) (totalCapacityB - diskAvailableCapacityB) / totalCapacityB > (Config.storage_flood_stage_usage_percent / 100.0);
+            return diskAvailableCapacityB < Config.storage_flood_stage_left_capacity_bytes
+                    && (double) (totalCapacityB - diskAvailableCapacityB) / totalCapacityB
+                    > (Config.storage_flood_stage_usage_percent / 100.0);
         } else {
-            return diskAvailableCapacityB < Config.storage_min_left_capacity_bytes ||
-                    (double) (totalCapacityB - diskAvailableCapacityB) / totalCapacityB > (Config.storage_high_watermark_usage_percent / 100.0);
+            return diskAvailableCapacityB < Config.storage_min_left_capacity_bytes
+                    || (double) (totalCapacityB - diskAvailableCapacityB) / totalCapacityB
+                    > (Config.storage_high_watermark_usage_percent / 100.0);
         }
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/DynamicPartitionProperty.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/DynamicPartitionProperty.java
index ca8bf9002e..83ba5b67a6 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/DynamicPartitionProperty.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/DynamicPartitionProperty.java
@@ -199,18 +199,18 @@ public class DynamicPartitionProperty {
      */
     public String getProperties(ReplicaAllocation tableReplicaAlloc) {
         ReplicaAllocation tmpAlloc = this.replicaAlloc.isNotSet() ? tableReplicaAlloc : this.replicaAlloc;
-        String res = ",\n\"" + ENABLE + "\" = \"" + enable + "\"" +
-                ",\n\"" + TIME_UNIT + "\" = \"" + timeUnit + "\"" +
-                ",\n\"" + TIME_ZONE + "\" = \"" + tz.getID() + "\"" +
-                ",\n\"" + START + "\" = \"" + start + "\"" +
-                ",\n\"" + END + "\" = \"" + end + "\"" +
-                ",\n\"" + PREFIX + "\" = \"" + prefix + "\"" +
-                ",\n\"" + REPLICATION_ALLOCATION + "\" = \"" + tmpAlloc.toCreateStmt() + "\"" +
-                ",\n\"" + BUCKETS + "\" = \"" + buckets + "\"" +
-                ",\n\"" + CREATE_HISTORY_PARTITION + "\" = \"" + createHistoryPartition + "\"" +
-                ",\n\"" + HISTORY_PARTITION_NUM + "\" = \"" + historyPartitionNum + "\"" +
-                ",\n\"" + HOT_PARTITION_NUM + "\" = \"" + hotPartitionNum + "\"" +
-                ",\n\"" + RESERVED_HISTORY_PERIODS + "\" = \"" + reservedHistoryPeriods + "\"";
+        String res = ",\n\"" + ENABLE + "\" = \"" + enable + "\""
+                + ",\n\"" + TIME_UNIT + "\" = \"" + timeUnit + "\""
+                + ",\n\"" + TIME_ZONE + "\" = \"" + tz.getID() + "\""
+                + ",\n\"" + START + "\" = \"" + start + "\""
+                + ",\n\"" + END + "\" = \"" + end + "\""
+                + ",\n\"" + PREFIX + "\" = \"" + prefix + "\""
+                + ",\n\"" + REPLICATION_ALLOCATION + "\" = \"" + tmpAlloc.toCreateStmt() + "\""
+                + ",\n\"" + BUCKETS + "\" = \"" + buckets + "\""
+                + ",\n\"" + CREATE_HISTORY_PARTITION + "\" = \"" + createHistoryPartition + "\""
+                + ",\n\"" + HISTORY_PARTITION_NUM + "\" = \"" + historyPartitionNum + "\""
+                + ",\n\"" + HOT_PARTITION_NUM + "\" = \"" + hotPartitionNum + "\""
+                + ",\n\"" + RESERVED_HISTORY_PERIODS + "\" = \"" + reservedHistoryPeriods + "\"";
         if (getTimeUnit().equalsIgnoreCase(TimeUnit.WEEK.toString())) {
             res += ",\n\"" + START_DAY_OF_WEEK + "\" = \"" + startOfWeek.dayOfWeek + "\"";
         } else if (getTimeUnit().equalsIgnoreCase(TimeUnit.MONTH.toString())) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/EsTable.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/EsTable.java
index c1c89155d2..6981d62857 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/EsTable.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/EsTable.java
@@ -428,8 +428,8 @@ public class EsTable extends Table {
             esMetaStateTracker.run();
             this.esTablePartitions = esMetaStateTracker.searchContext().tablePartitions();
         } catch (Throwable e) {
-            LOG.warn("Exception happens when fetch index [{}] meta data from remote es cluster." +
-                    "table id: {}, err: {}", this.name, this.id, e.getMessage());
+            LOG.warn("Exception happens when fetch index [{}] meta data from remote es cluster."
+                    + "table id: {}, err: {}", this.name, this.id, e.getMessage());
             this.esTablePartitions = null;
             this.lastMetaDataSyncException = e;
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Function.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Function.java
index 49ba2b6f36..7e609c5070 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Function.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Function.java
@@ -228,10 +228,21 @@ public class Function implements Writable {
         hasVarArgs = v;
     }
 
-    public void setId(long functionId) { this.id = functionId; }
-    public long getId() { return id; }
-    public void setChecksum(String checksum) { this.checksum = checksum; }
-    public String getChecksum() { return checksum; }
+    public void setId(long functionId) {
+        this.id = functionId;
+    }
+
+    public long getId() {
+        return id;
+    }
+
+    public void setChecksum(String checksum) {
+        this.checksum = checksum;
+    }
+
+    public String getChecksum() {
+        return checksum;
+    }
 
     // TODO(cmy): Currently we judge whether it is UDF by wheter the 'location' is set.
     // Maybe we should use a separate variable to identify,
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSearchDesc.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSearchDesc.java
index d357ff25f7..3eed1ab499 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSearchDesc.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSearchDesc.java
@@ -38,9 +38,17 @@ public class FunctionSearchDesc implements Writable {
         this.isVariadic = isVariadic;
     }
 
-    public FunctionName getName() { return name; }
-    public Type[] getArgTypes() { return argTypes; }
-    public boolean isVariadic() { return isVariadic; }
+    public FunctionName getName() {
+        return name;
+    }
+
+    public Type[] getArgTypes() {
+        return argTypes;
+    }
+
+    public boolean isVariadic() {
+        return isVariadic;
+    }
 
     public boolean isIdentical(Function function) {
         if (!name.equals(function.getFunctionName())) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSet.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSet.java
index 4b94052643..63c49b2f14 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSet.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/FunctionSet.java
@@ -178,39 +178,39 @@ public class FunctionSet<T> {
                     .build();
 
     private static final Map<Type, String> MIN_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
-                .put(Type.BOOLEAN,
-                    "3minIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.TINYINT,
-                    "3minIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.SMALLINT,
-                    "3minIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.INT,
-                    "3minIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.BIGINT,
-                    "3minIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.FLOAT,
-                    "3minIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DOUBLE,
-                    "3minIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
-               // .put(Type.CHAR,
-               //     "3minIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.VARCHAR,
-                    "3minIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.STRING,
-                    "3minIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATE,
-                    "3minIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATETIME,
-                    "3minIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DECIMALV2,
-                    "3minIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.LARGEINT,
-                    "3minIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .build();
+            ImmutableMap.<Type, String>builder()
+                    .put(Type.BOOLEAN,
+                            "3minIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.TINYINT,
+                            "3minIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.SMALLINT,
+                            "3minIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.INT,
+                            "3minIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.BIGINT,
+                            "3minIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.FLOAT,
+                            "3minIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DOUBLE,
+                            "3minIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    // .put(Type.CHAR,
+                    //          "3minIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.VARCHAR,
+                            "3minIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.STRING,
+                            "3minIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATE,
+                            "3minIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATETIME,
+                            "3minIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DECIMALV2,
+                            "3minIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.LARGEINT,
+                            "3minIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .build();
 
     private static final Map<Type, String> MAX_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.BOOLEAN,
                     "3maxIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
                 .put(Type.TINYINT,
@@ -368,7 +368,7 @@ public class FunctionSet<T> {
                     .build();
 
     private static final Map<Type, String> STDDEV_INIT_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "14knuth_var_initEPN9doris_udf15FunctionContextEPNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -386,7 +386,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> STDDEV_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "16knuth_var_updateIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PNS2_9StringValE")
                 .put(Type.SMALLINT,
@@ -405,7 +405,7 @@ public class FunctionSet<T> {
 
 
     private static final Map<Type, String> STDDEV_REMOVE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "16knuth_var_removeIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PNS2_9StringValE")
                 .put(Type.SMALLINT,
@@ -422,7 +422,7 @@ public class FunctionSet<T> {
                         "16knuth_var_removeEPN9doris_udf15FunctionContextERKNS1_12DecimalV2ValEPNS1_9StringValE")
                 .build();
     private static final Map<Type, String> STDDEV_MERGE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "15knuth_var_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_")
                 .put(Type.SMALLINT,
@@ -440,7 +440,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> STDDEV_FINALIZE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "21knuth_stddev_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -458,7 +458,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> STDDEV_GET_VALUE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "22knuth_stddev_get_valueEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -494,7 +494,7 @@ public class FunctionSet<T> {
                     .build();
 
     private static final Map<Type, String> STDDEV_POP_GET_VALUE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                 "26knuth_stddev_pop_get_valueEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -512,7 +512,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> VAR_FINALIZE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "18knuth_var_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -530,7 +530,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> VAR_GET_VALUE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "19knuth_var_get_valueEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -548,7 +548,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> VAR_POP_FINALIZE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "22knuth_var_pop_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -566,7 +566,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> VAR_POP_GET_VALUE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.TINYINT,
                         "23knuth_var_pop_get_valueEPN9doris_udf15FunctionContextERKNS1_9StringValE")
                 .put(Type.SMALLINT,
@@ -586,7 +586,7 @@ public class FunctionSet<T> {
     public static final String HLL_UNION = "hll_union";
 
     private static final Map<Type, String> HLL_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.BOOLEAN,
                     "10hll_updateIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PNS2_9StringValE")
                 .put(Type.TINYINT,
@@ -619,7 +619,7 @@ public class FunctionSet<T> {
 
 
     private static final Map<Type, String> HLL_UNION_AGG_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.VARCHAR,
                         "_ZN5doris12HllFunctions9hll_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_")
                 .put(Type.STRING,
@@ -629,7 +629,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> OFFSET_FN_INIT_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.BOOLEAN,
                      "14offset_fn_initIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextEPT_")
                 .put(Type.DECIMALV2,
@@ -662,7 +662,7 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> OFFSET_FN_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
+            ImmutableMap.<Type, String>builder()
                 .put(Type.BOOLEAN,
                      "16offset_fn_updateIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_RKNS2_9BigIntValES8_PS6_")
                 .put(Type.DECIMALV2,
@@ -699,144 +699,145 @@ public class FunctionSet<T> {
                 .build();
 
     private static final Map<Type, String> LAST_VALUE_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
-                .put(Type.BOOLEAN,
-                     "15last_val_updateIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DECIMALV2,
-                     "15last_val_updateIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.TINYINT,
-                     "15last_val_updateIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.SMALLINT,
-                     "15last_val_updateIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATE,
-                     "15last_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATETIME,
-                     "15last_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.INT,
-                     "15last_val_updateIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.FLOAT,
-                     "15last_val_updateIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.BIGINT,
-                     "15last_val_updateIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DOUBLE,
-                     "15last_val_updateIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
-                // .put(Type.CHAR,
-                //     "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.VARCHAR,
-                     "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.STRING,
-                     "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.LARGEINT,
-                     "15last_val_updateIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .build();
+            ImmutableMap.<Type, String>builder()
+                    .put(Type.BOOLEAN,
+                            "15last_val_updateIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DECIMALV2,
+                            "15last_val_updateIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.TINYINT,
+                            "15last_val_updateIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.SMALLINT,
+                            "15last_val_updateIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATE,
+                            "15last_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATETIME,
+                            "15last_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.INT,
+                            "15last_val_updateIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.FLOAT,
+                             "15last_val_updateIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.BIGINT,
+                             "15last_val_updateIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DOUBLE,
+                            "15last_val_updateIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    // .put(Type.CHAR,
+                    //         "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.VARCHAR,
+                            "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.STRING,
+                            "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.LARGEINT,
+                            "15last_val_updateIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .build();
 
     private static final Map<Type, String> FIRST_VALUE_REWRITE_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
-                .put(Type.BOOLEAN,
-                     "24first_val_rewrite_updateIN9doris_udf10BooleanValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.DECIMALV2,
-                     "24first_val_rewrite_updateIN9doris_udf12DecimalV2ValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.TINYINT,
-                     "24first_val_rewrite_updateIN9doris_udf10TinyIntValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.SMALLINT,
-                     "24first_val_rewrite_updateIN9doris_udf11SmallIntValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.DATE,
-                     "24first_val_rewrite_updateIN9doris_udf11DateTimeValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.DATETIME,
-                     "24first_val_rewrite_updateIN9doris_udf11DateTimeValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.INT,
-                     "24first_val_rewrite_updateIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.FLOAT,
-                     "24first_val_rewrite_updateIN9doris_udf8FloatValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.BIGINT,
-                     "24first_val_rewrite_updateIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_RKS3_PS6_")
-                .put(Type.DOUBLE,
-                     "24first_val_rewrite_updateIN9doris_udf9DoubleValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.VARCHAR,
-                     "24first_val_rewrite_updateIN9doris_udf9StringValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.STRING,
-                     "24first_val_rewrite_updateIN9doris_udf9StringValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                .put(Type.LARGEINT,
-                     "24first_val_rewrite_updateIN9doris_udf11LargeIntValEEEvPNS2_15"
-                     + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
-                // .put(Type.VARCHAR,
-                //     "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .build();
+            ImmutableMap.<Type, String>builder()
+                    .put(Type.BOOLEAN,
+                            "24first_val_rewrite_updateIN9doris_udf10BooleanValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.DECIMALV2,
+                            "24first_val_rewrite_updateIN9doris_udf12DecimalV2ValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.TINYINT,
+                            "24first_val_rewrite_updateIN9doris_udf10TinyIntValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.SMALLINT,
+                             "24first_val_rewrite_updateIN9doris_udf11SmallIntValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.DATE,
+                            "24first_val_rewrite_updateIN9doris_udf11DateTimeValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.DATETIME,
+                            "24first_val_rewrite_updateIN9doris_udf11DateTimeValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.INT,
+                            "24first_val_rewrite_updateIN9doris_udf6IntValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.FLOAT,
+                            "24first_val_rewrite_updateIN9doris_udf8FloatValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.BIGINT,
+                            "24first_val_rewrite_updateIN9doris_udf9BigIntValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKS3_PS6_")
+                    .put(Type.DOUBLE,
+                            "24first_val_rewrite_updateIN9doris_udf9DoubleValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.VARCHAR,
+                            "24first_val_rewrite_updateIN9doris_udf9StringValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.STRING,
+                            "24first_val_rewrite_updateIN9doris_udf9StringValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    .put(Type.LARGEINT,
+                            "24first_val_rewrite_updateIN9doris_udf11LargeIntValEEEvPNS2_15"
+                                    + "FunctionContextERKT_RKNS2_9BigIntValEPS6_")
+                    // .put(Type.VARCHAR,
+                    //         "15last_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .build();
 
     private static final Map<Type, String> LAST_VALUE_REMOVE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
-                .put(Type.BOOLEAN,
-                     "15last_val_removeIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DECIMALV2,
-                     "15last_val_removeIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.TINYINT,
-                     "15last_val_removeIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.SMALLINT,
-                     "15last_val_removeIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATE,
-                     "15last_val_removeIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATETIME,
-                     "15last_val_removeIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.INT,
-                     "15last_val_removeIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.FLOAT,
-                     "15last_val_removeIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.BIGINT,
-                     "15last_val_removeIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DOUBLE,
-                     "15last_val_removeIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
-                // .put(Type.CHAR,
-                //     "15last_val_removeIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.VARCHAR,
-                     "15last_val_removeIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.STRING,
-                     "15last_val_removeIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.LARGEINT,
-                     "15last_val_removeIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .build();
+            ImmutableMap.<Type, String>builder()
+                    .put(Type.BOOLEAN,
+                            "15last_val_removeIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DECIMALV2,
+                            "15last_val_removeIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.TINYINT,
+                            "15last_val_removeIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.SMALLINT,
+                            "15last_val_removeIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATE,
+                             "15last_val_removeIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATETIME,
+                            "15last_val_removeIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.INT,
+                            "15last_val_removeIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.FLOAT,
+                            "15last_val_removeIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.BIGINT,
+                            "15last_val_removeIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DOUBLE,
+                            "15last_val_removeIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    // .put(Type.CHAR,
+                    //         "15last_val_removeIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.VARCHAR,
+                            "15last_val_removeIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.STRING,
+                            "15last_val_removeIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.LARGEINT,
+                            "15last_val_removeIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .build();
 
     private static final Map<Type, String> FIRST_VALUE_UPDATE_SYMBOL =
-        ImmutableMap.<Type, String>builder()
-                .put(Type.BOOLEAN,
-                     "16first_val_updateIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DECIMALV2,
-                     "16first_val_updateIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.TINYINT,
-                     "16first_val_updateIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.SMALLINT,
-                     "16first_val_updateIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATE,
-                     "16first_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DATETIME,
-                     "16first_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.INT,
-                     "16first_val_updateIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.FLOAT,
-                     "16first_val_updateIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.BIGINT,
-                     "16first_val_updateIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.DOUBLE,
-                     "16first_val_updateIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
-                // .put(Type.CHAR,
-                //     "16first_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.VARCHAR,
-                     "16first_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.STRING,
-                     "16first_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
-                .put(Type.LARGEINT,
-                     "16first_val_updateIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
-
-                .build();
+            ImmutableMap.<Type, String>builder()
+                    .put(Type.BOOLEAN,
+                            "16first_val_updateIN9doris_udf10BooleanValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DECIMALV2,
+                            "16first_val_updateIN9doris_udf12DecimalV2ValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.TINYINT,
+                            "16first_val_updateIN9doris_udf10TinyIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.SMALLINT,
+                            "16first_val_updateIN9doris_udf11SmallIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATE,
+                            "16first_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DATETIME,
+                            "16first_val_updateIN9doris_udf11DateTimeValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.INT,
+                            "16first_val_updateIN9doris_udf6IntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.FLOAT,
+                            "16first_val_updateIN9doris_udf8FloatValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.BIGINT,
+                            "16first_val_updateIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.DOUBLE,
+                            "16first_val_updateIN9doris_udf9DoubleValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    // .put(Type.CHAR,
+                    //         "16first_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.VARCHAR,
+                            "16first_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.STRING,
+                            "16first_val_updateIN9doris_udf9StringValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .put(Type.LARGEINT,
+                            "16first_val_updateIN9doris_udf11LargeIntValEEEvPNS2_15FunctionContextERKT_PS6_")
+                    .build();
 
     public static final String TO_BITMAP = "to_bitmap";
     public static final String BITMAP_UNION = "bitmap_union";
@@ -1200,8 +1201,8 @@ public class FunctionSet<T> {
                 || functionName.equalsIgnoreCase("least")
                 || functionName.equalsIgnoreCase("lead")
                 || functionName.equalsIgnoreCase("lag")) {
-            final ScalarType descArgType = (ScalarType)descArgTypes[0];
-            final ScalarType candicateArgType = (ScalarType)candicateArgTypes[0];
+            final ScalarType descArgType = (ScalarType) descArgTypes[0];
+            final ScalarType candicateArgType = (ScalarType) candicateArgTypes[0];
             if (!descArgType.isStringType() && candicateArgType.isStringType()) {
                 // The implementations of hex for string and int are different.
                 return false;
@@ -1301,10 +1302,10 @@ public class FunctionSet<T> {
         }
         ScalarFunction scalarFunction = (ScalarFunction) fn;
         vecFns.add(ScalarFunction.createVecBuiltin(scalarFunction.functionName(), scalarFunction.getPrepareFnSymbol(),
-                        scalarFunction.getSymbolName(), scalarFunction.getCloseFnSymbol(),
-                        Lists.newArrayList(scalarFunction.getArgs()), scalarFunction.hasVarArgs(),
-                        scalarFunction.getReturnType(), scalarFunction.isUserVisible(),
-                        scalarFunction.getNullableMode()));
+                scalarFunction.getSymbolName(), scalarFunction.getCloseFnSymbol(),
+                    Lists.newArrayList(scalarFunction.getArgs()), scalarFunction.hasVarArgs(),
+                    scalarFunction.getReturnType(), scalarFunction.isUserVisible(),
+                    scalarFunction.getNullableMode()));
     }
 
 
@@ -1326,13 +1327,13 @@ public class FunctionSet<T> {
         // Type stringType[] = {Type.CHAR, Type.VARCHAR};
         // count(*)
         addBuiltin(AggregateFunction.createBuiltin(FunctionSet.COUNT,
-            new ArrayList<Type>(), Type.BIGINT, Type.BIGINT,
-            prefix + "18init_zero_not_nullIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextEPT_",
-            prefix + "17count_star_updateEPN9doris_udf15FunctionContextEPNS1_9BigIntValE",
-            prefix + "11count_mergeEPN9doris_udf15FunctionContextERKNS1_9BigIntValEPS4_",
-            null, null,
-            prefix + "17count_star_removeEPN9doris_udf15FunctionContextEPNS1_9BigIntValE",
-            null, false, true, true));
+                new ArrayList<Type>(), Type.BIGINT, Type.BIGINT,
+                prefix + "18init_zero_not_nullIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextEPT_",
+                prefix + "17count_star_updateEPN9doris_udf15FunctionContextEPNS1_9BigIntValE",
+                prefix + "11count_mergeEPN9doris_udf15FunctionContextERKNS1_9BigIntValEPS4_",
+                null, null,
+                prefix + "17count_star_removeEPN9doris_udf15FunctionContextEPNS1_9BigIntValE",
+                null, false, true, true));
         // vectorized
         addBuiltin(AggregateFunction.createBuiltin(FunctionSet.COUNT,
                 new ArrayList<Type>(), Type.BIGINT, Type.BIGINT,
@@ -1401,29 +1402,29 @@ public class FunctionSet<T> {
 
             // count in multi distinct
             if (t.equals(Type.CHAR) || t.equals(Type.VARCHAR)) {
-               addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    Type.VARCHAR,
-                    prefix + "26count_distinct_string_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                    prefix + "28count_distinct_string_updateEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
-                    prefix + "27count_distinct_string_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
-                    prefix + "31count_distinct_string_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    null,
-                    null,
-                    prefix + "30count_distinct_string_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
+                        Type.BIGINT,
+                        Type.VARCHAR,
+                        prefix + "26count_distinct_string_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        prefix + "28count_distinct_string_updateEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
+                        prefix + "27count_distinct_string_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
+                        prefix + "31count_distinct_string_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        null,
+                        null,
+                        prefix + "30count_distinct_string_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        false, true, true));
                 // vectorized
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    Type.VARCHAR,
-                    prefix + "",
-                    prefix + "",
-                    prefix + "",
-                    prefix + "",
-                    null,
-                    null,
-                    prefix + "",
-                    false, true, true, true));
+                        Type.BIGINT,
+                        Type.VARCHAR,
+                        prefix + "",
+                        prefix + "",
+                        prefix + "",
+                        prefix + "",
+                        null,
+                        null,
+                        prefix + "",
+                        false, true, true, true));
             } else if (t.equals(Type.STRING)) {
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
                         Type.BIGINT,
@@ -1450,121 +1451,119 @@ public class FunctionSet<T> {
                         false, true, true, true));
             } else if (t.equals(Type.TINYINT) || t.equals(Type.SMALLINT) || t.equals(Type.INT)
                     || t.equals(Type.BIGINT) || t.equals(Type.LARGEINT) || t.equals(Type.DOUBLE)) {
-               addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    Type.VARCHAR,
-                    prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
-                    null,
-                    null,
-                    prefix + MULTI_DISTINCT_COUNT_FINALIZE_SYMBOL.get(t),
-                    false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
+                        Type.BIGINT,
+                        Type.VARCHAR,
+                        prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
+                        null,
+                        null,
+                        prefix + MULTI_DISTINCT_COUNT_FINALIZE_SYMBOL.get(t),
+                        false, true, true));
                 // vectorized
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    t,
-                    prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
-                    null,
-                    null,
-                    prefix + MULTI_DISTINCT_COUNT_FINALIZE_SYMBOL.get(t),
-                    false, true, true, true));
-
-
+                        Type.BIGINT,
+                        t,
+                        prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
+                        null,
+                        null,
+                        prefix + MULTI_DISTINCT_COUNT_FINALIZE_SYMBOL.get(t),
+                        false, true, true, true));
             } else if (t.equals(Type.DATE) || t.equals(Type.DATETIME)) {
-               addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    Type.VARCHAR,
-                    prefix + "24count_distinct_date_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                    prefix + "26count_distinct_date_updateEPN9doris_udf15FunctionContextERNS1_11DateTimeValEPNS1_9StringValE",
-                    prefix + "25count_distinct_date_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
-                    prefix + "29count_distinct_date_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    null,
-                    null,
-                    prefix + "28count_distinct_date_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
+                        Type.BIGINT,
+                        Type.VARCHAR,
+                        prefix + "24count_distinct_date_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        prefix + "26count_distinct_date_updateEPN9doris_udf15FunctionContextERNS1_11DateTimeValEPNS1_9StringValE",
+                        prefix + "25count_distinct_date_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
+                        prefix + "29count_distinct_date_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        null,
+                        null,
+                        prefix + "28count_distinct_date_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        false, true, true));
                 // vectorized
                 // now we don't support datetime distinct
             } else if (t.equals(Type.DECIMALV2)) {
-               addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    Type.VARCHAR,
-                    prefix + "36count_or_sum_distinct_decimalv2_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                    prefix + "38count_or_sum_distinct_decimalv2_updateEPN9doris_udf15FunctionContextERNS1_12DecimalV2ValEPNS1_9StringValE",
-                    prefix + "37count_or_sum_distinct_decimalv2_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
-                    prefix + "41count_or_sum_distinct_decimalv2_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    null,
-                    null,
-                    prefix + "33count_distinct_decimalv2_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
+                        Type.BIGINT,
+                        Type.VARCHAR,
+                        prefix + "36count_or_sum_distinct_decimalv2_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        prefix + "38count_or_sum_distinct_decimalv2_updateEPN9doris_udf15FunctionContextERNS1_12DecimalV2ValEPNS1_9StringValE",
+                        prefix + "37count_or_sum_distinct_decimalv2_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
+                        prefix + "41count_or_sum_distinct_decimalv2_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        null,
+                        null,
+                        prefix + "33count_distinct_decimalv2_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        false, true, true));
                 // vectorized
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_count", Lists.newArrayList(t),
-                    Type.BIGINT,
-                    Type.DECIMALV2,
-                    prefix + "",
-                    prefix + "",
-                    prefix + "",
-                    prefix + "",
-                    null,
-                    null,
-                    prefix + "",
-                    false, true, true, true));
+                        Type.BIGINT,
+                        Type.DECIMALV2,
+                        prefix + "",
+                        prefix + "",
+                        prefix + "",
+                        prefix + "",
+                        null,
+                        null,
+                        prefix + "",
+                        false, true, true, true));
             }
 
             // sum in multi distinct
             if (t.equals(Type.BIGINT) || t.equals(Type.LARGEINT) || t.equals(Type.DOUBLE)) {
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_sum", Lists.newArrayList(t),
-                    t,
-                    Type.VARCHAR,
-                    prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
-                    null,
-                    null,
-                    prefix + MULTI_DISTINCT_SUM_FINALIZE_SYMBOL.get(t),
-                    false, true, true));
+                        t,
+                        Type.VARCHAR,
+                        prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
+                        null,
+                        null,
+                        prefix + MULTI_DISTINCT_SUM_FINALIZE_SYMBOL.get(t),
+                        false, true, true));
 
                 // vectorized
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_sum", Lists.newArrayList(t),
-                    t,
-                    t,
-                    prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
-                    prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
-                    null,
-                    null,
-                    prefix + MULTI_DISTINCT_SUM_FINALIZE_SYMBOL.get(t),
-                    false, true, true, true));
+                        t,
+                        t,
+                        prefix + MULTI_DISTINCT_INIT_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_UPDATE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_MERGE_SYMBOL.get(t),
+                        prefix + MULTI_DISTINCT_SERIALIZE_SYMBOL.get(t),
+                        null,
+                        null,
+                        prefix + MULTI_DISTINCT_SUM_FINALIZE_SYMBOL.get(t),
+                        false, true, true, true));
             }  else if (t.equals(Type.DECIMALV2)) {
-               addBuiltin(AggregateFunction.createBuiltin("multi_distinct_sum", Lists.newArrayList(t),
-                    MULTI_DISTINCT_SUM_RETURN_TYPE.get(t),
-                    Type.VARCHAR,
-                    prefix + "36count_or_sum_distinct_decimalv2_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                    prefix + "38count_or_sum_distinct_decimalv2_updateEPN9doris_udf15FunctionContextERNS1_12DecimalV2ValEPNS1_9StringValE",
-                    prefix + "37count_or_sum_distinct_decimalv2_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
-                    prefix + "41count_or_sum_distinct_decimalv2_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    null,
-                    null,
-                    prefix + "31sum_distinct_decimalv2_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                    false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("multi_distinct_sum", Lists.newArrayList(t),
+                        MULTI_DISTINCT_SUM_RETURN_TYPE.get(t),
+                        Type.VARCHAR,
+                        prefix + "36count_or_sum_distinct_decimalv2_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        prefix + "38count_or_sum_distinct_decimalv2_updateEPN9doris_udf15FunctionContextERNS1_12DecimalV2ValEPNS1_9StringValE",
+                        prefix + "37count_or_sum_distinct_decimalv2_mergeEPN9doris_udf15FunctionContextERNS1_9StringValEPS4_",
+                        prefix + "41count_or_sum_distinct_decimalv2_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        null,
+                        null,
+                        prefix + "31sum_distinct_decimalv2_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        false, true, true));
                 // vectorized
                 addBuiltin(AggregateFunction.createBuiltin("multi_distinct_sum", Lists.newArrayList(t),
-                    MULTI_DISTINCT_SUM_RETURN_TYPE.get(t),
-                    Type.DECIMALV2,
-                    prefix + "",
-                    prefix + "",
-                    prefix + "",
-                    prefix + "",
-                    null,
-                    null,
-                    prefix + "",
-                    false, true, true, true));
+                        MULTI_DISTINCT_SUM_RETURN_TYPE.get(t),
+                        Type.DECIMALV2,
+                        prefix + "",
+                        prefix + "",
+                        prefix + "",
+                        prefix + "",
+                        null,
+                        null,
+                        prefix + "",
+                        false, true, true, true));
             }
             // Min
             String minMaxSerializeOrFinalize = t.isStringType() ? stringValSerializeOrFinalize : null;
@@ -1750,39 +1749,39 @@ public class FunctionSet<T> {
 
             // TopN
             if (TOPN_UPDATE_SYMBOL.containsKey(t)) {
-                    addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT), Type.VARCHAR,
-                                    Type.VARCHAR,
-                                    "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                                    TOPN_UPDATE_SYMBOL.get(t),
-                                    "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
-                                    "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    true, false, true));
-                    addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT, Type.INT),
-                                    Type.VARCHAR, Type.VARCHAR,
-                                    "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                                    TOPN_UPDATE_MORE_PARAM_SYMBOL.get(t),
-                                    "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
-                                    "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    true, false, true));
-                    // vectorized
-                    addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT), Type.VARCHAR,
-                                    Type.VARCHAR,
-                                    "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                                    TOPN_UPDATE_SYMBOL.get(t),
-                                    "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
-                                    "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    true, false, true, true));
-                    addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT, Type.INT),
-                                    Type.VARCHAR, Type.VARCHAR,
-                                    "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
-                                    TOPN_UPDATE_MORE_PARAM_SYMBOL.get(t),
-                                    "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
-                                    "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
-                                    true, false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT), Type.VARCHAR,
+                        Type.VARCHAR,
+                        "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        TOPN_UPDATE_SYMBOL.get(t),
+                        "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
+                        "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        true, false, true));
+                addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT, Type.INT),
+                        Type.VARCHAR, Type.VARCHAR,
+                        "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        TOPN_UPDATE_MORE_PARAM_SYMBOL.get(t),
+                        "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
+                        "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        true, false, true));
+                // vectorized
+                addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT), Type.VARCHAR,
+                        Type.VARCHAR,
+                        "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        TOPN_UPDATE_SYMBOL.get(t),
+                        "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
+                        "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        true, false, true, true));
+                addBuiltin(AggregateFunction.createBuiltin("topn", Lists.newArrayList(t, Type.INT, Type.INT),
+                        Type.VARCHAR, Type.VARCHAR,
+                        "_ZN5doris13TopNFunctions9topn_initEPN9doris_udf15FunctionContextEPNS1_9StringValE",
+                        TOPN_UPDATE_MORE_PARAM_SYMBOL.get(t),
+                        "_ZN5doris13TopNFunctions10topn_mergeEPN9doris_udf15FunctionContextERKNS1_9StringValEPS4_",
+                        "_ZN5doris13TopNFunctions14topn_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        "_ZN5doris13TopNFunctions13topn_finalizeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
+                        true, false, true, true));
             }
 
             if (STDDEV_UPDATE_SYMBOL.containsKey(t)) {
@@ -2017,7 +2016,7 @@ public class FunctionSet<T> {
                 Type.VARCHAR, Type.STRING};
         for (Type t : types) {
             addBuiltin(AggregateFunction.createBuiltin(ORTHOGONAL_BITMAP_INTERSECT,
-                    Lists.newArrayList(Type.BITMAP, t,t),
+                    Lists.newArrayList(Type.BITMAP, t, t),
                     Type.BITMAP,
                     Type.VARCHAR,
                     true,
@@ -2030,7 +2029,7 @@ public class FunctionSet<T> {
                     "_ZN5doris15BitmapFunctions16bitmap_serializeEPN9doris_udf15FunctionContextERKNS1_9StringValE",
                     true, false, true));
             addBuiltin(AggregateFunction.createBuiltin(ORTHOGONAL_BITMAP_INTERSECT_COUNT,
-                    Lists.newArrayList(Type.BITMAP, t,t),
+                    Lists.newArrayList(Type.BITMAP, t, t),
                     Type.BIGINT,
                     Type.VARCHAR,
                     true,
@@ -2342,7 +2341,7 @@ public class FunctionSet<T> {
                 prefix + "20dense_rank_get_valueEPN9doris_udf15FunctionContextERNS1_9StringValE",
                 prefix + "13rank_finalizeEPN9doris_udf15FunctionContextERNS1_9StringValE"));
         //row_number
-        addBuiltin(AggregateFunction.createAnalyticBuiltin( "row_number",
+        addBuiltin(AggregateFunction.createAnalyticBuiltin("row_number",
                 new ArrayList<Type>(), Type.BIGINT, Type.BIGINT,
                 prefix + "18init_zero_not_nullIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextEPT_",
                 prefix + "17count_star_updateEPN9doris_udf15FunctionContextEPNS1_9BigIntValE",
@@ -2366,7 +2365,7 @@ public class FunctionSet<T> {
                 prefix + "20dense_rank_get_valueEPN9doris_udf15FunctionContextERNS1_9StringValE",
                 prefix + "13rank_finalizeEPN9doris_udf15FunctionContextERNS1_9StringValE", true));
         //vec row_number
-        addBuiltin(AggregateFunction.createAnalyticBuiltin( "row_number",
+        addBuiltin(AggregateFunction.createAnalyticBuiltin("row_number",
                 new ArrayList<Type>(), Type.BIGINT, Type.BIGINT,
                 prefix + "18init_zero_not_nullIN9doris_udf9BigIntValEEEvPNS2_15FunctionContextEPT_",
                 prefix + "17count_star_updateEPN9doris_udf15FunctionContextEPNS1_9BigIntValE",
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveMetaStoreClientHelper.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveMetaStoreClientHelper.java
index 53e27dfc6c..5b11708bfd 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveMetaStoreClientHelper.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveMetaStoreClientHelper.java
@@ -550,7 +550,7 @@ public class HiveMetaStoreClientHelper {
             if (stack.size() != 1) {
                 throw new DdlException("Build Hive expression Failed: " + stack.size());
             }
-            return (ExprNodeGenericFuncDesc)stack.pop();
+            return (ExprNodeGenericFuncDesc) stack.pop();
         }
 
         public ExprBuilder pred(String name, int args) throws DdlException {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveTable.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveTable.java
index d418e47307..68fb389335 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveTable.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/HiveTable.java
@@ -104,7 +104,7 @@ public class HiveTable extends Table {
 
         if (!copiedProps.isEmpty()) {
             Iterator<Map.Entry<String, String>> iter = copiedProps.entrySet().iterator();
-            while(iter.hasNext()) {
+            while (iter.hasNext()) {
                 Map.Entry<String, String> entry = iter.next();
                 if (entry.getKey().startsWith(HIVE_HDFS_PREFIX)) {
                     hiveProperties.put(entry.getKey(), entry.getValue());
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/ListPartitionInfo.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/ListPartitionInfo.java
index 201c89d053..afa6562f86 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/ListPartitionInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/ListPartitionInfo.java
@@ -34,7 +34,7 @@ import java.util.Collections;
 import java.util.List;
 import java.util.Map;
 
-public class ListPartitionInfo extends PartitionInfo{
+public class ListPartitionInfo extends PartitionInfo {
 
     public ListPartitionInfo() {
         // for persist
@@ -60,8 +60,8 @@ public class ListPartitionInfo extends PartitionInfo{
 
         for (List<PartitionValue> values : partitionKeyDesc.getInValues()) {
             Preconditions.checkArgument(values.size() == partitionColumns.size(),
-                    "partition key desc list size[" + values.size() + "] is not equal to " +
-                            "partition column size[" + partitionColumns.size() + "]");
+                    "partition key desc list size[" + values.size() + "] is not equal to "
+                            + "partition column size[" + partitionColumns.size() + "]");
         }
         List<PartitionKey> partitionKeys = new ArrayList<>();
         try {
@@ -83,11 +83,11 @@ public class ListPartitionInfo extends PartitionInfo{
     private void checkNewPartitionKey(PartitionKey newKey, PartitionKeyDesc keyDesc, boolean isTemp) throws AnalysisException {
         Map<Long, PartitionItem> id2Item = idToItem;
         if (isTemp) {
-             id2Item = idToTempItem;
+            id2Item = idToTempItem;
         }
         // check new partition key not exists.
         for (Map.Entry<Long, PartitionItem> entry : id2Item.entrySet()) {
-            if (((ListPartitionItem)entry.getValue()).getItems().contains(newKey)) {
+            if (((ListPartitionItem) entry.getValue()).getItems().contains(newKey)) {
                 StringBuilder sb = new StringBuilder();
                 sb.append("The partition key[").append(newKey.toSql()).append("] in partition item[")
                         .append(keyDesc.toSql()).append("] is conflict with current partitionKeys[")
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/MetadataViewer.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/MetadataViewer.java
index acf6820cdb..887af28a74 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/MetadataViewer.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/MetadataViewer.java
@@ -88,7 +88,7 @@ public class MetadataViewer {
                                 status = ReplicaStatus.DEAD;
                             } else if (replica.getVersion() < visibleVersion
                                         || replica.getLastFailedVersion() > 0) {
-                                    status = ReplicaStatus.VERSION_ERROR;
+                                status = ReplicaStatus.VERSION_ERROR;
 
                             } else if (replica.getSchemaHash() != -1 && replica.getSchemaHash() != schemaHash) {
                                 status = ReplicaStatus.SCHEMA_ERROR;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcCatalogResource.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcCatalogResource.java
index e77f9ffe15..4340ff2cf9 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcCatalogResource.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcCatalogResource.java
@@ -144,7 +144,7 @@ public class OdbcCatalogResource extends Resource {
             adler32.update(type.name().getBytes(charsetName));
             LOG.debug("signature. view type: {}", type.name());
             // configs
-            for (Map.Entry<String, String> config: configs.entrySet()) {
+            for (Map.Entry<String, String> config : configs.entrySet()) {
                 adler32.update(config.getKey().getBytes(charsetName));
                 adler32.update(config.getValue().getBytes(charsetName));
                 LOG.debug("signature. view config: {}", config);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcTable.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcTable.java
index 9c69ef787f..0fa55265d5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcTable.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/OdbcTable.java
@@ -111,8 +111,8 @@ public class OdbcTable extends Table {
     private void validate(Map<String, String> properties) throws DdlException {
         if (properties == null) {
             throw new DdlException("Please set properties of odbc table, "
-                    + "they are: odbc_catalog_resource or [host, port, user, password, driver, odbc_type]" +
-                    " and database and table");
+                    + "they are: odbc_catalog_resource or [host, port, user, password, driver, odbc_type]"
+                    + " and database and table");
         }
         if (properties.containsKey(ODBC_CATALOG_RESOURCE)) {
             odbcCatalogResourceName = properties.get(ODBC_CATALOG_RESOURCE);
@@ -383,7 +383,7 @@ public class OdbcTable extends Table {
         return copied;
     }
 
-    public void resetIdsForRestore(Catalog catalog){
+    public void resetIdsForRestore(Catalog catalog) {
         id = catalog.getNextId();
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/OlapTable.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/OlapTable.java
index 064aad90e5..c7401e08ae 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/OlapTable.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/OlapTable.java
@@ -629,7 +629,7 @@ public class OlapTable extends Table {
     public KeysType getKeysTypeByIndexId(long indexId) {
         MaterializedIndexMeta indexMeta = indexIdToMeta.get(indexId);
         Preconditions.checkNotNull(indexMeta, "index id:" + indexId + " meta is null");
-         return indexMeta.getKeysType();
+        return indexMeta.getKeysType();
     }
 
     public PartitionInfo getPartitionInfo() {
@@ -704,8 +704,8 @@ public class OlapTable extends Table {
             idToPartition.remove(partition.getId());
             nameToPartition.remove(partitionName);
 
-            Preconditions.checkState(partitionInfo.getType() == PartitionType.RANGE ||
-                    partitionInfo.getType() == PartitionType.LIST);
+            Preconditions.checkState(partitionInfo.getType() == PartitionType.RANGE
+                    || partitionInfo.getType() == PartitionType.LIST);
 
             if (!isForceDrop) {
                 // recycle partition
@@ -1177,7 +1177,7 @@ public class OlapTable extends Table {
             partitionInfo = RangePartitionInfo.read(in);
         } else if (partType == PartitionType.LIST) {
             partitionInfo = ListPartitionInfo.read(in);
-        }else {
+        } else {
             throw new IOException("invalid partition type: " + partType);
         }
 
@@ -1475,7 +1475,7 @@ public class OlapTable extends Table {
 
     public Column getBaseColumn(String columnName) {
         for (Column column : getBaseSchema()) {
-            if (column.getName().equalsIgnoreCase(columnName)){
+            if (column.getName().equalsIgnoreCase(columnName)) {
                 return column;
             }
         }
@@ -1719,15 +1719,15 @@ public class OlapTable extends Table {
         if (groupingExps == null || groupingExps.isEmpty()) {
             return false;
         }
-        List<Expr> partitionExps = aggregateInfo.getPartitionExprs() != null ?
-                aggregateInfo.getPartitionExprs() : groupingExps;
+        List<Expr> partitionExps = aggregateInfo.getPartitionExprs() != null
+                ? aggregateInfo.getPartitionExprs() : groupingExps;
         DistributionInfo distribution = getDefaultDistributionInfo();
-        if(distribution instanceof HashDistributionInfo) {
+        if (distribution instanceof HashDistributionInfo) {
             List<Column> distributeColumns =
-                    ((HashDistributionInfo)distribution).getDistributionColumns();
+                    ((HashDistributionInfo) distribution).getDistributionColumns();
             PartitionInfo partitionInfo = getPartitionInfo();
             if (partitionInfo instanceof RangePartitionInfo) {
-                List<Column> rangeColumns = ((RangePartitionInfo)partitionInfo).getPartitionColumns();
+                List<Column> rangeColumns = partitionInfo.getPartitionColumns();
                 if (!distributeColumns.containsAll(rangeColumns)) {
                     return false;
                 }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionInfo.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionInfo.java
index 73cbde708e..41a37240f3 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionInfo.java
@@ -92,7 +92,7 @@ public class PartitionInfo implements Writable {
         return type;
     }
 
-    public List<Column> getPartitionColumns(){
+    public List<Column> getPartitionColumns() {
         return partitionColumns;
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionItem.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionItem.java
index f71b8c60b0..b62ece4474 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionItem.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/PartitionItem.java
@@ -22,7 +22,7 @@ import org.apache.doris.common.io.Writable;
 import java.util.Comparator;
 import java.util.Map;
 
-public abstract class PartitionItem implements Comparable<PartitionItem>,Writable {
+public abstract class PartitionItem implements Comparable<PartitionItem>, Writable {
     public static final Comparator<Map.Entry<Long, PartitionItem>> ITEM_MAP_ENTRY_COMPARATOR =
             Comparator.comparing(o -> ((ListPartitionItem) o.getValue()).getItems().iterator().next());
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/PrimitiveType.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/PrimitiveType.java
index 702e9daf37..d88369b77e 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/PrimitiveType.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/PrimitiveType.java
@@ -715,7 +715,7 @@ public enum PrimitiveType {
         return (this == DATE || this == DATETIME);
     }
 
-    public boolean isArrayType(){
+    public boolean isArrayType() {
         return this == ARRAY;
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/RangePartitionInfo.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/RangePartitionInfo.java
index 5cc4ce13bc..090c78c4e2 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/RangePartitionInfo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/RangePartitionInfo.java
@@ -82,8 +82,8 @@ public class RangePartitionInfo extends PartitionInfo {
         boolean isFixedPartitionKeyValueType = partKeyDesc.getPartitionType() == PartitionKeyDesc.PartitionKeyValueType.FIXED;
 
         // generate partitionItemEntryList
-        List<Map.Entry<Long, PartitionItem>> partitionItemEntryList = isFixedPartitionKeyValueType ?
-                        getPartitionItemEntryList(isTemp, false) : getPartitionItemEntryList(isTemp, true);
+        List<Map.Entry<Long, PartitionItem>> partitionItemEntryList = isFixedPartitionKeyValueType
+                ? getPartitionItemEntryList(isTemp, false) : getPartitionItemEntryList(isTemp, true);
 
         if (isFixedPartitionKeyValueType) {
             return createNewRangeForFixedPartitionValueType(partKeyDesc, partitionItemEntryList);
@@ -137,10 +137,9 @@ public class RangePartitionInfo extends PartitionInfo {
     }
 
     private Range<PartitionKey> createNewRangeForLessThanPartitionValueType(PartitionKey newRangeUpper,
-                                                                            Range<PartitionKey> lastRange, Range<PartitionKey> currentRange)
-            throws AnalysisException, DdlException {
-        PartitionKey lowKey = lastRange == null ?
-                PartitionKey.createInfinityPartitionKey(partitionColumns, false) : lastRange.upperEndpoint();
+            Range<PartitionKey> lastRange, Range<PartitionKey> currentRange) throws AnalysisException, DdlException {
+        PartitionKey lowKey = lastRange == null ? PartitionKey.createInfinityPartitionKey(partitionColumns, false)
+                : lastRange.upperEndpoint();
 
         // check: [left, right), error if left equal right
         if (lowKey.compareTo(newRangeUpper) >= 0) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarFunction.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarFunction.java
index 299160cc43..c87fd65481 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarFunction.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarFunction.java
@@ -271,16 +271,6 @@ public class ScalarFunction extends Function {
                 new FunctionName(name), argTypes, retType, hasVarArgs, userVisible);
         fn.symbolName = symbol;
         fn.nullableMode = nullableMode;
-
-//        try {
-//            fn.symbolName_ = fn.lookupSymbol(symbol, TSymbolType.UDF_EVALUATE, null,
-//                    fn.hasVarArgs(), fn.getArgs());
-//        } catch (AnalysisException e) {
-//            // This should never happen
-//            Preconditions.checkState(false, "Builtin symbol '" + symbol + "'" + argTypes
-//                    + " not found!" + e.getStackTrace());
-//            throw new RuntimeException("Builtin symbol not found!", e);
-//        }
         return fn;
     }
 
@@ -333,13 +323,29 @@ public class ScalarFunction extends Function {
         return fn;
     }
 
-    public void setSymbolName(String s) { symbolName = s; }
-    public void setPrepareFnSymbol(String s) { prepareFnSymbol = s; }
-    public void setCloseFnSymbol(String s) { closeFnSymbol = s; }
+    public void setSymbolName(String s) {
+        symbolName = s;
+    }
+
+    public void setPrepareFnSymbol(String s) {
+        prepareFnSymbol = s;
+    }
+
+    public void setCloseFnSymbol(String s) {
+        closeFnSymbol = s;
+    }
 
-    public String getSymbolName() { return symbolName; }
-    public String getPrepareFnSymbol() { return prepareFnSymbol; }
-    public String getCloseFnSymbol() { return closeFnSymbol; }
+    public String getSymbolName() {
+        return symbolName;
+    }
+
+    public String getPrepareFnSymbol() {
+        return prepareFnSymbol;
+    }
+
+    public String getCloseFnSymbol() {
+        return closeFnSymbol;
+    }
 
     @Override
     public String toSql(boolean ifNotExists) {
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarType.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarType.java
index f21798d51d..bb9a7a9520 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarType.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/ScalarType.java
@@ -414,7 +414,7 @@ public class ScalarType extends Type {
         TScalarType scalarType = new TScalarType();
         scalarType.setType(type.toThrift());
 
-        switch(type) {
+        switch (type) {
             case VARCHAR:
             case CHAR:
             case HLL:
@@ -444,18 +444,39 @@ public class ScalarType extends Type {
     }
 
     @Override
-    public PrimitiveType getPrimitiveType() { return type; }
-    public int ordinal() { return type.ordinal(); }
+    public PrimitiveType getPrimitiveType() {
+        return type;
+    }
+
+    public int ordinal() {
+        return type.ordinal();
+    }
 
     @Override
-    public int getLength() { return len; }
-    public void setLength(int len) {this.len = len; }
-    public boolean isAssignedStrLenInColDefinition() { return isAssignedStrLenInColDefinition; }
-    public void setAssignedStrLenInColDefinition() { this.isAssignedStrLenInColDefinition = true; }
+    public int getLength() {
+        return len;
+    }
+
+    public void setLength(int len) {
+        this.len = len;
+    }
+
+    public boolean isAssignedStrLenInColDefinition() {
+        return isAssignedStrLenInColDefinition;
+    }
+
+    public void setAssignedStrLenInColDefinition() {
+        this.isAssignedStrLenInColDefinition = true;
+    }
 
     // add scalar infix to override with getPrecision
-    public int getScalarScale() { return scale; }
-    public int getScalarPrecision() { return precision; }
+    public int getScalarScale() {
+        return scale;
+    }
+
+    public int getScalarPrecision() {
+        return precision;
+    }
 
     public String getScalarPrecisionStr() {
         return precisionStr;
@@ -561,7 +582,7 @@ public class ScalarType extends Type {
         if (!(o instanceof ScalarType)) {
             return false;
         }
-        ScalarType other = (ScalarType)o;
+        ScalarType other = (ScalarType) o;
         if (type != other.type) {
             return false;
         }
@@ -571,7 +592,7 @@ public class ScalarType extends Type {
         if (type == PrimitiveType.VARCHAR) {
             return len == other.len;
         }
-        if ( type == PrimitiveType.DECIMALV2) {
+        if (type == PrimitiveType.DECIMALV2) {
             return precision == other.precision && scale == other.scale;
         }
         return true;
@@ -588,7 +609,7 @@ public class ScalarType extends Type {
         } else if (isDecimalV2()) {
             return createDecimalV2TypeInternal(MAX_PRECISION, scale);
         } else if (isLargeIntType()) {
-        return ScalarType.LARGEINT;
+            return ScalarType.LARGEINT;
         } else {
             return ScalarType.INVALID;
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/SchemaTable.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/SchemaTable.java
index c1b8ff513f..a774ed7c15 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/SchemaTable.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/SchemaTable.java
@@ -67,7 +67,7 @@ public class SchemaTable extends Table {
     // like 'show table where_clause'. If we decide to support it, we must mock these related table here.
     public static Map<String, Table> TABLE_MAP =
             ImmutableMap
-                    .<String, Table> builder()
+                    .<String, Table>builder()
                     .put("tables", new SchemaTable(
                             SystemIdGenerator.getNextId(),
                             "tables",
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Table.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Table.java
index e7b2ed43a4..df70948dcd 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Table.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Table.java
@@ -180,7 +180,7 @@ public class Table extends MetaObject implements Writable {
 
     public boolean tryWriteLock(long timeout, TimeUnit unit) {
         try {
-           return this.rwLock.writeLock().tryLock(timeout, unit);
+            return this.rwLock.writeLock().tryLock(timeout, unit);
         } catch (InterruptedException e) {
             LOG.warn("failed to try write lock at table[" + name + "]", e);
             return false;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Tablet.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Tablet.java
index c1d3f5e2cf..c96c59e1c7 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Tablet.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Tablet.java
@@ -240,9 +240,9 @@ public class Tablet extends MetaObject implements Writable {
                 }
             }
             final long finalMinVersionCount = minVersionCount;
-            return allQueryableReplica.stream().filter(replica -> replica.getVersionCount() == -1 ||
-                            replica.getVersionCount() < Config.min_version_count_indicate_replica_compaction_too_slow ||
-                            replica.getVersionCount() < finalMinVersionCount * QUERYABLE_TIMES_OF_MIN_VERSION_COUNT)
+            return allQueryableReplica.stream().filter(replica -> replica.getVersionCount() == -1
+                            || replica.getVersionCount() < Config.min_version_count_indicate_replica_compaction_too_slow
+                            || replica.getVersionCount() < finalMinVersionCount * QUERYABLE_TIMES_OF_MIN_VERSION_COUNT)
                     .collect(Collectors.toList());
         }
         return allQueryableReplica;
@@ -544,8 +544,8 @@ public class Tablet extends MetaObject implements Writable {
             // get the max version diff
             long delta = versions.get(versions.size() - 1) - versions.get(0);
             double ratio = (double) delta / versions.get(versions.size() - 1);
-            if (versions.get(versions.size() - 1) > Config.min_version_count_indicate_replica_compaction_too_slow &&
-                    ratio > Config.valid_version_count_delta_ratio_between_replicas) {
+            if (versions.get(versions.size() - 1) > Config.min_version_count_indicate_replica_compaction_too_slow
+                    && ratio > Config.valid_version_count_delta_ratio_between_replicas) {
                 return Pair.create(TabletStatus.REPLICA_COMPACTION_TOO_SLOW, Priority.HIGH);
             }
         }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java
index ff37661e7d..1d843226f8 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/TabletInvertedIndex.java
@@ -154,8 +154,8 @@ public class TabletInvertedIndex {
 
                         // check and set path
                         // path info of replica is only saved in Master FE
-                        if (backendTabletInfo.isSetPathHash() &&
-                                replica.getPathHash() != backendTabletInfo.getPathHash()) {
+                        if (backendTabletInfo.isSetPathHash()
+                                && replica.getPathHash() != backendTabletInfo.getPathHash()) {
                             replica.setPathHash(backendTabletInfo.getPathHash());
                         }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java
index 2a522baa3a..0ffbcdd37a 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/Type.java
@@ -143,7 +143,9 @@ public abstract class Type {
      * The output of this is stored directly in the hive metastore as the column type.
      * The string must match exactly.
      */
-    public final String toSql() { return toSql(0); }
+    public final String toSql() {
+        return toSql(0);
+    }
 
     /**
      * Recursive helper for toSql() to be implemented by subclasses. Keeps track of the
@@ -154,7 +156,9 @@ public abstract class Type {
     /**
      * Same as toSql() but adds newlines and spaces for better readability of nested types.
      */
-    public String prettyPrint() { return prettyPrint(0); }
+    public String prettyPrint() {
+        return prettyPrint(0);
+    }
 
     /**
      * Pretty prints this type with lpad number of leading spaces. Used to implement
@@ -182,9 +186,17 @@ public abstract class Type {
         return isScalarType(PrimitiveType.DECIMALV2);
     }
 
-    public boolean isWildcardDecimal() { return false; }
-    public boolean isWildcardVarchar() { return false; }
-    public boolean isWildcardChar() { return false; }
+    public boolean isWildcardDecimal() {
+        return false;
+    }
+
+    public boolean isWildcardVarchar() {
+        return false;
+    }
+
+    public boolean isWildcardChar() {
+        return false;
+    }
 
     public boolean isStringType() {
         return isScalarType(PrimitiveType.VARCHAR)
@@ -208,8 +220,8 @@ public abstract class Type {
     }
 
     public static final String OnlyMetricTypeErrorMsg =
-            "Doris hll and bitmap column must use with specific function, and don't support filter or group by." +
-                    "please run 'help hll' or 'help bitmap' in your mysql client.";
+            "Doris hll and bitmap column must use with specific function, and don't support filter or group by."
+                    + "please run 'help hll' or 'help bitmap' in your mysql client.";
 
     public boolean isHllType() {
         return isScalarType(PrimitiveType.HLL);
@@ -219,7 +231,9 @@ public abstract class Type {
         return isScalarType(PrimitiveType.BITMAP);
     }
 
-    public boolean isQuantileStateType() { return isScalarType(PrimitiveType.QUANTILE_STATE); }
+    public boolean isQuantileStateType() {
+        return isScalarType(PrimitiveType.QUANTILE_STATE);
+    }
 
     public boolean isObjectStored() {
         return isHllType() || isBitmapType() || isQuantileStateType();
@@ -234,9 +248,9 @@ public abstract class Type {
     }
 
     public boolean isFixedPointType() {
-        return isScalarType(PrimitiveType.TINYINT) || isScalarType(PrimitiveType.SMALLINT) ||
-                isScalarType(PrimitiveType.INT) || isScalarType(PrimitiveType.BIGINT) ||
-                isScalarType(PrimitiveType.LARGEINT);
+        return isScalarType(PrimitiveType.TINYINT) || isScalarType(PrimitiveType.SMALLINT)
+                || isScalarType(PrimitiveType.INT) || isScalarType(PrimitiveType.BIGINT)
+                || isScalarType(PrimitiveType.LARGEINT);
     }
 
     public boolean isFloatingPointType() {
@@ -318,7 +332,9 @@ public abstract class Type {
         return true;
     }
 
-    public int getLength() { return -1; }
+    public int getLength() {
+        return -1;
+    }
 
     /**
      * Indicates whether we support partitioning tables on columns of this type.
@@ -402,7 +418,7 @@ public abstract class Type {
         if (t1.isScalarType() && t2.isScalarType()) {
             return ScalarType.canCastTo((ScalarType) t1, (ScalarType) t2);
         } else if (t1.isArrayType() && t2.isArrayType()) {
-            return ArrayType.canCastTo((ArrayType)t1, (ArrayType)t2);
+            return ArrayType.canCastTo((ArrayType) t1, (ArrayType) t2);
         }
         return t1.isNull() || t1.getPrimitiveType() == PrimitiveType.VARCHAR;
     }
@@ -450,9 +466,9 @@ public abstract class Type {
      * Returns null if this expr is not instance of StringLiteral or StringLiteral
      * inner value could not parse to long. otherwise return parsed Long result.
      */
-    public static Long tryParseToLong(Expr expectStringExpr){
+    public static Long tryParseToLong(Expr expectStringExpr) {
         if (expectStringExpr instanceof StringLiteral) {
-            String value = ((StringLiteral)expectStringExpr).getValue();
+            String value = ((StringLiteral) expectStringExpr).getValue();
             return Longs.tryParse(value);
         }
         return null;
@@ -506,7 +522,7 @@ public abstract class Type {
 
     // TODO(dhc): fix this
     public static Type fromPrimitiveType(PrimitiveType type) {
-        switch(type) {
+        switch (type) {
             case BOOLEAN:
                 return Type.BOOLEAN;
             case TINYINT:
@@ -559,7 +575,7 @@ public abstract class Type {
 
     public static List<TTypeDesc> toThrift(ArrayList<Type> types) {
         ArrayList<TTypeDesc> result = Lists.newArrayList();
-        for (Type t: types) {
+        for (Type t : types) {
             result.add(t.toThrift());
         }
         return result;
@@ -968,7 +984,7 @@ public abstract class Type {
 
         // DOUBLE
         compatibilityMatrix[DOUBLE.ordinal()][DATE.ordinal()] = PrimitiveType.INVALID_TYPE;
-        compatibilityMatrix[DOUBLE.ordinal()][DATETIME.ordinal()] = PrimitiveType.DOUBLE ;
+        compatibilityMatrix[DOUBLE.ordinal()][DATETIME.ordinal()] = PrimitiveType.DOUBLE;
         compatibilityMatrix[DOUBLE.ordinal()][CHAR.ordinal()] = PrimitiveType.INVALID_TYPE;
         compatibilityMatrix[DOUBLE.ordinal()][VARCHAR.ordinal()] = PrimitiveType.INVALID_TYPE;
         compatibilityMatrix[DOUBLE.ordinal()][DECIMALV2.ordinal()] = PrimitiveType.INVALID_TYPE;
@@ -1141,8 +1157,8 @@ public abstract class Type {
         }
 
         // int family type and char family type should cast to char family type
-        if ((t1ResultType.isFixedPointType() && t2ResultType.isCharFamily()) ||
-                (t2ResultType.isFixedPointType() && t1ResultType.isCharFamily())) {
+        if ((t1ResultType.isFixedPointType() && t2ResultType.isCharFamily())
+                || (t2ResultType.isFixedPointType() && t1ResultType.isCharFamily())) {
             return t1.isStringType() ?  t1 : t2;
         }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/catalog/View.java b/fe/fe-core/src/main/java/org/apache/doris/catalog/View.java
index c842776257..26966ebe63 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/catalog/View.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/catalog/View.java
@@ -178,8 +178,8 @@ public class View extends Table {
         }
         // Make sure the view definition parses to a query statement.
         if (!(node instanceof QueryStmt)) {
-            throw new UserException(String.format("View definition of %s " +
-                    "is not a query statement", name));
+            throw new UserException(String.format("View definition of %s "
+                    + "is not a query statement", name));
         }
         queryStmtRef = new SoftReference<QueryStmt>((QueryStmt) node);
         return (QueryStmt) node;
@@ -188,7 +188,9 @@ public class View extends Table {
     /**
      * Returns the column labels the user specified in the WITH-clause.
      */
-    public List<String> getOriginalColLabels() { return colLabels; }
+    public List<String> getOriginalColLabels() {
+        return colLabels;
+    }
 
     /**
      * Returns the explicit column labels for this view, or null if they need to be derived
@@ -240,7 +242,7 @@ public class View extends Table {
         return copied;
     }
 
-    public void resetIdsForRestore(Catalog catalog){
+    public void resetIdsForRestore(Catalog catalog) {
         id = catalog.getNextId();
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/BackendLoadStatistic.java b/fe/fe-core/src/main/java/org/apache/doris/clone/BackendLoadStatistic.java
index 69474e57fc..bcc5edcab9 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/BackendLoadStatistic.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/BackendLoadStatistic.java
@@ -314,7 +314,7 @@ public class BackendLoadStatistic {
         return status;
     }
 
-     /*
+    /**
      * Check whether the backend can be more balance if we migrate a tablet with size 'tabletSize' from
      * `srcPath` to 'destPath'
      * 1. recalculate the load score of src and dest path after migrate the tablet.
@@ -345,17 +345,17 @@ public class BackendLoadStatistic {
         }
         double avgUsedPercent = totalCapacity == 0 ? 0.0 : totalUsedCapacity / (double) totalCapacity;
         double currentSrcPathScore = srcPathStat.getCapacityB() == 0
-            ? 0.0 : srcPathStat.getUsedCapacityB() / (double) srcPathStat.getCapacityB();
+                ? 0.0 : srcPathStat.getUsedCapacityB() / (double) srcPathStat.getCapacityB();
         double currentDestPathScore = destPathStat.getCapacityB() == 0
-            ? 0.0 : destPathStat.getUsedCapacityB() / (double) destPathStat.getCapacityB();
+                ? 0.0 : destPathStat.getUsedCapacityB() / (double) destPathStat.getCapacityB();
 
         double newSrcPathScore = srcPathStat.getCapacityB() == 0
-            ? 0.0 : (srcPathStat.getUsedCapacityB() - tabletSize) / (double) srcPathStat.getCapacityB();
+                ? 0.0 : (srcPathStat.getUsedCapacityB() - tabletSize) / (double) srcPathStat.getCapacityB();
         double newDestPathScore = destPathStat.getCapacityB() == 0
-            ? 0.0 : (destPathStat.getUsedCapacityB() + tabletSize) / (double) destPathStat.getCapacityB();
+                ? 0.0 : (destPathStat.getUsedCapacityB() + tabletSize) / (double) destPathStat.getCapacityB();
 
         double currentDiff = Math.abs(currentSrcPathScore - avgUsedPercent)
-            + Math.abs(currentDestPathScore - avgUsedPercent);
+                + Math.abs(currentDestPathScore - avgUsedPercent);
         double newDiff = Math.abs(newSrcPathScore - avgUsedPercent) + Math.abs(newDestPathScore - avgUsedPercent);
 
         LOG.debug("after migrate {}(size: {}) from {} to {}, medium: {}, the load score changed."
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/ColocateTableCheckerAndBalancer.java b/fe/fe-core/src/main/java/org/apache/doris/clone/ColocateTableCheckerAndBalancer.java
index 0bc2239579..111f8d0aa7 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/ColocateTableCheckerAndBalancer.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/ColocateTableCheckerAndBalancer.java
@@ -449,8 +449,8 @@ public class ColocateTableCheckerAndBalancer extends MasterDaemon {
             if (!isThisRoundChanged) {
                 // if all backends are checked but this round is not changed,
                 // we should end the loop
-                LOG.info("all backends are checked but this round is not changed, " +
-                        "end outer loop in colocate group {}", groupId);
+                LOG.info("all backends are checked but this round is not changed, "
+                        + "end outer loop in colocate group {}", groupId);
                 break;
             }
             // end inner loop
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/DynamicPartitionScheduler.java b/fe/fe-core/src/main/java/org/apache/doris/clone/DynamicPartitionScheduler.java
index 4728803fc7..0aec8f21f0 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/DynamicPartitionScheduler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/DynamicPartitionScheduler.java
@@ -336,7 +336,7 @@ public class DynamicPartitionScheduler extends MasterDaemon {
         for (Long dropPartitionId : isContaineds.keySet()) {
             // Do not drop the partition "by force", or the partition will be dropped directly instread of being in
             // catalog recycle bin. This is for safe reason.
-            if(!isContaineds.get(dropPartitionId)) {
+            if (!isContaineds.get(dropPartitionId)) {
                 String dropPartitionName = olapTable.getPartition(dropPartitionId).getName();
                 dropPartitionClauses.add(new DropPartitionClause(false, dropPartitionName, false, false));
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/PartitionRebalancer.java b/fe/fe-core/src/main/java/org/apache/doris/clone/PartitionRebalancer.java
index 0962afd9e6..406bf53bb5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/PartitionRebalancer.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/PartitionRebalancer.java
@@ -322,11 +322,11 @@ public class PartitionRebalancer extends Rebalancer {
 
         @Override
         public String toString() {
-            return "ReplicaMove{" +
-                    "tabletId=" + tabletId +
-                    ", fromBe=" + fromBe +
-                    ", toBe=" + toBe +
-                    '}';
+            return "ReplicaMove{"
+                    + "tabletId=" + tabletId
+                    + ", fromBe=" + fromBe
+                    + ", toBe=" + toBe
+                    + '}';
         }
     }
 
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/TabletChecker.java b/fe/fe-core/src/main/java/org/apache/doris/clone/TabletChecker.java
index d51cae0fe4..121a8de8b5 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/TabletChecker.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/TabletChecker.java
@@ -69,13 +69,15 @@ public class TabletChecker extends MasterDaemon {
     private TabletScheduler tabletScheduler;
     private TabletSchedulerStat stat;
 
-    HashMap<String, AtomicLong> tabletCountByStatus = new HashMap<String, AtomicLong>() {{
-        put("total", new AtomicLong(0L));
-        put("unhealthy", new AtomicLong(0L));
-        put("added", new AtomicLong(0L));
-        put("in_sched", new AtomicLong(0L));
-        put("not_ready", new AtomicLong(0L));
-    }};
+    HashMap<String, AtomicLong> tabletCountByStatus = new HashMap<String, AtomicLong>() {
+        {
+            put("total", new AtomicLong(0L));
+            put("unhealthy", new AtomicLong(0L));
+            put("added", new AtomicLong(0L));
+            put("in_sched", new AtomicLong(0L));
+            put("not_ready", new AtomicLong(0L));
+        }
+    };
 
     // db id -> (tbl id -> PrioPart)
     // priority of replicas of partitions in this table will be set to VERY_HIGH if not healthy
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/TabletSchedCtx.java b/fe/fe-core/src/main/java/org/apache/doris/clone/TabletSchedCtx.java
index e228ee9cb9..6bc3947cc8 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/TabletSchedCtx.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/TabletSchedCtx.java
@@ -695,8 +695,9 @@ public class TabletSchedCtx implements Comparable<TabletSchedCtx> {
             // forever, because the replica in the DECOMMISSION state will not receive the load task.
             chosenReplica.setWatermarkTxnId(-1);
             chosenReplica.setState(ReplicaState.NORMAL);
-            LOG.info("choose replica {} on backend {} of tablet {} as dest replica for version incomplete," +
-                    " and change state from DECOMMISSION to NORMAL", chosenReplica.getId(), chosenReplica.getBackendId(), tabletId);
+            LOG.info("choose replica {} on backend {} of tablet {} as dest replica for version incomplete,"
+                    + " and change state from DECOMMISSION to NORMAL",
+                    chosenReplica.getId(), chosenReplica.getBackendId(), tabletId);
         }
         setDest(chosenReplica.getBackendId(), chosenReplica.getPathHash());
     }
@@ -1074,7 +1075,7 @@ public class TabletSchedCtx implements Comparable<TabletSchedCtx> {
             failedSchedCounter = 0;
             if (originDynamicPriority != dynamicPriority) {
                 LOG.debug("downgrade dynamic priority from {} to {}, origin: {}, tablet: {}",
-                    originDynamicPriority.name(), dynamicPriority.name(), origPriority.name(), tabletId);
+                        originDynamicPriority.name(), dynamicPriority.name(), origPriority.name(), tabletId);
                 stat.counterTabletPrioDowngraded.incrementAndGet();
                 return true;
             }
@@ -1083,7 +1084,7 @@ public class TabletSchedCtx implements Comparable<TabletSchedCtx> {
             // no need to set lastSchedTime, lastSchedTime is set each time we schedule this tablet
             if (originDynamicPriority != dynamicPriority) {
                 LOG.debug("upgrade dynamic priority from {} to {}, origin: {}, tablet: {}",
-                    originDynamicPriority.name(), dynamicPriority.name(), origPriority.name(), tabletId);
+                        originDynamicPriority.name(), dynamicPriority.name(), origPriority.name(), tabletId);
                 stat.counterTabletPrioUpgraded.incrementAndGet();
                 return true;
             }
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/TabletScheduler.java b/fe/fe-core/src/main/java/org/apache/doris/clone/TabletScheduler.java
index a6c09ef048..6b84a432ed 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/TabletScheduler.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/TabletScheduler.java
@@ -545,13 +545,14 @@ public class TabletScheduler extends MasterDaemon {
                 try {
                     DatabaseTransactionMgr dbTransactionMgr = Catalog.getCurrentGlobalTransactionMgr().getDatabaseTransactionMgr(db.getId());
                     for (TransactionState transactionState : dbTransactionMgr.getPreCommittedTxnList()) {
-                        if(transactionState.getTableIdList().contains(tbl.getId())) {
+                        if (transactionState.getTableIdList().contains(tbl.getId())) {
                             // If table releate to transaction with precommitted status, do not allow to do balance.
                             throw new SchedException(Status.UNRECOVERABLE,
                                     "There exists PRECOMMITTED transaction related to table");
                         }
                     }
                 } catch (AnalysisException e) {
+                    // CHECKSTYLE IGNORE THIS LINE
                 }
             }
 
@@ -578,8 +579,8 @@ public class TabletScheduler extends MasterDaemon {
             }
 
             // for disk balance more accurately, we only schedule tablet when has lastly stat info about disk
-            if (tabletCtx.getType() == TabletSchedCtx.Type.BALANCE &&
-                   tabletCtx.getBalanceType() == TabletSchedCtx.BalanceType.DISK_BALANCE) {
+            if (tabletCtx.getType() == TabletSchedCtx.Type.BALANCE
+                    && tabletCtx.getBalanceType() == TabletSchedCtx.BalanceType.DISK_BALANCE) {
                 checkDiskBalanceLastSuccTime(tabletCtx.getTempSrcBackendId(), tabletCtx.getTempSrcPathHash());
             }
             // we do not concern priority here.
diff --git a/fe/fe-core/src/main/java/org/apache/doris/clone/TwoDimensionalGreedyRebalanceAlgo.java b/fe/fe-core/src/main/java/org/apache/doris/clone/TwoDimensionalGreedyRebalanceAlgo.java
index 3590246355..6dcb401f43 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/clone/TwoDimensionalGreedyRebalanceAlgo.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/clone/TwoDimensionalGreedyRebalanceAlgo.java
@@ -74,10 +74,10 @@ public class TwoDimensionalGreedyRebalanceAlgo {
                 return false;
             }
             PartitionMove that = (PartitionMove) o;
-            return Objects.equal(partitionId, that.partitionId) &&
-                    Objects.equal(indexId, that.indexId) &&
-                    Objects.equal(fromBe, that.fromBe) &&
-                    Objects.equal(toBe, that.toBe);
+            return Objects.equal(partitionId, that.partitionId)
+                    && Objects.equal(indexId, that.indexId)
+                    && Objects.equal(fromBe, that.fromBe)
+                    && Objects.equal(toBe, that.toBe);
         }
 
         @Override
@@ -87,11 +87,11 @@ public class TwoDimensionalGreedyRebalanceAlgo {
 
         @Override
         public String toString() {
-            return "ReplicaMove{" +
-                    "pid=" + partitionId + "-" + indexId +
-                    ", from=" + fromBe +
-                    ", to=" + toBe +
-                    '}';
+            return "ReplicaMove{"
+                    + "pid=" + partitionId + "-" + indexId
+                    + ", from=" + fromBe
+                    + ", to=" + toBe
+                    + '}';
         }
     }
 
@@ -189,8 +189,8 @@ public class TwoDimensionalGreedyRebalanceAlgo {
         // improves cluster skew.
         NavigableSet<PartitionBalanceInfo> maxSet = skewMap.get(maxPartitionSkew);
         for (PartitionBalanceInfo pbi : maxSet) {
-            Preconditions.checkArgument(!pbi.beByReplicaCount.isEmpty(), "no information on replicas of " +
-                    "partition " + pbi.partitionId + "-" + pbi.indexId);
+            Preconditions.checkArgument(!pbi.beByReplicaCount.isEmpty(), "no information on replicas of "
+                    + "partition " + pbi.partitionId + "-" + pbi.indexId);
 
             Long minReplicaCount = pbi.beByReplicaCount.keySet().first();
             Long maxReplicaCount = pbi.beByReplicaCount.keySet().last();
@@ -216,7 +216,8 @@ public class TwoDimensionalGreedyRebalanceAlgo {
                 continue;
             }
 
-            Long minLoadedBe, maxLoadedBe;
+            Long minLoadedBe;
+            Long maxLoadedBe;
             if (equalSkewOption == EqualSkewOption.PICK_FIRST) {
                 // beWithExtremumCount lists & intersection lists are natural ordering
                 minLoadedBe = minLoaded.intersection.isEmpty() ? minLoaded.beWithExtremumCount.get(0) : minLoaded.intersection.get(0);
diff --git a/fe/fe-core/src/main/java/org/apache/doris/common/CIDR.java b/fe/fe-core/src/main/java/org/apache/doris/common/CIDR.java
index dbe2692fc8..4cef7be025 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/common/CIDR.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/common/CIDR.java
@@ -56,7 +56,7 @@ public class CIDR {
     // Specify IP in CIDR format like: new IPv4("192.168.0.8/16");
     public CIDR(String cidrNotation) {
         // if there is no mask, fill "/32" as suffix
-        if(cidrNotation.indexOf("/") == -1) {
+        if (!cidrNotation.contains("/")) {
             cidrNotation += "/32";
         }
 
@@ -78,7 +78,7 @@ public class CIDR {
         return contains(toInteger(address));
     }
 
-     // Get the IP in symbolic form, i.e. xxx.xxx.xxx.xxx
+    // Get the IP in symbolic form, i.e. xxx.xxx.xxx.xxx
     public String getIP() {
         return format(address);
     }
@@ -101,7 +101,7 @@ public class CIDR {
         return sb.toString();
     }
 
-     // Get the IP and netmask in CIDR form, i.e. xxx.xxx.xxx.xxx/xx
+    // Get the IP and netmask in CIDR form, i.e. xxx.xxx.xxx.xxx/xx
     public String getCIDR() {
         int numberOfBits = maskBitNumMap.get(netmask);
         return format(address & netmask) + "/" + numberOfBits;
@@ -150,7 +150,7 @@ public class CIDR {
         return network & UNSIGNED_INT_MASK;
     }
 
-    private long broadcastLong(){
+    private long broadcastLong() {
         long network = (address & netmask);
         long broadcast = network | ~(netmask);
         return broadcast & UNSIGNED_INT_MASK;
diff --git a/fe/fe-core/src/main/java/org/apache/doris/common/ConfigBase.java b/fe/fe-core/src/main/java/org/apache/doris/common/ConfigBase.java
index bad29927a7..213e8f5907 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/common/ConfigBase.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/common/ConfigBase.java
@@ -61,7 +61,7 @@ public class ConfigBase {
 
     static class DefaultConfHandler implements ConfHandler {
         @Override
-        public void handle(Field field, String confVal) throws Exception{
+        public void handle(Field field, String confVal) throws Exception {
             setConfigField(field, confVal);
         }
     }
@@ -299,7 +299,7 @@ public class ConfigBase {
         if (!anno.mutable()) {
             throw new DdlException("Config '" + key + "' is not mutable");
         }
-        if (anno.masterOnly() && !Catalog.getCurrentCatalog().isMaster()){
+        if (anno.masterOnly() && !Catalog.getCurrentCatalog().isMaster()) {
             throw new DdlException("Config '" + key + "' is master only");
         }
 
@@ -347,7 +347,7 @@ public class ConfigBase {
         File file = new File(customConfFile);
         if (!file.exists()) {
             file.createNewFile();
-        } else if (resetPersist){
+        } else if (resetPersist) {
             // clear the customConfFile content
             try (PrintWriter writer = new PrintWriter(file)) {
                 writer.print("");
diff --git a/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java b/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java
index 39b705fa64..a1ae7c0f5f 100644
--- a/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java
+++ b/fe/fe-core/src/main/java/org/apache/doris/common/ErrorCode.java
@@ -45,8 +45,8 @@ public enum ErrorCode {
     ERR_CANT_READ_DIR(1018, new byte[]{'H', 'Y', '0', '0', '0'}, "Can't read dir of '%s' (errno: %d)"),
     ERR_CANT_SET_WD(1019, new byte[]{'H', 'Y', '0', '0', '0'}, "Can't change dir to '%s' (errno: %d)"),
     ERR_CHECKREAD(1020, new byte[]{'H', 'Y', '0', '0', '0'}, "Record has changed since last read in table '%s'"),
-    ERR_DISK_FULL(1021, new byte[]{'H', 'Y', '0', '0', '0'}, "Disk full (%s); waiting for someone to free some space." +
-            ".."),
+    ERR_DISK_FULL(1021, new byte[]{'H', 'Y', '0', '0', '0'}, "Disk full (%s); waiting for someone to free some space."
+            + ".."),
     ERR_DUP_KEY(1022, new byte[]{'2', '3', '0', '0', '0'}, "Can't write; duplicate key in table '%s'"),
     ERR_ERROR_ON_CLOSE(1023, new byte[]{'H', 'Y', '0', '0', '0'}, "Error on close of '%s' (errno: %d)"),
     ERR_ERROR_ON_READ(1024, new byte[]{'H', 'Y', '0', '0', '0'}, "Error reading file '%s' (errno: %d)"),
@@ -62,23 +62,23 @@ public enum ErrorCode {
     ERR_NOT_KEYFILE(1034, new byte[]{'H', 'Y', '0', '0', '0'}, "Incorrect key file for table '%s'; try to repair it"),
     ERR_OLD_KEYFILE(1035, new byte[]{'H', 'Y', '0', '0', '0'}, "Old key file for table '%s'; repair it!"),
     ERR_OPEN_AS_READONLY(1036, new byte[]{'H', 'Y', '0', '0', '0'}, "Table '%s' is read only"),
-    ERR_OUTOFMEMORY(1037, new byte[]{'H', 'Y', '0', '0', '1'}, "Out of memory; restart server and try again (needed " +
-            "%d bytes)"),
-    ERR_OUT_OF_SORTMEMORY(1038, new byte[]{'H', 'Y', '0', '0', '1'}, "Out of sort memory, consider increasing server " +
-            "sort buffer size"),
-    ERR_UNEXPECTED_EOF(1039, new byte[]{'H', 'Y', '0', '0', '0'}, "Unexpected EOF found when reading file '%s' " +
-            "(Errno: %d)"),
+    ERR_OUTOFMEMORY(1037, new byte[]{'H', 'Y', '0', '0', '1'}, "Out of memory; restart server and try again (needed "
+            + "%d bytes)"),
+    ERR_OUT_OF_SORTMEMORY(1038, new byte[]{'H', 'Y', '0', '0', '1'}, "Out of sort memory, consider increasing server "
+            + "sort buffer size"),
+    ERR_UNEXPECTED_EOF(1039, new byte[]{'H', 'Y', '0', '0', '0'}, "Unexpected EOF found when reading file '%s' "
+            + "(Errno: %d)"),
     ERR_CON_COUNT_ERROR(1040, new byte[]{'0', '8', '0', '0', '4'}, "Too many connections"),
-    ERR_OUT_OF_RESOURCES(1041, new byte[]{'H', 'Y', '0', '0', '0'}, "Out of memory; check if mysqld or some other " +
-            "process uses all available memory; if not, you may have to use 'ulimit' to allow mysqld to use more " +
-            "memory or " +
-            "you can add more swap space"),
+    ERR_OUT_OF_RESOURCES(1041, new byte[]{'H', 'Y', '0', '0', '0'}, "Out of memory; check if mysqld or some other "
+            + "process uses all available memory; if not, you may have to use 'ulimit' to allow mysqld to use more "
+            + "memory or "
+            + "you can add more swap space"),
     ERR_BAD_HOST_ERROR(1042, new byte[]{'0', '8', 'S', '0', '1'}, "Can't get hostname for your address"),
     ERR_HANDSHAKE_ERROR(1043, new byte[]{'0', '8', 'S', '0', '1'}, "Bad handshake"),
-    ERR_DBACCESS_DENIED_ERROR(1044, new byte[]{'4', '2', '0', '0', '0'}, "Access denied for user '%s'@'%s' to " +
-            "database '%s'"),
-    ERR_ACCESS_DENIED_ERROR(1045, new byte[]{'2', '8', '0', '0', '0'}, "Access denied for user '%s' (using " +
-            "password: %s)"),
+    ERR_DBACCESS_DENIED_ERROR(1044, new byte[]{'4', '2', '0', '0', '0'}, "Access denied for user '%s'@'%s' to "
+            + "database '%s'"),
+    ERR_ACCESS_DENIED_ERROR(1045, new byte[]{'2', '8', '0', '0', '0'}, "Access denied for user '%s' (using "
+            + "password: %s)"),
     ERR_NO_DB_ERROR(1046, new byte[]{'3', 'D', '0', '0', '0'}, "No database selected"),
     ERR_UNKNOWN_COM_ERROR(1047, new byte[]{'0', '8', 'S', '0', '1'}, "Unknown command"),
     ERR_BAD_NULL_ERROR(1048, new byte[]{'2', '3', '0', '0', '0'}, "Column '%s' cannot be null"),
@@ -90,8 +90,8 @@ public enum ErrorCode {
     ERR_BAD_FIELD_ERROR(1054, new byte[]{'4', '2', 'S', '2', '2'}, "Unknown column '%s' in '%s'"),
     ERR_WRONG_FIELD_WITH_GROUP(1055, new byte[]{'4', '2', '0', '0', '0'}, "'%s' isn't in GROUP BY"),
     ERR_WRONG_GROUP_FIELD(1056, new byte[]{'4', '2', '0', '0', '0'}, "Can't group on '%s'"),
-    ERR_WRONG_SUM_SELECT(1057, new byte[]{'4', '2', '0', '0', '0'}, "Statement has sum functions and columns in same " +
-            "statement"),
+    ERR_WRONG_SUM_SELECT(1057, new byte[]{'4', '2', '0', '0', '0'}, "Statement has sum functions and columns in same "
+            + "statement"),
     ERR_WRONG_VALUE_COUNT(1058, new byte[]{'2', '1', 'S', '0', '1'}, "Column count doesn't match value count"),
     ERR_TOO_LONG_IDENT(1059, new byte[]{'4', '2', '0', '0', '0'}, "Identifier name '%s' is too long"),
     ERR_DUP_FIELDNAME(1060, new byte[]{'4', '2', 'S', '2', '1'}, "Duplicate column name '%s'"),
@@ -104,83 +104,83 @@ public enum ErrorCode {
     ERR_INVALID_DEFAULT(1067, new byte[]{'4', '2', '0', '0', '0'}, "Invalid default value for '%s'"),
     ERR_MULTIPLE_PRI_KEY(1068, new byte[]{'4', '2', '0', '0', '0'}, "Multiple primary key defined"),
     ERR_TOO_MANY_KEYS(1069, new byte[]{'4', '2', '0', '0', '0'}, "Too many keys specified; max %d keys allowed"),
-    ERR_TOO_MANY_KEY_PARTS(1070, new byte[]{'4', '2', '0', '0', '0'}, "Too many key parts specified; max %d parts " +
-            "allowed"),
-    ERR_TOO_LONG_KEY(1071, new byte[]{'4', '2', '0', '0', '0'}, "Specified key was too long; max key length is %d " +
-            "bytes"),
+    ERR_TOO_MANY_KEY_PARTS(1070, new byte[]{'4', '2', '0', '0', '0'}, "Too many key parts specified; max %d parts "
+            + "allowed"),
+    ERR_TOO_LONG_KEY(1071, new byte[]{'4', '2', '0', '0', '0'}, "Specified key was too long; max key length is %d "
+            + "bytes"),
     ERR_KEY_COLUMN_DOES_NOT_EXITS(1072, new byte[]{'4', '2', '0', '0', '0'}, "Key column '%s' doesn't exist in table"),
-    ERR_BLOB_USED_AS_KEY(1073, new byte[]{'4', '2', '0', '0', '0'}, "BLOB column '%s' can't be used in key " +
-            "specification with the used table type"),
-    ERR_TOO_BIG_FIELDLENGTH(1074, new byte[]{'4', '2', '0', '0', '0'}, "Column length too big for column '%s' (max = " +
-            "%d); use BLOB or TEXT instead"),
-    ERR_WRONG_AUTO_KEY(1075, new byte[]{'4', '2', '0', '0', '0'}, "Incorrect table definition; there can be only one " +
-            "auto column and it must be defined as a key"),
-    ERR_READY(1076, new byte[]{'H', 'Y', '0', '0', '0'}, "%s: ready for connections. Version: '%s' socket: '%s' port:" +
-            " %d"),
+    ERR_BLOB_USED_AS_KEY(1073, new byte[]{'4', '2', '0', '0', '0'}, "BLOB column '%s' can't be used in key "
+            + "specification with the used table type"),
+    ERR_TOO_BIG_FIELDLENGTH(1074, new byte[]{'4', '2', '0', '0', '0'}, "Column length too big for column '%s' (max = "
+            + "%d); use BLOB or TEXT instead"),
+    ERR_WRONG_AUTO_KEY(1075, new byte[]{'4', '2', '0', '0', '0'}, "Incorrect table definition; there can be only one "
+            + "auto column and it must be defined as a key"),
+    ERR_READY(1076, new byte[]{'H', 'Y', '0', '0', '0'}, "%s: ready for connections. Version: '%s' socket: '%s' port:"
+            + " %d"),
     ERR_NORMAL_SHUTDOWN(1077, new byte[]{'H', 'Y', '0', '0', '0'}, "%s: Normal shutdown"),
     ERR_GOT_SIGNAL(1078, new byte[]{'H', 'Y', '0', '0', '0'}, "%s: Got signal %d. Aborting!"),
     ERR_SHUTDOWN_COMPLETE(1079, new byte[]{'H', 'Y', '0', '0', '0'}, "%s: Shutdown complete"),
     ERR_FORCING_CLOSE(1080, new byte[]{'0', '8', 'S', '0', '1'}, "%s: Forcing close of thread %d user: '%s'"),
     ERR_IPSOCK_ERROR(1081, new byte[]{'0', '8', 'S', '0', '1'}, "Can't create IP socket"),
-    ERR_NO_SUCH_INDEX(1082, new byte[]{'4', '2', 'S', '1', '2'}, "Table '%s' has no index like the one used in CREATE" +
-            " INDEX; recreate the table"),
-    ERR_WRONG_FIELD_TERMINATORS(1083, new byte[]{'4', '2', '0', '0', '0'}, "Field separator argument is not what is " +
-            "expected; check the manual"),
-    ERR_BLOBS_AND_NO_TERMINATED(1084, new byte[]{'4', '2', '0', '0', '0'}, "You can't use fixed rowlength with BLOBs;" +
-            " please use 'fields terminated by'"),
-    ERR_TEXTFILE_NOT_READABLE(1085, new byte[]{'H', 'Y', '0', '0', '0'}, "The file '%s' must be in the database " +
-            "directory or be readable by all"),
+    ERR_NO_SUCH_INDEX(1082, new byte[]{'4', '2', 'S', '1', '2'}, "Table '%s' has no index like the one used in CREATE"
+            + " INDEX; recreate the table"),
+    ERR_WRONG_FIELD_TERMINATORS(1083, new byte[]{'4', '2', '0', '0', '0'}, "Field separator argument is not what is "
+            + "expected; check the manual"),
+    ERR_BLOBS_AND_NO_TERMINATED(1084, new byte[]{'4', '2', '0', '0', '0'}, "You can't use fixed rowlength with BLOBs;"
+            + " please use 'fields terminated by'"),
+    ERR_TEXTFILE_NOT_READABLE(1085, new byte[]{'H', 'Y', '0', '0', '0'}, "The file '%s' must be in the database "
+            + "directory or be readable by all"),
     ERR_FILE_EXISTS_ERROR(1086, new byte[]{'H', 'Y', '0', '0', '0'}, "File '%s' already exists"),
     ERR_LOAD_INF(1087, new byte[]{'H', 'Y', '0', '0', '0'}, "Records: %d Deleted: %d Skipped: %d Warnings: %d"),
     ERR_ALTER_INF(1088, new byte[]{'H', 'Y', '0', '0', '0'}, "Records: %d Duplicates: %d"),
-    ERR_WRONG_SUB_KEY(1089, new byte[]{'H', 'Y', '0', '0', '0'}, "Incorrect prefix key; the used key part isn't a " +
-            "string, the used length is longer than the key part, or the storage engine doesn't support unique prefix" +
-            " keys"),
-    ERR_CANT_REMOVE_ALL_FIELDS(1090, new byte[]{'4', '2', '0', '0', '0'}, "You can't delete all columns with ALTER " +
-            "TABLE; use DROP TABLE instead"),
-    ERR_CANT_DROP_FIELD_OR_KEY(1091, new byte[]{'4', '2', '0', '0', '0'}, "Can't DROP '%s'; check that column/key " +
-            "exists"),
+    ERR_WRONG_SUB_KEY(1089, new byte[]{'H', 'Y', '0', '0', '0'}, "Incorrect prefix key; the used key part isn't a "
+            + "string, the used length is longer than the key part, or the storage engine doesn't support unique prefix"
+            + " keys"),
+    ERR_CANT_REMOVE_ALL_FIELDS(1090, new byte[]{'4', '2', '0', '0', '0'}, "You can't delete all columns with ALTER "
+            + "TABLE; use DROP TABLE instead"),
+    ERR_CANT_DROP_FIELD_OR_KEY(1091, new byte[]{'4', '2', '0', '0', '0'}, "Can't DROP '%s'; check that column/key "
+            + "exists"),
     ERR_INSERT_INF(1092, new byte[]{'H', 'Y', '0', '0', '0'}, "Records: %d Duplicates: %d Warnings: %d"),
-    ERR_UPDATE_TABLE_USED(1093, new byte[]{'H', 'Y', '0', '0', '0'}, "You can't specify target table '%s' for update " +
-            "in FROM clause"),
+    ERR_UPDATE_TABLE_USED(1093, new byte[]{'H', 'Y', '0', '0', '0'}, "You can't specify target table '%s' for update "
+            + "in FROM clause"),
     ERR_NO_SUCH_THREAD(1094, new byte[]{'H', 'Y', '0', '0', '0'}, "Unknown thread id: %d"),
     ERR_KILL_DENIED_ERROR(1095, new byte[]{'H', 'Y', '0', '0', '0'}, "You are not owner of thread %d"),
     ERR_NO_TABLES_USED(1096, new byte[]{'H', 'Y', '0', '0', '0'}, "No tables used"),
     ERR_TOO_BIG_SET(1097, new byte[]{'H', 'Y', '0', '0', '0'}, "Too many strings for column %s and SET"),
     ERR_NO_UNIQUE_LOGFILE(1098, new byte[]{'H', 'Y', '0', '0', '0'}, "Can't generate a unique log-filename %s.(1-999)"),
-    ERR_TABLE_NOT_LOCKED_FOR_WRITE(1099, new byte[]{'H', 'Y', '0', '0', '0'}, "Table '%s' was locked with a READ lock" +
-            " and can't be updated"),
+    ERR_TABLE_NOT_LOCKED_FOR_WRITE(1099, new byte[]{'H', 'Y', '0', '0', '0'}, "Table '%s' was locked with a READ lock"
+            + " and can't be updated"),
     ERR_TABLE_NOT_LOCKED(1100, new byte[]{'H', 'Y', '0', '0', '0'}, "Table '%s' was not locked with LOCK TABLES"),
     ERR_UNUSED_17(1101, new byte[]{}, "You should never see it"),
     ERR_WRONG_DB_NAME(1102, new byte[]{'4', '2', '0', '0', '0'}, "Incorrect database name '%s'"),
     ERR_WRONG_TABLE_NAME(1103, new byte[]{'4', '2', '0', '0', '0'}, "Incorrect table name '%s'"),
-    ERR_TOO_BIG_SELECT(1104, new byte[]{'4', '2', '0', '0', '0'}, "The SELECT would examine more than MAX_JOIN_SIZE " +
-            "rows; check your WHERE and use SET SQL_BIG_SELECTS=1 or SET MAX_JOIN_SIZE=# if the SELECT is okay"),
+    ERR_TOO_BIG_SELECT(1104, new byte[]{'4', '2', '0', '0', '0'}, "The SELECT would examine more than MAX_JOIN_SIZE "
+            + "rows; check your WHERE and use SET SQL_BIG_SELECTS=1 or SET MAX_JOIN_SIZE=# if the SELECT is okay"),
     ERR_UNKNOWN_ERROR(1105, new byte[]{'H', 'Y', '0', '0', '0'}, "Unknown error"),
     ERR_UNKNOWN_PROCEDURE(1106, new byte[]{'4', '2', '0', '0', '0'}, "Unknown procedure '%s'"),
-    ERR_WRONG_PARAMCOUNT_TO_PROCEDURE(1107, new byte[]{'4', '2', '0', '0', '0'}, "Incorrect parameter count to " +
-            "procedure '%s'"),
-    ERR_WRONG_PARAMETERS_TO_PROCEDURE(1108, new byte[]{'H', 'Y', '0', '0', '0'}, "Incorrect parameters to procedure " +
-            "'%s'"),
+    ERR_WRONG_PARAMCOUNT_TO_PROCEDURE(1107, new byte[]{'4', '2', '0', '0', '0'}, "Incorrect parameter count to "
+            + "procedure '%s'"),
+    ERR_WRONG_PARAMETERS_TO_PROCEDURE(1108, new byte[]{'H', 'Y', '0', '0', '0'}, "Incorrect parameters to procedure "
+            + "'%s'"),
     ERR_UNKNOWN_TABLE(1109, new byte[]{'4', '2', 'S', '0', '2'}, "Unknown table '%s' in %s"),
     ERR_FIELD_SPECIFIED_TWICE(1110, new byte[]{'4', '2', '0', '0', '0'}, "Column '%s' specified twice"),
     ERR_INVALID_GROUP_FUNC_USE(1111, new byte[]{'H', 'Y', '0', '0', '0'}, "Invalid use of group function"),
-    ERR_UNSUPPORTED_EXTENSION(1112, new byte[]{'4', '2', '0', '0', '0'}, "Table '%s' uses an extension that doesn't " +
-            "exist in this MariaDB version"),
... 23205 lines suppressed ...


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@doris.apache.org
For additional commands, e-mail: commits-help@doris.apache.org