JavaScript is disabled on your browser.
Skip navigation links
Overview
Package
Class
Use
Tree
Deprecated
Index
Help
Prev
Next
Frames
No Frames
All Classes
Hierarchy For All Packages
Package Hierarchies:
org.apache.giraph
,
org.apache.giraph.aggregators
,
org.apache.giraph.aggregators.matrix.dense
,
org.apache.giraph.aggregators.matrix.sparse
,
org.apache.giraph.block_app.framework
,
org.apache.giraph.block_app.framework.block
,
org.apache.giraph.block_app.reducers.array
,
org.apache.giraph.comm
,
org.apache.giraph.comm.messages
,
org.apache.giraph.comm.messages.queue
,
org.apache.giraph.conf
,
org.apache.giraph.edge
,
org.apache.giraph.examples
,
org.apache.giraph.examples.block_app
,
org.apache.giraph.examples.scc
,
org.apache.giraph.generate
,
org.apache.giraph.graph
,
org.apache.giraph.io
,
org.apache.giraph.jython
,
org.apache.giraph.master
,
org.apache.giraph.partition
,
org.apache.giraph.reducers.impl
,
org.apache.giraph.types
,
org.apache.giraph.types.heaps
,
org.apache.giraph.utils
,
org.apache.giraph.utils.hashing
,
org.apache.giraph.utils.io
,
org.apache.giraph.vertex
,
org.apache.giraph.writable.kryo
,
org.apache.giraph.yarn
,
org.apache.giraph.zk
Class Hierarchy
java.lang.
Object
org.apache.giraph.block_app.framework.
AbstractBlockFactory
<S> (implements org.apache.giraph.block_app.framework.
BlockFactory
<S>)
org.apache.giraph.block_app.framework.
TestLongNullNullBlockFactory
org.apache.giraph.block_app.framework.
MultipleSimultanousMutationsTest.SendingAndAddEdgeBlockFactory
org.apache.giraph.block_app.framework.
SendingMessagesTest.SendingMessagesToNeighborsBlockFactory
org.apache.giraph.block_app.framework.
TestWorkerMessages.TestWorkerMessagesBlockFactory
org.apache.giraph.block_app.framework.piece.
AbstractPiece
<I,V,E,M,WV,WM,S> (implements org.apache.giraph.block_app.framework.block.
Block
)
org.apache.giraph.block_app.framework.piece.
DefaultParentPiece
<I,V,E,M,WV,WM,S>
org.apache.giraph.block_app.framework.
BlockApiHandleTest.TestPiece
org.apache.giraph.block_app.framework.piece.
PieceWithWorkerContext
<I,V,E,M,WV,WM,S>
org.apache.giraph.block_app.framework.
TestWorkerMessages.TestWorkerMessagesPiece
org.apache.giraph.comm.messages.queue.
AsyncMessageStoreWrapperTest
org.apache.giraph.block_app.framework.
BlockApiHandleTest
org.apache.giraph.block_app.framework.
BlockApiHandleTest.DummyObjectWithApiHandle
org.apache.giraph.block_app.framework.
BlockExecutionTest
org.apache.giraph.block_app.framework.block.
BlockTestingUtils
org.apache.giraph.block_app.framework.block.
BlockTestingUtils.CheckIterator
<T> (implements java.util.
Iterator
<E>)
org.apache.giraph.examples.
BrachaTouegDeadlockComputationTest
org.apache.giraph.
BspCase
(implements org.apache.zookeeper.Watcher)
org.apache.giraph.aggregators.
TestAggregatorsHandling
org.apache.giraph.
TestAutoCheckpoint
org.apache.giraph.
TestBspBasic
org.apache.giraph.
TestCheckpointing
org.apache.giraph.
TestComputationState
org.apache.giraph.io.
TestFilters
org.apache.giraph.
TestGraphPartitioner
org.apache.giraph.io.
TestJsonBase64Format
org.apache.giraph.examples.
TestKryoPageRank
org.apache.giraph.
TestManualCheckpoint
org.apache.giraph.
TestMaxSuperstep
org.apache.giraph.examples.block_app.
TestMigrationBspBasic
org.apache.giraph.
TestMutateGraph
org.apache.giraph.
TestNotEnoughMapTasks
org.apache.giraph.
TestOutOfCore
org.apache.giraph.examples.
TestPageRank
org.apache.giraph.io.
TestVertexEdgeInput
org.apache.giraph.zk.
ComputationDoneNameTest
org.apache.giraph.examples.
ConnectedComponentsComputationTest
org.apache.giraph.examples.
ConnectedComponentsComputationTestInMemory
org.apache.giraph.comm.
ConnectionTest
org.apache.giraph.edge.
DefaultCreateSourceVertexCallback
<I> (implements org.apache.giraph.edge.
CreateSourceVertexCallback
<I>)
org.apache.giraph.io.
TestCreateSourceVertex.CreateEvenSourceVerticesCallback
org.apache.giraph.conf.
DefaultImmutableClassesGiraphConfigurable
<I,V,E> (implements org.apache.giraph.conf.
ImmutableClassesGiraphConfigurable
<I,V,E>)
org.apache.giraph.edge.
ConfigurableOutEdges
<I,E> (implements org.apache.giraph.edge.
OutEdges
<I,E>)
org.apache.giraph.edge.
ByteArrayEdges
<I,E> (implements org.apache.giraph.edge.
ReuseObjectsOutEdges
<I,E>, org.apache.giraph.utils.
Trimmable
)
org.apache.giraph.io.
TestVertexEdgeInput.TestOutEdgesFilterEven
org.apache.giraph.graph.
DefaultVertexResolver
<I,V,E> (implements org.apache.giraph.graph.
VertexResolver
<I,V,E>)
org.apache.giraph.
TestMutateGraph.TestVertexResolver
<I,V,E>
org.apache.giraph.io.
GiraphInputFormat
<I,V,E>
org.apache.giraph.io.
VertexInputFormat
<I,V,E>
org.apache.giraph.io.formats.
TextVertexInputFormat
<I,V,E>
org.apache.giraph.io.formats.
AdjacencyListTextVertexInputFormat
<I,V,E>
org.apache.giraph.io.formats.
LongDoubleDoubleAdjacencyListVertexInputFormat
org.apache.giraph.io.
TestLongDoubleDoubleAdjacencyListVertexInputFormat
org.apache.giraph.io.formats.
TextDoubleDoubleAdjacencyListVertexInputFormat
org.apache.giraph.io.
TestTextDoubleDoubleAdjacencyListVertexInputFormat
org.apache.giraph.master.
TestMasterObserver.InputFormat
org.apache.giraph.master.
MasterCompute
(implements org.apache.giraph.master.
MasterAggregatorUsage
, org.apache.giraph.master.
MasterGlobalCommUsage
, org.apache.hadoop.io.Writable)
org.apache.giraph.master.
DefaultMasterCompute
org.apache.giraph.
TestCheckpointing.CheckpointVertexMasterCompute
org.apache.giraph.master.
TestSwitchClasses.SwitchingClassesMasterCompute
org.apache.giraph.io.
OutputFormat
<I,V,E>
org.apache.giraph.io.
EdgeOutputFormat
<I,V,E>
org.apache.giraph.io.formats.
TextEdgeOutputFormat
<I,V,E>
org.apache.giraph.io.formats.
SrcIdDstIdEdgeValueTextOutputFormat
<I,V,E>
org.apache.giraph.io.
TestSrcIdDstIdEdgeValueTextOutputFormat
org.apache.giraph.io.
VertexOutputFormat
<I,V,E>
org.apache.giraph.io.formats.
TextVertexOutputFormat
<I,V,E>
org.apache.giraph.io.formats.
AdjacencyListTextVertexOutputFormat
<I,V,E>
org.apache.giraph.io.
TestAdjacencyListTextVertexOutputFormat
org.apache.giraph.io.formats.
IdWithValueTextOutputFormat
<I,V,E>
org.apache.giraph.io.
TestIdWithValueTextOutputFormat
org.apache.giraph.worker.
WorkerAggregatorDelegator
<I,V,E> (implements org.apache.giraph.worker.
WorkerAggregatorUsage
, org.apache.giraph.worker.
WorkerGlobalCommUsage
)
org.apache.giraph.graph.
AbstractComputation
<I,V,E,M1,M2> (implements org.apache.giraph.graph.
Computation
<I,V,E,M1,M2>)
org.apache.giraph.graph.
BasicComputation
<I,V,E,M>
org.apache.giraph.utils.
ComputationCountEdges
org.apache.giraph.io.
TestVertexEdgeInput.TestComputationCheckEdgesType
org.apache.giraph.utils.
NoOpComputation
<I,V,E,M>
org.apache.giraph.utils.
IntIntNullNoOpComputation
org.apache.giraph.utils.
IntNoOpComputation
org.apache.giraph.utils.
LongNoOpComputation
org.apache.giraph.io.
TestAdjacencyListTextVertexOutputFormat.DummyComputation
org.apache.giraph.partition.
TestGiraphTransferRegulator.TestComputation
org.apache.giraph.io.
TestIdWithValueTextOutputFormat.DummyComputation
org.apache.giraph.io.
TestLongDoubleDoubleAdjacencyListVertexInputFormat.DummyComputation
org.apache.giraph.partition.
TestPartitionStores.MyComputation
org.apache.giraph.io.
TestSrcIdDstIdEdgeValueTextOutputFormat.DummyComputation
org.apache.giraph.io.
TestTextDoubleDoubleAdjacencyListVertexInputFormat.DummyComputation
org.apache.giraph.graph.
TestVertexAndEdges.TestComputation
org.apache.giraph.
TestCheckpointing.CheckpointComputation
org.apache.giraph.master.
TestMasterObserver.SimpleComputation
org.apache.giraph.
TestMaxSuperstep.InfiniteLoopComputation
org.apache.giraph.partition.
TestPartitionStores.EmptyComputation
org.apache.giraph.partition.
TestPartitionStores.TestOutOfCoreMessagesComputation
org.apache.giraph.master.
TestComputationCombinerTypes.NoOpComputation
<I,V,E,M1,M2>
org.apache.giraph.master.
TestSwitchClasses.Computation1
org.apache.giraph.master.
TestSwitchClasses.Computation2
org.apache.giraph.master.
TestSwitchClasses.Computation3
org.apache.giraph.worker.
WorkerContext
(implements org.apache.giraph.worker.
WorkerIndexUsage
<I>, org.apache.hadoop.io.Writable)
org.apache.giraph.worker.
DefaultWorkerContext
org.apache.giraph.
TestCheckpointing.CheckpointVertexWorkerContext
org.apache.giraph.master.
DefaultMasterObserver
(implements org.apache.giraph.master.
MasterObserver
)
org.apache.giraph.master.
TestMasterObserver.Obs
org.apache.giraph.writable.kryo.
DirectWritableSerializerCopyTest
org.apache.giraph.generate.
GeneratePrimitiveClasses
org.apache.giraph.edge.
IdAndNullArrayEdgesTest
org.apache.giraph.edge.
IdAndValueArrayEdgesTest
org.apache.giraph.comm.
IncreasingBitSetTest
org.apache.giraph.writable.kryo.
KryoSimpleTests
org.apache.giraph.writable.kryo.
KryoSimpleTests.TestClass
org.apache.giraph.writable.kryo.
KryoSimpleWritable
(implements org.apache.giraph.writable.kryo.markers.
KryoIgnoreWritable
)
org.apache.giraph.writable.kryo.
KryoSimpleTests.TestClassFromWritable
org.apache.giraph.writable.kryo.
KryoWritable
(implements org.apache.giraph.writable.kryo.markers.
KryoIgnoreWritable
)
org.apache.giraph.writable.kryo.
KryoSimpleTests.TestClassFromKryoWritable
org.apache.giraph.writable.kryo.
KryoWritableTest.LongKryoWritable
org.apache.giraph.writable.kryo.
KryoWritableTest.LongListKryoWritable
org.apache.giraph.writable.kryo.
KryoWritableTest.NestedKryoWritable
<T>
org.apache.giraph.writable.kryo.
KryoWritableTest.TestClassA
org.apache.giraph.writable.kryo.
KryoWritableTest
org.apache.giraph.writable.kryo.
KryoWritableWrapperTest
org.apache.giraph.edge.
LongByteHashMapEdgesTest
org.apache.giraph.edge.
LongDiffNullArrayEdgesTest
org.apache.giraph.examples.
MaxComputationTest
org.apache.giraph.examples.
MinimumIntCombinerTest
org.apache.giraph.comm.
MockExceptionHandler
(implements java.lang.
Thread.UncaughtExceptionHandler
)
org.apache.giraph.utils.
MockUtils
org.apache.giraph.utils.
MockUtils.MockedEnvironment
<I,V,E,M>
org.apache.giraph.block_app.framework.
MultipleSimultanousMutationsTest
org.apache.giraph.block_app.reducers.array.
ObjectStripingTest
org.apache.giraph.examples.
PageRankComputationTest
org.apache.giraph.examples.
RandomWalkTestUtils
org.apache.giraph.examples.
RandomWalkWithRestartComputationTest
org.apache.giraph.comm.
RequestFailureTest
org.apache.giraph.comm.
RequestTest
org.apache.giraph.comm.
SaslConnectionTest
org.apache.giraph.examples.scc.
SccComputationTestInMemory
org.apache.giraph.block_app.framework.
SendingMessagesTest
org.apache.giraph.partition.
SimpleRangePartitionFactoryTest
org.apache.giraph.examples.
SimpleShortestPathsComputationTest
org.apache.giraph.examples.
SimpleTriangleClosingComputationTest
org.apache.giraph.types.
TestBasicCollections
org.apache.giraph.utils.io.
TestBigDataIO
org.apache.giraph.aggregators.
TestBooleanAggregators
org.apache.giraph.types.
TestCollections
org.apache.giraph.master.
TestComputationCombinerTypes
org.apache.giraph.vertex.
TestComputationTypes
org.apache.giraph.vertex.
TestComputationTypes.GeneratedVertexMatchMessageCombiner
(implements org.apache.giraph.combiner.
MessageCombiner
<I,M>)
org.apache.giraph.vertex.
TestComputationTypes.GeneratedVertexMismatchMessageCombiner
(implements org.apache.giraph.combiner.
MessageCombiner
<I,M>)
org.apache.giraph.vertex.
TestComputationTypes.GeneratedVertexMismatchValueFactory
(implements org.apache.giraph.factories.
VertexValueFactory
<V>)
org.apache.giraph.io.
TestCreateSourceVertex
org.apache.giraph.aggregators.
TestDoubleAggregators
org.apache.giraph.aggregators.matrix.dense.
TestDoubleDenseMatrix
org.apache.giraph.aggregators.matrix.sparse.
TestDoubleSparseMatrix
org.apache.giraph.io.
TestFilters.EdgeFilter
(implements org.apache.giraph.io.filters.
EdgeInputFilter
<I,E>)
org.apache.giraph.io.
TestFilters.VertexFilter
(implements org.apache.giraph.io.filters.
VertexInputFilter
<I,V,E>)
org.apache.giraph.types.heaps.
TestFixedCapacityIntByteMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityIntDoubleMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityIntFloatMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityIntIntMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityIntLongMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityLongByteMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityLongDoubleMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityLongFloatMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityLongIntMinHeap
org.apache.giraph.types.heaps.
TestFixedCapacityLongLongMinHeap
org.apache.giraph.aggregators.
TestFloatAggregators
org.apache.giraph.aggregators.matrix.dense.
TestFloatDenseMatrix
org.apache.giraph.aggregators.matrix.sparse.
TestFloatSparseMatrix
org.apache.giraph.conf.
TestGiraphConfiguration
org.apache.giraph.conf.
TestGiraphConfiguration.A
(implements org.apache.giraph.conf.
TestGiraphConfiguration.If
)
org.apache.giraph.conf.
TestGiraphConfiguration.B
(implements org.apache.giraph.conf.
TestGiraphConfiguration.If
)
org.apache.giraph.conf.
TestGiraphConfiguration.C
(implements org.apache.giraph.conf.
TestGiraphConfiguration.If
)
org.apache.giraph.partition.
TestGiraphTransferRegulator
org.apache.giraph.block_app.framework.block.
TestIfBlock
org.apache.giraph.aggregators.
TestIntAggregators
org.apache.giraph.aggregators.matrix.dense.
TestIntDenseMatrix
org.apache.giraph.comm.messages.
TestIntFloatPrimitiveMessageStores
org.apache.giraph.aggregators.matrix.sparse.
TestIntSparseMatrix
org.apache.giraph.jython.
TestJythonBasic
org.apache.giraph.jython.
TestJythonComputation
org.apache.giraph.jython.
TestJythonWritableWrapper
org.apache.giraph.aggregators.
TestLongAggregators
org.apache.giraph.aggregators.matrix.dense.
TestLongDenseMatrix
org.apache.giraph.comm.messages.
TestLongDoublePrimitiveMessageStores
org.apache.giraph.aggregators.matrix.sparse.
TestLongSparseMatrix
org.apache.giraph.utils.hashing.
TestLongWritableFunnel
org.apache.giraph.reducers.impl.
TestLongXorReduce
org.apache.giraph.master.
TestMasterObserver
org.apache.giraph.comm.
TestMessageStores
org.apache.giraph.edge.
TestMultiGraphEdges
org.apache.giraph.edge.
TestMultiRandomAccessEdges
org.apache.giraph.edge.
TestNullValueEdges
org.apache.giraph.conf.
TestObjectCreation
org.apache.giraph.partition.
TestPartitionStores
org.apache.giraph.zk.
TestPredicateLock
org.apache.giraph.utils.
TestProgressableUtils
org.apache.giraph.utils.
TestReflectionUtils
org.apache.giraph.block_app.framework.block.
TestRepeatBlock
org.apache.giraph.block_app.framework.block.
TestRepeatUntilBlock
org.apache.giraph.edge.
TestStrictGraphEdges
org.apache.giraph.edge.
TestStrictRandomAccessEdges
org.apache.giraph.master.
TestSwitchClasses
org.apache.giraph.master.
TestSwitchClasses.MinimumMessageCombiner
(implements org.apache.giraph.combiner.
MessageCombiner
<I,M>)
org.apache.giraph.master.
TestSwitchClasses.StatusValue
(implements org.apache.hadoop.io.Writable)
org.apache.giraph.master.
TestSwitchClasses.SumMessageCombiner
(implements org.apache.giraph.combiner.
MessageCombiner
<I,M>)
org.apache.giraph.utils.
TestTestGraph
org.apache.giraph.utils.
TestTestGraph.SumLongVertexValueCombiner
(implements org.apache.giraph.graph.
VertexValueCombiner
<V>)
org.apache.giraph.utils.
TestUnsafeByteArrayOutputStream
org.apache.giraph.utils.
TestVarint
org.apache.giraph.graph.
TestVertexAndEdges
org.apache.giraph.graph.
TestByteValueVertex
org.apache.giraph.graph.
TestVertexAndEdges.TestOutEdges
(implements org.apache.giraph.edge.
OutEdges
<I,E>)
org.apache.giraph.io.
TestVertexEdgeInput.IntSumVertexValueCombiner
(implements org.apache.giraph.graph.
VertexValueCombiner
<V>)
org.apache.giraph.io.
TestVertexEdgeInput.TestVertexValueFactory
(implements org.apache.giraph.factories.
VertexValueFactory
<V>)
org.apache.giraph.block_app.framework.
TestWorkerMessages
org.apache.giraph.utils.
TestWritableUtils
org.apache.giraph.yarn.
TestYarnJob
(implements org.apache.zookeeper.Watcher)
org.apache.giraph.zk.
TestZooKeeperExt
(implements org.apache.zookeeper.Watcher)
org.apache.giraph.zk.
TestZooKeeperManager
org.apache.giraph.examples.
TryMultiIpcBindingPortsTest
Interface Hierarchy
org.apache.giraph.conf.
TestGiraphConfiguration.If
Enum Hierarchy
java.lang.
Object
java.lang.
Enum
<E> (implements java.lang.
Comparable
<T>, java.io.
Serializable
)
org.apache.giraph.generate.
GeneratePrimitiveClasses.PrimitiveType
Skip navigation links
Overview
Package
Class
Use
Tree
Deprecated
Index
Help
Prev
Next
Frames
No Frames
All Classes
Copyright © 2011-2020
The Apache Software Foundation
. All Rights Reserved.