From 8b456183a7dfb569765f4bd4d5bad201b2831afb Mon Sep 17 00:00:00 2001 From: coderzc Date: Tue, 20 Aug 2024 12:24:08 +0800 Subject: [PATCH] Migrate project to computer directory --- .github/workflows/ci.yml | 1 + .../core/output/AbstractComputerOutput.java | 52 - .../computer/core/output/ComputerOutput.java | 66 - .../core/output/hg/HugeGraphOutput.java | 104 -- .../hg/exceptions/WriteBackException.java | 39 - .../core/output/hg/metrics/LoadMetrics.java | 47 - .../core/output/hg/metrics/LoadReport.java | 40 - .../core/output/hg/metrics/LoadSummary.java | 71 -- .../core/output/hg/metrics/Printer.java | 56 - .../core/output/hg/task/BatchInsertTask.java | 101 -- .../core/output/hg/task/InsertTask.java | 79 -- .../core/output/hg/task/SingleInsertTask.java | 60 - .../core/output/hg/task/TaskManager.java | 187 --- .../core/output/LimitedLogOutput.java | 56 - .../computer/core/output/LogOutput.java | 42 - .../computer/core/output/hdfs/HdfsOutput.java | 174 --- .../core/output/hdfs/HdfsOutputMerger.java | 88 -- .../core/output/hg/HugeGraphDoubleOutput.java | 30 - .../core/output/hg/HugeGraphFloatOutput.java | 30 - .../core/output/hg/HugeGraphIdOutput.java | 37 - .../core/output/hg/HugeGraphIntOutput.java | 30 - .../core/output/hg/HugeGraphLongOutput.java | 30 - .../core/output/hg/HugeGraphStringOutput.java | 30 - .../computer/dist/HugeGraphComputer.java | 151 --- .../computer/dist/ComputerDistTestSuite.java | 27 - .../computer/dist/HugeGraphComputerTest.java | 103 -- computer/README.md | 44 + .../computer-algorithm}/pom.xml | 0 .../betweenness/BetweennessCentrality.java | 0 .../BetweennessCentralityParams.java | 0 .../betweenness/BetweennessMessage.java | 0 .../betweenness/BetweennessValue.java | 0 .../closeness/ClosenessCentrality.java | 0 .../closeness/ClosenessCentralityParams.java | 0 .../closeness/ClosenessMessage.java | 0 .../centrality/closeness/ClosenessValue.java | 0 .../centrality/degree/DegreeCentrality.java | 0 .../degree/DegreeCentralityParams.java | 0 .../centrality/pagerank/PageRank.java | 0 .../centrality/pagerank/PageRank4Master.java | 0 .../centrality/pagerank/PageRankParams.java | 0 .../community/cc/ClusteringCoefficient.java | 0 .../cc/ClusteringCoefficientOutput.java | 0 .../cc/ClusteringCoefficientParams.java | 0 .../cc/ClusteringCoefficientValue.java | 0 .../algorithm/community/kcore/Kcore.java | 0 .../community/kcore/KcoreParams.java | 0 .../algorithm/community/kcore/KcoreValue.java | 0 .../computer/algorithm/community/lpa/Lpa.java | 0 .../algorithm/community/lpa/LpaParams.java | 0 .../trianglecount/TriangleCount.java | 0 .../trianglecount/TriangleCountParams.java | 0 .../trianglecount/TriangleCountValue.java | 0 .../computer/algorithm/community/wcc/Wcc.java | 0 .../algorithm/community/wcc/WccParams.java | 0 .../algorithm/path/rings/RingsDetection.java | 0 .../path/rings/RingsDetectionOutput.java | 0 .../path/rings/RingsDetectionParams.java | 0 .../path/rings/filter/FilterDescribe.java | 0 .../rings/filter/RingsDetectionMessage.java | 0 .../filter/RingsDetectionWithFilter.java | 0 .../RingsDetectionWithFilterParams.java | 0 .../path/rings/filter/SpreadFilter.java | 0 .../algorithm/path/shortest/QuantityType.java | 0 .../shortest/SingleSourceShortestPath.java | 0 .../SingleSourceShortestPathCombiner.java | 0 .../SingleSourceShortestPathMaster.java | 0 .../SingleSourceShortestPathOutput.java | 0 .../SingleSourceShortestPathParams.java | 0 .../SingleSourceShortestPathValue.java | 0 .../algorithm/sampling/RandomWalk.java | 0 .../algorithm/sampling/RandomWalkMessage.java | 0 .../algorithm/sampling/RandomWalkOutput.java | 0 .../algorithm/sampling/RandomWalkParams.java | 0 .../computer-api}/pom.xml | 0 .../computer/algorithm/AlgorithmParams.java | 0 .../computer/core/aggregator/Aggregator.java | 0 .../core/aggregator/Aggregator4Master.java | 0 .../core/aggregator/Aggregator4Worker.java | 0 .../computer/core/allocator/Allocator.java | 0 .../computer/core/allocator/Recyclable.java | 0 .../core/allocator/RecyclerReference.java | 0 .../computer/core/combiner/Combiner.java | 0 .../core/combiner/DoubleValueSumCombiner.java | 0 .../core/combiner/FloatValueSumCombiner.java | 0 .../core/combiner/IdListMergeCombiner.java | 0 .../core/combiner/IdSetMergeCombiner.java | 0 .../core/combiner/IntValueSumCombiner.java | 0 .../core/combiner/LongValueSumCombiner.java | 0 .../combiner/MergeNewPropertiesCombiner.java | 0 .../combiner/MergeOldPropertiesCombiner.java | 0 .../core/combiner/OverwriteCombiner.java | 0 .../combiner/OverwritePropertiesCombiner.java | 0 .../core/combiner/PropertiesCombiner.java | 0 .../core/combiner/ValueMaxCombiner.java | 0 .../core/combiner/ValueMinCombiner.java | 0 .../computer/core/common/ComputerContext.java | 0 .../computer/core/common/Constants.java | 0 .../computer/core/common/SerialEnum.java | 0 .../common/exception/ComputerException.java | 0 .../computer/core/config/ComputerOptions.java | 0 .../computer/core/config/Config.java | 0 .../computer/core/config/DefaultConfig.java | 0 .../computer/core/config/EdgeFrequency.java | 0 .../computer/core/config/HotConfig.java | 0 .../hugegraph/computer/core/config/Null.java | 0 .../computer/core/graph/GraphFactory.java | 0 .../computer/core/graph/edge/Edge.java | 0 .../computer/core/graph/edge/Edges.java | 0 .../hugegraph/computer/core/graph/id/Id.java | 0 .../computer/core/graph/id/IdFactory.java | 0 .../computer/core/graph/id/IdType.java | 0 .../graph/properties/DefaultProperties.java | 0 .../core/graph/properties/Properties.java | 0 .../core/graph/value/BooleanValue.java | 0 .../core/graph/value/DoubleValue.java | 0 .../computer/core/graph/value/FloatValue.java | 0 .../computer/core/graph/value/IdList.java | 0 .../computer/core/graph/value/IdListList.java | 0 .../computer/core/graph/value/IdSet.java | 0 .../computer/core/graph/value/IntValue.java | 0 .../computer/core/graph/value/ListValue.java | 0 .../computer/core/graph/value/LongValue.java | 0 .../computer/core/graph/value/MapValue.java | 0 .../computer/core/graph/value/NullValue.java | 0 .../core/graph/value/StringValue.java | 0 .../computer/core/graph/value/Value.java | 0 .../computer/core/graph/value/ValueType.java | 0 .../computer/core/graph/vertex/Vertex.java | 0 .../computer/core/input/InputFilter.java | 0 .../computer/core/io/BytesInput.java | 0 .../computer/core/io/BytesOutput.java | 0 .../computer/core/io/GraphComputeInput.java | 0 .../computer/core/io/GraphComputeOutput.java | 0 .../computer/core/io/GraphInput.java | 0 .../computer/core/io/GraphOutput.java | 0 .../core/io/GraphWritebackOutput.java | 0 .../computer/core/io/RandomAccessInput.java | 0 .../computer/core/io/RandomAccessOutput.java | 0 .../hugegraph/computer/core/io/Readable.java | 0 .../hugegraph/computer/core/io/Writable.java | 0 .../core/master/DefaultMasterComputation.java | 0 .../core/master/MasterComputation.java | 0 .../core/master/MasterComputationContext.java | 0 .../computer/core/master/MasterContext.java | 0 .../computer/core/util/BytesUtil.java | 0 .../computer/core/util/CoderUtil.java | 0 .../hugegraph/computer/core/util/IdUtil.java | 0 .../computer/core/util/JsonUtilExt.java | 0 .../computer/core/worker/Computation.java | 0 .../core/worker/ComputationContext.java | 0 .../core/worker/FilterComputation.java | 0 .../core/worker/ReduceComputation.java | 0 .../computer/core/worker/WorkerContext.java | 0 .../computer-core}/pom.xml | 0 .../computer/core/aggregator/Aggregators.java | 0 .../core/aggregator/DefaultAggregator.java | 0 .../core/aggregator/MasterAggrManager.java | 0 .../core/aggregator/RegisterAggregators.java | 0 .../core/aggregator/WorkerAggrManager.java | 0 .../core/allocator/DefaultAllocator.java | 0 .../core/allocator/RecycleHandler.java | 0 .../computer/core/bsp/Bsp4Master.java | 0 .../computer/core/bsp/Bsp4Worker.java | 0 .../hugegraph/computer/core/bsp/BspBase.java | 0 .../computer/core/bsp/BspClient.java | 0 .../hugegraph/computer/core/bsp/BspEvent.java | 0 .../computer/core/bsp/EtcdBspClient.java | 0 .../computer/core/bsp/EtcdClient.java | 0 .../combiner/AbstractPointerCombiner.java | 1 - .../core/combiner/EdgeValueCombiner.java | 0 .../core/combiner/MessageValueCombiner.java | 0 .../core/combiner/PointerCombiner.java | 0 .../core/combiner/VertexValueCombiner.java | 0 .../computer/core/common/ContainerInfo.java | 1 - .../common/exception/IllegalArgException.java | 0 .../core/common/exception/ReadException.java | 0 .../common/exception/TransportException.java | 0 .../core/common/exception/WriteException.java | 0 .../computer/core/compute/ComputeManager.java | 0 .../core/compute/FileGraphPartition.java | 0 .../core/compute/input/EdgesInput.java | 0 .../core/compute/input/MessageInput.java | 0 .../core/compute/input/ReusablePointer.java | 1 - .../core/compute/input/VertexInput.java | 0 .../core/graph/BuiltinGraphFactory.java | 0 .../computer/core/graph/SuperstepStat.java | 1 - .../computer/core/graph/edge/DefaultEdge.java | 0 .../core/graph/edge/DefaultEdges.java | 0 .../computer/core/graph/id/BytesId.java | 0 .../core/graph/partition/HashPartitioner.java | 0 .../core/graph/partition/PartitionStat.java | 1 - .../core/graph/partition/Partitioner.java | 0 .../core/graph/vertex/DefaultVertex.java | 0 .../computer/core/input/EdgeFetcher.java | 0 .../computer/core/input/ElementFetcher.java | 0 .../computer/core/input/GraphFetcher.java | 0 .../computer/core/input/HugeConverter.java | 0 .../hugegraph/computer/core/input/IdUtil.java | 0 .../core/input/InputSourceFactory.java | 0 .../computer/core/input/InputSplit.java | 0 .../core/input/InputSplitFetcher.java | 0 .../core/input/MasterInputHandler.java | 0 .../core/input/MasterInputManager.java | 0 .../computer/core/input/VertexFetcher.java | 0 .../core/input/WorkerInputManager.java | 0 .../core/input/filter/DefaultInputFilter.java | 0 .../filter/ExtractAllPropertyInputFilter.java | 0 .../core/input/hg/HugeEdgeFetcher.java | 0 .../core/input/hg/HugeElementFetcher.java | 0 .../core/input/hg/HugeGraphFetcher.java | 0 .../core/input/hg/HugeInputSplitFetcher.java | 0 .../core/input/hg/HugeVertexFetcher.java | 0 .../core/input/loader/FileEdgeFetcher.java | 0 .../core/input/loader/FileElementFetcher.java | 0 .../core/input/loader/FileInputSplit.java | 0 .../core/input/loader/FileVertxFetcher.java | 0 .../loader/LoaderFileInputSplitFetcher.java | 0 .../core/input/loader/LoaderGraphFetcher.java | 0 .../core/io/AbstractBufferedFileInput.java | 0 .../core/io/AbstractBufferedFileOutput.java | 0 .../computer/core/io/BufferedFileInput.java | 0 .../computer/core/io/BufferedFileOutput.java | 0 .../computer/core/io/BufferedStreamInput.java | 0 .../core/io/BufferedStreamOutput.java | 0 .../core/io/CsvStructGraphOutput.java | 0 .../hugegraph/computer/core/io/IOFactory.java | 0 .../core/io/JsonStructGraphOutput.java | 0 .../computer/core/io/OptimizedBytesInput.java | 0 .../core/io/OptimizedBytesOutput.java | 0 .../computer/core/io/OutputFormat.java | 0 .../computer/core/io/StreamGraphInput.java | 0 .../computer/core/io/StreamGraphOutput.java | 0 .../computer/core/io/StructGraphOutput.java | 0 .../core/io/StructRandomAccessOutput.java | 0 .../computer/core/io/UnsafeBytesInput.java | 0 .../computer/core/io/UnsafeBytesOutput.java | 0 .../computer/core/manager/Manager.java | 0 .../computer/core/manager/Managers.java | 0 .../computer/core/master/MasterService.java | 0 .../computer/core/network/ClientFactory.java | 0 .../computer/core/network/ClientHandler.java | 0 .../computer/core/network/ConnectionId.java | 0 .../core/network/DataClientManager.java | 0 .../core/network/DataServerManager.java | 0 .../computer/core/network/IOMode.java | 0 .../computer/core/network/MessageHandler.java | 0 .../core/network/TransportClient.java | 0 .../computer/core/network/TransportConf.java | 0 .../core/network/TransportHandler.java | 0 .../core/network/TransportProvider.java | 0 .../core/network/TransportServer.java | 0 .../computer/core/network/TransportState.java | 0 .../computer/core/network/TransportUtil.java | 0 .../core/network/buffer/FileRegionBuffer.java | 0 .../core/network/buffer/NettyBuffer.java | 0 .../core/network/buffer/NetworkBuffer.java | 0 .../core/network/buffer/NioBuffer.java | 0 .../network/connection/ConnectionManager.java | 0 .../TransportConnectionManager.java | 0 .../core/network/message/AbstractMessage.java | 0 .../core/network/message/AckMessage.java | 0 .../core/network/message/DataMessage.java | 0 .../core/network/message/FailMessage.java | 0 .../core/network/message/FinishMessage.java | 0 .../core/network/message/Message.java | 0 .../core/network/message/MessageType.java | 0 .../core/network/message/PingMessage.java | 0 .../core/network/message/PongMessage.java | 0 .../core/network/message/RequestMessage.java | 0 .../core/network/message/ResponseMessage.java | 0 .../core/network/message/StartMessage.java | 0 .../network/netty/AbstractNettyHandler.java | 0 .../network/netty/BufAllocatorFactory.java | 0 .../netty/ChannelFutureListenerOnWrite.java | 0 .../core/network/netty/HeartbeatHandler.java | 0 .../network/netty/NettyClientFactory.java | 0 .../network/netty/NettyClientHandler.java | 0 .../network/netty/NettyEventLoopUtil.java | 0 .../core/network/netty/NettyProtocol.java | 0 .../network/netty/NettyServerHandler.java | 0 .../network/netty/NettyTransportClient.java | 0 .../network/netty/NettyTransportProvider.java | 0 .../network/netty/NettyTransportServer.java | 0 .../core/network/netty/ServerIdleHandler.java | 0 .../network/netty/codec/FrameDecoder.java | 0 .../network/netty/codec/MessageDecoder.java | 0 .../network/netty/codec/MessageEncoder.java | 0 .../netty/codec/PreciseFrameDecoder.java | 0 .../core/network/session/ClientSession.java | 0 .../core/network/session/ServerSession.java | 0 .../network/session/TransportSession.java | 0 .../core/receiver/MessageRecvBuffers.java | 0 .../core/receiver/MessageRecvManager.java | 2 +- .../core/receiver/MessageRecvPartition.java | 0 .../core/receiver/MessageRecvPartitions.java | 10 +- .../computer/core/receiver/MessageStat.java | 0 .../edge/EdgeMessageRecvPartition.java | 0 .../edge/EdgeMessageRecvPartitions.java | 4 +- .../message/ComputeMessageRecvPartition.java | 0 .../message/ComputeMessageRecvPartitions.java | 4 +- .../vertex/VertexMessageRecvPartition.java | 0 .../vertex/VertexMessageRecvPartitions.java | 4 +- .../core/rpc/AggregateRpcService.java | 0 .../core/rpc/InputSplitRpcService.java | 0 .../computer/core/rpc/MasterRpcManager.java | 0 .../computer/core/rpc/WorkerRpcManager.java | 0 .../computer/core/sender/MessageQueue.java | 0 .../core/sender/MessageSendBuffers.java | 0 .../core/sender/MessageSendManager.java | 0 .../core/sender/MessageSendPartition.java | 0 .../computer/core/sender/MessageSender.java | 0 .../computer/core/sender/MultiQueue.java | 0 .../computer/core/sender/QueuedMessage.java | 0 .../core/sender/QueuedMessageSender.java | 0 .../computer/core/sender/WriteBuffer.java | 0 .../computer/core/sender/WriteBuffers.java | 0 .../core/snapshot/SnapshotManager.java | 35 +- .../computer/core/sort/BufferFileSorter.java | 0 .../computer/core/sort/DefaultSorter.java | 0 .../computer/core/sort/HgkvFileSorter.java | 0 .../hugegraph/computer/core/sort/Sorter.java | 0 .../sort/flusher/CombinableSorterFlusher.java | 0 .../flusher/CombineKvInnerSortFlusher.java | 0 .../flusher/CombineKvOuterSortFlusher.java | 0 .../flusher/CombineSubKvInnerSortFlusher.java | 0 .../flusher/CombineSubKvOuterSortFlusher.java | 0 .../core/sort/flusher/InnerSortFlusher.java | 0 .../core/sort/flusher/KvInnerSortFlusher.java | 0 .../core/sort/flusher/KvOuterSortFlusher.java | 0 .../core/sort/flusher/OuterSortFlusher.java | 0 .../core/sort/flusher/PeekableIterator.java | 0 .../sort/flusher/PeekableIteratorAdaptor.java | 0 .../computer/core/sort/merge/FileMerger.java | 0 .../core/sort/merge/FileMergerImpl.java | 0 .../core/sort/sorter/InputSorter.java | 0 .../core/sort/sorter/InputsSorter.java | 0 .../core/sort/sorter/InputsSorterImpl.java | 0 .../core/sort/sorter/JavaInputSorter.java | 0 .../core/sort/sorter/SubKvSorter.java | 0 .../sort/sorting/AbstractInputsSorting.java | 0 .../core/sort/sorting/HeapInputsSorting.java | 0 .../core/sort/sorting/InputsSorting.java | 0 .../sort/sorting/LoserTreeInputsSorting.java | 0 .../core/sort/sorting/RecvSortManager.java | 0 .../core/sort/sorting/SendSortManager.java | 0 .../core/sort/sorting/SortManager.java | 0 .../core/sort/sorting/SortingFactory.java | 0 .../core/sort/sorting/SortingMode.java | 0 .../computer/core/store/EntryIterator.java | 0 .../computer/core/store/FileGenerator.java | 0 .../computer/core/store/FileManager.java | 0 .../core/store/KvEntryFileReader.java | 0 .../core/store/KvEntryFileWriter.java | 0 .../computer/core/store/StoreManager.java | 0 .../core/store/SuperstepFileGenerator.java | 0 .../core/store/buffer/KvEntriesInput.java | 0 .../buffer/KvEntriesWithFirstSubKvInput.java | 0 .../core/store/buffer/SubKvEntriesInput.java | 0 .../core/store/entry/AbstractKvEntry.java | 0 .../core/store/entry/CachedPointer.java | 0 .../core/store/entry/DefaultKvEntry.java | 0 .../core/store/entry/EntriesUtil.java | 0 .../computer/core/store/entry/EntryInput.java | 2 - .../core/store/entry/EntryInputImpl.java | 1 - .../core/store/entry/EntryOutput.java | 0 .../core/store/entry/EntryOutputImpl.java | 0 .../core/store/entry/InlinePointer.java | 0 .../computer/core/store/entry/KvEntry.java | 0 .../core/store/entry/KvEntryReader.java | 2 - .../core/store/entry/KvEntryReaderImpl.java | 1 - .../store/entry/KvEntryWithFirstSubKv.java | 0 .../core/store/entry/KvEntryWriter.java | 0 .../core/store/entry/KvEntryWriterImpl.java | 0 .../computer/core/store/entry/Pointer.java | 0 .../computer/core/store/entry/Range.java | 0 .../bufferfile/BufferFileEntryBuilder.java | 0 .../bufferfile/BufferFileEntryReader.java | 0 .../bufferfile/BufferFileSubEntryReader.java | 0 .../store/file/hgkvfile/AbstractHgkvFile.java | 0 .../core/store/file/hgkvfile/HgkvDir.java | 0 .../core/store/file/hgkvfile/HgkvDirImpl.java | 0 .../core/store/file/hgkvfile/HgkvFile.java | 0 .../store/file/hgkvfile/HgkvFileImpl.java | 0 .../file/hgkvfile/builder/BlockBuilder.java | 0 .../builder/DataBlockBuilderImpl.java | 0 .../hgkvfile/builder/HgkvDirBuilderImpl.java | 0 .../hgkvfile/builder/HgkvFileBuilder.java | 0 .../hgkvfile/builder/HgkvFileBuilderImpl.java | 0 .../hgkvfile/builder/IndexBlockBuilder.java | 0 .../builder/IndexBlockBuilderImpl.java | 0 .../reader/HgkvDir4SubKvReaderImpl.java | 0 .../hgkvfile/reader/HgkvDirReaderImpl.java | 0 .../hgkvfile/reader/HgkvFileReaderImpl.java | 0 .../file/select/DefaultSelectedFiles.java | 0 .../file/select/DisperseEvenlySelector.java | 0 .../store/file/select/InputFilesSelector.java | 0 .../core/store/file/select/SelectedFiles.java | 0 .../store/file/seqfile/BitsFileReader.java | 0 .../file/seqfile/BitsFileReaderImpl.java | 0 .../store/file/seqfile/BitsFileWriter.java | 0 .../file/seqfile/BitsFileWriterImpl.java | 0 .../core/store/file/seqfile/ValueFile.java | 0 .../store/file/seqfile/ValueFileInput.java | 0 .../store/file/seqfile/ValueFileOutput.java | 0 .../core/util/ComputerContextUtil.java | 0 .../computer/core/util/Consumers.java | 0 .../computer/core/util/FileUtil.java | 0 .../computer/core/util/JsonUtil.java | 0 .../computer/core/util/SerializeUtil.java | 1 - .../computer/core/util/ShutdownHook.java | 0 .../computer/core/util/StringEncodeUtil.java | 0 .../computer/core/worker/WorkerService.java | 0 .../computer/core/worker/WorkerStat.java | 1 - .../core/worker/load/LoadService.java | 0 .../computer-dist}/Dockerfile | 0 .../computer-dist}/pom.xml | 0 .../computer-dist}/release-docs/LICENSE | 0 .../computer-dist}/release-docs/NOTICE | 0 .../licenses/LICENSE-accessors-smart.txt | 0 .../licenses/LICENSE-activation.txt | 0 .../LICENSE-animal-sniffer-annotations.txt | 0 .../licenses/LICENSE-annotations.txt | 0 .../licenses/LICENSE-apiguardian-api.txt | 0 .../release-docs/licenses/LICENSE-asm.txt | 0 .../licenses/LICENSE-audience-annotations.txt | 0 .../LICENSE-auto-service-annotations.txt | 0 .../licenses/LICENSE-automaton.txt | 0 .../release-docs/licenses/LICENSE-avro.txt | 0 .../licenses/LICENSE-bcprov-jdk18on.txt | 0 .../release-docs/licenses/LICENSE-bolt.txt | 0 .../licenses/LICENSE-builder-annotations.txt | 0 .../licenses/LICENSE-byte-buddy.txt | 0 .../licenses/LICENSE-checker-qual.txt | 0 .../licenses/LICENSE-commons-beanutils.txt | 0 .../licenses/LICENSE-commons-cli.txt | 0 .../licenses/LICENSE-commons-codec.txt | 0 .../licenses/LICENSE-commons-collections.txt | 0 .../licenses/LICENSE-commons-compress.txt | 0 .../LICENSE-commons-configuration.txt | 0 .../LICENSE-commons-configuration2.txt | 0 .../licenses/LICENSE-commons-crypto.txt | 0 .../licenses/LICENSE-commons-io.txt | 0 .../licenses/LICENSE-commons-lang.txt | 0 .../licenses/LICENSE-commons-lang3.txt | 0 .../licenses/LICENSE-commons-logging.txt | 0 .../licenses/LICENSE-commons-math3.txt | 0 .../licenses/LICENSE-commons-net.txt | 0 .../licenses/LICENSE-commons-text.txt | 0 .../licenses/LICENSE-curator-client.txt | 0 .../licenses/LICENSE-curator-framework.txt | 0 .../licenses/LICENSE-curator-recipes.txt | 0 .../licenses/LICENSE-disruptor.txt | 0 .../LICENSE-error_prone_annotations.txt | 0 .../licenses/LICENSE-failsafe.txt | 0 .../licenses/LICENSE-findbugs-annotations.txt | 0 .../release-docs/licenses/LICENSE-generex.txt | 0 .../licenses/LICENSE-groovy-all.txt | 0 .../licenses/LICENSE-grpc-api.txt | 0 .../licenses/LICENSE-grpc-context.txt | 0 .../licenses/LICENSE-grpc-core.txt | 0 .../licenses/LICENSE-grpc-grpclb.txt | 0 .../licenses/LICENSE-grpc-netty.txt | 0 .../licenses/LICENSE-grpc-protobuf-lite.txt | 0 .../licenses/LICENSE-grpc-protobuf.txt | 0 .../licenses/LICENSE-grpc-stub.txt | 0 .../release-docs/licenses/LICENSE-gson.txt | 0 .../release-docs/licenses/LICENSE-guava.txt | 0 .../licenses/LICENSE-hadoop-annotations.txt | 0 .../licenses/LICENSE-hadoop-auth.txt | 0 .../licenses/LICENSE-hadoop-common.txt | 0 .../licenses/LICENSE-hadoop-hdfs-client.txt | 0 .../licenses/LICENSE-hamcrest-core.txt | 0 .../licenses/LICENSE-hbase-client.txt | 0 .../licenses/LICENSE-hbase-common.txt | 0 .../licenses/LICENSE-hbase-hadoop-compat.txt | 0 .../licenses/LICENSE-hbase-hadoop2-compat.txt | 0 .../licenses/LICENSE-hbase-http.txt | 0 .../licenses/LICENSE-hbase-mapreduce.txt | 0 .../licenses/LICENSE-hbase-metrics-api.txt | 0 .../licenses/LICENSE-hbase-metrics.txt | 0 .../licenses/LICENSE-hbase-procedure.txt | 0 .../LICENSE-hbase-protocol-shaded.txt | 0 .../licenses/LICENSE-hbase-protocol.txt | 0 .../licenses/LICENSE-hbase-replication.txt | 0 .../licenses/LICENSE-hbase-server.txt | 0 ...LICENSE-hbase-shaded-client-byo-hadoop.txt | 0 .../LICENSE-hbase-shaded-miscellaneous.txt | 0 .../licenses/LICENSE-hbase-shaded-netty.txt | 0 .../LICENSE-hbase-shaded-protobuf.txt | 0 .../licenses/LICENSE-hbase-zookeeper.txt | 0 .../release-docs/licenses/LICENSE-hessian.txt | 0 .../licenses/LICENSE-htrace-core4.txt | 0 .../licenses/LICENSE-hugegraph-client.txt | 0 .../licenses/LICENSE-hugegraph-common.txt | 0 .../licenses/LICENSE-hugegraph-loader.txt | 0 .../licenses/LICENSE-hugegraph-rpc.txt | 0 .../licenses/LICENSE-j2objc-annotations.txt | 0 .../licenses/LICENSE-jackson-annotations.txt | 0 .../licenses/LICENSE-jackson-core-asl.txt | 0 .../licenses/LICENSE-jackson-core.txt | 0 .../licenses/LICENSE-jackson-databind.txt | 0 .../LICENSE-jackson-dataformat-yaml.txt | 0 .../LICENSE-jackson-datatype-jsr310.txt | 0 .../licenses/LICENSE-jackson-jaxrs-base.txt | 0 .../LICENSE-jackson-jaxrs-json-provider.txt | 0 .../licenses/LICENSE-jackson-jaxrs.txt | 0 .../licenses/LICENSE-jackson-mapper-asl.txt | 0 ...ICENSE-jackson-module-jaxb-annotations.txt | 0 .../licenses/LICENSE-jackson-xc.txt | 0 .../LICENSE-jakarta.activation-api.txt | 0 .../licenses/LICENSE-jakarta.activation.txt | 0 .../licenses/LICENSE-jamon-runtime.txt | 0 .../licenses/LICENSE-javassist.txt | 0 .../licenses/LICENSE-javax.annotation-api.txt | 0 .../licenses/LICENSE-javax.el.txt | 0 .../licenses/LICENSE-javax.inject.txt | 0 .../licenses/LICENSE-javax.json.txt | 0 .../licenses/LICENSE-javax.servlet-api.txt | 0 .../LICENSE-javax.servlet.jsp-api.txt | 0 .../licenses/LICENSE-javax.servlet.jsp.txt | 0 .../licenses/LICENSE-jaxb-core.txt | 0 .../licenses/LICENSE-jaxb-impl.txt | 0 .../licenses/LICENSE-jcip-annotations.txt | 0 .../licenses/LICENSE-jcodings.txt | 0 .../licenses/LICENSE-jcommander.txt | 0 .../LICENSE-jersey-container-servlet-core.txt | 0 .../licenses/LICENSE-jersey-core.txt | 0 .../licenses/LICENSE-jersey-json.txt | 0 .../licenses/LICENSE-jersey-servlet.txt | 0 .../licenses/LICENSE-jetcd-common.txt | 0 .../licenses/LICENSE-jetcd-core.txt | 0 .../licenses/LICENSE-jettison.txt | 0 .../licenses/LICENSE-jetty-http.txt | 0 .../licenses/LICENSE-jetty-io.txt | 0 .../licenses/LICENSE-jetty-security.txt | 0 .../licenses/LICENSE-jetty-server.txt | 0 .../licenses/LICENSE-jetty-servlet.txt | 0 .../licenses/LICENSE-jetty-util-ajax.txt | 0 .../licenses/LICENSE-jetty-util.txt | 0 .../licenses/LICENSE-jetty-webapp.txt | 0 .../licenses/LICENSE-jetty-xml.txt | 0 .../release-docs/licenses/LICENSE-jline.txt | 0 .../licenses/LICENSE-joda-time.txt | 0 .../release-docs/licenses/LICENSE-joni.txt | 0 .../release-docs/licenses/LICENSE-jsch.txt | 0 .../licenses/LICENSE-json-smart.txt | 0 .../release-docs/licenses/LICENSE-jsr305.txt | 0 .../release-docs/licenses/LICENSE-junit.txt | 0 .../licenses/LICENSE-kerb-admin.txt | 0 .../licenses/LICENSE-kerb-client.txt | 0 .../licenses/LICENSE-kerb-common.txt | 0 .../licenses/LICENSE-kerb-core.txt | 0 .../licenses/LICENSE-kerb-crypto.txt | 0 .../licenses/LICENSE-kerb-identity.txt | 0 .../licenses/LICENSE-kerb-server.txt | 0 .../licenses/LICENSE-kerb-simplekdc.txt | 0 .../licenses/LICENSE-kerb-util.txt | 0 .../licenses/LICENSE-kerby-asn1.txt | 0 .../licenses/LICENSE-kerby-config.txt | 0 .../licenses/LICENSE-kerby-pkix.txt | 0 .../licenses/LICENSE-kerby-util.txt | 0 .../licenses/LICENSE-kerby-xdr.txt | 0 .../licenses/LICENSE-kotlin-stdlib-common.txt | 0 .../licenses/LICENSE-kotlin-stdlib-jdk7.txt | 0 .../licenses/LICENSE-kotlin-stdlib-jdk8.txt | 0 .../licenses/LICENSE-kotlin-stdlib.txt | 0 .../licenses/LICENSE-kubernetes-client.txt | 0 ...kubernetes-model-admissionregistration.txt | 0 ...LICENSE-kubernetes-model-apiextensions.txt | 0 .../LICENSE-kubernetes-model-apps.txt | 0 .../LICENSE-kubernetes-model-autoscaling.txt | 0 .../LICENSE-kubernetes-model-batch.txt | 0 .../LICENSE-kubernetes-model-certificates.txt | 0 .../LICENSE-kubernetes-model-common.txt | 0 .../LICENSE-kubernetes-model-coordination.txt | 0 .../LICENSE-kubernetes-model-core.txt | 0 .../LICENSE-kubernetes-model-discovery.txt | 0 .../LICENSE-kubernetes-model-events.txt | 0 .../LICENSE-kubernetes-model-extensions.txt | 0 .../LICENSE-kubernetes-model-flowcontrol.txt | 0 .../LICENSE-kubernetes-model-metrics.txt | 0 .../LICENSE-kubernetes-model-networking.txt | 0 .../LICENSE-kubernetes-model-node.txt | 0 .../LICENSE-kubernetes-model-policy.txt | 0 .../LICENSE-kubernetes-model-rbac.txt | 0 .../LICENSE-kubernetes-model-scheduling.txt | 0 .../LICENSE-kubernetes-model-storageclass.txt | 0 .../LICENSE-kubernetes-server-mock.txt | 0 .../licenses/LICENSE-lightning-csv.txt | 0 .../licenses/LICENSE-listenablefuture.txt | 0 .../licenses/LICENSE-log4j-api.txt | 0 .../licenses/LICENSE-log4j-core.txt | 0 .../licenses/LICENSE-log4j-slf4j-impl.txt | 0 .../release-docs/licenses/LICENSE-log4j.txt | 0 .../licenses/LICENSE-logging-interceptor.txt | 0 .../licenses/LICENSE-lookout-api.txt | 0 .../licenses/LICENSE-lz4-java.txt | 0 .../licenses/LICENSE-metrics-core.txt | 0 .../release-docs/licenses/LICENSE-minio.txt | 0 .../licenses/LICENSE-mockito-core.txt | 0 .../release-docs/licenses/LICENSE-mvel2.txt | 0 .../licenses/LICENSE-netty-all.txt | 0 .../release-docs/licenses/LICENSE-netty.txt | 0 .../licenses/LICENSE-nimbus-jose-jwt.txt | 0 .../licenses/LICENSE-objenesis.txt | 0 .../release-docs/licenses/LICENSE-okhttp.txt | 0 .../licenses/LICENSE-okio-jvm.txt | 0 .../release-docs/licenses/LICENSE-okio.txt | 0 .../licenses/LICENSE-opentracing-api.txt | 0 .../licenses/LICENSE-opentracing-mock.txt | 0 .../licenses/LICENSE-opentracing-noop.txt | 0 .../licenses/LICENSE-opentracing-util.txt | 0 .../release-docs/licenses/LICENSE-ow2-asm.txt | 0 .../licenses/LICENSE-paranamer.txt | 0 .../licenses/LICENSE-perfmark-api.txt | 0 .../LICENSE-proto-google-common-protos.txt | 0 .../licenses/LICENSE-protobuf-java-util.txt | 0 .../licenses/LICENSE-protobuf-java.txt | 0 .../release-docs/licenses/LICENSE-re2j.txt | 0 .../LICENSE-resourcecify-annotations.txt | 0 .../licenses/LICENSE-sfm-converter.txt | 0 .../release-docs/licenses/LICENSE-sfm-csv.txt | 0 .../release-docs/licenses/LICENSE-sfm-map.txt | 0 .../licenses/LICENSE-sfm-reflect.txt | 0 .../licenses/LICENSE-sfm-tuples.txt | 0 .../licenses/LICENSE-sfm-util.txt | 0 .../licenses/LICENSE-simple-xml-safe.txt | 0 .../licenses/LICENSE-slf4j-api.txt | 0 .../licenses/LICENSE-slf4j-log4j12.txt | 0 .../licenses/LICENSE-snakeyaml.txt | 0 .../licenses/LICENSE-snappy-java.txt | 0 .../licenses/LICENSE-sofa-common-tools.txt | 0 .../licenses/LICENSE-sofa-rpc-all.txt | 0 .../licenses/LICENSE-stax2-api.txt | 0 .../licenses/LICENSE-sundr-codegen.txt | 0 .../licenses/LICENSE-sundr-core.txt | 0 .../licenses/LICENSE-swagger-annotations.txt | 0 .../licenses/LICENSE-swagger-core.txt | 0 .../licenses/LICENSE-swagger-models.txt | 0 .../licenses/LICENSE-token-provider.txt | 0 .../licenses/LICENSE-tracer-core.txt | 0 .../licenses/LICENSE-validation-api.txt | 0 .../licenses/LICENSE-woodstox-core.txt | 0 .../licenses/LICENSE-zjsonpatch.txt | 0 .../licenses/LICENSE-zookeeper.txt | 0 .../computer-dist}/scripts/apache-release.sh | 0 .../scripts/dependency/check_dependencies.sh | 0 .../scripts/dependency/known-dependencies.txt | 0 .../regenerate_known_dependencies.sh | 0 .../assembly/dataset/load-movie-data.groovy | 0 .../src/assembly/dataset/schema.groovy | 0 .../src/assembly/dataset/struct.json | 0 .../src/assembly/descriptor/assembly.xml | 0 .../src/assembly/static/bin/start-computer.sh | 0 .../assembly/static/conf/computer.properties | 0 .../src/assembly/static/conf/log4j2.xml | 0 .../src/assembly/travis/build-images.sh | 0 .../src/assembly/travis/install-env.sh | 0 .../src/assembly/travis/install-hdfs.sh | 0 .../travis/install-hugegraph-from-source.sh | 0 .../src/assembly/travis/install-k8s.sh | 0 .../travis/load-data-into-hugegraph.sh | 0 .../src/assembly/travis/start-etcd.sh | 0 .../computer-driver}/pom.xml | 0 .../computer/driver/ComputerDriver.java | 0 .../driver/ComputerDriverException.java | 0 .../computer/driver/DefaultJobState.java | 0 .../computer/driver/JobObserver.java | 0 .../hugegraph/computer/driver/JobState.java | 0 .../hugegraph/computer/driver/JobStatus.java | 0 .../computer/driver/SuperstepStat.java | 0 .../driver/config/DriverConfigOption.java | 0 .../computer/driver/util/JsonUtil.java | 0 .../computer-k8s-operator}/Dockerfile | 0 .../crd-generate/.dockerignore | 0 .../crd-generate/.gitignore | 0 .../crd-generate/Dockerfile | 0 .../crd-generate/Makefile | 0 .../crd-generate/PROJECT | 0 .../crd-generate/README.md | 0 .../crd-generate/api/v1/groupversion_info.go | 0 .../api/v1/hugegraphcomputerjob_types.go | 0 .../api/v1/hugegraphcomputerjob_webhook.go | 0 .../crd-generate/api/v1/webhook_suite_test.go | 3 - .../crd-generate/cmd/generate.go | 0 .../crd-generate/cmd/main.go | 0 .../config/certmanager/certificate.yaml | 0 .../config/certmanager/kustomization.yaml | 0 .../config/certmanager/kustomizeconfig.yaml | 0 ...che.org_hugegraphcomputerjobs.v1beta1.yaml | 1076 +++++++++++++++++ ...raph.apache.org_hugegraphcomputerjobs.yaml | 1074 ++++++++++++++++ .../config/crd/kustomization.yaml | 0 .../config/crd/kustomizeconfig.yaml | 0 .../cainjection_in_hugegraphcomputerjobs.yaml | 0 .../webhook_in_hugegraphcomputerjobs.yaml | 0 .../config/default/kustomization.yaml | 0 .../default/manager_auth_proxy_patch.yaml | 0 .../config/default/manager_config_patch.yaml | 0 .../config/default/manager_webhook_patch.yaml | 0 .../default/webhookcainjection_patch.yaml | 0 .../crd-generate/config/etcd/etcd_server.yaml | 0 .../config/etcd/kustomization.yaml | 0 .../manager/controller_manager_config.yaml | 0 .../config/manager/kustomization.yaml | 0 .../crd-generate/config/manager/manager.yaml | 0 .../config/minio/kustomization.yaml | 0 .../config/minio/minio_server.yaml | 0 .../config/prometheus/kustomization.yaml | 0 .../config/prometheus/monitor.yaml | 0 .../rbac/auth_proxy_client_clusterrole.yaml | 0 .../config/rbac/auth_proxy_role.yaml | 0 .../config/rbac/auth_proxy_role_binding.yaml | 0 .../config/rbac/auth_proxy_service.yaml | 0 .../hugegraphcomputerjob_editor_role.yaml | 0 .../hugegraphcomputerjob_viewer_role.yaml | 0 .../config/rbac/kustomization.yaml | 0 .../config/rbac/leader_election_role.yaml | 0 .../rbac/leader_election_role_binding.yaml | 0 .../crd-generate/config/rbac/role.yaml | 0 .../config/rbac/role_binding.yaml | 0 .../config/rbac/service_account.yaml | 0 .../config/samples/kustomization.yaml | 0 .../operator_v1_hugegraphcomputerjob.yaml | 0 .../config/webhook/kustomization.yaml | 0 .../config/webhook/kustomizeconfig.yaml | 0 .../config/webhook/manifests.yaml | 0 .../crd-generate/config/webhook/service.yaml | 0 .../crd-generate/go.mod | 0 .../crd-generate/go.sum | 0 .../crd-generate/hack/boilerplate.go.txt | 0 .../manifest/hugegraph-computer-crd.v1.yaml | 0 .../hugegraph-computer-crd.v1beta1.yaml | 0 .../manifest/hugegraph-computer-operator.yaml | 0 .../computer-k8s-operator}/pom.xml | 0 .../k8s/operator/OperatorEntrypoint.java | 0 .../operator/common/AbstractController.java | 0 .../k8s/operator/common/MatchWithMsg.java | 0 .../k8s/operator/common/OperatorRequest.java | 0 .../k8s/operator/common/OperatorResult.java | 0 .../k8s/operator/common/WorkQueue.java | 0 .../k8s/operator/config/OperatorOptions.java | 0 .../controller/ComputerJobComponent.java | 0 .../controller/ComputerJobController.java | 0 .../controller/ComputerJobDeployer.java | 0 .../src/main/resources/log4j2.xml | 0 .../computer-k8s}/pom.xml | 0 .../computer-k8s}/schema/crd-schema.json | 0 .../computer-k8s}/schema/enum-schema.json | 0 .../hugegraph/computer/k8s/Constants.java | 0 .../k8s/config/KubeDriverOptions.java | 0 .../computer/k8s/config/KubeSpecOptions.java | 0 .../k8s/crd/model/HugeGraphComputerJob.java | 0 .../crd/model/HugeGraphComputerJobList.java | 0 .../computer/k8s/driver/KubernetesDriver.java | 2 +- .../hugegraph/computer/k8s/util/KubeUtil.java | 0 .../src/main/resources/docker_push.sh | 0 .../conf/images/docker_push_test.sh | 0 .../computer-test}/conf/log4j2-test.xml | 0 .../computer-test}/pom.xml | 0 .../apache/hugegraph/computer/GenOption.java | 51 + .../computer/algorithm/AlgorithmTestBase.java | 0 .../algorithm/AlgorithmTestSuite.java | 0 .../BetweennessCentralityTest.java | 0 .../closeness/ClosenessCentralityTest.java | 0 .../degree/DegreeCentralityTest.java | 0 .../centrality/pagerank/PageRankTest.java | 0 .../cc/ClusteringCoefficientTest.java | 0 .../algorithm/community/kcore/KcoreTest.java | 0 .../algorithm/community/lpa/LpaTest.java | 4 +- .../trianglecount/TriangleCountTest.java | 0 .../algorithm/community/wcc/WccTest.java | 0 .../path/rings/RingsDetectionTest.java | 0 .../rings/RingsDetectionWithFilterTest.java | 0 .../SingleSourceShortestPathTest.java | 0 .../algorithm/sampling/RandomWalkTest.java | 0 .../core/allocator/AllocatorTestSuite.java | 0 .../core/allocator/DefaultAllocatorTest.java | 0 .../core/allocator/RecyclersTest.java | 0 .../computer/core/bsp/BspEventTest.java | 0 .../computer/core/bsp/BspTestSuite.java | 0 .../computer/core/bsp/EtcdBspTest.java | 0 .../computer/core/bsp/EtcdClientTest.java | 0 .../core/combiner/CombinerTestSuite.java | 0 .../combiner/DoubleValueSumCombinerTest.java | 0 .../combiner/FloatValueSumCombinerTest.java | 0 .../combiner/IntValueSumCombinerTest.java | 0 .../combiner/LongValueSumCombinerTest.java | 0 .../MergeNewPropertiesCombinerTest.java | 0 .../MergeOldPropertiesCombinerTest.java | 0 .../core/combiner/OverwriteCombinerTest.java | 0 .../core/combiner/PointerCombinerTest.java | 0 .../core/combiner/ValueMaxCombinerTest.java | 0 .../core/combiner/ValueMinCombinerTest.java | 0 .../computer/core/common/CommonTestSuite.java | 0 .../core/common/ContainerInfoTest.java | 0 .../computer/core/common/ExceptionTest.java | 0 .../core/common/FakeMasterComputation.java | 0 .../core/compute/ComputeManagerTest.java | 0 .../core/compute/ComputeTestSuite.java | 0 .../core/compute/MockComputation.java | 0 .../core/compute/MockMessageSender.java | 0 .../core/compute/input/EdgesInputTest.java | 0 .../core/compute/input/MessageInputTest.java | 0 .../compute/input/ResuablePointerTest.java | 0 .../computer/core/config/ConfigTestSuite.java | 0 .../core/config/DefaultConfigTest.java | 0 .../core/graph/BuiltinGraphFactoryTest.java | 0 .../computer/core/graph/DefaultEdgeTest.java | 0 .../core/graph/DefaultPropertiesTest.java | 0 .../computer/core/graph/GraphTestSuite.java | 0 .../core/graph/SuperstepStatTest.java | 0 .../computer/core/graph/id/BytesIdTest.java | 0 .../computer/core/graph/id/IdFactoryTest.java | 0 .../computer/core/graph/id/IdTypeTest.java | 0 .../graph/partition/HashPartitionerTest.java | 0 .../graph/partition/PartitionStatTest.java | 0 .../core/graph/value/BooleanValueTest.java | 0 .../core/graph/value/DoubleValueTest.java | 0 .../core/graph/value/FloatValueTest.java | 0 .../core/graph/value/IdListListTest.java | 0 .../core/graph/value/IdValueListTest.java | 0 .../core/graph/value/IdValueTest.java | 0 .../core/graph/value/IntValueTest.java | 0 .../core/graph/value/ListValueTest.java | 0 .../core/graph/value/LongValueTest.java | 0 .../core/graph/value/NullValueTest.java | 0 .../core/graph/value/StringValueTest.java | 0 .../core/graph/value/ValueTypeTest.java | 0 .../core/input/FileInputSplitTest.java | 0 .../core/input/HugeConverterTest.java | 0 .../core/input/InputSplitDataTest.java | 0 .../computer/core/input/InputSplitTest.java | 0 .../computer/core/input/InputTestSuite.java | 0 .../core/input/MockMasterInputManager.java | 0 .../computer/core/input/MockRpcClient.java | 0 .../core/input/MockWorkerInputManager.java | 0 .../computer/core/io/BufferedFileTest.java | 0 .../computer/core/io/BufferedStreamTest.java | 0 .../core/io/CsvStructGraphOutputTest.java | 0 .../computer/core/io/IOTestSuite.java | 0 .../core/io/JsonStructGraphOutputTest.java | 0 .../computer/core/io/MockRankComputation.java | 0 .../core/io/OptimizedUnsafeBytesTest.java | 0 .../core/io/StreamGraphOutputInputTest.java | 0 .../core/io/StructRandomAccessOutputTest.java | 0 .../computer/core/io/UnsafeBytesTest.java | 0 .../core/network/ConnectionIdTest.java | 0 .../core/network/DataServerManagerTest.java | 0 .../core/network/MockClientHandler.java | 0 .../core/network/MockMessageHandler.java | 0 .../core/network/MockUnDecodeMessage.java | 0 .../core/network/NetworkTestSuite.java | 0 .../core/network/TransportUtilTest.java | 0 .../network/buffer/NetworkBufferTest.java | 0 .../connection/ConnectionManagerTest.java | 0 .../network/netty/AbstractNetworkTest.java | 0 .../network/netty/HeartbeatHandlerTest.java | 0 .../network/netty/NettyClientFactoryTest.java | 0 .../netty/NettyEncodeDecodeHandlerTest.java | 0 .../netty/NettyTransportClientTest.java | 0 .../netty/NettyTransportServerTest.java | 0 .../network/session/TransportSessionTest.java | 0 .../core/receiver/MessageRecvBuffersTest.java | 0 .../core/receiver/MessageRecvManagerTest.java | 0 .../core/receiver/ReceiverTestSuite.java | 0 .../computer/core/receiver/ReceiverUtil.java | 1 - .../edge/EdgeMessageRecvPartitionTest.java | 0 .../ComputeMessageRecvPartitionTest.java | 0 .../VertexMessageRecvPartitionTest.java | 0 .../core/sender/MessageQueueTest.java | 0 .../core/sender/MessageSendBuffersTest.java | 0 .../core/sender/MessageSendManagerTest.java | 0 .../core/sender/MockTransportClient.java | 0 .../computer/core/sender/MultiQueueTest.java | 0 .../core/sender/QueuedMessageSenderTest.java | 0 .../core/sender/QueuedMessageTest.java | 0 .../computer/core/sender/SenderTestSuite.java | 0 .../computer/core/sender/WriteBufferTest.java | 0 .../core/sender/WriteBuffersTest.java | 0 .../computer/core/sort/SorterTestUtil.java | 1 - .../sort/combiner/MockIntSumCombiner.java | 0 .../core/sort/sorter/EmptyFlusherTest.java | 0 .../core/sort/sorter/FlusherTest.java | 0 .../core/sort/sorter/SortLargeDataTest.java | 0 .../computer/core/sort/sorter/SorterTest.java | 0 .../core/sort/sorter/SorterTestSuite.java | 0 .../core/sort/sorting/InputsSortingTest.java | 0 .../core/sort/sorting/SortingTestSuite.java | 0 .../computer/core/sort/sorting/TestData.java | 0 .../computer/core/store/BitFileTest.java | 0 .../computer/core/store/EntriesUtilTest.java | 0 .../computer/core/store/EntryOutputTest.java | 0 .../computer/core/store/FileManagerTest.java | 0 .../computer/core/store/HgkvDirTest.java | 0 .../computer/core/store/HgkvFileTest.java | 0 .../computer/core/store/PointerTest.java | 0 .../computer/core/store/StoreTestSuite.java | 0 .../computer/core/store/StoreTestUtil.java | 0 .../computer/core/store/ValueFileTest.java | 0 .../core/util/ComputerContextUtilTest.java | 0 .../computer/core/util/IdUtilTest.java | 0 .../computer/core/util/JsonUtilTest.java | 0 .../computer/core/util/SerializeUtilTest.java | 0 .../computer/core/util/UtilTestSuite.java | 0 .../computer/core/worker/MockComputation.java | 0 .../core/worker/MockComputation2.java | 0 .../core/worker/MockComputationParams.java | 0 .../core/worker/MockMasterComputation.java | 0 .../core/worker/MockMasterComputation2.java | 0 .../core/worker/MockWorkerService.java | 0 .../core/worker/WorkerServiceTest.java | 0 .../computer/core/worker/WorkerStatTest.java | 0 .../computer/core/worker/WorkerTestSuite.java | 0 .../computer/driver/ComputerOptionsTest.java | 0 .../hugegraph/computer/driver/DriverTest.java | 0 .../computer/driver/DriverTestSuite.java | 0 .../computer/k8s/AbstractK8sTest.java | 0 .../hugegraph/computer/k8s/K8sTestSuite.java | 0 .../computer/k8s/KubernetesDriverTest.java | 0 .../hugegraph/computer/k8s/MiniKubeTest.java | 0 .../hugegraph/computer/k8s/OperatorTest.java | 0 .../suite/integrate/IntegrateTestSuite.java | 0 .../suite/integrate/MockComputation.java | 0 .../suite/integrate/SenderIntegrateTest.java | 0 .../computer/suite/unit/UnitTestBase.java | 1 - .../computer/suite/unit/UnitTestSuite.java | 0 .../src/main/resources/computer.properties | 0 .../resources/hdfs_input_test/core-site.xml | 0 .../resources/hdfs_input_test/schema.json | 0 .../resources/hdfs_input_test/struct.json | 0 .../src/main/resources/log4j2.xml | 0 .../computer-yarn}/pom.xml | 0 pom.xml => computer/pom.xml | 0 934 files changed, 2279 insertions(+), 1781 deletions(-) delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/AbstractComputerOutput.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/ComputerOutput.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/exceptions/WriteBackException.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/BatchInsertTask.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/SingleInsertTask.java delete mode 100644 computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/TaskManager.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LimitedLogOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LogOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java delete mode 100644 computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphStringOutput.java delete mode 100644 computer-dist/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputer.java delete mode 100644 computer-test/src/main/java/org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java delete mode 100644 computer-test/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java create mode 100644 computer/README.md rename {computer-algorithm => computer/computer-algorithm}/pom.xml (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/QuantityType.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPath.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathCombiner.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathMaster.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathOutput.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathParams.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathValue.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalk.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkMessage.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkOutput.java (100%) rename {computer-algorithm => computer/computer-algorithm}/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkParams.java (100%) rename {computer-api => computer/computer-api}/pom.xml (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/IdListMergeCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/IdSetMergeCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/config/Config.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/config/Null.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/util/IdUtil.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilExt.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java (100%) rename {computer-api => computer/computer-api}/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java (100%) rename {computer-core => computer/computer-core}/pom.xml (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java (98%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java (98%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java (98%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java (99%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java (98%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/AbstractMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java (99%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java (96%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java (96%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java (94%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java (97%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java (98%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/util/StringEncodeUtil.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java (100%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java (98%) rename {computer-core => computer/computer-core}/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java (100%) rename {computer-dist => computer/computer-dist}/Dockerfile (100%) rename {computer-dist => computer/computer-dist}/pom.xml (100%) rename {computer-dist => computer/computer-dist}/release-docs/LICENSE (100%) rename {computer-dist => computer/computer-dist}/release-docs/NOTICE (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-accessors-smart.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-activation.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-animal-sniffer-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-apiguardian-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-asm.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-audience-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-auto-service-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-automaton.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-avro.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-bcprov-jdk18on.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-bolt.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-builder-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-byte-buddy.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-checker-qual.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-beanutils.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-cli.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-codec.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-collections.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-compress.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-configuration.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-configuration2.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-crypto.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-io.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-lang.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-lang3.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-logging.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-math3.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-net.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-commons-text.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-curator-client.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-curator-framework.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-curator-recipes.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-disruptor.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-error_prone_annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-failsafe.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-findbugs-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-generex.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-groovy-all.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-context.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-grpclb.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-netty.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-protobuf-lite.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-protobuf.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-grpc-stub.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-gson.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-guava.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hadoop-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hadoop-auth.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hadoop-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hadoop-hdfs-client.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hamcrest-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-client.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-hadoop-compat.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-hadoop2-compat.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-http.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-mapreduce.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-metrics-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-metrics.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-procedure.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-protocol-shaded.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-protocol.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-replication.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-server.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-shaded-client-byo-hadoop.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-shaded-miscellaneous.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-shaded-netty.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-shaded-protobuf.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hbase-zookeeper.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hessian.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-htrace-core4.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hugegraph-client.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hugegraph-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hugegraph-loader.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-hugegraph-rpc.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-j2objc-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-core-asl.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-databind.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-dataformat-yaml.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-datatype-jsr310.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-jaxrs-base.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-jaxrs-json-provider.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-jaxrs.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-mapper-asl.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-module-jaxb-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jackson-xc.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jakarta.activation-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jakarta.activation.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jamon-runtime.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javassist.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.annotation-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.el.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.inject.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.json.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.servlet-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.servlet.jsp-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-javax.servlet.jsp.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jaxb-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jaxb-impl.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jcip-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jcodings.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jcommander.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jersey-container-servlet-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jersey-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jersey-json.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jersey-servlet.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetcd-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetcd-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jettison.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-http.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-io.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-security.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-server.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-servlet.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-util-ajax.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-util.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-webapp.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jetty-xml.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jline.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-joda-time.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-joni.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jsch.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-json-smart.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-jsr305.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-junit.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-admin.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-client.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-crypto.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-identity.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-server.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-simplekdc.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerb-util.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerby-asn1.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerby-config.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerby-pkix.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerby-util.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kerby-xdr.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kotlin-stdlib-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kotlin-stdlib-jdk7.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kotlin-stdlib-jdk8.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kotlin-stdlib.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-client.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-admissionregistration.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-apiextensions.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-apps.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-autoscaling.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-batch.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-certificates.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-common.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-coordination.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-discovery.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-events.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-extensions.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-flowcontrol.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-metrics.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-networking.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-node.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-policy.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-rbac.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-scheduling.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-model-storageclass.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-kubernetes-server-mock.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-lightning-csv.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-listenablefuture.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-log4j-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-log4j-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-log4j-slf4j-impl.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-log4j.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-logging-interceptor.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-lookout-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-lz4-java.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-metrics-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-minio.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-mockito-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-mvel2.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-netty-all.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-netty.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-nimbus-jose-jwt.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-objenesis.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-okhttp.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-okio-jvm.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-okio.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-opentracing-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-opentracing-mock.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-opentracing-noop.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-opentracing-util.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-ow2-asm.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-paranamer.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-perfmark-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-proto-google-common-protos.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-protobuf-java-util.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-protobuf-java.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-re2j.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-resourcecify-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sfm-converter.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sfm-csv.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sfm-map.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sfm-reflect.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sfm-tuples.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sfm-util.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-simple-xml-safe.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-slf4j-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-slf4j-log4j12.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-snakeyaml.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-snappy-java.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sofa-common-tools.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sofa-rpc-all.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-stax2-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sundr-codegen.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-sundr-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-swagger-annotations.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-swagger-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-swagger-models.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-token-provider.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-tracer-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-validation-api.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-woodstox-core.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-zjsonpatch.txt (100%) rename {computer-dist => computer/computer-dist}/release-docs/licenses/LICENSE-zookeeper.txt (100%) rename {computer-dist => computer/computer-dist}/scripts/apache-release.sh (100%) rename {computer-dist => computer/computer-dist}/scripts/dependency/check_dependencies.sh (100%) rename {computer-dist => computer/computer-dist}/scripts/dependency/known-dependencies.txt (100%) rename {computer-dist => computer/computer-dist}/scripts/dependency/regenerate_known_dependencies.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/dataset/load-movie-data.groovy (100%) rename {computer-dist => computer/computer-dist}/src/assembly/dataset/schema.groovy (100%) rename {computer-dist => computer/computer-dist}/src/assembly/dataset/struct.json (100%) rename {computer-dist => computer/computer-dist}/src/assembly/descriptor/assembly.xml (100%) rename {computer-dist => computer/computer-dist}/src/assembly/static/bin/start-computer.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/static/conf/computer.properties (100%) rename {computer-dist => computer/computer-dist}/src/assembly/static/conf/log4j2.xml (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/build-images.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/install-env.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/install-hdfs.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/install-hugegraph-from-source.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/install-k8s.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/load-data-into-hugegraph.sh (100%) rename {computer-dist => computer/computer-dist}/src/assembly/travis/start-etcd.sh (100%) rename {computer-driver => computer/computer-driver}/pom.xml (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/JobState.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java (100%) rename {computer-driver => computer/computer-driver}/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/Dockerfile (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/.dockerignore (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/.gitignore (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/Dockerfile (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/Makefile (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/PROJECT (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/README.md (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/api/v1/groupversion_info.go (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/api/v1/hugegraphcomputerjob_types.go (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/api/v1/hugegraphcomputerjob_webhook.go (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/api/v1/webhook_suite_test.go (98%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/cmd/generate.go (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/cmd/main.go (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/certmanager/certificate.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/certmanager/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/certmanager/kustomizeconfig.yaml (100%) create mode 100644 computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.v1beta1.yaml create mode 100644 computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.yaml rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/crd/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/crd/kustomizeconfig.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/crd/patches/cainjection_in_hugegraphcomputerjobs.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/crd/patches/webhook_in_hugegraphcomputerjobs.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/default/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/default/manager_auth_proxy_patch.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/default/manager_config_patch.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/default/manager_webhook_patch.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/default/webhookcainjection_patch.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/etcd/etcd_server.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/etcd/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/manager/controller_manager_config.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/manager/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/manager/manager.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/minio/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/minio/minio_server.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/prometheus/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/prometheus/monitor.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/auth_proxy_client_clusterrole.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/auth_proxy_role.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/auth_proxy_role_binding.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/auth_proxy_service.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/hugegraphcomputerjob_editor_role.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/hugegraphcomputerjob_viewer_role.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/leader_election_role.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/leader_election_role_binding.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/role.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/role_binding.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/rbac/service_account.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/samples/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/samples/operator_v1_hugegraphcomputerjob.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/webhook/kustomization.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/webhook/kustomizeconfig.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/webhook/manifests.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/config/webhook/service.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/go.mod (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/go.sum (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/crd-generate/hack/boilerplate.go.txt (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/manifest/hugegraph-computer-crd.v1.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/manifest/hugegraph-computer-crd.v1beta1.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/manifest/hugegraph-computer-operator.yaml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/pom.xml (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java (100%) rename {computer-k8s-operator => computer/computer-k8s-operator}/src/main/resources/log4j2.xml (100%) rename {computer-k8s => computer/computer-k8s}/pom.xml (100%) rename {computer-k8s => computer/computer-k8s}/schema/crd-schema.json (100%) rename {computer-k8s => computer/computer-k8s}/schema/enum-schema.json (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java (100%) rename {computer-k8s => computer/computer-k8s}/src/main/resources/docker_push.sh (100%) rename {computer-test => computer/computer-test}/conf/images/docker_push_test.sh (100%) rename {computer-test => computer/computer-test}/conf/log4j2-test.xml (100%) rename {computer-test => computer/computer-test}/pom.xml (100%) create mode 100644 computer/computer-test/src/main/java/org/apache/hugegraph/computer/GenOption.java rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java (98%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java (99%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/util/IdUtilTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java (100%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java (99%) rename {computer-test => computer/computer-test}/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java (100%) rename {computer-test => computer/computer-test}/src/main/resources/computer.properties (100%) rename {computer-test => computer/computer-test}/src/main/resources/hdfs_input_test/core-site.xml (100%) rename {computer-test => computer/computer-test}/src/main/resources/hdfs_input_test/schema.json (100%) rename {computer-test => computer/computer-test}/src/main/resources/hdfs_input_test/struct.json (100%) rename {computer-test => computer/computer-test}/src/main/resources/log4j2.xml (100%) rename {computer-yarn => computer/computer-yarn}/pom.xml (100%) rename pom.xml => computer/pom.xml (100%) diff --git a/.github/workflows/ci.yml b/.github/workflows/ci.yml index 5cfd38a12..dbca08039 100644 --- a/.github/workflows/ci.yml +++ b/.github/workflows/ci.yml @@ -22,6 +22,7 @@ jobs: - name: Checkout uses: actions/checkout@v4 with: + path: computer fetch-depth: 2 - name: Install JDK 8 for HDFS 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 deleted file mode 100644 index 06881394a..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/AbstractComputerOutput.java +++ /dev/null @@ -1,52 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output; - -import org.apache.hugegraph.computer.core.config.ComputerOptions; -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.worker.Computation; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -public abstract class AbstractComputerOutput implements ComputerOutput { - - private static final Logger LOG = Log.logger(ComputerOutput.class); - - private String name; - private int partition; - - @Override - public void init(Config config, int partition) { - Computation computation = config.createObject( - ComputerOptions.WORKER_COMPUTATION_CLASS); - this.name = computation.name(); - this.partition = partition; - - LOG.info("Start write back partition {} for {}", - this.partition(), this.name()); - } - - @Override - public String name() { - return this.name; - } - - public int partition() { - return this.partition; - } -} 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 deleted file mode 100644 index 3522853f9..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/ComputerOutput.java +++ /dev/null @@ -1,66 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output; - -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.graph.vertex.Vertex; -import org.apache.hugegraph.computer.core.worker.Computation; - -/** - * Computer output is used to output computer results. There is an output object - * for every partition. - */ -public interface ComputerOutput { - - /** - * Initialize the output. Create connection to target output system. - */ - void init(Config config, int partition); - - /** - * For each vertex in partition, this method is called regardless - * vertex's status. - */ - void write(Vertex vertex); - - /** - * Write filter. - * True to commit the computation result, otherwise not to commit. - */ - default boolean filter(Config config, Computation computation, Vertex vertex) { - return true; - } - - /** - * Merge output files of multiple partitions if applicable. - */ - default void mergePartitions(Config config) { - // pass - } - - /** - * Close the connection to target output system. Commit if target output - * required. - */ - void close(); - - /** - * The name of output property. - */ - String name(); -} 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 deleted file mode 100644 index f5994b128..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphOutput.java +++ /dev/null @@ -1,104 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -import java.util.ArrayList; -import java.util.List; - -import org.apache.hugegraph.computer.core.config.ComputerOptions; -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.graph.vertex.Vertex; -import org.apache.hugegraph.computer.core.output.AbstractComputerOutput; -import org.apache.hugegraph.computer.core.output.hg.task.TaskManager; -import org.apache.hugegraph.driver.HugeClient; -import org.apache.hugegraph.structure.constant.WriteType; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -public abstract class HugeGraphOutput extends AbstractComputerOutput { - - private static final Logger LOG = Log.logger(HugeGraphOutput.class); - - private TaskManager taskManager; - private List localVertices; - private int batchSize; - private WriteType writeType; - - @Override - public void init(Config config, int partition) { - super.init(config, partition); - - this.taskManager = new TaskManager(config); - this.batchSize = config.get(ComputerOptions.OUTPUT_BATCH_SIZE); - this.localVertices = new ArrayList<>(this.batchSize); - this.writeType = WriteType.valueOf( - config.get(ComputerOptions.OUTPUT_RESULT_WRITE_TYPE)); - - this.prepareSchema(); - } - - public HugeClient client() { - return this.taskManager.client(); - } - - @Override - public void write(Vertex vertex) { - this.localVertices.add(this.constructHugeVertex(vertex)); - if (this.localVertices.size() >= this.batchSize) { - this.commit(); - } - } - - @Override - public void close() { - if (!this.localVertices.isEmpty()) { - this.commit(); - } - this.taskManager.waitFinished(); - this.taskManager.shutdown(); - LOG.info("End write back partition {}", this.partition()); - } - - protected void commit() { - this.taskManager.submitBatch(this.localVertices); - LOG.info("Write back {} vertices", this.localVertices.size()); - - this.localVertices = new ArrayList<>(this.batchSize); - } - - protected org.apache.hugegraph.structure.graph.Vertex constructHugeVertex( - Vertex vertex) { - org.apache.hugegraph.structure.graph.Vertex hugeVertex = - new org.apache.hugegraph.structure.graph.Vertex(null); - hugeVertex.id(vertex.id().asObject()); - hugeVertex.property(this.name(), this.value(vertex)); - return hugeVertex; - } - - protected T value(Vertex vertex) { - @SuppressWarnings("unchecked") - T value = (T) vertex.value().value(); - return value; - } - - protected WriteType writeType() { - return this.writeType; - } - - protected abstract void prepareSchema(); -} 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 deleted file mode 100644 index 4558b2744..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/exceptions/WriteBackException.java +++ /dev/null @@ -1,39 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.exceptions; - -public class WriteBackException extends RuntimeException { - - private static final long serialVersionUID = 5504623124963497613L; - - public WriteBackException(String message) { - super(message); - } - - public WriteBackException(String message, Throwable cause) { - super(message, cause); - } - - public WriteBackException(String message, Object... args) { - super(String.format(message, args)); - } - - public WriteBackException(String message, Throwable cause, Object... args) { - super(String.format(message, args), cause); - } -} 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 deleted file mode 100644 index 2a1a559e4..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadMetrics.java +++ /dev/null @@ -1,47 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.metrics; - -import java.util.concurrent.atomic.LongAdder; - -public final class LoadMetrics { - - private final LongAdder insertSuccess; - private final LongAdder insertFailure; - - public LoadMetrics() { - this.insertSuccess = new LongAdder(); - this.insertFailure = new LongAdder(); - } - - public long insertSuccess() { - return this.insertSuccess.longValue(); - } - - public void plusInsertSuccess(long count) { - this.insertSuccess.add(count); - } - - public long insertFailure() { - return this.insertFailure.longValue(); - } - - public void increaseInsertFailure() { - this.insertFailure.increment(); - } -} 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 deleted file mode 100644 index 2fd188108..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadReport.java +++ /dev/null @@ -1,40 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.metrics; - -public final class LoadReport { - - private long vertexInsertSuccess; - private long vertexInsertFailure; - - public long vertexInsertSuccess() { - return this.vertexInsertSuccess; - } - - public long vertexInsertFailure() { - return this.vertexInsertFailure; - } - - public static LoadReport collect(LoadSummary summary) { - LoadReport report = new LoadReport(); - LoadMetrics metrics = summary.metrics(); - report.vertexInsertSuccess += metrics.insertSuccess(); - report.vertexInsertFailure += metrics.insertFailure(); - return report; - } -} 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 deleted file mode 100644 index 38676098d..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/LoadSummary.java +++ /dev/null @@ -1,71 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.metrics; - -import java.util.concurrent.atomic.LongAdder; - -import org.apache.commons.lang3.time.StopWatch; - -public final class LoadSummary { - - private final LongAdder vertexLoaded; - private final StopWatch totalTimer; - private final LoadMetrics metrics; - - public LoadSummary() { - this.vertexLoaded = new LongAdder(); - this.totalTimer = new StopWatch(); - this.metrics = new LoadMetrics(); - } - - public LoadMetrics metrics() { - return this.metrics; - } - - public long vertexLoaded() { - return this.vertexLoaded.longValue(); - } - - public void plusLoaded(int count) { - this.vertexLoaded.add(count); - } - - public long totalTime() { - return this.totalTimer.getTime(); - } - - public void startTimer() { - if (!this.totalTimer.isStarted()) { - this.totalTimer.start(); - } - } - - public void stopTimer() { - if (!this.totalTimer.isStopped()) { - this.totalTimer.stop(); - } - } - - public long loadRate() { - long totalTime = this.totalTime(); - if (totalTime == 0) { - return -1; - } - return this.vertexLoaded() * 1000 / totalTime; - } -} 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 deleted file mode 100644 index bc6b258ca..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/metrics/Printer.java +++ /dev/null @@ -1,56 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.metrics; - -import org.apache.hugegraph.util.Log; -import org.apache.hugegraph.util.TimeUtil; -import org.slf4j.Logger; - -public final class Printer { - - private static final Logger LOG = Log.logger(Printer.class); - - public static void printSummary(LoadSummary summary) { - printCountReport(LoadReport.collect(summary)); - printMeterReport(summary); - } - - private static void printCountReport(LoadReport report) { - log("count metrics"); - log("vertex insert success", report.vertexInsertSuccess()); - log("vertex insert failure", report.vertexInsertFailure()); - } - - private static void printMeterReport(LoadSummary summary) { - log("meter metrics"); - log("total time", TimeUtil.readableTime(summary.totalTime())); - log("vertex load rate(vertices/s)", summary.loadRate()); - } - - private static void log(String message) { - LOG.info(message); - } - - private static void log(String key, long value) { - LOG.info(String.format(" %-30s: %-20d", key, value)); - } - - private static void log(String key, String value) { - LOG.info(String.format(" %-30s: %-20s", key, value)); - } -} 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 deleted file mode 100644 index 69d99ed1b..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/BatchInsertTask.java +++ /dev/null @@ -1,101 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.task; - -import java.util.List; - -import org.apache.commons.lang3.StringUtils; -import org.apache.hugegraph.computer.core.config.ComputerOptions; -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.output.hg.metrics.LoadSummary; -import org.apache.hugegraph.driver.HugeClient; -import org.apache.hugegraph.exception.ServerException; -import org.apache.hugegraph.rest.ClientException; -import org.apache.hugegraph.structure.graph.Vertex; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -public class BatchInsertTask extends InsertTask { - - private static final Logger LOG = Log.logger(TaskManager.class); - - public BatchInsertTask(Config config, HugeClient client, - List batch, LoadSummary loadSummary) { - super(config, client, batch, loadSummary); - } - - @Override - public void run() { - int retryCount = 0; - int retryTimes = this.config.get(ComputerOptions.OUTPUT_RETRY_TIMES); - do { - try { - this.insertBatch(this.batch); - break; - } catch (ClientException e) { - LOG.debug("client exception: {}", e.getMessage()); - Throwable cause = e.getCause(); - if (cause != null && cause.getMessage() != null) { - if (StringUtils.containsAny(cause.getMessage(), - UNACCEPTABLE_MESSAGES)) { - throw e; - } - } - retryCount = this.waitThenRetry(retryCount, e); - } catch (ServerException e) { - String message = e.getMessage(); - LOG.error("server exception: {}", message); - if (UNACCEPTABLE_EXCEPTIONS.contains(e.exception())) { - throw e; - } - if (StringUtils.containsAny(message, UNACCEPTABLE_MESSAGES)) { - throw e; - } - retryCount = this.waitThenRetry(retryCount, e); - } - } while (retryCount > 0 && retryCount <= retryTimes); - - int count = this.batch.size(); - // This metrics just for current element mapping - this.plusLoadSuccess(count); - } - - private int waitThenRetry(int retryCount, RuntimeException e) { - int retryTimes = this.config.get(ComputerOptions.OUTPUT_RETRY_TIMES); - if (retryTimes <= 0) { - return retryCount; - } - - if (++retryCount > retryTimes) { - LOG.error("Batch insert has been retried more than {} times", - retryTimes); - throw e; - } - - long interval = (1L << retryCount) * - this.config.get(ComputerOptions.OUTPUT_RETRY_INTERVAL); - LOG.debug("Batch insert will sleep {} seconds then do the {}th retry", - interval, retryCount); - try { - Thread.sleep(interval * 1000L); - } catch (InterruptedException ignored) { - // That's fine, just continue. - } - return retryCount; - } -} 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 deleted file mode 100644 index 251ed4951..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/InsertTask.java +++ /dev/null @@ -1,79 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.task; - -import java.util.List; -import java.util.Set; - -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.output.hg.metrics.LoadMetrics; -import org.apache.hugegraph.computer.core.output.hg.metrics.LoadSummary; -import org.apache.hugegraph.driver.HugeClient; -import org.apache.hugegraph.structure.graph.Vertex; - -import com.google.common.collect.ImmutableSet; - -public abstract class InsertTask implements Runnable { - - public static final Set UNACCEPTABLE_EXCEPTIONS = ImmutableSet.of( - "class java.lang.IllegalArgumentException" - ); - - public static final String[] UNACCEPTABLE_MESSAGES = { - // org.apache.http.conn.HttpHostConnectException - "Connection refused", - "The server is being shutting down", - "not allowed to insert, because already exist a vertex " + - "with same id and different label" - }; - - protected Config config; - private HugeClient client; - protected final List batch; - private LoadSummary summary; - - public InsertTask(Config config, HugeClient client, - List batch, LoadSummary loadSummary) { - this.config = config; - this.client = client; - this.batch = batch; - this.summary = loadSummary; - } - - public LoadSummary summary() { - return this.summary; - } - - public LoadMetrics metrics() { - return this.summary().metrics(); - } - - protected void plusLoadSuccess(int count) { - LoadMetrics metrics = this.summary().metrics(); - metrics.plusInsertSuccess(count); - this.summary().plusLoaded(count); - } - - protected void increaseLoadSuccess() { - this.plusLoadSuccess(1); - } - - protected void insertBatch(List vertices) { - this.client.graph().addVertices(vertices); - } -} 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 deleted file mode 100644 index f823a24d8..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/SingleInsertTask.java +++ /dev/null @@ -1,60 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.task; - -import java.util.List; - -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.output.hg.metrics.LoadSummary; -import org.apache.hugegraph.driver.HugeClient; -import org.apache.hugegraph.structure.graph.Vertex; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -import com.google.common.collect.ImmutableList; - -public class SingleInsertTask extends InsertTask { - - private static final Logger LOG = Log.logger(TaskManager.class); - - public SingleInsertTask(Config config, HugeClient client, - List batch, LoadSummary loadSummary) { - super(config, client, batch, loadSummary); - } - - @Override - public void run() { - for (Vertex vertex : this.batch) { - try { - this.insertSingle(vertex); - this.increaseLoadSuccess(); - } catch (Exception e) { - this.metrics().increaseInsertFailure(); - this.handleInsertFailure(e); - } - } - } - - private void handleInsertFailure(Exception e) { - LOG.error("Single insert error", e); - } - - private void insertSingle(Vertex vertex) { - this.insertBatch(ImmutableList.of(vertex)); - } -} 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 deleted file mode 100644 index cdeb95ed8..000000000 --- a/computer-api/src/main/java/org/apache/hugegraph/computer/core/output/hg/task/TaskManager.java +++ /dev/null @@ -1,187 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg.task; - -import java.util.List; -import java.util.concurrent.CompletableFuture; -import java.util.concurrent.ExecutorService; -import java.util.concurrent.Semaphore; -import java.util.concurrent.TimeUnit; - -import org.apache.hugegraph.computer.core.config.ComputerOptions; -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.output.hg.exceptions.WriteBackException; -import org.apache.hugegraph.computer.core.output.hg.metrics.LoadSummary; -import org.apache.hugegraph.computer.core.output.hg.metrics.Printer; -import org.apache.hugegraph.driver.HugeClient; -import org.apache.hugegraph.driver.HugeClientBuilder; -import org.apache.hugegraph.structure.graph.Vertex; -import org.apache.hugegraph.util.ExecutorUtil; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -public final class TaskManager { - - private static final Logger LOG = Log.logger(TaskManager.class); - - public static final String BATCH_WORKER = "batch-worker-%d"; - public static final String SINGLE_WORKER = "single-worker-%d"; - - private HugeClient client; - private Config config; - - private final Semaphore batchSemaphore; - private final Semaphore singleSemaphore; - private final ExecutorService batchService; - private final ExecutorService singleService; - - private LoadSummary loadSummary; - - public TaskManager(Config config) { - this.config = config; - String url = config.get(ComputerOptions.HUGEGRAPH_URL); - String graph = config.get(ComputerOptions.HUGEGRAPH_GRAPH_NAME); - String username = config.get(ComputerOptions.HUGEGRAPH_USERNAME); - String password = config.get(ComputerOptions.HUGEGRAPH_PASSWORD); - this.client = new HugeClientBuilder(url, graph).configUser(username, password).build(); - // Try to make all batch threads running and don't wait for producer - this.batchSemaphore = new Semaphore(this.batchSemaphoreNum()); - /* - * Let batch threads go forward as far as possible and don't wait for - * single thread pool - */ - this.singleSemaphore = new Semaphore(this.singleSemaphoreNum()); - /* - * In principle, unbounded synchronization queue(which may lead to OOM) - * should not be used, but there the task manager uses semaphores to - * limit the number of tasks added. When there are no idle threads in - * the thread pool, the producer will be blocked, so OOM will not occur. - */ - this.batchService = ExecutorUtil.newFixedThreadPool( - config.get(ComputerOptions.OUTPUT_BATCH_THREADS), - BATCH_WORKER); - this.singleService = ExecutorUtil.newFixedThreadPool( - config.get(ComputerOptions.OUTPUT_SINGLE_THREADS), - SINGLE_WORKER); - - this.loadSummary = new LoadSummary(); - this.loadSummary.startTimer(); - } - - public HugeClient client() { - return this.client; - } - - private int batchSemaphoreNum() { - return 1 + this.config.get(ComputerOptions.OUTPUT_BATCH_THREADS); - } - - private int singleSemaphoreNum() { - return 2 * this.config.get(ComputerOptions.OUTPUT_SINGLE_THREADS); - } - - public void waitFinished() { - LOG.info("Waiting for the insert tasks finished"); - try { - // Wait batch mode task stopped - this.batchSemaphore.acquire(this.batchSemaphoreNum()); - LOG.info("The batch-mode tasks stopped"); - } catch (InterruptedException e) { - LOG.error("Interrupted while waiting batch-mode tasks"); - } finally { - this.batchSemaphore.release(this.batchSemaphoreNum()); - } - - try { - // Wait single mode task stopped - this.singleSemaphore.acquire(this.singleSemaphoreNum()); - LOG.info("The single-mode tasks stopped"); - } catch (InterruptedException e) { - LOG.error("Interrupted while waiting single-mode tasks"); - } finally { - this.singleSemaphore.release(this.singleSemaphoreNum()); - } - } - - public void shutdown() { - long timeout = this.config.get( - ComputerOptions.OUTPUT_THREAD_POOL_SHUTDOWN_TIMEOUT); - try { - this.batchService.shutdown(); - this.batchService.awaitTermination(timeout, TimeUnit.SECONDS); - LOG.info("The batch-mode tasks service executor shutdown"); - } catch (InterruptedException e) { - LOG.error("The batch-mode tasks are interrupted"); - } finally { - if (!this.batchService.isTerminated()) { - LOG.error("The unfinished batch-mode tasks will be cancelled"); - } - this.batchService.shutdownNow(); - } - - try { - this.singleService.shutdown(); - this.singleService.awaitTermination(timeout, TimeUnit.SECONDS); - LOG.info("The single-mode tasks service executor shutdown"); - } catch (InterruptedException e) { - LOG.error("The single-mode tasks are interrupted"); - } finally { - if (!this.singleService.isTerminated()) { - LOG.error("The unfinished single-mode tasks will be cancelled"); - } - this.singleService.shutdownNow(); - } - this.loadSummary.stopTimer(); - Printer.printSummary(this.loadSummary); - - this.client.close(); - } - - public void submitBatch(List batch) { - try { - this.batchSemaphore.acquire(); - } catch (InterruptedException e) { - throw new WriteBackException( - "Interrupted while waiting to submit batch", e); - } - - InsertTask task = new BatchInsertTask(this.config, this.client, - batch, this.loadSummary); - CompletableFuture.runAsync(task, this.batchService).exceptionally(e -> { - LOG.warn("Batch insert error, try single insert", e); - this.submitInSingle(batch); - return null; - }).whenComplete((r, e) -> this.batchSemaphore.release()); - } - - private void submitInSingle(List batch) { - try { - this.singleSemaphore.acquire(); - } catch (InterruptedException e) { - throw new WriteBackException( - "Interrupted while waiting to submit single", e); - } - - InsertTask task = new SingleInsertTask(this.config, this.client, - batch, this.loadSummary); - CompletableFuture.runAsync(task, this.singleService) - .whenComplete((r, e) -> { - this.singleSemaphore.release(); - }); - } -} 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 deleted file mode 100644 index dca6aea1d..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LimitedLogOutput.java +++ /dev/null @@ -1,56 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output; - -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.graph.vertex.Vertex; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -public class LimitedLogOutput extends AbstractComputerOutput { - - private static final Logger LOG = Log.logger(LimitedLogOutput.class); - - private static final String CONF_LIMIT_OUTPUT_PER_PARTITION_KEY = - "output.limit_logt_output"; - private static final int CONF_LIMIT_OUTPUT_PER_PARTITION_DEFAULT = 10; - - private int limit; - private int logged; - - @Override - public void init(Config config, int partition) { - super.init(config, partition); - this.limit = config.getInt(CONF_LIMIT_OUTPUT_PER_PARTITION_KEY, - CONF_LIMIT_OUTPUT_PER_PARTITION_DEFAULT); - this.logged = 0; - } - - @Override - public void write(Vertex vertex) { - if (this.logged < this.limit) { - LOG.info("'{}': '{}'", vertex.id(), vertex.value().string()); - this.logged++; - } - } - - @Override - public void close() { - LOG.info("End write back partition {}", this.partition()); - } -} 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 deleted file mode 100644 index ecc7ddf0a..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/LogOutput.java +++ /dev/null @@ -1,42 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output; - -import org.apache.hugegraph.computer.core.graph.vertex.Vertex; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -/** - * LogOutput print the computation result to log file. - * It can't be used on production environment. - * Be used for test or development only. - */ -public class LogOutput extends AbstractComputerOutput { - - private static final Logger LOG = Log.logger(LogOutput.class); - - @Override - public void write(Vertex vertex) { - LOG.info("'{}': '{}'", vertex.id(), vertex.value().string()); - } - - @Override - public void close() { - LOG.info("End write back partition {}", this.partition()); - } -} 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 deleted file mode 100644 index 9d4beece7..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutput.java +++ /dev/null @@ -1,174 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hdfs; - -import java.io.IOException; -import java.net.URI; - -import org.apache.commons.lang3.StringUtils; -import org.apache.hadoop.conf.Configuration; -import org.apache.hadoop.fs.FSDataOutputStream; -import org.apache.hadoop.fs.FileSystem; -import org.apache.hadoop.fs.Path; -import org.apache.hadoop.security.UserGroupInformation; -import org.apache.hugegraph.computer.core.common.exception.ComputerException; -import org.apache.hugegraph.computer.core.config.ComputerOptions; -import org.apache.hugegraph.computer.core.config.Config; -import org.apache.hugegraph.computer.core.graph.vertex.Vertex; -import org.apache.hugegraph.computer.core.output.AbstractComputerOutput; -import org.apache.hugegraph.computer.core.util.StringEncodeUtil; -import org.apache.hugegraph.util.Log; -import org.slf4j.Logger; - -public class HdfsOutput extends AbstractComputerOutput { - - private static final Logger LOG = Log.logger(HdfsOutput.class); - - private FileSystem fs; - private FSDataOutputStream fileOutputStream; - private String delimiter; - private static final String REPLICATION_KEY = "dfs.replication"; - private static final String FILE_PREFIX = "partition_"; - private static final String FILE_SUFFIX = ".csv"; - - @Override - public void init(Config config, int partition) { - super.init(config, partition); - - try { - Configuration configuration = new Configuration(); - Short replication = config.get( - ComputerOptions.OUTPUT_HDFS_REPLICATION); - configuration.set(REPLICATION_KEY, String.valueOf(replication)); - this.fs = HdfsOutput.openHDFS(config, configuration); - - this.delimiter = config.get(ComputerOptions.OUTPUT_HDFS_DELIMITER); - String dir = config.get(ComputerOptions.OUTPUT_HDFS_DIR); - String jobId = config.get(ComputerOptions.JOB_ID); - Path hdfsPath = buildPath(dir, jobId, partition); - this.fileOutputStream = this.fs.create(hdfsPath, true); - } catch (IOException | InterruptedException e) { - throw new ComputerException("Failed to init hdfs output on " + - "partition [%s]", e, partition); - } - } - - @Override - public void write(Vertex vertex) { - try { - if (!this.filter(vertex)) { - return; - } - this.writeString(vertex.id().toString()); - this.writeString(this.delimiter); - this.writeString(this.constructValueString(vertex)); - this.writeString(System.lineSeparator()); - } catch (IOException e) { - throw new ComputerException("Failed to write vertex: {}", - vertex.toString(), e); - } - } - - protected boolean filter(Vertex vertex) { - return true; - } - - protected void writeBytes(byte[] bytes) throws IOException { - this.fileOutputStream.write(bytes); - } - - protected void writeString(String string) throws IOException { - this.writeBytes(StringEncodeUtil.encode(string)); - } - - protected String constructValueString(Vertex vertex) { - return vertex.value().string(); - } - - public static Path buildPath(String dir, String jobId, int partition) { - Path dirPath = new Path(dir, jobId); - return new Path(dirPath, FILE_PREFIX + partition + FILE_SUFFIX); - } - - @Override - public void mergePartitions(Config config) { - Boolean merge = config.get(ComputerOptions.OUTPUT_HDFS_MERGE); - if (merge) { - LOG.info("Merge hdfs output partitions started"); - HdfsOutputMerger hdfsOutputMerger = new HdfsOutputMerger(); - try { - hdfsOutputMerger.init(config); - hdfsOutputMerger.merge(); - } finally { - hdfsOutputMerger.close(); - } - LOG.info("Merge hdfs output partitions finished"); - } - } - - @Override - public void close() { - try { - if (this.fileOutputStream != null) { - this.fileOutputStream.close(); - } - if (this.fs != null) { - this.fs.close(); - } - } catch (IOException e) { - throw new ComputerException("Failed to close hdfs", e); - } - } - - public static FileSystem openHDFS(Config config, Configuration conf) - throws IOException, - InterruptedException { - String url = config.get(ComputerOptions.OUTPUT_HDFS_URL); - Boolean enableKerberos = config.get( - ComputerOptions.OUTPUT_HDFS_KERBEROS_ENABLE); - - String coreSite = config.get( - ComputerOptions.OUTPUT_HDFS_CORE_SITE_PATH); - if (StringUtils.isNotBlank(coreSite)) { - conf.addResource(new Path(coreSite)); - } - String hdfsSite = config.get(ComputerOptions.OUTPUT_HDFS_SITE_PATH); - if (StringUtils.isNotBlank(hdfsSite)) { - conf.addResource(new Path(hdfsSite)); - } - - if (enableKerberos) { - String krb5Conf = config.get(ComputerOptions.OUTPUT_HDFS_KRB5_CONF); - System.setProperty("java.security.krb5.conf", krb5Conf); - String principal = config.get( - ComputerOptions.OUTPUT_HDFS_KERBEROS_PRINCIPAL); - String keyTab = config.get( - ComputerOptions.OUTPUT_HDFS_KERBEROS_KEYTAB); - conf.set("fs.defaultFS", url); - conf.set("hadoop.security.authentication", "kerberos"); - conf.set("dfs.namenode.kerberos.principal", principal); - - UserGroupInformation.setConfiguration(conf); - UserGroupInformation.loginUserFromKeytab(principal, keyTab); - return FileSystem.get(conf); - } else { - String user = config.get(ComputerOptions.OUTPUT_HDFS_USER); - return FileSystem.get(URI.create(url), conf, user); - } - } -} 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 deleted file mode 100644 index 5b107caff..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hdfs/HdfsOutputMerger.java +++ /dev/null @@ -1,88 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hdfs; - -import java.io.IOException; -import java.util.ArrayList; -import java.util.List; - -import org.apache.hadoop.conf.Configuration; -import org.apache.hadoop.fs.FileSystem; -import org.apache.hadoop.fs.Path; -import org.apache.hugegraph.computer.core.common.exception.ComputerException; -import org.apache.hugegraph.computer.core.config.ComputerOptions; -import org.apache.hugegraph.computer.core.config.Config; - -public class HdfsOutputMerger { - - private FileSystem fs; - private Path[] sourcePaths; - private Path mergedPath; - private static final String MERGED_FILE_NAME = "all.csv"; - - protected HdfsOutputMerger() { - } - - protected void init(Config config) { - try { - Configuration configuration = new Configuration(); - this.fs = HdfsOutput.openHDFS(config, configuration); - - String dir = config.get(ComputerOptions.OUTPUT_HDFS_DIR); - String jobId = config.get(ComputerOptions.JOB_ID); - int partitions = config.get(ComputerOptions.JOB_PARTITIONS_COUNT); - this.sourcePaths = this.paths(dir, jobId, partitions); - this.mergedPath = new Path(new Path(dir, jobId), MERGED_FILE_NAME); - } catch (Exception e) { - throw new ComputerException("Failed to init hdfs output merger", e); - } - } - - protected void merge() { - try { - this.fs.create(this.mergedPath, true).close(); - this.fs.concat(this.mergedPath, this.sourcePaths); - } catch (IOException e) { - throw new ComputerException("Failed to merge hdfs output files", e); - } - } - - private Path[] paths(String dir, String jobId, int partitions) throws - IOException { - List pathList = new ArrayList<>(); - for (int i = 0; i < partitions; i++) { - Path path = HdfsOutput.buildPath(dir, jobId, i); - if (this.fs.exists(path) && - this.fs.getFileStatus(path).getLen() > 0) { - pathList.add(path); - } - } - return pathList.toArray(new Path[0]); - } - - protected void close() { - try { - if (this.fs != null) { - this.fs.close(); - } - } catch (IOException e) { - throw new ComputerException("Failed to close hdfs output merger", - e); - } - } -} 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 deleted file mode 100644 index b948eb812..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphDoubleOutput.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -public class HugeGraphDoubleOutput extends HugeGraphOutput { - - @Override - protected void prepareSchema() { - this.client().schema().propertyKey(this.name()) - .asDouble() - .writeType(this.writeType()) - .ifNotExist() - .create(); - } -} 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 deleted file mode 100644 index 11664fbcd..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphFloatOutput.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -public class HugeGraphFloatOutput extends HugeGraphOutput { - - @Override - protected void prepareSchema() { - this.client().schema().propertyKey(this.name()) - .asFloat() - .writeType(this.writeType()) - .ifNotExist() - .create(); - } -} 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 deleted file mode 100644 index beafe1846..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIdOutput.java +++ /dev/null @@ -1,37 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -import org.apache.hugegraph.computer.core.graph.vertex.Vertex; - -public class HugeGraphIdOutput extends HugeGraphOutput { - - @Override - protected void prepareSchema() { - this.client().schema().propertyKey(this.name()) - .asText() - .writeType(this.writeType()) - .ifNotExist() - .create(); - } - - @Override - protected String value(Vertex vertex) { - return vertex.value().string(); - } -} 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 deleted file mode 100644 index f480cd76e..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphIntOutput.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -public class HugeGraphIntOutput extends HugeGraphOutput { - - @Override - protected void prepareSchema() { - this.client().schema().propertyKey(this.name()) - .asInt() - .writeType(this.writeType()) - .ifNotExist() - .create(); - } -} 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 deleted file mode 100644 index d155d80a9..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphLongOutput.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -public class HugeGraphLongOutput extends HugeGraphOutput { - - @Override - protected void prepareSchema() { - this.client().schema().propertyKey(this.name()) - .asLong() - .writeType(this.writeType()) - .ifNotExist() - .create(); - } -} 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 deleted file mode 100644 index db2fcdb57..000000000 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/output/hg/HugeGraphStringOutput.java +++ /dev/null @@ -1,30 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.core.output.hg; - -public class HugeGraphStringOutput extends HugeGraphOutput { - - @Override - protected void prepareSchema() { - this.client().schema().propertyKey(this.name()) - .asText() - .writeType(this.writeType()) - .ifNotExist() - .create(); - } -} diff --git a/computer-dist/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputer.java b/computer-dist/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputer.java deleted file mode 100644 index 8fd09bab7..000000000 --- a/computer-dist/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputer.java +++ /dev/null @@ -1,151 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ - -package org.apache.hugegraph.computer.dist; - -import java.io.BufferedReader; -import java.io.FileReader; -import java.io.IOException; -import java.util.Properties; - -import org.apache.commons.lang.ArrayUtils; -import org.apache.commons.lang.StringUtils; -import org.apache.hugegraph.computer.core.common.ComputerContext; -import org.apache.hugegraph.computer.core.graph.id.IdType; -import org.apache.hugegraph.computer.core.graph.value.ValueType; -import org.apache.hugegraph.computer.core.master.MasterService; -import org.apache.hugegraph.computer.core.network.message.MessageType; -import org.apache.hugegraph.computer.core.util.ComputerContextUtil; -import org.apache.hugegraph.computer.core.worker.WorkerService; -import org.apache.hugegraph.config.OptionSpace; -import org.apache.hugegraph.config.RpcOptions; -import org.apache.hugegraph.util.E; -import org.apache.hugegraph.util.Log; -import org.apache.logging.log4j.LogManager; -import org.slf4j.Logger; - -public class HugeGraphComputer { - - private static final Logger LOG = Log.logger(HugeGraphComputer.class); - - private static final String ROLE_MASTER = "master"; - private static final String ROLE_WORKER = "worker"; - - /** - * Some class must be load first, in order to invoke static method to init; - */ - private static void loadClass() throws ClassNotFoundException { - Class.forName(IdType.class.getCanonicalName()); - Class.forName(MessageType.class.getCanonicalName()); - Class.forName(ValueType.class.getCanonicalName()); - } - - public static void main(String[] args) throws IOException, - ClassNotFoundException { - Runtime.getRuntime().addShutdownHook(new Thread(LogManager::shutdown)); - - E.checkArgument(ArrayUtils.getLength(args) == 3, - "Argument count must be three, " + - "the first is conf path;" + - "the second is role type;" + - "the third is drive type."); - String role = args[1]; - E.checkArgument(!StringUtils.isEmpty(role), - "The role can't be null or emtpy, " + - "it must be either '%s' or '%s'", - ROLE_MASTER, ROLE_WORKER); - setUncaughtExceptionHandler(); - loadClass(); - registerOptions(); - ComputerContext context = parseContext(args[0], role); - switch (role) { - case ROLE_MASTER: - executeMasterService(context); - break; - case ROLE_WORKER: - executeWorkerService(context); - break; - default: - throw new IllegalArgumentException( - String.format("Unexpected role '%s'", role)); - } - } - - protected static void setUncaughtExceptionHandler() { - Thread.UncaughtExceptionHandler handler = - Thread.getDefaultUncaughtExceptionHandler(); - Thread.setDefaultUncaughtExceptionHandler( - new PrintExceptionHandler(handler) - ); - } - - private static class PrintExceptionHandler implements - Thread.UncaughtExceptionHandler { - - private final Thread.UncaughtExceptionHandler handler; - - PrintExceptionHandler(Thread.UncaughtExceptionHandler handler) { - this.handler = handler; - } - - @Override - public void uncaughtException(Thread t, Throwable e) { - HugeGraphComputer.LOG.error("Failed to run service on {}, {}", - t, e.getMessage(), e); - if (this.handler != null) { - this.handler.uncaughtException(t, e); - } - } - } - - private static void executeWorkerService(ComputerContext context) { - try (WorkerService workerService = new WorkerService()) { - workerService.init(context.config()); - workerService.execute(); - } - } - - private static void executeMasterService(ComputerContext context) { - try (MasterService masterService = new MasterService()) { - masterService.init(context.config()); - masterService.execute(); - } - } - - private static ComputerContext parseContext(String conf, String role) - throws IOException { - Properties properties = new Properties(); - BufferedReader bufferedReader = new BufferedReader( - new FileReader(conf)); - properties.load(bufferedReader); - properties.remove(RpcOptions.RPC_REMOTE_URL.name()); - if (ROLE_WORKER.equals(role)) { - properties.remove(RpcOptions.RPC_SERVER_HOST.name()); - properties.remove(RpcOptions.RPC_SERVER_PORT.name()); - } - ComputerContextUtil.initContext(properties); - return ComputerContext.instance(); - } - - private static void registerOptions() { - OptionSpace.register("computer", - "org.apache.hugegraph.computer.core.config." + - "ComputerOptions"); - OptionSpace.register("computer-rpc", - "org.apache.hugegraph.config.RpcOptions"); - } -} 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 deleted file mode 100644 index ebdf1f4dd..000000000 --- a/computer-test/src/main/java/org/apache/hugegraph/computer/dist/ComputerDistTestSuite.java +++ /dev/null @@ -1,27 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ -package org.apache.hugegraph.computer.dist; - -import org.junit.runner.RunWith; -import org.junit.runners.Suite; - -@RunWith(Suite.class) -@Suite.SuiteClasses({ - HugeGraphComputerTest.class -}) -public class ComputerDistTestSuite { -} 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 deleted file mode 100644 index 429aa75fc..000000000 --- a/computer-test/src/main/java/org/apache/hugegraph/computer/dist/HugeGraphComputerTest.java +++ /dev/null @@ -1,103 +0,0 @@ -/* - * Licensed to the Apache Software Foundation (ASF) under one or more - * contributor license agreements. See the NOTICE file distributed with this - * work for additional information regarding copyright ownership. The ASF - * licenses this file to You under the Apache License, Version 2.0 (the - * "License"); you may not use this file except in compliance with the License. - * You may obtain a copy of the License at - * - * http://www.apache.org/licenses/LICENSE-2.0 - * - * Unless required by applicable law or agreed to in writing, software - * distributed under the License is distributed on an "AS IS" BASIS, WITHOUT - * WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. See the - * License for the specific language governing permissions and limitations - * under the License. - */ -package org.apache.hugegraph.computer.dist; - -import java.util.Arrays; -import java.util.concurrent.CountDownLatch; -import java.util.concurrent.ExecutorService; -import java.util.concurrent.Executors; -import java.util.concurrent.atomic.AtomicBoolean; - -import org.apache.hugegraph.computer.suite.unit.UnitTestBase; -import org.apache.hugegraph.testutil.Assert; -import org.apache.hugegraph.util.Log; -import org.junit.Test; -import org.slf4j.Logger; - -public class HugeGraphComputerTest extends UnitTestBase { - - private static final Logger LOG = Log.logger(HugeGraphComputerTest.class); - - @Test - public void testServiceWith1Worker() throws InterruptedException { - ExecutorService pool = Executors.newFixedThreadPool(2); - CountDownLatch countDownLatch = new CountDownLatch(2); - Throwable[] exceptions = new Throwable[2]; - String masterConfPath = HugeGraphComputerTest.class.getResource( - "/computer.properties").getPath(); - String work1ConfPath = HugeGraphComputerTest.class.getResource( - "/computer.properties").getPath(); - pool.submit(() -> { - try { - Thread.sleep(2000L); - String[] args = {work1ConfPath, "worker", "local"}; - HugeGraphComputer.main(args); - } catch (Throwable e) { - LOG.error("Failed to start worker", e); - exceptions[0] = e; - } finally { - countDownLatch.countDown(); - } - }); - - pool.submit(() -> { - try { - String[] args = {masterConfPath, "master", "local"}; - HugeGraphComputer.main(args); - } catch (Throwable e) { - LOG.error("Failed to start master", e); - exceptions[1] = e; - } finally { - countDownLatch.countDown(); - } - }); - - countDownLatch.await(); - pool.shutdownNow(); - - Assert.assertFalse(Arrays.asList(exceptions).toString(), - this.existError(exceptions)); - } - - @Test - public void testServiceWithError() { - String work1ConfPath = HugeGraphComputerTest.class.getResource( - "/computer.properties").getPath(); - Assert.assertThrows(IllegalArgumentException.class, - () -> { - String[] args1 = {work1ConfPath, "worker111", - "local"}; - HugeGraphComputer.main(args1); - }); - } - - @Test - public void testPrintUncaughtException() throws InterruptedException { - AtomicBoolean isRun = new AtomicBoolean(false); - Thread.UncaughtExceptionHandler handler = (t, e) -> { - isRun.compareAndSet(false, true); - }; - Thread.setDefaultUncaughtExceptionHandler(handler); - HugeGraphComputer.setUncaughtExceptionHandler(); - Thread t = new Thread(() -> { - throw new RuntimeException(); - }); - t.start(); - t.join(); - Assert.assertTrue(isRun.get()); - } -} diff --git a/computer/README.md b/computer/README.md new file mode 100644 index 000000000..f168e3be9 --- /dev/null +++ b/computer/README.md @@ -0,0 +1,44 @@ +# Apache HugeGraph-Computer + +[![License](https://img.shields.io/badge/license-Apache%202-0E78BA.svg)](https://www.apache.org/licenses/LICENSE-2.0.html) +[![Build Status](https://github.com/apache/hugegraph-computer/actions/workflows/ci.yml/badge.svg)](https://github.com/apache/hugegraph-computer/actions/workflows/ci.yml) +[![codecov](https://codecov.io/gh/apache/incubator-hugegraph-computer/branch/master/graph/badge.svg)](https://codecov.io/gh/apache/incubator-hugegraph-computer) + +The hugegraph-computer is a distributed graph processing system for hugegraph. + +## Learn More + +The [project homepage](https://hugegraph.apache.org/docs/) contains more information about hugegraph-computer. + +And here are links of other repositories: +1. [hugegraph-server](https://github.com/apache/hugegraph) (graph's core component - OLTP server) +2. [hugegraph-toolchain](https://github.com/apache/hugegraph-toolchain) (include loader/dashboard/tool/client) +3. [hugegraph-commons](https://github.com/apache/hugegraph-commons) (include common & rpc module) +4. [hugegraph-website](https://github.com/apache/hugegraph-doc) (include doc & website code) + +## Note + +- If some classes under computer-k8s cannot be found, you need to execute `mvn clean install` in advance to generate corresponding classes. + +## Contributing + +- Welcome to contribute to HugeGraph, please see [How to Contribute](https://hugegraph.apache.org/docs/contribution-guidelines/contribute/) for more information. +- Note: It's recommended to use [GitHub Desktop](https://desktop.github.com/) to greatly simplify the PR and commit process. +- Thank you to all the people who already contributed to HugeGraph! + +[![contributors graph](https://contrib.rocks/image?repo=apache/hugegraph-computer)](https://github.com/apache/incubator-hugegraph-computer/graphs/contributors) + +## License + +hugegraph-computer is licensed under [Apache 2.0](https://github.com/apache/incubator-hugegraph-computer/blob/master/LICENSE) License. + +### Contact Us + +--- + + - [GitHub Issues](https://github.com/apache/incubator-hugegraph-computer/issues): Feedback on usage issues and functional requirements (quick response) + - Feedback Email: [dev@hugegraph.apache.org](mailto:dev@hugegraph.apache.org) ([subscriber](https://hugegraph.apache.org/docs/contribution-guidelines/subscribe/) only) + - WeChat public account: Apache HugeGraph, welcome to scan this QR code to follow us. + + QR png + diff --git a/computer-algorithm/pom.xml b/computer/computer-algorithm/pom.xml similarity index 100% rename from computer-algorithm/pom.xml rename to computer/computer-algorithm/pom.xml diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentrality.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessMessage.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessValue.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentrality.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessMessage.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessValue.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentrality.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRank4Master.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficient.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientOutput.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientValue.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/Kcore.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreValue.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/Lpa.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCount.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountValue.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/Wcc.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetection.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionOutput.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/FilterDescribe.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionMessage.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilter.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/RingsDetectionWithFilterParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/filter/SpreadFilter.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/QuantityType.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/QuantityType.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/QuantityType.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/QuantityType.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPath.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPath.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPath.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPath.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathCombiner.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathCombiner.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathCombiner.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathCombiner.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathMaster.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathMaster.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathMaster.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathMaster.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathOutput.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathOutput.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathOutput.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathOutput.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathParams.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathValue.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathValue.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathValue.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathValue.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalk.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalk.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalk.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalk.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkMessage.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkMessage.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkMessage.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkMessage.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkOutput.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkOutput.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkOutput.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkOutput.java diff --git a/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkParams.java b/computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkParams.java similarity index 100% rename from computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkParams.java rename to computer/computer-algorithm/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkParams.java diff --git a/computer-api/pom.xml b/computer/computer-api/pom.xml similarity index 100% rename from computer-api/pom.xml rename to computer/computer-api/pom.xml diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmParams.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Master.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregator4Worker.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Allocator.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/Recyclable.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclerReference.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/Combiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdListMergeCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdListMergeCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdListMergeCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdListMergeCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdSetMergeCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdSetMergeCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdSetMergeCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IdSetMergeCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwritePropertiesCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/PropertiesCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombiner.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/ComputerContext.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/Constants.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/SerialEnum.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/common/exception/ComputerException.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/ComputerOptions.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Config.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfig.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/EdgeFrequency.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/HotConfig.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/config/Null.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/GraphFactory.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edge.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/edge/Edges.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/Id.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactory.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdType.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/DefaultProperties.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/properties/Properties.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdList.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListList.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdSet.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/MapValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValue.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/Value.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueType.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/Vertex.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/input/InputFilter.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesInput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/BytesOutput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeInput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphComputeOutput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphInput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphOutput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/GraphWritebackOutput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessInput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/RandomAccessOutput.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Readable.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/io/Writable.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/DefaultMasterComputation.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputation.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterComputationContext.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/master/MasterContext.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/BytesUtil.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/CoderUtil.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/IdUtil.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/IdUtil.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/util/IdUtil.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/IdUtil.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilExt.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilExt.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilExt.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilExt.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/Computation.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ComputationContext.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/FilterComputation.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/ReduceComputation.java diff --git a/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java b/computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java similarity index 100% rename from computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java rename to computer/computer-api/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerContext.java diff --git a/computer-core/pom.xml b/computer/computer-core/pom.xml similarity index 100% rename from computer-core/pom.xml rename to computer/computer-core/pom.xml diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/Aggregators.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/DefaultAggregator.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/MasterAggrManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/RegisterAggregators.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/aggregator/WorkerAggrManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocator.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/allocator/RecycleHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Master.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/Bsp4Worker.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspBase.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspClient.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEvent.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspClient.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClient.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java similarity index 98% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java index 56c606797..5e79cff56 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/AbstractPointerCombiner.java @@ -24,7 +24,6 @@ import org.apache.hugegraph.computer.core.io.BytesOutput; import org.apache.hugegraph.computer.core.io.IOFactory; import org.apache.hugegraph.computer.core.io.RandomAccessInput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.store.entry.InlinePointer; import org.apache.hugegraph.computer.core.store.entry.Pointer; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/EdgeValueCombiner.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/MessageValueCombiner.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombiner.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/combiner/VertexValueCombiner.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java similarity index 98% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java index 643db7aae..a43ffac45 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfo.java @@ -22,7 +22,6 @@ import org.apache.hugegraph.computer.core.io.RandomAccessInput; import org.apache.hugegraph.computer.core.io.RandomAccessOutput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.network.TransportUtil; import org.apache.hugegraph.computer.core.util.JsonUtil; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/IllegalArgException.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/ReadException.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/TransportException.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/common/exception/WriteException.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/FileGraphPartition.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java similarity index 98% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java index 3d4a23753..2be423597 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/ReusablePointer.java @@ -24,7 +24,6 @@ import org.apache.hugegraph.computer.core.io.IOFactory; import org.apache.hugegraph.computer.core.io.RandomAccessInput; import org.apache.hugegraph.computer.core.io.RandomAccessOutput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.store.entry.Pointer; import org.apache.hugegraph.computer.core.util.BytesUtil; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/compute/input/VertexInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java similarity index 99% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java index fa7fb3b59..42bb2f445 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStat.java @@ -24,7 +24,6 @@ import org.apache.hugegraph.computer.core.graph.partition.PartitionStat; import org.apache.hugegraph.computer.core.io.RandomAccessInput; import org.apache.hugegraph.computer.core.io.RandomAccessOutput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.util.JsonUtil; import org.apache.hugegraph.computer.core.worker.WorkerStat; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdge.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/edge/DefaultEdges.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesId.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitioner.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java similarity index 98% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java index a47e4d8c7..aa48c80c6 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStat.java @@ -21,7 +21,6 @@ import org.apache.hugegraph.computer.core.io.RandomAccessInput; import org.apache.hugegraph.computer.core.io.RandomAccessOutput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.receiver.MessageStat; import org.apache.hugegraph.computer.core.util.JsonUtil; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/partition/Partitioner.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/graph/vertex/DefaultVertex.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/EdgeFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/ElementFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/GraphFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/IdUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSourceFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplit.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/MasterInputManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/VertexFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/WorkerInputManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/DefaultInputFilter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/filter/ExtractAllPropertyInputFilter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeEdgeFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeElementFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeGraphFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeInputSplitFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/hg/HugeVertexFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileEdgeFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileElementFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileInputSplit.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/FileVertxFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderFileInputSplitFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/input/loader/LoaderGraphFetcher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/AbstractBufferedFileOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/IOFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedBytesOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/OutputFormat.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructGraphOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Manager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/manager/Managers.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/master/MasterService.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ClientHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionId.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataClientManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/IOMode.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/MessageHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportClient.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportConf.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportProvider.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportServer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportState.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/FileRegionBuffer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NettyBuffer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBuffer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NioBuffer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/connection/TransportConnectionManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AbstractMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AbstractMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AbstractMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AbstractMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/AckMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/DataMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FailMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/FinishMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/Message.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/MessageType.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PingMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/PongMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/RequestMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/ResponseMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/message/StartMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNettyHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/BufAllocatorFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ChannelFutureListenerOnWrite.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEventLoopUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyProtocol.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyServerHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClient.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportProvider.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/ServerIdleHandler.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/FrameDecoder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageDecoder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/MessageEncoder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/netty/codec/PreciseFrameDecoder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ClientSession.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/ServerSession.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSession.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffers.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java index 54237d4f3..82032b1ba 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManager.java @@ -18,9 +18,9 @@ package org.apache.hugegraph.computer.core.receiver; import java.util.Map; +import java.util.concurrent.CompletableFuture; import java.util.concurrent.ExecutionException; import java.util.concurrent.TimeUnit; -import java.util.concurrent.CompletableFuture; import java.util.concurrent.TimeoutException; import java.util.concurrent.atomic.AtomicInteger; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartition.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java index 222fff2c7..bae331c6f 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvPartitions.java @@ -17,6 +17,11 @@ package org.apache.hugegraph.computer.core.receiver; +import java.io.File; +import java.util.HashMap; +import java.util.List; +import java.util.Map; + import org.apache.commons.io.FileUtils; import org.apache.hugegraph.computer.core.common.ComputerContext; import org.apache.hugegraph.computer.core.config.Config; @@ -27,11 +32,6 @@ import org.apache.hugegraph.computer.core.store.SuperstepFileGenerator; import org.apache.hugegraph.computer.core.store.entry.KvEntry; -import java.io.File; -import java.util.HashMap; -import java.util.List; -import java.util.Map; - public abstract class MessageRecvPartitions

{ protected final ComputerContext context; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageStat.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartition.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java index 558bfaa2b..bf6a5c933 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitions.java @@ -17,6 +17,8 @@ package org.apache.hugegraph.computer.core.receiver.edge; +import java.util.List; + import org.apache.hugegraph.computer.core.common.ComputerContext; import org.apache.hugegraph.computer.core.network.message.MessageType; import org.apache.hugegraph.computer.core.receiver.MessageRecvPartitions; @@ -24,8 +26,6 @@ import org.apache.hugegraph.computer.core.sort.sorting.SortManager; import org.apache.hugegraph.computer.core.store.SuperstepFileGenerator; -import java.util.List; - public class EdgeMessageRecvPartitions extends MessageRecvPartitions { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartition.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java index a3e3e3584..7cceff20a 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitions.java @@ -17,14 +17,14 @@ package org.apache.hugegraph.computer.core.receiver.message; +import java.util.List; + import org.apache.hugegraph.computer.core.common.ComputerContext; import org.apache.hugegraph.computer.core.receiver.MessageRecvPartitions; import org.apache.hugegraph.computer.core.snapshot.SnapshotManager; import org.apache.hugegraph.computer.core.sort.sorting.SortManager; import org.apache.hugegraph.computer.core.store.SuperstepFileGenerator; -import java.util.List; - public class ComputeMessageRecvPartitions extends MessageRecvPartitions { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartition.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java index 982ae7409..92ed1d182 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitions.java @@ -17,6 +17,8 @@ package org.apache.hugegraph.computer.core.receiver.vertex; +import java.util.List; + import org.apache.hugegraph.computer.core.common.ComputerContext; import org.apache.hugegraph.computer.core.network.message.MessageType; import org.apache.hugegraph.computer.core.receiver.MessageRecvPartitions; @@ -24,8 +26,6 @@ import org.apache.hugegraph.computer.core.sort.sorting.SortManager; import org.apache.hugegraph.computer.core.store.SuperstepFileGenerator; -import java.util.List; - public class VertexMessageRecvPartitions extends MessageRecvPartitions { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/AggregateRpcService.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/InputSplitRpcService.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/MasterRpcManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/rpc/WorkerRpcManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueue.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffers.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendPartition.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSender.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueue.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessage.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSender.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffers.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java similarity index 99% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java index 674d95d72..f1c2b8191 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/snapshot/SnapshotManager.java @@ -17,17 +17,13 @@ package org.apache.hugegraph.computer.core.snapshot; -import io.minio.BucketExistsArgs; -import io.minio.DownloadObjectArgs; -import io.minio.ListObjectsArgs; -import io.minio.MakeBucketArgs; -import io.minio.MinioClient; -import io.minio.RemoveObjectsArgs; -import io.minio.Result; -import io.minio.UploadObjectArgs; -import io.minio.messages.DeleteError; -import io.minio.messages.DeleteObject; -import io.minio.messages.Item; +import java.io.File; +import java.nio.file.Path; +import java.nio.file.Paths; +import java.util.LinkedList; +import java.util.List; +import java.util.Locale; + import org.apache.commons.lang.StringUtils; import org.apache.hugegraph.computer.core.common.ComputerContext; import org.apache.hugegraph.computer.core.common.ContainerInfo; @@ -43,12 +39,17 @@ import org.apache.hugegraph.util.Log; import org.slf4j.Logger; -import java.io.File; -import java.nio.file.Path; -import java.nio.file.Paths; -import java.util.LinkedList; -import java.util.List; -import java.util.Locale; +import io.minio.BucketExistsArgs; +import io.minio.DownloadObjectArgs; +import io.minio.ListObjectsArgs; +import io.minio.MakeBucketArgs; +import io.minio.MinioClient; +import io.minio.RemoveObjectsArgs; +import io.minio.Result; +import io.minio.UploadObjectArgs; +import io.minio.messages.DeleteError; +import io.minio.messages.DeleteObject; +import io.minio.messages.Item; public class SnapshotManager implements Manager { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/BufferFileSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/DefaultSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/HgkvFileSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/Sorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombinableSorterFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvInnerSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineKvOuterSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvInnerSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/CombineSubKvOuterSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/InnerSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvInnerSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/KvOuterSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/OuterSortFlusher.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIterator.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/flusher/PeekableIteratorAdaptor.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMerger.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/merge/FileMergerImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/InputsSorterImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/JavaInputSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SubKvSorter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/AbstractInputsSorting.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/HeapInputsSorting.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSorting.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/LoserTreeInputsSorting.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/RecvSortManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SendSortManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingFactory.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingMode.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/EntryIterator.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileGenerator.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/FileManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileReader.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/KvEntryFileWriter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/StoreManager.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/SuperstepFileGenerator.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/KvEntriesWithFirstSubKvInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/buffer/SubKvEntriesInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/AbstractKvEntry.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/CachedPointer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/DefaultKvEntry.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntriesUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java similarity index 96% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java index 48197c164..8663da8ed 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInput.java @@ -19,8 +19,6 @@ import java.io.IOException; -import org.apache.hugegraph.computer.core.io.Readable; - public interface EntryInput { /** diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java similarity index 96% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java index dae29884e..c08facf1d 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryInputImpl.java @@ -20,7 +20,6 @@ import java.io.IOException; import org.apache.hugegraph.computer.core.io.RandomAccessInput; -import org.apache.hugegraph.computer.core.io.Readable; public class EntryInputImpl implements EntryInput { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/EntryOutputImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/InlinePointer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntry.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java similarity index 94% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java index d03b22521..ccb2ec620 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReader.java @@ -19,8 +19,6 @@ import java.io.IOException; -import org.apache.hugegraph.computer.core.io.Readable; - public interface KvEntryReader { void readSubKv(Readable subKey, Readable subValue) throws IOException; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java similarity index 97% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java index fee7fef22..3ff0efd45 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryReaderImpl.java @@ -21,7 +21,6 @@ import org.apache.hugegraph.computer.core.common.exception.ComputerException; import org.apache.hugegraph.computer.core.io.RandomAccessInput; -import org.apache.hugegraph.computer.core.io.Readable; public class KvEntryReaderImpl implements KvEntryReader { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWithFirstSubKv.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/KvEntryWriterImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Pointer.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/entry/Range.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryBuilder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileEntryReader.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/bufferfile/BufferFileSubEntryReader.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/AbstractHgkvFile.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDir.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvDirImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFile.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/HgkvFileImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/BlockBuilder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/DataBlockBuilderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvDirBuilderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/HgkvFileBuilderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilder.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/builder/IndexBlockBuilderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDir4SubKvReaderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvDirReaderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/hgkvfile/reader/HgkvFileReaderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DefaultSelectedFiles.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/DisperseEvenlySelector.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/InputFilesSelector.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/select/SelectedFiles.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReader.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileReaderImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriter.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/BitsFileWriterImpl.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFile.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileInput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/store/file/seqfile/ValueFileOutput.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/Consumers.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/FileUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java similarity index 98% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java index 7dfb6d7ce..0cb8449f0 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtil.java @@ -27,7 +27,6 @@ import org.apache.hugegraph.computer.core.io.BytesInput; import org.apache.hugegraph.computer.core.io.BytesOutput; import org.apache.hugegraph.computer.core.io.IOFactory; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; public final class SerializeUtil { diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/ShutdownHook.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncodeUtil.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncodeUtil.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncodeUtil.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/util/StringEncodeUtil.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerService.java diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java similarity index 98% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java index 40491f2c8..b056a9179 100644 --- a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java +++ b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStat.java @@ -25,7 +25,6 @@ import org.apache.hugegraph.computer.core.graph.partition.PartitionStat; import org.apache.hugegraph.computer.core.io.RandomAccessInput; import org.apache.hugegraph.computer.core.io.RandomAccessOutput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.util.JsonUtil; import org.apache.hugegraph.util.E; diff --git a/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java b/computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java similarity index 100% rename from computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java rename to computer/computer-core/src/main/java/org/apache/hugegraph/computer/core/worker/load/LoadService.java diff --git a/computer-dist/Dockerfile b/computer/computer-dist/Dockerfile similarity index 100% rename from computer-dist/Dockerfile rename to computer/computer-dist/Dockerfile diff --git a/computer-dist/pom.xml b/computer/computer-dist/pom.xml similarity index 100% rename from computer-dist/pom.xml rename to computer/computer-dist/pom.xml diff --git a/computer-dist/release-docs/LICENSE b/computer/computer-dist/release-docs/LICENSE similarity index 100% rename from computer-dist/release-docs/LICENSE rename to computer/computer-dist/release-docs/LICENSE diff --git a/computer-dist/release-docs/NOTICE b/computer/computer-dist/release-docs/NOTICE similarity index 100% rename from computer-dist/release-docs/NOTICE rename to computer/computer-dist/release-docs/NOTICE diff --git a/computer-dist/release-docs/licenses/LICENSE-accessors-smart.txt b/computer/computer-dist/release-docs/licenses/LICENSE-accessors-smart.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-accessors-smart.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-accessors-smart.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-activation.txt b/computer/computer-dist/release-docs/licenses/LICENSE-activation.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-activation.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-activation.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-animal-sniffer-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-animal-sniffer-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-animal-sniffer-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-animal-sniffer-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-apiguardian-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-apiguardian-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-apiguardian-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-apiguardian-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-asm.txt b/computer/computer-dist/release-docs/licenses/LICENSE-asm.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-asm.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-asm.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-audience-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-audience-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-audience-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-audience-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-auto-service-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-auto-service-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-auto-service-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-auto-service-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-automaton.txt b/computer/computer-dist/release-docs/licenses/LICENSE-automaton.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-automaton.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-automaton.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-avro.txt b/computer/computer-dist/release-docs/licenses/LICENSE-avro.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-avro.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-avro.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-bcprov-jdk18on.txt b/computer/computer-dist/release-docs/licenses/LICENSE-bcprov-jdk18on.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-bcprov-jdk18on.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-bcprov-jdk18on.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-bolt.txt b/computer/computer-dist/release-docs/licenses/LICENSE-bolt.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-bolt.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-bolt.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-builder-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-builder-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-builder-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-builder-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-byte-buddy.txt b/computer/computer-dist/release-docs/licenses/LICENSE-byte-buddy.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-byte-buddy.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-byte-buddy.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-checker-qual.txt b/computer/computer-dist/release-docs/licenses/LICENSE-checker-qual.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-checker-qual.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-checker-qual.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-beanutils.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-beanutils.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-beanutils.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-beanutils.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-cli.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-cli.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-cli.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-cli.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-codec.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-codec.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-codec.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-codec.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-collections.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-collections.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-collections.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-collections.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-compress.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-compress.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-compress.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-compress.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-configuration.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-configuration.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-configuration.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-configuration.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-configuration2.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-configuration2.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-configuration2.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-configuration2.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-crypto.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-crypto.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-crypto.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-crypto.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-io.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-io.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-io.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-io.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-lang.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-lang.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-lang.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-lang.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-lang3.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-lang3.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-lang3.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-lang3.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-logging.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-logging.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-logging.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-logging.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-math3.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-math3.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-math3.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-math3.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-net.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-net.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-net.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-net.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-commons-text.txt b/computer/computer-dist/release-docs/licenses/LICENSE-commons-text.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-commons-text.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-commons-text.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-curator-client.txt b/computer/computer-dist/release-docs/licenses/LICENSE-curator-client.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-curator-client.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-curator-client.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-curator-framework.txt b/computer/computer-dist/release-docs/licenses/LICENSE-curator-framework.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-curator-framework.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-curator-framework.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-curator-recipes.txt b/computer/computer-dist/release-docs/licenses/LICENSE-curator-recipes.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-curator-recipes.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-curator-recipes.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-disruptor.txt b/computer/computer-dist/release-docs/licenses/LICENSE-disruptor.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-disruptor.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-disruptor.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-error_prone_annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-error_prone_annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-error_prone_annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-error_prone_annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-failsafe.txt b/computer/computer-dist/release-docs/licenses/LICENSE-failsafe.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-failsafe.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-failsafe.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-findbugs-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-findbugs-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-findbugs-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-findbugs-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-generex.txt b/computer/computer-dist/release-docs/licenses/LICENSE-generex.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-generex.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-generex.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-groovy-all.txt b/computer/computer-dist/release-docs/licenses/LICENSE-groovy-all.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-groovy-all.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-groovy-all.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-context.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-context.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-context.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-context.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-grpclb.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-grpclb.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-grpclb.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-grpclb.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-netty.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-netty.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-netty.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-netty.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-protobuf-lite.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-protobuf-lite.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-protobuf-lite.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-protobuf-lite.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-protobuf.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-protobuf.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-protobuf.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-protobuf.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-grpc-stub.txt b/computer/computer-dist/release-docs/licenses/LICENSE-grpc-stub.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-grpc-stub.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-grpc-stub.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-gson.txt b/computer/computer-dist/release-docs/licenses/LICENSE-gson.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-gson.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-gson.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-guava.txt b/computer/computer-dist/release-docs/licenses/LICENSE-guava.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-guava.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-guava.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hadoop-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hadoop-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hadoop-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hadoop-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hadoop-auth.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hadoop-auth.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hadoop-auth.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hadoop-auth.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hadoop-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hadoop-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hadoop-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hadoop-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hadoop-hdfs-client.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hadoop-hdfs-client.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hadoop-hdfs-client.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hadoop-hdfs-client.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hamcrest-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hamcrest-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hamcrest-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hamcrest-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-client.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-client.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-client.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-client.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-hadoop-compat.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-hadoop-compat.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-hadoop-compat.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-hadoop-compat.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-hadoop2-compat.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-hadoop2-compat.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-hadoop2-compat.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-hadoop2-compat.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-http.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-http.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-http.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-http.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-mapreduce.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-mapreduce.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-mapreduce.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-mapreduce.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-metrics-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-metrics-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-metrics-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-metrics-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-metrics.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-metrics.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-metrics.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-metrics.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-procedure.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-procedure.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-procedure.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-procedure.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-protocol-shaded.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-protocol-shaded.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-protocol-shaded.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-protocol-shaded.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-protocol.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-protocol.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-protocol.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-protocol.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-replication.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-replication.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-replication.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-replication.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-server.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-server.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-server.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-server.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-client-byo-hadoop.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-client-byo-hadoop.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-shaded-client-byo-hadoop.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-client-byo-hadoop.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-miscellaneous.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-miscellaneous.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-shaded-miscellaneous.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-miscellaneous.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-netty.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-netty.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-shaded-netty.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-netty.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-protobuf.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-protobuf.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-shaded-protobuf.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-shaded-protobuf.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hbase-zookeeper.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hbase-zookeeper.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hbase-zookeeper.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hbase-zookeeper.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hessian.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hessian.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hessian.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hessian.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-htrace-core4.txt b/computer/computer-dist/release-docs/licenses/LICENSE-htrace-core4.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-htrace-core4.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-htrace-core4.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hugegraph-client.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-client.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hugegraph-client.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-client.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hugegraph-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hugegraph-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hugegraph-loader.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-loader.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hugegraph-loader.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-loader.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-hugegraph-rpc.txt b/computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-rpc.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-hugegraph-rpc.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-hugegraph-rpc.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-j2objc-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-j2objc-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-j2objc-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-j2objc-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-core-asl.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-core-asl.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-core-asl.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-core-asl.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-databind.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-databind.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-databind.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-databind.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-dataformat-yaml.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-dataformat-yaml.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-dataformat-yaml.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-dataformat-yaml.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-datatype-jsr310.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-datatype-jsr310.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-datatype-jsr310.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-datatype-jsr310.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-base.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-base.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-base.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-base.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-json-provider.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-json-provider.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-json-provider.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs-json-provider.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-jaxrs.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-mapper-asl.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-mapper-asl.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-mapper-asl.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-mapper-asl.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-module-jaxb-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-module-jaxb-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-module-jaxb-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-module-jaxb-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jackson-xc.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jackson-xc.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jackson-xc.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jackson-xc.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jakarta.activation-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jakarta.activation-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jakarta.activation-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jakarta.activation-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jakarta.activation.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jakarta.activation.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jakarta.activation.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jakarta.activation.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jamon-runtime.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jamon-runtime.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jamon-runtime.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jamon-runtime.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javassist.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javassist.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javassist.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javassist.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.annotation-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.annotation-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.annotation-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.annotation-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.el.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.el.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.el.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.el.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.inject.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.inject.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.inject.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.inject.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.json.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.json.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.json.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.json.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.servlet-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.servlet-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.servlet-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.servlet-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp.txt b/computer/computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-javax.servlet.jsp.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jaxb-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jaxb-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jaxb-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jaxb-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jaxb-impl.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jaxb-impl.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jaxb-impl.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jaxb-impl.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jcip-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jcip-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jcip-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jcip-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jcodings.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jcodings.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jcodings.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jcodings.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jcommander.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jcommander.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jcommander.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jcommander.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jersey-container-servlet-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jersey-container-servlet-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jersey-container-servlet-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jersey-container-servlet-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jersey-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jersey-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jersey-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jersey-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jersey-json.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jersey-json.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jersey-json.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jersey-json.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jersey-servlet.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jersey-servlet.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jersey-servlet.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jersey-servlet.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetcd-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetcd-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetcd-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetcd-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetcd-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetcd-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetcd-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetcd-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jettison.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jettison.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jettison.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jettison.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-http.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-http.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-http.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-http.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-io.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-io.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-io.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-io.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-security.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-security.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-security.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-security.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-server.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-server.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-server.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-server.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-servlet.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-servlet.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-servlet.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-servlet.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-util-ajax.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-util-ajax.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-util-ajax.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-util-ajax.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-util.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-util.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-util.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-util.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-webapp.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-webapp.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-webapp.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-webapp.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jetty-xml.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jetty-xml.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jetty-xml.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jetty-xml.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jline.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jline.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jline.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jline.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-joda-time.txt b/computer/computer-dist/release-docs/licenses/LICENSE-joda-time.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-joda-time.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-joda-time.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-joni.txt b/computer/computer-dist/release-docs/licenses/LICENSE-joni.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-joni.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-joni.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jsch.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jsch.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jsch.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jsch.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-json-smart.txt b/computer/computer-dist/release-docs/licenses/LICENSE-json-smart.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-json-smart.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-json-smart.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-jsr305.txt b/computer/computer-dist/release-docs/licenses/LICENSE-jsr305.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-jsr305.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-jsr305.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-junit.txt b/computer/computer-dist/release-docs/licenses/LICENSE-junit.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-junit.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-junit.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-admin.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-admin.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-admin.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-admin.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-client.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-client.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-client.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-client.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-crypto.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-crypto.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-crypto.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-crypto.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-identity.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-identity.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-identity.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-identity.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-server.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-server.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-server.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-server.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-simplekdc.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-simplekdc.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-simplekdc.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-simplekdc.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerb-util.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerb-util.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerb-util.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerb-util.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerby-asn1.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerby-asn1.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerby-asn1.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerby-asn1.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerby-config.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerby-config.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerby-config.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerby-config.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerby-pkix.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerby-pkix.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerby-pkix.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerby-pkix.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerby-util.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerby-util.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerby-util.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerby-util.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kerby-xdr.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kerby-xdr.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kerby-xdr.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kerby-xdr.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk7.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk7.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk7.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk7.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk8.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk8.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk8.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib-jdk8.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kotlin-stdlib.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-client.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-client.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-client.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-client.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-admissionregistration.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-admissionregistration.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-admissionregistration.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-admissionregistration.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apiextensions.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apiextensions.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apiextensions.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apiextensions.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apps.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apps.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apps.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-apps.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-autoscaling.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-autoscaling.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-autoscaling.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-autoscaling.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-batch.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-batch.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-batch.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-batch.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-certificates.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-certificates.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-certificates.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-certificates.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-common.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-common.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-common.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-common.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-coordination.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-coordination.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-coordination.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-coordination.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-discovery.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-discovery.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-discovery.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-discovery.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-events.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-events.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-events.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-events.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-extensions.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-extensions.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-extensions.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-extensions.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-flowcontrol.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-flowcontrol.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-flowcontrol.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-flowcontrol.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-metrics.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-metrics.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-metrics.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-metrics.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-networking.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-networking.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-networking.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-networking.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-node.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-node.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-node.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-node.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-policy.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-policy.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-policy.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-policy.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-rbac.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-rbac.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-rbac.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-rbac.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-scheduling.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-scheduling.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-scheduling.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-scheduling.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-storageclass.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-storageclass.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-model-storageclass.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-model-storageclass.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-kubernetes-server-mock.txt b/computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-server-mock.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-kubernetes-server-mock.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-kubernetes-server-mock.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-lightning-csv.txt b/computer/computer-dist/release-docs/licenses/LICENSE-lightning-csv.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-lightning-csv.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-lightning-csv.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-listenablefuture.txt b/computer/computer-dist/release-docs/licenses/LICENSE-listenablefuture.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-listenablefuture.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-listenablefuture.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-log4j-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-log4j-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-log4j-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-log4j-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-log4j-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-log4j-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-log4j-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-log4j-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-log4j-slf4j-impl.txt b/computer/computer-dist/release-docs/licenses/LICENSE-log4j-slf4j-impl.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-log4j-slf4j-impl.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-log4j-slf4j-impl.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-log4j.txt b/computer/computer-dist/release-docs/licenses/LICENSE-log4j.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-log4j.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-log4j.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-logging-interceptor.txt b/computer/computer-dist/release-docs/licenses/LICENSE-logging-interceptor.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-logging-interceptor.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-logging-interceptor.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-lookout-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-lookout-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-lookout-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-lookout-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-lz4-java.txt b/computer/computer-dist/release-docs/licenses/LICENSE-lz4-java.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-lz4-java.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-lz4-java.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-metrics-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-metrics-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-metrics-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-metrics-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-minio.txt b/computer/computer-dist/release-docs/licenses/LICENSE-minio.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-minio.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-minio.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-mockito-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-mockito-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-mockito-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-mockito-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-mvel2.txt b/computer/computer-dist/release-docs/licenses/LICENSE-mvel2.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-mvel2.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-mvel2.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-netty-all.txt b/computer/computer-dist/release-docs/licenses/LICENSE-netty-all.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-netty-all.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-netty-all.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-netty.txt b/computer/computer-dist/release-docs/licenses/LICENSE-netty.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-netty.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-netty.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-nimbus-jose-jwt.txt b/computer/computer-dist/release-docs/licenses/LICENSE-nimbus-jose-jwt.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-nimbus-jose-jwt.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-nimbus-jose-jwt.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-objenesis.txt b/computer/computer-dist/release-docs/licenses/LICENSE-objenesis.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-objenesis.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-objenesis.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-okhttp.txt b/computer/computer-dist/release-docs/licenses/LICENSE-okhttp.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-okhttp.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-okhttp.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-okio-jvm.txt b/computer/computer-dist/release-docs/licenses/LICENSE-okio-jvm.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-okio-jvm.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-okio-jvm.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-okio.txt b/computer/computer-dist/release-docs/licenses/LICENSE-okio.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-okio.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-okio.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-opentracing-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-opentracing-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-opentracing-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-opentracing-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-opentracing-mock.txt b/computer/computer-dist/release-docs/licenses/LICENSE-opentracing-mock.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-opentracing-mock.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-opentracing-mock.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-opentracing-noop.txt b/computer/computer-dist/release-docs/licenses/LICENSE-opentracing-noop.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-opentracing-noop.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-opentracing-noop.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-opentracing-util.txt b/computer/computer-dist/release-docs/licenses/LICENSE-opentracing-util.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-opentracing-util.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-opentracing-util.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-ow2-asm.txt b/computer/computer-dist/release-docs/licenses/LICENSE-ow2-asm.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-ow2-asm.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-ow2-asm.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-paranamer.txt b/computer/computer-dist/release-docs/licenses/LICENSE-paranamer.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-paranamer.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-paranamer.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-perfmark-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-perfmark-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-perfmark-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-perfmark-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-proto-google-common-protos.txt b/computer/computer-dist/release-docs/licenses/LICENSE-proto-google-common-protos.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-proto-google-common-protos.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-proto-google-common-protos.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-protobuf-java-util.txt b/computer/computer-dist/release-docs/licenses/LICENSE-protobuf-java-util.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-protobuf-java-util.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-protobuf-java-util.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-protobuf-java.txt b/computer/computer-dist/release-docs/licenses/LICENSE-protobuf-java.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-protobuf-java.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-protobuf-java.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-re2j.txt b/computer/computer-dist/release-docs/licenses/LICENSE-re2j.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-re2j.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-re2j.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-resourcecify-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-resourcecify-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-resourcecify-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-resourcecify-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sfm-converter.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sfm-converter.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sfm-converter.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sfm-converter.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sfm-csv.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sfm-csv.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sfm-csv.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sfm-csv.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sfm-map.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sfm-map.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sfm-map.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sfm-map.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sfm-reflect.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sfm-reflect.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sfm-reflect.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sfm-reflect.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sfm-tuples.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sfm-tuples.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sfm-tuples.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sfm-tuples.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sfm-util.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sfm-util.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sfm-util.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sfm-util.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-simple-xml-safe.txt b/computer/computer-dist/release-docs/licenses/LICENSE-simple-xml-safe.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-simple-xml-safe.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-simple-xml-safe.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-slf4j-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-slf4j-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-slf4j-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-slf4j-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-slf4j-log4j12.txt b/computer/computer-dist/release-docs/licenses/LICENSE-slf4j-log4j12.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-slf4j-log4j12.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-slf4j-log4j12.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-snakeyaml.txt b/computer/computer-dist/release-docs/licenses/LICENSE-snakeyaml.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-snakeyaml.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-snakeyaml.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-snappy-java.txt b/computer/computer-dist/release-docs/licenses/LICENSE-snappy-java.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-snappy-java.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-snappy-java.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sofa-common-tools.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sofa-common-tools.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sofa-common-tools.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sofa-common-tools.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sofa-rpc-all.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sofa-rpc-all.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sofa-rpc-all.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sofa-rpc-all.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-stax2-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-stax2-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-stax2-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-stax2-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sundr-codegen.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sundr-codegen.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sundr-codegen.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sundr-codegen.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-sundr-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-sundr-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-sundr-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-sundr-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-swagger-annotations.txt b/computer/computer-dist/release-docs/licenses/LICENSE-swagger-annotations.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-swagger-annotations.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-swagger-annotations.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-swagger-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-swagger-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-swagger-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-swagger-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-swagger-models.txt b/computer/computer-dist/release-docs/licenses/LICENSE-swagger-models.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-swagger-models.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-swagger-models.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-token-provider.txt b/computer/computer-dist/release-docs/licenses/LICENSE-token-provider.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-token-provider.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-token-provider.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-tracer-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-tracer-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-tracer-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-tracer-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-validation-api.txt b/computer/computer-dist/release-docs/licenses/LICENSE-validation-api.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-validation-api.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-validation-api.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-woodstox-core.txt b/computer/computer-dist/release-docs/licenses/LICENSE-woodstox-core.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-woodstox-core.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-woodstox-core.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-zjsonpatch.txt b/computer/computer-dist/release-docs/licenses/LICENSE-zjsonpatch.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-zjsonpatch.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-zjsonpatch.txt diff --git a/computer-dist/release-docs/licenses/LICENSE-zookeeper.txt b/computer/computer-dist/release-docs/licenses/LICENSE-zookeeper.txt similarity index 100% rename from computer-dist/release-docs/licenses/LICENSE-zookeeper.txt rename to computer/computer-dist/release-docs/licenses/LICENSE-zookeeper.txt diff --git a/computer-dist/scripts/apache-release.sh b/computer/computer-dist/scripts/apache-release.sh similarity index 100% rename from computer-dist/scripts/apache-release.sh rename to computer/computer-dist/scripts/apache-release.sh diff --git a/computer-dist/scripts/dependency/check_dependencies.sh b/computer/computer-dist/scripts/dependency/check_dependencies.sh similarity index 100% rename from computer-dist/scripts/dependency/check_dependencies.sh rename to computer/computer-dist/scripts/dependency/check_dependencies.sh diff --git a/computer-dist/scripts/dependency/known-dependencies.txt b/computer/computer-dist/scripts/dependency/known-dependencies.txt similarity index 100% rename from computer-dist/scripts/dependency/known-dependencies.txt rename to computer/computer-dist/scripts/dependency/known-dependencies.txt diff --git a/computer-dist/scripts/dependency/regenerate_known_dependencies.sh b/computer/computer-dist/scripts/dependency/regenerate_known_dependencies.sh similarity index 100% rename from computer-dist/scripts/dependency/regenerate_known_dependencies.sh rename to computer/computer-dist/scripts/dependency/regenerate_known_dependencies.sh diff --git a/computer-dist/src/assembly/dataset/load-movie-data.groovy b/computer/computer-dist/src/assembly/dataset/load-movie-data.groovy similarity index 100% rename from computer-dist/src/assembly/dataset/load-movie-data.groovy rename to computer/computer-dist/src/assembly/dataset/load-movie-data.groovy diff --git a/computer-dist/src/assembly/dataset/schema.groovy b/computer/computer-dist/src/assembly/dataset/schema.groovy similarity index 100% rename from computer-dist/src/assembly/dataset/schema.groovy rename to computer/computer-dist/src/assembly/dataset/schema.groovy diff --git a/computer-dist/src/assembly/dataset/struct.json b/computer/computer-dist/src/assembly/dataset/struct.json similarity index 100% rename from computer-dist/src/assembly/dataset/struct.json rename to computer/computer-dist/src/assembly/dataset/struct.json diff --git a/computer-dist/src/assembly/descriptor/assembly.xml b/computer/computer-dist/src/assembly/descriptor/assembly.xml similarity index 100% rename from computer-dist/src/assembly/descriptor/assembly.xml rename to computer/computer-dist/src/assembly/descriptor/assembly.xml diff --git a/computer-dist/src/assembly/static/bin/start-computer.sh b/computer/computer-dist/src/assembly/static/bin/start-computer.sh similarity index 100% rename from computer-dist/src/assembly/static/bin/start-computer.sh rename to computer/computer-dist/src/assembly/static/bin/start-computer.sh diff --git a/computer-dist/src/assembly/static/conf/computer.properties b/computer/computer-dist/src/assembly/static/conf/computer.properties similarity index 100% rename from computer-dist/src/assembly/static/conf/computer.properties rename to computer/computer-dist/src/assembly/static/conf/computer.properties diff --git a/computer-dist/src/assembly/static/conf/log4j2.xml b/computer/computer-dist/src/assembly/static/conf/log4j2.xml similarity index 100% rename from computer-dist/src/assembly/static/conf/log4j2.xml rename to computer/computer-dist/src/assembly/static/conf/log4j2.xml diff --git a/computer-dist/src/assembly/travis/build-images.sh b/computer/computer-dist/src/assembly/travis/build-images.sh similarity index 100% rename from computer-dist/src/assembly/travis/build-images.sh rename to computer/computer-dist/src/assembly/travis/build-images.sh diff --git a/computer-dist/src/assembly/travis/install-env.sh b/computer/computer-dist/src/assembly/travis/install-env.sh similarity index 100% rename from computer-dist/src/assembly/travis/install-env.sh rename to computer/computer-dist/src/assembly/travis/install-env.sh diff --git a/computer-dist/src/assembly/travis/install-hdfs.sh b/computer/computer-dist/src/assembly/travis/install-hdfs.sh similarity index 100% rename from computer-dist/src/assembly/travis/install-hdfs.sh rename to computer/computer-dist/src/assembly/travis/install-hdfs.sh diff --git a/computer-dist/src/assembly/travis/install-hugegraph-from-source.sh b/computer/computer-dist/src/assembly/travis/install-hugegraph-from-source.sh similarity index 100% rename from computer-dist/src/assembly/travis/install-hugegraph-from-source.sh rename to computer/computer-dist/src/assembly/travis/install-hugegraph-from-source.sh diff --git a/computer-dist/src/assembly/travis/install-k8s.sh b/computer/computer-dist/src/assembly/travis/install-k8s.sh similarity index 100% rename from computer-dist/src/assembly/travis/install-k8s.sh rename to computer/computer-dist/src/assembly/travis/install-k8s.sh diff --git a/computer-dist/src/assembly/travis/load-data-into-hugegraph.sh b/computer/computer-dist/src/assembly/travis/load-data-into-hugegraph.sh similarity index 100% rename from computer-dist/src/assembly/travis/load-data-into-hugegraph.sh rename to computer/computer-dist/src/assembly/travis/load-data-into-hugegraph.sh diff --git a/computer-dist/src/assembly/travis/start-etcd.sh b/computer/computer-dist/src/assembly/travis/start-etcd.sh similarity index 100% rename from computer-dist/src/assembly/travis/start-etcd.sh rename to computer/computer-dist/src/assembly/travis/start-etcd.sh diff --git a/computer-driver/pom.xml b/computer/computer-driver/pom.xml similarity index 100% rename from computer-driver/pom.xml rename to computer/computer-driver/pom.xml diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriver.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/ComputerDriverException.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/DefaultJobState.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobObserver.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobState.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/JobStatus.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/SuperstepStat.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/config/DriverConfigOption.java diff --git a/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java b/computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java similarity index 100% rename from computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java rename to computer/computer-driver/src/main/java/org/apache/hugegraph/computer/driver/util/JsonUtil.java diff --git a/computer-k8s-operator/Dockerfile b/computer/computer-k8s-operator/Dockerfile similarity index 100% rename from computer-k8s-operator/Dockerfile rename to computer/computer-k8s-operator/Dockerfile diff --git a/computer-k8s-operator/crd-generate/.dockerignore b/computer/computer-k8s-operator/crd-generate/.dockerignore similarity index 100% rename from computer-k8s-operator/crd-generate/.dockerignore rename to computer/computer-k8s-operator/crd-generate/.dockerignore diff --git a/computer-k8s-operator/crd-generate/.gitignore b/computer/computer-k8s-operator/crd-generate/.gitignore similarity index 100% rename from computer-k8s-operator/crd-generate/.gitignore rename to computer/computer-k8s-operator/crd-generate/.gitignore diff --git a/computer-k8s-operator/crd-generate/Dockerfile b/computer/computer-k8s-operator/crd-generate/Dockerfile similarity index 100% rename from computer-k8s-operator/crd-generate/Dockerfile rename to computer/computer-k8s-operator/crd-generate/Dockerfile diff --git a/computer-k8s-operator/crd-generate/Makefile b/computer/computer-k8s-operator/crd-generate/Makefile similarity index 100% rename from computer-k8s-operator/crd-generate/Makefile rename to computer/computer-k8s-operator/crd-generate/Makefile diff --git a/computer-k8s-operator/crd-generate/PROJECT b/computer/computer-k8s-operator/crd-generate/PROJECT similarity index 100% rename from computer-k8s-operator/crd-generate/PROJECT rename to computer/computer-k8s-operator/crd-generate/PROJECT diff --git a/computer-k8s-operator/crd-generate/README.md b/computer/computer-k8s-operator/crd-generate/README.md similarity index 100% rename from computer-k8s-operator/crd-generate/README.md rename to computer/computer-k8s-operator/crd-generate/README.md diff --git a/computer-k8s-operator/crd-generate/api/v1/groupversion_info.go b/computer/computer-k8s-operator/crd-generate/api/v1/groupversion_info.go similarity index 100% rename from computer-k8s-operator/crd-generate/api/v1/groupversion_info.go rename to computer/computer-k8s-operator/crd-generate/api/v1/groupversion_info.go diff --git a/computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_types.go b/computer/computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_types.go similarity index 100% rename from computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_types.go rename to computer/computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_types.go diff --git a/computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_webhook.go b/computer/computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_webhook.go similarity index 100% rename from computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_webhook.go rename to computer/computer-k8s-operator/crd-generate/api/v1/hugegraphcomputerjob_webhook.go diff --git a/computer-k8s-operator/crd-generate/api/v1/webhook_suite_test.go b/computer/computer-k8s-operator/crd-generate/api/v1/webhook_suite_test.go similarity index 98% rename from computer-k8s-operator/crd-generate/api/v1/webhook_suite_test.go rename to computer/computer-k8s-operator/crd-generate/api/v1/webhook_suite_test.go index c59ec7622..a7c2403de 100644 --- a/computer-k8s-operator/crd-generate/api/v1/webhook_suite_test.go +++ b/computer/computer-k8s-operator/crd-generate/api/v1/webhook_suite_test.go @@ -26,9 +26,6 @@ import ( "testing" "time" - . "github.com/onsi/ginkgo/v2" - . "github.com/onsi/gomega" - admissionv1 "k8s.io/api/admission/v1" //+kubebuilder:scaffold:imports "k8s.io/apimachinery/pkg/runtime" diff --git a/computer-k8s-operator/crd-generate/cmd/generate.go b/computer/computer-k8s-operator/crd-generate/cmd/generate.go similarity index 100% rename from computer-k8s-operator/crd-generate/cmd/generate.go rename to computer/computer-k8s-operator/crd-generate/cmd/generate.go diff --git a/computer-k8s-operator/crd-generate/cmd/main.go b/computer/computer-k8s-operator/crd-generate/cmd/main.go similarity index 100% rename from computer-k8s-operator/crd-generate/cmd/main.go rename to computer/computer-k8s-operator/crd-generate/cmd/main.go diff --git a/computer-k8s-operator/crd-generate/config/certmanager/certificate.yaml b/computer/computer-k8s-operator/crd-generate/config/certmanager/certificate.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/certmanager/certificate.yaml rename to computer/computer-k8s-operator/crd-generate/config/certmanager/certificate.yaml diff --git a/computer-k8s-operator/crd-generate/config/certmanager/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/certmanager/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/certmanager/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/certmanager/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/certmanager/kustomizeconfig.yaml b/computer/computer-k8s-operator/crd-generate/config/certmanager/kustomizeconfig.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/certmanager/kustomizeconfig.yaml rename to computer/computer-k8s-operator/crd-generate/config/certmanager/kustomizeconfig.yaml diff --git a/computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.v1beta1.yaml b/computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.v1beta1.yaml new file mode 100644 index 000000000..0ca18546c --- /dev/null +++ b/computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.v1beta1.yaml @@ -0,0 +1,1076 @@ + +--- +apiVersion: apiextensions.k8s.io/v1beta1 +kind: CustomResourceDefinition +metadata: + annotations: + controller-gen.kubebuilder.io/version: v0.5.0 + creationTimestamp: null + name: hugegraphcomputerjobs.operator.hugegraph.apache.org +spec: + additionalPrinterColumns: + - JSONPath: .spec.jobId + name: JobId + type: string + - JSONPath: .status.jobStatus + name: JobStatus + type: string + - JSONPath: .status.jobState.superstep + name: Superstep + type: integer + - JSONPath: .status.jobState.maxSuperstep + name: MaxSuperstep + type: integer + - JSONPath: .status.jobState.lastSuperstepStat + name: SuperstepStat + type: string + group: operator.hugegraph.apache.org + names: + kind: HugeGraphComputerJob + listKind: HugeGraphComputerJobList + plural: hugegraphcomputerjobs + shortNames: + - hcjob + singular: hugegraphcomputerjob + preserveUnknownFields: false + scope: Namespaced + subresources: + status: {} + validation: + openAPIV3Schema: + properties: + apiVersion: + type: string + kind: + type: string + metadata: + type: object + spec: + properties: + algorithmName: + type: string + computerConf: + additionalProperties: + type: string + type: object + configMapPaths: + additionalProperties: + type: string + type: object + envFrom: + items: + properties: + configMapRef: + properties: + name: + type: string + optional: + type: boolean + type: object + prefix: + type: string + secretRef: + properties: + name: + type: string + optional: + type: boolean + type: object + type: object + type: array + envVars: + items: + properties: + name: + type: string + value: + type: string + valueFrom: + properties: + configMapKeyRef: + properties: + key: + type: string + name: + type: string + optional: + type: boolean + required: + - key + type: object + fieldRef: + properties: + apiVersion: + type: string + fieldPath: + type: string + required: + - fieldPath + type: object + resourceFieldRef: + properties: + containerName: + type: string + divisor: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + resource: + type: string + required: + - resource + type: object + secretKeyRef: + properties: + key: + type: string + name: + type: string + optional: + type: boolean + required: + - key + type: object + type: object + required: + - name + type: object + type: array + image: + type: string + jarFile: + type: string + jobId: + type: string + jvmOptions: + type: string + log4jXml: + type: string + masterArgs: + items: + type: string + type: array + masterCommand: + items: + type: string + type: array + masterCpu: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + masterMemory: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + podTemplateSpec: + x-kubernetes-preserve-unknown-fields: true + pullPolicy: + enum: + - Always + - Never + - IfNotPresent + type: string + pullSecrets: + items: + properties: + name: + type: string + type: object + type: array + remoteJarUri: + pattern: ^(http|https):\/\/([\w.]+\/?)\S*$ + type: string + secretPaths: + additionalProperties: + type: string + type: object + securityContext: + properties: + allowPrivilegeEscalation: + type: boolean + capabilities: + properties: + add: + items: + type: string + type: array + drop: + items: + type: string + type: array + type: object + privileged: + type: boolean + procMount: + type: string + readOnlyRootFilesystem: + type: boolean + runAsGroup: + format: int64 + type: integer + runAsNonRoot: + type: boolean + runAsUser: + format: int64 + type: integer + seLinuxOptions: + properties: + level: + type: string + role: + type: string + type: + type: string + user: + type: string + type: object + seccompProfile: + properties: + localhostProfile: + type: string + type: + type: string + required: + - type + type: object + windowsOptions: + properties: + gmsaCredentialSpec: + type: string + gmsaCredentialSpecName: + type: string + hostProcess: + type: boolean + runAsUserName: + type: string + type: object + type: object + volumeMounts: + items: + properties: + mountPath: + type: string + mountPropagation: + type: string + name: + type: string + readOnly: + type: boolean + subPath: + type: string + subPathExpr: + type: string + required: + - mountPath + - name + type: object + type: array + volumes: + items: + properties: + awsElasticBlockStore: + properties: + fsType: + type: string + partition: + format: int32 + type: integer + readOnly: + type: boolean + volumeID: + type: string + required: + - volumeID + type: object + azureDisk: + properties: + cachingMode: + type: string + diskName: + type: string + diskURI: + type: string + fsType: + type: string + kind: + type: string + readOnly: + type: boolean + required: + - diskName + - diskURI + type: object + azureFile: + properties: + readOnly: + type: boolean + secretName: + type: string + shareName: + type: string + required: + - secretName + - shareName + type: object + cephfs: + properties: + monitors: + items: + type: string + type: array + path: + type: string + readOnly: + type: boolean + secretFile: + type: string + secretRef: + properties: + name: + type: string + type: object + user: + type: string + required: + - monitors + type: object + cinder: + properties: + fsType: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + volumeID: + type: string + required: + - volumeID + type: object + configMap: + properties: + defaultMode: + format: int32 + type: integer + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + name: + type: string + optional: + type: boolean + type: object + csi: + properties: + driver: + type: string + fsType: + type: string + nodePublishSecretRef: + properties: + name: + type: string + type: object + readOnly: + type: boolean + volumeAttributes: + additionalProperties: + type: string + type: object + required: + - driver + type: object + downwardAPI: + properties: + defaultMode: + format: int32 + type: integer + items: + items: + properties: + fieldRef: + properties: + apiVersion: + type: string + fieldPath: + type: string + required: + - fieldPath + type: object + mode: + format: int32 + type: integer + path: + type: string + resourceFieldRef: + properties: + containerName: + type: string + divisor: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + resource: + type: string + required: + - resource + type: object + required: + - path + type: object + type: array + type: object + emptyDir: + properties: + medium: + type: string + sizeLimit: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + type: object + ephemeral: + properties: + volumeClaimTemplate: + properties: + metadata: + type: object + spec: + properties: + accessModes: + items: + type: string + type: array + dataSource: + properties: + apiGroup: + type: string + kind: + type: string + name: + type: string + required: + - kind + - name + type: object + dataSourceRef: + properties: + apiGroup: + type: string + kind: + type: string + name: + type: string + namespace: + type: string + required: + - kind + - name + type: object + resources: + properties: + claims: + items: + properties: + name: + type: string + required: + - name + type: object + type: array + x-kubernetes-list-map-keys: + - name + x-kubernetes-list-type: map + limits: + additionalProperties: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + type: object + requests: + additionalProperties: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + type: object + type: object + selector: + properties: + matchExpressions: + items: + properties: + key: + type: string + operator: + type: string + values: + items: + type: string + type: array + required: + - key + - operator + type: object + type: array + matchLabels: + additionalProperties: + type: string + type: object + type: object + storageClassName: + type: string + volumeMode: + type: string + volumeName: + type: string + type: object + required: + - spec + type: object + type: object + fc: + properties: + fsType: + type: string + lun: + format: int32 + type: integer + readOnly: + type: boolean + targetWWNs: + items: + type: string + type: array + wwids: + items: + type: string + type: array + type: object + flexVolume: + properties: + driver: + type: string + fsType: + type: string + options: + additionalProperties: + type: string + type: object + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + required: + - driver + type: object + flocker: + properties: + datasetName: + type: string + datasetUUID: + type: string + type: object + gcePersistentDisk: + properties: + fsType: + type: string + partition: + format: int32 + type: integer + pdName: + type: string + readOnly: + type: boolean + required: + - pdName + type: object + gitRepo: + properties: + directory: + type: string + repository: + type: string + revision: + type: string + required: + - repository + type: object + glusterfs: + properties: + endpoints: + type: string + path: + type: string + readOnly: + type: boolean + required: + - endpoints + - path + type: object + hostPath: + properties: + path: + type: string + type: + type: string + required: + - path + type: object + iscsi: + properties: + chapAuthDiscovery: + type: boolean + chapAuthSession: + type: boolean + fsType: + type: string + initiatorName: + type: string + iqn: + type: string + iscsiInterface: + type: string + lun: + format: int32 + type: integer + portals: + items: + type: string + type: array + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + targetPortal: + type: string + required: + - iqn + - lun + - targetPortal + type: object + name: + type: string + nfs: + properties: + path: + type: string + readOnly: + type: boolean + server: + type: string + required: + - path + - server + type: object + persistentVolumeClaim: + properties: + claimName: + type: string + readOnly: + type: boolean + required: + - claimName + type: object + photonPersistentDisk: + properties: + fsType: + type: string + pdID: + type: string + required: + - pdID + type: object + portworxVolume: + properties: + fsType: + type: string + readOnly: + type: boolean + volumeID: + type: string + required: + - volumeID + type: object + projected: + properties: + defaultMode: + format: int32 + type: integer + sources: + items: + properties: + configMap: + properties: + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + name: + type: string + optional: + type: boolean + type: object + downwardAPI: + properties: + items: + items: + properties: + fieldRef: + properties: + apiVersion: + type: string + fieldPath: + type: string + required: + - fieldPath + type: object + mode: + format: int32 + type: integer + path: + type: string + resourceFieldRef: + properties: + containerName: + type: string + divisor: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + resource: + type: string + required: + - resource + type: object + required: + - path + type: object + type: array + type: object + secret: + properties: + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + name: + type: string + optional: + type: boolean + type: object + serviceAccountToken: + properties: + audience: + type: string + expirationSeconds: + format: int64 + type: integer + path: + type: string + required: + - path + type: object + type: object + type: array + type: object + quobyte: + properties: + group: + type: string + readOnly: + type: boolean + registry: + type: string + tenant: + type: string + user: + type: string + volume: + type: string + required: + - registry + - volume + type: object + rbd: + properties: + fsType: + type: string + image: + type: string + keyring: + type: string + monitors: + items: + type: string + type: array + pool: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + user: + type: string + required: + - image + - monitors + type: object + scaleIO: + properties: + fsType: + type: string + gateway: + type: string + protectionDomain: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + sslEnabled: + type: boolean + storageMode: + type: string + storagePool: + type: string + system: + type: string + volumeName: + type: string + required: + - gateway + - secretRef + - system + type: object + secret: + properties: + defaultMode: + format: int32 + type: integer + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + optional: + type: boolean + secretName: + type: string + type: object + storageos: + properties: + fsType: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + volumeName: + type: string + volumeNamespace: + type: string + type: object + vsphereVolume: + properties: + fsType: + type: string + storagePolicyID: + type: string + storagePolicyName: + type: string + volumePath: + type: string + required: + - volumePath + type: object + required: + - name + type: object + type: array + workerArgs: + items: + type: string + type: array + workerCommand: + items: + type: string + type: array + workerCpu: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + workerInstances: + format: int32 + minimum: 1 + type: integer + workerMemory: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + required: + - algorithmName + - computerConf + - image + - jobId + - workerInstances + type: object + status: + properties: + componentStates: + properties: + configMap: + properties: + errorLog: + type: string + message: + type: string + name: + type: string + state: + type: string + required: + - name + - state + type: object + masterJob: + properties: + errorLog: + type: string + message: + type: string + name: + type: string + state: + type: string + required: + - name + - state + type: object + workerJob: + properties: + errorLog: + type: string + message: + type: string + name: + type: string + state: + type: string + required: + - name + - state + type: object + type: object + jobState: + properties: + lastSuperstepStat: + type: string + maxSuperstep: + format: int32 + type: integer + superstep: + format: int32 + type: integer + type: object + jobStatus: + type: string + lastUpdateTime: + format: date-time + type: string + required: + - jobStatus + type: object + type: object + version: v1 + versions: + - name: v1 + served: true + storage: true +status: + acceptedNames: + kind: "" + plural: "" + conditions: [] + storedVersions: [] diff --git a/computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.yaml b/computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.yaml new file mode 100644 index 000000000..376dcca65 --- /dev/null +++ b/computer/computer-k8s-operator/crd-generate/config/crd/bases/operator.hugegraph.apache.org_hugegraphcomputerjobs.yaml @@ -0,0 +1,1074 @@ + +--- +apiVersion: apiextensions.k8s.io/v1 +kind: CustomResourceDefinition +metadata: + annotations: + controller-gen.kubebuilder.io/version: v0.5.0 + creationTimestamp: null + name: hugegraphcomputerjobs.operator.hugegraph.apache.org +spec: + group: operator.hugegraph.apache.org + names: + kind: HugeGraphComputerJob + listKind: HugeGraphComputerJobList + plural: hugegraphcomputerjobs + shortNames: + - hcjob + singular: hugegraphcomputerjob + scope: Namespaced + versions: + - additionalPrinterColumns: + - jsonPath: .spec.jobId + name: JobId + type: string + - jsonPath: .status.jobStatus + name: JobStatus + type: string + - jsonPath: .status.jobState.superstep + name: Superstep + type: integer + - jsonPath: .status.jobState.maxSuperstep + name: MaxSuperstep + type: integer + - jsonPath: .status.jobState.lastSuperstepStat + name: SuperstepStat + type: string + name: v1 + schema: + openAPIV3Schema: + properties: + apiVersion: + type: string + kind: + type: string + metadata: + type: object + spec: + properties: + algorithmName: + type: string + computerConf: + additionalProperties: + type: string + type: object + configMapPaths: + additionalProperties: + type: string + type: object + envFrom: + items: + properties: + configMapRef: + properties: + name: + type: string + optional: + type: boolean + type: object + prefix: + type: string + secretRef: + properties: + name: + type: string + optional: + type: boolean + type: object + type: object + type: array + envVars: + items: + properties: + name: + type: string + value: + type: string + valueFrom: + properties: + configMapKeyRef: + properties: + key: + type: string + name: + type: string + optional: + type: boolean + required: + - key + type: object + fieldRef: + properties: + apiVersion: + type: string + fieldPath: + type: string + required: + - fieldPath + type: object + resourceFieldRef: + properties: + containerName: + type: string + divisor: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + resource: + type: string + required: + - resource + type: object + secretKeyRef: + properties: + key: + type: string + name: + type: string + optional: + type: boolean + required: + - key + type: object + type: object + required: + - name + type: object + type: array + image: + type: string + jarFile: + type: string + jobId: + type: string + jvmOptions: + type: string + log4jXml: + type: string + masterArgs: + items: + type: string + type: array + masterCommand: + items: + type: string + type: array + masterCpu: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + masterMemory: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + podTemplateSpec: + x-kubernetes-preserve-unknown-fields: true + pullPolicy: + enum: + - Always + - Never + - IfNotPresent + type: string + pullSecrets: + items: + properties: + name: + type: string + type: object + type: array + remoteJarUri: + pattern: ^(http|https):\/\/([\w.]+\/?)\S*$ + type: string + secretPaths: + additionalProperties: + type: string + type: object + securityContext: + properties: + allowPrivilegeEscalation: + type: boolean + capabilities: + properties: + add: + items: + type: string + type: array + drop: + items: + type: string + type: array + type: object + privileged: + type: boolean + procMount: + type: string + readOnlyRootFilesystem: + type: boolean + runAsGroup: + format: int64 + type: integer + runAsNonRoot: + type: boolean + runAsUser: + format: int64 + type: integer + seLinuxOptions: + properties: + level: + type: string + role: + type: string + type: + type: string + user: + type: string + type: object + seccompProfile: + properties: + localhostProfile: + type: string + type: + type: string + required: + - type + type: object + windowsOptions: + properties: + gmsaCredentialSpec: + type: string + gmsaCredentialSpecName: + type: string + hostProcess: + type: boolean + runAsUserName: + type: string + type: object + type: object + volumeMounts: + items: + properties: + mountPath: + type: string + mountPropagation: + type: string + name: + type: string + readOnly: + type: boolean + subPath: + type: string + subPathExpr: + type: string + required: + - mountPath + - name + type: object + type: array + volumes: + items: + properties: + awsElasticBlockStore: + properties: + fsType: + type: string + partition: + format: int32 + type: integer + readOnly: + type: boolean + volumeID: + type: string + required: + - volumeID + type: object + azureDisk: + properties: + cachingMode: + type: string + diskName: + type: string + diskURI: + type: string + fsType: + type: string + kind: + type: string + readOnly: + type: boolean + required: + - diskName + - diskURI + type: object + azureFile: + properties: + readOnly: + type: boolean + secretName: + type: string + shareName: + type: string + required: + - secretName + - shareName + type: object + cephfs: + properties: + monitors: + items: + type: string + type: array + path: + type: string + readOnly: + type: boolean + secretFile: + type: string + secretRef: + properties: + name: + type: string + type: object + user: + type: string + required: + - monitors + type: object + cinder: + properties: + fsType: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + volumeID: + type: string + required: + - volumeID + type: object + configMap: + properties: + defaultMode: + format: int32 + type: integer + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + name: + type: string + optional: + type: boolean + type: object + csi: + properties: + driver: + type: string + fsType: + type: string + nodePublishSecretRef: + properties: + name: + type: string + type: object + readOnly: + type: boolean + volumeAttributes: + additionalProperties: + type: string + type: object + required: + - driver + type: object + downwardAPI: + properties: + defaultMode: + format: int32 + type: integer + items: + items: + properties: + fieldRef: + properties: + apiVersion: + type: string + fieldPath: + type: string + required: + - fieldPath + type: object + mode: + format: int32 + type: integer + path: + type: string + resourceFieldRef: + properties: + containerName: + type: string + divisor: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + resource: + type: string + required: + - resource + type: object + required: + - path + type: object + type: array + type: object + emptyDir: + properties: + medium: + type: string + sizeLimit: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + type: object + ephemeral: + properties: + volumeClaimTemplate: + properties: + metadata: + type: object + spec: + properties: + accessModes: + items: + type: string + type: array + dataSource: + properties: + apiGroup: + type: string + kind: + type: string + name: + type: string + required: + - kind + - name + type: object + dataSourceRef: + properties: + apiGroup: + type: string + kind: + type: string + name: + type: string + namespace: + type: string + required: + - kind + - name + type: object + resources: + properties: + claims: + items: + properties: + name: + type: string + required: + - name + type: object + type: array + x-kubernetes-list-map-keys: + - name + x-kubernetes-list-type: map + limits: + additionalProperties: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + type: object + requests: + additionalProperties: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + type: object + type: object + selector: + properties: + matchExpressions: + items: + properties: + key: + type: string + operator: + type: string + values: + items: + type: string + type: array + required: + - key + - operator + type: object + type: array + matchLabels: + additionalProperties: + type: string + type: object + type: object + storageClassName: + type: string + volumeMode: + type: string + volumeName: + type: string + type: object + required: + - spec + type: object + type: object + fc: + properties: + fsType: + type: string + lun: + format: int32 + type: integer + readOnly: + type: boolean + targetWWNs: + items: + type: string + type: array + wwids: + items: + type: string + type: array + type: object + flexVolume: + properties: + driver: + type: string + fsType: + type: string + options: + additionalProperties: + type: string + type: object + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + required: + - driver + type: object + flocker: + properties: + datasetName: + type: string + datasetUUID: + type: string + type: object + gcePersistentDisk: + properties: + fsType: + type: string + partition: + format: int32 + type: integer + pdName: + type: string + readOnly: + type: boolean + required: + - pdName + type: object + gitRepo: + properties: + directory: + type: string + repository: + type: string + revision: + type: string + required: + - repository + type: object + glusterfs: + properties: + endpoints: + type: string + path: + type: string + readOnly: + type: boolean + required: + - endpoints + - path + type: object + hostPath: + properties: + path: + type: string + type: + type: string + required: + - path + type: object + iscsi: + properties: + chapAuthDiscovery: + type: boolean + chapAuthSession: + type: boolean + fsType: + type: string + initiatorName: + type: string + iqn: + type: string + iscsiInterface: + type: string + lun: + format: int32 + type: integer + portals: + items: + type: string + type: array + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + targetPortal: + type: string + required: + - iqn + - lun + - targetPortal + type: object + name: + type: string + nfs: + properties: + path: + type: string + readOnly: + type: boolean + server: + type: string + required: + - path + - server + type: object + persistentVolumeClaim: + properties: + claimName: + type: string + readOnly: + type: boolean + required: + - claimName + type: object + photonPersistentDisk: + properties: + fsType: + type: string + pdID: + type: string + required: + - pdID + type: object + portworxVolume: + properties: + fsType: + type: string + readOnly: + type: boolean + volumeID: + type: string + required: + - volumeID + type: object + projected: + properties: + defaultMode: + format: int32 + type: integer + sources: + items: + properties: + configMap: + properties: + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + name: + type: string + optional: + type: boolean + type: object + downwardAPI: + properties: + items: + items: + properties: + fieldRef: + properties: + apiVersion: + type: string + fieldPath: + type: string + required: + - fieldPath + type: object + mode: + format: int32 + type: integer + path: + type: string + resourceFieldRef: + properties: + containerName: + type: string + divisor: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + resource: + type: string + required: + - resource + type: object + required: + - path + type: object + type: array + type: object + secret: + properties: + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + name: + type: string + optional: + type: boolean + type: object + serviceAccountToken: + properties: + audience: + type: string + expirationSeconds: + format: int64 + type: integer + path: + type: string + required: + - path + type: object + type: object + type: array + type: object + quobyte: + properties: + group: + type: string + readOnly: + type: boolean + registry: + type: string + tenant: + type: string + user: + type: string + volume: + type: string + required: + - registry + - volume + type: object + rbd: + properties: + fsType: + type: string + image: + type: string + keyring: + type: string + monitors: + items: + type: string + type: array + pool: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + user: + type: string + required: + - image + - monitors + type: object + scaleIO: + properties: + fsType: + type: string + gateway: + type: string + protectionDomain: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + sslEnabled: + type: boolean + storageMode: + type: string + storagePool: + type: string + system: + type: string + volumeName: + type: string + required: + - gateway + - secretRef + - system + type: object + secret: + properties: + defaultMode: + format: int32 + type: integer + items: + items: + properties: + key: + type: string + mode: + format: int32 + type: integer + path: + type: string + required: + - key + - path + type: object + type: array + optional: + type: boolean + secretName: + type: string + type: object + storageos: + properties: + fsType: + type: string + readOnly: + type: boolean + secretRef: + properties: + name: + type: string + type: object + volumeName: + type: string + volumeNamespace: + type: string + type: object + vsphereVolume: + properties: + fsType: + type: string + storagePolicyID: + type: string + storagePolicyName: + type: string + volumePath: + type: string + required: + - volumePath + type: object + required: + - name + type: object + type: array + workerArgs: + items: + type: string + type: array + workerCommand: + items: + type: string + type: array + workerCpu: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + workerInstances: + format: int32 + minimum: 1 + type: integer + workerMemory: + anyOf: + - type: integer + - type: string + pattern: ^(\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))(([KMGTPE]i)|[numkMGTPE]|([eE](\+|-)?(([0-9]+(\.[0-9]*)?)|(\.[0-9]+))))?$ + x-kubernetes-int-or-string: true + required: + - algorithmName + - computerConf + - image + - jobId + - workerInstances + type: object + status: + properties: + componentStates: + properties: + configMap: + properties: + errorLog: + type: string + message: + type: string + name: + type: string + state: + type: string + required: + - name + - state + type: object + masterJob: + properties: + errorLog: + type: string + message: + type: string + name: + type: string + state: + type: string + required: + - name + - state + type: object + workerJob: + properties: + errorLog: + type: string + message: + type: string + name: + type: string + state: + type: string + required: + - name + - state + type: object + type: object + jobState: + properties: + lastSuperstepStat: + type: string + maxSuperstep: + format: int32 + type: integer + superstep: + format: int32 + type: integer + type: object + jobStatus: + type: string + lastUpdateTime: + format: date-time + type: string + required: + - jobStatus + type: object + type: object + served: true + storage: true + subresources: + status: {} +status: + acceptedNames: + kind: "" + plural: "" + conditions: [] + storedVersions: [] diff --git a/computer-k8s-operator/crd-generate/config/crd/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/crd/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/crd/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/crd/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/crd/kustomizeconfig.yaml b/computer/computer-k8s-operator/crd-generate/config/crd/kustomizeconfig.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/crd/kustomizeconfig.yaml rename to computer/computer-k8s-operator/crd-generate/config/crd/kustomizeconfig.yaml diff --git a/computer-k8s-operator/crd-generate/config/crd/patches/cainjection_in_hugegraphcomputerjobs.yaml b/computer/computer-k8s-operator/crd-generate/config/crd/patches/cainjection_in_hugegraphcomputerjobs.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/crd/patches/cainjection_in_hugegraphcomputerjobs.yaml rename to computer/computer-k8s-operator/crd-generate/config/crd/patches/cainjection_in_hugegraphcomputerjobs.yaml diff --git a/computer-k8s-operator/crd-generate/config/crd/patches/webhook_in_hugegraphcomputerjobs.yaml b/computer/computer-k8s-operator/crd-generate/config/crd/patches/webhook_in_hugegraphcomputerjobs.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/crd/patches/webhook_in_hugegraphcomputerjobs.yaml rename to computer/computer-k8s-operator/crd-generate/config/crd/patches/webhook_in_hugegraphcomputerjobs.yaml diff --git a/computer-k8s-operator/crd-generate/config/default/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/default/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/default/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/default/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/default/manager_auth_proxy_patch.yaml b/computer/computer-k8s-operator/crd-generate/config/default/manager_auth_proxy_patch.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/default/manager_auth_proxy_patch.yaml rename to computer/computer-k8s-operator/crd-generate/config/default/manager_auth_proxy_patch.yaml diff --git a/computer-k8s-operator/crd-generate/config/default/manager_config_patch.yaml b/computer/computer-k8s-operator/crd-generate/config/default/manager_config_patch.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/default/manager_config_patch.yaml rename to computer/computer-k8s-operator/crd-generate/config/default/manager_config_patch.yaml diff --git a/computer-k8s-operator/crd-generate/config/default/manager_webhook_patch.yaml b/computer/computer-k8s-operator/crd-generate/config/default/manager_webhook_patch.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/default/manager_webhook_patch.yaml rename to computer/computer-k8s-operator/crd-generate/config/default/manager_webhook_patch.yaml diff --git a/computer-k8s-operator/crd-generate/config/default/webhookcainjection_patch.yaml b/computer/computer-k8s-operator/crd-generate/config/default/webhookcainjection_patch.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/default/webhookcainjection_patch.yaml rename to computer/computer-k8s-operator/crd-generate/config/default/webhookcainjection_patch.yaml diff --git a/computer-k8s-operator/crd-generate/config/etcd/etcd_server.yaml b/computer/computer-k8s-operator/crd-generate/config/etcd/etcd_server.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/etcd/etcd_server.yaml rename to computer/computer-k8s-operator/crd-generate/config/etcd/etcd_server.yaml diff --git a/computer-k8s-operator/crd-generate/config/etcd/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/etcd/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/etcd/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/etcd/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/manager/controller_manager_config.yaml b/computer/computer-k8s-operator/crd-generate/config/manager/controller_manager_config.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/manager/controller_manager_config.yaml rename to computer/computer-k8s-operator/crd-generate/config/manager/controller_manager_config.yaml diff --git a/computer-k8s-operator/crd-generate/config/manager/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/manager/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/manager/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/manager/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/manager/manager.yaml b/computer/computer-k8s-operator/crd-generate/config/manager/manager.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/manager/manager.yaml rename to computer/computer-k8s-operator/crd-generate/config/manager/manager.yaml diff --git a/computer-k8s-operator/crd-generate/config/minio/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/minio/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/minio/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/minio/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/minio/minio_server.yaml b/computer/computer-k8s-operator/crd-generate/config/minio/minio_server.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/minio/minio_server.yaml rename to computer/computer-k8s-operator/crd-generate/config/minio/minio_server.yaml diff --git a/computer-k8s-operator/crd-generate/config/prometheus/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/prometheus/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/prometheus/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/prometheus/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/prometheus/monitor.yaml b/computer/computer-k8s-operator/crd-generate/config/prometheus/monitor.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/prometheus/monitor.yaml rename to computer/computer-k8s-operator/crd-generate/config/prometheus/monitor.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_client_clusterrole.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_client_clusterrole.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/auth_proxy_client_clusterrole.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_client_clusterrole.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role_binding.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role_binding.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role_binding.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_role_binding.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_service.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_service.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/auth_proxy_service.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/auth_proxy_service.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_editor_role.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_editor_role.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_editor_role.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_editor_role.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_viewer_role.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_viewer_role.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_viewer_role.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/hugegraphcomputerjob_viewer_role.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/leader_election_role.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/leader_election_role.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/leader_election_role.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/leader_election_role.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/leader_election_role_binding.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/leader_election_role_binding.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/leader_election_role_binding.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/leader_election_role_binding.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/role.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/role.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/role.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/role.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/role_binding.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/role_binding.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/role_binding.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/role_binding.yaml diff --git a/computer-k8s-operator/crd-generate/config/rbac/service_account.yaml b/computer/computer-k8s-operator/crd-generate/config/rbac/service_account.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/rbac/service_account.yaml rename to computer/computer-k8s-operator/crd-generate/config/rbac/service_account.yaml diff --git a/computer-k8s-operator/crd-generate/config/samples/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/samples/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/samples/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/samples/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/samples/operator_v1_hugegraphcomputerjob.yaml b/computer/computer-k8s-operator/crd-generate/config/samples/operator_v1_hugegraphcomputerjob.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/samples/operator_v1_hugegraphcomputerjob.yaml rename to computer/computer-k8s-operator/crd-generate/config/samples/operator_v1_hugegraphcomputerjob.yaml diff --git a/computer-k8s-operator/crd-generate/config/webhook/kustomization.yaml b/computer/computer-k8s-operator/crd-generate/config/webhook/kustomization.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/webhook/kustomization.yaml rename to computer/computer-k8s-operator/crd-generate/config/webhook/kustomization.yaml diff --git a/computer-k8s-operator/crd-generate/config/webhook/kustomizeconfig.yaml b/computer/computer-k8s-operator/crd-generate/config/webhook/kustomizeconfig.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/webhook/kustomizeconfig.yaml rename to computer/computer-k8s-operator/crd-generate/config/webhook/kustomizeconfig.yaml diff --git a/computer-k8s-operator/crd-generate/config/webhook/manifests.yaml b/computer/computer-k8s-operator/crd-generate/config/webhook/manifests.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/webhook/manifests.yaml rename to computer/computer-k8s-operator/crd-generate/config/webhook/manifests.yaml diff --git a/computer-k8s-operator/crd-generate/config/webhook/service.yaml b/computer/computer-k8s-operator/crd-generate/config/webhook/service.yaml similarity index 100% rename from computer-k8s-operator/crd-generate/config/webhook/service.yaml rename to computer/computer-k8s-operator/crd-generate/config/webhook/service.yaml diff --git a/computer-k8s-operator/crd-generate/go.mod b/computer/computer-k8s-operator/crd-generate/go.mod similarity index 100% rename from computer-k8s-operator/crd-generate/go.mod rename to computer/computer-k8s-operator/crd-generate/go.mod diff --git a/computer-k8s-operator/crd-generate/go.sum b/computer/computer-k8s-operator/crd-generate/go.sum similarity index 100% rename from computer-k8s-operator/crd-generate/go.sum rename to computer/computer-k8s-operator/crd-generate/go.sum diff --git a/computer-k8s-operator/crd-generate/hack/boilerplate.go.txt b/computer/computer-k8s-operator/crd-generate/hack/boilerplate.go.txt similarity index 100% rename from computer-k8s-operator/crd-generate/hack/boilerplate.go.txt rename to computer/computer-k8s-operator/crd-generate/hack/boilerplate.go.txt diff --git a/computer-k8s-operator/manifest/hugegraph-computer-crd.v1.yaml b/computer/computer-k8s-operator/manifest/hugegraph-computer-crd.v1.yaml similarity index 100% rename from computer-k8s-operator/manifest/hugegraph-computer-crd.v1.yaml rename to computer/computer-k8s-operator/manifest/hugegraph-computer-crd.v1.yaml diff --git a/computer-k8s-operator/manifest/hugegraph-computer-crd.v1beta1.yaml b/computer/computer-k8s-operator/manifest/hugegraph-computer-crd.v1beta1.yaml similarity index 100% rename from computer-k8s-operator/manifest/hugegraph-computer-crd.v1beta1.yaml rename to computer/computer-k8s-operator/manifest/hugegraph-computer-crd.v1beta1.yaml diff --git a/computer-k8s-operator/manifest/hugegraph-computer-operator.yaml b/computer/computer-k8s-operator/manifest/hugegraph-computer-operator.yaml similarity index 100% rename from computer-k8s-operator/manifest/hugegraph-computer-operator.yaml rename to computer/computer-k8s-operator/manifest/hugegraph-computer-operator.yaml diff --git a/computer-k8s-operator/pom.xml b/computer/computer-k8s-operator/pom.xml similarity index 100% rename from computer-k8s-operator/pom.xml rename to computer/computer-k8s-operator/pom.xml diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/OperatorEntrypoint.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/AbstractController.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/MatchWithMsg.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorRequest.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/OperatorResult.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/common/WorkQueue.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/config/OperatorOptions.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobComponent.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobController.java diff --git a/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java b/computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java similarity index 100% rename from computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java rename to computer/computer-k8s-operator/src/main/java/org/apache/hugegraph/computer/k8s/operator/controller/ComputerJobDeployer.java diff --git a/computer-k8s-operator/src/main/resources/log4j2.xml b/computer/computer-k8s-operator/src/main/resources/log4j2.xml similarity index 100% rename from computer-k8s-operator/src/main/resources/log4j2.xml rename to computer/computer-k8s-operator/src/main/resources/log4j2.xml diff --git a/computer-k8s/pom.xml b/computer/computer-k8s/pom.xml similarity index 100% rename from computer-k8s/pom.xml rename to computer/computer-k8s/pom.xml diff --git a/computer-k8s/schema/crd-schema.json b/computer/computer-k8s/schema/crd-schema.json similarity index 100% rename from computer-k8s/schema/crd-schema.json rename to computer/computer-k8s/schema/crd-schema.json diff --git a/computer-k8s/schema/enum-schema.json b/computer/computer-k8s/schema/enum-schema.json similarity index 100% rename from computer-k8s/schema/enum-schema.json rename to computer/computer-k8s/schema/enum-schema.json diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/Constants.java diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeDriverOptions.java diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/config/KubeSpecOptions.java diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJob.java diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/crd/model/HugeGraphComputerJobList.java diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java index a6e845b65..ad184b848 100644 --- a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java +++ b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/driver/KubernetesDriver.java @@ -39,7 +39,6 @@ import java.util.concurrent.CompletableFuture; import java.util.concurrent.ConcurrentHashMap; -import io.fabric8.kubernetes.api.model.DeletionPropagation; import org.apache.commons.collections.CollectionUtils; import org.apache.commons.io.FileUtils; import org.apache.commons.lang3.StringUtils; @@ -69,6 +68,7 @@ import org.apache.hugegraph.util.Log; import org.slf4j.Logger; +import io.fabric8.kubernetes.api.model.DeletionPropagation; import io.fabric8.kubernetes.api.model.Event; import io.fabric8.kubernetes.api.model.LocalObjectReference; import io.fabric8.kubernetes.api.model.ObjectMeta; diff --git a/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java b/computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java similarity index 100% rename from computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java rename to computer/computer-k8s/src/main/java/org/apache/hugegraph/computer/k8s/util/KubeUtil.java diff --git a/computer-k8s/src/main/resources/docker_push.sh b/computer/computer-k8s/src/main/resources/docker_push.sh similarity index 100% rename from computer-k8s/src/main/resources/docker_push.sh rename to computer/computer-k8s/src/main/resources/docker_push.sh diff --git a/computer-test/conf/images/docker_push_test.sh b/computer/computer-test/conf/images/docker_push_test.sh similarity index 100% rename from computer-test/conf/images/docker_push_test.sh rename to computer/computer-test/conf/images/docker_push_test.sh diff --git a/computer-test/conf/log4j2-test.xml b/computer/computer-test/conf/log4j2-test.xml similarity index 100% rename from computer-test/conf/log4j2-test.xml rename to computer/computer-test/conf/log4j2-test.xml diff --git a/computer-test/pom.xml b/computer/computer-test/pom.xml similarity index 100% rename from computer-test/pom.xml rename to computer/computer-test/pom.xml diff --git a/computer/computer-test/src/main/java/org/apache/hugegraph/computer/GenOption.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/GenOption.java new file mode 100644 index 000000000..a162da8d3 --- /dev/null +++ b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/GenOption.java @@ -0,0 +1,51 @@ +/* + * Licensed to the Apache Software Foundation (ASF) under one + * or more contributor license agreements. See the NOTICE file + * distributed with this work for additional information + * regarding copyright ownership. The ASF licenses this file + * to you under the Apache License, Version 2.0 (the + * "License"); you may not use this file except in compliance + * with the License. You may obtain a copy of the License at + * + * http://www.apache.org/licenses/LICENSE-2.0 + * + * Unless required by applicable law or agreed to in writing, + * software distributed under the License is distributed on an + * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY + * KIND, either express or implied. See the License for the + * specific language governing permissions and limitations + * under the License. + */ +package org.apache.hugegraph.computer; + +import java.util.Map; +import java.util.stream.Collectors; + +import org.apache.commons.lang.text.StrBuilder; +import org.apache.hugegraph.computer.k8s.config.KubeDriverOptions; +import org.apache.hugegraph.config.OptionHolder; +import org.apache.hugegraph.config.TypedOption; + +public class GenOption { + + public static void main(String[] args) { + OptionHolder instance = KubeDriverOptions.instance(); + + Map> options = instance.options(); + + StrBuilder strBuilder = new StrBuilder(); + + options.entrySet().stream().sorted(Map.Entry.comparingByKey()).collect( + Collectors.toList()).forEach(enrtry -> { + TypedOption value = enrtry.getValue(); + Object o = value.defaultValue(); + String defaultV = o instanceof Class ? ((Class) o).getCanonicalName() : + String.valueOf(o); + strBuilder.append("|"); + strBuilder.append(value.name()).append("|").append(defaultV).append("|") + .append(value.desc()).append("|").append("\n"); + }); + + System.out.println(strBuilder); + } +} diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestBase.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/AlgorithmTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/betweenness/BetweennessCentralityTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/closeness/ClosenessCentralityTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/degree/DegreeCentralityTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/centrality/pagerank/PageRankTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/cc/ClusteringCoefficientTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/kcore/KcoreTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java index 50e12981a..f4331a9d7 100644 --- a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java +++ b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/lpa/LpaTest.java @@ -17,6 +17,8 @@ package org.apache.hugegraph.computer.algorithm.community.lpa; +import java.util.HashSet; + import org.apache.hugegraph.computer.algorithm.AlgorithmTestBase; import org.apache.hugegraph.computer.core.config.ComputerOptions; import org.apache.hugegraph.computer.core.output.hg.HugeGraphStringOutput; @@ -29,8 +31,6 @@ import org.junit.BeforeClass; import org.junit.Test; -import java.util.HashSet; - public class LpaTest extends AlgorithmTestBase { private static final String VERTX_LABEL = "tc_user"; diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/trianglecount/TriangleCountTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/community/wcc/WccTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/rings/RingsDetectionWithFilterTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/path/shortest/SingleSourceShortestPathTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/algorithm/sampling/RandomWalkTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/AllocatorTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/DefaultAllocatorTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/allocator/RecyclersTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspEventTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/BspTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdBspTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/bsp/EtcdClientTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/CombinerTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/DoubleValueSumCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/FloatValueSumCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/IntValueSumCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/LongValueSumCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeNewPropertiesCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/MergeOldPropertiesCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/OverwriteCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/PointerCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMaxCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/combiner/ValueMinCombinerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/CommonTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ContainerInfoTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/ExceptionTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/common/FakeMasterComputation.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeManagerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/ComputeTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockComputation.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/MockMessageSender.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/EdgesInputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/MessageInputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/compute/input/ResuablePointerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/ConfigTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/config/DefaultConfigTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/BuiltinGraphFactoryTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultEdgeTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/DefaultPropertiesTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/GraphTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/SuperstepStatTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/BytesIdTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdFactoryTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/id/IdTypeTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/HashPartitionerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/partition/PartitionStatTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/BooleanValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/DoubleValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/FloatValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdListListTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueListTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IdValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/IntValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ListValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/LongValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/NullValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/StringValueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/graph/value/ValueTypeTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/FileInputSplitTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/HugeConverterTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitDataTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputSplitTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/InputTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockMasterInputManager.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockRpcClient.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/input/MockWorkerInputManager.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedFileTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/BufferedStreamTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/CsvStructGraphOutputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/IOTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/JsonStructGraphOutputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/MockRankComputation.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/OptimizedUnsafeBytesTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StreamGraphOutputInputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/StructRandomAccessOutputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/io/UnsafeBytesTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/ConnectionIdTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/DataServerManagerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockClientHandler.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockMessageHandler.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/MockUnDecodeMessage.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/NetworkTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/TransportUtilTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/buffer/NetworkBufferTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/connection/ConnectionManagerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/AbstractNetworkTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/HeartbeatHandlerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyClientFactoryTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyEncodeDecodeHandlerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportClientTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/netty/NettyTransportServerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/network/session/TransportSessionTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvBuffersTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/MessageRecvManagerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java similarity index 98% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java index d17d24435..0634b6ccb 100644 --- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java +++ b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/ReceiverUtil.java @@ -25,7 +25,6 @@ import org.apache.hugegraph.computer.core.io.BytesOutput; import org.apache.hugegraph.computer.core.io.IOFactory; import org.apache.hugegraph.computer.core.io.RandomAccessInput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.StreamGraphInput; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.network.buffer.NettyBuffer; diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/edge/EdgeMessageRecvPartitionTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/message/ComputeMessageRecvPartitionTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/receiver/vertex/VertexMessageRecvPartitionTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageQueueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendBuffersTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MessageSendManagerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MockTransportClient.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/MultiQueueTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageSenderTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/QueuedMessageTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/SenderTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBufferTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sender/WriteBuffersTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java similarity index 99% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java index 30cc9f295..aa7882083 100644 --- a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java +++ b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/SorterTestUtil.java @@ -34,7 +34,6 @@ import org.apache.hugegraph.computer.core.io.BytesInput; import org.apache.hugegraph.computer.core.io.BytesOutput; import org.apache.hugegraph.computer.core.io.IOFactory; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.Writable; import org.apache.hugegraph.computer.core.store.StoreTestUtil; import org.apache.hugegraph.computer.core.store.entry.EntriesUtil; diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/combiner/MockIntSumCombiner.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/EmptyFlusherTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/FlusherTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SortLargeDataTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorter/SorterTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/InputsSortingTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/SortingTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/sort/sorting/TestData.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/BitFileTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntriesUtilTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/EntryOutputTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/FileManagerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvDirTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/HgkvFileTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/PointerTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/StoreTestUtil.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/store/ValueFileTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/ComputerContextUtilTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/IdUtilTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/IdUtilTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/util/IdUtilTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/IdUtilTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/JsonUtilTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/SerializeUtilTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/util/UtilTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputation2.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockComputationParams.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockMasterComputation2.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/MockWorkerService.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerServiceTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerStatTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/core/worker/WorkerTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/driver/ComputerOptionsTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/driver/DriverTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/AbstractK8sTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/K8sTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/KubernetesDriverTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/MiniKubeTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/k8s/OperatorTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/IntegrateTestSuite.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/MockComputation.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/integrate/SenderIntegrateTest.java diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java similarity index 99% rename from computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java index efc0703fb..5977d2469 100644 --- a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java +++ b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestBase.java @@ -40,7 +40,6 @@ import org.apache.hugegraph.computer.core.io.OutputFormat; import org.apache.hugegraph.computer.core.io.RandomAccessInput; import org.apache.hugegraph.computer.core.io.RandomAccessOutput; -import org.apache.hugegraph.computer.core.io.Readable; import org.apache.hugegraph.computer.core.io.StreamGraphInput; import org.apache.hugegraph.computer.core.io.StreamGraphOutput; import org.apache.hugegraph.computer.core.io.Writable; diff --git a/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java b/computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java similarity index 100% rename from computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java rename to computer/computer-test/src/main/java/org/apache/hugegraph/computer/suite/unit/UnitTestSuite.java diff --git a/computer-test/src/main/resources/computer.properties b/computer/computer-test/src/main/resources/computer.properties similarity index 100% rename from computer-test/src/main/resources/computer.properties rename to computer/computer-test/src/main/resources/computer.properties diff --git a/computer-test/src/main/resources/hdfs_input_test/core-site.xml b/computer/computer-test/src/main/resources/hdfs_input_test/core-site.xml similarity index 100% rename from computer-test/src/main/resources/hdfs_input_test/core-site.xml rename to computer/computer-test/src/main/resources/hdfs_input_test/core-site.xml diff --git a/computer-test/src/main/resources/hdfs_input_test/schema.json b/computer/computer-test/src/main/resources/hdfs_input_test/schema.json similarity index 100% rename from computer-test/src/main/resources/hdfs_input_test/schema.json rename to computer/computer-test/src/main/resources/hdfs_input_test/schema.json diff --git a/computer-test/src/main/resources/hdfs_input_test/struct.json b/computer/computer-test/src/main/resources/hdfs_input_test/struct.json similarity index 100% rename from computer-test/src/main/resources/hdfs_input_test/struct.json rename to computer/computer-test/src/main/resources/hdfs_input_test/struct.json diff --git a/computer-test/src/main/resources/log4j2.xml b/computer/computer-test/src/main/resources/log4j2.xml similarity index 100% rename from computer-test/src/main/resources/log4j2.xml rename to computer/computer-test/src/main/resources/log4j2.xml diff --git a/computer-yarn/pom.xml b/computer/computer-yarn/pom.xml similarity index 100% rename from computer-yarn/pom.xml rename to computer/computer-yarn/pom.xml diff --git a/pom.xml b/computer/pom.xml similarity index 100% rename from pom.xml rename to computer/pom.xml