You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hugegraph.apache.org by ji...@apache.org on 2023/01/16 18:13:39 UTC

[incubator-hugegraph-computer] branch master updated: chore: remove unused license code (#225)

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 075ea17d chore: remove unused license code (#225)
075ea17d is described below

commit 075ea17da01c55b1aee9d353bf00900072083062
Author: 青年 <10...@qq.com>
AuthorDate: Tue Jan 17 02:13:33 2023 +0800

    chore: remove unused license code (#225)
---
 .../algorithm/centrality/betweenness/BetweennessCentrality.java       | 1 -
 .../algorithm/centrality/betweenness/BetweennessCentralityParams.java | 1 -
 .../computer/algorithm/centrality/betweenness/BetweennessMessage.java | 1 -
 .../computer/algorithm/centrality/betweenness/BetweennessValue.java   | 1 -
 .../computer/algorithm/centrality/closeness/ClosenessCentrality.java  | 1 -
 .../algorithm/centrality/closeness/ClosenessCentralityParams.java     | 1 -
 .../computer/algorithm/centrality/closeness/ClosenessMessage.java     | 1 -
 .../computer/algorithm/centrality/closeness/ClosenessValue.java       | 1 -
 .../computer/algorithm/centrality/degree/DegreeCentrality.java        | 1 -
 .../computer/algorithm/centrality/degree/DegreeCentralityParams.java  | 1 -
 .../hugegraph/computer/algorithm/centrality/pagerank/PageRank.java    | 1 -
 .../computer/algorithm/centrality/pagerank/PageRank4Master.java       | 1 -
 .../computer/algorithm/centrality/pagerank/PageRankParams.java        | 1 -
 .../computer/algorithm/community/cc/ClusteringCoefficient.java        | 1 -
 .../computer/algorithm/community/cc/ClusteringCoefficientOutput.java  | 1 -
 .../computer/algorithm/community/cc/ClusteringCoefficientParams.java  | 1 -
 .../computer/algorithm/community/cc/ClusteringCoefficientValue.java   | 1 -
 .../apache/hugegraph/computer/algorithm/community/kcore/Kcore.java    | 1 -
 .../hugegraph/computer/algorithm/community/kcore/KcoreParams.java     | 1 -
 .../hugegraph/computer/algorithm/community/kcore/KcoreValue.java      | 1 -
 .../org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java    | 1 -
 .../apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java  | 1 -
 .../computer/algorithm/community/trianglecount/TriangleCount.java     | 1 -
 .../algorithm/community/trianglecount/TriangleCountParams.java        | 1 -
 .../algorithm/community/trianglecount/TriangleCountValue.java         | 1 -
 .../org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java    | 1 -
 .../apache/hugegraph/computer/algorithm/community/wcc/WccParams.java  | 1 -
 .../hugegraph/computer/algorithm/path/rings/RingsDetection.java       | 1 -
 .../hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java | 1 -
 .../hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java | 1 -
 .../computer/algorithm/path/rings/filter/FilterDescribe.java          | 1 -
 .../computer/algorithm/path/rings/filter/RingsDetectionMessage.java   | 1 -
 .../algorithm/path/rings/filter/RingsDetectionWithFilter.java         | 1 -
 .../algorithm/path/rings/filter/RingsDetectionWithFilterParams.java   | 1 -
 .../hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java  | 4 +---
 .../java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java | 1 -
 .../org/apache/hugegraph/computer/core/aggregator/Aggregator.java     | 1 -
 .../apache/hugegraph/computer/core/aggregator/Aggregator4Master.java  | 1 -
 .../apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/allocator/Allocator.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/allocator/Recyclable.java | 1 -
 .../apache/hugegraph/computer/core/allocator/RecyclerReference.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/combiner/Combiner.java    | 1 -
 .../hugegraph/computer/core/combiner/DoubleValueSumCombiner.java      | 1 -
 .../hugegraph/computer/core/combiner/FloatValueSumCombiner.java       | 1 -
 .../apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java  | 1 -
 .../apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java | 1 -
 .../hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java  | 1 -
 .../hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java  | 1 -
 .../apache/hugegraph/computer/core/combiner/OverwriteCombiner.java    | 1 -
 .../hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java | 1 -
 .../apache/hugegraph/computer/core/combiner/PropertiesCombiner.java   | 1 -
 .../org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java | 1 -
 .../org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java | 1 -
 .../org/apache/hugegraph/computer/core/common/ComputerContext.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/common/Constants.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/common/SerialEnum.java    | 1 -
 .../hugegraph/computer/core/common/exception/ComputerException.java   | 1 -
 .../org/apache/hugegraph/computer/core/config/ComputerOptions.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/core/config/Config.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/config/DefaultConfig.java | 1 -
 .../java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java | 1 -
 .../java/org/apache/hugegraph/computer/core/config/HotConfig.java     | 1 -
 .../src/main/java/org/apache/hugegraph/computer/core/config/Null.java | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/GraphFactory.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/edge/Edges.java     | 1 -
 .../src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java | 1 -
 .../hugegraph/computer/core/graph/properties/DefaultProperties.java   | 1 -
 .../apache/hugegraph/computer/core/graph/properties/Properties.java   | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/BooleanValue.java  | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/DoubleValue.java   | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/FloatValue.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/value/IdList.java   | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/IdListList.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/value/IdSet.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/value/IntValue.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/ListValue.java     | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/LongValue.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/value/MapValue.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/NullValue.java     | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/StringValue.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/value/Value.java    | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/ValueType.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/input/InputFilter.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/BytesInput.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java | 1 -
 .../org/apache/hugegraph/computer/core/io/GraphComputeOutput.java     | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/GraphInput.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java  | 1 -
 .../org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java | 1 -
 .../org/apache/hugegraph/computer/core/io/RandomAccessOutput.java     | 1 -
 .../src/main/java/org/apache/hugegraph/computer/core/io/Readable.java | 1 -
 .../src/main/java/org/apache/hugegraph/computer/core/io/Writable.java | 1 -
 .../hugegraph/computer/core/master/DefaultMasterComputation.java      | 1 -
 .../org/apache/hugegraph/computer/core/master/MasterComputation.java  | 1 -
 .../hugegraph/computer/core/master/MasterComputationContext.java      | 1 -
 .../java/org/apache/hugegraph/computer/core/master/MasterContext.java | 1 -
 .../apache/hugegraph/computer/core/output/AbstractComputerOutput.java | 1 -
 .../org/apache/hugegraph/computer/core/output/ComputerOutput.java     | 1 -
 .../org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java | 1 -
 .../computer/core/output/hg/exceptions/WriteBackException.java        | 1 -
 .../apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java | 1 -
 .../apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java  | 1 -
 .../apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java | 1 -
 .../org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java | 1 -
 .../hugegraph/computer/core/output/hg/task/BatchInsertTask.java       | 1 -
 .../org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java | 1 -
 .../hugegraph/computer/core/output/hg/task/SingleInsertTask.java      | 1 -
 .../apache/hugegraph/computer/core/output/hg/task/TaskManager.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java  | 1 -
 .../main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/worker/Computation.java   | 1 -
 .../org/apache/hugegraph/computer/core/worker/ComputationContext.java | 1 -
 .../org/apache/hugegraph/computer/core/worker/FilterComputation.java  | 1 -
 .../org/apache/hugegraph/computer/core/worker/ReduceComputation.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/worker/WorkerContext.java | 1 -
 .../org/apache/hugegraph/computer/core/aggregator/Aggregators.java    | 1 -
 .../apache/hugegraph/computer/core/aggregator/DefaultAggregator.java  | 1 -
 .../apache/hugegraph/computer/core/aggregator/MasterAggrManager.java  | 1 -
 .../hugegraph/computer/core/aggregator/RegisterAggregators.java       | 1 -
 .../apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java  | 1 -
 .../apache/hugegraph/computer/core/allocator/DefaultAllocator.java    | 1 -
 .../org/apache/hugegraph/computer/core/allocator/RecycleHandler.java  | 1 -
 .../main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java  | 1 -
 .../main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java  | 1 -
 .../src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java | 1 -
 .../main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java  | 1 -
 .../hugegraph/computer/core/combiner/AbstractPointerCombiner.java     | 1 -
 .../apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java    | 1 -
 .../apache/hugegraph/computer/core/combiner/MessageValueCombiner.java | 1 -
 .../org/apache/hugegraph/computer/core/combiner/PointerCombiner.java  | 1 -
 .../apache/hugegraph/computer/core/combiner/VertexValueCombiner.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/common/ContainerInfo.java | 1 -
 .../hugegraph/computer/core/common/exception/IllegalArgException.java | 1 -
 .../hugegraph/computer/core/common/exception/ReadException.java       | 1 -
 .../hugegraph/computer/core/common/exception/TransportException.java  | 1 -
 .../hugegraph/computer/core/common/exception/WriteException.java      | 1 -
 .../org/apache/hugegraph/computer/core/compute/ComputeManager.java    | 1 -
 .../apache/hugegraph/computer/core/compute/FileGraphPartition.java    | 1 -
 .../org/apache/hugegraph/computer/core/compute/input/EdgesInput.java  | 1 -
 .../apache/hugegraph/computer/core/compute/input/MessageInput.java    | 1 -
 .../apache/hugegraph/computer/core/compute/input/ReusablePointer.java | 1 -
 .../org/apache/hugegraph/computer/core/compute/input/VertexInput.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java  | 1 -
 .../org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java    | 1 -
 .../org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/id/BytesId.java     | 1 -
 .../hugegraph/computer/core/graph/partition/HashPartitioner.java      | 1 -
 .../apache/hugegraph/computer/core/graph/partition/PartitionStat.java | 1 -
 .../apache/hugegraph/computer/core/graph/partition/Partitioner.java   | 1 -
 .../apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/input/ElementFetcher.java | 1 -
 .../java/org/apache/hugegraph/computer/core/input/GraphFetcher.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/input/HugeConverter.java  | 1 -
 .../main/java/org/apache/hugegraph/computer/core/input/IdUtil.java    | 1 -
 .../org/apache/hugegraph/computer/core/input/InputSourceFactory.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/input/InputSplit.java     | 1 -
 .../org/apache/hugegraph/computer/core/input/InputSplitFetcher.java   | 1 -
 .../org/apache/hugegraph/computer/core/input/MasterInputHandler.java  | 1 -
 .../org/apache/hugegraph/computer/core/input/MasterInputManager.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/input/VertexFetcher.java  | 1 -
 .../org/apache/hugegraph/computer/core/input/WorkerInputManager.java  | 1 -
 .../hugegraph/computer/core/input/filter/DefaultInputFilter.java      | 1 -
 .../computer/core/input/filter/ExtractAllPropertyInputFilter.java     | 1 -
 .../org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java  | 1 -
 .../apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java   | 1 -
 .../org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java | 1 -
 .../hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java       | 1 -
 .../apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java    | 1 -
 .../apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java  | 1 -
 .../hugegraph/computer/core/input/loader/FileElementFetcher.java      | 1 -
 .../apache/hugegraph/computer/core/input/loader/FileInputSplit.java   | 1 -
 .../apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java | 1 -
 .../computer/core/input/loader/LoaderFileInputSplitFetcher.java       | 1 -
 .../hugegraph/computer/core/input/loader/LoaderGraphFetcher.java      | 1 -
 .../apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java  | 1 -
 .../apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java | 1 -
 .../java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java | 1 -
 .../org/apache/hugegraph/computer/core/io/BufferedFileOutput.java     | 1 -
 .../org/apache/hugegraph/computer/core/io/BufferedStreamInput.java    | 1 -
 .../org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java   | 1 -
 .../org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/IOFactory.java    | 1 -
 .../org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java  | 1 -
 .../org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java    | 1 -
 .../org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java | 1 -
 .../java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java | 1 -
 .../java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java | 1 -
 .../apache/hugegraph/computer/core/io/StructRandomAccessOutput.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java | 1 -
 .../main/java/org/apache/hugegraph/computer/core/manager/Manager.java | 1 -
 .../java/org/apache/hugegraph/computer/core/manager/Managers.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/master/MasterService.java | 1 -
 .../org/apache/hugegraph/computer/core/network/ClientFactory.java     | 1 -
 .../org/apache/hugegraph/computer/core/network/ClientHandler.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/network/ConnectionId.java | 1 -
 .../org/apache/hugegraph/computer/core/network/DataClientManager.java | 1 -
 .../org/apache/hugegraph/computer/core/network/DataServerManager.java | 1 -
 .../main/java/org/apache/hugegraph/computer/core/network/IOMode.java  | 1 -
 .../org/apache/hugegraph/computer/core/network/MessageHandler.java    | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportClient.java   | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportConf.java     | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportHandler.java  | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportProvider.java | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportServer.java   | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportState.java    | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportUtil.java     | 1 -
 .../hugegraph/computer/core/network/buffer/FileRegionBuffer.java      | 1 -
 .../apache/hugegraph/computer/core/network/buffer/NettyBuffer.java    | 1 -
 .../apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java  | 1 -
 .../org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java  | 1 -
 .../hugegraph/computer/core/network/connection/ConnectionManager.java | 1 -
 .../computer/core/network/connection/TransportConnectionManager.java  | 1 -
 .../apache/hugegraph/computer/core/network/message/AckMessage.java    | 1 -
 .../apache/hugegraph/computer/core/network/message/DataMessage.java   | 1 -
 .../apache/hugegraph/computer/core/network/message/FailMessage.java   | 1 -
 .../apache/hugegraph/computer/core/network/message/FinishMessage.java | 1 -
 .../org/apache/hugegraph/computer/core/network/message/Message.java   | 1 -
 .../apache/hugegraph/computer/core/network/message/MessageType.java   | 1 -
 .../apache/hugegraph/computer/core/network/message/PingMessage.java   | 1 -
 .../apache/hugegraph/computer/core/network/message/PongMessage.java   | 1 -
 .../hugegraph/computer/core/network/message/RequestMessage.java       | 1 -
 .../hugegraph/computer/core/network/message/ResponseMessage.java      | 1 -
 .../apache/hugegraph/computer/core/network/message/StartMessage.java  | 1 -
 .../hugegraph/computer/core/network/netty/AbstractNettyHandler.java   | 1 -
 .../hugegraph/computer/core/network/netty/BufAllocatorFactory.java    | 1 -
 .../computer/core/network/netty/ChannelFutureListenerOnWrite.java     | 1 -
 .../hugegraph/computer/core/network/netty/HeartbeatHandler.java       | 1 -
 .../hugegraph/computer/core/network/netty/NettyClientFactory.java     | 1 -
 .../hugegraph/computer/core/network/netty/NettyClientHandler.java     | 1 -
 .../hugegraph/computer/core/network/netty/NettyEventLoopUtil.java     | 1 -
 .../apache/hugegraph/computer/core/network/netty/NettyProtocol.java   | 1 -
 .../hugegraph/computer/core/network/netty/NettyServerHandler.java     | 1 -
 .../hugegraph/computer/core/network/netty/NettyTransportClient.java   | 1 -
 .../hugegraph/computer/core/network/netty/NettyTransportProvider.java | 1 -
 .../hugegraph/computer/core/network/netty/NettyTransportServer.java   | 1 -
 .../hugegraph/computer/core/network/netty/ServerIdleHandler.java      | 1 -
 .../hugegraph/computer/core/network/netty/codec/FrameDecoder.java     | 1 -
 .../hugegraph/computer/core/network/netty/codec/MessageDecoder.java   | 1 -
 .../hugegraph/computer/core/network/netty/codec/MessageEncoder.java   | 1 -
 .../computer/core/network/netty/codec/PreciseFrameDecoder.java        | 1 -
 .../apache/hugegraph/computer/core/network/session/ClientSession.java | 1 -
 .../apache/hugegraph/computer/core/network/session/ServerSession.java | 1 -
 .../hugegraph/computer/core/network/session/TransportSession.java     | 1 -
 .../org/apache/hugegraph/computer/core/output/LimitedLogOutput.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/output/LogOutput.java     | 1 -
 .../org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java    | 1 -
 .../apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java  | 1 -
 .../hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java      | 1 -
 .../hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java       | 1 -
 .../apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java   | 1 -
 .../apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java  | 1 -
 .../apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java | 1 -
 .../hugegraph/computer/core/output/hg/HugeGraphStringOutput.java      | 1 -
 .../apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java   | 1 -
 .../apache/hugegraph/computer/core/receiver/MessageRecvManager.java   | 1 -
 .../apache/hugegraph/computer/core/receiver/MessageRecvPartition.java | 1 -
 .../hugegraph/computer/core/receiver/MessageRecvPartitions.java       | 1 -
 .../java/org/apache/hugegraph/computer/core/receiver/MessageStat.java | 1 -
 .../computer/core/receiver/edge/EdgeMessageRecvPartition.java         | 1 -
 .../computer/core/receiver/edge/EdgeMessageRecvPartitions.java        | 1 -
 .../computer/core/receiver/message/ComputeMessageRecvPartition.java   | 1 -
 .../computer/core/receiver/message/ComputeMessageRecvPartitions.java  | 1 -
 .../computer/core/receiver/vertex/VertexMessageRecvPartition.java     | 1 -
 .../computer/core/receiver/vertex/VertexMessageRecvPartitions.java    | 1 -
 .../org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java   | 1 -
 .../org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java | 1 -
 .../java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java | 1 -
 .../java/org/apache/hugegraph/computer/core/sender/MessageQueue.java  | 1 -
 .../org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java | 1 -
 .../org/apache/hugegraph/computer/core/sender/MessageSendManager.java | 1 -
 .../apache/hugegraph/computer/core/sender/MessageSendPartition.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/sender/MessageSender.java | 1 -
 .../java/org/apache/hugegraph/computer/core/sender/MultiQueue.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java | 1 -
 .../apache/hugegraph/computer/core/sender/QueuedMessageSender.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java  | 1 -
 .../org/apache/hugegraph/computer/core/sort/BufferFileSorter.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java  | 1 -
 .../src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java | 1 -
 .../hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java | 1 -
 .../computer/core/sort/flusher/CombineKvInnerSortFlusher.java         | 1 -
 .../computer/core/sort/flusher/CombineKvOuterSortFlusher.java         | 1 -
 .../computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java      | 1 -
 .../computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java      | 1 -
 .../apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java | 1 -
 .../hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java      | 1 -
 .../hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java      | 1 -
 .../apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java | 1 -
 .../apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java | 1 -
 .../hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java | 1 -
 .../org/apache/hugegraph/computer/core/sort/merge/FileMerger.java     | 1 -
 .../org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java   | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java  | 1 -
 .../apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java  | 1 -
 .../apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java   | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java   | 1 -
 .../hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java   | 1 -
 .../hugegraph/computer/core/sort/sorting/HeapInputsSorting.java       | 1 -
 .../apache/hugegraph/computer/core/sort/sorting/InputsSorting.java    | 1 -
 .../hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java  | 1 -
 .../apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java  | 1 -
 .../apache/hugegraph/computer/core/sort/sorting/SendSortManager.java  | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorting/SortManager.java  | 1 -
 .../apache/hugegraph/computer/core/sort/sorting/SortingFactory.java   | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/store/EntryIterator.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/store/FileGenerator.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/store/FileManager.java    | 1 -
 .../org/apache/hugegraph/computer/core/store/KvEntryFileReader.java   | 1 -
 .../org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/store/StoreManager.java   | 1 -
 .../apache/hugegraph/computer/core/store/SuperstepFileGenerator.java  | 1 -
 .../apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java   | 1 -
 .../computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java      | 1 -
 .../hugegraph/computer/core/store/buffer/SubKvEntriesInput.java       | 1 -
 .../apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java   | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/CachedPointer.java | 1 -
 .../apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java    | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java   | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/EntryInput.java    | 1 -
 .../apache/hugegraph/computer/core/store/entry/EntryInputImpl.java    | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/EntryOutput.java   | 1 -
 .../apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java   | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/InlinePointer.java | 1 -
 .../java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java  | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java | 1 -
 .../apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java | 1 -
 .../hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java    | 1 -
 .../org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java | 1 -
 .../apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java | 1 -
 .../java/org/apache/hugegraph/computer/core/store/entry/Pointer.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/store/entry/Range.java    | 1 -
 .../computer/core/store/file/bufferfile/BufferFileEntryBuilder.java   | 1 -
 .../computer/core/store/file/bufferfile/BufferFileEntryReader.java    | 1 -
 .../computer/core/store/file/bufferfile/BufferFileSubEntryReader.java | 1 -
 .../hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java | 1 -
 .../apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java   | 1 -
 .../hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java      | 1 -
 .../apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java  | 1 -
 .../hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java     | 1 -
 .../computer/core/store/file/hgkvfile/builder/BlockBuilder.java       | 1 -
 .../core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java        | 1 -
 .../computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java | 1 -
 .../computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java    | 1 -
 .../core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java         | 1 -
 .../computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java  | 1 -
 .../core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java       | 1 -
 .../core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java      | 1 -
 .../computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java   | 1 -
 .../computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java  | 1 -
 .../computer/core/store/file/select/DefaultSelectedFiles.java         | 1 -
 .../computer/core/store/file/select/DisperseEvenlySelector.java       | 1 -
 .../hugegraph/computer/core/store/file/select/InputFilesSelector.java | 1 -
 .../hugegraph/computer/core/store/file/select/SelectedFiles.java      | 1 -
 .../hugegraph/computer/core/store/file/seqfile/BitsFileReader.java    | 1 -
 .../computer/core/store/file/seqfile/BitsFileReaderImpl.java          | 1 -
 .../hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java    | 1 -
 .../computer/core/store/file/seqfile/BitsFileWriterImpl.java          | 1 -
 .../apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java  | 1 -
 .../hugegraph/computer/core/store/file/seqfile/ValueFileInput.java    | 1 -
 .../hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java   | 1 -
 .../org/apache/hugegraph/computer/core/util/ComputerContextUtil.java  | 1 -
 .../main/java/org/apache/hugegraph/computer/core/util/Consumers.java  | 1 -
 .../main/java/org/apache/hugegraph/computer/core/util/FileUtil.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/util/SerializeUtil.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/util/ShutdownHook.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/util/StringEncoding.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/worker/WorkerService.java | 1 -
 .../java/org/apache/hugegraph/computer/core/worker/WorkerStat.java    | 1 -
 .../org/apache/hugegraph/computer/core/worker/load/LoadService.java   | 1 -
 computer-dist/src/assembly/dataset/load-movie-data.groovy             | 1 -
 computer-dist/src/assembly/dataset/schema.groovy                      | 1 -
 .../java/org/apache/hugegraph/computer/driver/ComputerDriver.java     | 1 -
 .../org/apache/hugegraph/computer/driver/ComputerDriverException.java | 1 -
 .../java/org/apache/hugegraph/computer/driver/DefaultJobState.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/driver/JobObserver.java   | 1 -
 .../src/main/java/org/apache/hugegraph/computer/driver/JobState.java  | 1 -
 .../src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java | 1 -
 .../main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java | 1 -
 .../apache/hugegraph/computer/driver/config/DriverConfigOption.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java | 1 -
 .../apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java    | 1 -
 .../hugegraph/computer/k8s/operator/common/AbstractController.java    | 1 -
 .../apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java   | 1 -
 .../hugegraph/computer/k8s/operator/common/OperatorRequest.java       | 1 -
 .../apache/hugegraph/computer/k8s/operator/common/OperatorResult.java | 1 -
 .../org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java  | 1 -
 .../hugegraph/computer/k8s/operator/config/OperatorOptions.java       | 1 -
 .../computer/k8s/operator/controller/ComputerJobComponent.java        | 1 -
 .../computer/k8s/operator/controller/ComputerJobController.java       | 1 -
 .../computer/k8s/operator/controller/ComputerJobDeployer.java         | 1 -
 .../src/main/java/org/apache/hugegraph/computer/k8s/Constants.java    | 1 -
 .../org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java   | 1 -
 .../org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java     | 1 -
 .../apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java | 1 -
 .../hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java    | 1 -
 .../org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java    | 1 -
 .../org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java    | 1 -
 .../org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java   | 1 -
 .../algorithm/centrality/betweenness/BetweennessCentralityTest.java   | 1 -
 .../algorithm/centrality/closeness/ClosenessCentralityTest.java       | 1 -
 .../computer/algorithm/centrality/degree/DegreeCentralityTest.java    | 1 -
 .../computer/algorithm/centrality/pagerank/PageRankTest.java          | 1 -
 .../computer/algorithm/community/cc/ClusteringCoefficientTest.java    | 1 -
 .../hugegraph/computer/algorithm/community/kcore/KcoreTest.java       | 1 -
 .../apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java    | 1 -
 .../computer/algorithm/community/trianglecount/TriangleCountTest.java | 1 -
 .../apache/hugegraph/computer/algorithm/community/wcc/WccTest.java    | 1 -
 .../hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java   | 1 -
 .../computer/algorithm/path/rings/RingsDetectionWithFilterTest.java   | 1 -
 .../apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java  | 1 -
 .../hugegraph/computer/core/allocator/DefaultAllocatorTest.java       | 1 -
 .../org/apache/hugegraph/computer/core/allocator/RecyclersTest.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java     | 1 -
 .../main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java | 1 -
 .../java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java   | 1 -
 .../apache/hugegraph/computer/core/combiner/CombinerTestSuite.java    | 1 -
 .../hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java  | 1 -
 .../hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java   | 1 -
 .../hugegraph/computer/core/combiner/IntValueSumCombinerTest.java     | 1 -
 .../hugegraph/computer/core/combiner/LongValueSumCombinerTest.java    | 1 -
 .../computer/core/combiner/MergeNewPropertiesCombinerTest.java        | 1 -
 .../computer/core/combiner/MergeOldPropertiesCombinerTest.java        | 1 -
 .../hugegraph/computer/core/combiner/OverwriteCombinerTest.java       | 1 -
 .../apache/hugegraph/computer/core/combiner/PointerCombinerTest.java  | 1 -
 .../apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java | 1 -
 .../apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java | 1 -
 .../org/apache/hugegraph/computer/core/common/CommonTestSuite.java    | 1 -
 .../org/apache/hugegraph/computer/core/common/ContainerInfoTest.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/common/ExceptionTest.java | 1 -
 .../apache/hugegraph/computer/core/common/FakeMasterComputation.java  | 1 -
 .../apache/hugegraph/computer/core/compute/ComputeManagerTest.java    | 1 -
 .../org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java  | 1 -
 .../org/apache/hugegraph/computer/core/compute/MockComputation.java   | 1 -
 .../org/apache/hugegraph/computer/core/compute/MockMessageSender.java | 1 -
 .../apache/hugegraph/computer/core/compute/input/EdgesInputTest.java  | 1 -
 .../hugegraph/computer/core/compute/input/MessageInputTest.java       | 1 -
 .../hugegraph/computer/core/compute/input/ResuablePointerTest.java    | 1 -
 .../org/apache/hugegraph/computer/core/config/ConfigTestSuite.java    | 1 -
 .../org/apache/hugegraph/computer/core/config/DefaultConfigTest.java  | 1 -
 .../apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java     | 1 -
 .../apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java  | 1 -
 .../hugegraph/computer/core/graph/partition/HashPartitionerTest.java  | 1 -
 .../hugegraph/computer/core/graph/partition/PartitionStatTest.java    | 1 -
 .../apache/hugegraph/computer/core/graph/value/BooleanValueTest.java  | 1 -
 .../apache/hugegraph/computer/core/graph/value/DoubleValueTest.java   | 1 -
 .../apache/hugegraph/computer/core/graph/value/FloatValueTest.java    | 1 -
 .../apache/hugegraph/computer/core/graph/value/IdListListTest.java    | 1 -
 .../apache/hugegraph/computer/core/graph/value/IdValueListTest.java   | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/IdValueTest.java   | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/IntValueTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/ListValueTest.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/LongValueTest.java | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/NullValueTest.java | 1 -
 .../apache/hugegraph/computer/core/graph/value/StringValueTest.java   | 1 -
 .../org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java | 1 -
 .../org/apache/hugegraph/computer/core/input/FileInputSplitTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/input/HugeConverterTest.java   | 1 -
 .../org/apache/hugegraph/computer/core/input/InputSplitDataTest.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/input/InputSplitTest.java | 1 -
 .../java/org/apache/hugegraph/computer/core/input/InputTestSuite.java | 1 -
 .../apache/hugegraph/computer/core/input/MockMasterInputManager.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/input/MockRpcClient.java  | 1 -
 .../apache/hugegraph/computer/core/input/MockWorkerInputManager.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/io/BufferedStreamTest.java     | 1 -
 .../apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java   | 1 -
 .../main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java  | 1 -
 .../apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/io/MockRankComputation.java    | 1 -
 .../apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java   | 1 -
 .../apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java | 1 -
 .../hugegraph/computer/core/io/StructRandomAccessOutputTest.java      | 1 -
 .../java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java   | 1 -
 .../org/apache/hugegraph/computer/core/network/ConnectionIdTest.java  | 1 -
 .../apache/hugegraph/computer/core/network/DataServerManagerTest.java | 1 -
 .../org/apache/hugegraph/computer/core/network/MockClientHandler.java | 1 -
 .../apache/hugegraph/computer/core/network/MockMessageHandler.java    | 1 -
 .../apache/hugegraph/computer/core/network/MockUnDecodeMessage.java   | 1 -
 .../org/apache/hugegraph/computer/core/network/NetworkTestSuite.java  | 1 -
 .../org/apache/hugegraph/computer/core/network/TransportUtilTest.java | 1 -
 .../hugegraph/computer/core/network/buffer/NetworkBufferTest.java     | 1 -
 .../computer/core/network/connection/ConnectionManagerTest.java       | 1 -
 .../hugegraph/computer/core/network/netty/AbstractNetworkTest.java    | 1 -
 .../hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java   | 1 -
 .../hugegraph/computer/core/network/netty/NettyClientFactoryTest.java | 1 -
 .../computer/core/network/netty/NettyEncodeDecodeHandlerTest.java     | 1 -
 .../computer/core/network/netty/NettyTransportClientTest.java         | 1 -
 .../computer/core/network/netty/NettyTransportServerTest.java         | 1 -
 .../hugegraph/computer/core/network/session/TransportSessionTest.java | 1 -
 .../hugegraph/computer/core/receiver/MessageRecvBuffersTest.java      | 1 -
 .../hugegraph/computer/core/receiver/MessageRecvManagerTest.java      | 1 -
 .../apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java    | 1 -
 .../org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java     | 1 -
 .../computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java     | 1 -
 .../core/receiver/message/ComputeMessageRecvPartitionTest.java        | 1 -
 .../computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java | 1 -
 .../org/apache/hugegraph/computer/core/sender/MessageQueueTest.java   | 1 -
 .../apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java | 1 -
 .../apache/hugegraph/computer/core/sender/MessageSendManagerTest.java | 1 -
 .../apache/hugegraph/computer/core/sender/MockTransportClient.java    | 1 -
 .../org/apache/hugegraph/computer/core/sender/MultiQueueTest.java     | 1 -
 .../hugegraph/computer/core/sender/QueuedMessageSenderTest.java       | 1 -
 .../org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/sender/SenderTestSuite.java    | 1 -
 .../org/apache/hugegraph/computer/core/sender/WriteBufferTest.java    | 1 -
 .../org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java  | 1 -
 .../hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java     | 1 -
 .../apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java   | 1 -
 .../apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java    | 1 -
 .../apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java   | 1 -
 .../hugegraph/computer/core/sort/sorting/InputsSortingTest.java       | 1 -
 .../apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java | 1 -
 .../org/apache/hugegraph/computer/core/sort/sorting/TestData.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/store/BitFileTest.java    | 1 -
 .../org/apache/hugegraph/computer/core/store/EntriesUtilTest.java     | 1 -
 .../org/apache/hugegraph/computer/core/store/EntryOutputTest.java     | 1 -
 .../org/apache/hugegraph/computer/core/store/FileManagerTest.java     | 1 -
 .../java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java   | 1 -
 .../java/org/apache/hugegraph/computer/core/store/PointerTest.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java | 1 -
 .../java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/store/ValueFileTest.java  | 1 -
 .../apache/hugegraph/computer/core/util/ComputerContextUtilTest.java  | 1 -
 .../java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java    | 1 -
 .../org/apache/hugegraph/computer/core/util/SerializeUtilTest.java    | 1 -
 .../java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java   | 1 -
 .../org/apache/hugegraph/computer/core/worker/MockComputation.java    | 1 -
 .../org/apache/hugegraph/computer/core/worker/MockComputation2.java   | 1 -
 .../apache/hugegraph/computer/core/worker/MockComputationParams.java  | 1 -
 .../apache/hugegraph/computer/core/worker/MockMasterComputation.java  | 1 -
 .../apache/hugegraph/computer/core/worker/MockMasterComputation2.java | 1 -
 .../org/apache/hugegraph/computer/core/worker/MockWorkerService.java  | 1 -
 .../org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java  | 1 -
 .../org/apache/hugegraph/computer/core/worker/WorkerStatTest.java     | 1 -
 .../org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java    | 1 -
 .../org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java     | 1 -
 .../org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java     | 1 -
 .../org/apache/hugegraph/computer/driver/ComputerOptionsTest.java     | 1 -
 .../main/java/org/apache/hugegraph/computer/driver/DriverTest.java    | 1 -
 .../java/org/apache/hugegraph/computer/driver/DriverTestSuite.java    | 1 -
 .../main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java  | 1 -
 .../src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java | 1 -
 .../java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java  | 1 -
 .../src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java | 1 -
 .../src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java | 1 -
 .../apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java | 1 -
 .../apache/hugegraph/computer/suite/integrate/MockComputation.java    | 1 -
 .../hugegraph/computer/suite/integrate/SenderIntegrateTest.java       | 1 -
 .../java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java   | 1 -
 .../java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java  | 1 -
 583 files changed, 1 insertion(+), 585 deletions(-)

diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java
index 796ce25c..9619744a 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java
index bbed320b..55e63996 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java
index 71c26866..6d2eacee 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java
index 19572152..06e8db38 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java
index 157bee9f..c4ed974e 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java
index 0b9ea69b..abc74c54 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java
index ddadc90c..925b3683 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java
index e0d9f842..9c126755 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java
index a3a5064d..a4649e06 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java
index 889a91bb..23a09b4f 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java
index 91952e9d..1141649c 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java
index 6142f9ef..14a57eab 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java
index 7ed107cf..d308051f 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java
index 858ff3e6..7af33aae 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java
index c9bd4c86..40a11de3 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java
index 38e4673e..ed3b09fa 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java
index 42b6e541..056093d3 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java
index d6720a3f..eeffe832 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java
index b2ee8129..fa4c532b 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java
index 6c278891..d00cbe6c 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java
index ec295c77..1bb34413 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java
index 7c7fc933..f5700a74 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java
index 1b8a40a6..6212aec6 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java
index 1b909259..93ed3c27 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java
index ebde17cb..6dae14f7 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java
index cb11dde5..ef177279 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java
index 42d89816..b01c32e4 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java
index 20cf3a63..956b06cc 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java
index 2b9e38d5..d16b499a 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java
index f08c6990..f06f3107 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java
index 9d298be7..be60a05b 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java
index 6453e10e..eb3c20ef 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java
index 97a3eac5..9f65535f 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java
index d8d473a0..9cfdc3a6 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java
index 49b59d39..9fdccbb5 100644
--- a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java
+++ b/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java
@@ -1,6 +1,4 @@
-/*
- *
- * Licensed to the Apache Software Foundation (ASF) under one or more
+/* * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
  * licenses this file to You under the Apache License, Version 2.0 (the
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java b/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java
index d796faac..4343e485 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java
index 5d415926..85d35c66 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java
index d951c5be..251a9fff 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java
index 7d8ae3b4..ec63a2be 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java
index 28b613ad..d8bec76c 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java
index 3dbca1f9..2506439e 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java
index 232da2ed..77cf1c85 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java
index fdc14dd1..a825a1b4 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java
index 4f3a20d2..490acedc 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java
index b8efa570..ce7a0b20 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java
index 26fdbc93..48e2a784 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java
index f6765ef5..a3e677ad 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java
index 1fff8f1b..13ca86a8 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java
index 527e814a..46f89edd 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java
index 7fc278d9..9374264a 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java
index 526ebde8..93b9621c 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java
index fea86acc..939e8a4e 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java
index e5aa6630..aa4d47ed 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java
index f664ffd3..d8130d4f 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java
index 672879a6..e3b310fc 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java
index 0b194370..73658f0a 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java
index ffa28067..5f7cd389 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java
index bcc2fb94..2165a6ea 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java
index e2dde4e4..f28f0208 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java
index 7a7122ea..5ad986b6 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java
index 93e25474..42b3bdf0 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java
index 493e6958..fb903dd5 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java
index 4e31f9e2..25a60cd0 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java
index 0e33de19..f42724d1 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java
index e7f03d01..199f40fe 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java
index 9ea2d8b2..b59e681d 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java
index b04f6e3a..4f73d650 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java
index 857d4e27..e4f6ac98 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java
index 4a32fcdc..2f9284e7 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java
index 41abc33e..c7965386 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java
index 755c08da..b88a0108 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java
index b1668b86..d7f12894 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java
index 2165bc2b..2e68ea49 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java
index 996113d0..f55e19ba 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java
index e2e4f68d..3260e37c 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java
index 1485bfb2..16f009bb 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java
index a6ff129e..ca3540e1 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java
index a05097ef..7b4267f8 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java
index 017ef146..bab4ba53 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java
index 199c709f..4813ec19 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java
index f7aedc6c..9ffc0151 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java
index d6dc4396..d9784785 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java
index f33a07c7..d3eb872d 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java
index 8ca344a2..f5049c23 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java
index 01190d2f..840bf3ff 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java
index abd5a9a6..641486a9 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java
@@ -1,5 +1,4 @@
 /*
- *
  *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java
index b97e9e60..a655040f 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java
index e6c14e67..bbb174a5 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java
index cc3bce2e..76df3e8e 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java
index 912f3ea5..a3e4983a 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java
index 9db2e69e..9691b4be 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java
index a2ddebac..fe994ae6 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java
index 07352014..4062097f 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java
index 550da4c3..e6fd3280 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java
index 00c97013..ca35a080 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java
index a5d26395..0b2e15e8 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java
index 2261767d..f42eaf5d 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java
index 89bd5828..01c7b4d8 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java
index f4dd445b..1908e484 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java
index 4094a1ec..87ce65ce 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java
index 22472d09..1d035144 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java
index 0f62fdcb..8664e61e 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java
index 8ff689b1..5923c663 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/AbstractComputerOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/AbstractComputerOutput.java
index c7b69f60..06881394 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/AbstractComputerOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/AbstractComputerOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/ComputerOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/ComputerOutput.java
index 00be98d9..c2c2cc20 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/ComputerOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/ComputerOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java
index 93da8ca6..f5994b12 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/exceptions/WriteBackException.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/exceptions/WriteBackException.java
index 29dec486..4558b274 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/exceptions/WriteBackException.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/exceptions/WriteBackException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java
index 23805394..2a1a559e 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java
index ede61857..2fd18810 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java
index 0c9eff98..38676098 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java
index ea7d49a9..bc6b258c 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/BatchInsertTask.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/BatchInsertTask.java
index 6778a252..69d99ed1 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/BatchInsertTask.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/BatchInsertTask.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java
index 16f3c269..251ed495 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/SingleInsertTask.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/SingleInsertTask.java
index c6e52ca8..f823a24d 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/SingleInsertTask.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/SingleInsertTask.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/TaskManager.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/TaskManager.java
index 3fcb4418..241ffdd9 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/TaskManager.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/TaskManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java
index c5ed913d..fb07abac 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java
index ae7bdac3..03e9295a 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java
index 1c2552e8..e6dad032 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java
index 2e3fb910..19fbaf1e 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java
index 16a46226..590f3417 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java
index 4e3fd426..dc9882d3 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java
index 19983f8b..2e5a5319 100644
--- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java
+++ b/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java
index 3ba6b852..54ca9562 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java
index c916039a..0178a129 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java
index f39fce39..b4a302bf 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java
index e31152ed..3b2e943c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java
index 3187959e..a05299e8 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java
index 101194f1..362b7789 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java
index dfaa498b..33250ebd 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java
index 33964447..b19ae530 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java
index 431ce020..99ba7038 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java
index da09b069..66a3fd93 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java
index c0f4d968..4fb0d2da 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java
index 8f646e67..252cd977 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java
index 375931df..59ca489b 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java
index 5dbe3a11..c4681be1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java
@@ -1,5 +1,4 @@
 /*
- *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
  *  work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java
index 79bc69bd..56c60679 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java
index a9c44727..356cda38 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java
index 8c834ba3..6ed80f90 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java
index 372a4413..1299dd9e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java
@@ -1,6 +1,5 @@
 package org.apache.hugegraph.computer.core.combiner;
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java
index 7e14621b..7273e550 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java
index 91b879c8..9c44390d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java
index 161f4be0..48f80fdb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java
index 44f3ac5c..d21dd8cf 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java
index aa97369c..85227cd8 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java
index 09b3998c..80b46af6 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java
index edec26de..685f47b9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java
index bfd98089..25312868 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java
index ba8080a3..3c36b5c2 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java
index 7c78def1..26c32992 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java
index f79f1981..3d4a2375 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java
index a97d3d8b..39374a6a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java
index 6f889038..0c52af4a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java
index 93b35e0e..fa7fb3b5 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java
index 7e85f50d..e074a209 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java
index a603e358..b691ff81 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java
index 2dd72315..7e734226 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java
index 2d682230..1b54310a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java
index 2f53e896..a47e4d8c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java
index a132b3a3..504c76be 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java
index 54bdfe33..e2f31f7a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java
index d9a78a37..7bde2b60 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java
index 0a88feb9..eade29d9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java
index 8dea4974..28328950 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java
index 060bb346..dd94dabc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java
index 469459c5..6e3b83da 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java
index eedf362a..f53ce387 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java
index 6abca83b..c62e21d0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java
index 90e70192..83141254 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java
index 9ecfd360..b6c47966 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java
index de5fd790..4b101740 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java
index fdfda404..f9dbd37b 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java
index e8d2a4d4..34a1352d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java
index 06f10ad0..b0ad6496 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java
index 0112e50f..201dd2ba 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java
index 8a3484d3..2cb024f6 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java
index ebf0545d..b14ed39c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java
index 868b825a..e39f1481 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java
index c187e8aa..49d99202 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java
index 117be2b5..cc6a65f9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java
index e6b021a3..ce003b55 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java
index bb975b74..eaa87bfb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java
index 57f53d70..e5c02f29 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java
index a7dececa..4d7b5433 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java
index 7c4d5faa..40e9bf5a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java
index 09c796a9..310cdd8d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java
index 6d6c916c..2c2775f1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java
index f8f44a62..04673133 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java
index b4c07165..98d5763d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java
index 2eb3f0bc..3136c3d4 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java
index 8530d351..e4382d95 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java
index 5c11dc91..f2f7598e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java
index 2be06227..9863dec9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java
index b8ec96d0..6c50cac4 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java
index bed37a9e..db1722ac 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java
index 9b378690..17f03828 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java
index 04ff3680..f08d731a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java
index 61b8a9b7..1e57c7da 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java
index 6664dcd0..7cd04d18 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java
index 54bb88b6..0ca08e02 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java
index 71d23633..4b79d35d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java
index 1ffaf90c..285a92cf 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java
index e31f0fea..aa548f27 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java
index 72965f1b..830162e6 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java
index 8147f905..c2806faa 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java
index 2a8f53c0..3acd6dc1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java
index 55a3ba01..fd1fdfd3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java
index 40e3e51a..e2df72ea 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java
index 78c6e283..de0ae9f1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java
index 8a8e7fb2..7d3a5593 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java
index 343f2bde..34f7043a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java
index cd5ef2f8..263935bc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java
index b5d851b9..aff65a74 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java
index 2d3837ca..eca40286 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java
index 829fa04f..980e1a20 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java
index 33801045..4cc858db 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java
index ef2bddff..58fd8c7d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java
index f1a46950..ebd11e13 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java
index 17dfd3a5..6d2fdf64 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java
index 67c1a3ff..ff269a70 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java
index c93e5e25..9c27f249 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java
index 1e1c22dd..ce196146 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java
index 75f80b7e..ce06c39b 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java
index 42933b70..8b9aba64 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java
index 4b839564..6b1e57eb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java
index 148f0a78..d25e18f5 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java
index c4bc6c64..692c1b95 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java
index ff148db2..89824876 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java
index 2f653d7c..cc11aaed 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java
index 6f749969..44d81066 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java
index 7e08ba4a..5deed75b 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java
index 836daa7e..1bffd0ad 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java
index e36434c3..aac18fd0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java
index ddbeaad0..44758ab9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java
index 84b088dc..31a5a845 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java
index 3ffe2692..b4cc4de3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java
index cff787d1..c5fb7a35 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java
index d4c106ba..4f07e02d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java
index 96924aa0..6224f3f0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java
index 530b1855..7d2cb6ab 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java
index ed43642b..c3715574 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java
index 8337793e..16d6889d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java
index 5e9a43c4..2caaa40f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java
index 0f1050da..8e27296c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java
index 92631f9c..3a053db0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java
index fce5e859..b0585e17 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java
index 8b9e3717..66222595 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java
index 289480fe..53ba15c2 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java
index 167209d4..b7e873fe 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java
index a05f6897..734342fc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java
index c873feea..30d0a5d0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java
index 39f4a421..42f6ea43 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java
index fac46b76..015fce59 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java
index 849759a1..8f49a1c0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java
index eeae945d..afb16297 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java
index fc00ae66..6f904d88 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java
index c34161c5..c3eaa0f9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java
index aeb0e2ed..a9364fbc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LimitedLogOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LimitedLogOutput.java
index 9df7f51b..dca6aea1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LimitedLogOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LimitedLogOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LogOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LogOutput.java
index 332d0503..ecc7ddf0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LogOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LogOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java
index 12cedcc3..0cce6e6c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java
index b612524d..5b107caf 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java
index 901b7754..b948eb81 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java
index d50394f2..11664fbc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java
index 2e5e2e2c..beafe184 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java
index f05f5e97..f480cd76 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java
index 195d09b9..d155d80a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphStringOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphStringOutput.java
index 4466d178..db2fcdb5 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphStringOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphStringOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java
index ae02a6d9..a9b71c01 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java
index c1e72dc5..5e51320a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java
index 43bba022..d63d5dab 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java
index e6b442a2..362b1425 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java
index 3f79ad6d..20f9aa1a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java
index 4ffdbf22..043bdd0e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java
index 13326d84..705a1a20 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java
index 11d4730f..c31f99bc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java
index 7f804e6f..618f4e43 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java
index 563f0b8a..952dc77c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java
index 71ecd66c..7046f3fa 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java
index 3d6c42bc..888706db 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java
index a256c1b8..46add8cb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java
index 642c499c..97657c21 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java
index 508f494c..809f82a9 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java
index 7588c160..43d50e2f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java
index 88d3222a..8a702cd5 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java
index f5e11b3e..ee981c02 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java
index 5dd7f852..8d65e9fc 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java
index 804d5c63..864951e8 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java
index 6139695b..78c143ae 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java
index eadc576b..7401daea 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java
index 55ff35b7..810d3b9a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java
index a17ea041..dac165fb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java
index b399aa71..32221735 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java
index 76821d6c..df467101 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java
index 7283d2e7..933cec79 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java
index 27b10665..7414727a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java
index a78e75fc..af3adc74 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java
index b779f11e..d1c4cc7f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java
index d63a0cc6..68e0f1a3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java
index e190dbd5..8041f1be 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java
index 64f16c02..3b807515 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java
index 164b60d5..ddbe7f93 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java
index a7199f31..6a65e32e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java
index 6ff48c19..129e38e6 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java
index 1ccb28f3..8a48eca8 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java
index c7245b20..be5a62c1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java
index 0709164b..cb76e8c7 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java
index 15c96301..e3954b50 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java
index 531366a4..1b85bd4c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java
index 4b217ce7..fccbb998 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java
index b7a487b2..5d09e786 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java
index d623c584..637bf12a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java
index 363b63e5..45f40e7e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java
index de28b296..d5e7528e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java
index aa7ef17d..b7d20bc1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java
index bbac0028..87ef42b2 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java
index a16cb3f6..359ee7ba 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java
index a65cfe0f..88b64c87 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java
index 5237084c..8479714f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java
index 2d76f66a..fa524782 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java
index 12b9f512..37c71cfa 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java
index 018df02a..124a02ab 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java
index a97274bc..50a06482 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java
index 1110e640..a471c545 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java
index cf2e0b2e..32c9f335 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java
index 2216de0f..29b9be72 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java
index f17124dd..b969aefa 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java
index d05518d8..eca38535 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java
index 02e30ab7..0291667a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java
index ab23dca4..2cc79659 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java
index c37a5604..665f9ec0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java
index cb7fa639..9f05e64e 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java
index 67a1ed3a..ccf2f8bd 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java
index 846f94af..cf9cadaa 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java
index 96815947..0570edef 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java
index 2b031b86..06798cbb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java
index 1bace812..a13afbc0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java
index ccea2b55..03d1abdd 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java
index 2e58d7d8..48197c16 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java
index c75cacf3..dae29884 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java
index 303e36dc..c28462bf 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java
index 1037e47f..3ccec02c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java
index 1bb22b3f..14b62459 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java
index 0b2cf1bf..edb8def3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java
index ad7d8476..d03b2252 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java
index b5338a88..fee7fef2 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java
index 5e7d5b95..73a64565 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java
index 321ad081..afec090d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java
index 964f8542..b6db9648 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java
index 1376359c..a5a9f877 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java
index c464f376..6cf715f2 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java
index ce6fdc39..5e185c8a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java
index d23cb685..9d3b4324 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java
index d9e21bd3..165abc02 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java
index 04ec20a1..eb78a770 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java
index ceecac24..03f56d48 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java
index f8078aa4..24957395 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java
index 398c0e15..3e4ae340 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java
index 94527b33..8ff1dc19 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java
index c9d3a42e..d78dd2de 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java
index b1492e4f..90e304d3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java
index a44e57f0..1a3b17ff 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java
index ffb7792b..685c3c6f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java
index f3fd68bf..8f82b5e3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java
index cacb04bd..a7910205 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java
index 29101638..b769855f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java
index 9db3f975..45370ceb 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java
index fb21c63f..7c9fe15b 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java
index 19600ed3..08d04915 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java
index 0d5d77ef..b180c032 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java
index ed9a3e43..5484d7e5 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java
index 3ad1aa0c..ea7306e1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java
index 58ac3826..2fdf220a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java
index 011daacf..6d72c79a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java
index 99d11987..d4d448be 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java
index a8f6a33a..714da3e3 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java
index 1d62756a..acea3e0c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java
index 095f474c..7327c7b1 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java
index 1d963cb7..70efbd43 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java
index d3f5b557..5630fef0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java
index f55c6fbc..4f3e544a 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java
index 7576442a..9ec6cfca 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java
index 02804f27..6e014b9f 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java
index 4dae830a..3a86e286 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java
index 0b4f80b9..7dfb6d7c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java
index 9f033a95..5726313d 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncoding.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncoding.java
index 2b9d3aa4..497fbb84 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncoding.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncoding.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java
index c21975c2..901d9ad2 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java
index e7765e41..40491f2c 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java b/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java
index 3614ad27..230f3eb0 100644
--- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java
+++ b/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-dist/src/assembly/dataset/load-movie-data.groovy b/computer-dist/src/assembly/dataset/load-movie-data.groovy
index 700082d8..683db53e 100644
--- a/computer-dist/src/assembly/dataset/load-movie-data.groovy
+++ b/computer-dist/src/assembly/dataset/load-movie-data.groovy
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-dist/src/assembly/dataset/schema.groovy b/computer-dist/src/assembly/dataset/schema.groovy
index d0b39544..80b4a8b5 100644
--- a/computer-dist/src/assembly/dataset/schema.groovy
+++ b/computer-dist/src/assembly/dataset/schema.groovy
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java
index f253afe6..caad7624 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java
index 7c2713f5..365272e3 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java
index 2d532cb6..f0f0002e 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java
index fa78d93d..641b9aa3 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java
index f964ce1c..40ca9695 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java
index ad412879..8131ff98 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java
index dddfd0cc..e587265f 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java
index 397c4cd5..358f72fc 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java
index 7a990c7e..78d93ed9 100644
--- a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java
+++ b/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java
index 1f7e726a..9934f513 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java
index 003abd0b..bad4566e 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java
index 8ee2f263..181c46de 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java
index 6be1febf..5236bba6 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java
index 33fcf35e..ec9164cb 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java
index 836a2ff7..4d82ddf0 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java
index 63ab7b7d..677c7cc1 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java
index 37738648..035967ea 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java
index 4057ff1c..353eda3a 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java
index 6f546a95..9d3aa61e 100644
--- a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java
+++ b/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java
index 13214fb9..ef9300c9 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java
index 45c6369d..7715bc8a 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java
index 78898bdf..e7308cbd 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java
index 6757e896..97a743d6 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java
index 78d32141..2cda5832 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java
index 85ff6433..a1e6bb2a 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java
index 130091d4..c76438f5 100644
--- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java
+++ b/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java
index 6a02eb7e..a499abdf 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java
index 38943eb8..ad0fc946 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java
index 9e57f76a..6ad54e95 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java
index 289f99f6..d66b01a8 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java
index 8b8e8d57..b24640d8 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java
index c6255819..ddea5806 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java
index f9172a2c..63d88e4a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java
index d251483a..919a5460 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java
index e22d6722..d4ba4d2f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java
index 8b876cea..cece925c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java
index e05d70ea..d1c10dec 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java
index ee5a51ee..81422320 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java
index 5af24213..56d687c9 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java
index 48c66656..86ee2338 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java
index 3555f7ae..7100119e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java
index 4576b660..313a594a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java
index 55716161..1997b201 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java
index a3c07e92..d1df1bc3 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
  *  work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java
index 5e7dce3e..9e9187f8 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java
index 3aa4d7e3..6b4c0849 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java
@@ -1,5 +1,4 @@
 /*
- *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
  *  work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java
index 8e73a1ee..611d5277 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java
index b5aed892..7ea60069 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java
index 3e8de587..9af9084a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java
index 07da9be5..a8cd0154 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java
index 2e20014b..925c7a74 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java
index 5011c56d..740a8b04 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java
index eb2f45f3..c68f6407 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java
index f86b489a..8de00044 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java
index 32a0e5b9..7beb32cf 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java
index 59d2e793..a452053b 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java
index c8917d17..6d23f43a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java
index 29bb8719..ef150e79 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java
index ab9bf04b..35eb303a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java
index b4b6e5a5..7f4f86e1 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java
index 810432eb..cbc2cea4 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java
index ce8b8658..c4052497 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java
index 9c782f88..ae5d3f8d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java
index 2cba7690..64792c5a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java
index 91929dbc..3535fd8a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java
index 36fab905..c2126d1b 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java
index 1ea34cc9..36361380 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java
index eb677191..7edc0b2f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java
index 6bd51715..78dd9439 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java
index 29e7e737..efec818f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java
index 4e085ccb..dd377c0c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java
index e5712a36..bd3b1f0b 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java
index fc7bc25a..54725b5d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java
index ea724a38..43dd38f3 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java
index b7cef9bf..1f2f2a38 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java
index d1c4eeb2..8e450875 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java
index b383ba30..c95ea8bf 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java
@@ -1,5 +1,4 @@
 /*
- *
  *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java
index 182fcb1b..344f5bd9 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java
@@ -1,5 +1,4 @@
 /*
- *
  *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java
index 18f403e6..9c302d8e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java
index d29832ba..e5a58082 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java
index 07d6e2c2..f87b069c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java
index 97135cff..7651f2b9 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java
index 8128dd42..f014ef84 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java
index 467ea6b8..5d637c0d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java
index fbd8ec9d..9fbc9045 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java
index 7d0897a6..9d0a7f34 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java
index d52d8719..68e5ea89 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java
index f31f5195..1f44d897 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java
index 17f9ea80..aba80b3a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java
index 5908ccb8..119a0d78 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java
index 8e50cd77..5d96160f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java
index 47acb699..c91d45df 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java
@@ -1,5 +1,4 @@
 /*
- *
  *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java
index ec2b211c..2635e73d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java
index dd797774..cc58f2a3 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java
index 72b113bf..d334a31f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java
index 49f4998d..70c7f866 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java
index 76ee2405..d83e9023 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java
index 061082ce..baf181ad 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java
index a6fd265e..4b6cf051 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java
index 5a8f9483..e9b6cda9 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java
index ca15c553..ab4805ed 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java
index 54bb381a..059ffe96 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java
index 1500d72b..32732cd5 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java
index cb4ad3cc..43fb3260 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  *
  *  Licensed to the Apache Software Foundation (ASF) under one or more
  *  contributor license agreements. See the NOTICE file distributed with this
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java
index fc8dfa83..99f89ae7 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java
index f78bfd07..69320720 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java
index 14cb0bf2..1fa33a43 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java
index 5d4b1388..0c3af035 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java
index ca803d21..45f01a3e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java
index 3dcb066a..27637778 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java
index 4b6fbd3d..382decee 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java
index 194e1720..89029ec1 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java
index f27631a1..19408974 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java
index 687c253e..0d86c336 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java
index 8406da4b..c1a38e13 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java
index 724f5fa8..e0a52c1e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java
index e6fdc412..df7f70c4 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java
index f27cd593..ac87f1fa 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java
index 525e24b7..503e3aed 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java
index 5993bf2b..c1e45f6f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java
index 20926a19..5bef2b2c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java
index 4e64d20b..a558080c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java
index bcfe1072..4ecd649d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java
index 818987b1..acf48bab 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java
index 70bd1b79..58ce87b7 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java
index 1c7e1d65..09f4378f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java
index a638c77c..7a78cfeb 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java
index da2f7826..3942b4ef 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java
index f4e66aa8..19a89fbe 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java
index d7b40365..d17d2443 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java
index 198ff423..28e6b520 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java
index f85a68c9..e23992be 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java
index de6e8d7f..185d4335 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java
index 7c84f0f1..37db2a01 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java
index 171aa482..6f644d01 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java
index e9bf07ed..6fdeca3f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java
index 404ca676..e8ca4653 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java
index bf80f480..08d930c7 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java
index 7fb73929..07fd1592 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java
index 5c898e27..50f8a0aa 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java
index d4b82222..36e57a3e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java
index cdc03213..2d00f43f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java
index bfa48beb..c37ba854 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java
index 61e9b113..30cc9f29 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java
index 74584457..76432971 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java
index dea38bcb..a650c8ed 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java
index 6777b2a7..28962d9f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java
index ac71cae4..b80262ac 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java
index c3d4695c..f41e89bd 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java
index 2734de95..5b5ef42c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java
index bd86c2e7..86daee80 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java
index e60bd4d5..fe1f622a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java
index 56b9fc39..420a60da 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java
index 9929fd02..173e9d25 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java
index 6075ca22..3dd2a80c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java
index 0dff6398..122d40ff 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java
index fc31edf5..03dbd543 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java
index 8003cf69..5b1b8ac6 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java
index d3c4710b..6d6b074f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java
index bd6ba49b..f24387c1 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java
index 35fc1b2a..7ff80b20 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java
index 9c1d0719..7ae88a25 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java
index 9b52c31d..a83093fc 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java
index 6754fecb..7eb46b3a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java
index e017f51f..af5cea0a 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java
index 8fa21fb4..7f542de6 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java
index a3e50e28..afde7358 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java
index 79b6f400..24302f5e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java
index b72e9749..8d1a707d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java
index e4392d44..3f72b633 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java
index 2b100def..2a05d6b6 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java
index 94c86a35..b86973df 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java
index 94570f36..74d3c5e5 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java
index cb2f9c77..b056c7d5 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java
index d499276c..9dcda046 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java
index d4399452..a10c3a64 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java
index 88c7e1ba..ebdf1f4d 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java
index da69ec74..429aa75f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java
index 51ee14c0..c74822ef 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java
index 4a8d17f2..bfcc2e4c 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java
index 0c48cf91..5a9b303e 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java
index 1d2f3541..a9a294aa 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java
index 4e862c23..71b5b5b2 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java
index 8dd50535..1f6a3469 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java
index ec9837b8..8b630ba8 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java
index 62654a0f..c4162b5f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java
index f1eb8a23..492aea73 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java
index 33dc6186..e5763402 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java
index 02a71f95..6ae0008b 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java
index d8bbc6a3..7aabea3f 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF
diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java
index 439959b5..62dec2cf 100644
--- a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java
+++ b/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java
@@ -1,5 +1,4 @@
 /*
- *
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements. See the NOTICE file distributed with this
  * work for additional information regarding copyright ownership. The ASF