A B C F G I M O P R S T V Z

A

add256kIntegers() - Method in class org.apache.giraph.comm.IncreasingBitSetTest
 
add256kIntegersAlternate() - Method in class org.apache.giraph.comm.IncreasingBitSetTest
 
add256kIntegersOutOfOrder() - Method in class org.apache.giraph.comm.IncreasingBitSetTest
 
alreadyProcessedRequest() - Method in class org.apache.giraph.comm.RequestFailureTest
 
assertValid(Vertex<I, V, E, M>, Vertex<I, V, E, M>) - Static method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
assertValidVertex(Configuration, GraphState<I, V, E, M>, Vertex<I, V, E, M>, I, V, Edge<I, E>...) - Static method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 

B

BASE_PATH - Static variable in class org.apache.giraph.TestZooKeeperExt
 
BspCase - Class in org.apache.giraph
Extended TestCase for making setting up Bsp testing.
BspCase(String) - Constructor for class org.apache.giraph.BspCase
Create the test case

C

cleanUp() - Method in class org.apache.giraph.comm.TestMessageStores
 
ComparisonUtilsTest - Class in org.apache.giraph.utils
 
ComparisonUtilsTest() - Constructor for class org.apache.giraph.utils.ComparisonUtilsTest
 
compute(Iterable<IntWritable>) - Method in class org.apache.giraph.comm.RequestFailureTest.TestVertex
 
compute(Iterable<IntWritable>) - Method in class org.apache.giraph.comm.RequestTest.TestVertex
 
compute(Iterable<BooleanWritable>) - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex
 
compute(Iterable<BooleanWritable>) - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex
 
ConnectedComponentsVertexTest - Class in org.apache.giraph.examples
Tests for ConnectedComponentsVertex
ConnectedComponentsVertexTest() - Constructor for class org.apache.giraph.examples.ConnectedComponentsVertexTest
 
ConnectionTest - Class in org.apache.giraph.comm
Test the netty connections
ConnectionTest() - Constructor for class org.apache.giraph.comm.ConnectionTest
 
connectOneClientToThreeServers() - Method in class org.apache.giraph.comm.ConnectionTest
Test connecting one client to three servers.
connectSingleClientServer() - Method in class org.apache.giraph.comm.ConnectionTest
Test connecting a single client to a single server.
connectThreeClientsToOneServer() - Method in class org.apache.giraph.comm.ConnectionTest
Test connecting three clients to one server.

F

FIRST_PATH - Static variable in class org.apache.giraph.TestZooKeeperExt
 

G

getCallingMethodName() - Static method in class org.apache.giraph.BspCase
 
getCommunications() - Method in class org.apache.giraph.utils.MockUtils.MockedEnvironment
the injected worker communications
getConfiguration() - Method in class org.apache.giraph.utils.MockUtils.MockedEnvironment
the injected hadoop configuration
getContext() - Method in class org.apache.giraph.utils.MockUtils.MockedEnvironment
the injected mapper context
getGraphState() - Method in class org.apache.giraph.utils.MockUtils.MockedEnvironment
the injected graph state
getNumResults(Configuration, Path) - Method in class org.apache.giraph.BspCase
Read all parts- files in the output and count their lines.
getNumWorkers() - Method in class org.apache.giraph.BspCase
Get the number of workers used in the BSP application
getSinglePartFileStatus(Configuration, Path) - Static method in class org.apache.giraph.BspCase
Get the single part file status and make sure there is only one part
getTempPath(String) - Method in class org.apache.giraph.BspCase
Create a temporary path
getZooKeeperList() - Method in class org.apache.giraph.BspCase
Get the ZooKeeper list

I

IncreasingBitSetTest - Class in org.apache.giraph.comm
Test IncreasingBitSetTest
IncreasingBitSetTest() - Constructor for class org.apache.giraph.comm.IncreasingBitSetTest
 

M

MinimumIntCombinerTest - Class in org.apache.giraph.examples
 
MinimumIntCombinerTest() - Constructor for class org.apache.giraph.examples.MinimumIntCombinerTest
 
mockServiceGetVertexPartitionOwner(int) - Static method in class org.apache.giraph.utils.MockUtils
 
MockUtils - Class in org.apache.giraph.utils
simplify mocking for unit testing vertices
MockUtils.MockedEnvironment<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
mocks and holds "environment objects" that are injected into a vertex
MockUtils.MockedEnvironment() - Constructor for class org.apache.giraph.utils.MockUtils.MockedEnvironment
 

O

org.apache.giraph - package org.apache.giraph
 
org.apache.giraph.aggregators - package org.apache.giraph.aggregators
 
org.apache.giraph.comm - package org.apache.giraph.comm
 
org.apache.giraph.examples - package org.apache.giraph.examples
 
org.apache.giraph.graph - package org.apache.giraph.graph
 
org.apache.giraph.graph.partition - package org.apache.giraph.graph.partition
 
org.apache.giraph.io - package org.apache.giraph.io
 
org.apache.giraph.utils - package org.apache.giraph.utils
 

P

prepare() - Method in class org.apache.giraph.comm.TestMessageStores
 
prepareJob(String, Class<?>, Class<?>) - Method in class org.apache.giraph.BspCase
Prepare a GiraphJob for test purposes
prepareJob(String, Class<?>, Class<?>, Class<?>, Path) - Method in class org.apache.giraph.BspCase
Prepare a GiraphJob for test purposes
prepareJob(String, Class<?>, Class<?>, Class<?>, Class<?>, Path) - Method in class org.apache.giraph.BspCase
Prepare a GiraphJob for test purposes
prepareJob(String, Class<?>, Class<?>, Class<?>, Class<?>, Class<?>, Path) - Method in class org.apache.giraph.BspCase
Prepare a GiraphJob for test purposes
prepareVertex(Vertex<I, V, E, M>, long, I, V, boolean) - Static method in class org.apache.giraph.utils.MockUtils
prepare a vertex for use in a unit test by setting its internal state and injecting mocked dependencies,
process(WatchedEvent) - Method in class org.apache.giraph.BspCase
 
process(WatchedEvent) - Method in class org.apache.giraph.TestZooKeeperExt
 

R

removeAndSetOutput(GiraphJob, Path) - Static method in class org.apache.giraph.BspCase
Helper method to remove an old output directory if it exists, and set the output path for any VertexOutputFormat that uses FileOutputFormat.
RequestFailureTest - Class in org.apache.giraph.comm
Test all the netty failure scenarios
RequestFailureTest() - Constructor for class org.apache.giraph.comm.RequestFailureTest
 
RequestFailureTest.TestVertex - Class in org.apache.giraph.comm
Only for testing.
RequestFailureTest.TestVertex() - Constructor for class org.apache.giraph.comm.RequestFailureTest.TestVertex
 
RequestTest - Class in org.apache.giraph.comm
Test all the different netty requests.
RequestTest() - Constructor for class org.apache.giraph.comm.RequestTest
 
RequestTest.TestVertex - Class in org.apache.giraph.comm
Only for testing.
RequestTest.TestVertex() - Constructor for class org.apache.giraph.comm.RequestTest.TestVertex
 
resendRequest() - Method in class org.apache.giraph.comm.RequestFailureTest
 
RPCCommunicationsTest - Class in org.apache.giraph.comm
 
RPCCommunicationsTest() - Constructor for class org.apache.giraph.comm.RPCCommunicationsTest
 

S

send2Requests() - Method in class org.apache.giraph.comm.RequestFailureTest
 
sendPartitionMessagesRequest() - Method in class org.apache.giraph.comm.RequestTest
 
sendPartitionMutationsRequest() - Method in class org.apache.giraph.comm.RequestTest
 
sendVertexPartition() - Method in class org.apache.giraph.comm.RequestTest
 
setGraphState(Vertex, GraphState) - Static method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
setUp() - Method in class org.apache.giraph.BspCase
 
setUp() - Method in class org.apache.giraph.comm.RequestFailureTest
 
setUp() - Method in class org.apache.giraph.comm.RequestTest
 
setUp() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
setUp() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
 
setUp() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
setUp() - Method in class org.apache.giraph.TestPredicateLock
 
setUp() - Method in class org.apache.giraph.TestZooKeeperExt
 
setupConfiguration(GiraphJob) - Method in class org.apache.giraph.BspCase
Adjust the configuration to the basic test case
SimpleShortestPathsVertexTest - Class in org.apache.giraph.examples
Contains a simple unit test for SimpleShortestPathsVertex
SimpleShortestPathsVertexTest() - Constructor for class org.apache.giraph.examples.SimpleShortestPathsVertexTest
 
SimpleTriangleClosingVertexTest - Class in org.apache.giraph.examples
Contains a simple unit test for SimpleTriangleClosingVertex
SimpleTriangleClosingVertexTest() - Constructor for class org.apache.giraph.examples.SimpleTriangleClosingVertexTest
 

T

tearDown() - Method in class org.apache.giraph.BspCase
 
tearDown() - Method in class org.apache.giraph.TestZooKeeperExt
 
testAddRemoveEdges() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
TestAdjacencyListTextVertexOutputFormat - Class in org.apache.giraph.io
 
TestAdjacencyListTextVertexOutputFormat() - Constructor for class org.apache.giraph.io.TestAdjacencyListTextVertexOutputFormat
 
TestAggregatorsHandling - Class in org.apache.giraph
Tests if aggregators are handled on a proper way during supersteps
TestAggregatorsHandling() - Constructor for class org.apache.giraph.TestAggregatorsHandling
 
testAggregatorsHandling() - Method in class org.apache.giraph.TestAggregatorsHandling
 
testAndAggregator() - Method in class org.apache.giraph.aggregators.TestBooleanAggregators
 
TestAutoCheckpoint - Class in org.apache.giraph
Unit test for automated checkpoint restarting
TestAutoCheckpoint() - Constructor for class org.apache.giraph.TestAutoCheckpoint
 
TestBooleanAggregators - Class in org.apache.giraph.aggregators
 
TestBooleanAggregators() - Constructor for class org.apache.giraph.aggregators.TestBooleanAggregators
 
TestBspBasic - Class in org.apache.giraph
Unit test for many simple BSP applications.
TestBspBasic() - Constructor for class org.apache.giraph.TestBspBasic
 
testBspCheckpoint() - Method in class org.apache.giraph.TestManualCheckpoint
Run a sample BSP job locally and test checkpointing.
testBspCombiner() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally with combiner and checkout output value.
testBspFail() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job in JobTracker, kill a task, and make sure the job fails (not enough attempts to restart)
testBspMasterCompute() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally and test MasterCompute.
testBspMsg() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally and test messages.
testBspPageRank() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally and test PageRank.
testBspPageRankWithAggregatorWriter() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally and test PageRank with AggregatorWriter.
testBspShortestPaths() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally and test shortest paths.
testBspSuperStep() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally and test supersteps.
testCombiner() - Method in class org.apache.giraph.examples.MinimumIntCombinerTest
 
testContinue() - Method in class org.apache.giraph.TestJsonBase64Format
Start a job and finish after i supersteps, then begin a new job and continue on more j supersteps.
testCreateExt() - Method in class org.apache.giraph.TestZooKeeperExt
 
testDeleteExt() - Method in class org.apache.giraph.TestZooKeeperExt
 
testDerivedInputFormatType() - Method in class org.apache.giraph.TestVertexTypes
 
testDerivedMatchingType() - Method in class org.apache.giraph.TestVertexTypes
 
testDifferentSeparators() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
 
testDifferentSeparators() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
testDiskBackedMessageStore() - Method in class org.apache.giraph.comm.TestMessageStores
 
testDiskBackedMessageStoreByPartition() - Method in class org.apache.giraph.comm.TestMessageStores
 
testDiskBackedPartitionStore() - Method in class org.apache.giraph.graph.partition.TestPartitionStores
 
TestDoubleAggregators - Class in org.apache.giraph.aggregators
 
TestDoubleAggregators() - Constructor for class org.apache.giraph.aggregators.TestDoubleAggregators
 
testDuplicateRpcPort() - Method in class org.apache.giraph.comm.RPCCommunicationsTest
 
TestEdgeListVertex - Class in org.apache.giraph.graph
Tests EdgeListVertex.
TestEdgeListVertex() - Constructor for class org.apache.giraph.graph.TestEdgeListVertex
 
testEdges() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
testEdgesMustHaveValues() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
 
testEdgesMustHaveValues() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
testEmptyVertexInputFormat() - Method in class org.apache.giraph.TestBspBasic
Run a sample BSP job locally with no vertices and make sure it completes.
testEquality() - Method in class org.apache.giraph.utils.ComparisonUtilsTest
 
testEqualityEmpty() - Method in class org.apache.giraph.utils.ComparisonUtilsTest
 
testEvent() - Method in class org.apache.giraph.TestPredicateLock
Single threaded case where the event is signaled.
TestFloatAggregators - Class in org.apache.giraph.aggregators
 
TestFloatAggregators() - Constructor for class org.apache.giraph.aggregators.TestFloatAggregators
 
testGetBasePath() - Method in class zk.TestZooKeeperManager
 
testGetChildrenExt() - Method in class org.apache.giraph.TestZooKeeperExt
 
testGetEdges() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
testGiraphTransferRegulator() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
TestGraphPartitioner - Class in org.apache.giraph
Unit test for manual checkpoint restarting
TestGraphPartitioner() - Constructor for class org.apache.giraph.TestGraphPartitioner
 
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.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
TestIdWithValueTextOutputFormat - Class in org.apache.giraph.io
 
TestIdWithValueTextOutputFormat() - Constructor for class org.apache.giraph.io.TestIdWithValueTextOutputFormat
 
testIndexMustHaveValue() - Method in class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
 
testIndexMustHaveValue() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
testInEquality() - Method in class org.apache.giraph.utils.ComparisonUtilsTest
 
testInEqualityDifferentLengths() - Method in class org.apache.giraph.utils.ComparisonUtilsTest
 
testInstantiate() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
testInstantiateNullVertex() - Method in class org.apache.giraph.TestBspBasic
Test whether vertices with NullWritable for vertex value type, edge value type and message value type can be instantiated.
testInstantiateVertex() - Method in class org.apache.giraph.TestBspBasic
Just instantiate the vertex (all functions are implemented) and the VertexInputFormat using reflection.
TestIntAggregators - Class in org.apache.giraph.aggregators
 
TestIntAggregators() - Constructor for class org.apache.giraph.aggregators.TestIntAggregators
 
TestIntIntNullIntVertex - Class in org.apache.giraph.graph
Tests IntIntNullIntVertex.
TestIntIntNullIntVertex() - Constructor for class org.apache.giraph.graph.TestIntIntNullIntVertex
 
TestJsonBase64Format - Class in org.apache.giraph
Test out the JsonBase64 format.
TestJsonBase64Format(String) - Constructor for class org.apache.giraph.TestJsonBase64Format
Create the test case
TestJsonBase64Format() - Constructor for class org.apache.giraph.TestJsonBase64Format
 
testJsonBase64FormatType() - Method in class org.apache.giraph.TestVertexTypes
 
testLineSanitizer() - Method in class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
testLocalityInfoSorter() - Method in class org.apache.giraph.TestBspBasic
Run a test to see if the LocalityInfoSorter can correctly sort locality information from a mocked znode of data.
testLocalJobRunnerConfig() - Method in class org.apache.giraph.TestBspBasic
Do some checks for local job runner.
TestLongAggregators - Class in org.apache.giraph.aggregators
 
TestLongAggregators() - Constructor for class org.apache.giraph.aggregators.TestLongAggregators
 
TestLongDoubleDoubleAdjacencyListVertexInputFormat - Class in org.apache.giraph.io
 
TestLongDoubleDoubleAdjacencyListVertexInputFormat() - Constructor for class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat
 
TestLongDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex - Class in org.apache.giraph.io
 
TestLongDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex() - Constructor for class org.apache.giraph.io.TestLongDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex
 
TestManualCheckpoint - Class in org.apache.giraph
Unit test for manual checkpoint restarting
TestManualCheckpoint() - Constructor for class org.apache.giraph.TestManualCheckpoint
 
testMatchingType() - Method in class org.apache.giraph.TestVertexTypes
 
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
 
testMismatchingCombiner() - Method in class org.apache.giraph.TestVertexTypes
 
testMismatchingVertex() - Method in class org.apache.giraph.TestVertexTypes
 
TestMutateGraph - Class in org.apache.giraph
Unit test for graph mutation
TestMutateGraph() - Constructor for class org.apache.giraph.TestMutateGraph
 
testMutateGraph() - Method in class org.apache.giraph.TestMutateGraph
Run a job that tests the various graph mutations that can occur
TestNotEnoughMapTasks - Class in org.apache.giraph
Unit test for not enough map tasks
TestNotEnoughMapTasks() - Constructor for class org.apache.giraph.TestNotEnoughMapTasks
 
testNotEnoughMapTasks() - Method in class org.apache.giraph.TestNotEnoughMapTasks
This job should always fail gracefully with not enough map tasks.
testOnNoShorterPathFound() - Method in class org.apache.giraph.examples.SimpleShortestPathsVertexTest
Test the behavior when a new, but not shorter path to a vertex has been found.
testOnShorterPathFound() - Method in class org.apache.giraph.examples.SimpleShortestPathsVertexTest
Test the behavior when a shorter path to a vertex has been found
testOrAggregator() - Method in class org.apache.giraph.aggregators.TestBooleanAggregators
 
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
 
testPartitioners() - Method in class org.apache.giraph.TestGraphPartitioner
Run a sample BSP job locally and test various partitioners and partition algorithms.
TestPartitionStores - Class in org.apache.giraph.graph.partition
Test case for partition stores.
TestPartitionStores() - Constructor for class org.apache.giraph.graph.partition.TestPartitionStores
 
TestPredicateLock - Class in org.apache.giraph
Ensure that PredicateLock objects work correctly.
TestPredicateLock() - Constructor for class org.apache.giraph.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
 
testReadWrite(PartitionStore<IntWritable, IntWritable, NullWritable, IntWritable>, Configuration) - Method in class org.apache.giraph.graph.partition.TestPartitionStores
 
testReverseIdAndValue() - Method in class org.apache.giraph.io.TestIdWithValueTextOutputFormat
 
testSerialize() - Method in class org.apache.giraph.graph.TestEdgeListVertex
 
testSerialize() - Method in class org.apache.giraph.graph.TestIntIntNullIntVertex
 
testSimpleMessageStore() - Method in class org.apache.giraph.comm.TestMessageStores
 
testSimplePartitionStore() - Method in class org.apache.giraph.graph.partition.TestPartitionStores
 
testSingleFault() - Method in class org.apache.giraph.TestAutoCheckpoint
Run a job that requires checkpointing and will have a worker crash and still recover from a previous checkpoint.
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
 
testSuperstepOne() - Method in class org.apache.giraph.examples.SimpleTriangleClosingVertexTest
Test behavior of compute() with incoming messages (superstep 1)
testSuperstepZero() - Method in class org.apache.giraph.examples.SimpleTriangleClosingVertexTest
Test the behavior of the triangle closing algorithm: does it send all its out edge values to all neighbors?
TestTextDoubleDoubleAdjacencyListVertexInputFormat - Class in org.apache.giraph.io
 
TestTextDoubleDoubleAdjacencyListVertexInputFormat() - Constructor for class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat
 
TestTextDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex - Class in org.apache.giraph.io
 
TestTextDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex() - Constructor for class org.apache.giraph.io.TestTextDoubleDoubleAdjacencyListVertexInputFormat.DummyVertex
 
testToyData() - Method in class org.apache.giraph.examples.ConnectedComponentsVertexTest
A local integration test on toy data
testToyData() - Method in class org.apache.giraph.examples.SimpleShortestPathsVertexTest
A local integration test on toy data
testToyData() - Method in class org.apache.giraph.examples.TryMultiRpcBindingPortsTest
A local integration test on toy data
TestVertexTypes - Class in org.apache.giraph
 
TestVertexTypes() - Constructor for class org.apache.giraph.TestVertexTypes
 
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.TestPredicateLock
Thread signaled test for PredicateLock.waitForever()
testWaitMsecs() - Method in class org.apache.giraph.TestPredicateLock
Thread signaled test to make sure the the event is signaled correctly
testWaitMsecsNoEvent() - Method in class org.apache.giraph.TestPredicateLock
SMake sure the the event is not signaled.
testWithDifferentDelimiter() - Method in class org.apache.giraph.io.TestAdjacencyListTextVertexOutputFormat
 
testWithDifferentDelimiter() - Method in class org.apache.giraph.io.TestIdWithValueTextOutputFormat
 
TestZooKeeperExt - Class in org.apache.giraph
 
TestZooKeeperExt() - Constructor for class org.apache.giraph.TestZooKeeperExt
 
TestZooKeeperManager - Class in zk
 
TestZooKeeperManager() - Constructor for class zk.TestZooKeeperManager
 
TryMultiRpcBindingPortsTest - Class in org.apache.giraph.examples
Tests for TryMultiRpcBindingPortsTest
TryMultiRpcBindingPortsTest() - Constructor for class org.apache.giraph.examples.TryMultiRpcBindingPortsTest
 

V

verifyMessageSent(I, M) - Method in class org.apache.giraph.utils.MockUtils.MockedEnvironment
assert that the test vertex message has been sent to a particular vertex
verifyNoMessageSent() - Method in class org.apache.giraph.utils.MockUtils.MockedEnvironment
assert that the test vertex has sent no message to a particular vertex

Z

zk - package zk
 

A B C F G I M O P R S T V Z

Copyright © 2011-2012 The Apache Software Foundation. All Rights Reserved.