jar

org.apache.hugegraph : computer-core

Maven & Gradle

Feb 10, 2023
Table Of Contents

Latest Version

Download org.apache.hugegraph : computer-core JAR file - Latest Versions:

All Versions

Download org.apache.hugegraph : computer-core JAR file - All Versions:

Version Vulnerabilities Size Updated
1.0.x

View Java Class Source Code in JAR file

  1. Download JD-GUI to open JAR file and explore Java source code file (.class .java)
  2. Click menu "File → Open File..." or just drag-and-drop the JAR file in the JD-GUI window computer-core-1.0.0.jar file.
    Once you open a JAR file, all the java classes in the JAR file will be displayed.

org.apache.hugegraph.computer.core.sender

├─ org.apache.hugegraph.computer.core.sender.MessageQueue.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.MessageSendBuffers.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.MessageSendManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.MessageSendPartition.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.MessageSender.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.MultiQueue.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.QueuedMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.QueuedMessageSender.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.WriteBuffer.class - [JAR]

├─ org.apache.hugegraph.computer.core.sender.WriteBuffers.class - [JAR]

org.apache.hugegraph.computer.core.output.hdfs

├─ org.apache.hugegraph.computer.core.output.hdfs.HdfsOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.hdfs.HdfsOutputMerger.class - [JAR]

org.apache.hugegraph.computer.core.store.buffer

├─ org.apache.hugegraph.computer.core.store.buffer.KvEntriesInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.buffer.KvEntriesWithFirstSubKvInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.buffer.SubKvEntriesInput.class - [JAR]

org.apache.hugegraph.computer.core.input

├─ org.apache.hugegraph.computer.core.input.EdgeFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.ElementFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.GraphFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.HugeConverter.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.IdUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.InputSourceFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.InputSplit.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.InputSplitFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.MasterInputHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.MasterInputManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.VertexFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.WorkerInputManager.class - [JAR]

org.apache.hugegraph.computer.core.store.file.bufferfile

├─ org.apache.hugegraph.computer.core.store.file.bufferfile.BufferFileEntryBuilder.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.bufferfile.BufferFileEntryReader.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.bufferfile.BufferFileSubEntryReader.class - [JAR]

org.apache.hugegraph.computer.core.graph.id

├─ org.apache.hugegraph.computer.core.graph.id.BytesId.class - [JAR]

org.apache.hugegraph.computer.core.input.filter

├─ org.apache.hugegraph.computer.core.input.filter.DefaultInputFilter.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.filter.ExtractAllPropertyInputFilter.class - [JAR]

org.apache.hugegraph.computer.core.worker.load

├─ org.apache.hugegraph.computer.core.worker.load.LoadService.class - [JAR]

org.apache.hugegraph.computer.core.bsp

├─ org.apache.hugegraph.computer.core.bsp.Bsp4Master.class - [JAR]

├─ org.apache.hugegraph.computer.core.bsp.Bsp4Worker.class - [JAR]

├─ org.apache.hugegraph.computer.core.bsp.BspBase.class - [JAR]

├─ org.apache.hugegraph.computer.core.bsp.BspClient.class - [JAR]

├─ org.apache.hugegraph.computer.core.bsp.BspEvent.class - [JAR]

├─ org.apache.hugegraph.computer.core.bsp.EtcdBspClient.class - [JAR]

├─ org.apache.hugegraph.computer.core.bsp.EtcdClient.class - [JAR]

org.apache.hugegraph.computer.core.common

├─ org.apache.hugegraph.computer.core.common.ContainerInfo.class - [JAR]

org.apache.hugegraph.computer.core.input.hg

├─ org.apache.hugegraph.computer.core.input.hg.HugeEdgeFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.hg.HugeElementFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.hg.HugeGraphFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.hg.HugeInputSplitFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.hg.HugeVertexFetcher.class - [JAR]

org.apache.hugegraph.computer.core.io

├─ org.apache.hugegraph.computer.core.io.AbstractBufferedFileInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.AbstractBufferedFileOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.BufferedFileInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.BufferedFileOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.BufferedStreamInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.BufferedStreamOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.CsvStructGraphOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.IOFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.JsonStructGraphOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.OptimizedBytesInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.OptimizedBytesOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.OutputFormat.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.StreamGraphInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.StreamGraphOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.StructGraphOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.StructRandomAccessOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.UnsafeBytesInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.io.UnsafeBytesOutput.class - [JAR]

org.apache.hugegraph.computer.core.network.netty

├─ org.apache.hugegraph.computer.core.network.netty.AbstractNettyHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.BufAllocatorFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.ChannelFutureListenerOnWrite.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.HeartbeatHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyClientFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyClientHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyEventLoopUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyProtocol.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyServerHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyTransportClient.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyTransportProvider.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.NettyTransportServer.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.ServerIdleHandler.class - [JAR]

org.apache.hugegraph.computer.core.receiver

├─ org.apache.hugegraph.computer.core.receiver.MessageRecvBuffers.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.MessageRecvManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.MessageRecvPartition.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.MessageRecvPartitions.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.MessageStat.class - [JAR]

org.apache.hugegraph.computer.core.store.file.select

├─ org.apache.hugegraph.computer.core.store.file.select.DefaultSelectedFiles.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.select.DisperseEvenlySelector.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.select.InputFilesSelector.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.select.SelectedFiles.class - [JAR]

org.apache.hugegraph.computer.core.sort.sorter

├─ org.apache.hugegraph.computer.core.sort.sorter.InputSorter.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorter.InputsSorter.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorter.InputsSorterImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorter.JavaInputSorter.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorter.SubKvSorter.class - [JAR]

org.apache.hugegraph.computer.core.aggregator

├─ org.apache.hugegraph.computer.core.aggregator.Aggregators.class - [JAR]

├─ org.apache.hugegraph.computer.core.aggregator.DefaultAggregator.class - [JAR]

├─ org.apache.hugegraph.computer.core.aggregator.MasterAggrManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.aggregator.RegisterAggregators.class - [JAR]

├─ org.apache.hugegraph.computer.core.aggregator.WorkerAggrManager.class - [JAR]

org.apache.hugegraph.computer.core.network

├─ org.apache.hugegraph.computer.core.network.ClientFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.ClientHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.ConnectionId.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.DataClientManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.DataServerManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.IOMode.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.MessageHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportClient.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportConf.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportHandler.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportProvider.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportServer.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportState.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.TransportUtil.class - [JAR]

org.apache.hugegraph.computer.core.graph.edge

├─ org.apache.hugegraph.computer.core.graph.edge.DefaultEdge.class - [JAR]

├─ org.apache.hugegraph.computer.core.graph.edge.DefaultEdges.class - [JAR]

org.apache.hugegraph.computer.core.network.connection

├─ org.apache.hugegraph.computer.core.network.connection.ConnectionManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.connection.TransportConnectionManager.class - [JAR]

org.apache.hugegraph.computer.core.common.exception

├─ org.apache.hugegraph.computer.core.common.exception.IllegalArgException.class - [JAR]

├─ org.apache.hugegraph.computer.core.common.exception.ReadException.class - [JAR]

├─ org.apache.hugegraph.computer.core.common.exception.TransportException.class - [JAR]

├─ org.apache.hugegraph.computer.core.common.exception.WriteException.class - [JAR]

org.apache.hugegraph.computer.core.sort

├─ org.apache.hugegraph.computer.core.sort.BufferFileSorter.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.DefaultSorter.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.HgkvFileSorter.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.Sorter.class - [JAR]

org.apache.hugegraph.computer.core.receiver.message

├─ org.apache.hugegraph.computer.core.receiver.message.ComputeMessageRecvPartition.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.message.ComputeMessageRecvPartitions.class - [JAR]

org.apache.hugegraph.computer.core.input.loader

├─ org.apache.hugegraph.computer.core.input.loader.FileEdgeFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.loader.FileElementFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.loader.FileInputSplit.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.loader.FileVertxFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.loader.LoaderFileInputSplitFetcher.class - [JAR]

├─ org.apache.hugegraph.computer.core.input.loader.LoaderGraphFetcher.class - [JAR]

org.apache.hugegraph.computer.core.store.file.seqfile

├─ org.apache.hugegraph.computer.core.store.file.seqfile.BitsFileReader.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.seqfile.BitsFileReaderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.seqfile.BitsFileWriter.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.seqfile.BitsFileWriterImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.seqfile.ValueFile.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.seqfile.ValueFileInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.seqfile.ValueFileOutput.class - [JAR]

org.apache.hugegraph.computer.core.manager

├─ org.apache.hugegraph.computer.core.manager.Manager.class - [JAR]

├─ org.apache.hugegraph.computer.core.manager.Managers.class - [JAR]

org.apache.hugegraph.computer.core.graph

├─ org.apache.hugegraph.computer.core.graph.BuiltinGraphFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.graph.SuperstepStat.class - [JAR]

org.apache.hugegraph.computer.core.sort.sorting

├─ org.apache.hugegraph.computer.core.sort.sorting.AbstractInputsSorting.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.HeapInputsSorting.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.InputsSorting.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.LoserTreeInputsSorting.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.RecvSortManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.SendSortManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.SortManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.SortingFactory.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.sorting.SortingMode.class - [JAR]

org.apache.hugegraph.computer.core.graph.partition

├─ org.apache.hugegraph.computer.core.graph.partition.HashPartitioner.class - [JAR]

├─ org.apache.hugegraph.computer.core.graph.partition.PartitionStat.class - [JAR]

├─ org.apache.hugegraph.computer.core.graph.partition.Partitioner.class - [JAR]

org.apache.hugegraph.computer.core.store.file.hgkvfile

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.AbstractHgkvFile.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.HgkvDir.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.HgkvDirImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.HgkvFile.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.HgkvFileImpl.class - [JAR]

org.apache.hugegraph.computer.core.combiner

├─ org.apache.hugegraph.computer.core.combiner.AbstractPointerCombiner.class - [JAR]

├─ org.apache.hugegraph.computer.core.combiner.EdgeValueCombiner.class - [JAR]

├─ org.apache.hugegraph.computer.core.combiner.MessageValueCombiner.class - [JAR]

├─ org.apache.hugegraph.computer.core.combiner.PointerCombiner.class - [JAR]

├─ org.apache.hugegraph.computer.core.combiner.VertexValueCombiner.class - [JAR]

org.apache.hugegraph.computer.core.sort.flusher

├─ org.apache.hugegraph.computer.core.sort.flusher.CombinableSorterFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.CombineKvInnerSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.CombineKvOuterSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.CombineSubKvInnerSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.CombineSubKvOuterSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.InnerSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.KvInnerSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.KvOuterSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.OuterSortFlusher.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.PeekableIterator.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.flusher.PeekableIteratorAdaptor.class - [JAR]

org.apache.hugegraph.computer.core.output

├─ org.apache.hugegraph.computer.core.output.LimitedLogOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.LogOutput.class - [JAR]

org.apache.hugegraph.computer.core.output.hg

├─ org.apache.hugegraph.computer.core.output.hg.HugeGraphDoubleOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.hg.HugeGraphFloatOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.hg.HugeGraphIdOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.hg.HugeGraphIntOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.hg.HugeGraphLongOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.output.hg.HugeGraphStringOutput.class - [JAR]

org.apache.hugegraph.computer.core.network.message

├─ org.apache.hugegraph.computer.core.network.message.AbstractMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.AckMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.DataMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.FailMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.FinishMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.Message.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.MessageType.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.PingMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.PongMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.RequestMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.ResponseMessage.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.message.StartMessage.class - [JAR]

org.apache.hugegraph.computer.core.store.file.hgkvfile.reader

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.reader.HgkvDir4SubKvReaderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.reader.HgkvDirReaderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.reader.HgkvFileReaderImpl.class - [JAR]

org.apache.hugegraph.computer.core.sort.merge

├─ org.apache.hugegraph.computer.core.sort.merge.FileMerger.class - [JAR]

├─ org.apache.hugegraph.computer.core.sort.merge.FileMergerImpl.class - [JAR]

org.apache.hugegraph.computer.core.util

├─ org.apache.hugegraph.computer.core.util.ComputerContextUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.util.Consumers.class - [JAR]

├─ org.apache.hugegraph.computer.core.util.FileUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.util.JsonUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.util.SerializeUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.util.ShutdownHook.class - [JAR]

├─ org.apache.hugegraph.computer.core.util.StringEncoding.class - [JAR]

org.apache.hugegraph.computer.core.receiver.vertex

├─ org.apache.hugegraph.computer.core.receiver.vertex.VertexMessageRecvPartition.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.vertex.VertexMessageRecvPartitions.class - [JAR]

org.apache.hugegraph.computer.core.master

├─ org.apache.hugegraph.computer.core.master.MasterService.class - [JAR]

org.apache.hugegraph.computer.core.graph.vertex

├─ org.apache.hugegraph.computer.core.graph.vertex.DefaultVertex.class - [JAR]

org.apache.hugegraph.computer.core.compute

├─ org.apache.hugegraph.computer.core.compute.ComputeManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.compute.FileGraphPartition.class - [JAR]

org.apache.hugegraph.computer.core.receiver.edge

├─ org.apache.hugegraph.computer.core.receiver.edge.EdgeMessageRecvPartition.class - [JAR]

├─ org.apache.hugegraph.computer.core.receiver.edge.EdgeMessageRecvPartitions.class - [JAR]

org.apache.hugegraph.computer.core.network.session

├─ org.apache.hugegraph.computer.core.network.session.ClientSession.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.session.ServerSession.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.session.TransportSession.class - [JAR]

org.apache.hugegraph.computer.core.compute.input

├─ org.apache.hugegraph.computer.core.compute.input.EdgesInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.compute.input.MessageInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.compute.input.ReusablePointer.class - [JAR]

├─ org.apache.hugegraph.computer.core.compute.input.VertexInput.class - [JAR]

org.apache.hugegraph.computer.core.store.file.hgkvfile.builder

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.BlockBuilder.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.DataBlockBuilderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.HgkvDirBuilderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.HgkvFileBuilder.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.HgkvFileBuilderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.IndexBlockBuilder.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.file.hgkvfile.builder.IndexBlockBuilderImpl.class - [JAR]

org.apache.hugegraph.computer.core.store.entry

├─ org.apache.hugegraph.computer.core.store.entry.AbstractKvEntry.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.CachedPointer.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.DefaultKvEntry.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.EntriesUtil.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.EntryInput.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.EntryInputImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.EntryOutput.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.EntryOutputImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.InlinePointer.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.KvEntry.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.KvEntryReader.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.KvEntryReaderImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.KvEntryWithFirstSubKv.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.KvEntryWriter.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.KvEntryWriterImpl.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.Pointer.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.entry.Range.class - [JAR]

org.apache.hugegraph.computer.core.worker

├─ org.apache.hugegraph.computer.core.worker.WorkerService.class - [JAR]

├─ org.apache.hugegraph.computer.core.worker.WorkerStat.class - [JAR]

org.apache.hugegraph.computer.core.network.buffer

├─ org.apache.hugegraph.computer.core.network.buffer.FileRegionBuffer.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.buffer.NettyBuffer.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.buffer.NetworkBuffer.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.buffer.NioBuffer.class - [JAR]

org.apache.hugegraph.computer.core.rpc

├─ org.apache.hugegraph.computer.core.rpc.AggregateRpcService.class - [JAR]

├─ org.apache.hugegraph.computer.core.rpc.InputSplitRpcService.class - [JAR]

├─ org.apache.hugegraph.computer.core.rpc.MasterRpcManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.rpc.WorkerRpcManager.class - [JAR]

org.apache.hugegraph.computer.core.allocator

├─ org.apache.hugegraph.computer.core.allocator.DefaultAllocator.class - [JAR]

├─ org.apache.hugegraph.computer.core.allocator.RecycleHandler.class - [JAR]

org.apache.hugegraph.computer.core.store

├─ org.apache.hugegraph.computer.core.store.EntryIterator.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.FileGenerator.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.FileManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.KvEntryFileReader.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.KvEntryFileWriter.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.StoreManager.class - [JAR]

├─ org.apache.hugegraph.computer.core.store.SuperstepFileGenerator.class - [JAR]

org.apache.hugegraph.computer.core.network.netty.codec

├─ org.apache.hugegraph.computer.core.network.netty.codec.FrameDecoder.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.codec.MessageDecoder.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.codec.MessageEncoder.class - [JAR]

├─ org.apache.hugegraph.computer.core.network.netty.codec.PreciseFrameDecoder.class - [JAR]