- tearDown() - Method in class org.apache.giraph.BspCase
-
- tearDown() - Method in class org.apache.giraph.zk.TestZooKeeperExt
-
- test1() - Method in class org.apache.giraph.writable.kryo.DirectWritableSerializerCopyTest
-
- test2() - Method in class org.apache.giraph.writable.kryo.DirectWritableSerializerCopyTest
-
- testAddedSmalerValues() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testAddedSmallerValues() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testAddedSmallerValues() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- testAddToClasses() - Method in class org.apache.giraph.conf.TestGiraphConfiguration
-
- TestAdjacencyListTextVertexOutputFormat - Class in org.apache.giraph.io
-
- TestAdjacencyListTextVertexOutputFormat() - Constructor for class org.apache.giraph.io.TestAdjacencyListTextVertexOutputFormat
-
- TestAdjacencyListTextVertexOutputFormat.DummyComputation - Class in org.apache.giraph.io
-
Dummy class to allow ImmutableClassesGiraphConfiguration to be created.
- testAllMatchWithCombiner() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testAllMatchWithoutCombiner() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testAndAggregator() - Method in class org.apache.giraph.aggregators.TestBooleanAggregators
-
- testArraysAsList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testArraysAsListMultiRef() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testAsyncQueue() - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapperTest
-
- testAvoidOverflowWithZero() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testBasic() - Method in class org.apache.giraph.jython.TestJythonBasic
-
- TestBasicCollections - Class in org.apache.giraph.types
-
Test BasicSets and Basic2ObjectMaps
- TestBasicCollections() - Constructor for class org.apache.giraph.types.TestBasicCollections
-
- testBasicSet() - Method in class org.apache.giraph.types.TestCollections
-
- TestBigDataIO - Class in org.apache.giraph.utils.io
-
- TestBigDataIO() - Constructor for class org.apache.giraph.utils.io.TestBigDataIO
-
- testBlacklistedClasses() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- TestBooleanAggregators - Class in org.apache.giraph.aggregators
-
- TestBooleanAggregators() - Constructor for class org.apache.giraph.aggregators.TestBooleanAggregators
-
- testByteArrayMessagesPerVertexStore() - Method in class org.apache.giraph.comm.TestMessageStores
-
- TestByteValueVertex - Class in org.apache.giraph.graph
-
Tests whether ByteValueVertex works -- same test as for DefaultVertex
but with different factory method for vertices.
- TestByteValueVertex() - Constructor for class org.apache.giraph.graph.TestByteValueVertex
-
- testCachedValue() - Method in class org.apache.giraph.graph.TestByteValueVertex
-
- TestClass() - Constructor for class org.apache.giraph.writable.kryo.KryoSimpleTests.TestClass
-
- TestClassA(String, List, int) - Constructor for class org.apache.giraph.writable.kryo.KryoWritableTest.TestClassA
-
- TestClassA() - Constructor for class org.apache.giraph.writable.kryo.KryoWritableTest.TestClassA
-
- TestClassFromKryoWritable() - Constructor for class org.apache.giraph.writable.kryo.KryoSimpleTests.TestClassFromKryoWritable
-
- testClassFromWritable() - Method in class org.apache.giraph.writable.kryo.KryoSimpleTests
-
- TestClassFromWritable() - Constructor for class org.apache.giraph.writable.kryo.KryoSimpleTests.TestClassFromWritable
-
- TestCollections - Class in org.apache.giraph.types
-
Test basic collections
- TestCollections() - Constructor for class org.apache.giraph.types.TestCollections
-
- testCollectionsNCopiesList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testCollectionsNCopiesObjectList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- TestComputation() - Constructor for class org.apache.giraph.graph.TestVertexAndEdges.TestComputation
-
- TestComputation() - Constructor for class org.apache.giraph.partition.TestGiraphTransferRegulator.TestComputation
-
- TestComputationCheckEdgesType() - Constructor for class org.apache.giraph.io.TestVertexEdgeInput.TestComputationCheckEdgesType
-
- TestComputationCombinerTypes - Class in org.apache.giraph.master
-
Test type verification when switching computation and combiner types
- TestComputationCombinerTypes() - Constructor for class org.apache.giraph.master.TestComputationCombinerTypes
-
- TestComputationCombinerTypes.NoOpComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M1 extends org.apache.hadoop.io.Writable,M2 extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.master
-
- testConfigurable() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testConfiguration() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testConstructorNewInstance() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testContinue() - Method in class org.apache.giraph.io.TestJsonBase64Format
-
Start a job and finish after i supersteps, then begin a new job and
continue on more j supersteps.
- testCountEdges(Class<? extends MessageStoreFactory>) - Method in class org.apache.giraph.jython.TestJythonComputation
-
- testCountEdgesInMemoryMessageStoreFactory() - Method in class org.apache.giraph.jython.TestJythonComputation
-
- testCreateClass() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testCreateExt() - Method in class org.apache.giraph.zk.TestZooKeeperExt
-
- TestCreateSourceVertex - Class in org.apache.giraph.io
-
Test createSourceVertex configuration option
- TestCreateSourceVertex() - Constructor for class org.apache.giraph.io.TestCreateSourceVertex
-
- TestCreateSourceVertex.CreateEvenSourceVerticesCallback - Class in org.apache.giraph.io
-
Only allows to create vertices with even ids.
- testCustomCreateSourceVertex() - Method in class org.apache.giraph.io.TestCreateSourceVertex
-
- testDeleteExt() - Method in class org.apache.giraph.zk.TestZooKeeperExt
-
- testDifferentCombinerIdType() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testDifferentCombinerMessageType() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testDifferentEdgeDataTypes() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testDifferentIdTypes() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testDifferentInputEdgesClass() - Method in class org.apache.giraph.io.TestVertexEdgeInput
-
- testDifferentMessageTypes() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testDifferentSeparators() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
-
- testDifferentSeparators() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
-
- testDifferentVertexValueTypes() - Method in class org.apache.giraph.master.TestComputationCombinerTypes
-
- testDiskBackedPartitionStore() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testDiskBackedPartitionStoreAdaptiveOOC() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testDiskBackedPartitionStoreComputation() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testDiskBackedPartitionStoreMT() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testDiskBackedPartitionStoreMTStatic() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testDiskBackedPartitionStoreWithByteArrayComputation() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testDiskBackedPartitionStoreWithByteArrayPartition() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- TestDoubleAggregators - Class in org.apache.giraph.aggregators
-
- TestDoubleAggregators() - Constructor for class org.apache.giraph.aggregators.TestDoubleAggregators
-
- TestDoubleDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
-
- TestDoubleDenseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.dense.TestDoubleDenseMatrix
-
- TestDoubleSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
-
- TestDoubleSparseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.TestDoubleSparseMatrix
-
- testEdgeCombineWithByteArrayPartition() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testEdgeCombineWithSimplePartition() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testEdgeFilter() - Method in class org.apache.giraph.io.TestFilters
-
- testEdges() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testEdges() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- testEdges() - Method in class org.apache.giraph.edge.LongByteHashMapEdgesTest
-
- testEdges() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testEdges() - Method in class org.apache.giraph.edge.TestNullValueEdges
-
- testEdges() - Method in class org.apache.giraph.graph.TestVertexAndEdges
-
Test the provided
OutEdges
implementations for instantiation,
initialization, edge addition, and edge removal.
- testEdgesMustHaveValues() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
-
- testEdgesMustHaveValues() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
-
- testEdgesOnly() - Method in class org.apache.giraph.io.TestVertexEdgeInput
-
- testEdgesOnlyWithReverse() - Method in class org.apache.giraph.io.TestVertexEdgeInput
-
- testEdgeValues() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testEdgeValues() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- testEdgeValues() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testEmptyImmutableBiMap() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testEvent() - Method in class org.apache.giraph.zk.TestPredicateLock
-
Single threaded case where the event is signaled.
- testFailSafeOnPotentialOverflow() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testFastutil2ObjMap() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testFastutilFloatList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testFastutilLongList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testFastutilMap() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testFastutilSet() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- TestFilters - Class in org.apache.giraph.io
-
- TestFilters() - Constructor for class org.apache.giraph.io.TestFilters
-
- TestFilters.EdgeFilter - Class in org.apache.giraph.io
-
- TestFilters.VertexFilter - Class in org.apache.giraph.io
-
- TestFixedCapacityIntByteMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityIntByteMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityIntByteMinHeap
-
- TestFixedCapacityIntDoubleMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityIntDoubleMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityIntDoubleMinHeap
-
- TestFixedCapacityIntFloatMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityIntFloatMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityIntFloatMinHeap
-
- TestFixedCapacityIntIntMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityIntIntMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityIntIntMinHeap
-
- TestFixedCapacityIntLongMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityIntLongMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityIntLongMinHeap
-
- TestFixedCapacityLongByteMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityLongByteMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityLongByteMinHeap
-
- TestFixedCapacityLongDoubleMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityLongDoubleMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityLongDoubleMinHeap
-
- TestFixedCapacityLongFloatMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityLongFloatMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityLongFloatMinHeap
-
- TestFixedCapacityLongIntMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityLongIntMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityLongIntMinHeap
-
- TestFixedCapacityLongLongMinHeap - Class in org.apache.giraph.types.heaps
-
- TestFixedCapacityLongLongMinHeap() - Constructor for class org.apache.giraph.types.heaps.TestFixedCapacityLongLongMinHeap
-
- TestFloatAggregators - Class in org.apache.giraph.aggregators
-
- TestFloatAggregators() - Constructor for class org.apache.giraph.aggregators.TestFloatAggregators
-
- TestFloatDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
-
- TestFloatDenseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.dense.TestFloatDenseMatrix
-
- TestFloatSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
-
- TestFloatSparseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.TestFloatSparseMatrix
-
- testFloatWritable2Object() - Method in class org.apache.giraph.types.TestBasicCollections
-
- testGenerateNameAndParseIt() - Method in class org.apache.giraph.zk.ComputationDoneNameTest
-
- testGetBasePath() - Method in class org.apache.giraph.zk.TestZooKeeperManager
-
- testGetChildrenExt() - Method in class org.apache.giraph.zk.TestZooKeeperExt
-
- testGetsCalled() - Method in class org.apache.giraph.master.TestMasterObserver
-
- TestGiraphConfiguration - Class in org.apache.giraph.conf
-
- TestGiraphConfiguration() - Constructor for class org.apache.giraph.conf.TestGiraphConfiguration
-
- TestGiraphConfiguration.A - Class in org.apache.giraph.conf
-
- TestGiraphConfiguration.B - Class in org.apache.giraph.conf
-
- TestGiraphConfiguration.C - Class in org.apache.giraph.conf
-
- TestGiraphConfiguration.If - Interface in org.apache.giraph.conf
-
- TestGiraphTransferRegulator - Class in org.apache.giraph.partition
-
Test the GiraphTransferRegulator.
- TestGiraphTransferRegulator() - Constructor for class org.apache.giraph.partition.TestGiraphTransferRegulator
-
- testGiraphTransferRegulator() - Method in class org.apache.giraph.partition.TestGiraphTransferRegulator
-
- TestGiraphTransferRegulator.TestComputation - Class in org.apache.giraph.partition
-
Dummy vertex.
- testHappyPath() - Method in class org.apache.giraph.io.TestIdWithValueTextOutputFormat
-
- testHappyPath() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
-
- testHappyPath() - Method in class org.apache.giraph.io.TestSrcIdDstIdEdgeValueTextOutputFormat
-
- testHappyPath() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityIntByteMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityIntDoubleMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityIntFloatMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityIntIntMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityIntLongMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityLongByteMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityLongDoubleMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityLongFloatMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityLongIntMinHeap
-
- testHeap() - Method in class org.apache.giraph.types.heaps.TestFixedCapacityLongLongMinHeap
-
- TestIdWithValueTextOutputFormat - Class in org.apache.giraph.io
-
- TestIdWithValueTextOutputFormat() - Constructor for class org.apache.giraph.io.TestIdWithValueTextOutputFormat
-
- TestIdWithValueTextOutputFormat.DummyComputation - Class in org.apache.giraph.io
-
Dummy class to allow ImmutableClassesGiraphConfiguration to be created.
- testImmutableBiMap() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testImmutableClassesGiraphConfigurationNewInstance() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testImmutableList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testImmutableMapSerialization() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testImmutableMapSinglePairSerialization() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testIndexMustHaveValue() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
-
- testIndexMustHaveValue() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
-
- testInferTypeParams() - Method in class org.apache.giraph.utils.TestReflectionUtils
-
- testInferWithGenerics() - Method in class org.apache.giraph.utils.TestReflectionUtils
-
- testInitialize() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testInitialize() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- TestIntAggregators - Class in org.apache.giraph.aggregators
-
- TestIntAggregators() - Constructor for class org.apache.giraph.aggregators.TestIntAggregators
-
- testIntArray() - Method in class org.apache.giraph.utils.TestWritableUtils
-
- testIntByteArrayMessageStore() - Method in class org.apache.giraph.comm.messages.TestIntFloatPrimitiveMessageStores
-
- testIntByteArrayMessageStoreWithMessageEncoding() - Method in class org.apache.giraph.comm.messages.TestIntFloatPrimitiveMessageStores
-
- TestIntDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
-
- TestIntDenseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.dense.TestIntDenseMatrix
-
- testIntFloatMessageStore() - Method in class org.apache.giraph.comm.messages.TestIntFloatPrimitiveMessageStores
-
- TestIntFloatPrimitiveMessageStores - Class in org.apache.giraph.comm.messages
-
- TestIntFloatPrimitiveMessageStores() - Constructor for class org.apache.giraph.comm.messages.TestIntFloatPrimitiveMessageStores
-
- TestIntSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
-
- TestIntSparseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.TestIntSparseMatrix
-
- testIteratorsConcat() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- TestJsonBase64Format - Class in org.apache.giraph.io
-
Test out the JsonBase64 format.
- TestJsonBase64Format() - Constructor for class org.apache.giraph.io.TestJsonBase64Format
-
Constructor.
- TestJythonBasic - Class in org.apache.giraph.jython
-
- TestJythonBasic() - Constructor for class org.apache.giraph.jython.TestJythonBasic
-
- TestJythonComputation - Class in org.apache.giraph.jython
-
- TestJythonComputation() - Constructor for class org.apache.giraph.jython.TestJythonComputation
-
- TestJythonWritableWrapper - Class in org.apache.giraph.jython
-
- TestJythonWritableWrapper() - Constructor for class org.apache.giraph.jython.TestJythonWritableWrapper
-
- testKryoImmutableMap() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- testKryoSimpleWrapper() - Method in class org.apache.giraph.writable.kryo.KryoSimpleTests
-
- testLargeBasicList() - Method in class org.apache.giraph.types.TestCollections
-
- testLargeBasicSet() - Method in class org.apache.giraph.types.TestCollections
-
- testLargeByteArrays() - Method in class org.apache.giraph.utils.io.TestBigDataIO
-
- testLineSanitizer() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
-
- testListSerialization() - Method in class org.apache.giraph.utils.TestWritableUtils
-
Tests readList and writeList functions in writable utils.
- TestLongAggregators - Class in org.apache.giraph.aggregators
-
- TestLongAggregators() - Constructor for class org.apache.giraph.aggregators.TestLongAggregators
-
- testLongArray() - Method in class org.apache.giraph.utils.TestWritableUtils
-
- testLongByteArrayMessageStore() - Method in class org.apache.giraph.comm.messages.TestLongDoublePrimitiveMessageStores
-
- TestLongDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
-
- TestLongDenseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.dense.TestLongDenseMatrix
-
- TestLongDoubleDoubleAdjacencyListVertexInputFormat - Class in org.apache.giraph.io
-
- TestLongDoubleDoubleAdjacencyListVertexInputFormat() - Constructor for class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
-
- TestLongDoubleDoubleAdjacencyListVertexInputFormat.DummyComputation - Class in org.apache.giraph.io
-
- testLongDoubleMessageStore() - Method in class org.apache.giraph.comm.messages.TestLongDoublePrimitiveMessageStores
-
- TestLongDoublePrimitiveMessageStores - Class in org.apache.giraph.comm.messages
-
- TestLongDoublePrimitiveMessageStores() - Constructor for class org.apache.giraph.comm.messages.TestLongDoublePrimitiveMessageStores
-
- testLongFastutilListProfile() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testLongKryoWritable() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- testLongListKryoWritable() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- testLongListWritable() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- testLongRangePartitionerFactory() - Method in class org.apache.giraph.partition.SimpleRangePartitionFactoryTest
-
- TestLongSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
-
- TestLongSparseMatrix() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.TestLongSparseMatrix
-
- testLongWritable() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- testLongWritable2Object() - Method in class org.apache.giraph.types.TestBasicCollections
-
- testLongWritable2ObjectConcurrent() - Method in class org.apache.giraph.types.TestBasicCollections
-
- TestLongWritableFunnel - Class in org.apache.giraph.utils.hashing
-
- TestLongWritableFunnel() - Constructor for class org.apache.giraph.utils.hashing.TestLongWritableFunnel
-
- TestLongXorReduce - Class in org.apache.giraph.reducers.impl
-
- TestLongXorReduce() - Constructor for class org.apache.giraph.reducers.impl.TestLongXorReduce
-
- TestMasterObserver - Class in org.apache.giraph.master
-
- TestMasterObserver() - Constructor for class org.apache.giraph.master.TestMasterObserver
-
- TestMasterObserver.InputFormat - Class in org.apache.giraph.master
-
- TestMasterObserver.Obs - Class in org.apache.giraph.master
-
- TestMasterObserver.SimpleComputation - Class in org.apache.giraph.master
-
- testMaxAggregator() - Method in class org.apache.giraph.aggregators.TestDoubleAggregators
-
- testMaxAggregator() - Method in class org.apache.giraph.aggregators.TestFloatAggregators
-
- testMaxAggregator() - Method in class org.apache.giraph.aggregators.TestIntAggregators
-
- testMaxAggregator() - Method in class org.apache.giraph.aggregators.TestLongAggregators
-
- TestMessageStores - Class in org.apache.giraph.comm
-
Test for different types of message stores
- TestMessageStores() - Constructor for class org.apache.giraph.comm.TestMessageStores
-
- testMinAggregator() - Method in class org.apache.giraph.aggregators.TestDoubleAggregators
-
- testMinAggregator() - Method in class org.apache.giraph.aggregators.TestFloatAggregators
-
- testMinAggregator() - Method in class org.apache.giraph.aggregators.TestIntAggregators
-
- testMinAggregator() - Method in class org.apache.giraph.aggregators.TestLongAggregators
-
- testMixedVertexEdgeFormat() - Method in class org.apache.giraph.io.TestVertexEdgeInput
-
- testMixedVertexValueEdgeFormat() - Method in class org.apache.giraph.io.TestVertexEdgeInput
-
- TestMultiGraphEdges - Class in org.apache.giraph.edge
-
Tests
OutEdges
implementations that allow parallel edges.
- TestMultiGraphEdges() - Constructor for class org.apache.giraph.edge.TestMultiGraphEdges
-
- TestMultiRandomAccessEdges - Class in org.apache.giraph.edge
-
- TestMultiRandomAccessEdges() - Constructor for class org.apache.giraph.edge.TestMultiRandomAccessEdges
-
- testMutateEdges() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testMutateEdges() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- testMutateEdges() - Method in class org.apache.giraph.edge.LongByteHashMapEdgesTest
-
- testMutateEdges() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testMutateEdges() - Method in class org.apache.giraph.edge.TestNullValueEdges
-
- testMutateEdges() - Method in class org.apache.giraph.graph.TestVertexAndEdges
-
- testNativeCreateClass() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testNegativeCreateSourceVertex() - Method in class org.apache.giraph.io.TestCreateSourceVertex
-
- testNestedKryoWritable() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- testNewInstance() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testNull() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- TestNullValueEdges - Class in org.apache.giraph.edge
-
Tests
OutEdges
implementations with null edge values.
- TestNullValueEdges() - Constructor for class org.apache.giraph.edge.TestNullValueEdges
-
- TestObjectCreation - Class in org.apache.giraph.conf
-
- TestObjectCreation() - Constructor for class org.apache.giraph.conf.TestObjectCreation
-
- testOrAggregator() - Method in class org.apache.giraph.aggregators.TestBooleanAggregators
-
- TestOutEdges() - Constructor for class org.apache.giraph.graph.TestVertexAndEdges.TestOutEdges
-
- TestOutEdgesFilterEven() - Constructor for class org.apache.giraph.io.TestVertexEdgeInput.TestOutEdgesFilterEven
-
- testOutOfCoreMessages() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- TestOutOfCoreMessagesComputation() - Constructor for class org.apache.giraph.partition.TestPartitionStores.TestOutOfCoreMessagesComputation
-
- testOverwriteAggregator() - Method in class org.apache.giraph.aggregators.TestBooleanAggregators
-
- testOverwriteAggregator() - Method in class org.apache.giraph.aggregators.TestDoubleAggregators
-
- testOverwriteAggregator() - Method in class org.apache.giraph.aggregators.TestFloatAggregators
-
- testOverwriteAggregator() - Method in class org.apache.giraph.aggregators.TestIntAggregators
-
- testOverwriteAggregator() - Method in class org.apache.giraph.aggregators.TestLongAggregators
-
- testPackagePath() - Method in class org.apache.giraph.utils.TestReflectionUtils
-
- testParallelEdges() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testParallelEdges() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- testParallelEdges() - Method in class org.apache.giraph.edge.LongByteHashMapEdgesTest
-
This implementation does not allow parallel edges.
- testParallelEdges() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testParallelEdges() - Method in class org.apache.giraph.edge.TestMultiGraphEdges
-
Ensures that all multigraph
OutEdges
implementations allow
parallel edges.
- testParallelEdges() - Method in class org.apache.giraph.edge.TestMultiRandomAccessEdges
-
- testParallelEdges() - Method in class org.apache.giraph.edge.TestStrictGraphEdges
-
Ensures that all strict graph
OutEdges
implementations
disallow parallel edges.
- testParallelEdges() - Method in class org.apache.giraph.edge.TestStrictRandomAccessEdges
-
- TestPartitionStores - Class in org.apache.giraph.partition
-
Test case for partition stores.
- TestPartitionStores() - Constructor for class org.apache.giraph.partition.TestPartitionStores
-
- TestPartitionStores.EmptyComputation - Class in org.apache.giraph.partition
-
Test compute method that sends each edge a notification of its parents.
- TestPartitionStores.MyComputation - Class in org.apache.giraph.partition
-
- TestPartitionStores.TestOutOfCoreMessagesComputation - Class in org.apache.giraph.partition
-
- testPositiveAndNegativeEdges() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testPositiveCreateSourceVertex() - Method in class org.apache.giraph.io.TestCreateSourceVertex
-
- TestPredicateLock - Class in org.apache.giraph.zk
-
Ensure that PredicateLock objects work correctly.
- TestPredicateLock() - Constructor for class org.apache.giraph.zk.TestPredicateLock
-
- testProductAggregator() - Method in class org.apache.giraph.aggregators.TestDoubleAggregators
-
- testProductAggregator() - Method in class org.apache.giraph.aggregators.TestFloatAggregators
-
- testProductAggregator() - Method in class org.apache.giraph.aggregators.TestIntAggregators
-
- testProductAggregator() - Method in class org.apache.giraph.aggregators.TestLongAggregators
-
- TestProgressableUtils - Class in org.apache.giraph.utils
-
Test ProgressableUtils
- TestProgressableUtils() - Constructor for class org.apache.giraph.utils.TestProgressableUtils
-
- testProgressableUtils() - Method in class org.apache.giraph.utils.TestProgressableUtils
-
- testPureYarnJob() - Method in class org.apache.giraph.yarn.TestYarnJob
-
- testRandom() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testReadWrite(PartitionStore<IntWritable, IntWritable, NullWritable>, ImmutableClassesGiraphConfiguration<IntWritable, IntWritable, NullWritable>) - Method in class org.apache.giraph.partition.TestPartitionStores
-
Test reading/writing to/from a partition store
- testRecursive() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testRecursiveKryoWritable() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- TestReflectionUtils - Class in org.apache.giraph.utils
-
- TestReflectionUtils() - Constructor for class org.apache.giraph.utils.TestReflectionUtils
-
- testReflectionUtilsNewInstance() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testReverseIdAndValue() - Method in class org.apache.giraph.io.TestIdWithValueTextOutputFormat
-
- testReverseIdAndValue() - Method in class org.apache.giraph.io.TestSrcIdDstIdEdgeValueTextOutputFormat
-
- testSerialization() - Method in class org.apache.giraph.edge.IdAndNullArrayEdgesTest
-
- testSerialization() - Method in class org.apache.giraph.edge.IdAndValueArrayEdgesTest
-
- testSerialization() - Method in class org.apache.giraph.edge.LongByteHashMapEdgesTest
-
- testSerialization() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdgesTest
-
- testSerialize() - Method in class org.apache.giraph.graph.TestVertexAndEdges
-
- testSetClasses() - Method in class org.apache.giraph.conf.TestGiraphConfiguration
-
- testSimplePartitionStore() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- testSingletonImmutableBiMapSerialization() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testSmall() - Method in class org.apache.giraph.utils.TestVarint
-
- TestSrcIdDstIdEdgeValueTextOutputFormat - Class in org.apache.giraph.io
-
- TestSrcIdDstIdEdgeValueTextOutputFormat() - Constructor for class org.apache.giraph.io.TestSrcIdDstIdEdgeValueTextOutputFormat
-
- TestSrcIdDstIdEdgeValueTextOutputFormat.DummyComputation - Class in org.apache.giraph.io
-
Dummy class to allow ImmutableClassesGiraphConfiguration to be created.
- TestStrictGraphEdges - Class in org.apache.giraph.edge
-
Tests
OutEdges
implementations that disallow parallel edges.
- TestStrictGraphEdges() - Constructor for class org.apache.giraph.edge.TestStrictGraphEdges
-
- TestStrictRandomAccessEdges - Class in org.apache.giraph.edge
-
- TestStrictRandomAccessEdges() - Constructor for class org.apache.giraph.edge.TestStrictRandomAccessEdges
-
- testSumAggregator() - Method in class org.apache.giraph.aggregators.TestDoubleAggregators
-
- testSumAggregator() - Method in class org.apache.giraph.aggregators.TestFloatAggregators
-
- testSumAggregator() - Method in class org.apache.giraph.aggregators.TestIntAggregators
-
- testSumAggregator() - Method in class org.apache.giraph.aggregators.TestLongAggregators
-
- TestSwitchClasses - Class in org.apache.giraph.master
-
Test switching Computation and MessageCombiner class during application
- TestSwitchClasses() - Constructor for class org.apache.giraph.master.TestSwitchClasses
-
- TestSwitchClasses.Computation1 - Class in org.apache.giraph.master
-
- TestSwitchClasses.Computation2 - Class in org.apache.giraph.master
-
- TestSwitchClasses.Computation3 - Class in org.apache.giraph.master
-
- TestSwitchClasses.MinimumMessageCombiner - Class in org.apache.giraph.master
-
- TestSwitchClasses.StatusValue - Class in org.apache.giraph.master
-
- TestSwitchClasses.SumMessageCombiner - Class in org.apache.giraph.master
-
- TestSwitchClasses.SwitchingClassesMasterCompute - Class in org.apache.giraph.master
-
- testSwitchingClasses() - Method in class org.apache.giraph.master.TestSwitchClasses
-
- testSyncNewInstance() - Method in class org.apache.giraph.conf.TestObjectCreation
-
- testTestClassA() - Method in class org.apache.giraph.writable.kryo.KryoWritableTest
-
- TestTestGraph - Class in org.apache.giraph.utils
-
Test TestGraph
- TestTestGraph() - Constructor for class org.apache.giraph.utils.TestTestGraph
-
- testTestGraph() - Method in class org.apache.giraph.utils.TestTestGraph
-
- TestTestGraph.SumLongVertexValueCombiner - Class in org.apache.giraph.utils
-
Vertex value combiner that sums up long vertex values
- TestTextDoubleDoubleAdjacencyListVertexInputFormat - Class in org.apache.giraph.io
-
- TestTextDoubleDoubleAdjacencyListVertexInputFormat() - Constructor for class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
-
- TestTextDoubleDoubleAdjacencyListVertexInputFormat.DummyComputation - Class in org.apache.giraph.io
-
- testUnmodifiableIterator() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- TestUnsafeByteArrayOutputStream - Class in org.apache.giraph.utils
-
- TestUnsafeByteArrayOutputStream() - Constructor for class org.apache.giraph.utils.TestUnsafeByteArrayOutputStream
-
- testUnsafePartitionSerializationClass() - Method in class org.apache.giraph.partition.TestPartitionStores
-
- TestVarint - Class in org.apache.giraph.utils
-
- TestVarint() - Constructor for class org.apache.giraph.utils.TestVarint
-
- testVarIntLarge() - Method in class org.apache.giraph.utils.TestVarint
-
- testVarIntSmall() - Method in class org.apache.giraph.utils.TestVarint
-
- testVarLongLarge() - Method in class org.apache.giraph.utils.TestVarint
-
- testVarLongSmall() - Method in class org.apache.giraph.utils.TestVarint
-
- testVars() - Method in class org.apache.giraph.utils.TestVarint
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.dense.TestDoubleDenseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.dense.TestFloatDenseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.dense.TestIntDenseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.dense.TestLongDenseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestDoubleSparseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestFloatSparseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestIntSparseMatrix
-
- testVectorAdd() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestLongSparseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.dense.TestDoubleDenseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.dense.TestFloatDenseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.dense.TestIntDenseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.dense.TestLongDenseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestDoubleSparseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestFloatSparseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestIntSparseMatrix
-
- testVectorSerialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.TestLongSparseMatrix
-
- testVectorSerializeSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestDoubleDenseMatrix
-
- testVectorSerializeSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestFloatDenseMatrix
-
- testVectorSerializeSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestIntDenseMatrix
-
- testVectorSerializeSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestLongDenseMatrix
-
- testVectorSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestDoubleDenseMatrix
-
- testVectorSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestFloatDenseMatrix
-
- testVectorSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestIntDenseMatrix
-
- testVectorSingleton() - Method in class org.apache.giraph.aggregators.matrix.dense.TestLongDenseMatrix
-
- TestVertexAndEdges - Class in org.apache.giraph.graph
-
- TestVertexAndEdges() - Constructor for class org.apache.giraph.graph.TestVertexAndEdges
-
- TestVertexAndEdges.TestComputation - Class in org.apache.giraph.graph
-
Dummy concrete vertex.
- TestVertexAndEdges.TestOutEdges - Class in org.apache.giraph.graph
-
A basic
OutEdges
implementation that doesn't provide any
special functionality.
- TestVertexEdgeInput - Class in org.apache.giraph.io
-
A test case to ensure that loading a graph from vertices and edges works as
expected.
- TestVertexEdgeInput() - Constructor for class org.apache.giraph.io.TestVertexEdgeInput
-
- TestVertexEdgeInput.IntSumVertexValueCombiner - Class in org.apache.giraph.io
-
Simple vertex value combiner that sums up the vertex values.
- TestVertexEdgeInput.TestComputationCheckEdgesType - Class in org.apache.giraph.io
-
- TestVertexEdgeInput.TestOutEdgesFilterEven - Class in org.apache.giraph.io
-
- TestVertexEdgeInput.TestVertexValueFactory - Class in org.apache.giraph.io
-
- testVertexFilter() - Method in class org.apache.giraph.io.TestFilters
-
- testVertexIdAndValue() - Method in class org.apache.giraph.graph.TestVertexAndEdges
-
Test vertex instantiation, initialization, and updating the vertex value.
- testVertexReceiver() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testVertexValueCombiner() - Method in class org.apache.giraph.io.TestVertexEdgeInput
-
- TestVertexValueFactory() - Constructor for class org.apache.giraph.io.TestVertexEdgeInput.TestVertexValueFactory
-
- testVertexWithEdges() - Method in class org.apache.giraph.io.TestAdjacencyListTextVertexOutputFormat
-
- testVertexWithNoEdges() - Method in class org.apache.giraph.io.TestAdjacencyListTextVertexOutputFormat
-
- testWaitForever() - Method in class org.apache.giraph.zk.TestPredicateLock
-
- testWaitMsecs() - Method in class org.apache.giraph.zk.TestPredicateLock
-
Thread signaled test to make sure the the event is signaled correctly
- testWaitMsecsNoEvent() - Method in class org.apache.giraph.zk.TestPredicateLock
-
SMake sure the the event is not signaled.
- testWFastutilLongList() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapperTest
-
- testWithDifferentDelimiter() - Method in class org.apache.giraph.io.TestAdjacencyListTextVertexOutputFormat
-
- testWithDifferentDelimiter() - Method in class org.apache.giraph.io.TestIdWithValueTextOutputFormat
-
- testWithDifferentDelimiter() - Method in class org.apache.giraph.io.TestSrcIdDstIdEdgeValueTextOutputFormat
-
- testWrap() - Method in class org.apache.giraph.jython.TestJythonWritableWrapper
-
- TestWritableUtils - Class in org.apache.giraph.utils
-
Test case for WritableUtils.
- TestWritableUtils() - Constructor for class org.apache.giraph.utils.TestWritableUtils
-
- testWriteBytes() - Method in class org.apache.giraph.utils.TestUnsafeByteArrayOutputStream
-
- testWriteChars() - Method in class org.apache.giraph.utils.TestUnsafeByteArrayOutputStream
-
- testWriteLongUTF() - Method in class org.apache.giraph.utils.TestUnsafeByteArrayOutputStream
-
- testWritesALong() - Method in class org.apache.giraph.utils.hashing.TestLongWritableFunnel
-
- testWriteUTF() - Method in class org.apache.giraph.utils.TestUnsafeByteArrayOutputStream
-
- testXor() - Method in class org.apache.giraph.reducers.impl.TestLongXorReduce
-
- TestYarnJob - Class in org.apache.giraph.yarn
-
Tests the Giraph on YARN workflow.
- TestYarnJob() - Constructor for class org.apache.giraph.yarn.TestYarnJob
-
- testZero() - Method in class org.apache.giraph.reducers.impl.TestLongXorReduce
-
- TestZooKeeperExt - Class in org.apache.giraph.zk
-
Test the ZooKeeperExt class.
- TestZooKeeperExt() - Constructor for class org.apache.giraph.zk.TestZooKeeperExt
-
- TestZooKeeperManager - Class in org.apache.giraph.zk
-
- TestZooKeeperManager() - Constructor for class org.apache.giraph.zk.TestZooKeeperManager
-
- toString() - Method in class org.apache.giraph.master.TestSwitchClasses.StatusValue
-