This project has retired. For details please refer to its Attic page.
Index (Apache Giraph Parent 1.4.0-SNAPSHOT API)
Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W Y Z _ 

A

abortTask(TaskAttemptContext) - Method in class org.apache.giraph.bsp.ImmutableOutputCommitter
 
abortTask(TaskAttemptContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
 
AbstractBlockFactory<S> - Class in org.apache.giraph.block_app.framework
Default block factory abstract class, providing default methods that need to be/can be overridden for specifying required/most common parameters, to simplify setting properties.
AbstractBlockFactory() - Constructor for class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
AbstractComputation<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.graph
See Computation for explanation of the interface.
AbstractComputation() - Constructor for class org.apache.giraph.graph.AbstractComputation
 
AbstractConfOption - Class in org.apache.giraph.conf
Abstract base class of configuration options
AbstractConfOption(String, String) - Constructor for class org.apache.giraph.conf.AbstractConfOption
Constructor
AbstractEdgeStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,K,Et> - Class in org.apache.giraph.edge
Basic implementation of edges store, extended this to easily define simple and primitive edge stores
AbstractEdgeStore(CentralizedServiceWorker<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>, Progressable) - Constructor for class org.apache.giraph.edge.AbstractEdgeStore
Constructor.
AbstractListPerVertexStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable,L extends List> - Class in org.apache.giraph.comm.messages
Abstract Implementation of SimpleMessageStore where multiple messages are stored per vertex as a list Used when there is no combiner provided.
AbstractListPerVertexStore(MessageValueFactory<M>, PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.AbstractListPerVertexStore
Constructor
AbstractLongByteOps - Class in org.apache.giraph.mapping
Implementation of basic methods in MappingStoreOps
AbstractLongByteOps() - Constructor for class org.apache.giraph.mapping.AbstractLongByteOps
 
AbstractPiece<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,WV,WM extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece
Parent of all Pieces, contains comprehensive list of methods Piece can support.
AbstractPiece() - Constructor for class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
AbstractPiece.InnerVertexReceiver - Class in org.apache.giraph.block_app.framework.piece
Inner class to provide clean use without specifying types
AbstractPiece.InnerVertexSender - Class in org.apache.giraph.block_app.framework.piece
Inner class to provide clean use without specifying types
AbstractVertexIdData<I extends org.apache.hadoop.io.WritableComparable,T> - Class in org.apache.giraph.utils
Partial implementation of vertexIdData
AbstractVertexIdData() - Constructor for class org.apache.giraph.utils.AbstractVertexIdData
 
acceptReducedValues(DataInput) - Method in class org.apache.giraph.master.MasterAggregatorHandler
Accept reduced values sent by worker.
ACK - Static variable in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
Bracha-Toueg ACK message.
AckSignalFlag - Enum in org.apache.giraph.comm.netty.handler
Flag used to differentiate acknowledgement flags.
activeThreadCheckIn() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
A processing thread would check in with out-of-core engine every once in a while to make sure that it can still remain active.
ACTUAL_LOCALITY_RATIO - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
add(DoubleDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Add the vector specified.
add(FloatDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Add the vector specified.
add(IntDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Add the vector specified.
add(LongDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Add the vector specified.
add(int, double) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Increment value for a given key
add(DoubleSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Add the vector specified.
add(FloatSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
Add the vector specified.
add(IntSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
Add the vector specified.
add(int, long) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Increment value for a given key
add(LongSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Add the vector specified.
add(PieceCount) - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
add(Configuration, Class<? extends C>) - Method in class org.apache.giraph.conf.ClassConfOption
Add class to list for key
add(Edge<I, E>) - Method in class org.apache.giraph.edge.ArrayListEdges
 
add(Edge<I, E>) - Method in class org.apache.giraph.edge.ByteArrayEdges
 
add(Edge<I, E>) - Method in class org.apache.giraph.edge.HashMapEdges
 
add(Edge<I, E>) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
add(Edge<I, NullWritable>) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
add(Edge<I, E>) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
add(Edge<IntWritable, NullWritable>) - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
add(Edge<LongWritable, ByteWritable>) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
add(long) - Method in class org.apache.giraph.edge.LongDiffArray
Add a value
add(Edge<LongWritable, NullWritable>) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
add(Edge<LongWritable, DoubleWritable>) - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
add(Edge<LongWritable, DoubleWritable>) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
add(Edge<LongWritable, NullWritable>) - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
add(Edge<LongWritable, NullWritable>) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
add(Edge<I, E>) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
add(Edge<I, E>) - Method in interface org.apache.giraph.edge.OutEdges
Add an edge.
add(String, long, String) - Method in class org.apache.giraph.metrics.AggregatedMetrics
Add value from hostname for a metric.
add(String, double, String) - Method in class org.apache.giraph.metrics.AggregatedMetrics
Add value from hostname for a metric.
add(WorkerSuperstepMetrics, String) - Method in class org.apache.giraph.metrics.AggregatedMetrics
Add metrics from worker.
add(int, byte) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Add a key value pair
add(int, double) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Add a key value pair
add(int, float) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Add a key value pair
add(int, int) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Add a key value pair
add(int, long) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Add a key value pair
add(long, byte) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Add a key value pair
add(long, double) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Add a key value pair
add(long, float) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Add a key value pair
add(long, int) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Add a key value pair
add(long, long) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Add a key value pair
add(T) - Method in interface org.apache.giraph.types.ops.collections.BasicSet
Adds value to the set.
add(IntWritable) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
add(LongWritable) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
add(I, T) - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
add(byte[], int, T) - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
add(byte[], int, int, M) - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
Add a message.
add(I, M) - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
add(byte[], int, M) - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
add(I, M) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
add(byte[], int, M) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
add(long) - Method in class org.apache.giraph.utils.IncreasingBitSet
Add a key if it is possible.
add(U, V) - Method in class org.apache.giraph.utils.PairList
Add a pair to the collection.
add(I, T) - Method in interface org.apache.giraph.utils.VertexIdData
Add a vertex id and data pair to the collection.
add(byte[], int, T) - Method in interface org.apache.giraph.utils.VertexIdData
Add a serialized vertex id and data.
addChannel(Channel) - Method in class org.apache.giraph.comm.netty.ChannelRotater
Add a channel to the rotation
addConcurrent(K, C, ConcurrentMap<K, C>) - Static method in class org.apache.giraph.utils.CollectionUtils
If map already has a value associated with the key it adds values to that value, otherwise it will put values to the map.
addCustomCounter(String, String, CustomCounter.Aggregation) - Static method in class org.apache.giraph.counters.CustomCounters
Add a counter group and name to the custom counters If it already exists, then it will not be added This will be called from the application to add the app-specific counters
addData(WorkerInfo, int, I, T) - Method in class org.apache.giraph.comm.SendVertexIdDataCache
Add data to the cache.
addData(WorkerInfo, int, byte[], int, T) - Method in class org.apache.giraph.comm.SendVertexIdDataCache
This method is similar to the method above, but use a serialized id to replace original I type destVertexId.
addEdge(Number, Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Edge to the graph with default Edge Value, by adding it to outEdges of fromVertex, potentially creating fromVertex if it doesn't exist.
addEdge(Number, Number, Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Edge to the graph with provided Edge Value, by adding it to outEdges of fromVertex, potentially creating fromVertex if it doesn't exist.
addEdge(Number, Number, E) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Edge to the graph with provided Edge Value, by adding it to outEdges of fromVertex, potentially creating fromVertex if it doesn't exist.
addEdge(WorkerInfo, int, I, Edge<I, E>) - Method in class org.apache.giraph.comm.SendEdgeCache
Add an edge to the cache.
addEdge(Edge<I, E>) - Method in class org.apache.giraph.graph.DefaultVertex
 
addEdge(Edge<I, Writable>) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
addEdge(Edge<I, E>) - Method in interface org.apache.giraph.graph.Vertex
Add an edge for this vertex (happens immediately)
addEdge(Edge<I, E>) - Method in class org.apache.giraph.graph.VertexMutations
Add an edge to this vertex
addEdge(I, Map.Entry<I, E>) - Method in class org.apache.giraph.utils.TestGraph
Add an edge to an existing vertex `
addEdge(I, I, E) - Method in class org.apache.giraph.utils.TestGraph
Add an edge to an existing vertex
addEdgeCount(long) - Method in class org.apache.giraph.partition.PartitionStats
Add edges to the edge count.
addEdgeInputPath(Configuration, Path) - Static method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Add a Path to the list of edge inputs.
addEdgeMutation(Integer, I, Edge<I, E>) - Method in class org.apache.giraph.comm.SendMutationsCache
Add an add edge mutation to the cache.
addEdgeRequest(I, Edge<I, E>) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Request to add an edge of a vertex in the graph (processed just prior to the next receive phase)
addEdgeRequest(I, Edge<I, E>) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
addEdgeRequest(I, Edge<I, E>) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
addEdgeRequest(I, Edge<I, E>) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a request to the appropriate vertex range owner to add an edge
addEdgeRequest(I, Edge<I, E>) - Method in class org.apache.giraph.graph.AbstractComputation
Request to add an edge of a vertex in the graph (processed just prior to the next superstep)
addEdgeRequest(I, Edge<I, E>) - Method in interface org.apache.giraph.graph.Computation
Request to add an edge of a vertex in the graph (processed just prior to the next superstep)
addEdgeRequest(Object, Edge) - Method in class org.apache.giraph.jython.JythonComputation
Request to add an edge of a vertex in the graph (processed just prior to the next superstep)
addEdges(Vertex<I, V, E>, VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Add edges to the Vertex.
addEdgesLoaded(long) - Method in class org.apache.giraph.worker.WorkerProgress
Add number of edges loaded
addEntry(LongWritable, ByteWritable) - Method in class org.apache.giraph.mapping.LongByteMappingStore
 
addEntry(I, B) - Method in interface org.apache.giraph.mapping.MappingStore
Add an entry to the mapping store
addEntry(int, T) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Adds a data entry for a given partition to the current data store.
addEntryToInMemoryPartitionData(int, T) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Adds a single entry for a given partition to the in-memory data store.
addEntryToInMemoryPartitionData(int, VertexIdEdges<I, E>) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
addEntryToInMemoryPartitionData(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
addEntryToInMemoryPartitionData(int, ExtendedDataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
addFileToResourceMap(Map<String, LocalResource>, FileSystem, Path) - Static method in class org.apache.giraph.yarn.YarnUtils
Boilerplate to add a file to the local resources..
addFsResourcesToMap(Map<String, LocalResource>, GiraphConfiguration, ApplicationId) - Static method in class org.apache.giraph.yarn.YarnUtils
Populates the LocalResources list with the HDFS paths listed in the conf under GiraphConstants.GIRAPH_YARN_LIBJARS, and the GiraphConfiguration for this job.
addGcObserverClass(Class<? extends GcObserver>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Add a GcObserver class (optional)
addGiraphConfToLocalResourceMap(GiraphConfiguration, ApplicationId, Map<String, LocalResource>) - Static method in class org.apache.giraph.yarn.YarnUtils
Populate the LocalResources list with the GiraphConf XML file's HDFS path.
addGiraphTimersAndSendCounters(long) - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Add the Giraph Timers to thirft counter struct, and send to the job client Counters include the Giraph Timers for setup, initialise, shutdown, total, and time for the given superstep
addGiraphTimersAndSendCounters(long) - Method in class org.apache.giraph.master.BspServiceMaster
We add the Giraph Timers separately, because we need to include the time required for shutdown and cleanup This will fetch the final Giraph Timers, and send all the counters to the job client
addIncomingWorkerToWorkerMessage(Writable) - Method in class org.apache.giraph.comm.ServerData
Add incoming message to this worker for next superstep.
addIndex(DataIndex.DataIndexEntry) - Method in class org.apache.giraph.ooc.persistence.DataIndex
Add an index to the index chain
addIOCommand(IOCommand) - Method in class org.apache.giraph.ooc.OutOfCoreIOScheduler
Add an IO command to the scheduling queue of the IO scheduler
addItem(T, String) - Method in class org.apache.giraph.metrics.AggregatedMetric
Add another item to the aggregation.
addItem(Double, String) - Method in class org.apache.giraph.metrics.AggregatedMetricDouble
 
addItem(Long, String) - Method in class org.apache.giraph.metrics.AggregatedMetricLong
 
ADDITIONAL_EDGE_REQUEST_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Additional size (expressed as a ratio) of each per-partition buffer on top of the average size for edges.
ADDITIONAL_MSG_REQUEST_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
How much bigger than the average per partition size to make initial per partition buffers.
ADDITIONAL_VERTEX_REQUEST_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Additional size (expressed as a ratio) of each per-partition buffer on top of the average size for vertices.
additionalInitConfig(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Additional configuration initialization, other then overriding class specification.
addLastWithExecutorCheck(String, ChannelHandler, String, EventExecutorGroup, Channel) - Static method in class org.apache.giraph.utils.PipelineUtils
Add a handler to pipeline if it is not already added and configure the handler to use an executor group based on equality of compareTo and handlerName
addListener(MetricsRegistryListener) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
addLocalClasspathToEnv(Map<String, String>, GiraphConfiguration) - Static method in class org.apache.giraph.yarn.YarnUtils
Popuate the environment string map to be added to the environment vars in a remote execution container.
addMapperObserverClass(Class<? extends MapperObserver>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Add a MapperObserver class (optional)
addMasterObserverClass(Class<? extends MasterObserver>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Add a MasterObserver class (optional)
addMessage(I, M) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
addMessage(I, M) - Method in interface org.apache.giraph.comm.messages.MessageStore
Adds a message for a particular vertex The method is used by InternalMessageStore to send local messages; for the general case, use a more efficient addPartitionMessages
addMessage(I, M) - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
addMessage(I, M) - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
addMessage(I, M) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
Adds a message for a particular vertex
addMessage(I, M) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
Adds a message for a particular vertex
addMessage(IntWritable, FloatWritable) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
addMessage(LongWritable, M) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
addMessage(LongWritable, DoubleWritable) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
addMessage(I, M) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
addMessage(WorkerInfo, int, I, M) - Method in class org.apache.giraph.comm.SendMessageCache
Add a message to the cache.
addMessage(WorkerInfo, int, byte[], int, M) - Method in class org.apache.giraph.comm.SendMessageCache
Add a message to the cache with serialized ids.
addMessage(I, M) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
addMessageBytesCount(long) - Method in class org.apache.giraph.graph.GlobalStats
Add messages to the global stats.
addMessageBytesSentCount(long) - Method in class org.apache.giraph.partition.PartitionStats
Add message bytes to messageBytesSentCount.
addMessageCount(long) - Method in class org.apache.giraph.graph.GlobalStats
Add messages to the global stats.
addMessagesSentCount(long) - Method in class org.apache.giraph.partition.PartitionStats
Add messages to the messages sent count.
addOocLoadBytesCount(long) - Method in class org.apache.giraph.graph.GlobalStats
Add bytes loaded to the global stats.
addOocStoreBytesCount(long) - Method in class org.apache.giraph.graph.GlobalStats
Add bytes stored to the global stats.
addOption(String, String, boolean, String) - Static method in class org.apache.giraph.utils.ConfigurationUtils
Callers can place additional options to be parsed and stored in our job's GiraphConfiguration via this utility call.
addOutputDesc(OD, String, GiraphConfiguration) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
addParameter(String, String) - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
Add parameter to this input format description
addParameters(JSONObject) - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
Add all parameters from json object
addParent(long) - Method in class org.apache.giraph.examples.scc.SccVertexValue
Adds a vertex id to the list of parent vertices.
addParent(Long) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
add a parent id into the list of parents kept at the vertex side
addPartition(Partition<I, V, E>) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
addPartition(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Add a partition
addPartition(Partition<I, V, E>) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
addPartition(Partition<I, V, E>) - Method in interface org.apache.giraph.partition.Partition
Add a partition's vertices.
addPartition(Partition<I, V, E>) - Method in interface org.apache.giraph.partition.PartitionStore
Add a *new* partition to the store.
addPartition(Partition<I, V, E>) - Method in class org.apache.giraph.partition.SimplePartition
 
addPartition(Partition<I, V, E>) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
addPartitionEdges(int, VertexIdEdges<I, E>) - Method in class org.apache.giraph.edge.AbstractEdgeStore
 
addPartitionEdges(int, VertexIdEdges<I, E>) - Method in interface org.apache.giraph.edge.EdgeStore
Add edges belonging to a given partition on this worker.
addPartitionEdges(int, VertexIdEdges<I, E>) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in interface org.apache.giraph.comm.messages.MessageStore
Adds messages for partition
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
addPartitionMessages(int, VertexIdMessages<IntWritable, FloatWritable>) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
addPartitionMessages(int, VertexIdMessages<LongWritable, M>) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
addPartitionMessages(int, VertexIdMessages<LongWritable, DoubleWritable>) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
addPartitionMessages(int, VertexIdMessages<I, M>) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
addPartitionStats(PartitionStats) - Method in class org.apache.giraph.graph.GlobalStats
Add the stats of a partition to the global stats.
addPartitionVertices(Integer, ExtendedDataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
addPartitionVertices(VertexIterator<I, V, E>) - Method in class org.apache.giraph.partition.BasicPartition
 
addPartitionVertices(VertexIterator<I, V, E>) - Method in interface org.apache.giraph.partition.Partition
Add vertices to a partition.
addPartitionVertices(Integer, ExtendedDataOutput) - Method in interface org.apache.giraph.partition.PartitionStore
Add vertices to a given partition from a given DataOutput instance.
addPartitionVertices(Integer, ExtendedDataOutput) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
addressesAndPartitionsReceived(AddressesAndPartitionsWritable) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Received addresses and partitions assignments from master.
addressesAndPartitionsReceived(AddressesAndPartitionsWritable) - Method in class org.apache.giraph.worker.BspServiceWorker
 
AddressesAndPartitionsRequest - Class in org.apache.giraph.comm.requests
Request for master sending addresses and partitions to workers
AddressesAndPartitionsRequest() - Constructor for class org.apache.giraph.comm.requests.AddressesAndPartitionsRequest
Constructor for reflection
AddressesAndPartitionsRequest(AddressesAndPartitionsWritable) - Constructor for class org.apache.giraph.comm.requests.AddressesAndPartitionsRequest
Constructor
AddressesAndPartitionsWritable - Class in org.apache.giraph.graph
Helper class to write descriptions of master, workers and partition owners
AddressesAndPartitionsWritable(MasterInfo, List<WorkerInfo>, Collection<PartitionOwner>) - Constructor for class org.apache.giraph.graph.AddressesAndPartitionsWritable
Constructor when we want to serialize object
AddressesAndPartitionsWritable() - Constructor for class org.apache.giraph.graph.AddressesAndPartitionsWritable
Constructor for reflection
addRow(FloatDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Add the float vector as a row in the matrix.
addRow(IntDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Add the int vector as a row in the matrix.
addScriptToLoad(Configuration, String, DeployType, Language) - Static method in class org.apache.giraph.scripting.ScriptLoader
Add a script to load on workers
addScriptToLoad(Configuration, DeployedScript) - Static method in class org.apache.giraph.scripting.ScriptLoader
Add a script to load on workers
addSpecialCount(Integer) - Method in class org.apache.giraph.comm.aggregators.SendGlobalCommCache
Creates special value which will hold the total number of global communication requests for worker with selected task id.
addSplits(InputType, List<InputSplit>, GiraphInputFormat) - Method in class org.apache.giraph.master.input.MasterInputSplitsHandler
Add splits
addSuperstepResetObserver(ResetSuperstepMetricsObserver) - Method in class org.apache.giraph.metrics.GiraphMetrics
Anyone using per-superstep counters needs to re-initialize their Metrics object on each new superstep.
addSymmetricEdge(Number, Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add symmetric Edge to the graph with default Edge Value, by adding it to outEdges of vertices on both ends, potentially creating them both, if they don't exist.
addSymmetricEdge(Number, Number, Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add symmetric Edge to the graph with provided Edge Value, by adding it to outEdges of vertices on both ends, potentially creating them both, if they don't exist.
addSymmetricEdge(Number, Number, E) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add symmetric Edge to the graph with provided Edge Value, by adding it to outEdges of vertices on both ends, potentially creating them both, if they don't exist.
addToClasses(Configuration, String, Class<? extends T>, Class<T>) - Static method in class org.apache.giraph.conf.ClassConfOption
Add a class to a property that is a list of classes.
addToOptions(Options) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Add option to cli Options
addValue(String, GlobalCommType, Writable) - Method in class org.apache.giraph.comm.aggregators.GlobalCommValueOutputStream
Write global communication object to the stream and increment internal counter
addValue(Integer, String, GlobalCommType, Writable) - Method in class org.apache.giraph.comm.aggregators.SendGlobalCommCache
Add global communication value to the cache
addVertex(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Vertex with a given id to the graph, initializing it to default vertex value and no edges.
addVertex(Number, Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Vertex with a given id and a given Vertex Value to the graph, initializing it to have no edges.
addVertex(Number, Number, Number, Number...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Vertex with a given id and a given Vertex Value to the graph, with listed outgoing edges, all initialized to same provided edgeValue.
addVertex(Number, V) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Vertex with a given id and a given Vertex Value to the graph, initializing it to have no edges.
addVertex(Number, V, Supplier<E>, Number...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Add Vertex with a given id and a given Vertex Value to the graph, with listed outgoing edges, all initialized to same provided edgeSupplier.
addVertex(PartitionOwner, Vertex<I, V, E>) - Method in class org.apache.giraph.comm.SendPartitionCache
Add a vertex to the cache.
addVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.graph.VertexMutations
Add a vertex mutation
addVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.utils.TestGraph
Add vertex
addVertex(I, V, Map.Entry<I, E>...) - Method in class org.apache.giraph.utils.TestGraph
Add vertex with given ID
addVertexIfDesired(I, Vertex<I, V, E>, VertexChanges<I, V, E>, boolean) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Add the Vertex if desired.
addVertexInputPath(Configuration, Path) - Static method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Add a Path to the list of vertex inputs.
addVertexMutation(Integer, Vertex<I, V, E>) - Method in class org.apache.giraph.comm.SendMutationsCache
Add a add vertex mutation to the cache.
addVertexMutations(VertexMutations<I, V, E>) - Method in class org.apache.giraph.graph.VertexMutations
Add one vertex mutations to another
addVertexRequest(I, V, OutEdges<I, E>) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Sends a request to create a vertex that will be available in the receive phase.
addVertexRequest(I, V) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Sends a request to create a vertex that will be available in the receive phase.
addVertexRequest(I, V, OutEdges<I, E>) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
addVertexRequest(I, V) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
addVertexRequest(Vertex<I, V, E>) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
addVertexRequest(Vertex<I, V, E>) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a request to the appropriate vertex range owner to add a vertex
addVertexRequest(I, V, OutEdges<I, E>) - Method in class org.apache.giraph.graph.AbstractComputation
Sends a request to create a vertex that will be available during the next superstep.
addVertexRequest(I, V) - Method in class org.apache.giraph.graph.AbstractComputation
Sends a request to create a vertex that will be available during the next superstep.
addVertexRequest(I, V, OutEdges<I, E>) - Method in interface org.apache.giraph.graph.Computation
Sends a request to create a vertex that will be available during the next superstep.
addVertexRequest(I, V) - Method in interface org.apache.giraph.graph.Computation
Sends a request to create a vertex that will be available during the next superstep.
addVertexRequest(Object, Object, OutEdges) - Method in class org.apache.giraph.jython.JythonComputation
Sends a request to create a vertex that will be available during the next superstep.
addVertexRequest(Object, Object) - Method in class org.apache.giraph.jython.JythonComputation
Sends a request to create a vertex that will be available during the next superstep.
addVerticesComputed(long) - Method in class org.apache.giraph.worker.WorkerProgress
Add number of vertices computed
addVerticesLoaded(long) - Method in class org.apache.giraph.worker.WorkerProgress
Add number of vertices loaded
addVerticesStored(long) - Method in class org.apache.giraph.worker.WorkerProgress
Add number of vertices stored
addW(BooleanWritable) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
addW(ByteWritable) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
addW(DoubleWritable) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
addW(FloatWritable) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
addW(IntWritable) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
addW(LongWritable) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
addW(T) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Add value to the collection
addWorkerObserverClass(Class<? extends WorkerObserver>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Add a WorkerObserver class (optional)
AdjacencyListTextVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
VertexReader that readers lines of text with vertices encoded as adjacency lists and converts each token to the correct type.
AdjacencyListTextVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat
 
AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader - Class in org.apache.giraph.io.formats
Vertex reader associated with AdjacencyListTextVertexInputFormat.
AdjacencyListTextVertexInputFormat.LineSanitizer - Interface in org.apache.giraph.io.formats
Utility for doing any cleaning of each line before it is tokenized.
AdjacencyListTextVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
OutputFormat to write out the graph nodes as text, value-separated (by tabs, by default).
AdjacencyListTextVertexOutputFormat() - Constructor for class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat
 
AdjacencyListTextVertexOutputFormat.AdjacencyListTextVertexWriter - Class in org.apache.giraph.io.formats
Vertex writer associated with AdjacencyListTextVertexOutputFormat.
AdjacencyListTextVertexReader() - Constructor for class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
Constructor without line sanitizer.
AdjacencyListTextVertexReader(AdjacencyListTextVertexInputFormat.LineSanitizer) - Constructor for class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
Constructor with line sanitizer.
AdjacencyListTextVertexWriter() - Constructor for class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat.AdjacencyListTextVertexWriter
 
AdjustableSemaphore - Class in org.apache.giraph.utils
Implementation of a semaphore where number of available permits can change
AdjustableSemaphore(int) - Constructor for class org.apache.giraph.utils.AdjustableSemaphore
Constructor
AGG_SUPERSTEP_TOTAL_BYTES - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
All bytes sent during this superstep
AGG_SUPERSTEP_TOTAL_MESSAGES - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
All messages during this superstep
AGG_SUPERSTEP_TOTAL_MILLIS - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
All millis during this superstep
AGG_TOTAL_BYTES - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
All bytes sent during this application
AGG_TOTAL_MESSAGES - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
All messages during this application
AGG_TOTAL_MILLIS - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
All millis during this application
aggregate(A) - Method in interface org.apache.giraph.aggregators.Aggregator
Add a new value.
aggregate(BooleanWritable) - Method in class org.apache.giraph.aggregators.BooleanAndAggregator
 
aggregate(BooleanWritable) - Method in class org.apache.giraph.aggregators.BooleanOrAggregator
 
aggregate(BooleanWritable) - Method in class org.apache.giraph.aggregators.BooleanOverwriteAggregator
 
aggregate(DoubleWritable) - Method in class org.apache.giraph.aggregators.DoubleMaxAggregator
 
aggregate(DoubleWritable) - Method in class org.apache.giraph.aggregators.DoubleMinAggregator
 
aggregate(DoubleWritable) - Method in class org.apache.giraph.aggregators.DoubleOverwriteAggregator
 
aggregate(DoubleWritable) - Method in class org.apache.giraph.aggregators.DoubleProductAggregator
 
aggregate(DoubleWritable) - Method in class org.apache.giraph.aggregators.DoubleSumAggregator
 
aggregate(FloatWritable) - Method in class org.apache.giraph.aggregators.FloatMaxAggregator
 
aggregate(FloatWritable) - Method in class org.apache.giraph.aggregators.FloatMinAggregator
 
aggregate(FloatWritable) - Method in class org.apache.giraph.aggregators.FloatOverwriteAggregator
 
aggregate(FloatWritable) - Method in class org.apache.giraph.aggregators.FloatProductAggregator
 
aggregate(FloatWritable) - Method in class org.apache.giraph.aggregators.FloatSumAggregator
 
aggregate(IntWritable) - Method in class org.apache.giraph.aggregators.IntMaxAggregator
 
aggregate(IntWritable) - Method in class org.apache.giraph.aggregators.IntMinAggregator
 
aggregate(IntWritable) - Method in class org.apache.giraph.aggregators.IntOverwriteAggregator
 
aggregate(IntWritable) - Method in class org.apache.giraph.aggregators.IntProductAggregator
 
aggregate(IntWritable) - Method in class org.apache.giraph.aggregators.IntSumAggregator
 
aggregate(LongWritable) - Method in class org.apache.giraph.aggregators.LongMaxAggregator
 
aggregate(LongWritable) - Method in class org.apache.giraph.aggregators.LongMinAggregator
 
aggregate(LongWritable) - Method in class org.apache.giraph.aggregators.LongOverwriteAggregator
 
aggregate(LongWritable) - Method in class org.apache.giraph.aggregators.LongProductAggregator
 
aggregate(LongWritable) - Method in class org.apache.giraph.aggregators.LongSumAggregator
 
aggregate(int, int, double, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(DoubleDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVectorSumAggregator
 
aggregate(int, int, float, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(FloatDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVectorSumAggregator
 
aggregate(int, int, int, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(IntDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVectorSumAggregator
 
aggregate(int, int, long, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(LongDenseVector) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVectorSumAggregator
 
aggregate(int, int, double, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(DoubleSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVectorSumAggregator
 
aggregate(int, int, float, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(FloatSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVectorSumAggregator
 
aggregate(int, int, int, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(IntSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVectorSumAggregator
 
aggregate(int, int, long, WorkerAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrixSumAggregator
Add the given value to the entry specified.
aggregate(LongSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVectorSumAggregator
 
aggregate(Text) - Method in class org.apache.giraph.aggregators.TextAppendAggregator
 
aggregate(PageRankWithKryoSimpleWritable.VertexValue) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.DoubleMaxWrapperAggregator
 
aggregate(PageRankWithKryoSimpleWritable.VertexValue) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.DoubleMinWrapperAggregator
 
aggregate(String, WorkerAggregatorUsage, Configuration) - Static method in class org.apache.giraph.utils.MasterLoggingAggregator
Aggregate some message to master logging aggregator, if the option for using it is set in the configuration.
aggregate(String, A) - Method in class org.apache.giraph.worker.WorkerAggregatorDelegator
 
aggregate(String, A) - Method in interface org.apache.giraph.worker.WorkerAggregatorUsage
Add a new value
AGGREGATE_SENT_MESSAGE_BYTES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate sent messages bytes counter name
AGGREGATE_SENT_MESSAGES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate sent messages counter name
AGGREGATE_VERTICES - Static variable in class org.apache.giraph.io.formats.PseudoRandomInputFormatConstants
Set the number of aggregate vertices.
AggregatedMetric<T extends Number> - Class in org.apache.giraph.metrics
An aggregator over metrics from multiple hosts.
AggregatedMetric() - Constructor for class org.apache.giraph.metrics.AggregatedMetric
 
AggregatedMetricDouble - Class in org.apache.giraph.metrics
Aggregator over metrics with double values
AggregatedMetricDouble() - Constructor for class org.apache.giraph.metrics.AggregatedMetricDouble
Constructor
AggregatedMetricLong - Class in org.apache.giraph.metrics
Aggregator over metrics with long values
AggregatedMetricLong() - Constructor for class org.apache.giraph.metrics.AggregatedMetricLong
Constructor
AggregatedMetrics - Class in org.apache.giraph.metrics
Map of a bunch of aggregated metrics
AggregatedMetrics() - Constructor for class org.apache.giraph.metrics.AggregatedMetrics
 
Aggregator<A extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.aggregators
Interface for Aggregator.
AGGREGATOR_WRITER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
AggregatorWriter class - optional
AggregatorBroadcast<A extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.master
Writable representation of aggregated value
AggregatorBroadcast() - Constructor for class org.apache.giraph.master.AggregatorBroadcast
Constructor
AggregatorBroadcast(Class<? extends Aggregator<A>>, A) - Constructor for class org.apache.giraph.master.AggregatorBroadcast
Constructor
AggregatorReduceOperation<A extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.master
Translates aggregation operation to reduce operations.
AggregatorReduceOperation() - Constructor for class org.apache.giraph.master.AggregatorReduceOperation
Constructor
AggregatorReduceOperation(Class<? extends Aggregator<A>>, ImmutableClassesGiraphConfiguration<?, ?, ?>) - Constructor for class org.apache.giraph.master.AggregatorReduceOperation
Constructor
AggregatorsBenchmark - Class in org.apache.giraph.benchmark
Benchmark for aggregators.
AggregatorsBenchmark() - Constructor for class org.apache.giraph.benchmark.AggregatorsBenchmark
 
AggregatorsBenchmark.AggregatorsBenchmarkComputation - Class in org.apache.giraph.benchmark
Vertex class for AggregatorsBenchmark
AggregatorsBenchmark.AggregatorsBenchmarkMasterCompute - Class in org.apache.giraph.benchmark
MasterCompute class for AggregatorsBenchmark
AggregatorsBenchmark.AggregatorsBenchmarkWorkerContext - Class in org.apache.giraph.benchmark
WorkerContext class for AggregatorsBenchmark
AggregatorsBenchmarkComputation() - Constructor for class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkComputation
 
AggregatorsBenchmarkMasterCompute() - Constructor for class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkMasterCompute
 
AggregatorsBenchmarkWorkerContext() - Constructor for class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkWorkerContext
 
AggregatorsTestComputation - Class in org.apache.giraph.examples
Computation which uses aggrergators.
AggregatorsTestComputation() - Constructor for class org.apache.giraph.examples.AggregatorsTestComputation
 
AggregatorsTestComputation.AggregatorsTestMasterCompute - Class in org.apache.giraph.examples
Master compute which uses aggregators.
AggregatorsTestComputation.SimpleEdgeInputFormat - Class in org.apache.giraph.examples
Simple VertexInputFormat
AggregatorsTestComputation.SimpleEdgeReader - Class in org.apache.giraph.examples
Simple Edge Reader
AggregatorsTestComputation.SimpleVertexInputFormat - Class in org.apache.giraph.examples
Simple VertexInputFormat
AggregatorsTestComputation.SimpleVertexReader - Class in org.apache.giraph.examples
Simple VertexReader
AggregatorsTestMasterCompute() - Constructor for class org.apache.giraph.examples.AggregatorsTestComputation.AggregatorsTestMasterCompute
 
AggregatorToGlobalCommTranslation - Class in org.apache.giraph.master
Class that translates aggregator handling on the master to reduce and broadcast operations supported by the MasterAggregatorHandler.
AggregatorToGlobalCommTranslation(ImmutableClassesGiraphConfiguration<?, ?, ?>, MasterGlobalCommUsage) - Constructor for class org.apache.giraph.master.AggregatorToGlobalCommTranslation
Constructor
aggregatorToString(String, Writable, long) - Method in class org.apache.giraph.aggregators.TextAggregatorWriter
Implements the way an aggregator is converted into a String.
AggregatorUsage - Interface in org.apache.giraph.aggregators
Master and workers can access aggregators through this interface.
AggregatorUtils - Class in org.apache.giraph.comm.aggregators
Class for aggregator constants and utility methods
AggregatorWriter - Interface in org.apache.giraph.aggregators
An AggregatorWriter is used to export Aggregators during or at the end of each computation.
aggregatorWriterClass - Variable in class org.apache.giraph.conf.GiraphClasses
Aggregator writer class - cached for fast access
Algorithm - Annotation Type in org.apache.giraph
This annotation should be used to annotate built-in algorithms.
Algorithm - Annotation Type in org.apache.giraph.examples
This annotation should be used to annotate built-in algorithms.
AllAggregatorServerData - Class in org.apache.giraph.comm.aggregators
Accepts aggregators and their values from previous superstep from master and workers which own aggregators.
AllAggregatorServerData(Progressable, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.comm.aggregators.AllAggregatorServerData
Constructor
allMetrics() - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
AllOptions - Class in org.apache.giraph.conf
Tracks all of the Giraph options
allowOneMessageToManyIdsEncoding() - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify that this Piece allows one to many ids encoding to be used for messages.
allVerticesHalted() - Method in class org.apache.giraph.graph.FinishedSuperstepStats
Are all the vertices halted?
AllWorkersInfo - Class in org.apache.giraph.worker
Information about all workers, their WorkerInfo values, and indices.
AllWorkersInfo(List<WorkerInfo>, WorkerInfo) - Constructor for class org.apache.giraph.worker.AllWorkersInfo
Constructor
ALWAYS - Static variable in class org.apache.giraph.aggregators.TextAggregatorWriter
Signal for "write values in every superstep" frequency
AM_HIGH_THRESHOLD - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
If mem-usage is above this threshold, active threads are set to 0
AM_LOW_THRESHOLD - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
If mem-usage is below this threshold, active threads are set to max
analyzePartitionStats(Collection<PartitionOwner>, List<PartitionStats>) - Static method in class org.apache.giraph.partition.PartitionUtils
Check for imbalances on a per worker basis, by calculating the mean, high and low workers by edges and vertices.
AndReduce - Class in org.apache.giraph.reducers.impl
ReduceOperation for calculating the AND function over boolean values.
AndReduce() - Constructor for class org.apache.giraph.reducers.impl.AndReduce
 
AnnotationUtils - Class in org.apache.giraph.utils
Helper class to deal with annotations in runtime.
APPLICATION_ATTEMPTS_DIR - Static variable in class org.apache.giraph.bsp.BspService
Directory of attempts of this application
applicationAttemptsPath - Variable in class org.apache.giraph.bsp.BspService
Path to the application attempts)
applicationFailed(Exception) - Method in class org.apache.giraph.master.DefaultMasterObserver
 
applicationFailed(Exception) - Method in interface org.apache.giraph.master.MasterObserver
If there is an error during the application.
applicationFailed(Exception) - Method in class org.apache.giraph.utils.JMapHistoDumper
 
applicationFailed(Exception) - Method in class org.apache.giraph.utils.LogVersions
 
applicationFailed(Exception) - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
ApplicationState - Enum in org.apache.giraph.bsp
State of the BSP application
apply(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.DefaultMessageFactorySupplierFromConf
 
apply(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.SupplierFromConfByCopy
 
apply(T) - Method in interface org.apache.giraph.function.Consumer
Applies this function to input
apply(F) - Method in interface org.apache.giraph.function.Function
Returns the result of applying this function to given input.
apply(T) - Method in class org.apache.giraph.function.ObjectHolder
 
apply(T) - Method in class org.apache.giraph.function.ObjectNotifier
 
apply(T) - Method in class org.apache.giraph.function.ObjectTransfer
 
apply(T1, T2) - Method in interface org.apache.giraph.function.PairConsumer
Applies this function to input1 and input2
apply(F1, F2) - Method in interface org.apache.giraph.function.PairFunction
Returns the result of applying this function to given input1 and input2.
apply(T1, T2) - Method in interface org.apache.giraph.function.PairPredicate
Returns the result of applying this predicate to input1 and input2.
apply(T) - Method in interface org.apache.giraph.function.Predicate
Returns the result of applying this predicate to input.
apply(boolean) - Method in interface org.apache.giraph.function.primitive.Boolean2BooleanFunction
Returns the result of applying this function to given input.
apply(boolean) - Method in interface org.apache.giraph.function.primitive.Boolean2ObjFunction
Returns the result of applying this function to given input.
apply(boolean) - Method in interface org.apache.giraph.function.primitive.BooleanConsumer
Applies this function to input
apply(boolean) - Method in interface org.apache.giraph.function.primitive.BooleanPredicate
Returns the result of applying this predicate to input.
apply(byte) - Method in interface org.apache.giraph.function.primitive.Byte2ByteFunction
Returns the result of applying this function to given input.
apply(byte) - Method in interface org.apache.giraph.function.primitive.Byte2ObjFunction
Returns the result of applying this function to given input.
apply(byte) - Method in interface org.apache.giraph.function.primitive.ByteConsumer
Applies this function to input
apply(byte) - Method in interface org.apache.giraph.function.primitive.BytePredicate
Returns the result of applying this predicate to input.
apply(double) - Method in interface org.apache.giraph.function.primitive.Double2DoubleFunction
Returns the result of applying this function to given input.
apply(double) - Method in interface org.apache.giraph.function.primitive.Double2ObjFunction
Returns the result of applying this function to given input.
apply(double) - Method in interface org.apache.giraph.function.primitive.DoubleConsumer
Applies this function to input
apply(double) - Method in interface org.apache.giraph.function.primitive.DoublePredicate
Returns the result of applying this predicate to input.
apply(float) - Method in interface org.apache.giraph.function.primitive.Float2FloatFunction
Returns the result of applying this function to given input.
apply(float) - Method in interface org.apache.giraph.function.primitive.Float2ObjFunction
Returns the result of applying this function to given input.
apply(float) - Method in interface org.apache.giraph.function.primitive.FloatConsumer
Applies this function to input
apply(float) - Method in interface org.apache.giraph.function.primitive.FloatPredicate
Returns the result of applying this predicate to input.
apply(int) - Method in interface org.apache.giraph.function.primitive.Int2IntFunction
Returns the result of applying this function to given input.
apply(int) - Method in interface org.apache.giraph.function.primitive.Int2ObjFunction
Returns the result of applying this function to given input.
apply(int) - Method in interface org.apache.giraph.function.primitive.IntConsumer
Applies this function to input
apply(int) - Method in interface org.apache.giraph.function.primitive.IntPredicate
Returns the result of applying this predicate to input.
apply(long) - Method in interface org.apache.giraph.function.primitive.Long2LongFunction
Returns the result of applying this function to given input.
apply(long) - Method in interface org.apache.giraph.function.primitive.Long2ObjFunction
Returns the result of applying this function to given input.
apply(long) - Method in interface org.apache.giraph.function.primitive.LongConsumer
Applies this function to input
apply(long) - Method in interface org.apache.giraph.function.primitive.LongPredicate
Returns the result of applying this predicate to input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2BooleanFunction
Returns the result of applying this function to given input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2ByteFunction
Returns the result of applying this function to given input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2DoubleFunction
Returns the result of applying this function to given input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2FloatFunction
Returns the result of applying this function to given input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2IntFunction
Returns the result of applying this function to given input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2LongFunction
Returns the result of applying this function to given input.
apply(T) - Method in interface org.apache.giraph.function.primitive.Obj2ShortFunction
Returns the result of applying this function to given input.
apply(boolean, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanBooleanConsumer
Applies this function to input1 and input2
apply(boolean, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanBooleanPredicate
Returns the result of applying this predicate to input.
apply(boolean, byte) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanByteConsumer
Applies this function to input1 and input2
apply(boolean, byte) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanBytePredicate
Returns the result of applying this predicate to input.
apply(boolean, double) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanDoubleConsumer
Applies this function to input1 and input2
apply(boolean, double) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanDoublePredicate
Returns the result of applying this predicate to input.
apply(boolean, float) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanFloatConsumer
Applies this function to input1 and input2
apply(boolean, float) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanFloatPredicate
Returns the result of applying this predicate to input.
apply(boolean, int) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanIntConsumer
Applies this function to input1 and input2
apply(boolean, int) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanIntPredicate
Returns the result of applying this predicate to input.
apply(boolean, long) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanLongConsumer
Applies this function to input1 and input2
apply(boolean, long) - Method in interface org.apache.giraph.function.primitive.pairs.BooleanLongPredicate
Returns the result of applying this predicate to input.
apply(byte, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.ByteBooleanConsumer
Applies this function to input1 and input2
apply(byte, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.ByteBooleanPredicate
Returns the result of applying this predicate to input.
apply(byte, byte) - Method in interface org.apache.giraph.function.primitive.pairs.ByteByteConsumer
Applies this function to input1 and input2
apply(byte, byte) - Method in interface org.apache.giraph.function.primitive.pairs.ByteBytePredicate
Returns the result of applying this predicate to input.
apply(byte, double) - Method in interface org.apache.giraph.function.primitive.pairs.ByteDoubleConsumer
Applies this function to input1 and input2
apply(byte, double) - Method in interface org.apache.giraph.function.primitive.pairs.ByteDoublePredicate
Returns the result of applying this predicate to input.
apply(byte, float) - Method in interface org.apache.giraph.function.primitive.pairs.ByteFloatConsumer
Applies this function to input1 and input2
apply(byte, float) - Method in interface org.apache.giraph.function.primitive.pairs.ByteFloatPredicate
Returns the result of applying this predicate to input.
apply(byte, int) - Method in interface org.apache.giraph.function.primitive.pairs.ByteIntConsumer
Applies this function to input1 and input2
apply(byte, int) - Method in interface org.apache.giraph.function.primitive.pairs.ByteIntPredicate
Returns the result of applying this predicate to input.
apply(byte, long) - Method in interface org.apache.giraph.function.primitive.pairs.ByteLongConsumer
Applies this function to input1 and input2
apply(byte, long) - Method in interface org.apache.giraph.function.primitive.pairs.ByteLongPredicate
Returns the result of applying this predicate to input.
apply(double, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleBooleanConsumer
Applies this function to input1 and input2
apply(double, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleBooleanPredicate
Returns the result of applying this predicate to input.
apply(double, byte) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleByteConsumer
Applies this function to input1 and input2
apply(double, byte) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleBytePredicate
Returns the result of applying this predicate to input.
apply(double, double) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleDoubleConsumer
Applies this function to input1 and input2
apply(double, double) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleDoublePredicate
Returns the result of applying this predicate to input.
apply(double, float) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleFloatConsumer
Applies this function to input1 and input2
apply(double, float) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleFloatPredicate
Returns the result of applying this predicate to input.
apply(double, int) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleIntConsumer
Applies this function to input1 and input2
apply(double, int) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleIntPredicate
Returns the result of applying this predicate to input.
apply(double, long) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleLongConsumer
Applies this function to input1 and input2
apply(double, long) - Method in interface org.apache.giraph.function.primitive.pairs.DoubleLongPredicate
Returns the result of applying this predicate to input.
apply(float, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.FloatBooleanConsumer
Applies this function to input1 and input2
apply(float, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.FloatBooleanPredicate
Returns the result of applying this predicate to input.
apply(float, byte) - Method in interface org.apache.giraph.function.primitive.pairs.FloatByteConsumer
Applies this function to input1 and input2
apply(float, byte) - Method in interface org.apache.giraph.function.primitive.pairs.FloatBytePredicate
Returns the result of applying this predicate to input.
apply(float, double) - Method in interface org.apache.giraph.function.primitive.pairs.FloatDoubleConsumer
Applies this function to input1 and input2
apply(float, double) - Method in interface org.apache.giraph.function.primitive.pairs.FloatDoublePredicate
Returns the result of applying this predicate to input.
apply(float, float) - Method in interface org.apache.giraph.function.primitive.pairs.FloatFloatConsumer
Applies this function to input1 and input2
apply(float, float) - Method in interface org.apache.giraph.function.primitive.pairs.FloatFloatPredicate
Returns the result of applying this predicate to input.
apply(float, int) - Method in interface org.apache.giraph.function.primitive.pairs.FloatIntConsumer
Applies this function to input1 and input2
apply(float, int) - Method in interface org.apache.giraph.function.primitive.pairs.FloatIntPredicate
Returns the result of applying this predicate to input.
apply(float, long) - Method in interface org.apache.giraph.function.primitive.pairs.FloatLongConsumer
Applies this function to input1 and input2
apply(float, long) - Method in interface org.apache.giraph.function.primitive.pairs.FloatLongPredicate
Returns the result of applying this predicate to input.
apply(int, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.IntBooleanConsumer
Applies this function to input1 and input2
apply(int, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.IntBooleanPredicate
Returns the result of applying this predicate to input.
apply(int, byte) - Method in interface org.apache.giraph.function.primitive.pairs.IntByteConsumer
Applies this function to input1 and input2
apply(int, byte) - Method in interface org.apache.giraph.function.primitive.pairs.IntBytePredicate
Returns the result of applying this predicate to input.
apply(int, double) - Method in interface org.apache.giraph.function.primitive.pairs.IntDoubleConsumer
Applies this function to input1 and input2
apply(int, double) - Method in interface org.apache.giraph.function.primitive.pairs.IntDoublePredicate
Returns the result of applying this predicate to input.
apply(int, float) - Method in interface org.apache.giraph.function.primitive.pairs.IntFloatConsumer
Applies this function to input1 and input2
apply(int, float) - Method in interface org.apache.giraph.function.primitive.pairs.IntFloatPredicate
Returns the result of applying this predicate to input.
apply(int, int) - Method in interface org.apache.giraph.function.primitive.pairs.IntIntConsumer
Applies this function to input1 and input2
apply(int, int) - Method in interface org.apache.giraph.function.primitive.pairs.IntIntPredicate
Returns the result of applying this predicate to input.
apply(int, long) - Method in interface org.apache.giraph.function.primitive.pairs.IntLongConsumer
Applies this function to input1 and input2
apply(int, long) - Method in interface org.apache.giraph.function.primitive.pairs.IntLongPredicate
Returns the result of applying this predicate to input.
apply(long, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.LongBooleanConsumer
Applies this function to input1 and input2
apply(long, boolean) - Method in interface org.apache.giraph.function.primitive.pairs.LongBooleanPredicate
Returns the result of applying this predicate to input.
apply(long, byte) - Method in interface org.apache.giraph.function.primitive.pairs.LongByteConsumer
Applies this function to input1 and input2
apply(long, byte) - Method in interface org.apache.giraph.function.primitive.pairs.LongBytePredicate
Returns the result of applying this predicate to input.
apply(long, double) - Method in interface org.apache.giraph.function.primitive.pairs.LongDoubleConsumer
Applies this function to input1 and input2
apply(long, double) - Method in interface org.apache.giraph.function.primitive.pairs.LongDoublePredicate
Returns the result of applying this predicate to input.
apply(long, float) - Method in interface org.apache.giraph.function.primitive.pairs.LongFloatConsumer
Applies this function to input1 and input2
apply(long, float) - Method in interface org.apache.giraph.function.primitive.pairs.LongFloatPredicate
Returns the result of applying this predicate to input.
apply(long, int) - Method in interface org.apache.giraph.function.primitive.pairs.LongIntConsumer
Applies this function to input1 and input2
apply(long, int) - Method in interface org.apache.giraph.function.primitive.pairs.LongIntPredicate
Returns the result of applying this predicate to input.
apply(long, long) - Method in interface org.apache.giraph.function.primitive.pairs.LongLongConsumer
Applies this function to input1 and input2
apply(long, long) - Method in interface org.apache.giraph.function.primitive.pairs.LongLongPredicate
Returns the result of applying this predicate to input.
apply(short) - Method in interface org.apache.giraph.function.primitive.Short2ObjFunction
Returns the result of applying this function to given input.
apply(short) - Method in interface org.apache.giraph.function.primitive.Short2ShortFunction
Returns the result of applying this function to given input.
apply(short) - Method in interface org.apache.giraph.function.primitive.ShortConsumer
Applies this function to input
apply(short) - Method in interface org.apache.giraph.function.primitive.ShortPredicate
Returns the result of applying this predicate to input.
apply(F1, F2, F3) - Method in interface org.apache.giraph.function.TripleFunction
Returns the result of applying this function to given input1, input2 and input3.
apply(Vertex<I, V, E>, T) - Method in interface org.apache.giraph.function.vertex.ConsumerWithVertex
Applies this function to vertex and input
apply(Vertex<I, V, E>, F) - Method in interface org.apache.giraph.function.vertex.FunctionWithVertex
Returns the result of applying this function to given vertex and input.
apply(int) - Method in class org.apache.giraph.object.MultiSizedReusable
 
approve(IOCommand) - Method in class org.apache.giraph.ooc.policy.FixedPartitionsOracle
 
approve(IOCommand) - Method in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
 
approve(IOCommand) - Method in interface org.apache.giraph.ooc.policy.OutOfCoreOracle
Whether a command is appropriate to bring the memory to a more desired state.
approve(IOCommand) - Method in class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
 
approve(IOCommand) - Method in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
 
ARGS - Static variable in class org.apache.giraph.utils.JMap
Arguments to pass in to command
ArrayHandle<T> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.array
Handle to array of handles underneath
ArrayListEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
OutEdges implementation backed by an ArrayList.
ArrayListEdges() - Constructor for class org.apache.giraph.edge.ArrayListEdges
 
ArrayListWritable<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
A Writable for ListArray containing instances of a class.
ArrayListWritable() - Constructor for class org.apache.giraph.utils.ArrayListWritable
Using the default constructor requires that the user implement setClass(), guaranteed to be invoked prior to instantiation in readFields()
ArrayListWritable(ArrayListWritable<M>) - Constructor for class org.apache.giraph.utils.ArrayListWritable
Constructor with another ArrayListWritable.
ArrayListWritable(Class<M>) - Constructor for class org.apache.giraph.utils.ArrayListWritable
This constructor allows setting the refClass during construction.
ArrayOfBroadcasts(int, Int2ObjFunction<BroadcastHandle<T>>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfBroadcasts
 
ArrayOfBroadcasts(int, Supplier<BroadcastHandle<T>>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfBroadcasts
 
ArrayOfHandles<H> - Class in org.apache.giraph.block_app.reducers.array
ArrayHandle implemented as an array of individual handles.
ArrayOfHandles(int, Supplier<H>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
ArrayOfHandles(int, Int2ObjFunction<H>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
ArrayOfHandles.ArrayOfBroadcasts<T> - Class in org.apache.giraph.block_app.reducers.array
BroadcastArrayHandle implemented as an array of separate broadcast handles.
ArrayOfHandles.ArrayOfReducers<S,R> - Class in org.apache.giraph.block_app.reducers.array
ReducerArrayHandle implemented as an array of separate reducer handles.
ArrayOfReducers(int, Supplier<ReducerHandle<S, R>>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfReducers
 
ArrayOfReducers(int, Int2ObjFunction<ReducerHandle<S, R>>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfReducers
 
ArrayReduce<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.reducers.array
One reducer representing reduction of array of individual values.
ArrayReduce() - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
ArrayReduce(int, ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.reducers.array.ArrayReduce
Create ReduceOperation that reduces arrays by reducing individual elements.
ArraysAsListSerializer - Class in org.apache.giraph.writable.kryo.serializers
Special serializer for Arrays.asList() as they can not be deserialized in a standard way.
ArraysAsListSerializer() - Constructor for class org.apache.giraph.writable.kryo.serializers.ArraysAsListSerializer
 
ArrayWritable<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
A Writable for arrays containing instances of a class.
ArrayWritable() - Constructor for class org.apache.giraph.utils.ArrayWritable
Constructor
ArrayWritable(Class<T>, T[]) - Constructor for class org.apache.giraph.utils.ArrayWritable
Constructor
AskForInputSplitRequest - Class in org.apache.giraph.comm.requests
A request which workers will send to master to ask it to give them splits
AskForInputSplitRequest(InputType, int, boolean) - Constructor for class org.apache.giraph.comm.requests.AskForInputSplitRequest
Constructor
AskForInputSplitRequest() - Constructor for class org.apache.giraph.comm.requests.AskForInputSplitRequest
Constructor used for reflection only
ASYNC_MESSAGE_STORE_THREADS_COUNT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of threads to use in async message store, 0 means we should not use async message processing
AsyncMessageStoreWrapper<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages.queue
This class decouples message receiving and processing into separate threads thus reducing contention.
AsyncMessageStoreWrapper(MessageStore<I, M>, Iterable<Integer>, int) - Constructor for class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
Constructs async wrapper around existing message store object.
AT_THE_END - Static variable in class org.apache.giraph.aggregators.TextAggregatorWriter
Signal for "write only the final values" frequency
authenticate() - Method in class org.apache.giraph.comm.netty.NettyClient
Authenticate all servers in addressChannelMap.
authenticate() - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
authenticate() - Method in interface org.apache.giraph.comm.WorkerClient
Authenticates, as client, with another BSP worker, as server.
authenticate() - Method in class org.apache.giraph.conf.GiraphConfiguration
Use authentication? (if supported)
AUTHENTICATE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Whether to use SASL with DIGEST and Hadoop Job Tokens to authenticate and authorize Netty BSP Clients to Servers.
AuthorizeServerHandler - Class in org.apache.giraph.comm.netty.handler
Authorize or deny client requests based on existence and completeness of client's SASL authentication.
AuthorizeServerHandler() - Constructor for class org.apache.giraph.comm.netty.handler.AuthorizeServerHandler
Constructor.
available() - Method in interface org.apache.giraph.utils.ExtendedDataInput
How many bytes are available?
available() - Method in class org.apache.giraph.utils.io.BigDataInput
 
available() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
available() - Method in class org.apache.giraph.utils.UnsafeReads
How many bytes are still available?
awaitChannelFuture(ChannelFuture, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait for ChannelFuture to finish, while periodically reporting progress.
awaitChannelGroupFuture(ChannelGroupFuture, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait for ChannelGroupFuture to finish, while periodically reporting progress.
awaitExecutorTermination(ExecutorService, Progressable, int) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait for executor tasks to terminate, while periodically reporting progress.
awaitExecutorTermination(ExecutorService, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait for executor tasks to terminate, while periodically reporting progress.
awaitSemaphorePermits(Semaphore, int, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait to acquire enough permits from Semaphore, while periodically reporting progress.
awaitTermination(long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
awaitTerminationFuture(EventExecutorGroup, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait for executorgroup to terminate, while periodically reporting progress

B

balancePartitionsAcrossWorkers(Configuration, Collection<PartitionOwner>, Collection<PartitionStats>, Collection<WorkerInfo>) - Static method in class org.apache.giraph.partition.PartitionBalancer
Balance the partitions with an algorithm based on a value.
BASE_DIR - Static variable in class org.apache.giraph.bsp.BspService
Base ZooKeeper directory
BASE_ZNODE_KEY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Base ZNode for Giraph's state in the ZooKeeper cluster.
basePath - Variable in class org.apache.giraph.bsp.BspService
Path to the job's root
Basic2ObjectMap<K,V> - Class in org.apache.giraph.types.ops.collections
Basic2ObjectMap with only basic set of operations.
Basic2ObjectMap() - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap
 
Basic2ObjectMap.BasicInt2ObjectOpenHashMap<V> - Class in org.apache.giraph.types.ops.collections
IntWritable implementation of Basic2ObjectMap
Basic2ObjectMap.BasicLong2ObjectOpenHashMap<V> - Class in org.apache.giraph.types.ops.collections
LongWritable implementation of Basic2ObjectMap
Basic2ObjectMap.BasicObject2ObjectOpenHashMap<K extends org.apache.hadoop.io.Writable,V> - Class in org.apache.giraph.types.ops.collections
Writable implementation of Basic2ObjectMap
Basic2ObjectMap.ReusableIterator<Iter extends Iterator<?>> - Class in org.apache.giraph.types.ops.collections
Iterator that reuses key object.
BasicAggregator<A extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.aggregators
Abstract class for Aggregator.
BasicAggregator() - Constructor for class org.apache.giraph.aggregators.BasicAggregator
Default constructor.
BasicAggregator(A) - Constructor for class org.apache.giraph.aggregators.BasicAggregator
Constructor
BasicArrayReduce<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.reducers.array
Efficient generic primitive array reduce operation.
BasicArrayReduce() - Constructor for class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
BasicArrayReduce(int, PrimitiveTypeOps<R>, ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
Create ReduceOperation that reduces BasicArrays by reducing individual elements, with predefined size.
BasicArrayReduce(PrimitiveTypeOps<R>, ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
Create ReduceOperation that reduces BasicArrays by reducing individual elements, with unbounded size.
BasicCollectionsUtils - Class in org.apache.giraph.types.ops.collections
Utility functions for constructing basic collections
BasicComputation<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.graph
Computation in which both incoming and outgoing message types are the same.
BasicComputation() - Constructor for class org.apache.giraph.graph.BasicComputation
 
BasicInputSplitsMasterOrganizer - Class in org.apache.giraph.master.input
Input splits organizer for vertex and edge input splits on master, which doesn't use locality information
BasicInputSplitsMasterOrganizer(List<byte[]>) - Constructor for class org.apache.giraph.master.input.BasicInputSplitsMasterOrganizer
Constructor
BasicInt2ObjectOpenHashMap(WritableWriter<V>) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
Constructor
BasicInt2ObjectOpenHashMap(int, WritableWriter<V>) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
Constructor
BasicIntOpenHashSet() - Constructor for class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
Constructor
BasicIntOpenHashSet(long) - Constructor for class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
Constructor
BasicLong2ObjectOpenHashMap(WritableWriter<V>) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
Constructor
BasicLong2ObjectOpenHashMap(int, WritableWriter<V>) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
Constructor
BasicLongOpenHashSet() - Constructor for class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
Constructor
BasicLongOpenHashSet(long) - Constructor for class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
Constructor
BasicMapReduce<K extends org.apache.hadoop.io.WritableComparable,S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.reducers.map
Efficient generic primitive map of values reduce operation.
BasicMapReduce() - Constructor for class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
BasicMapReduce(PrimitiveIdTypeOps<K>, PrimitiveTypeOps<R>, ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.reducers.map.BasicMapReduce
Create ReduceOperation that reduces BasicMaps by reducing individual elements corresponding to the same key.
BasicObject2ObjectOpenHashMap(WritableWriter<K>, WritableWriter<V>) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
Constructor
BasicObject2ObjectOpenHashMap(int, WritableWriter<K>, WritableWriter<V>) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
Constructor
BasicPartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Basic partition class for other partitions to extend.
BasicPartition() - Constructor for class org.apache.giraph.partition.BasicPartition
 
BasicPartitionOwner - Class in org.apache.giraph.partition
Basic partition owner, can be subclassed for more complicated partition owner implementations.
BasicPartitionOwner() - Constructor for class org.apache.giraph.partition.BasicPartitionOwner
Default constructor.
BasicPartitionOwner(int, WorkerInfo) - Constructor for class org.apache.giraph.partition.BasicPartitionOwner
Constructor with partition id and worker info.
BasicPartitionOwner(int, WorkerInfo, WorkerInfo, String) - Constructor for class org.apache.giraph.partition.BasicPartitionOwner
Constructor with partition id and worker info.
BasicSet<T> - Interface in org.apache.giraph.types.ops.collections
BasicSet with only basic set of operations.
BasicSet.BasicIntOpenHashSet - Class in org.apache.giraph.types.ops.collections
IntWritable implementation of BasicSet
BasicSet.BasicLongOpenHashSet - Class in org.apache.giraph.types.ops.collections
LongWritable implementation of BasicSet
BasicVertexValueReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Abstract base class for VertexValueReader.
BasicVertexValueReader() - Constructor for class org.apache.giraph.io.BasicVertexValueReader
 
becomeMaster() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Become the master.
becomeMaster() - Method in class org.apache.giraph.master.BspServiceMaster
 
BenchmarkOption - Class in org.apache.giraph.benchmark
Command line options for benchmarks
BenchmarkOption(String, String, boolean, String) - Constructor for class org.apache.giraph.benchmark.BenchmarkOption
Constructor for option which is not required
BenchmarkOption(String, String, boolean, String, String) - Constructor for class org.apache.giraph.benchmark.BenchmarkOption
Constructor for option which is not required
BigDataInput - Class in org.apache.giraph.utils.io
Implementations of ExtendedDataInput are limited because they can only handle up to 1GB of data.
BigDataInput(BigDataOutput) - Constructor for class org.apache.giraph.utils.io.BigDataInput
Constructor
BigDataInputOutput - Class in org.apache.giraph.utils.io
DataInputOutput which uses BigDataInput and BigDataOutput to support larger than allowed array size streams.
BigDataInputOutput(ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.utils.io.BigDataInputOutput
Constructor
BigDataOutput - Class in org.apache.giraph.utils.io
Implementations of ExtendedDataOutput are limited because they can only handle up to 1GB of data.
BigDataOutput(ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.utils.io.BigDataOutput
Constructor
BigDataOutput(int, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.utils.io.BigDataOutput
Constructor
Block - Interface in org.apache.giraph.block_app.framework.block
Composable unit of execution.
BLOCK_FACTORY_CLASS - Static variable in class org.apache.giraph.block_app.framework.BlockUtils
Property describing BlockFactory to use for current application run
BLOCK_WORKER_CONTEXT_VALUE_CLASS - Static variable in class org.apache.giraph.block_app.framework.BlockUtils
Property describing block worker context value class to use
BlockApi - Interface in org.apache.giraph.block_app.framework.api
Basic block computation API for accessing items present on both workers and master.
BlockApiHandle - Class in org.apache.giraph.block_app.framework.api
Class that contains references to Block Api objects.
BlockApiHandle() - Constructor for class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
BlockComputation - Class in org.apache.giraph.block_app.framework.api.giraph
Computation that executes receiver and sender blocks passed into BlockWorkerPieces.
BlockComputation() - Constructor for class org.apache.giraph.block_app.framework.api.giraph.BlockComputation
 
BlockConfApi - Interface in org.apache.giraph.block_app.framework.api
Block computation API for accessing configuration.
BlockCounters - Class in org.apache.giraph.block_app.framework.internal
Utility class for Blocks Framework related counters
BlockFactory<S> - Interface in org.apache.giraph.block_app.framework
Class describing a particular application.
BlockingElementsSet<T> - Class in org.apache.giraph.utils
Keeps a set of elements, and allows for waiting on certain number of elements to become available.
BlockingElementsSet() - Constructor for class org.apache.giraph.utils.BlockingElementsSet
 
BlockMasterApi - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for the master methods.
BlockMasterCompute<S> - Class in org.apache.giraph.block_app.framework.api.giraph
MasterCompute class which executes block computation.
BlockMasterCompute() - Constructor for class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
BlockMasterLogic<S> - Class in org.apache.giraph.block_app.framework.internal
Block execution logic on master, iterating over Pieces of the application Block, executing master logic, and providing what needs to be executed on the workers.
BlockMasterLogic() - Constructor for class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
 
BlockMasterLogic.TimeStatsPerEvent - Class in org.apache.giraph.block_app.framework.internal
Class tracking invocation count and elapsed time for a set of events, each event being having a String name.
BlockOutputApi - Interface in org.apache.giraph.block_app.framework.api
Block worker output api
BlockOutputDesc<OW extends BlockOutputWriter> - Interface in org.apache.giraph.block_app.framework.output
Output description
BlockOutputFormat - Class in org.apache.giraph.block_app.framework.output
Hadoop output format to use with block output.
BlockOutputFormat() - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
BlockOutputHandle - Class in org.apache.giraph.block_app.framework.output
Handler for blocks output - keeps track of outputs and writers created
BlockOutputHandle() - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
BlockOutputHandle(String, Configuration, Progressable) - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
BlockOutputHandleAccessor - Interface in org.apache.giraph.block_app.framework.api
Function for accessing BlockOutputHandle.
BlockOutputOption<OD extends BlockOutputDesc<OW>,OW extends BlockOutputWriter> - Class in org.apache.giraph.block_app.framework.output
Block output option, with apis to use from application code
BlockOutputOption(String) - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
BlockOutputWriter - Interface in org.apache.giraph.block_app.framework.output
Block output writer
BlockUtils - Class in org.apache.giraph.block_app.framework
Utility functions for block applications
BlockWithApiHandle - Interface in org.apache.giraph.block_app.framework.block
Applications that need access to a BlockApiHandle should return a Block of this type.
BlockWorkerApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker methods.
BlockWorkerContext - Class in org.apache.giraph.block_app.framework.api.giraph
WorkerContext that executes receiver and sender blocks passed into BlockWorkerPieces.
BlockWorkerContext() - Constructor for class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
BlockWorkerContextApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker context methods.
BlockWorkerContextLogic - Class in org.apache.giraph.block_app.framework.internal
Block execution logic on WorkerContext.
BlockWorkerContextLogic() - Constructor for class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
BlockWorkerContextReceiveApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker context receive methods.
BlockWorkerContextSendApi<I extends org.apache.hadoop.io.WritableComparable,WM extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker send methods.
BlockWorkerLogic - Class in org.apache.giraph.block_app.framework.internal
Block execution logic on workers.
BlockWorkerLogic(BlockWorkerPieces) - Constructor for class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
BlockWorkerPieces<S> - Class in org.apache.giraph.block_app.framework.internal
Pair of pieces to be executed on workers in a superstep
BlockWorkerPieces(PairedPieceAndStage<S>, PairedPieceAndStage<S>, BlockApiHandle) - Constructor for class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
BlockWorkerReceiveApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker receive methods.
BlockWorkerSendApi<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> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker send methods.
BlockWorkerValueAccessor - Interface in org.apache.giraph.block_app.framework.api
Function for accessing WorkerValue.
Boolean2BooleanFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (boolean) -> boolean
Boolean2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (boolean) -> T
BOOLEAN_BOOLEAN_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Boolean,BooleanWritable
BooleanAndAggregator - Class in org.apache.giraph.aggregators
Aggregator for calculating the AND function over boolean values.
BooleanAndAggregator() - Constructor for class org.apache.giraph.aggregators.BooleanAndAggregator
 
BooleanBooleanConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, boolean) -> void
BooleanBooleanPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, boolean) -> boolean
BooleanByteConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, byte) -> void
BooleanBytePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, byte) -> boolean
BooleanConfOption - Class in org.apache.giraph.conf
Boolean configuration option
BooleanConfOption(String, boolean, String) - Constructor for class org.apache.giraph.conf.BooleanConfOption
Constructor
BooleanConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (boolean) -> void
BooleanDoubleConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, double) -> void
BooleanDoublePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, double) -> boolean
BooleanFloatConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, float) -> void
BooleanFloatPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, float) -> boolean
BooleanIntConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, int) -> void
BooleanIntPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, int) -> boolean
BooleanLongConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, long) -> void
BooleanLongPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (boolean, long) -> boolean
BooleanOrAggregator - Class in org.apache.giraph.aggregators
Aggregator for calculating the OR function over boolean values.
BooleanOrAggregator() - Constructor for class org.apache.giraph.aggregators.BooleanOrAggregator
 
BooleanOverwriteAggregator - Class in org.apache.giraph.aggregators
Aggregator that stores a value that is overwritten once another value is aggregated.
BooleanOverwriteAggregator() - Constructor for class org.apache.giraph.aggregators.BooleanOverwriteAggregator
 
BooleanPredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (boolean) -> boolean
BooleanToBooleanWritableWrapper - Class in org.apache.giraph.types
Converts Booleans to BooleanWritables
BooleanToBooleanWritableWrapper() - Constructor for class org.apache.giraph.types.BooleanToBooleanWritableWrapper
 
BooleanTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with BooleanWritable type
BooleanWritableToBooleanUnwrapper - Class in org.apache.giraph.types
Converts BooleanWritables to Booleans.
BooleanWritableToBooleanUnwrapper() - Constructor for class org.apache.giraph.types.BooleanWritableToBooleanUnwrapper
 
Boxed<T> - Interface in org.apache.giraph.writable.kryo
Boxed interface
BRACHA_TOUEG_DL_INITIATOR_ID - Static variable in class org.apache.giraph.examples.BrachaTouegDeadlockComputation
The deadlock detection initiator id
BrachaTouegDeadlockComputation - Class in org.apache.giraph.examples
This code demonstrates the Bracha Toueg deadlock detection algorithm.
BrachaTouegDeadlockComputation() - Constructor for class org.apache.giraph.examples.BrachaTouegDeadlockComputation
 
BrachaTouegDeadlockInputFormat - Class in org.apache.giraph.examples.io.formats
VertexInputFormat for the Bracha Toueg Deadlock Detection algorithm specified in JSON format.
BrachaTouegDeadlockInputFormat() - Constructor for class org.apache.giraph.examples.io.formats.BrachaTouegDeadlockInputFormat
 
BrachaTouegDeadlockMessage - Class in org.apache.giraph.examples.utils
Data sent via a message that includes the source vertex id.
BrachaTouegDeadlockMessage() - Constructor for class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
Default empty constructor.
BrachaTouegDeadlockMessage(long, long) - Constructor for class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
 
BrachaTouegDeadlockVertexValue - Class in org.apache.giraph.examples.utils
Vertex value used for the Bracha-Toueg Dealock algorithm
BrachaTouegDeadlockVertexValue() - Constructor for class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
Default constructor
BrachaTouegDeadlockVertexValue(HashMap<Long, ArrayList<Long>>) - Constructor for class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
Parametrized constructor
broadcast(T) - Method in interface org.apache.giraph.block_app.framework.api.BlockMasterApi
Broadcast given value to all workers for next computation.
broadcast(String, Writable) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
broadcast(int, Int2ObjFunction<V>, BlockMasterApi) - Static method in class org.apache.giraph.block_app.reducers.array.HugeArrayUtils
Broadcast a huge array, by splitting into NUM_STRIPES number of parts.
broadcast(int, Int2ObjFunction<V>, PrimitiveTypeOps<V>, BlockMasterApi) - Static method in class org.apache.giraph.block_app.reducers.array.HugeArrayUtils
Broadcast a huge array, by splitting into NUM_STRIPES number of parts.
broadcast(String, Writable) - Method in class org.apache.giraph.master.MasterAggregatorHandler
 
broadcast(String, Writable) - Method in class org.apache.giraph.master.MasterCompute
 
broadcast(String, Writable) - Method in class org.apache.giraph.master.MasterGlobalCommHandler
 
broadcast(String, Writable) - Method in interface org.apache.giraph.master.MasterGlobalCommUsageAggregators
Broadcast given value to all workers for next computation.
BroadcastArrayHandle<T> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.array
Handle to array of broadcasts
BroadcastHandle<T> - Interface in org.apache.giraph.block_app.framework.piece.global_comm
Handle to a broadcast.
BroadcastHandleImpl() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.BroadcastHandleImpl
 
BroadcastMapHandle<K,V> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.map
Handle to map of broadcasts
broadcasts - Variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle
 
broadcastValue(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ReducerArrayHandle
Broadcast whole array of reducers to master
broadcastValue(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
broadcastValue(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.ReducerMapHandle
Broadcast whole map of reducers to master
broadcastValue(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Broadcast reduced value from master
broadcastValue(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle
Broadcast reduced value from master
broadcastValue(BlockMasterApi) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfReducers
 
broadcastValue(BlockMasterApi) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Broadcast reduced value from master
broadcastValue(BlockMasterApi) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
BspEvent - Interface in org.apache.giraph.zk
Synchronize on waiting for an event to have happened.
BspInputFormat - Class in org.apache.giraph.bsp
This InputFormat supports the BSP model by ensuring that the user specifies how many splits (number of mappers) should be started simultaneously.
BspInputFormat() - Constructor for class org.apache.giraph.bsp.BspInputFormat
 
BspInputSplit - Class in org.apache.giraph.bsp
This InputSplit will not give any ordering or location data.
BspInputSplit() - Constructor for class org.apache.giraph.bsp.BspInputSplit
Reflection constructor.
BspInputSplit(int, int) - Constructor for class org.apache.giraph.bsp.BspInputSplit
Constructor used by BspInputFormat.
BspOutputFormat - Class in org.apache.giraph.bsp
This is for internal use only.
BspOutputFormat() - Constructor for class org.apache.giraph.bsp.BspOutputFormat
 
BspRecordWriter - Class in org.apache.giraph.bsp
Used by BspOutputFormat since some versions of Hadoop require that a RecordWriter is returned from getRecordWriter.
BspRecordWriter() - Constructor for class org.apache.giraph.bsp.BspRecordWriter
 
BspService<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.bsp
Zookeeper-based implementation of CentralizedService.
BspService(Mapper<?, ?, ?, ?>.Context, GraphTaskManager<I, V, E>) - Constructor for class org.apache.giraph.bsp.BspService
Constructor.
BspServiceMaster<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.master
ZooKeeper-based implementation of CentralizedServiceMaster.
BspServiceMaster(Mapper<?, ?, ?, ?>.Context, GraphTaskManager<I, V, E>) - Constructor for class org.apache.giraph.master.BspServiceMaster
Constructor for setting up the master.
BspServiceWorker<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
ZooKeeper-based implementation of CentralizedServiceWorker.
BspServiceWorker(Mapper<?, ?, ?, ?>.Context, GraphTaskManager<I, V, E>) - Constructor for class org.apache.giraph.worker.BspServiceWorker
Constructor for setting up the worker.
BulkConfigurator - Interface in org.apache.giraph.conf
Function that modifies configuration.
Byte2ByteFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (byte) -> byte
Byte2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (byte) -> T
BYTE_BYTE_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Byte,ByteWritable
BYTE_INT_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Byte,IntWritable
BYTE_LONG_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Byte,LongWritable
ByteArrayEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
OutEdges implementation backed by a byte array.
ByteArrayEdges() - Constructor for class org.apache.giraph.edge.ByteArrayEdges
 
ByteArrayMessagesPerVertexStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
Implementation of SimpleMessageStore where multiple messages are stored per vertex as byte backed datastructures.
ByteArrayMessagesPerVertexStore(MessageValueFactory<M>, PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
Constructor
ByteArrayMessagesPerVertexStore.Factory<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
ByteArrayOneMessageToManyIds<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Stores a message and a list of target vertex ids.
ByteArrayOneMessageToManyIds(MessageValueFactory<M>) - Constructor for class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
Constructor.
ByteArrayPartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Byte array based partition.
ByteArrayPartition() - Constructor for class org.apache.giraph.partition.ByteArrayPartition
Constructor for reflection.
ByteArrayRequest - Class in org.apache.giraph.comm.requests
Abstract request which has a byte array as its data
ByteArrayVertexIdData<I extends org.apache.hadoop.io.WritableComparable,T> - Class in org.apache.giraph.utils
Stores pairs of vertex id and generic data in a single byte array
ByteArrayVertexIdData() - Constructor for class org.apache.giraph.utils.ByteArrayVertexIdData
 
ByteArrayVertexIdEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Stores vertex id and edge pairs in a single byte array.
ByteArrayVertexIdEdges() - Constructor for class org.apache.giraph.utils.ByteArrayVertexIdEdges
 
ByteArrayVertexIdMessages<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Stores vertex id and message pairs in a single byte array.
ByteArrayVertexIdMessages(MessageValueFactory<M>) - Constructor for class org.apache.giraph.utils.ByteArrayVertexIdMessages
Constructor
ByteArrayWithSenderTaskIdRequest - Class in org.apache.giraph.comm.requests
Abstract request which has a byte array and task id of the sender as its data
ByteArrayWithSenderTaskIdRequest(byte[], int) - Constructor for class org.apache.giraph.comm.requests.ByteArrayWithSenderTaskIdRequest
Constructor
ByteArrayWithSenderTaskIdRequest() - Constructor for class org.apache.giraph.comm.requests.ByteArrayWithSenderTaskIdRequest
Default constructor
byteBookkeeper(ByteBuf) - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Updates properties based on bytes sent / received
ByteBooleanConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, boolean) -> void
ByteBooleanPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, boolean) -> boolean
ByteByteConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, byte) -> void
ByteBytePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, byte) -> boolean
ByteConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (byte) -> void
ByteCounter - Interface in org.apache.giraph.comm.netty
ByteCounter interface
ByteCounterDelegate - Class in org.apache.giraph.comm.netty
Delegate Object to help keep track of the bytes processed and provide some metrics when desired as part of the Netty Channel stack.
ByteCounterDelegate(boolean) - Constructor for class org.apache.giraph.comm.netty.ByteCounterDelegate
Constructor to specify if delegate is created by InBound/ Outbound counter
ByteDoubleConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, double) -> void
ByteDoublePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, double) -> boolean
ByteFloatConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, float) -> void
ByteFloatPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, float) -> boolean
ByteIntConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, int) -> void
ByteIntPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, int) -> boolean
ByteLongConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, long) -> void
ByteLongPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (byte, long) -> boolean
BytePredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (byte) -> boolean
BYTES_LOAD_FROM_DISK - Static variable in class org.apache.giraph.ooc.OutOfCoreIOCallable
Name of Metric for number of bytes read from disk
BYTES_STORE_TO_DISK - Static variable in class org.apache.giraph.ooc.OutOfCoreIOCallable
Name of Metric for number of bytes written to disk
bytesTransferred() - Method in class org.apache.giraph.ooc.command.IOCommand
Get the number of bytes transferred (loaded/stored from/to disk).
ByteStructIterable<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
This iterable is designed to deserialize a byte array on the fly to provide new copies of writable objects when desired.
ByteStructIterable(Factory<? extends ExtendedDataInput>) - Constructor for class org.apache.giraph.utils.ByteStructIterable
Constructor
ByteStructIterator<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
This iterator is designed to deserialize a byte array on the fly to provide new copies of writable objects when desired.
ByteStructIterator(ExtendedDataInput) - Constructor for class org.apache.giraph.utils.ByteStructIterator
Wrap ExtendedDataInput in ByteArrayIterator
ByteStructVertexIdDataIterator<I extends org.apache.hadoop.io.WritableComparable,T> - Class in org.apache.giraph.utils
Special iterator that reuses vertex ids and data objects so that the lifetime of the object is only until next() is called.
ByteStructVertexIdDataIterator(AbstractVertexIdData<I, T>) - Constructor for class org.apache.giraph.utils.ByteStructVertexIdDataIterator
Constructor
ByteStructVertexIdEdgeIterator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Special iterator that reuses vertex ids and edge objects so that the lifetime of the object is only until next() is called.
ByteStructVertexIdEdgeIterator(AbstractVertexIdData<I, Edge<I, E>>) - Constructor for class org.apache.giraph.utils.ByteStructVertexIdEdgeIterator
Constructor
ByteStructVertexIdIterator<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.utils
Common implementation for VertexIdEdgeIterator, VertexIdMessageIterator and VertexIdMessageBytesIterator.
ByteStructVertexIdIterator(ExtendedDataOutput, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.utils.ByteStructVertexIdIterator
Constructor.
ByteStructVertexIdMessageBytesIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Special iterator that reuses vertex ids and messages bytes so that the lifetime of the object is only until next() is called.
ByteStructVertexIdMessageBytesIterator(AbstractVertexIdData<I, M>) - Constructor for class org.apache.giraph.utils.ByteStructVertexIdMessageBytesIterator
Constructor with vertexIdData
ByteStructVertexIdMessageIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Special iterator that reuses vertex ids and message objects so that the lifetime of the object is only until next() is called.
ByteStructVertexIdMessageIterator(AbstractVertexIdData<I, M>) - Constructor for class org.apache.giraph.utils.ByteStructVertexIdMessageIterator
Constructor with vertexIdData
ByteToByteWritableWrapper - Class in org.apache.giraph.types
Converts Bytes to ByteWritables
ByteToByteWritableWrapper() - Constructor for class org.apache.giraph.types.ByteToByteWritableWrapper
 
ByteToIntWritableWrapper - Class in org.apache.giraph.types
Converts Bytes to IntWritables
ByteToIntWritableWrapper() - Constructor for class org.apache.giraph.types.ByteToIntWritableWrapper
 
ByteToLongWritableWrapper - Class in org.apache.giraph.types
Converts Bytes to LongWritables
ByteToLongWritableWrapper() - Constructor for class org.apache.giraph.types.ByteToLongWritableWrapper
 
ByteTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with ByteWritable type
ByteUtils - Class in org.apache.giraph.utils
Utilities class for byte operations and constants
ByteValueVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
Special version of vertex that holds the value in raw byte form to save memory.
ByteValueVertex() - Constructor for class org.apache.giraph.graph.ByteValueVertex
 
ByteWritableToByteUnwrapper - Class in org.apache.giraph.types
Converts ByteWritables to Bytes
ByteWritableToByteUnwrapper() - Constructor for class org.apache.giraph.types.ByteWritableToByteUnwrapper
 
ByteWritableToIntUnwrapper - Class in org.apache.giraph.types
Converts Integers to ByteWritables
ByteWritableToIntUnwrapper() - Constructor for class org.apache.giraph.types.ByteWritableToIntUnwrapper
 
ByteWritableToLongUnwrapper - Class in org.apache.giraph.types
Converts ByteWritables to Longs
ByteWritableToLongUnwrapper() - Constructor for class org.apache.giraph.types.ByteWritableToLongUnwrapper
 
ByteWritableToShortUnwrapper - Class in org.apache.giraph.types
Converts ByteWritables to Shorts
ByteWritableToShortUnwrapper() - Constructor for class org.apache.giraph.types.ByteWritableToShortUnwrapper
 

C

calculateResponse(AckSignalFlag, int) - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
 
calculateResponse(AckSignalFlag, int) - Method in interface org.apache.giraph.comm.flow_control.FlowControl
Calculate/Build the response to piggyback with acknowledgement
calculateResponse(AckSignalFlag, int) - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
calculateResponse(AckSignalFlag, int) - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
call() - Method in class org.apache.giraph.graph.ComputeCallable
 
call() - Method in class org.apache.giraph.ooc.OutOfCoreIOCallable
 
call() - Method in class org.apache.giraph.utils.LogStacktraceCallable
 
call() - Method in class org.apache.giraph.worker.InputSplitsCallable
 
CallableFactory<R> - Interface in org.apache.giraph.utils
Factory for creating Callables
callGc() - Method in class org.apache.giraph.worker.MemoryObserver
Manually call gc, if enough time from last call has passed
canFinishInTime(GiraphConfiguration, Job, CombinedWorkerProgress) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
Determine if the job will finish in allotted time
capacity() - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
capacity() - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
capacity() - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
capacity() - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
capacity() - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
capacity() - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
capacity() - Method in interface org.apache.giraph.types.ops.collections.WCollection
Capacity of currently allocated memory
CAPACITY_OF_DATAOUT_IN_BUFFER - Static variable in class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer
This option sets the capacity of an ExtendedDataOutput instance created in ExtendedByteArrayOutputBuffer
cardinality() - Method in class org.apache.giraph.utils.IncreasingBitSet
Get the number of set bits
castToConsumer() - Method in class org.apache.giraph.function.ObjectTransfer
To be called when needing to pass it as a Consumer - making it obvious that K, V and E on consumer side can be any types, and to make code work without compile errors/warnings.
castToSupplier() - Method in class org.apache.giraph.function.ObjectTransfer
To be called when needing to pass it as a Supplier - making it obvious that K, V and E on supplier side can be any types, and to make code work without compile errors/warnings.
CentralizedService<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.bsp
Basic service interface shared by both CentralizedServiceMaster and CentralizedServiceWorker.
CentralizedServiceMaster<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.bsp
At most, there will be one active master at a time, but many threads can be trying to be the active master.
CentralizedServiceWorker<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.bsp
All workers should have access to this centralized service to execute the following methods.
chainConfigurators(BulkConfigurator...) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Chain execution of multiple BulkConfigurators into one.
chainModifiers(TestGraphModifier<I, V, E>...) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Chain execution of multiple TestGraphModifier into one.
changedIteration(int) - Method in interface org.apache.giraph.block_app.library.iteration.IterationStage
 
changedIteration(int) - Method in class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
changedMigrationSuperstep(int) - Method in interface org.apache.giraph.block_app.migration.MigrationSuperstepStage
 
changedMigrationSuperstep(int) - Method in class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
CHANNEL_SASL_NETTY_SERVERS - Static variable in class org.apache.giraph.comm.netty.NettyServer
Used to authenticate with netty clients
channelActive(ChannelHandlerContext) - Method in class org.apache.giraph.comm.netty.handler.RequestServerHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.giraph.comm.netty.handler.RequestServerHandler
 
channelInactive(ChannelHandlerContext) - Method in class org.apache.giraph.comm.netty.handler.ResponseClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.AuthorizeServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.RequestDecoder
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.RequestServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.ResponseClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.SaslClientHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.SaslServerHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
ChannelRotater - Class in org.apache.giraph.comm.netty
Maintains multiple channels and rotates between them.
ChannelRotater(Integer, InetSocketAddress) - Constructor for class org.apache.giraph.comm.netty.ChannelRotater
Constructor
CHANNELS_PER_SERVER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of channels used per server
CHECK_IN_INTERVAL - Static variable in class org.apache.giraph.ooc.OutOfCoreEngine
Number of 'units of processing' after which an active thread should check-in with the out-of-core engine in order to re-claim its permission to stay active.
CHECK_MEMORY_INTERVAL - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
Memory check interval in msec
CHECK_MEMORY_INTERVAL - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
The interval at which memory observer thread wakes up.
checkBlockTypes(Block, Object, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
 
checkConfiguration(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in interface org.apache.giraph.factories.ComputationFactory
Check that the Configuration passed in is setup correctly to run a job.
checkConfiguration(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.factories.DefaultComputationFactory
 
checkConfiguration(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.jython.factories.JythonComputationFactory
 
CHECKER_IF_WORKER_SHOULD_FAIL_AFTER_EXCEPTION_CLASS - Static variable in class org.apache.giraph.graph.GraphTaskManager
Class which checks if an exception on some thread should cause worker to fail
checkIfWorkerShouldFail(Thread, Throwable) - Method in interface org.apache.giraph.graph.GraphTaskManager.CheckerIfWorkerShouldFailAfterException
Check if worker should fail after a thread gets an exception
checkIfWorkerShouldFail(Thread, Throwable) - Method in class org.apache.giraph.graph.GraphTaskManager.FailWithEveryExceptionOccurred
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.GeneratedVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.PseudoRandomEdgeInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.PseudoRandomIntNullVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.PseudoRandomVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.formats.WattsStrogatzVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.GiraphInputFormat
Check that input is valid.
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.internal.WrappedEdgeInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.internal.WrappedMappingInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.io.internal.WrappedVertexInputFormat
 
checkInputSpecs(Configuration) - Method in class org.apache.giraph.utils.InMemoryVertexInputFormat
 
checkOption(CommandLine, Logger) - Method in class org.apache.giraph.benchmark.BenchmarkOption
If option is not required just return true.
checkOutput(NumericTestGraph<I, V, E>) - Method in interface org.apache.giraph.block_app.test_setup.TestGraphChecker
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.bsp.BspOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.formats.InMemoryVertexOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.formats.SequenceFileVertexOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.internal.WrappedVertexOutputFormat
 
checkOutputSpecs(JobContext) - Method in class org.apache.giraph.io.OutputFormat
Check for validity of the output-specification for the job.
CHECKPOINT_COMPRESSION_CODEC - Static variable in interface org.apache.giraph.conf.GiraphConstants
Compression algorithm to be used for checkpointing.
CHECKPOINT_DATA_POSTFIX - Static variable in class org.apache.giraph.utils.CheckpointingUtils
If at the end of a checkpoint file, indicates that we store WorkerContext and aggregator handler data.
CHECKPOINT_DIRECTORY - Static variable in interface org.apache.giraph.conf.GiraphConstants
This directory has/stores the available checkpoint files in HDFS.
CHECKPOINT_FINALIZED_POSTFIX - Static variable in class org.apache.giraph.utils.CheckpointingUtils
If at the end of a checkpoint file, indicates the stitched checkpoint file prefixes.
CHECKPOINT_FREQUENCY - Static variable in interface org.apache.giraph.conf.GiraphConstants
How often to checkpoint (i.e.
CHECKPOINT_METADATA_POSTFIX - Static variable in class org.apache.giraph.utils.CheckpointingUtils
If at the end of a checkpoint file, indicates metadata
CHECKPOINT_SUPPORTED_CHECKER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Defines if and when checkpointing is supported by this job.
CHECKPOINT_VALID_POSTFIX - Static variable in class org.apache.giraph.utils.CheckpointingUtils
If at the end of a checkpoint file, indicates metadata and data is valid for the same filenames without .valid
CHECKPOINT_VERTICES_POSTFIX - Static variable in class org.apache.giraph.utils.CheckpointingUtils
If at the end of a checkpoint file, indicates vertices, edges, messages, etc.
checkpointBasePath - Variable in class org.apache.giraph.bsp.BspService
Path to the checkpoint's root (including job id)
CheckpointingUtils - Class in org.apache.giraph.utils
Holds useful functions to get checkpoint paths in hdfs.
CheckpointStatus - Enum in org.apache.giraph.bsp.checkpoints
Enum represents possible checkpoint state.
CheckpointSupportedChecker - Interface in org.apache.giraph.bsp.checkpoints
To prevent accidental checkpointing of non-checkpointable app you may provide implementation of this interface.
checkWorkers() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Check all the WorkerInfo objects to ensure that a minimum number of good workers exists out of the total that have reported.
checkWorkers() - Method in class org.apache.giraph.master.BspServiceMaster
 
ClassConfOption<C> - Class in org.apache.giraph.conf
Class configuration option
CLEANED_UP_DIR - Static variable in class org.apache.giraph.bsp.BspService
Denotes which workers have been cleaned up
cleanedUpPath - Variable in class org.apache.giraph.bsp.BspService
Path to the cleaned up notifications
cleanup(SuperstepState) - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Clean up the service (no calls may be issued after this)
cleanup(FinishedSuperstepStats) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Clean up the service (no calls may be issued after this)
cleanup(Mapper<Object, Object, Object, Object>.Context) - Method in class org.apache.giraph.graph.GraphMapper
 
cleanup() - Method in class org.apache.giraph.graph.GraphTaskManager
Called by owner of this GraphTaskManager object on each compute node
cleanup() - Method in interface org.apache.giraph.graph.JobProgressTrackerClient
Close the connections if any
cleanup() - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
cleanup() - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
cleanup(SuperstepState) - Method in class org.apache.giraph.master.BspServiceMaster
 
cleanup(FinishedSuperstepStats) - Method in class org.apache.giraph.worker.BspServiceWorker
 
cleanup() - Method in class org.apache.giraph.zk.InProcessZooKeeperRunner
 
cleanup() - Method in class org.apache.giraph.zk.ZooKeeperManager
Do necessary cleanup in zookeeper wrapper.
cleanup() - Method in interface org.apache.giraph.zk.ZooKeeperRunner
Does necessary cleanup after zookeeper job is complete.
CLEANUP_CHECKPOINTS_AFTER_SUCCESS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Delete checkpoints after a successful job run?
cleanupOnExit() - Method in class org.apache.giraph.zk.ZooKeeperManager
Mark files zookeeper creates in hdfs to be deleted on exit.
clear() - Method in class com.yammer.metrics.core.NoOpCounter
 
clear() - Method in class com.yammer.metrics.core.NoOpHistogram
 
clear() - Method in class com.yammer.metrics.core.NoOpTimer
 
clear() - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Clear the contents of the vector.
clear() - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
Clear the contents of the vector.
clear() - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
Clear the contents of the vector.
clear() - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Clear the contents of the vector.
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Clear the heap
clear() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
clear() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
clear() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
clear() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Removes all of the elements from this list.
clear() - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
clear() - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
clear() - Method in interface org.apache.giraph.types.ops.collections.BasicSet
Removes all of the elements from this list.
clear() - Method in interface org.apache.giraph.types.ops.collections.WCollection
Removes all of the elements from this
clear() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
clear() - Method in class org.apache.giraph.utils.TestGraph
Clear all data
clear() - Method in interface org.apache.giraph.utils.VertexIdData
Clear the list.
clearAll() - Method in interface org.apache.giraph.comm.messages.MessageStore
Clears all resources used by this store.
clearAll() - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
clearAll() - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
clearAll() - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
clearAll() - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
 
clearAll() - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
clearAll() - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
clearAll() - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
clearAll() - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
clearCounters() - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Clear storage to reset for reading new InputSplit
clearParents() - Method in class org.apache.giraph.examples.scc.SccVertexValue
Clear parents list.
clearPartition(int) - Method in interface org.apache.giraph.comm.messages.MessageStore
Clears messages for a partition.
clearPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
clearPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
clearPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
clearPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
 
clearPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
clearPartition(int) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
clearPartition(int) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
clearPartition(int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
clearVertexMessages(I) - Method in interface org.apache.giraph.comm.messages.MessageStore
Clears messages for a vertex.
clearVertexMessages(I) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
clearVertexMessages(I) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
clearVertexMessages(IntWritable) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
clearVertexMessages(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
 
clearVertexMessages(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
clearVertexMessages(I) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
clearVertexMessages(I) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
clearVertexMessages(I) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
CLIENT_RECEIVE_BUFFER_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Client receive buffer size
CLIENT_SEND_BUFFER_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Client send buffer size
CLIENT_THRIFT_SERVER_HOST - Static variable in class org.apache.giraph.job.ClientThriftServer
The client can run a Thrift server (e.g.
CLIENT_THRIFT_SERVER_PORT - Static variable in class org.apache.giraph.job.ClientThriftServer
The client can run a Thrift server (e.g.
clientProcessor - Variable in class org.apache.giraph.comm.SendMessageCache
NettyWorkerClientRequestProcessor for message sending
ClientRequestId - Class in org.apache.giraph.comm.netty.handler
Simple immutable object to use for tracking requests uniquely.
ClientRequestId(int, long) - Constructor for class org.apache.giraph.comm.netty.handler.ClientRequestId
Constructor.
ClientThriftServer - Class in org.apache.giraph.job
Manages the life cycle of the Thrift server started on the client.
ClientThriftServer(GiraphConfiguration, List<?>) - Constructor for class org.apache.giraph.job.ClientThriftServer
Create and start the Thrift server.
cloneValue(E) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge
 
cloneValue(DoubleWritable) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge.DoubleEdgeValue
 
cloneValue(FloatWritable) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge.FloatEdgeValue
 
cloneValue(IntWritable) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge.IntEdgeValue
 
cloneValue(LongWritable) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge.LongEdgeValue
 
cloneValue(NullWritable) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge.NoEdgeValue
 
cloneValue(E) - Method in interface org.apache.giraph.mapping.translate.TranslateEdge
Clone edge value
close() - Method in interface org.apache.giraph.aggregators.AggregatorWriter
The method is called at the end of a successful computation.
close() - Method in class org.apache.giraph.aggregators.TextAggregatorWriter
 
close(TaskAttemptContext) - Method in class org.apache.giraph.bsp.BspRecordWriter
 
close() - Method in interface org.apache.giraph.comm.MasterServer
Shuts down.
close() - Method in class org.apache.giraph.comm.netty.NettyMasterServer
 
close() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
close() - Method in interface org.apache.giraph.comm.WorkerServer
Shuts down.
close() - Method in class org.apache.giraph.examples.GeneratedEdgeReader
 
close() - Method in class org.apache.giraph.examples.GeneratedVertexReader
 
close() - Method in class org.apache.giraph.examples.SimpleAggregatorWriter
 
close() - Method in class org.apache.giraph.io.EdgeReader
Close this EdgeReader to future operations.
close(TaskAttemptContext) - Method in class org.apache.giraph.io.EdgeWriter
Close this EdgeWriter to future operations.
close() - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader
 
close() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
 
close(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriter
 
close() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
 
close(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriter
 
close() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
 
close() - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
close() - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
close() - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
close() - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
close() - Method in interface org.apache.giraph.io.iterables.GiraphReader
Close this GiraphReader to future operations.
close() - Method in class org.apache.giraph.io.iterables.MappingReaderWrapper
 
close() - Method in class org.apache.giraph.io.iterables.VertexReaderWrapper
 
close() - Method in class org.apache.giraph.io.MappingReader
Close this MappingReader to future operations.
close() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
 
close() - Method in class org.apache.giraph.io.VertexReader
Close this VertexReader to future operations.
close(TaskAttemptContext) - Method in class org.apache.giraph.io.VertexWriter
Close this VertexWriter to future operations.
close() - Method in class org.apache.giraph.master.MasterAggregatorHandler
close() - Method in class org.apache.giraph.zk.ZooKeeperExt
Close this client object.
closeAllWriters() - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
closeChannels(ChannelFutureListener) - Method in class org.apache.giraph.comm.netty.ChannelRotater
Close the channels
closeConnections() - Method in interface org.apache.giraph.comm.MasterClient
Closes all connections.
closeConnections() - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
closeConnections() - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
closeConnections() - Method in interface org.apache.giraph.comm.WorkerClient
Closes all connections.
closeZooKeeper() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Close zookeeper
closeZooKeeper() - Method in class org.apache.giraph.worker.BspServiceWorker
Method to close the zookeeper connection, after the worker has sent the counters to the master
CollectionsNCopiesSerializer<T> - Class in org.apache.giraph.writable.kryo.serializers
Special serializer for Collections.nCopies
CollectionsNCopiesSerializer() - Constructor for class org.apache.giraph.writable.kryo.serializers.CollectionsNCopiesSerializer
 
CollectionUtils - Class in org.apache.giraph.utils
Helper methods for Collections
CollectPrimitiveReduceOperation<S> - Class in org.apache.giraph.block_app.reducers.collect
Collect primitive values reduce operation
CollectPrimitiveReduceOperation() - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
For reflection only
CollectPrimitiveReduceOperation(PrimitiveTypeOps<S>) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
CollectReduceOperation<S> - Class in org.apache.giraph.block_app.reducers.collect
Collect values reduce operation
CollectReduceOperation() - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
CollectShardedBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<List<S>>>) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle.CollectShardedBroadcastHandle
 
CollectShardedPrimitiveBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<WArrayList<S>>>) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle.CollectShardedPrimitiveBroadcastHandle
 
CollectShardedPrimitiveReducerHandle<S> - Class in org.apache.giraph.block_app.reducers.collect
ShardedReducerHandle where we keep a list of reduced values, when primitives are used
CollectShardedPrimitiveReducerHandle(CreateReducersApi, Class<S>) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle
 
CollectShardedPrimitiveReducerHandle.CollectShardedPrimitiveBroadcastHandle - Class in org.apache.giraph.block_app.reducers.collect
Broadcast handle for CollectShardedPrimitiveReducerHandle
CollectShardedReducerHandle<S> - Class in org.apache.giraph.block_app.reducers.collect
ShardedReducerHandle where we keep a list of reduced values
CollectShardedReducerHandle(CreateReducersApi) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle
 
CollectShardedReducerHandle.CollectShardedBroadcastHandle - Class in org.apache.giraph.block_app.reducers.collect
BroadcastHandle for CollectShardedReducerHandle
CollectShardedTuplesOfPrimitivesBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<List<WArrayList>>>) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesBroadcastHandle
 
CollectShardedTuplesOfPrimitivesReduceBroadcast() - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
 
CollectShardedTuplesOfPrimitivesReducerHandle - Class in org.apache.giraph.block_app.reducers.collect
ShardedReducerHandle where we keep a list of reduced values, and values consist of multiple primitives, so we keep one primitive list for each
CollectShardedTuplesOfPrimitivesReducerHandle(CreateReducersApi, Class<?>...) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle
 
CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesBroadcastHandle - Class in org.apache.giraph.block_app.reducers.collect
BroadcastHandle for CollectShardedTuplesOfPrimitivesReducerHandle
CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast - Class in org.apache.giraph.block_app.reducers.collect
Reduce broadcast wrapper
CollectTuplesOfPrimitivesReduceOperation - Class in org.apache.giraph.block_app.reducers.collect
Collect tuples of primitive values reduce operation
CollectTuplesOfPrimitivesReduceOperation() - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
For reflection only
CollectTuplesOfPrimitivesReduceOperation(List<PrimitiveTypeOps>) - Constructor for class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
com.yammer.metrics.core - package com.yammer.metrics.core
Package of communication related objects, IPC service.
combine(WritableComparable, DoubleWritable, DoubleWritable) - Method in class org.apache.giraph.combiner.DoubleSumMessageCombiner
Deprecated.
 
combine(WritableComparable, FloatWritable, FloatWritable) - Method in class org.apache.giraph.combiner.FloatSumMessageCombiner
Deprecated.
 
combine(WritableComparable, M, M) - Method in class org.apache.giraph.combiner.MaxMessageCombiner
 
combine(I, M, M) - Method in interface org.apache.giraph.combiner.MessageCombiner
Combine messageToCombine with originalMessage, by modifying originalMessage.
combine(WritableComparable, DoubleWritable, DoubleWritable) - Method in class org.apache.giraph.combiner.MinimumDoubleMessageCombiner
 
combine(WritableComparable, IntWritable, IntWritable) - Method in class org.apache.giraph.combiner.MinimumIntMessageCombiner
 
combine(I, M, M) - Method in class org.apache.giraph.combiner.MinMessageCombiner
 
combine(WritableComparable, NullWritable, NullWritable) - Method in class org.apache.giraph.combiner.NullMessageCombiner
 
combine(WritableComparable, IntWritable, IntWritable) - Method in class org.apache.giraph.combiner.SimpleSumMessageCombiner
Deprecated.
 
combine(WritableComparable, M, M) - Method in class org.apache.giraph.combiner.SumMessageCombiner
 
combine(V, V) - Method in class org.apache.giraph.graph.DefaultVertexValueCombiner
 
combine(V, V) - Method in interface org.apache.giraph.graph.VertexValueCombiner
Combine a vertex with the original vertex by modifying originalVertex.
CombinedWorkerProgress - Class in org.apache.giraph.job
Class which combines multiple workers' progresses to get overall application progress
CombinedWorkerProgress(Iterable<WorkerProgress>, MasterProgress, Configuration) - Constructor for class org.apache.giraph.job.CombinedWorkerProgress
Constructor
commandCompleted(IOCommand) - Method in class org.apache.giraph.ooc.policy.FixedPartitionsOracle
 
commandCompleted(IOCommand) - Method in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
 
commandCompleted(IOCommand) - Method in interface org.apache.giraph.ooc.policy.OutOfCoreOracle
Notification of command completion.
commandCompleted(IOCommand) - Method in class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
 
commandCompleted(IOCommand) - Method in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
 
commit() - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
Commit everything
commit(JobContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
For cleaning up the job's output after job completion.
commitJob(JobContext) - Method in class org.apache.giraph.bsp.ImmutableOutputCommitter
 
commitJob(JobContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.giraph.bsp.ImmutableOutputCommitter
 
commitTask(TaskAttemptContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
 
compare(int, byte, int, byte) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Comapre two (key, value) entries
compare(int, double, int, double) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Comapre two (key, value) entries
compare(int, float, int, float) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Comapre two (key, value) entries
compare(int, int, int, int) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Comapre two (key, value) entries
compare(int, long, int, long) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Comapre two (key, value) entries
compare(long, byte, long, byte) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Comapre two (key, value) entries
compare(long, double, long, double) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Comapre two (key, value) entries
compare(long, float, long, float) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Comapre two (key, value) entries
compare(long, int, long, int) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Comapre two (key, value) entries
compare(long, long, long, long) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Comapre two (key, value) entries
compare(ByteWritable, ByteWritable) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
compare(DoubleWritable, DoubleWritable) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
compare(FloatWritable, FloatWritable) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
compare(IntWritable, IntWritable) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
compare(LongWritable, LongWritable) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
compare(T, T) - Method in interface org.apache.giraph.types.ops.NumericTypeOps
Compare two values
compare(Edge<I, E>, Edge<I, E>) - Method in class org.apache.giraph.utils.EdgeComparator
 
compareEdges(Edge<I, E>, Edge<I, E>) - Static method in class org.apache.giraph.utils.EdgeComparator
Compares two edges.
compareTo(AbstractConfOption) - Method in class org.apache.giraph.conf.AbstractConfOption
 
compareTo(Object) - Method in class org.apache.giraph.counters.CustomCounter
 
compareTo(SimpleTriangleClosingComputation.Pair) - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair
Comparator to quickly sort by values
compareTo(Object) - Method in class org.apache.giraph.jython.wrappers.JythonWritableWrapper
 
Computation<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> - Interface in org.apache.giraph.graph
Interface for an application for computation.
COMPUTATION_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Computation class - required
COMPUTATION_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Computation factory class - optional
COMPUTATION_LANGUAGE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Which language computation is implemented in
computationClass - Variable in class org.apache.giraph.conf.GiraphClasses
Computation class - cached for fast access
computationDone - Variable in class org.apache.giraph.worker.WorkerProgressStats
Whether all compute supersteps are done
computationDone() - Method in class org.apache.giraph.zk.ZooKeeperManager
Check if all the computation is done.
ComputationDoneName - Class in org.apache.giraph.zk
This name is used by each worker as a file to let the ZooKeeper servers know that they can shutdown.
ComputationDoneName(int) - Constructor for class org.apache.giraph.zk.ComputationDoneName
Constructor.
ComputationFactory<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> - Interface in org.apache.giraph.factories
Factory for creating Computations
computationFactoryClass - Variable in class org.apache.giraph.conf.GiraphClasses
ComputationFactory class - cached for fast access
computationName(GiraphConfiguration) - Method in interface org.apache.giraph.factories.ComputationFactory
Get name of this particular computation
computationName(GiraphConfiguration) - Method in class org.apache.giraph.factories.DefaultComputationFactory
 
computationName(GiraphConfiguration) - Method in class org.apache.giraph.jython.factories.JythonComputationFactory
 
compute(Vertex<LongWritable, DoubleWritable, DoubleWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkComputation
 
compute() - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkMasterCompute
 
compute(Vertex<IntWritable, FloatWritable, NullWritable>, Iterable<FloatWritable>) - Method in class org.apache.giraph.benchmark.PageRankComputation
 
compute(Vertex<LongWritable, DoubleWritable, DoubleWritable>, Iterable<BytesWritable>) - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageComputation
 
compute(Vertex<LongWritable, DoubleWritable, DoubleWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkComputation
 
compute() - Method in class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkMasterCompute
 
compute(Vertex<LongWritable, DoubleWritable, DoubleWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.benchmark.ShortestPathsComputation
 
compute(Vertex<LongWritable, DoubleWritable, DoubleWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.benchmark.WeightedPageRankComputation
 
compute(Vertex, Iterable) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockComputation
 
compute() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
compute(Vertex, Iterable) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
compute(Vertex<I, V, E>, Iterable<M1>) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
compute() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
compute() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.AggregatorsTestMasterCompute
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.AggregatorsTestComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterComputation
 
compute() - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterCompute
 
compute(Vertex<LongWritable, BrachaTouegDeadlockVertexValue, LongWritable>, Iterable<BrachaTouegDeadlockMessage>) - Method in class org.apache.giraph.examples.BrachaTouegDeadlockComputation
 
compute(Vertex<IntWritable, IntWritable, NullWritable>, Iterable<IntWritable>) - Method in class org.apache.giraph.examples.ConnectedComponentsComputation
Propagates the smallest vertex id to all neighbors.
compute(Vertex<I, V, E>, Iterable<M>) - Method in class org.apache.giraph.examples.IdentityComputation
 
compute(Vertex<IntWritable, IntWritable, NullWritable>, Iterable<IntWritable>) - Method in class org.apache.giraph.examples.MaxComputation
 
compute(Vertex<LongWritable, PageRankWithKryoSimpleWritable.VertexValue, PageRankWithKryoSimpleWritable.EdgeValue>, Iterable<PageRankWithKryoSimpleWritable.MessageValue>) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable
 
compute(Vertex<LongWritable, DoubleWritable, E>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.RandomWalkComputation
 
compute() - Method in class org.apache.giraph.examples.RandomWalkVertexMasterCompute
 
compute(Vertex<LongWritable, SccVertexValue, NullWritable>, Iterable<LongWritable>) - Method in class org.apache.giraph.examples.scc.SccComputation
 
compute() - Method in class org.apache.giraph.examples.scc.SccPhaseMasterCompute
 
compute(Vertex<LongWritable, IntWritable, FloatWritable>, Iterable<FloatWritable>) - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointComputation
 
compute(Vertex<LongWritable, IntWritable, FloatWritable>, Iterable<IntWritable>) - Method in class org.apache.giraph.examples.SimpleCombinerComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleFailComputation
 
compute(Vertex<LongWritable, LongWritable, DoubleWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleInDegreeCountComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation
 
compute() - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterCompute
 
compute(Vertex<LongWritable, IntWritable, FloatWritable>, Iterable<IntWritable>) - Method in class org.apache.giraph.examples.SimpleMsgComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation
 
compute(Vertex<LongWritable, LongWritable, DoubleWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleOutDegreeCountComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimplePageRankComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleShortestPathsComputation
 
compute(Vertex<LongWritable, IntWritable, FloatWritable>, Iterable<IntWritable>) - Method in class org.apache.giraph.examples.SimpleSuperstepComputation
 
compute(Vertex<IntWritable, SimpleTriangleClosingComputation.IntArrayListWritable, NullWritable>, Iterable<IntWritable>) - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation
 
compute(Vertex<LongWritable, IntWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext.SimpleComputation
 
compute(Vertex<LongWritable, DoubleWritable, FloatWritable>, Iterable<DoubleWritable>) - Method in class org.apache.giraph.examples.TestComputationStateComputation
 
compute(Vertex<LongWritable, IntWritable, FloatWritable>, Iterable<VerifyMessage.VerifiableMessage>) - Method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation
 
compute(Vertex<I, V, E>, Iterable<M1>) - Method in class org.apache.giraph.graph.AbstractComputation
Must be defined by user to do computation on a single Vertex.
compute(Vertex<I, V, E>, Iterable<M1>) - Method in interface org.apache.giraph.graph.Computation
Must be defined by user to do computation on a single Vertex.
compute(Object, Iterable) - Method in class org.apache.giraph.jython.JythonComputation
User's computation function
compute(Vertex<I, V, E>, Iterable<M1>) - Method in class org.apache.giraph.jython.JythonGiraphComputation
 
compute() - Method in class org.apache.giraph.master.DefaultMasterCompute
 
compute() - Method in class org.apache.giraph.master.MasterCompute
Must be defined by user to specify what the master has to do.
ComputeCallable<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.graph
Compute as many vertex partitions as possible.
ComputeCallable(Mapper<?, ?, ?, ?>.Context, GraphState, MessageStore<I, M1>, ImmutableClassesGiraphConfiguration<I, V, E>, CentralizedServiceWorker<I, V, E>) - Constructor for class org.apache.giraph.graph.ComputeCallable
Constructor
computeNext(long) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Executes operations on master (master compute and registering reducers), and calculates next pieces to be exectued on workers.
computePartition(LongWritable, int, int, byte) - Method in class org.apache.giraph.mapping.AbstractLongByteOps
Compute partition given id, partitionCount, workerCount & target
computePartitionCount(int, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.partition.PartitionUtils
Compute the number of partitions, based on the configuration.
conditionalSetStatusAndLog(boolean, TaskAttemptContext, Logger, Level, String) - Static method in class org.apache.giraph.utils.LoggerUtils
Helper method to set the status and log message together if condition has been been met.
conf - Variable in class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
Hadoop configuration
conf - Variable in class org.apache.giraph.comm.requests.WritableRequest
Configuration
conf - Variable in class org.apache.giraph.edge.InMemoryEdgeStoreFactory
Giraph configuration.
conf - Variable in class org.apache.giraph.utils.io.BigDataOutput
Configuration
conf - Variable in class org.apache.giraph.utils.TestGraph
The configuration
config - Variable in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
Giraph configuration
config - Variable in class org.apache.giraph.comm.messages.SimpleMessageStore
Giraph configuration
ConfigurableOutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Common base class for OutEdges implementations that require a configuration.
ConfigurableOutEdges() - Constructor for class org.apache.giraph.edge.ConfigurableOutEdges
 
configuration - Variable in class org.apache.giraph.edge.AbstractEdgeStore
Giraph configuration.
configuration - Variable in class org.apache.giraph.worker.InputSplitsCallable
Configuration
ConfigurationObjectUtils - Class in org.apache.giraph.utils
Utility methods for dealing with Hadoop configuration
ConfigurationUtils - Class in org.apache.giraph.utils
Translate command line args into Configuration Key-Value pairs.
CONFIGURATORS - Static variable in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Comma separated list of BulkConfigurators, that are going to be called to simplify specifying of large number of properties.
configure(GiraphConfiguration) - Method in interface org.apache.giraph.conf.BulkConfigurator
Modify given configuration.
configure(GiraphConfiguration) - Method in class org.apache.giraph.conf.FacebookConfiguration
Expand GiraphConfiguration with default Facebook settings.
CONFIGURE_JAVA_OPTS - Static variable in class org.apache.giraph.conf.FacebookConfiguration
Whether to configure java opts.
configureHadoopSecurity() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check environment for Hadoop security token location in case we are executing the Giraph job on a MRv1 Hadoop cluster.
configureIfPossible(Object) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Configure an object with this instance if the object is configurable.
configureIfPossible(Object, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.ConfigurationUtils
Configure an object with an ImmutableClassesGiraphConfiguration if that objects supports it.
ConfOptionType - Enum in org.apache.giraph.conf
Type of value for a Configuration option
connectAllAddresses(Collection<? extends TaskInfo>) - Method in class org.apache.giraph.comm.netty.NettyClient
Connect to a collection of tasks servers
ConnectedComponentsComputation - Class in org.apache.giraph.examples
Implementation of the HCC algorithm that identifies connected components and assigns each vertex its "component identifier" (the smallest vertex id in the component) The idea behind the algorithm is very simple: propagate the smallest vertex id along the edges to all vertices of a connected component.
ConnectedComponentsComputation() - Constructor for class org.apache.giraph.examples.ConnectedComponentsComputation
 
Consumer<T> - Interface in org.apache.giraph.function
Function: (T) -> void
ConsumerWithVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,T> - Interface in org.apache.giraph.function.vertex
Function: (vertex, T) -> void A class that can consume objects of a single type, when given a vertex.
contains(Configuration) - Method in class org.apache.giraph.conf.AbstractConfOption
Check if option is set in configuration
contains(IntWritable) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
contains(LongWritable) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
contains(T) - Method in interface org.apache.giraph.types.ops.collections.BasicSet
Checks whether set contains given value
containsKey(IntWritable) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
containsKey(LongWritable) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
containsKey(K) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
containsKey(K) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Checks whether key is present in the map
context - Variable in class org.apache.giraph.worker.InputSplitsCallable
Context
ContextSettable - Interface in org.apache.giraph.conf
Worker/Master/Mapper observer can implement this to get context set, to allow them to access job counters
CONVERGED - Static variable in class org.apache.giraph.examples.scc.SccPhaseMasterCompute
Flags whether a vertex converged in the Backward Traversal phase
convertEdgeToLine(I, V, Edge<I, E>) - Method in class org.apache.giraph.io.formats.SrcIdDstIdEdgeValueTextOutputFormat.SrcIdDstIdEdgeValueEdgeWriter
 
convertEdgeToLine(I, V, Edge<I, E>) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriterToEachLine
Writes a line for the given edge.
convertFromByteArray(byte[]) - Static method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Converting from byte array
convertToByteArray(T) - Static method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Converting the object to byte array.
convertToSequenceFileKey(I) - Method in class org.apache.giraph.io.formats.SequenceFileVertexOutputFormat
Converts a vertex identifier into a sequence file key.
convertToSequenceFileValue(V) - Method in class org.apache.giraph.io.formats.SequenceFileVertexOutputFormat
Converts a vertex value into a sequence file value.
convertVertexToLine(Vertex<I, V, E>) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat.AdjacencyListTextVertexWriter
 
convertVertexToLine(Vertex<I, V, E>) - Method in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat.IdWithValueVertexWriter
 
convertVertexToLine(Vertex<I, V, E>) - Method in class org.apache.giraph.io.formats.JsonBase64VertexOutputFormat.JsonBase64VertexWriter
 
convertVertexToLine(Vertex<I, V, E>) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriterToEachLine
Writes a line for the given vertex.
coordinateSuperstep() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Master coordinates the superstep
coordinateSuperstep() - Method in class org.apache.giraph.master.BspServiceMaster
 
copy() - Method in class org.apache.giraph.graph.VertexMutations
Copy the vertex mutations.
copy() - Method in class org.apache.giraph.ooc.persistence.DataIndex
Create a copy of the existing DataIndex
copy(Iterable<Edge<I, E>>) - Static method in class org.apache.giraph.utils.EdgeIterables
Make a deep copy of an edge iterable and return it as an ArrayList.
copy(Kryo, T) - Method in class org.apache.giraph.writable.kryo.serializers.DirectWritableSerializer
 
copyAndAdd(Path, Configuration) - Static method in class org.apache.giraph.utils.DistributedCacheUtils
Copy a file to HDFS if it is local, and adds it to the distributed cache.
copyInto(T, T) - Static method in class org.apache.giraph.utils.WritableUtils
Copy from into to, by serializing and deserializing it.
copyInto(T, T, boolean) - Static method in class org.apache.giraph.utils.WritableUtils
Copy from into to, by serializing and deserializing it.
copyToHdfs(Path, Configuration) - Static method in class org.apache.giraph.utils.DistributedCacheUtils
Copy a file to HDFS if it is local.
CORES_FRACTION_DURING_COMMUNICATION - Static variable in class org.apache.giraph.conf.FacebookConfiguration
Which fraction of cores to use for threads when computation and communication overlap
count() - Method in class com.yammer.metrics.core.NoOpCounter
 
count() - Method in class com.yammer.metrics.core.NoOpHistogram
 
count() - Method in class com.yammer.metrics.core.NoOpMeter
 
count() - Method in class com.yammer.metrics.core.NoOpTimer
 
count - Variable in class org.apache.giraph.metrics.AggregatedMetric
Number of values seen
count() - Method in class org.apache.giraph.metrics.AggregatedMetric
Get number of values seen
Counter - Interface in org.apache.giraph.block_app.framework.api
Interface wrapping around org.appache.hadoop.mapreduce.Counter
COUNTERS_DIR - Static variable in class org.apache.giraph.bsp.BspService
Counter sub directory
CounterUtils - Class in org.apache.giraph.utils
Utility methods for dealing with counters
CountingCache - Class in org.apache.giraph.comm.aggregators
Cache which counts the number of flushes per task id (destination worker id), so we know how many requests were sent to the worker
CountingCache() - Constructor for class org.apache.giraph.comm.aggregators.CountingCache
 
CountingOutputStream - Class in org.apache.giraph.comm.aggregators
Wrapper for output stream which keeps the place in the beginning for the count of objects which were written to it
CountingOutputStream() - Constructor for class org.apache.giraph.comm.aggregators.CountingOutputStream
Default constructor
create(String, Class<? extends T>, Class<T>, String) - Static method in class org.apache.giraph.conf.ClassConfOption
Static create method
create(String, Class<X>, X, String) - Static method in class org.apache.giraph.conf.EnumConfOption
Create new EnumConfOption
create(String, Class<X>, X, String) - Static method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
Create new EnumGraphTypeConfOption
create(I, E) - Static method in class org.apache.giraph.edge.EdgeFactory
Create an edge pointing to a given ID with a value
create(I) - Static method in class org.apache.giraph.edge.EdgeFactory
Create an edge pointing to a given ID without a value
create(GiraphConfiguration, String, String) - Static method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Create registry with Hadoop Configuration and group to use for metrics.
create(GiraphConfiguration, long) - Static method in class org.apache.giraph.metrics.SuperstepMetricsRegistry
Create with Hadoop Configuration and superstep number.
create(Class<W>, Class<J>) - Static method in class org.apache.giraph.types.JavaWritablePair
Create holder for classes
create() - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.MapTypeOps
 
create() - Method in enum org.apache.giraph.types.ops.TextTypeOps
 
create() - Method in interface org.apache.giraph.types.ops.TypeOps
Create new instance of type T.
create() - Method in interface org.apache.giraph.utils.Factory
Create new object
create() - Method in class org.apache.giraph.utils.io.DataInputOutput
 
create(Kryo, Input, Class<T>) - Method in class org.apache.giraph.writable.kryo.serializers.DirectWritableSerializer
Used by DirectWritableSerializer.read(Kryo, Input, Class) to create the new object.
create(Kryo, Input, Class<T>) - Method in class org.apache.giraph.writable.kryo.serializers.ReusableFieldSerializer
 
create2ObjectMap(Class<I>) - Static method in class org.apache.giraph.types.ops.collections.BasicCollectionsUtils
Construct OpenHashMap with primitive keys.
create2ObjectMap(Class<I>, WritableWriter<I>, WritableWriter<V>) - Static method in class org.apache.giraph.types.ops.collections.BasicCollectionsUtils
Construct OpenHashMap with primitive keys.
create2ObjectOpenHashMap(WritableWriter<V>) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
create2ObjectOpenHashMap(int, WritableWriter<V>) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
create2ObjectOpenHashMap(WritableWriter<V>) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
create2ObjectOpenHashMap(int, WritableWriter<V>) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
create2ObjectOpenHashMap(WritableWriter<V>) - Method in interface org.apache.giraph.types.ops.PrimitiveIdTypeOps
Create Basic2ObjectMap with key type T.
create2ObjectOpenHashMap(int, WritableWriter<V>) - Method in interface org.apache.giraph.types.ops.PrimitiveIdTypeOps
Create Basic2ObjectMap with key type T, given capacity.
CREATE_EDGE_SOURCE_VERTICES - Static variable in interface org.apache.giraph.conf.GiraphConstants
This option can be used to specify if a source vertex present in edge input but not in vertex input can be created
CREATE_EDGE_SOURCE_VERTICES_CALLBACK - Static variable in interface org.apache.giraph.conf.GiraphConstants
Defines a call back that can be used to make decisions on whether the vertex should be created or not in the runtime.
createAggregatorWriter() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user aggregator output format class
createAndExtractTypes(ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.master.SuperstepClasses
Create superstep classes by initiazling from current state in configuration
createAndInitializeInputOutEdges() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create an input OutEdges instance and initialize it with the default capacity.
createAndInitializeOutEdges() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a OutEdges instance and initialize it with the default capacity.
createAndInitializeOutEdges(int) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a OutEdges instance and initialize it with the given capacity (the number of edges that will be added).
createAndInitializeOutEdges(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a OutEdges instance and initialize it with the given iterable of edges.
createArrayHandles(int, ReduceOperation<S, T>, CreateReducersApi.CreateReducerFunctionApi) - Static method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
Registers one new reducer, that will reduce array of objects, by reducing individual elements using elementReduceOp.
createArrayHandles(PrimitiveTypeOps<R>, ReduceOperation<S, R>, CreateReducersApi.CreateReducerFunctionApi) - Static method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
Registers one new reducer, that will reduce BasicArray, by reducing individual elements using elementReduceOp, with unbounded size.
createArrayHandles(int, PrimitiveTypeOps<R>, ReduceOperation<S, R>, CreateReducersApi.CreateReducerFunctionApi) - Static method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
Registers one new reducer, that will reduce BasicArray, by reducing individual elements using elementReduceOp, with predefined size.
createArrayList() - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
createArrayList(int) - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
createArrayList() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createArrayList(int) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createArrayList() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createArrayList(int) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createArrayList() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createArrayList(int) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createArrayList() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createArrayList(int) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createArrayList() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createArrayList(int) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createArrayList() - Method in interface org.apache.giraph.types.ops.PrimitiveTypeOps
Create WArrayList of type T.
createArrayList(int) - Method in interface org.apache.giraph.types.ops.PrimitiveTypeOps
Create WArrayList of type T, given capacity.
createBlock(GiraphConfiguration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Create a block (representing a full Giraph job), based on the given configuration.
createBlock(GiraphConfiguration) - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory
 
createBlockFactory(Configuration) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Create new BlockFactory that is specified in the configuration.
createBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<WArrayList<S>>>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle
 
createBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<List<S>>>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle
 
createBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<List<WArrayList>>>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle
 
createBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<R>>) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
createBroadcastResult(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle.CollectShardedPrimitiveBroadcastHandle
 
createBroadcastResult(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle.CollectShardedBroadcastHandle
 
createBroadcastResult(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesBroadcastHandle
 
createBroadcastResult(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle
 
createCallable() - Method in class org.apache.giraph.ooc.OutOfCoreIOCallableFactory
Creates/Launches IO threads
createCandidateStamp() - Method in class org.apache.giraph.zk.ZooKeeperManager
Create a HDFS stamp for this task.
createClassName(String) - Static method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Creates a new node for the given class name.
createComputation() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user computation
createComputation(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in interface org.apache.giraph.factories.ComputationFactory
Get Computation object
createComputation(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.factories.DefaultComputationFactory
 
createComputation(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.jython.factories.JythonComputationFactory
 
createComputationFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get computation factory
createCopy() - Method in class org.apache.giraph.master.AggregatorReduceOperation
Creates copy of this object
createCopy(BooleanWritable) - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
createCopy(ByteWritable) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createCopy(DoubleWritable) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createCopy(FloatWritable) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createCopy(IntWritable) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createCopy(LongWritable) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createCopy(MapWritable) - Method in enum org.apache.giraph.types.ops.MapTypeOps
 
createCopy(Text) - Method in enum org.apache.giraph.types.ops.TextTypeOps
 
createCopy(T) - Method in interface org.apache.giraph.types.ops.TypeOps
Create a copy of passed object
createCopy(UnsafeByteArrayOutputStream, UnsafeReusableByteArrayInput, T, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.WritableUtils
Create a copy of Writable object, by serializing and deserializing it.
createCopy(T) - Static method in class org.apache.giraph.utils.WritableUtils
Create a copy of Writable object, by serializing and deserializing it.
createCopy(T, Class<? extends T>, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.WritableUtils
Create a copy of Writable object, by serializing and deserializing it.
createCopy(T, ValueFactory<T>, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.WritableUtils
Create a copy of Writable object, by serializing and deserializing it.
createCopy(T) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Create copy of the object, by magically recursively copying all of its fields, keeping reference structures (like cycles)
createCopyForNewSuperstep() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
createCopyForNewSuperstep() - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
createCopyForNewSuperstep() - Method in interface org.apache.giraph.conf.MessageClasses
Creates a fresh copy of this object, to be used and changed for new superstep.
createData() - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
createData() - Method in class org.apache.giraph.utils.ByteArrayVertexIdEdges
 
createData() - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
createData() - Method in interface org.apache.giraph.utils.VertexIdData
Create a new data object.
createDataInput() - Method in class org.apache.giraph.utils.io.BigDataInputOutput
 
createDataInput() - Method in class org.apache.giraph.utils.io.DataInputOutput
Create DataInput which reads data from underlying DataOutput
createDataInput() - Method in class org.apache.giraph.utils.io.ExtendedDataInputOutput
 
createEdge() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user edge.
createEdge(TranslateEdge<I, E>, Edge<I, E>) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create edge based on #createEdge definition
createEdgeInputFormats(ImmutableClassesGiraphConfiguration<I, Writable, E>) - Static method in class org.apache.giraph.io.formats.multi.EdgeInputFormatDescription
Create all edge input formats
createEdgeInputSplits() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Create the BspInputSplit objects from the index range based on the user-defined EdgeInputFormat.
createEdgeInputSplits() - Method in class org.apache.giraph.master.BspServiceMaster
 
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeInputFormat
 
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.EdgeInputFormat
Create an edge reader for a given split.
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IntNullReverseTextEdgeInputFormat
 
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat
 
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.PseudoRandomEdgeInputFormat
 
createEdgeReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeInputFormat
 
createEdges(Map.Entry<I, E>...) - Method in class org.apache.giraph.utils.TestGraph
Create edges for given ids
createEdgeStoreFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create edge store factory
createEdgeValue() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user edge value
createEdgeWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.EdgeOutputFormat
Create an edge writer for a given split.
createEdgeWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.SrcIdDstIdEdgeValueTextOutputFormat
 
createEdgeWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat
The factory method which produces the TextEdgeOutputFormat.TextEdgeWriter used by this output format.
createEdgeWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeOutputFormat
 
createExecutionStage(GiraphConfiguration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Create an empty instance of execution stage object.
createExecutionStage(GiraphConfiguration) - Method in class org.apache.giraph.block_app.migration.MigrationFullBlockFactory
 
createExt(String, byte[], List<ACL>, CreateMode, boolean) - Method in class org.apache.giraph.zk.ZooKeeperExt
Provides a possibility of a creating a path consisting of more than one znode (not atomic).
createExtendedDataInput(byte[], int, int) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create an extended data input (can be subclassed)
createExtendedDataInput(byte[]) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create an extended data input (can be subclassed)
createExtendedDataInput(ExtendedDataOutput) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create extendedDataInput based on extendedDataOutput
createExtendedDataOutput() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create an extended data output (can be subclassed)
createExtendedDataOutput(int) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create an extended data output (can be subclassed)
createExtendedDataOutput(byte[], int) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create an extended data output (can be subclassed)
createFake() - Static method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Create no-op empty registry that makes no-op metrics.
createFake() - Static method in class org.apache.giraph.metrics.SuperstepMetricsRegistry
Create an empty registry
createForBasic2ObjectMap(PrimitiveIdTypeOps<K>) - Static method in class org.apache.giraph.object.MultiSizedReusable
 
createForBasicSet(PrimitiveIdTypeOps<I>) - Static method in class org.apache.giraph.object.MultiSizedReusable
 
createGcObservers(Mapper<?, ?, ?, ?>.Context) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create array of GcObservers.
createGlobalReducer(ReduceOperation<S, R>) - Method in interface org.apache.giraph.block_app.framework.api.CreateReducersApi
Create global reducer, returning a handle to it.
createGlobalReducer(ReduceOperation<S, R>, R) - Method in interface org.apache.giraph.block_app.framework.api.CreateReducersApi
Create global reducer, returning a handle to it.
createGlobalReducer(ReduceOperation<S, R>) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
createGlobalReducer(ReduceOperation<S, R>, R) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
createGlobalReducer(MasterGlobalCommUsage, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
createGlobalReducerArrayHandle(int, ReduceOperation<S, R>, CreateReducersApi) - Static method in class org.apache.giraph.block_app.reducers.array.HugeArrayUtils
Create global array of reducers, by splitting the huge array into NUM_STRIPES number of parts.
createGlobalReducerArrayHandle(int, ReduceOperation<S, R>, CreateReducersApi, int) - Static method in class org.apache.giraph.block_app.reducers.array.HugeArrayUtils
Create global array of reducers, by splitting the huge array into maxNumStripes number of parts.
createGraphPartitioner() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user graph partitioner class
createIncomingMessageValueFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create new incoming message value factory
createInitAndCheckOutputDesc(String, Configuration, String) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
createInitAndCheckOutputDescsMap(Configuration, String) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
createInitAndCheckOutputDescsMap(JobContext) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
createInitialMessage() - Method in class org.apache.giraph.combiner.DoubleSumMessageCombiner
Deprecated.
 
createInitialMessage() - Method in class org.apache.giraph.combiner.FloatSumMessageCombiner
Deprecated.
 
createInitialMessage() - Method in class org.apache.giraph.combiner.MaxMessageCombiner
 
createInitialMessage() - Method in interface org.apache.giraph.combiner.MessageCombiner
Get the initial message.
createInitialMessage() - Method in class org.apache.giraph.combiner.MinimumDoubleMessageCombiner
 
createInitialMessage() - Method in class org.apache.giraph.combiner.MinimumIntMessageCombiner
 
createInitialMessage() - Method in class org.apache.giraph.combiner.MinMessageCombiner
 
createInitialMessage() - Method in class org.apache.giraph.combiner.NullMessageCombiner
 
createInitialMessage() - Method in class org.apache.giraph.combiner.SimpleSumMessageCombiner
Deprecated.
 
createInitialMessage() - Method in class org.apache.giraph.combiner.SumMessageCombiner
 
createInitialPartitionOwners(Collection<WorkerInfo>, int) - Method in interface org.apache.giraph.partition.MasterGraphPartitioner
Set some initial partition owners for the graph.
createInitialPartitionOwners(Collection<WorkerInfo>, int) - Method in class org.apache.giraph.partition.MasterGraphPartitionerImpl
 
createInitialValue() - Method in interface org.apache.giraph.aggregators.Aggregator
Return new aggregated value which is neutral to aggregate operation.
createInitialValue() - Method in class org.apache.giraph.aggregators.BooleanAndAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.BooleanOrAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.BooleanOverwriteAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.DoubleMaxAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.DoubleMinAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.DoubleOverwriteAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.DoubleProductAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.DoubleSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.FloatMaxAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.FloatMinAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.FloatOverwriteAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.FloatProductAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.FloatSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.IntMaxAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.IntMinAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.IntOverwriteAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.IntProductAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.IntSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.LongMaxAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.LongMinAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.LongOverwriteAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.LongProductAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.LongSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVectorSumAggregator
 
createInitialValue() - Method in class org.apache.giraph.aggregators.TextAppendAggregator
 
createInitialValue() - Method in class org.apache.giraph.benchmark.ReducersBenchmark.TestLongSumReducer
 
createInitialValue() - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
createInitialValue() - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
createInitialValue() - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
createInitialValue(String) - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Create initial value for a reducer.
createInitialValue() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.DoubleMaxWrapperAggregator
 
createInitialValue() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.DoubleMinWrapperAggregator
 
createInitialValue() - Method in class org.apache.giraph.master.AggregatorReduceOperation
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.AndReduce
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.LongXorReduce
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.MaxPairReducer
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.MaxReduce
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.MinReduce
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.OrReduce
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.PairReduce
 
createInitialValue() - Method in class org.apache.giraph.reducers.impl.SumReduce
 
createInitialValue() - Method in interface org.apache.giraph.reducers.ReduceOperation
Return new reduced value which is neutral to reduce operation.
createInitialValue() - Method in class org.apache.giraph.reducers.Reducer
Return new initial reduced value.
createInputOutEdges() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user OutEdges used during edge-based input
createJobProgressTrackerService(GiraphConfiguration, GiraphJobObserver) - Static method in class org.apache.giraph.job.DefaultJobProgressTrackerService
Create job progress server on job client if enabled in configuration.
createLineRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
Create the line record reader.
createLineRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
Create the line record reader.
createLineRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
Create the line record reader.
createLineRecordWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriter
Create the line record writer.
createLineRecordWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriter
Create the line record writer.
createList() - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
createList() - Method in class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
createList(int) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle
 
createList(int) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle
 
createList() - Method in class org.apache.giraph.comm.messages.AbstractListPerVertexStore
Create an instance of L
createList() - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
createList() - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractListStore
Create an instance of L
createList() - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
createLists(int) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle
 
createLocalArrayHandles(PrimitiveTypeOps<R>, ReduceOperation<S, R>, CreateReducersApi) - Static method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
Registers one new local reducer, that will reduce BasicArray, by reducing individual elements using elementReduceOp, with unbounded size.
createLocalArrayHandles(int, PrimitiveTypeOps<R>, ReduceOperation<S, R>, CreateReducersApi) - Static method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
Registers one new local reducer, that will reduce BasicArray, by reducing individual elements using elementReduceOp, with predefined size.
createLocalMapHandles(PrimitiveIdTypeOps<K>, PrimitiveTypeOps<R>, ReduceOperation<S, R>, CreateReducersApi) - Static method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
Registers one new local reducer, that will reduce BasicMap, by reducing individual elements corresponding to the same key using elementReduceOp.
createLocalReducer(ReduceOperation<S, R>) - Method in interface org.apache.giraph.block_app.framework.api.CreateReducersApi
Create local reducer, returning a handle to it.
createLocalReducer(ReduceOperation<S, R>, R) - Method in interface org.apache.giraph.block_app.framework.api.CreateReducersApi
Create local reducer, returning a handle to it.
createLocalReducer(ReduceOperation<S, R>) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
createLocalReducer(ReduceOperation<S, R>, R) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
createLocalReducer(MasterGlobalCommUsage, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
createMapHandles(PrimitiveIdTypeOps<K>, PrimitiveTypeOps<R>, ReduceOperation<S, R>, CreateReducersApi.CreateReducerFunctionApi) - Static method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
Registers one new reducer, that will reduce BasicMap, by reducing individual elements corresponding to the same key using elementReduceOp.
createMapperObservers(Mapper<?, ?, ?, ?>.Context) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create array of MapperObservers.
createMappingInputFormats(ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.io.formats.multi.MappingInputFormatDescription
Create all mapping input formats
createMappingInputSplits() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Create the BspInputSplit objects from the index range based on the user-defined MappingInputFormat.
createMappingInputSplits() - Method in class org.apache.giraph.master.BspServiceMaster
 
createMappingReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
 
createMappingReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedMappingInputFormat
 
createMappingReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.MappingInputFormat
Create a vertex reader for a given split.
createMappingStore() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a MappingStore instance
createMappingStoreOps() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a MappingStoreOps instance
createMappingTarget() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create and return mappingTarget instance
createMasterCompute() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user master
createMasterGraphPartitioner() - Method in class org.apache.giraph.partition.GraphPartitionerFactory
 
createMasterGraphPartitioner() - Method in interface org.apache.giraph.partition.GraphPartitionerFactoryInterface
Create the MasterGraphPartitioner used by the master.
createMasterObservers(Mapper<?, ?, ?, ?>.Context) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create array of MasterObservers.
createMaxPositiveValue() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createMaxPositiveValue() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createMaxPositiveValue() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createMaxPositiveValue() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createMaxPositiveValue() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createMaxPositiveValue() - Method in interface org.apache.giraph.types.ops.NumericTypeOps
Maximal positive value representable via current type.
createMessage() - Method in class org.apache.giraph.comm.messages.PointerListMessagesIterable
Create message from factory
createMessageCombiner(ImmutableClassesGiraphConfiguration<I, ? extends Writable, ? extends Writable>) - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
createMessageCombiner(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
createMessageCombiner(ImmutableClassesGiraphConfiguration<I, ? extends Writable, ? extends Writable>) - Method in interface org.apache.giraph.conf.MessageClasses
Create new instance of MessageCombiner
createMessagesInputOutput() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create DataInputOutput to store messages
createMessageValueFactory(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
createMessageValueFactory(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
createMessageValueFactory(ImmutableClassesGiraphConfiguration) - Method in interface org.apache.giraph.conf.MessageClasses
Create new instance of MessageValueFactory
createMigrationAppBlock(Class<? extends MigrationAbstractComputation.MigrationFullAbstractComputation<I, V, E, MR, MS>>, MigrationMasterCompute.MigrationFullMasterCompute, Class<MS>, Class<? extends MessageCombiner<? super I, MS>>, GiraphConfiguration) - Method in class org.apache.giraph.block_app.migration.MigrationFullBlockFactory
 
createMigrationPiece(Class<? extends MigrationAbstractComputation<I, V, E, MR, MS>>, MigrationMasterCompute, Supplier<Iterable<MR>>, Consumer<Iterable<MS>>, Class<MS>, Class<? extends MessageCombiner<? super I, MS>>) - Static method in class org.apache.giraph.block_app.migration.MigrationPiece
 
createMinNegativeValue() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createMinNegativeValue() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createMinNegativeValue() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createMinNegativeValue() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createMinNegativeValue() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createMinNegativeValue() - Method in interface org.apache.giraph.types.ops.NumericTypeOps
Minimal negative value representable via current type.
createOnceExt(String, byte[], List<ACL>, CreateMode, boolean) - Method in class org.apache.giraph.zk.ZooKeeperExt
Create a znode if there is no other znode there
createOne() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createOne() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createOne() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createOne() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createOne() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createOne() - Method in interface org.apache.giraph.types.ops.NumericTypeOps
Value of one
createOpenHashSet() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createOpenHashSet(long) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createOpenHashSet() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createOpenHashSet(long) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createOpenHashSet() - Method in interface org.apache.giraph.types.ops.PrimitiveIdTypeOps
Create BasicSet of type T.
createOpenHashSet(long) - Method in interface org.apache.giraph.types.ops.PrimitiveIdTypeOps
Create BasicSet of type T, given capacity.
createOrSetExt(String, byte[], List<ACL>, CreateMode, boolean, int) - Method in class org.apache.giraph.zk.ZooKeeperExt
Create a znode.
createOutEdges() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user OutEdges
createOutgoingMessageCombiner() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user combiner class
createOutgoingMessageValueFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create new outgoing message value factory
createOutput(int) - Method in class org.apache.giraph.utils.io.BigDataOutput
Create next data output
createOutputWriter(Configuration, Progressable) - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
Create writer
createPartition(int, Progressable) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a partition
createPartitionEntry(int) - Static method in class org.apache.giraph.ooc.persistence.DataIndex.NumericIndexEntry
Create a data index entry for a given partition
createPartitionOwner() - Method in interface org.apache.giraph.partition.WorkerGraphPartitioner
Instantiate the PartitionOwner implementation used to read the master assignments.
createPartitionOwner() - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
 
createPartitionStats() - Method in interface org.apache.giraph.partition.MasterGraphPartitioner
Instantiate the PartitionStats implementation used to read the worker stats
createPartitionStats() - Method in class org.apache.giraph.partition.MasterGraphPartitionerImpl
 
createReceiveFiltering(SupplierFromVertex<I, V, E, Boolean>, Block) - Static method in class org.apache.giraph.block_app.framework.block.FilteringBlock
Creates filtering block, that filters only vertexReceive function, and always calls vertexSend function.
createReceiveFiltering(SupplierFromVertex<? super I, ? super V, ? super E, Boolean>, AbstractPiece<? super I, ? super V, ? super E, ? super M, ? super WV, ? super WM, ? super S>) - Static method in class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
Creates filtering piece, that filters only vertexReceive function, and always calls vertexSend function.
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.bsp.BspInputFormat
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.GiraphTextInputFormat
 
createReduceOperation() - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle
 
createReduceOperation() - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle
 
createReduceOperation() - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle
 
createReduceOperation() - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
createReducer(ReduceOperation<S, R>) - Method in interface org.apache.giraph.block_app.framework.api.CreateReducersApi.CreateReducerFunctionApi
 
createReduceResult(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedPrimitiveReducerHandle
 
createReduceResult(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedReducerHandle
 
createReduceResult(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle
 
createReduceResult(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
CreateReducersApi - Interface in org.apache.giraph.block_app.framework.api
Api for creating reducer handles.
CreateReducersApi.CreateReducerFunctionApi - Interface in org.apache.giraph.block_app.framework.api
Function that creates a reducer - abstracting away whether it is local or global reducer
CreateReducersApiWrapper - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Wrapping masterApi and reducers handler into API for creating reducer handles.
CreateReducersApiWrapper(BlockMasterApi, ReducersForPieceHandler) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
createReusable(I, E) - Static method in class org.apache.giraph.edge.EdgeFactory
Create a reusable edge pointing to a given ID with a value
createReusable(I) - Static method in class org.apache.giraph.edge.EdgeFactory
Create a reusable edge pointing to a given ID with a value
createReusableEdge() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a reusable edge.
createSendFiltering(SupplierFromVertex<I, V, E, Boolean>, Block) - Static method in class org.apache.giraph.block_app.framework.block.FilteringBlock
Creates filtering block, that filters only vertexSend function, and always calls vertexReceive function.
createSendFiltering(SupplierFromVertex<? super I, ? super V, ? super E, Boolean>, AbstractPiece<? super I, ? super V, ? super E, ? super M, ? super WV, ? super WM, ? super S>) - Static method in class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
Creates filtering block, that filters only vertexSend function, and always calls vertexReceive function.
createSingleStripeBySendersFunction(Block) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Given a block, creates a function that will given a predicate filter calls to vertexSend function based on that predicate.
createSingleValue() - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
 
createSingleValue() - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle
 
CreateSourceVertexCallback<I extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Implementations of this interface can decide whether we should create a vertex when it is not present in vertex input but exists in edge input.
createSuperstepEntry(long) - Static method in class org.apache.giraph.ooc.persistence.DataIndex.NumericIndexEntry
Create a data index entry for a given superstep
createSuperstepOutput(Mapper<?, ?, ?, ?>.Context) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create the proper superstep output, based on the configuration settings.
createTempDir(File, String) - Static method in class org.apache.giraph.utils.FileUtils
Make a temporary directory.
createTempFile(File, String) - Static method in class org.apache.giraph.utils.FileUtils
Make a temporary file.
createTestDir(String) - Static method in class org.apache.giraph.utils.FileUtils
Create a temporary folder that will be removed after the test.
createTestTempFileOrDir(File, String, boolean) - Static method in class org.apache.giraph.utils.FileUtils
Create a test temp file or directory.
createThreadFactory(String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.giraph.utils.ThreadUtils
Creates new thread factory with specified thread name format.
createThreadFactory(String) - Static method in class org.apache.giraph.utils.ThreadUtils
Creates new thread factory with specified thread name format.
createToRead(ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.master.SuperstepClasses
Create empty superstep classes, readFields needs to be called afterwards
createUncaughtExceptionHandler() - Method in class org.apache.giraph.graph.GraphTaskManager
Creates exception handler that will terminate process gracefully in case of any uncaught exception.
createUncaughtExceptionHandler(GraphTaskManager.CheckerIfWorkerShouldFailAfterException) - Method in class org.apache.giraph.graph.GraphTaskManager
Creates exception handler with the passed implementation of GraphTaskManager.CheckerIfWorkerShouldFailAfterException.
createUnknownCount() - Static method in class org.apache.giraph.block_app.framework.block.PieceCount
 
createValue() - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
createValue() - Method in class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
createValue() - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
createValue() - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
createValue() - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
Look at ReduceOperation.createValue.
createVertex() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
createVertex() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a vertex
createVertexId() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user vertex index
createVertexId(Et) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Create vertexId from a given key
createVertexId(Int2ObjectMap.Entry<OutEdges<IntWritable, E>>) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
createVertexId(Long2ObjectMap.Entry<OutEdges<LongWritable, E>>) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
createVertexId(Map.Entry<I, OutEdges<I, E>>) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
createVertexIdData() - Method in class org.apache.giraph.comm.requests.SendWorkerDataRequest
Create a new VertexIdData specialized for the use case.
createVertexIdData() - Method in class org.apache.giraph.comm.requests.SendWorkerEdgesRequest
 
createVertexIdData() - Method in class org.apache.giraph.comm.requests.SendWorkerMessagesRequest
 
createVertexIdData() - Method in class org.apache.giraph.comm.SendEdgeCache
 
createVertexIdData() - Method in class org.apache.giraph.comm.SendMessageCache
 
createVertexIdData() - Method in class org.apache.giraph.comm.SendVertexIdDataCache
Create a new VertexIdData specialized for the use case.
createVertexInputFormats(ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.io.formats.multi.VertexInputFormatDescription
Create all vertex input formats
createVertexInputSplits() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Create the BspInputSplit objects from the index range based on the user-defined VertexInputFormat.
createVertexInputSplits() - Method in class org.apache.giraph.master.BspServiceMaster
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.io.formats.BrachaTouegDeadlockInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.LongDoubleFloatTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.LongDoubleNullTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IntIntNullTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IntNullNullTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.JsonBase64VertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.JsonLongDoubleFloatDoubleVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.LongDoubleDoubleAdjacencyListVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.LongLongNullTextInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.PseudoRandomIntNullVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.PseudoRandomVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextDoubleDoubleAdjacencyListVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat
The factory method which produces the TextVertexInputFormat.TextVertexReader used by this input format.
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.WattsStrogatzVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedVertexInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.VertexInputFormat
Create a vertex reader for a given split.
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.VertexValueInputFormat
 
createVertexReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.utils.InMemoryVertexInputFormat
 
createVertexResolver() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user vertex revolver
createVertexValue() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user vertex value
createVertexValueCombiner() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user vertex value combiner class
createVertexValueReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IntIntTextVertexValueInputFormat
 
createVertexValueReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat
 
createVertexValueReader(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.VertexValueInputFormat
Create a VertexValueReader for a given split.
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.examples.SimpleTextVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.examples.VertexWithDoubleValueDoubleEdgeTextOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.examples.VertexWithDoubleValueNullEdgeTextOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.GraphvizOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.InMemoryVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.JsonBase64VertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.JsonLongDoubleFloatDoubleVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.SequenceFileVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat
The factory method which produces the TextVertexOutputFormat.TextVertexWriter used by this output format.
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedVertexOutputFormat
 
createVertexWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.VertexOutputFormat
Create a vertex writer for a given split.
createWithOptional(String, String) - Static method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Create registry with group to use for metrics.
createWorkerContext() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a user worker context
createWorkerGraphPartitioner() - Method in class org.apache.giraph.partition.GraphPartitionerFactory
 
createWorkerGraphPartitioner() - Method in interface org.apache.giraph.partition.GraphPartitionerFactoryInterface
Create the WorkerGraphPartitioner used by the worker.
createWorkerObservers(Mapper<?, ?, ?, ?>.Context) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create array of WorkerObservers.
createWrappedEdgeInputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a wrapper for user edge input format, which makes sure that Configuration parameters are set properly in all methods related to this format.
createWrappedEdgeOutputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a wrapper for user edge output format, which makes sure that Configuration parameters are set properly in all methods related to this format.
createWrappedMappingInputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a wrapper for user mapping input format, which makes sure that Configuration parameters are set properly in all methods related to this format.
createWrappedVertexInputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a wrapper for user vertex input format, which makes sure that Configuration parameters are set properly in all methods related to this format.
createWrappedVertexOutputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create a wrapper for user vertex output format, which makes sure that Configuration parameters are set properly in all methods related to this format.
createWritable() - Method in class org.apache.giraph.comm.messages.MessagesIterable
 
createWritable() - Method in class org.apache.giraph.utils.ByteStructIterable
Must be able to create the writable object
createWritable() - Method in class org.apache.giraph.utils.ByteStructIterator
Must be able to create the writable object
createWritable(Class<W>) - Static method in class org.apache.giraph.utils.WritableUtils
Instantiate a new Writable, checking for NullWritable along the way.
createWritable(Class<W>, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.WritableUtils
Instantiate a new Writable, checking for NullWritable along the way.
createZero() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
createZero() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
createZero() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
createZero() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
createZero() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
createZero() - Method in interface org.apache.giraph.types.ops.NumericTypeOps
Value of zero
CREDIT_HIGH_THRESHOLD - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
If mem-usage is above this threshold, credit is set to 0
CREDIT_LOW_THRESHOLD - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
If mem-usage is below this threshold, credit is set to max
CreditBasedFlowControl - Class in org.apache.giraph.comm.flow_control
Representation of credit-based flow control policy.
CreditBasedFlowControl(ImmutableClassesGiraphConfiguration, NettyClient, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Constructor
CTRL_IN_EDGE - Static variable in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
Bracha-Toueg control incoming-edge message
CURRENT_MASTER_PARTITION_TASK_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
current master partition task counter name
CURRENT_WORKERS_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
workers counter name
currentDataOutput - Variable in class org.apache.giraph.utils.io.BigDataOutput
Data output which we are currently writing to
currentSuperstep - Variable in class org.apache.giraph.worker.WorkerProgressStats
Superstep which worker is executing, Long.MAX_VALUE if it's output
CustomCounter - Class in org.apache.giraph.counters
An object of this class represents a counter with a group name, counter name, value, and type of aggregation to be performed
CustomCounter() - Constructor for class org.apache.giraph.counters.CustomCounter
Create a default custom counter
CustomCounter(String, String, CustomCounter.Aggregation) - Constructor for class org.apache.giraph.counters.CustomCounter
Create a counter with a given group, name, and aggregation type The default value is 0
CustomCounter(String, String, CustomCounter.Aggregation, long) - Constructor for class org.apache.giraph.counters.CustomCounter
Create a counter with a group, name, aggregation type, and value
CustomCounter.Aggregation - Enum in org.apache.giraph.counters
To store the type of aggregation to be done on the counters
CustomCounters - Class in org.apache.giraph.counters
Custom counters created by the client or app Stores the names of the counters, and the final aggregated values Since there is no way to get the list of available counters from the context, we need to call addCustomCounter to store the information about the list of available counters.
CustomCounters() - Constructor for class org.apache.giraph.counters.CustomCounters
Create custom counters

D

dataExist(int, DataIndex) - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
 
dataExist(int, DataIndex) - Method in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
 
dataExist(int, DataIndex) - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
Whether the data for the given thread and index chain exists?
DataIndex - Class in org.apache.giraph.ooc.persistence
Index chain used in out-of-core data accessor object (DAO) to access serialized data.
DataIndex() - Constructor for class org.apache.giraph.ooc.persistence.DataIndex
 
DataIndex.DataIndexEntry - Interface in org.apache.giraph.ooc.persistence
Interface to unify different types of entries used as index chain
DataIndex.NumericIndexEntry - Class in org.apache.giraph.ooc.persistence
Class representing any index chain that depends on something with id.
DataIndex.TypeIndexEntry - Enum in org.apache.giraph.ooc.persistence
Different static types of index chain entry
dataInputFactory - Variable in class org.apache.giraph.utils.ByteStructIterable
Factory for data input
DataInputOutput - Class in org.apache.giraph.utils.io
Provides both DataOutput which we can write to and DataInputs which are going to read data which was written to DataOutput.
DataInputOutput() - Constructor for class org.apache.giraph.utils.io.DataInputOutput
 
DataInputWrapperStream - Class in org.apache.giraph.writable.kryo
Thin wrapper around DataInput so it can be used as an InputStream For use with Input
DataInputWrapperStream() - Constructor for class org.apache.giraph.writable.kryo.DataInputWrapperStream
 
dataOutput - Variable in class org.apache.giraph.comm.aggregators.CountingOutputStream
DataOutput to which subclasses will be writing data
dataOutputs - Variable in class org.apache.giraph.utils.io.BigDataOutput
List of filled outputs, will be null until we get a lot of data
DataOutputWrapperStream - Class in org.apache.giraph.writable.kryo
Thin wrapper around a DataOutput so it can be used as an OutputStream For use with Output)
DataOutputWrapperStream() - Constructor for class org.apache.giraph.writable.kryo.DataOutputWrapperStream
 
dataSize - Variable in class org.apache.giraph.utils.ByteStructVertexIdDataIterator
Serialized size of the message object in bytestore
deactivate() - Method in class org.apache.giraph.examples.scc.SccVertexValue
Remove this vertex from the computation.
dec() - Method in class com.yammer.metrics.core.NoOpCounter
 
dec(long) - Method in class com.yammer.metrics.core.NoOpCounter
 
DECIMAL_FORMAT - Static variable in class org.apache.giraph.job.CombinedWorkerProgress
Decimal format which rounds numbers to two decimal places
decode(ChannelHandlerContext, Object) - Method in class org.apache.giraph.comm.netty.handler.SaslClientHandler
Decode the message read by handler
decodeBytes(String) - Static method in class org.apache.giraph.utils.ConfigurationObjectUtils
Decode bytes from a hex String
decodeEdge(String, String) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
Decode an edge from the line into an instance of a correctly typed Edge
decodeEdge(String, String) - Method in class org.apache.giraph.io.formats.LongDoubleDoubleAdjacencyListVertexInputFormat.LongDoubleDoubleAdjacencyListVertexReader
 
decodeEdge(String, String) - Method in class org.apache.giraph.io.formats.TextDoubleDoubleAdjacencyListVertexInputFormat.TextDoubleDoubleAdjacencyListVertexReader
 
decodeId(String) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
Decode the id for this line into an instance of its correct type.
decodeId(String) - Method in class org.apache.giraph.io.formats.LongDoubleDoubleAdjacencyListVertexInputFormat.LongDoubleDoubleAdjacencyListVertexReader
 
decodeId(String) - Method in class org.apache.giraph.io.formats.TextDoubleDoubleAdjacencyListVertexInputFormat.TextDoubleDoubleAdjacencyListVertexReader
 
decodeValue(String) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
Decode the value for this line into an instance of its correct type.
decodeValue(String) - Method in class org.apache.giraph.io.formats.LongDoubleDoubleAdjacencyListVertexInputFormat.LongDoubleDoubleAdjacencyListVertexReader
 
decodeValue(String) - Method in class org.apache.giraph.io.formats.TextDoubleDoubleAdjacencyListVertexInputFormat.TextDoubleDoubleAdjacencyListVertexReader
 
decodeWritableRequest(ByteBuf, WritableRequest) - Static method in class org.apache.giraph.utils.RequestUtils
decodeWritableRequest based on predicate
decrementEdges() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
Decrement the number of edges (to account for a deletion from the mutable iterator).
DEFAULT_INPUT_SPLIT_THREAD_COUNT - Static variable in class org.apache.giraph.master.BspServiceMaster
Default number of threads to use when writing input splits to zookeeper
DEFAULT_NUM_BYTES_PER_MESSAGE - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
Default bytes per message
DEFAULT_NUM_MESSAGES_PER_EDGE - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
Default messages per edge
DEFAULT_READER_EDGES - Static variable in class org.apache.giraph.examples.GeneratedEdgeReader
Default edges produced by this reader
DEFAULT_ZOOKEEPER_MAX_CLIENT_CNXNS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Default ZooKeeper maximum client connections.
DEFAULT_ZOOKEEPER_SNAP_COUNT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Default ZooKeeper snap count.
DEFAULT_ZOOKEEPER_TICK_TIME - Static variable in interface org.apache.giraph.conf.GiraphConstants
Default ZooKeeper tick time.
DefaultCheckpointSupportedChecker - Class in org.apache.giraph.bsp.checkpoints
Default checkpoint supported checker.
DefaultCheckpointSupportedChecker() - Constructor for class org.apache.giraph.bsp.checkpoints.DefaultCheckpointSupportedChecker
 
DefaultComputationFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Default computation factory that simply creates java computation object
DefaultComputationFactory() - Constructor for class org.apache.giraph.factories.DefaultComputationFactory
 
DefaultCreateSourceVertexCallback<I extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Default implementation of vertex creation decision maker.
DefaultCreateSourceVertexCallback() - Constructor for class org.apache.giraph.edge.DefaultCreateSourceVertexCallback
 
DefaultEdge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
A complete edge, the target vertex and the edge value.
DefaultEdge() - Constructor for class org.apache.giraph.edge.DefaultEdge
Constructor for reflection
DefaultEdge(I, E) - Constructor for class org.apache.giraph.edge.DefaultEdge
Create the edge with final values.
DefaultEdgeInputFilter<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.filters
Default edge filter that lets in all edges.
DefaultEdgeInputFilter() - Constructor for class org.apache.giraph.io.filters.DefaultEdgeInputFilter
 
DefaultEdgeValueFactory<E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Factory class to create default edge values.
DefaultEdgeValueFactory() - Constructor for class org.apache.giraph.factories.DefaultEdgeValueFactory
 
DefaultEmbeddedLongByteOps - Class in org.apache.giraph.mapping
MappingStoreOps implementation used to embed target information into vertex id.
DefaultEmbeddedLongByteOps() - Constructor for class org.apache.giraph.mapping.DefaultEmbeddedLongByteOps
Default constructor (do not use)
DefaultGiraphJobRetryChecker - Class in org.apache.giraph.job
Default implementation of GiraphJobRetryChecker, which never retries the job.
DefaultGiraphJobRetryChecker() - Constructor for class org.apache.giraph.job.DefaultGiraphJobRetryChecker
 
DefaultHaltInstructionsWriter() - Constructor for class org.apache.giraph.job.HaltApplicationUtils.DefaultHaltInstructionsWriter
 
DefaultImmutableClassesGiraphConfigurable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.conf
Default implementation of ImmutableClassesGiraphConfigurable
DefaultImmutableClassesGiraphConfigurable() - Constructor for class org.apache.giraph.conf.DefaultImmutableClassesGiraphConfigurable
 
DefaultInputOutEdgesFactory<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Default factory class for creating OutEdges instances to be used during input.
DefaultInputOutEdgesFactory() - Constructor for class org.apache.giraph.factories.DefaultInputOutEdgesFactory
 
DefaultJobObserver - Class in org.apache.giraph.job
Default implementation of job observer that does nothing.
DefaultJobObserver() - Constructor for class org.apache.giraph.job.DefaultJobObserver
 
DefaultJobProgressTrackerService - Class in org.apache.giraph.job
Default implementation of JobProgressTrackerService
DefaultJobProgressTrackerService() - Constructor for class org.apache.giraph.job.DefaultJobProgressTrackerService
 
DefaultLongByteOps - Class in org.apache.giraph.mapping
MappingStoreOps implementation which reads partition information from map
DefaultLongByteOps() - Constructor for class org.apache.giraph.mapping.DefaultLongByteOps
Default constructor (do not use)
DefaultMasterCompute - Class in org.apache.giraph.master
A dumb implementation of MasterCompute.
DefaultMasterCompute() - Constructor for class org.apache.giraph.master.DefaultMasterCompute
 
DefaultMasterObserver - Class in org.apache.giraph.master
A no-op implementation of MasterObserver to make it easier for users.
DefaultMasterObserver() - Constructor for class org.apache.giraph.master.DefaultMasterObserver
 
DefaultMessageClasses<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.conf
Default implementation of MessageClasses
DefaultMessageClasses() - Constructor for class org.apache.giraph.conf.DefaultMessageClasses
Constructor
DefaultMessageClasses(Class<M>, Class<? extends MessageValueFactory<M>>, Class<? extends MessageCombiner<? super I, M>>, MessageEncodeAndStoreType) - Constructor for class org.apache.giraph.conf.DefaultMessageClasses
Constructor
DefaultMessageFactorySupplierFromConf(Class<M>) - Constructor for class org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.DefaultMessageFactorySupplierFromConf
 
DefaultMessageValueFactory<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Factory class to create default message values.
DefaultMessageValueFactory(Class<M>, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.factories.DefaultMessageValueFactory
Constructor
DefaultOutEdgesFactory<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Default factory class for creating OutEdges instances to be used during computation.
DefaultOutEdgesFactory() - Constructor for class org.apache.giraph.factories.DefaultOutEdgesFactory
 
DefaultOutputCommitter - Class in org.apache.giraph.utils
Output committer which has abstract commit method
DefaultOutputCommitter() - Constructor for class org.apache.giraph.utils.DefaultOutputCommitter
 
DefaultParentPiece<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,WV,WM extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece
Additional abstract implementations for all pieces to be used.
DefaultParentPiece() - Constructor for class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
DefaultVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
Class which holds vertex id, data and edges.
DefaultVertex() - Constructor for class org.apache.giraph.graph.DefaultVertex
 
DefaultVertexIdFactory<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.factories
Default VertexIdFactory that simply uses the default constructor for the vertex ID class.
DefaultVertexIdFactory() - Constructor for class org.apache.giraph.factories.DefaultVertexIdFactory
 
DefaultVertexInputFilter<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.io.filters
Default vertex filter that lets in all vertices.
DefaultVertexInputFilter() - Constructor for class org.apache.giraph.io.filters.DefaultVertexInputFilter
 
DefaultVertexResolver<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
Default implementation of how to resolve vertex creation/removal, messages to nonexistent vertices, etc.
DefaultVertexResolver() - Constructor for class org.apache.giraph.graph.DefaultVertexResolver
 
DefaultVertexValueCombiner<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
The default vertex value combining approach is to simply keep the original value.
DefaultVertexValueCombiner() - Constructor for class org.apache.giraph.graph.DefaultVertexValueCombiner
 
DefaultVertexValueFactory<V extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Default VertexValueFactory that simply uses the default constructor for the vertex value class.
DefaultVertexValueFactory() - Constructor for class org.apache.giraph.factories.DefaultVertexValueFactory
 
DefaultWorkerContext - Class in org.apache.giraph.worker
A dummy implementation of WorkerContext.
DefaultWorkerContext() - Constructor for class org.apache.giraph.worker.DefaultWorkerContext
 
DefaultWorkerObserver - Class in org.apache.giraph.worker
Default Observer for Worker that does nothing.
DefaultWorkerObserver() - Constructor for class org.apache.giraph.worker.DefaultWorkerObserver
 
DelegatePiece<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,WV,WM extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece.delegate
Delegate Piece which allows combining multiple pieces in same iteration: new DelegatePiece(new LogicPiece(), new StatsPiece()) You should be careful when doing so, since those pieces must not interact, and only one can send messages.
DelegatePiece(AbstractPiece<? super I, ? super V, ? super E, ? super M, ? super WV, ? super WM, ? super S>...) - Constructor for class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
DelegatePiece(AbstractPiece<? super I, ? super V, ? super E, ? super M, ? super WV, ? super WM, ? super S>) - Constructor for class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
DelegatePiece.DelegateWorkerReceiveFunctions - Class in org.apache.giraph.block_app.framework.piece.delegate
Delegating WorkerReceivePiece
DelegatePiece.DelegateWorkerSendFunctions - Class in org.apache.giraph.block_app.framework.piece.delegate
Delegating WorkerSendPiece
delegateWorkerReceiveFunctions(ArrayList<VertexReceiver<I, V, E, M>>, BlockWorkerReceiveApi<I>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
DelegateWorkerReceiveFunctions(ArrayList<VertexReceiver<I, V, E, M>>) - Constructor for class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerReceiveFunctions
 
delegateWorkerReceiveFunctions(ArrayList<VertexReceiver<I, V, E, M>>, BlockWorkerReceiveApi<I>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
 
delegateWorkerSendFunctions(ArrayList<AbstractPiece<I, V, E, M, WV, WM, S>.InnerVertexSender>, BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
DelegateWorkerSendFunctions(ArrayList<AbstractPiece<I, V, E, M, WV, WM, S>.InnerVertexSender>) - Constructor for class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerSendFunctions
 
delegateWorkerSendFunctions(ArrayList<AbstractPiece<I, V, E, M, WV, WM, S>.InnerVertexSender>, BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
 
delegationName() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
delegationName() - Method in class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
 
delete(File) - Static method in class org.apache.giraph.utils.FileUtils
Recursively delete a directory
deleteExt(String, int, boolean) - Method in class org.apache.giraph.zk.ZooKeeperExt
Delete a path recursively.
deletePath(Configuration, String) - Static method in class org.apache.giraph.utils.FileUtils
Helper method to remove a path if it exists.
deletePath(Configuration, Path) - Static method in class org.apache.giraph.utils.FileUtils
Helper method to remove a path if it exists.
DeployedScript - Class in org.apache.giraph.scripting
A script that was deployed to the cluster.
DeployedScript(String, DeployType, Language) - Constructor for class org.apache.giraph.scripting.DeployedScript
Constructor
DeployType - Enum in org.apache.giraph.scripting
Type of deployment for a file
DirectWritableSerializer<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.writable.kryo.serializers
A custom Serializer that will call the Writable methods defined by the object itself to serialize the object, instead of Kryo auto-magically serializing
DirectWritableSerializer() - Constructor for class org.apache.giraph.writable.kryo.serializers.DirectWritableSerializer
 
DISABLE_GIRAPH_CLASS_RESOLVER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Whether to disable GiraphClassResolver which is an efficient implementation of kryo class resolver.
DisabledCheckpointSupportedChecker - Class in org.apache.giraph.bsp.checkpoints
Disable all checkpoints.
DisabledCheckpointSupportedChecker() - Constructor for class org.apache.giraph.bsp.checkpoints.DisabledCheckpointSupportedChecker
 
DISK_BANDWIDTH_ESTIMATE - Static variable in class org.apache.giraph.ooc.OutOfCoreIOStatistics
An estimate of disk bandwidth.
DiskBackedDataStore<T> - Class in org.apache.giraph.ooc.data
This class provides basic operations for data structures that have to participate in out-of-core mechanism.
DiskBackedEdgeStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.ooc.data
Implementation of an edge-store used for out-of-core mechanism.
DiskBackedEdgeStore(EdgeStore<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.data.DiskBackedEdgeStore
Constructor
DiskBackedMessageStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.ooc.data
Implementation of a message store used for out-of-core mechanism.
DiskBackedMessageStore(ImmutableClassesGiraphConfiguration<I, ?, ?>, OutOfCoreEngine, MessageStore<I, M>, boolean, long) - Constructor for class org.apache.giraph.ooc.data.DiskBackedMessageStore
Constructor
DiskBackedPartitionStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.ooc.data
Implementation of a partition-store used for out-of-core mechanism.
DiskBackedPartitionStore(PartitionStore<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>, Mapper<?, ?, ?, ?>.Context, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.data.DiskBackedPartitionStore
Constructor.
DistributedCacheUtils - Class in org.apache.giraph.utils
Helpers for dealing with DistributedCache
distributeReducedValues(Iterable<byte[]>) - Method in interface org.apache.giraph.comm.aggregators.WorkerAggregatorRequestProcessor
Sends reduced values to all other workers
distributeReducedValues(Iterable<byte[]>) - Method in class org.apache.giraph.comm.netty.NettyWorkerAggregatorRequestProcessor
 
DNS_INTERFACE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Interface to use for hostname resolution
DNS_NAMESERVER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Server for hostname resolution
DO_OUTPUT_DURING_COMPUTATION - Static variable in interface org.apache.giraph.conf.GiraphConstants
If you use this option, instead of having saving vertices in the end of application, saveVertex will be called right after each vertex.compute() is called.
doCompression() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Has the user enabled compression in netty client & server
doExchange() - Method in class org.apache.giraph.partition.PartitionExchange
Is this worker involved in a partition exchange? Receiving or sending?
DONE - Static variable in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
Bracha-Toueg DONE message.
DONE_FRACTIONS_TO_STORE_IN_COUNTERS - Static variable in class org.apache.giraph.master.input.MasterInputSplitsHandler
Store in counters timestamps when we finished reading these fractions of input
doneLoadingPartition(int, long) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that load of a partition for a specific superstep is completed
doneOffloadingBuffer(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that offload of raw data buffers (vertex/edges/ messages) of a particular partition is completed.
doneOffloadingMessages(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that offload of messages for a particular partition is complete.
doneOffloadingPartition(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that offload of a partition (partition data and its current messages) is completed.
doneProcessingPartition(int) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Notify out-of-core engine that processing of a particular partition is done
doOutputDuringComputation() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check if output should be done during computation
doRequest(WorkerInfo, WritableRequest) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
When doing the request, short circuit if it is local
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.AddressesAndPartitionsRequest
 
doRequest(MasterGlobalCommHandler) - Method in class org.apache.giraph.comm.requests.AskForInputSplitRequest
 
doRequest(MasterGlobalCommHandler) - Method in interface org.apache.giraph.comm.requests.MasterRequest
Execute the request
doRequest(MasterGlobalCommHandler) - Method in class org.apache.giraph.comm.requests.PartitionStatsRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.ReplyWithInputSplitRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendAggregatorsToOwnerRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendAggregatorsToWorkerRequest
 
doRequest(ServerData<I, V, E>) - Method in class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
 
doRequest(ServerData<I, V, E>) - Method in class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
 
doRequest(MasterGlobalCommHandler) - Method in class org.apache.giraph.comm.requests.SendReducedToMasterRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendResumeRequest
 
doRequest(ServerData<I, V, E>) - Method in class org.apache.giraph.comm.requests.SendVertexRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendWorkerAggregatorsRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendWorkerEdgesRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendWorkerMessagesRequest
 
doRequest(ServerData) - Method in class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
 
doRequest(ServerData<WritableComparable, Writable, Writable>) - Method in class org.apache.giraph.comm.requests.SendWorkerToWorkerMessageRequest
 
doRequest(ServerData<I, V, E>) - Method in class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
 
doRequest(ServerData<I, V, E>) - Method in interface org.apache.giraph.comm.requests.WorkerRequest
Execute the request
doSend(int, WritableRequest) - Method in class org.apache.giraph.comm.netty.NettyClient
Actual send of a request.
dotString() - Method in enum org.apache.giraph.graph.GraphType
Name of graph type with dots, like vertex.id or vertex.value
DOUBLE - Static variable in class org.apache.giraph.combiner.MaxMessageCombiner
DoubleWritable specialization
DOUBLE - Static variable in class org.apache.giraph.combiner.SumMessageCombiner
DoubleWritable specialization
DOUBLE - Static variable in class org.apache.giraph.reducers.impl.MaxReduce
DoubleWritable specialization
DOUBLE - Static variable in class org.apache.giraph.reducers.impl.MinReduce
DoubleWritable specialization
DOUBLE - Static variable in class org.apache.giraph.reducers.impl.SumReduce
DoubleWritable specialization
Double2DoubleFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (double) -> double
Double2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (double) -> T
DOUBLE_DOUBLE_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Double,DoubleWritable
DOUBLE_FLOAT_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Double,FloatWritable
DoubleBooleanConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, boolean) -> void
DoubleBooleanPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, boolean) -> boolean
DoubleByteConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, byte) -> void
DoubleBytePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, byte) -> boolean
DoubleConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (double) -> void
DoubleDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
A double matrix holds the values of the entries in double vectors.
DoubleDenseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Create a new matrix with the same number of rows and columns.
DoubleDenseMatrix(int, int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Create a new matrix with the given number of rows and columns.
DoubleDenseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The double dense matrix aggregator is used to register and aggregate double dense matrices.
DoubleDenseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
DoubleDenseVector - Class in org.apache.giraph.aggregators.matrix.dense
The double dense vector holds the values of a particular row.
DoubleDenseVector() - Constructor for class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Create a new vector with default size.
DoubleDenseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Create a new vector with given size.
DoubleDenseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The double dense vector aggregator is used to aggregate double dense vectors.
DoubleDenseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVectorSumAggregator
 
DoubleDoubleConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, double) -> void
DoubleDoublePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, double) -> boolean
DoubleDoubleWritable - Class in org.apache.giraph.writable.tuple
Double-double Pair Writable
DoubleDoubleWritable() - Constructor for class org.apache.giraph.writable.tuple.DoubleDoubleWritable
Constructor
DoubleDoubleWritable(double, double) - Constructor for class org.apache.giraph.writable.tuple.DoubleDoubleWritable
Constructor
DoubleEdgeValue() - Constructor for class org.apache.giraph.mapping.translate.LongByteTranslateEdge.DoubleEdgeValue
 
DoubleFloatConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, float) -> void
DoubleFloatPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, float) -> boolean
DoubleIntConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, int) -> void
DoubleIntPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, int) -> boolean
DoubleLongConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, long) -> void
DoubleLongPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (double, long) -> boolean
DoubleMaxAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting max double value.
DoubleMaxAggregator() - Constructor for class org.apache.giraph.aggregators.DoubleMaxAggregator
 
DoubleMaxWrapperAggregator() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.DoubleMaxWrapperAggregator
 
DoubleMinAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting min double value.
DoubleMinAggregator() - Constructor for class org.apache.giraph.aggregators.DoubleMinAggregator
 
DoubleMinWrapperAggregator() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.DoubleMinWrapperAggregator
 
DoubleOverwriteAggregator - Class in org.apache.giraph.aggregators
Aggregator that stores a value that is overwritten once another value is aggregated.
DoubleOverwriteAggregator() - Constructor for class org.apache.giraph.aggregators.DoubleOverwriteAggregator
 
DoublePredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (double) -> boolean
DoubleProductAggregator - Class in org.apache.giraph.aggregators
Aggregator for calculating products of double values.
DoubleProductAggregator() - Constructor for class org.apache.giraph.aggregators.DoubleProductAggregator
 
DoubleRef(double) - Constructor for class org.apache.giraph.function.primitive.PrimitiveRefs.DoubleRef
Constructor
DoubleSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
A double matrix holds the values of the entries in double vectors.
DoubleSparseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrix
Create a new matrix with the given number of rows.
DoubleSparseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The double matrix aggregator is used to register and aggregate double matrices.
DoubleSparseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
DoubleSparseVector - Class in org.apache.giraph.aggregators.matrix.sparse
The double vector holds the values of a particular row.
DoubleSparseVector() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Create a new vector with default size.
DoubleSparseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Create a new vector with given size.
DoubleSparseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The double vector aggregator is used to aggregate double vectors.
DoubleSparseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVectorSumAggregator
 
DoubleSumAggregator - Class in org.apache.giraph.aggregators
Aggregator for summing up double values.
DoubleSumAggregator() - Constructor for class org.apache.giraph.aggregators.DoubleSumAggregator
 
DoubleSumMessageCombiner - Class in org.apache.giraph.combiner
Deprecated.
DoubleSumMessageCombiner() - Constructor for class org.apache.giraph.combiner.DoubleSumMessageCombiner
Deprecated.
 
doubleSupplier(double) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
 
DoubleToDoubleWritableWrapper - Class in org.apache.giraph.types
Converts Doubles to DoubleWritables
DoubleToDoubleWritableWrapper() - Constructor for class org.apache.giraph.types.DoubleToDoubleWritableWrapper
 
DoubleTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with DoubleWritable type
DoubleWritableToDoubleUnwrapper - Class in org.apache.giraph.types
Converts DoubleWritables to Doubles
DoubleWritableToDoubleUnwrapper() - Constructor for class org.apache.giraph.types.DoubleWritableToDoubleUnwrapper
 
doZooKeeperCleanup(ZooKeeperExt, String) - Method in class org.apache.giraph.zk.GiraphZooKeeperAdmin
Cleans the ZooKeeper quorum of in-memory failed/killed job fragments.
dropEdge(I, Edge<I, E>) - Method in class org.apache.giraph.io.filters.DefaultEdgeInputFilter
 
dropEdge(I, Edge<I, E>) - Method in interface org.apache.giraph.io.filters.EdgeInputFilter
Whether to drop this edge
dropVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.io.filters.DefaultVertexInputFilter
 
dropVertex(Vertex<I, V, E>) - Method in interface org.apache.giraph.io.filters.VertexInputFilter
Whether to drop a vertex on input.
dumpToStream(PrintStream) - Method in class org.apache.giraph.metrics.GiraphMetrics
Dump all metrics to output stream provided.
DynamicChannelBufferInputStream - Class in org.apache.giraph.utils
Special input that reads from a DynamicChannelBuffer.
DynamicChannelBufferInputStream(ByteBuf) - Constructor for class org.apache.giraph.utils.DynamicChannelBufferInputStream
Constructor.
DynamicChannelBufferOutputStream - Class in org.apache.giraph.utils
Special output stream that can grow as needed and dumps to a DynamicChannelBuffer.
DynamicChannelBufferOutputStream(int) - Constructor for class org.apache.giraph.utils.DynamicChannelBufferOutputStream
Constructor
DynamicChannelBufferOutputStream(ByteBuf) - Constructor for class org.apache.giraph.utils.DynamicChannelBufferOutputStream
Constructor with the buffer to use

E

EachVertexInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Traverse each Vertex in the graph, and initialize it with a given consumer function.
EachVertexInit(Consumer<Vertex<I, V, E>>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.EachVertexInit
 
Edge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
A complete edge, the target vertex and the edge value.
EDGE_ARRAY_KEY - Static variable in class org.apache.giraph.io.formats.JsonBase64VertexFormat
Edge value array key (all the edges are stored here)
EDGE_INPUT_DIR - Static variable in class org.apache.giraph.io.formats.GiraphFileInputFormat
Edge input file paths.
EDGE_INPUT_FILTER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
EdgeInputFilter class
EDGE_INPUT_FORMAT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
EdgeInputFormat class
EDGE_INPUT_FORMAT_DESCRIPTIONS - Static variable in class org.apache.giraph.io.formats.multi.EdgeInputFormatDescription
EdgeInputFormats description - JSON array containing a JSON array for each edge input.
EDGE_OUTPUT_FORMAT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
EdgeOutputFormat class
EDGE_OUTPUT_FORMAT_SUBDIR - Static variable in interface org.apache.giraph.conf.GiraphConstants
EdgeOutputFormat sub-directory
EDGE_STORE_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Edge Store Factory
EDGE_TRANSLATION_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Class used to conduct expensive edge translation during vertex input
EDGE_VALUE_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Edge value class
EDGE_VALUE_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Edge value factory class - optional
EdgeComparator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.utils
Comparator for edges.
EdgeComparator() - Constructor for class org.apache.giraph.utils.EdgeComparator
 
EdgeFactory - Class in org.apache.giraph.edge
Factory for creating Edges
EdgeInput() - Constructor for class org.apache.giraph.jython.JythonJob.EdgeInput
 
EdgeInputFilter<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.io.filters
Filters edges on input.
edgeInputFilterClass - Variable in class org.apache.giraph.conf.GiraphClasses
Edge Input Filter class
EdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Input format for reading single edges.
EdgeInputFormat() - Constructor for class org.apache.giraph.io.EdgeInputFormat
 
edgeInputFormatClass - Variable in class org.apache.giraph.conf.GiraphClasses
Edge input format class - cached for fast access
EdgeInputFormatDescription<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats.multi
Description of the edge input format - holds edge input format class and all parameters specifically set for that edge input format.
EdgeInputFormatDescription(Class<? extends EdgeInputFormat<I, E>>) - Constructor for class org.apache.giraph.io.formats.multi.EdgeInputFormatDescription
Constructor with edge input format class
EdgeInputFormatDescription(String) - Constructor for class org.apache.giraph.io.formats.multi.EdgeInputFormatDescription
Constructor with json string describing this input format
EdgeInputSplitsCallable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
Load as many edge input splits as possible.
EdgeInputSplitsCallable(EdgeInputFormat<I, E>, Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.EdgeInputSplitsCallable
Constructor.
EdgeInputSplitsCallableFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
EdgeInputSplitsCallableFactory(EdgeInputFormat<I, E>, Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.EdgeInputSplitsCallableFactory
Constructor.
edgeInputSplitsLoaded - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many edge input splits were loaded until now
edgeInputSplitsSet() - Method in class org.apache.giraph.master.MasterProgress
Whether or not number of edge input splits was set yet
EdgeIterables - Class in org.apache.giraph.utils
Utility methods for iterables of edges.
EdgeNoValue<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.edge
An edge that has no value.
EdgeOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
abstract class which can only write edges
EdgeOutputFormat() - Constructor for class org.apache.giraph.io.EdgeOutputFormat
 
edgeOutputFormatClass - Variable in class org.apache.giraph.conf.GiraphClasses
Edge output format class - cached for fast access
EdgeReader<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Analogous to org.apache.giraph.bsp.BspRecordReader for edges.
EdgeReader() - Constructor for class org.apache.giraph.io.EdgeReader
 
EdgeReaderWrapper<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.iterables
Wraps GiraphReader for edges into EdgeReader
EdgeReaderWrapper(GiraphReader<EdgeWithSource<I, E>>) - Constructor for class org.apache.giraph.io.iterables.EdgeReaderWrapper
Constructor
EDGES_FILTERED - Static variable in interface org.apache.giraph.metrics.MetricNames
Total edges loaded
EDGES_FILTERED_PCT - Static variable in interface org.apache.giraph.metrics.MetricNames
Percent of edges filtered out
EDGES_FILTERED_UPDATE_PERIOD - Static variable in class org.apache.giraph.worker.EdgeInputSplitsCallable
How often to update filtered metrics
EDGES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate edges counter name
EDGES_PER_VERTEX - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for number of edges per vertex
EDGES_PER_VERTEX - Static variable in class org.apache.giraph.io.formats.PseudoRandomInputFormatConstants
Set the number of edges per vertex (pseudo-random destination).
EDGES_UPDATE_PERIOD - Static variable in class org.apache.giraph.worker.EdgeInputSplitsCallable
How often to update metrics and print info
edgesLoaded - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many edges were loaded
EdgeStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Collects incoming edges for vertices owned by this worker.
EdgeStoreFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Factory to create a new Edge Store
edgeSupplier - Variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
edgeTranslationClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the class used for edge translation during vertex input
edgeTranslationInstance() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Instance of TranslateEdge that contains helper method for edge translation
EdgeValue() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.EdgeValue
Constructor
EdgeValue(Float) - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.EdgeValue
Constructor
EdgeValueFactory<E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.factories
Factory class to create default edge values.
edgeValueOrCreate(E) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
EdgeWithSource<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.iterables
Wrapper for edge and its source id
EdgeWithSource() - Constructor for class org.apache.giraph.io.iterables.EdgeWithSource
Constructor
EdgeWithSource(I, ReusableEdge<I, E>) - Constructor for class org.apache.giraph.io.iterables.EdgeWithSource
Constructor with source id and edge
EdgeWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
 
EdgeWriter() - Constructor for class org.apache.giraph.io.EdgeWriter
 
EGDE_BALANCE_ALGORITHM - Static variable in class org.apache.giraph.partition.PartitionBalancer
Rebalance across supersteps by edges
embedTargetInfo(LongWritable) - Method in class org.apache.giraph.mapping.DefaultEmbeddedLongByteOps
 
embedTargetInfo(LongWritable) - Method in class org.apache.giraph.mapping.DefaultLongByteOps
 
embedTargetInfo(I) - Method in interface org.apache.giraph.mapping.MappingStoreOps
Embed target information into vertexId
EMERGENCY_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
The memory pressure at which the job is cloe to fail, even though we were using maximal disk bandwidth and minimal network rate.
emit(String) - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext.EmitterWorkerContext
Write this string to the output stream.
EmitterWorkerContext() - Constructor for class org.apache.giraph.examples.SimpleVertexWithWorkerContext.EmitterWorkerContext
 
EmptyBlock - Class in org.apache.giraph.block_app.framework.block
Block without any pieces
EmptyBlock() - Constructor for class org.apache.giraph.block_app.framework.block.EmptyBlock
 
EmptyIterable<T> - Class in org.apache.giraph.utils
Singleton class for empty iterables.
EmptyIterable() - Constructor for class org.apache.giraph.utils.EmptyIterable
 
ENABLE_FAULT - Static variable in class org.apache.giraph.examples.SimpleCheckpoint
Should fault?
encodeBytes(byte[]) - Static method in class org.apache.giraph.utils.ConfigurationObjectUtils
Encode bytes to a hex String
endConsume(ConsumerWithVertex<I, V, E, P>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
End chain by processing messages received within the last link in the chain.
endCustom(Function<SupplierFromVertex<I, V, E, P>, Block>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
End chain by providing a function that will produce Block to be attached to the end of current chain, given a supplier of messages received within the last link in the chain.
endOfInput() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
endOfInput() - Method in interface org.apache.giraph.utils.ExtendedDataInput
Check if we read everything from the input
endOfInput() - Method in class org.apache.giraph.utils.io.BigDataInput
 
endOfInput() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
endReduce(String, ReduceOperation<S, R>, FunctionWithVertex<I, V, E, P, S>, Consumer<R>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
End chain by giving received messages to valueSupplier, to produce value that should be reduced, and consumed on master by reducedValueConsumer.
endReduceWithMaster(String, ReduceOperation<S, R>, FunctionWithVertex<I, V, E, P, S>, PairConsumer<R, BlockMasterApi>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
End chain by giving received messages to valueSupplier, to produce value that should be reduced, and consumed on master by reducedValueConsumer.
ensureWritable(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
ensureWritable(int) - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Ensure that backing byte structure has at least minSize additional bytes
ensureWritable(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
entrySerializedSize(T) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Gets the size of a given entry in bytes.
entrySerializedSize(VertexIdEdges<I, E>) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
entrySerializedSize(VertexIdMessages<I, M>) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
entrySerializedSize(ExtendedDataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
EnumConfOption<T extends Enum<T>> - Class in org.apache.giraph.conf
Enum Configuration option
EnumConfOption(String, Class<T>, T, String) - Constructor for class org.apache.giraph.conf.EnumConfOption
Constructor
equal(Edge<I, E>, Edge<I, E>) - Static method in class org.apache.giraph.utils.EdgeComparator
Indicates whether two edges are equal.
equals(Object) - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
equals(Object) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
equals(Object) - Method in class org.apache.giraph.comm.netty.handler.ClientRequestId
 
equals(Object) - Method in class org.apache.giraph.conf.AbstractConfOption
 
equals(Object) - Method in class org.apache.giraph.counters.CustomCounter
 
equals(Object) - Method in class org.apache.giraph.counters.GiraphHadoopCounter
 
equals(Object) - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair
 
equals(Object) - Method in class org.apache.giraph.graph.TaskInfo
 
equals(Object) - Method in class org.apache.giraph.jython.wrappers.JythonWrapperBase
 
equals(Object) - Method in class org.apache.giraph.jython.wrappers.JythonWritableWrapper
 
equals(Object) - Method in class org.apache.giraph.ooc.persistence.DataIndex
 
equals(Object) - Method in class org.apache.giraph.ooc.persistence.DataIndex.NumericIndexEntry
 
equals(Object) - Method in class org.apache.giraph.scripting.DeployedScript
 
equals(Object) - Method in class org.apache.giraph.types.JavaWritablePair
 
equals(Iterable<Edge<I, E>>, Iterable<Edge<I, E>>) - Static method in class org.apache.giraph.utils.EdgeIterables
Compare two edge iterables element-wise.
EVENT_WAIT_MSECS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Millseconds to wait for an event before continuing
eventType() - Method in class com.yammer.metrics.core.NoOpTimer
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.giraph.comm.netty.handler.RequestServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.giraph.comm.netty.handler.ResponseClientHandler
 
exchangeVertexPartitions(Collection<? extends PartitionOwner>) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
If desired by the user, vertex partitions are redistributed among workers according to the chosen WorkerGraphPartitioner.
exchangeVertexPartitions(Collection<? extends PartitionOwner>) - Method in class org.apache.giraph.worker.BspServiceWorker
 
execute(Runnable) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
execute() - Method in class org.apache.giraph.graph.GraphTaskManager
Perform the work assigned to this compute node for this job run.
execute() - Method in class org.apache.giraph.ooc.command.IOCommand
Execute (load/store of data) the IO command, and change the data stores appropriately based on the data loaded/stored.
execute() - Method in class org.apache.giraph.ooc.command.LoadPartitionIOCommand
 
execute() - Method in class org.apache.giraph.ooc.command.StoreDataBufferIOCommand
 
execute() - Method in class org.apache.giraph.ooc.command.StoreIncomingMessageIOCommand
 
execute() - Method in class org.apache.giraph.ooc.command.StorePartitionIOCommand
 
execute() - Method in class org.apache.giraph.ooc.command.WaitIOCommand
 
exists(String, boolean) - Method in class org.apache.giraph.zk.ZooKeeperExt
Return the stat of the node of the given path.
exists(String, Watcher) - Method in class org.apache.giraph.zk.ZooKeeperExt
Return the stat of the node of the given path.
exportGiraphConfiguration(GiraphConfiguration, ApplicationId) - Static method in class org.apache.giraph.yarn.YarnUtils
Export our populated GiraphConfiguration as an XML file to be used by the ApplicationMaster's exec container, and register it with LocalResources.
ExtendedByteArrayDataInput - Class in org.apache.giraph.utils
Provides access to a internals of ByteArrayInputStream
ExtendedByteArrayDataInput(byte[]) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayDataInput
Constructor
ExtendedByteArrayDataInput(byte[], int, int) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayDataInput
Get access to portion of a byte array
ExtendedByteArrayDataOutput - Class in org.apache.giraph.utils
Adds some functionality to ByteArrayOutputStream, such as an option to write int value over previously written data and directly get the byte array.
ExtendedByteArrayDataOutput(byte[]) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayDataOutput
Uses the byte array provided or if null, use a default size
ExtendedByteArrayDataOutput(byte[], int) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayDataOutput
Uses the byte array provided at the given pos
ExtendedByteArrayDataOutput() - Constructor for class org.apache.giraph.utils.ExtendedByteArrayDataOutput
Creates a new byte array output stream.
ExtendedByteArrayDataOutput(int) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayDataOutput
Creates a new byte array output stream, with a buffer capacity of the specified size, in bytes.
ExtendedByteArrayOutputBuffer - Class in org.apache.giraph.utils
Wraps a list of byte array outputs and provides convenient utilities on top of it
ExtendedByteArrayOutputBuffer(ImmutableClassesGiraphConfiguration<?, ?, ?>) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer
Constructor
ExtendedByteArrayOutputBuffer.IndexAndDataOut - Class in org.apache.giraph.utils
Holder for index & DataOutput objects
extendedDataInput - Variable in class org.apache.giraph.utils.ByteStructIterator
Data input
extendedDataInput - Variable in class org.apache.giraph.utils.ByteStructVertexIdIterator
Reader of the serialized edges
ExtendedDataInput - Interface in org.apache.giraph.utils
Add some functionality to data input
ExtendedDataInputOutput - Class in org.apache.giraph.utils.io
Wraps ExtendedDataOutput and ExtendedDataOutput to be able to write data and later read data from the same place
ExtendedDataInputOutput(ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.utils.io.ExtendedDataInputOutput
Constructor
extendedDataOutput - Variable in class org.apache.giraph.utils.AbstractVertexIdData
Extended data output
ExtendedDataOutput - Interface in org.apache.giraph.utils
Add a few features to data output
extractAvailableWorkers() - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
Update availableWorkers

F

FacebookConfiguration - Class in org.apache.giraph.conf
Default configuration used in Facebook
FacebookConfiguration() - Constructor for class org.apache.giraph.conf.FacebookConfiguration
 
Factory() - Constructor for class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore.Factory
Constructor for reflection
Factory(PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore.Factory
 
Factory(MasterGlobalCommHandler) - Constructor for class org.apache.giraph.comm.netty.handler.MasterRequestServerHandler.Factory
Constructor
Factory() - Constructor for class org.apache.giraph.comm.netty.handler.SaslServerHandler.Factory
Constructor
Factory(ServerData<I, V, E>) - Constructor for class org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler.Factory
Constructor
factory(ImmutableClassesGiraphConfiguration) - Method in enum org.apache.giraph.graph.GraphType
Get factory for creating this graph type
Factory<T> - Interface in org.apache.giraph.utils
Factory for any kind of objects
factoryClassOption() - Method in enum org.apache.giraph.graph.GraphType
Get the option for the factory that creates this graph type
FAIL_FIRST_IPC_PORT_BIND_ATTEMPT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Fail first IPC port binding attempt, simulate binding failure on real grid testing
FAIL_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
The memory pressure at/above which the job would fail
FAIL_ON_EMPTY_INPUT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Whether to fail the job or just warn when input is empty
failureCleanup(Exception) - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Called when the job fails in order to let the Master do any cleanup.
failureCleanup() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Operations that will be called if there is a failure by a worker.
failureCleanup(Exception) - Method in class org.apache.giraph.master.BspServiceMaster
 
failureCleanup() - Method in class org.apache.giraph.worker.BspServiceWorker
 
FailWithEveryExceptionOccurred() - Constructor for class org.apache.giraph.graph.GraphTaskManager.FailWithEveryExceptionOccurred
 
FakeTime - Class in org.apache.giraph.time
Thread-safe implementation of Time for testing that can help get time based ordering of events when desired.
FakeTime() - Constructor for class org.apache.giraph.time.FakeTime
 
fastForEachW(Consumer<BooleanWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
fastForEachW(Consumer<ByteWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
fastForEachW(Consumer<DoubleWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
fastForEachW(Consumer<FloatWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
fastForEachW(Consumer<IntWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
fastForEachW(Consumer<LongWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
fastForEachW(Consumer<T>) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Traverse all elements of the collection, calling given function on each element.
fastForEachWhileW(Predicate<BooleanWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
fastForEachWhileW(Predicate<ByteWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
fastForEachWhileW(Predicate<DoubleWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
fastForEachWhileW(Predicate<FloatWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
fastForEachWhileW(Predicate<IntWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
fastForEachWhileW(Predicate<LongWritable>) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
fastForEachWhileW(Predicate<T>) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Traverse all elements of the collection, calling given function on each element, or until predicate returns false.
fastHash(long) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Returns 32-bit hash of a given value.
fastHashStriping(int) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Fast hash-based striping for LongWritable IDs, returns a function that for a given ID returns it's stripe index.
fastHashStripingPredicate(int) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Fast hash-based striping for LongWritable IDs, returns a function that for a given stripe index returns a predicate checking whether ID is in that stripe.
fastIteratorW() - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
fastIteratorW(BooleanWritable) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
fastIteratorW() - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
fastIteratorW(ByteWritable) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
fastIteratorW() - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
fastIteratorW(DoubleWritable) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
fastIteratorW() - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
fastIteratorW(FloatWritable) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
fastIteratorW() - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
fastIteratorW(IntWritable) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
fastIteratorW() - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
fastIteratorW(LongWritable) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
fastIteratorW() - Method in interface org.apache.giraph.types.ops.collections.WCollection
Fast iterator over collection objects, which doesn't allocate new element for each returned element, and can be iterated multiple times using reset().
fastIteratorW(T) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Fast iterator over collection objects, which doesn't allocate new element for each returned element, and can be iterated multiple times using reset().
fastKeyIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
fastKeyIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
fastKeyIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
fastKeyIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Fast iterator over keys within this map, which doesn't allocate new element for each returned element.
fastStripe(long, int) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Returns number in [0, stripes) range, from given input value.
FastUtilSerializer<T> - Class in org.apache.giraph.writable.kryo.serializers
Kryo Serializer for Fastutil collection class.
FastUtilSerializer(Kryo, Class<T>) - Constructor for class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Creates and initializes new serializer for a given fastutil class.
FAULT_FILE - Static variable in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
Filename to indicate whether a fault was found
FAULTING_SUPERSTEP - Static variable in class org.apache.giraph.examples.SimpleCheckpoint
Which superstep to cause the worker to fail
FAULTING_VERTEX_ID - Static variable in class org.apache.giraph.examples.SimpleCheckpoint
Vertex id to fault on
fifteenMinuteRate() - Method in class com.yammer.metrics.core.NoOpMeter
 
fifteenMinuteRate() - Method in class com.yammer.metrics.core.NoOpTimer
 
FILENAME - Static variable in class org.apache.giraph.aggregators.TextAggregatorWriter
The filename of the outputfile
FileOutputFormatUtil - Class in org.apache.giraph.io.formats
Utility to access file output format in a way independent of current hadoop implementation.
FileUtils - Class in org.apache.giraph.utils
Helper class for filesystem operations during testing
FILLING_THRESHOLD_OF_DATAOUT_IN_BUFFER - Static variable in class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer
This option sets the maximum fraction of a ExtendedDataOutput instance (stored in ExtendedByteArrayOutputBuffer) that can be filled
fillNextSuperstepMapsWhenReady(Set<Integer>, Map<String, Writable>, Map<String, Reducer<Object, Writable>>) - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
This function will wait until all aggregator requests from workers have arrived, and fill the maps for next superstep when ready.
fillW(int, int, T) - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Sets given range of elements to a specified value.
fillW(int, int, BooleanWritable) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
fillW(int, int, ByteWritable) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
fillW(int, int, DoubleWritable) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
fillW(int, int, FloatWritable) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
fillW(int, int, IntWritable) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
fillW(int, int, LongWritable) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
FilteringBlock<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.block
Block which filters out calls to vertexSend/vertexReceive functions of all pieces in a given block.
FilteringBlock(SupplierFromVertex<I, V, E, Boolean>, SupplierFromVertex<I, V, E, Boolean>, Block) - Constructor for class org.apache.giraph.block_app.framework.block.FilteringBlock
Creates filtering block which uses passed toCallSend to filter calls to vertexSend, and passed toCallReceive to filter calls to vertexReceive, on all pieces within passed block.
FilteringBlock(SupplierFromVertex<I, V, E, Boolean>, Block) - Constructor for class org.apache.giraph.block_app.framework.block.FilteringBlock
Creates filtering block, where both vertexSend and vertexReceive is filtered based on same supplier.
FilteringPiece<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,WV,WM extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece.delegate
Piece which uses a provided suppliers to decide whether or not to run receive/send piece part on a certain vertex.
FilteringPiece(SupplierFromVertex<? super I, ? super V, ? super E, Boolean>, SupplierFromVertex<? super I, ? super V, ? super E, Boolean>, AbstractPiece<? super I, ? super V, ? super E, ? super M, ? super WV, ? super WM, ? super S>) - Constructor for class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
Creates filtering piece which uses passed toCallSend to filter calls to vertexSend, and passed toCallReceive to filter calls to vertexReceive, on passed innerPiece.
FilteringPiece(SupplierFromVertex<? super I, ? super V, ? super E, Boolean>, AbstractPiece<? super I, ? super V, ? super E, ? super M, ? super WV, ? super WM, ? super S>) - Constructor for class org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece
Creates filtering piece, where both vertexSend and vertexReceive is filtered based on same supplier.
finalizeInput(boolean) - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataInputWrapper
 
finalizeInput(boolean) - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataInputWrapper
Finalize and close the DataInput used for persistence.
finalizeOutput() - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataOutputWrapper
 
finalizeOutput() - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataOutputWrapper
Finalize and close the DataOutput used for persistence.
finalizePartitionStats(Collection<PartitionStats>, PartitionStore<I, V, E>) - Method in interface org.apache.giraph.partition.WorkerGraphPartitioner
At the end of a superstep, workers have PartitionStats generated for each of their partitions.
finalizePartitionStats(Collection<PartitionStats>, PartitionStore<I, V, E>) - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
 
finalizeStore() - Method in interface org.apache.giraph.comm.messages.MessageStore
Called before start of computation in bspworker Since it is run from a single thread while the store is not being accessed by any other thread - this is ensured to be thread-safe
finalizeStore() - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
finalizeStore() - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
finalizeStore() - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
finalizeStore() - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractListStore
 
finalizeStore() - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
finalizeStore() - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
finalizeStore() - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
finalizeStore() - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
FINISHED_VERTICES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate finished vertices counter name
FinishedSuperstepStats - Class in org.apache.giraph.graph
Immutable graph stats after the completion of a superstep
FinishedSuperstepStats(long, boolean, long, long, boolean, CheckpointStatus) - Constructor for class org.apache.giraph.graph.FinishedSuperstepStats
Constructor.
finishLoadingEdges() - Method in class org.apache.giraph.worker.WorkerProgress
Notify this class that worker finished loading edges
finishLoadingVertices() - Method in class org.apache.giraph.worker.WorkerProgress
Notify this class that worker finished loading vertices
finishSendingValues() - Method in interface org.apache.giraph.comm.MasterClient
Flush aggregated values cache.
finishSendingValues() - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
finishStoring() - Method in class org.apache.giraph.worker.WorkerProgress
Notify this class that storing data is done
finishSuperstep(List<PartitionStats>, GiraphTimerContext) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Worker is done with its portion of the superstep.
finishSuperstep() - Method in class org.apache.giraph.master.MasterAggregatorHandler
Finalize aggregators for current superstep
finishSuperstep(List<PartitionStats>, GiraphTimerContext) - Method in class org.apache.giraph.worker.BspServiceWorker
 
finishSuperstep(WorkerAggregatorRequestProcessor) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
Send aggregators to their owners and in the end to the master
finishThreadComputation() - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
 
finishThreadComputation() - Method in class org.apache.giraph.worker.WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage
 
finishThreadComputation() - Method in interface org.apache.giraph.worker.WorkerThreadGlobalCommUsage
Call this after thread's computation is finished, i.e.
firstList - Variable in class org.apache.giraph.utils.PairList
List to keep first elements of pairs in
firstToken() - Method in class org.apache.giraph.comm.netty.SaslNettyClient
Used by authenticateOnChannel() to initiate SASL handshake with server.
fiveMinuteRate() - Method in class com.yammer.metrics.core.NoOpMeter
 
fiveMinuteRate() - Method in class com.yammer.metrics.core.NoOpTimer
 
FixedCapacityIntByteMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (int key, byte value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityIntByteMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Initialize the heap with desired capacity
FixedCapacityIntDoubleMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (int key, double value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityIntDoubleMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Initialize the heap with desired capacity
FixedCapacityIntFloatMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (int key, float value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityIntFloatMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Initialize the heap with desired capacity
FixedCapacityIntIntMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (int key, int value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityIntIntMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Initialize the heap with desired capacity
FixedCapacityIntLongMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (int key, long value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityIntLongMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Initialize the heap with desired capacity
FixedCapacityLongByteMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (long key, byte value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityLongByteMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Initialize the heap with desired capacity
FixedCapacityLongDoubleMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (long key, double value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityLongDoubleMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Initialize the heap with desired capacity
FixedCapacityLongFloatMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (long key, float value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityLongFloatMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Initialize the heap with desired capacity
FixedCapacityLongIntMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (long key, int value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityLongIntMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Initialize the heap with desired capacity
FixedCapacityLongLongMinHeap - Class in org.apache.giraph.types.heaps
Min heap which holds (long key, long value) pairs with the largest values as its elements, up to the given maximum number of elements.
FixedCapacityLongLongMinHeap(int) - Constructor for class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Initialize the heap with desired capacity
FixedPartitionsOracle - Class in org.apache.giraph.ooc.policy
Oracle for fixed out-of-core mechanism
FixedPartitionsOracle(ImmutableClassesGiraphConfiguration, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.policy.FixedPartitionsOracle
Constructor
FLOAT - Static variable in class org.apache.giraph.combiner.MaxMessageCombiner
DoubleWritable specialization
FLOAT - Static variable in class org.apache.giraph.combiner.SumMessageCombiner
DoubleWritable specialization
Float2FloatFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (float) -> float
Float2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (float) -> T
FLOAT_DOUBLE_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Float,DoubleWritable
FLOAT_FLOAT_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Float,FloatWritable
FloatBooleanConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, boolean) -> void
FloatBooleanPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, boolean) -> boolean
FloatByteConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, byte) -> void
FloatBytePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, byte) -> boolean
FloatConfOption - Class in org.apache.giraph.conf
Float Configuration option
FloatConfOption(String, float, String) - Constructor for class org.apache.giraph.conf.FloatConfOption
Constructor
FloatConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (float) -> void
FloatDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
A float matrix holds the values of the entries in float vectors.
FloatDenseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Create a new matrix with the same number of rows and columns.
FloatDenseMatrix(int, int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Create a new matrix with the given number of rows and columns.
FloatDenseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The float dense matrix aggregator is used to register and aggregate float dense matrices.
FloatDenseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
FloatDenseVector - Class in org.apache.giraph.aggregators.matrix.dense
The float dense vector holds the values of a particular row.
FloatDenseVector() - Constructor for class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Create a new vector with default size.
FloatDenseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Create a new vector with given size.
FloatDenseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The float dense vector aggregator is used to aggregate float dense vectors.
FloatDenseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.dense.FloatDenseVectorSumAggregator
 
FloatDoubleConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, double) -> void
FloatDoublePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, double) -> boolean
FloatEdgeValue() - Constructor for class org.apache.giraph.mapping.translate.LongByteTranslateEdge.FloatEdgeValue
 
FloatFloatConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, float) -> void
FloatFloatPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, float) -> boolean
FloatIntConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, int) -> void
FloatIntPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, int) -> boolean
FloatLongConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, long) -> void
FloatLongPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (float, long) -> boolean
FloatMaxAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting max float value.
FloatMaxAggregator() - Constructor for class org.apache.giraph.aggregators.FloatMaxAggregator
 
FloatMinAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting min float value.
FloatMinAggregator() - Constructor for class org.apache.giraph.aggregators.FloatMinAggregator
 
FloatOverwriteAggregator - Class in org.apache.giraph.aggregators
Aggregator that stores a value that is overwritten once another value is aggregated.
FloatOverwriteAggregator() - Constructor for class org.apache.giraph.aggregators.FloatOverwriteAggregator
 
FloatPredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (float) -> boolean
FloatProductAggregator - Class in org.apache.giraph.aggregators
Aggregator for calculating products of float values.
FloatProductAggregator() - Constructor for class org.apache.giraph.aggregators.FloatProductAggregator
 
FloatRef(float) - Constructor for class org.apache.giraph.function.primitive.PrimitiveRefs.FloatRef
Constructor
FloatSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
A float matrix holds the values of the entries in float vectors.
FloatSparseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Create a new matrix with the given number of rows.
FloatSparseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The float matrix aggregator is used to register and aggregate float matrices.
FloatSparseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
FloatSparseVector - Class in org.apache.giraph.aggregators.matrix.sparse
The float vector holds the values of a particular row.
FloatSparseVector() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
Create a new vector with default size.
FloatSparseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
Create a new vector with given size.
FloatSparseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The float vector aggregator is used to aggregate float vectors.
FloatSparseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVectorSumAggregator
 
FloatSumAggregator - Class in org.apache.giraph.aggregators
Aggregator for summing up float values.
FloatSumAggregator() - Constructor for class org.apache.giraph.aggregators.FloatSumAggregator
 
FloatSumMessageCombiner - Class in org.apache.giraph.combiner
Deprecated.
FloatSumMessageCombiner() - Constructor for class org.apache.giraph.combiner.FloatSumMessageCombiner
Deprecated.
 
FloatToDoubleWritableWrapper - Class in org.apache.giraph.types
Converts Floats to DoubleWritables
FloatToDoubleWritableWrapper() - Constructor for class org.apache.giraph.types.FloatToDoubleWritableWrapper
 
FloatToFloatWritableWrapper - Class in org.apache.giraph.types
Converts Floats to FloatWritables
FloatToFloatWritableWrapper() - Constructor for class org.apache.giraph.types.FloatToFloatWritableWrapper
 
FloatTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with FloatWritable type
FloatWritableToDoubleUnwrapper - Class in org.apache.giraph.types
Converts FloatWritables to Doubles
FloatWritableToDoubleUnwrapper() - Constructor for class org.apache.giraph.types.FloatWritableToDoubleUnwrapper
 
FloatWritableToFloatUnwrapper - Class in org.apache.giraph.types
Converts FloatWritables to Floats
FloatWritableToFloatUnwrapper() - Constructor for class org.apache.giraph.types.FloatWritableToFloatUnwrapper
 
FlowControl - Interface in org.apache.giraph.comm.flow_control
Interface representing flow control policy in sending requests
flowControl - Variable in class org.apache.giraph.comm.netty.handler.RequestServerHandler
Flow control used in sending requests
flush() - Method in class org.apache.giraph.comm.aggregators.CountingOutputStream
Returns all the data from the stream and clears it.
flush() - Method in interface org.apache.giraph.comm.aggregators.WorkerAggregatorRequestProcessor
Flush aggregated values cache.
flush() - Method in interface org.apache.giraph.comm.MasterClient
Flush all outgoing messages.
flush() - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
flush() - Method in class org.apache.giraph.comm.netty.NettyWorkerAggregatorRequestProcessor
 
flush() - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
flush() - Method in class org.apache.giraph.comm.SendMessageCache
Flush the rest of the messages to the workers.
flush() - Method in class org.apache.giraph.comm.SendOneMessageToManyCache
 
flush() - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Flush all outgoing messages.
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in interface org.apache.giraph.block_app.framework.block.Block
Calls consumer for each Piece: - in no particular order - potentially calling multiple times on same Piece - even if Piece might never be returned in the iterator - it will be called at least once for every piece that is going to be returned by iterator Can be used for static analysis/introspection of the block, without actually executing them.
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.EmptyBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.FilteringBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
forAllVertices(String, Consumer<Vertex<I, V, E>>) - Static method in class org.apache.giraph.block_app.library.Pieces
For each vertex execute given process function.
forAllVerticesOnReceive(String, Consumer<Vertex<I, V, E>>) - Static method in class org.apache.giraph.block_app.library.Pieces
For each vertex execute given process function.
FORCE_CHECKPOINT_USER_FLAG - Static variable in class org.apache.giraph.bsp.BspService
User sets this flag to checkpoint and stop the job
forEachBoolean(BooleanConsumer) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachBoolean(BooleanConsumer) - Method in interface org.apache.giraph.types.ops.collections.WBooleanCollection
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachByte(ByteConsumer) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachByte(ByteConsumer) - Method in interface org.apache.giraph.types.ops.collections.WByteCollection
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachDouble(DoubleConsumer) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachDouble(DoubleConsumer) - Method in interface org.apache.giraph.types.ops.collections.WDoubleCollection
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachFloat(FloatConsumer) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachFloat(FloatConsumer) - Method in interface org.apache.giraph.types.ops.collections.WFloatCollection
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachInt(IntConsumer) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachInt(IntConsumer) - Method in interface org.apache.giraph.types.ops.collections.WIntCollection
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachIntByte(IntByteConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachIntDouble(IntDoubleConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachIntFloat(IntFloatConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachIntInt(IntIntConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachIntLong(IntLongConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachLong(LongConsumer) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachLong(LongConsumer) - Method in interface org.apache.giraph.types.ops.collections.WLongCollection
Traverse all elements of the array list, calling given function on each element, or until predicate returns false.
forEachLongByte(LongByteConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachLongDouble(LongDoubleConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachLongFloat(LongFloatConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachLongInt(LongIntConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachLongLong(LongLongConsumer) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Traverse all elements of the heap, calling given function on each element.
forEachWhileBoolean(BooleanPredicate) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Traverse all elements of the array list, calling given function on each element.
forEachWhileBoolean(BooleanPredicate) - Method in interface org.apache.giraph.types.ops.collections.WBooleanCollection
Traverse all elements of the array list, calling given function on each element.
forEachWhileByte(BytePredicate) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
Traverse all elements of the array list, calling given function on each element.
forEachWhileByte(BytePredicate) - Method in interface org.apache.giraph.types.ops.collections.WByteCollection
Traverse all elements of the array list, calling given function on each element.
forEachWhileDouble(DoublePredicate) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Traverse all elements of the array list, calling given function on each element.
forEachWhileDouble(DoublePredicate) - Method in interface org.apache.giraph.types.ops.collections.WDoubleCollection
Traverse all elements of the array list, calling given function on each element.
forEachWhileFloat(FloatPredicate) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Traverse all elements of the array list, calling given function on each element.
forEachWhileFloat(FloatPredicate) - Method in interface org.apache.giraph.types.ops.collections.WFloatCollection
Traverse all elements of the array list, calling given function on each element.
forEachWhileInt(IntPredicate) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
Traverse all elements of the array list, calling given function on each element.
forEachWhileInt(IntPredicate) - Method in interface org.apache.giraph.types.ops.collections.WIntCollection
Traverse all elements of the array list, calling given function on each element.
forEachWhileIntByte(IntBytePredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileIntDouble(IntDoublePredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileIntFloat(IntFloatPredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileIntInt(IntIntPredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileIntLong(IntLongPredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileLong(LongPredicate) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
Traverse all elements of the array list, calling given function on each element.
forEachWhileLong(LongPredicate) - Method in interface org.apache.giraph.types.ops.collections.WLongCollection
Traverse all elements of the array list, calling given function on each element.
forEachWhileLongByte(LongBytePredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileLongDouble(LongDoublePredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileLongFloat(LongFloatPredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileLongInt(LongIntPredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
forEachWhileLongLong(LongLongPredicate) - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Traverse all elements of the heap, calling given function on each element, or until predicate returns false.
FRACTION_OF_REQUESTS_TO_CLOSE_BEFORE_PROCEEDING - Static variable in class org.apache.giraph.comm.flow_control.StaticFlowControl
After pausing a thread due to too large number of open requests, which fraction of these requests need to be closed before we continue
FREE_MEMORY_FRACTION_FOR_GC - Static variable in class org.apache.giraph.worker.MemoryObserver
For which fraction of free memory will we issue manual gc calls
freeMemoryFraction() - Static method in class org.apache.giraph.utils.MemoryUtils
Get fraction of memory that's free
freeMemoryFraction - Variable in class org.apache.giraph.worker.WorkerProgressStats
Fraction of memory that's free
freeMemoryMB() - Static method in class org.apache.giraph.utils.MemoryUtils
Get free memory in megabytes
freeMemoryMB - Variable in class org.apache.giraph.worker.WorkerProgressStats
Free memory
freePlusUnallocatedMemoryMB() - Static method in class org.apache.giraph.utils.MemoryUtils
Get free plus unallocated memory in megabytes
FREQUENCY - Static variable in class org.apache.giraph.aggregators.TextAggregatorWriter
The frequency of writing: - NEVER: never write, files aren't created at all - AT_THE_END: aggregators are written only when the computation is over - int: i.e.
fromByteArray(byte[], T) - Static method in class org.apache.giraph.utils.WritableUtils
Deserialize from given byte array into given writable, using new instance of ExtendedByteArrayDataInput.
fromByteArrayUnsafe(byte[], T, UnsafeReusableByteArrayInput) - Static method in class org.apache.giraph.utils.WritableUtils
Deserialize from given byte array into given writable, using given reusable UnsafeReusableByteArrayInput.
fromName(String) - Static method in class org.apache.giraph.zk.ComputationDoneName
Create this object from a name (if possible).
Function<F,T> - Interface in org.apache.giraph.function
Function: (F) -> T
FunctionWithVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,F,T> - Interface in org.apache.giraph.function.vertex
Function: (vertex, F) -> T Determines an output value based on a vertex and an input value.
funnel(LongWritable, PrimitiveSink) - Method in enum org.apache.giraph.utils.hashing.LongWritableFunnel
 

G

GC_MINIMUM_RECLAIM_FRACTION - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
Used to detect a high memory pressure situation
GC_OBSERVER_CLASSES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Classes for GC Observer - optional
gcCompleted(GarbageCollectionNotificationInfo) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Notify the out-of-core engine that a GC has just been completed
gcCompleted(GarbageCollectionNotificationInfo) - Method in class org.apache.giraph.ooc.policy.FixedPartitionsOracle
 
gcCompleted(GarbageCollectionNotificationInfo) - Method in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
When a new GC has completed, we can get an accurate measurement of the memory usage.
gcCompleted(GarbageCollectionNotificationInfo) - Method in interface org.apache.giraph.ooc.policy.OutOfCoreOracle
Notification of GC completion.
gcCompleted(GarbageCollectionNotificationInfo) - Method in class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
 
gcCompleted(GarbageCollectionNotificationInfo) - Method in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
 
GcObserver - Interface in org.apache.giraph.utils
Observer for when GCs occur
gcOccurred(GarbageCollectionNotificationInfo) - Method in interface org.apache.giraph.utils.GcObserver
Called to notify that GC occurred
gcOccurred(GcInfo) - Method in class org.apache.giraph.utils.GcTracker
Called to notify gc tracker that gc occurred
gcTimeSpentSince(long) - Method in class org.apache.giraph.utils.GcTracker
Check how much time was spent doing gc since some timestamp
GcTracker - Class in org.apache.giraph.utils
Tracks last k GC pauses and is able to tell how much time was spent doing GC since some point in time.
GcTracker() - Constructor for class org.apache.giraph.utils.GcTracker
Constructor with default number of last gcs to keep
GcTracker(Configuration) - Constructor for class org.apache.giraph.utils.GcTracker
Constructor with configuration
generateChangedPartitionOwners(Collection<PartitionStats>, Collection<WorkerInfo>, int, long) - Method in interface org.apache.giraph.partition.MasterGraphPartitioner
After the worker stats have been merged to a single list, the master can use this information to send commands to the workers for any Partition changes.
generateChangedPartitionOwners(Collection<PartitionStats>, Collection<WorkerInfo>, int, long) - Method in class org.apache.giraph.partition.MasterGraphPartitionerImpl
 
GeneratedEdgeReader<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.examples
Used by GeneratedEdgeInputFormat to read some generated data
GeneratedEdgeReader() - Constructor for class org.apache.giraph.examples.GeneratedEdgeReader
Default constructor for reflection.
generateDestVertex(int, Random) - Method in class org.apache.giraph.io.formats.PseudoRandomIntNullLocalEdgesHelper
Generate a destination vertex id for the given source vertex, using the desired configuration for edge locality and the provided pseudo-random generator.
generateDestVertex(long, Random) - Method in class org.apache.giraph.io.formats.PseudoRandomLocalEdgesHelper
Generate a destination vertex id for the given source vertex, using the desired configuration for edge locality and the provided pseudo-random generator.
GeneratedVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
This VertexInputFormat is meant for testing/debugging.
GeneratedVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.GeneratedVertexInputFormat
 
GeneratedVertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.examples
Used by GeneratedVertexInputFormat to read some generated data
GeneratedVertexReader() - Constructor for class org.apache.giraph.examples.GeneratedVertexReader
Default constructor for reflection.
generateStripedBlock(int, Function<Predicate<LongWritable>, Block>) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Generate striped block, with given number of stripes, using given blockGenerator to generate block for each stripe.
generateStripedBlock(int, Function<Predicate<I>, Block>, Int2ObjFunction<Int2ObjFunction<Predicate<I>>>) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Generate striped block, with given number of stripes, using given blockGenerator to generate block for each stripe, and using striping based on given stripeSupplier.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
Get a particular entry of the vector.
get(int, int) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrix
Get a specific entry of the matrix.
get(int) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Get a particular entry of the vector.
get(int) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ArrayHandle
Get value at index.
get(K) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.MapHandle
Get value for key.
get(int) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
get(Configuration) - Method in class org.apache.giraph.conf.BooleanConfOption
Lookup value in Configuration
get(Configuration) - Method in class org.apache.giraph.conf.ClassConfOption
Lookup value
get(Configuration) - Method in class org.apache.giraph.conf.EnumConfOption
Lookup value
get(Configuration) - Method in class org.apache.giraph.conf.FloatConfOption
Lookup value
get(Configuration) - Method in class org.apache.giraph.conf.IntConfOption
Lookup value
get(Configuration, Class<T>) - Method in class org.apache.giraph.conf.JsonStringConfOption
Get JSON value
get(Configuration, TypeReference<T>) - Method in class org.apache.giraph.conf.JsonStringConfOption
Get JSON value
get(Configuration) - Method in class org.apache.giraph.conf.LongConfOption
Lookup value
get(GraphType) - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
Get data for given GraphType
get(GraphType) - Method in class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
Get option for given GraphType
get(GraphType) - Method in class org.apache.giraph.conf.PerGraphTypeEnum
Get data for given GraphType
get(GraphType) - Method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
Get option for given GraphType
get(Configuration) - Method in class org.apache.giraph.conf.StrConfOption
Lookup value
get() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.EdgeValue
Get edge value
get() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.MessageValue
Get message value
get() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.VertexValue
Get vertex value
get() - Method in class org.apache.giraph.examples.scc.SccVertexValue
Returns the vertex value.
get() - Method in class org.apache.giraph.function.ObjectHolder
 
get() - Method in class org.apache.giraph.function.ObjectTransfer
 
get() - Method in interface org.apache.giraph.function.primitive.IntSupplier
Retrieves an int value.
get() - Method in interface org.apache.giraph.function.Supplier
Retrieves an instance of the appropriate type.
get(Vertex<I, V, E>) - Method in interface org.apache.giraph.function.vertex.SupplierFromVertex
Retrieves an instance of the appropriate type, given a vertex.
get(ImmutableClassesGiraphConfiguration) - Method in enum org.apache.giraph.graph.GraphType
Get class set by user for this option
get(Configuration) - Method in enum org.apache.giraph.graph.GraphType
Get class set by user for this option
get() - Static method in class org.apache.giraph.master.MasterProgress
Get singleton instance of MasterProgress.
get(String) - Method in class org.apache.giraph.metrics.AggregatedMetrics
Get AggregatedMetric with given name.
get() - Static method in class org.apache.giraph.metrics.GiraphMetrics
Get singleton instance of GiraphMetrics.
get() - Static method in class org.apache.giraph.metrics.MetricsRegistryDebugger
Get singleton static instance of this class.
get() - Static method in class org.apache.giraph.time.SystemTime
Get an instance (shared) of this object
get(Time, TimeUnit) - Static method in class org.apache.giraph.time.Times
Convenience method to measure time in a given TimeUnit.
get(IntWritable) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
get(LongWritable) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
get(K) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
get(K) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Get value for a given key
get() - Method in class org.apache.giraph.utils.ArrayWritable
Ger array
get() - Static method in class org.apache.giraph.utils.EmptyIterable
Get the singleton empty iterable
get() - Static method in class org.apache.giraph.utils.GiraphDepVersions
Get singleton instance
get() - Static method in class org.apache.giraph.worker.WorkerProgress
Get singleton instance of WorkerProgress.
get() - Method in interface org.apache.giraph.writable.kryo.Boxed
Gets the boxed value.
get() - Method in class org.apache.giraph.writable.kryo.KryoSimpleWrapper
Unwrap the object value
get() - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Unwrap the object value
get() - Method in class org.apache.giraph.writable.kryo.TransientRandom
Get instance of Random
getAckSignalFlag(int) - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Get the response flag from a response
getAckSignalFlag(int) - Method in interface org.apache.giraph.comm.flow_control.FlowControl
Decode the acknowledgement signal from the response after an open request is completed
getAckSignalFlag(int) - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
getAckSignalFlag(int) - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
getAddedEdgeList() - Method in interface org.apache.giraph.graph.VertexChanges
Get the added edges for this particular vertex index from the previous superstep
getAddedEdgeList() - Method in class org.apache.giraph.graph.VertexMutations
 
getAddedVertexList() - Method in interface org.apache.giraph.graph.VertexChanges
Get the added vertices for this particular vertex index from the previous superstep.
getAddedVertexList() - Method in class org.apache.giraph.graph.VertexMutations
 
getAggregatedValue() - Method in interface org.apache.giraph.aggregators.Aggregator
Return current aggregated value.
getAggregatedValue(String) - Method in interface org.apache.giraph.aggregators.AggregatorUsage
Get value of an aggregator.
getAggregatedValue() - Method in class org.apache.giraph.aggregators.BasicAggregator
 
getAggregatedValue(String) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getAggregatedValue(String) - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
 
getAggregatedValue(String) - Method in class org.apache.giraph.master.MasterCompute
 
getAggregatedValue(String) - Method in class org.apache.giraph.worker.WorkerAggregatorDelegator
 
getAggregateOOCBytesLoaded() - Method in class org.apache.giraph.counters.GiraphStats
Get OOCBytesLoaded counter
getAggregateOOCBytesStored() - Method in class org.apache.giraph.counters.GiraphStats
Get OOCBytesStored counter
getAggregateSentMessageBytes() - Method in class org.apache.giraph.counters.GiraphStats
Get AggregateSentMessageBytes counter
getAggregateSentMessages() - Method in class org.apache.giraph.counters.GiraphStats
Get AggregateSentMessages counter
getAggregation() - Method in class org.apache.giraph.counters.CustomCounter
 
getAggregatorClass() - Method in class org.apache.giraph.master.AggregatorReduceOperation
 
getAggregatorHandler() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get worker aggregator handler
getAggregatorHandler() - Method in class org.apache.giraph.master.MasterGlobalCommHandler
 
getAggregatorHandler() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getAggregatorTranslationHandler() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Handler for aggregators to reduce/broadcast translation
getAggregatorTranslationHandler() - Method in class org.apache.giraph.master.BspServiceMaster
 
getAggregatorWriterClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get AggregatorWriter used
getAggregatorWriterClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed AggregatorWriter.
getAll() - Method in class org.apache.giraph.metrics.AggregatedMetrics
Get map of all aggregated metrics.
getAll() - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Get map of all metrics.
getAllAggregatorData() - Method in class org.apache.giraph.comm.ServerData
Get holder for aggregators from previous superstep
getAllEdgeValues(I) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
getAllEdgeValues(I) - Method in interface org.apache.giraph.edge.MultiRandomAccessOutEdges
Return an iterable over the edge values for a given target vertex id.
getAllEdgeValues(I) - Method in class org.apache.giraph.graph.DefaultVertex
 
getAllEdgeValues(I) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getAllEdgeValues(I) - Method in interface org.apache.giraph.graph.Vertex
Get an iterable over the values of all edges with the given target vertex id.
getAllPartitionStats(int, Progressable) - Method in class org.apache.giraph.master.MasterGlobalCommHandler
Get all partition stats.
getAndClearCurrentWorkerToWorkerMessages() - Method in class org.apache.giraph.comm.ServerData
Get and clear worker to worker messages for this superstep.
getAndClearCustomCounters() - Static method in class org.apache.giraph.counters.CustomCounters
Get the unique counter group and names This will also clear the counters list, to avoid duplicate counters from the previous superstep from being sent to the zookeeper again
getAndClearMessagesFromOtherWorkers() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getAndClearMessagesFromOtherWorkers() - Method in class org.apache.giraph.worker.WorkerContext
Get messages which other workers sent to this worker and clear them (can be called once per superstep)
getAnnotatedClasses(Class<T>, String) - Static method in class org.apache.giraph.utils.AnnotationUtils
Finds all classes within a package which are annotated with certain annotation.
getApplicationAttempt() - Method in class org.apache.giraph.bsp.BspService
Get the latest application attempt and cache it.
getApplicationAttemptChangedEvent() - Method in class org.apache.giraph.bsp.BspService
 
getArray(Configuration) - Method in class org.apache.giraph.conf.ClassConfOption
Lookup array of classes for key
getArray(Configuration) - Method in class org.apache.giraph.conf.StrConfOption
Get array of values for key
getAuthenticated() - Method in class org.apache.giraph.comm.netty.SaslNettyClient
 
getBasePath(Configuration) - Static method in class org.apache.giraph.zk.ZooKeeperManager
Return the base ZooKeeper ZNode from which all other ZNodes Giraph creates should be sited, for instance in a multi-tenant ZooKeeper, the znode reserved for Giraph
getBaseReader() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
Get wrapped EdgeReader
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark
 
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.GiraphBenchmark
Get the options to use in this benchmark.
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.PageRankBenchmark
 
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark
 
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.ReducersBenchmark
 
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.ShortestPathsBenchmark
 
getBenchmarkOptions() - Method in class org.apache.giraph.benchmark.WeightedPageRankBenchmark
 
getBiasedHistogram(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Creates a new biased Histogram and registers it under the given group and name
getBlockApiHandle() - Method in interface org.apache.giraph.block_app.framework.block.BlockWithApiHandle
 
getBlockApiHandle() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getBlockOutputHandle() - Method in interface org.apache.giraph.block_app.framework.api.BlockOutputHandleAccessor
Get global block output handle.
getBroadcast(WorkerBroadcastUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.BroadcastHandle
Get broadcasted value
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.BroadcastHandleImpl
 
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Get broadcasted value
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Get broadcasted value
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle
 
getBroadcast(String) - Method in class org.apache.giraph.worker.WorkerAggregatorDelegator
 
getBroadcast(String) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
 
getBroadcast(String) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage
 
getBroadcast(String) - Method in interface org.apache.giraph.worker.WorkerBroadcastUsage
Get value broadcasted from master
getBroadcastedSize(WorkerBroadcastUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.BroadcastArrayHandle
Number of elements that were broadcasted.
getBroadcastedSize(WorkerBroadcastUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.BroadcastMapHandle
Number of elements that were broadcasted.
getBroadcastedSize(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfBroadcasts
 
getByteArray() - Method in class org.apache.giraph.utils.ByteArrayVertexIdData
Get the underlying byte-array.
getByteArray(String, Configuration) - Static method in class org.apache.giraph.utils.ConfigurationObjectUtils
Get byte array from a conf option
getByteArray() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
getByteArray() - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Get the internal byte array (if possible), read-only
getByteArray() - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
getBytes() - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics.BytesDuration
 
getBytesLoadedFromDisk() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getBytesProcessed() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
 
getBytesProcessedPerSuperstep() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Returns bytes processed per superstep.
getBytesReceived() - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
getBytesReceived() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
getBytesReceived() - Method in interface org.apache.giraph.comm.NetworkMetrics
Returns aggregate bytes received.
getBytesReceivedPerSuperstep() - Method in class org.apache.giraph.comm.netty.InboundByteCounter
Returns bytes received per superstep.
getBytesReceivedPerSuperstep() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
getBytesReceivedPerSuperstep() - Method in interface org.apache.giraph.comm.NetworkMetrics
Returns bytes received in current superstep
getBytesSent() - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
getBytesStoredOnDisk() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getByteTarget(LongWritable) - Method in class org.apache.giraph.mapping.LongByteMappingStore
Auxiliary method to be used by getTarget
getCandidateBuffersToOffload(int) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Looks through all partitions that their data is not in the data store (is offloaded to disk), and sees if any of them has enough raw data buffer in memory.
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Get capacity of the heap
getCapacity() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Get capacity of the heap
getChannels() - Method in class org.apache.giraph.comm.netty.ChannelRotater
Get a copy of the channels
getCheckpointBasePath(long) - Method in class org.apache.giraph.bsp.BspService
Generate the base superstep directory path for a given application attempt
getCheckpointBasePath(Configuration, String) - Static method in class org.apache.giraph.utils.CheckpointingUtils
Path to the checkpoint's root (including job id)
getCheckpointFrequency() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the checkpoint frequeuncy of how many supersteps to wait before checkpointing
getCheckpointMarkPath(Configuration, String) - Static method in class org.apache.giraph.utils.CheckpointingUtils
Path to checkpoint&halt node in hdfs.
getCheckpointStatus() - Method in class org.apache.giraph.graph.FinishedSuperstepStats
What master thinks about checkpointing after this superstep.
getCheckpointStatus() - Method in class org.apache.giraph.graph.GlobalStats
 
getChildrenExt(String, boolean, boolean, boolean) - Method in class org.apache.giraph.zk.ZooKeeperExt
Get the children of the path with extensions.
getClassesIterator(String) - Static method in class org.apache.giraph.utils.AnnotationUtils
 
getClassesOfType(Configuration, String, Class<T>, Class<? extends T>...) - Static method in class org.apache.giraph.conf.ClassConfOption
Get classes from a property that all implement a given interface.
getClassId(String) - Static method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Gets ID for the given class name.
getClassName(int) - Static method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Get class name for given ID.
getCleanedUpChildrenChangedEvent() - Method in class org.apache.giraph.bsp.BspService
 
getClientId() - Method in class org.apache.giraph.comm.requests.WritableRequest
 
getClientPortAddress() - Method in class org.apache.giraph.zk.ZookeeperConfig
Get zookeeper server address
getCommandTypeStats(IOCommand.IOCommandType) - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics
Get aggregate statistics of a given command type in the command history
getCommTimer() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getComputation() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getComputation() - Method in class org.apache.giraph.master.MasterCompute
Get Computation class to be used
getComputation_name() - Method in class org.apache.giraph.jython.JythonJob
 
getComputationClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Computation class
getComputationClass() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the user's subclassed Computation
getComputationClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
getComputationClass() - Method in class org.apache.giraph.master.SuperstepClasses
 
getComputationFactoryClass() - Method in class org.apache.giraph.conf.GiraphClasses
 
getComputationFactoryClass() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the user's subclassed ComputationFactory
getComputationFactoryClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get computation factory class
getComputationName() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get name of computation being run.
getComputeAllTimer() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getComputeMs() - Method in class org.apache.giraph.partition.PartitionStats
 
getConf() - Method in class org.apache.giraph.benchmark.GiraphBenchmark
 
getConf() - Method in interface org.apache.giraph.block_app.framework.api.BlockConfApi
Return the configuration used by this object.
getConf() - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerApi
 
getConf() - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
 
getConf() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
getConf() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
getConf() - Method in class org.apache.giraph.comm.requests.WritableRequest
 
getConf() - Method in class org.apache.giraph.comm.SendDataCache
 
getConf() - Method in class org.apache.giraph.conf.DefaultImmutableClassesGiraphConfigurable
 
getConf() - Method in interface org.apache.giraph.conf.ImmutableClassesGiraphConfigurable
Return the configuration used by this object.
getConf() - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
getConf() - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
getConf() - Method in class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat
 
getConf() - Method in class org.apache.giraph.examples.LongDoubleFloatTextInputFormat
 
getConf() - Method in class org.apache.giraph.examples.LongDoubleNullTextInputFormat
 
getConf() - Method in class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat
 
getConf() - Method in class org.apache.giraph.examples.SimpleCheckpoint
 
getConf() - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext
 
getConf() - Method in class org.apache.giraph.GiraphRunner
 
getConf() - Method in class org.apache.giraph.graph.GraphTaskManager
 
getConf() - Method in class org.apache.giraph.graph.VertexMutations
 
getConf() - Method in class org.apache.giraph.job.DefaultJobObserver
 
getConf() - Method in class org.apache.giraph.master.DefaultMasterObserver
 
getConf() - Method in class org.apache.giraph.partition.BasicPartition
 
getConf() - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
getConf() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
getConf() - Method in class org.apache.giraph.utils.ArrayListWritable
 
getConf() - Method in class org.apache.giraph.utils.ByteArrayVertexIdEdges
Cast the ImmutableClassesGiraphConfiguration so it can be used to generate edge objects.
getConf() - Method in class org.apache.giraph.utils.io.BigDataOutput
 
getConf() - Method in class org.apache.giraph.utils.JMapHistoDumper
 
getConf() - Method in class org.apache.giraph.utils.LogVersions
 
getConf() - Method in class org.apache.giraph.utils.TestGraph
 
getConf() - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
getConf() - Method in class org.apache.giraph.zk.GiraphZooKeeperAdmin
 
getConf() - Method in class org.apache.giraph.zk.ZooKeeperNodeCreator
 
getConfiguration() - Method in class org.apache.giraph.bsp.BspService
 
getConfiguration() - Method in interface org.apache.giraph.bsp.CentralizedService
Get configuration
getConfiguration() - Method in class org.apache.giraph.job.GiraphJob
Get the configuration from the internal job.
getContext() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getContext() - Method in class org.apache.giraph.bsp.BspService
 
getContext() - Method in class org.apache.giraph.counters.HadoopCountersBase
Get Hadoop Context
getContext() - Method in class org.apache.giraph.graph.AbstractComputation
Get the mapper context
getContext() - Method in interface org.apache.giraph.graph.Computation
Get the mapper context
getContext() - Method in class org.apache.giraph.graph.GraphState
 
getContext() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
Get the context.
getContext() - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriter
Get the context.
getContext() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
Get the context.
getContext() - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriter
Get the context.
getContext() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
Get the context.
getContext() - Method in class org.apache.giraph.jython.JythonComputation
Get the mapper context
getContext() - Method in class org.apache.giraph.master.MasterCompute
Get the mapper context
getContext() - Method in class org.apache.giraph.worker.WorkerContext
Get the mapper context
getConvenienceConfiguratorPackages() - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Provide list of strings representing packages where configurators will be searched for, allowing that full path is not required for CONFIGURATORS option.
getCount() - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
getCount(Integer) - Method in class org.apache.giraph.comm.aggregators.CountingCache
Get number of flushes for worker with desired task id
getCounter(String, String) - Method in interface org.apache.giraph.block_app.framework.api.StatusReporter
Get specified counter handler
getCounter(Mapper.Context, String, String) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
getCounter(String) - Method in class org.apache.giraph.counters.HadoopCountersBase
Get or create counter with given name and class's group name.
getCounter(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Creates a new Counter and registers it under the given group and name.
getCounterGroupAndNames() - Static method in class org.apache.giraph.master.input.MasterInputSplitsHandler
 
getCounterGroupsAndNames() - Static method in class org.apache.giraph.comm.netty.NettyClient
 
getCounterList() - Method in class org.apache.giraph.counters.CustomCounters
Get the counter list
getCounterList() - Method in class org.apache.giraph.counters.GiraphStats
Get a map of counter names, and values To be used by the master to send to the job client
getCounterList(long) - Method in class org.apache.giraph.counters.GiraphTimers
Get a map of counter names and values for the given superstep Counters include Setup, Initialise, Shutdown, Total, and time for the given superstep
getCounterName() - Method in class org.apache.giraph.counters.CustomCounter
 
getCounters() - Method in class org.apache.giraph.counters.GiraphCountersThriftStruct
 
getCreateSourceVertex() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get option whether to create a source vertex present only in edge input
getCurrentData() - Method in class org.apache.giraph.utils.ByteStructVertexIdDataIterator
 
getCurrentData() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
getCurrentData() - Method in interface org.apache.giraph.utils.VertexIdDataIterator
Get the current data.
getCurrentDataSize() - Method in class org.apache.giraph.utils.ByteStructVertexIdDataIterator
 
getCurrentDataSize() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
getCurrentDataSize() - Method in interface org.apache.giraph.utils.VertexIdDataIterator
Get serialized size of current data
getCurrentDate() - Method in class org.apache.giraph.time.FakeTime
 
getCurrentDate() - Method in class org.apache.giraph.time.SystemTime
 
getCurrentDate() - Method in interface org.apache.giraph.time.Time
Get the current date
getCurrentEdge() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
Get the last edge returned by the mutable iterator.
getCurrentEdge() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeReader
 
getCurrentEdge() - Method in class org.apache.giraph.io.EdgeReader
Get the current edge.
getCurrentEdge() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
 
getCurrentEdge() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
 
getCurrentEdge() - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
getCurrentEdge() - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
getCurrentEdge() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
 
getCurrentEdge() - Method in class org.apache.giraph.utils.ByteStructVertexIdEdgeIterator
 
getCurrentEdge() - Method in interface org.apache.giraph.utils.VertexIdEdgeIterator
Get the current edge.
getCurrentEntry() - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
getCurrentEntry() - Method in class org.apache.giraph.io.iterables.MappingReaderWrapper
 
getCurrentEntry() - Method in class org.apache.giraph.io.MappingReader
Get the current entry.
getCurrentFirst() - Method in class org.apache.giraph.utils.PairList.Iterator
Get first element of the current pair of the iteration.
getCurrentMasterTaskPartition() - Method in class org.apache.giraph.counters.GiraphStats
Get CurrentMasterTaskPartition counter
getCurrentMessage() - Method in class org.apache.giraph.utils.ByteStructVertexIdMessageIterator
 
getCurrentMessage() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
getCurrentMessage() - Method in interface org.apache.giraph.utils.VertexIdMessageIterator
Get the current message.
getCurrentMessageSize() - Method in class org.apache.giraph.utils.ByteStructVertexIdMessageIterator
 
getCurrentMessageSize() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
getCurrentMessageSize() - Method in interface org.apache.giraph.utils.VertexIdMessageIterator
Get the serialized size of current message
getCurrentMessageStore() - Method in class org.apache.giraph.comm.ServerData
Get message store for current messages (messages which we received in previous super step and which will be consumed in current super step)
getCurrentObject() - Method in class org.apache.giraph.io.iterables.IteratorToReaderWrapper
Get the current object
getCurrentPartitionOwners() - Method in interface org.apache.giraph.partition.MasterGraphPartitioner
Get current partition owners at this time.
getCurrentPartitionOwners() - Method in class org.apache.giraph.partition.MasterGraphPartitionerImpl
 
getCurrentSecond() - Method in class org.apache.giraph.utils.PairList.Iterator
Get second element of the current pair of the iteration.
getCurrentSourceId() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeReader
 
getCurrentSourceId() - Method in class org.apache.giraph.io.EdgeReader
Get the current edge source id.
getCurrentSourceId() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
 
getCurrentSourceId() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
 
getCurrentSourceId() - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
getCurrentSourceId() - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
getCurrentSourceId() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
 
getCurrentSuperstep() - Method in class org.apache.giraph.job.CombinedWorkerProgress
Get Current superstep
getCurrentSuperstep() - Method in class org.apache.giraph.worker.WorkerProgress
 
getCurrentValue() - Method in class org.apache.giraph.reducers.Reducer
 
getCurrentVertex() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat.LongDoubleDoubleDoubleVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.LongDoubleFloatTextInputFormat.LongDoubleFloatVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.LongDoubleNullTextInputFormat.LongDoubleNullDoubleVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat.NormalizingLongDoubleDoubleDoubleVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLine
 
getCurrentVertex() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
 
getCurrentVertex() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
 
getCurrentVertex() - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
getCurrentVertex() - Method in class org.apache.giraph.io.iterables.VertexReaderWrapper
 
getCurrentVertex() - Method in class org.apache.giraph.io.VertexReader
Get the current vertex.
getCurrentVertex() - Method in class org.apache.giraph.io.VertexValueReader
 
getCurrentVertexId() - Method in class org.apache.giraph.io.BasicVertexValueReader
User-defined method to extract the vertex id.
getCurrentVertexId() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
 
getCurrentVertexId() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
 
getCurrentVertexId() - Method in class org.apache.giraph.utils.ByteStructVertexIdIterator
 
getCurrentVertexId() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
getCurrentVertexId() - Method in interface org.apache.giraph.utils.VertexIdIterator
Get the current vertex id.
getCurrentVertexId() - Method in class org.apache.giraph.utils.VertexIterator
Get the current vertex id.
getCurrentVertexValue() - Method in class org.apache.giraph.io.BasicVertexValueReader
User-defined method to extract the vertex value.
getCurrentVertexValue() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
 
getCurrentVertexValue() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
 
getCurrentWorkers() - Method in class org.apache.giraph.counters.GiraphStats
Get CurrentWorkers counter
getCurrentWorkerToWorkerMessages() - Method in class org.apache.giraph.comm.ServerData
Get worker to worker messages received in previous superstep.
getDanglingProbability() - Method in class org.apache.giraph.examples.RandomWalkComputation
Returns the cumulative probability from dangling vertices.
getData() - Method in class org.apache.giraph.comm.requests.ByteArrayRequest
Get request data
getData(int) - Method in class org.apache.giraph.comm.SendDataCache
Get the data cache for a partition id
getData(String, Watcher, Stat) - Method in class org.apache.giraph.zk.ZooKeeperExt
Return the data and the stat of the node of the given path.
getData(String, boolean, Stat) - Method in class org.apache.giraph.zk.ZooKeeperExt
Return the data and the stat of the node of the given path.
getDataAccessor() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
 
getDataDir() - Method in class org.apache.giraph.zk.ZookeeperConfig
Snapshot dir
getDataFromMasterWhenReady(MasterInfo) - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
This function will wait until all aggregator requests from master have arrived, and return that data afterwards.
getDataInput() - Method in class org.apache.giraph.comm.requests.ByteArrayRequest
Get request data in the form of DataInput
getDataInput() - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataInputWrapper
 
getDataInput() - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataInputWrapper
 
getDataLogDir() - Method in class org.apache.giraph.zk.ZookeeperConfig
Transaction dir
getDataOutput() - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataOutputWrapper
 
getDataOutput() - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataOutputWrapper
 
getDataOutput(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer
Get dataoutput from bytearrayOutputs
getDataOutput() - Method in class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer.IndexAndDataOut
 
getDataOutput() - Method in class org.apache.giraph.utils.io.BigDataInputOutput
 
getDataOutput() - Method in class org.apache.giraph.utils.io.DataInputOutput
Get DataOutput to write to
getDataOutput() - Method in class org.apache.giraph.utils.io.ExtendedDataInputOutput
 
getDataOutputs() - Method in class org.apache.giraph.utils.io.BigDataOutput
Get DataOutputs which contain written data.
getDefaultClass() - Method in class org.apache.giraph.conf.ClassConfOption
 
getDefaultValue() - Method in class org.apache.giraph.conf.BooleanConfOption
Get the default value of this option
getDefaultValue() - Method in class org.apache.giraph.conf.FloatConfOption
 
getDefaultValue() - Method in class org.apache.giraph.conf.IntConfOption
 
getDefaultValue() - Method in class org.apache.giraph.conf.LongConfOption
 
getDefaultValue() - Method in class org.apache.giraph.conf.StrConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.AbstractConfOption
Get string representation of default value
getDefaultValueStr() - Method in class org.apache.giraph.conf.BooleanConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.ClassConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.EnumConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.FloatConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.IntConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.JsonStringConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.LongConfOption
 
getDefaultValueStr() - Method in class org.apache.giraph.conf.StrConfOption
 
getDeployType() - Method in class org.apache.giraph.scripting.DeployedScript
 
getDescription() - Method in class org.apache.giraph.conf.AbstractConfOption
 
getDestinationAddress() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
 
getDestinationTaskId() - Method in class org.apache.giraph.comm.netty.handler.ClientRequestId
 
getDiff(Time, TimeUnit, long) - Static method in class org.apache.giraph.time.Times
Convenience method to get time since the beginning of an event in a given TimeUnit.
getDiskBandwidth() - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics
 
getDisplayName() - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Get counter display name.
getDouble() - Method in class org.apache.giraph.metrics.ValueGauge
Get double representation of value held.
getDuration() - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics.BytesDuration
 
getDynamicChannelBuffer() - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
Get the dynamic channel buffer
getEdge() - Method in class org.apache.giraph.io.iterables.EdgeWithSource
 
getEdge_inputs() - Method in class org.apache.giraph.jython.JythonJob
 
getEdge_value() - Method in class org.apache.giraph.jython.JythonJob
 
getEdgeCount() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
getEdgeCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getEdgeCount() - Method in class org.apache.giraph.graph.VertexEdgeCount
 
getEdgeCount() - Method in class org.apache.giraph.partition.ByteArrayPartition
 
getEdgeCount() - Method in interface org.apache.giraph.partition.Partition
Get the number of edges in this partition.
getEdgeCount() - Method in class org.apache.giraph.partition.PartitionStats
Get the edge count.
getEdgeCount() - Method in class org.apache.giraph.partition.SimplePartition
 
getEdgeInputFilter() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the edge input filter to use
getEdgeInputFilterClass() - Method in class org.apache.giraph.conf.GiraphClasses
 
getEdgeInputFilterClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the vertex input filter class
getEdgeInputFormatClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get EdgeInputFormat used
getEdgeInputFormatClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed EdgeInputFormat.
getEdgeInputFormatDescriptions(Configuration) - Static method in class org.apache.giraph.io.formats.multi.EdgeInputFormatDescription
Get descriptions of edge input formats from configuration.
getEdgeInputPaths(JobContext) - Static method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Get the list of edge input Paths.
getEdgeInputSplitsCount() - Method in class org.apache.giraph.master.MasterProgress
 
getEdgeInputSplitsLoaded() - Method in class org.apache.giraph.worker.WorkerProgress
 
getEdgeOutputFormatClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get VertexOutputFormat set
getEdgeOutputFormatClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed EdgeOutputFormat.
getEdges() - Method in class org.apache.giraph.counters.GiraphStats
Get Edges counter
getEdges(String[]) - Method in class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat.LongLongNullVertexReader
 
getEdges() - Method in class org.apache.giraph.graph.DefaultVertex
 
getEdges() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getEdges() - Method in interface org.apache.giraph.graph.Vertex
Get a read-only view of the out-edges of this vertex.
getEdges(String[]) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
 
getEdges(String[]) - Method in class org.apache.giraph.io.formats.IntIntNullTextInputFormat.IntIntNullVertexReader
 
getEdges(String[]) - Method in class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat.IntIntNullVertexReader
 
getEdges(String) - Method in class org.apache.giraph.io.formats.IntNullNullTextInputFormat.IntNullNullNullVertexReader
 
getEdges(JSONObject) - Method in class org.apache.giraph.io.formats.JsonBase64VertexInputFormat.JsonBase64VertexReader
 
getEdges(String[]) - Method in class org.apache.giraph.io.formats.LongLongNullTextInputFormat.LongLongNullVertexReader
 
getEdges(Text) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLine
Reads edges value from the current line.
getEdges(T) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
Reads edges from the preprocessed line.
getEdges(T) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
Reads edges from the preprocessed line.
getEdgesLoaded() - Method in class org.apache.giraph.worker.WorkerProgress
 
getEdgeSplits(JobContext) - Method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Generate the list of edge input splits.
getEdgeStore() - Method in class org.apache.giraph.comm.ServerData
Return the edge store for this worker.
getEdgeValue() - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
 
getEdgeValue() - Method in class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
 
getEdgeValue() - Method in class org.apache.giraph.conf.PerGraphTypeEnum
 
getEdgeValue() - Method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
 
getEdgeValue(I) - Method in class org.apache.giraph.edge.HashMapEdges
 
getEdgeValue(LongWritable) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
getEdgeValue(LongWritable) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
getEdgeValue(LongWritable) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
getEdgeValue(I) - Method in interface org.apache.giraph.edge.StrictRandomAccessOutEdges
Return the edge value for the given target vertex id (or null if there is no edge pointing to it).
getEdgeValue(I) - Method in class org.apache.giraph.graph.DefaultVertex
 
getEdgeValue(I) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getEdgeValue(I) - Method in interface org.apache.giraph.graph.Vertex
Return the value of the first edge with the given target vertex id, or null if there is no such edge.
getEdgeValue() - Method in class org.apache.giraph.io.iterables.EdgeWithSource
 
getEdgeValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete edge value class application will use.
getEdgeValueClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Edge Value class
getEdgeValueClass() - Method in class org.apache.giraph.conf.GiraphTypes
 
getEdgeValueClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed edge value class.
getEdgeValueClass(GiraphConfiguration) - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory
 
getEdgeValueFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get Factory for creating edge values
getEdgeValueFactory() - Method in class org.apache.giraph.factories.ValueFactories
 
getElapsedMsecs() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
Get the elapsed millseconds since the request started.
getElapsedNanos() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
Get the elapsed nanoseconds since the request started.
getElement(Progressable) - Method in class org.apache.giraph.utils.BlockingElementsSet
Get one element when it becomes available, reporting progress while waiting
getElements(int, Progressable) - Method in class org.apache.giraph.utils.BlockingElementsSet
Get desired number of elements when they become available, reporting progress while waiting
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
getElementTypeOps() - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
getElementTypeOps() - Method in interface org.apache.giraph.types.ops.collections.BasicSet
TypeOps for type of elements this object holds
getElementTypeOps() - Method in interface org.apache.giraph.types.ops.collections.WCollection
TypeOps for type of elements this object holds
getEnableFault() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
getEventWaitMsecs() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the number of milliseconds to wait for an event before continuing on
getExecutionStage() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getExistingGauge(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Get a Gauge that is already present in the MetricsRegistry
getFilename() - Static method in class org.apache.giraph.examples.SimpleAggregatorWriter
 
getFinalMax() - Static method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
getFinalMax() - Static method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
getFinalMin() - Static method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
getFinalMin() - Static method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
getFinalSum() - Static method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
getFinalSum() - Static method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
getFinalSum() - Static method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
getFinalSum() - Static method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
getFinalSum() - Static method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
getFinalSum() - Static method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation
 
getFinishedVertexCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getFinishedVertexCount() - Method in class org.apache.giraph.partition.PartitionStats
Get the finished vertex count.
getFinishedVertexes() - Method in class org.apache.giraph.counters.GiraphStats
Get FinishedVertexes counter
getFirst() - Method in class org.apache.giraph.utils.IntPair
Get the first element.
getFlowControl() - Method in interface org.apache.giraph.comm.MasterClient
Get the reference to the flow control policy used for sending requests
getFlowControl() - Method in class org.apache.giraph.comm.netty.NettyClient
 
getFlowControl() - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
getFlowControl() - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
getFlowControl() - Method in interface org.apache.giraph.comm.WorkerClient
 
getFlowControl() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
 
getFreeMemoryFraction() - Method in class org.apache.giraph.worker.WorkerProgress
 
getFreeMemoryMB() - Method in class org.apache.giraph.worker.WorkerProgress
 
getFs() - Method in class org.apache.giraph.bsp.BspService
Get the file system
getFsCachePath(FileSystem, ApplicationId) - Static method in class org.apache.giraph.yarn.YarnUtils
Get the base HDFS dir we will be storing our LocalResources in.
getFutureResult(Future<T>, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Wait for the result of the future to be ready, while periodically reporting progress.
getGauge(String, Gauge<T>) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Given a new Gauge, registers it under the given group and name.
getGcJavaOpts(Configuration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
getGcJavaOpts(Configuration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Get special GC Java options.
getGcJavaOpts(Configuration) - Static method in class org.apache.giraph.conf.FacebookConfiguration
Get garbage collection java opts to use
getGcObserverClasses() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get array of GcObserver classes set in configuration.
getGcTracker() - Method in class org.apache.giraph.metrics.GiraphMetrics
Get GC tracker
getGiraph_options() - Method in class org.apache.giraph.jython.JythonJob
 
getGiraphTypes() - Method in class org.apache.giraph.conf.GiraphClasses
 
getGiraphTypes() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get user types describing graph (I,V,E,M1,M2)
getGlobalCommHandler() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Get handler for global communication
getGlobalCommHandler() - Method in class org.apache.giraph.master.BspServiceMaster
 
getGlobalStats() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Loads Global stats from zookeeper.
getGlobalStats() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getGraph() - Static method in class org.apache.giraph.utils.InMemoryVertexInputFormat
 
getGraphFractionInMemory() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Since the statistics are based on estimates, we assume each partial partition is taking about half of the full partition in terms of memory footprint.
getGraphFunctions() - Method in class org.apache.giraph.graph.GraphTaskManager
Get the worker function enum.
getGraphPartitionerClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed GraphPartitionerFactory.
getGraphPartitionerFactory() - Method in class org.apache.giraph.bsp.BspService
Subclasses can use this to instantiate their respective partitioners
getGraphPartitionerFactoryClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get the GraphPartitionerFactory
getGraphPercentageInMemory() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getGraphTaskManager() - Method in class org.apache.giraph.bsp.BspService
 
getGraphTaskManager() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the GraphTaskManager that this service is using.
getGraphType() - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
Get the graph type this factory is meant for
getGraphType() - Method in class org.apache.giraph.jython.JythonOptions.JythonGraphTypeOptions
 
getGroupName() - Method in class org.apache.giraph.counters.CustomCounter
 
getGroupName() - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Get group name used for metrics.
getHadoopCounter() - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Get underlying Hadoop Counter we're wrapping.
getHaltComputation() - Method in class org.apache.giraph.graph.GlobalStats
 
getHdfsFileCreationRetries() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getHdfsFileCreationRetryWaitMs() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getHealthyHostnameIdFromPath(String) - Static method in class org.apache.giraph.bsp.BspService
Get the hostname and id from a "healthy" worker path
getHive_database() - Method in class org.apache.giraph.jython.JythonJob
 
getHive_io() - Method in class org.apache.giraph.jython.JythonJob.TypeWithHive
 
getHive_reader() - Method in class org.apache.giraph.jython.JythonJob.TypeWithHive
 
getHive_writer() - Method in class org.apache.giraph.jython.JythonJob.TypeWithHive
 
getHostname() - Method in class org.apache.giraph.bsp.BspService
 
getHostname() - Method in class org.apache.giraph.graph.TaskInfo
Get this task's hostname
getHostname() - Method in class org.apache.giraph.metrics.ValueWithHostname
 
getHostnameId() - Method in class org.apache.giraph.graph.TaskInfo
Get hostname and task id
getHostnameTaskId() - Method in class org.apache.giraph.bsp.BspService
 
getHostOrIp() - Method in class org.apache.giraph.graph.TaskInfo
Get this task's host address.
getId(String[]) - Method in class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat.LongLongNullVertexReader
 
getId() - Method in class org.apache.giraph.graph.DefaultVertex
 
getId() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getId() - Method in interface org.apache.giraph.graph.Vertex
Get the vertex id.
getId(String[]) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
 
getId(String[]) - Method in class org.apache.giraph.io.formats.IntIntNullTextInputFormat.IntIntNullVertexReader
 
getId(String[]) - Method in class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat.IntIntNullVertexReader
 
getId(IntPair) - Method in class org.apache.giraph.io.formats.IntIntTextVertexValueInputFormat.IntIntTextVertexValueReader
 
getId(String) - Method in class org.apache.giraph.io.formats.IntNullNullTextInputFormat.IntNullNullNullVertexReader
 
getId(JSONObject) - Method in class org.apache.giraph.io.formats.JsonBase64VertexInputFormat.JsonBase64VertexReader
 
getId(String[]) - Method in class org.apache.giraph.io.formats.LongLongNullTextInputFormat.LongLongNullVertexReader
 
getId(Text) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLine
Reads vertex id from the current line.
getId(T) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
Reads vertex id from the preprocessed line.
getId(T) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
Reads vertex id from the preprocessed line.
getId(Text) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
Reads vertex id from the current line.
getId(T) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
Reads vertex id from the preprocessed line.
getId() - Method in class org.apache.giraph.partition.BasicPartition
 
getId() - Method in interface org.apache.giraph.partition.Partition
Get the partition id.
getId_column() - Method in class org.apache.giraph.jython.JythonJob.VertexInput
 
getId_column() - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
getIdWithInHoldAck() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
getIdWithInHoldDone() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
getInByteCounter() - Method in class org.apache.giraph.comm.netty.NettyServer
Returns a handle on the in-bound byte counter.
getIncoming_message_value() - Method in class org.apache.giraph.jython.JythonJob
 
getIncomingMessageClasses() - Method in class org.apache.giraph.conf.GiraphClasses
 
getIncomingMessageClasses() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get incoming message classes
getIncomingMessageStore() - Method in class org.apache.giraph.comm.ServerData
Get message store for incoming messages (messages which will be consumed in the next super step)
getIncomingMessageValueClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed incoming message value class.
getIndex() - Method in class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer.IndexAndDataOut
 
getIndexAndDataOut() - Method in class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer
Return threadLocal indexAndDataOutput instance
getInetSocketAddress() - Method in class org.apache.giraph.graph.TaskInfo
Get a new instance of the InetSocketAddress for this hostname and port
getInitialBufferSize(int) - Method in class org.apache.giraph.comm.SendDataCache
Get initial buffer size of a partition.
getInitializeMs() - Method in class org.apache.giraph.counters.GiraphTimers
Get counter for initializing the process, having to wait for a minimum number of processes to be available before setup step
getInputFormat() - Method in class org.apache.giraph.worker.EdgeInputSplitsCallable
 
getInputFormat() - Method in class org.apache.giraph.worker.InputSplitsCallable
Get input format
getInputFormat() - Method in class org.apache.giraph.worker.MappingInputSplitsCallable
 
getInputFormat() - Method in class org.apache.giraph.worker.VertexInputSplitsCallable
 
getInputFormatClass() - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
 
getInputOutEdgesClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Vertex edges class used during edge-based input
getInputOutEdgesClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed OutEdges used for input
getInputSplit(byte[]) - Method in class org.apache.giraph.worker.InputSplitsCallable
Talk to ZooKeeper to convert the input split path to the actual InputSplit.
getInputSplitMaxEdges() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getInputSplitMaxVertices() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getInputSplitsAllDoneEvent() - Method in class org.apache.giraph.bsp.BspService
 
getInputSplitsHandler() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get input splits handler used during input
getInputSplitsHandler() - Method in class org.apache.giraph.master.MasterGlobalCommHandler
 
getInputSplitsHandler() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getInputSplitsWorkerDoneEvent() - Method in class org.apache.giraph.bsp.BspService
 
getInputType() - Method in class org.apache.giraph.worker.EdgeInputSplitsCallable
 
getInputType() - Method in class org.apache.giraph.worker.InputSplitsCallable
Get input type
getInputType() - Method in class org.apache.giraph.worker.MappingInputSplitsCallable
 
getInputType() - Method in class org.apache.giraph.worker.VertexInputSplitsCallable
 
getInstance() - Static method in class org.apache.giraph.counters.GiraphStats
Get singleton instance.
getInstance() - Static method in class org.apache.giraph.counters.GiraphTimers
Get singleton instance.
getInt(byte[], int) - Static method in class org.apache.giraph.utils.UnsafeArrayReads
Get an int at an arbitrary position in a byte[]
getInterfaceClass() - Method in class org.apache.giraph.conf.ClassConfOption
 
getInternalJob() - Method in class org.apache.giraph.job.GiraphJob
Be very cautious when using this method as it returns the internal job of GiraphJob.
getInternalRegistry() - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Get internal MetricsRegistry used.
getInterpreter() - Static method in class org.apache.giraph.jython.JythonUtils
Get Jython interpreter
getIntoW(int, T) - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Get element at given index in the array, storing it into 'to' argument
getIntoW(int, BooleanWritable) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
getIntoW(int, ByteWritable) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
getIntoW(int, DoubleWritable) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
getIntoW(int, FloatWritable) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
getIntoW(int, IntWritable) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
getIntoW(int, LongWritable) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
getIOScheduler() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to IO scheduler
getIOStatistics() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to IO statistics collector
getIteration() - Method in interface org.apache.giraph.block_app.library.iteration.IterationStage
 
getIteration() - Method in class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
getIterator() - Method in class org.apache.giraph.utils.PairList
Get iterator through elements of this object.
getJava_options() - Method in class org.apache.giraph.jython.JythonJob
 
getJavaClass() - Method in class org.apache.giraph.types.JavaWritablePair
 
getJobId() - Method in class org.apache.giraph.bsp.BspService
Get the job id
getJobId() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
getJobID(Job) - Static method in class org.apache.giraph.job.HadoopUtils
Get Job ID from job.
getJobName() - Method in class org.apache.giraph.job.GiraphJob
 
getJobObserver() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create job observer
getJobObserverClass() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get job observer class
getJobProgressTracker() - Method in class org.apache.giraph.bsp.BspService
 
getJobProgressTracker() - Method in interface org.apache.giraph.bsp.CentralizedService
Get JobProgressTracker to report progress to
getJobProgressTracker() - Method in class org.apache.giraph.graph.GraphTaskManager
 
getJobRetryChecker() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Create job retry checker
getJobRetryCheckerClass() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get job retry checker class
getJobState() - Method in class org.apache.giraph.bsp.BspService
Get the master commanded job state as a JSONObject.
getJythonClassNameOption() - Method in class org.apache.giraph.jython.JythonOptions.JythonGraphTypeOptions
 
getKey() - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
getKey() - Method in class org.apache.giraph.conf.AbstractConfOption
 
getKey() - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair
key getter
getKeyTypeOps() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
getKeyTypeOps() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
getKeyTypeOps() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
getKeyTypeOps() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
TypeOps for type of keys this object holds
getLanguage() - Method in class org.apache.giraph.scripting.DeployedScript
 
getLastBaseKey() - Method in class org.apache.giraph.utils.IncreasingBitSet
Get the last base key (mainly for debugging).
getLastCheckpointedSuperstep() - Method in class org.apache.giraph.bsp.BspService
Get the last saved superstep.
getLastCheckpointedSuperstep() - Method in class org.apache.giraph.counters.GiraphStats
Get LastCheckpointedSuperstep counter
getLastCheckpointedSuperstep(FileSystem, String) - Static method in class org.apache.giraph.utils.CheckpointingUtils
Get the last saved superstep.
getLastGoodCheckpoint() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Get the last known good checkpoint
getLastGoodCheckpoint() - Method in class org.apache.giraph.master.BspServiceMaster
 
getLeft() - Method in class org.apache.giraph.writable.tuple.PairWritable
 
getLength() - Method in class org.apache.giraph.bsp.BspInputSplit
 
getList(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractListStore
Get list for the current vertexId
getList(Configuration) - Method in class org.apache.giraph.conf.StrConfOption
Get list of values for key
getLoadedScripts() - Static method in class org.apache.giraph.scripting.ScriptLoader
Get list of scripts already loaded.
getLoadPartitionId(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get id of a partition to load its data to memory.
getLocalCacheFile(Configuration, String) - Static method in class org.apache.giraph.utils.DistributedCacheUtils
Get local path to file from a DistributedCache.
getLocalData() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getLocalFiles(Set<String>) - Static method in class org.apache.giraph.yarn.YarnUtils
Utility function to locate local JAR files and other resources recursively in the dirs on the local CLASSPATH.
getLocalHostname() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the local hostname on the given interface.
getLocalHostOrIp() - Method in interface org.apache.giraph.comm.MasterServer
Get server host or IP
getLocalHostOrIp() - Method in class org.apache.giraph.comm.netty.NettyMasterServer
 
getLocalHostOrIp() - Method in class org.apache.giraph.comm.netty.NettyServer
 
getLocalHostOrIp() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
getLocalHostOrIp() - Method in interface org.apache.giraph.comm.WorkerServer
Get server host name or IP
getLocalHostOrIp() - Method in class org.apache.giraph.conf.GiraphConfiguration
Return local host name by default.
getLocalLevel() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getLocalTestMode() - Method in class org.apache.giraph.conf.GiraphConfiguration
is this job run a local test?
getLocalVertexCount() - Method in class org.apache.giraph.graph.FinishedSuperstepStats
 
getLocations() - Method in class org.apache.giraph.bsp.BspInputSplit
 
getLong() - Method in class org.apache.giraph.metrics.ValueGauge
Get long representation of value held.
getLowestGraphPercentageInMemory() - Method in class org.apache.giraph.counters.GiraphStats
 
getLowestGraphPercentageInMemory() - Method in class org.apache.giraph.graph.GlobalStats
 
getLowestGraphPercentageInMemory() - Method in class org.apache.giraph.worker.WorkerProgress
 
getMapperObserverClasses() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get array of MapperObserver classes set in configuration.
getMappingCount() - Method in class org.apache.giraph.graph.VertexEdgeCount
 
getMappingInputFormatClass() - Method in class org.apache.giraph.conf.GiraphClasses
 
getMappingInputFormatClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get MappingInputFormatClass
getMappingInputFormatDescriptions(Configuration) - Static method in class org.apache.giraph.io.formats.multi.MappingInputFormatDescription
Get descriptions of mapping input formats from configuration.
getMappingStore() - Method in class org.apache.giraph.worker.LocalData
 
getMappingStoreClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get MappingStore class to be used
getMappingStoreOps() - Method in class org.apache.giraph.worker.LocalData
 
getMappingStoreOpsClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get MappingStoreOps class to be used
getMappingTarget() - Method in class org.apache.giraph.mapping.MappingEntry
 
getMappingTargetClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get mappingTarget class
getMapTasks() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the number of map tasks in this job
getMasterApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getMasterCompute() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Get MasterCompute object
getMasterCompute() - Method in class org.apache.giraph.master.BspServiceMaster
 
getMasterComputeClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get MasterCompute used
getMasterComputeClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed MasterCompute
getMasterElectionChildrenChangedEvent() - Method in class org.apache.giraph.bsp.BspService
 
getMasterInfo() - Method in interface org.apache.giraph.bsp.CentralizedService
Get master info
getMasterInfo() - Method in class org.apache.giraph.graph.AddressesAndPartitionsWritable
Get master information
getMasterInfo() - Method in class org.apache.giraph.master.BspServiceMaster
 
getMasterInfo() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getMasterObserverClasses() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get array of MasterObserver classes set in the configuration.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrixSumAggregator
Read the aggregated values of the matrix.
getMatrix(int, AggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrixSumAggregator
Read the aggregated values of the matrix.
getMaxCounterWaitMsecs() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getMaxEdgesPerTransfer() - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Getter for MAX edge count to initiate a transfer
getMaxMappers() - Method in class org.apache.giraph.conf.GiraphConfiguration
How many mappers is job asking for, taking into account whether master is running on the same mapper as worker or not
getMaxMasterSuperstepWaitMsecs() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the maximum milliseconds to wait before giving up trying to get the minimum number of workers before a superstep.
getMaxNumberOfSupersteps() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the maximum number of supersteps of this application.
getMaxPermits() - Method in class org.apache.giraph.utils.AdjustableSemaphore
 
getMaxSessionTimeout() - Method in class org.apache.giraph.zk.ZookeeperConfig
Maximum session timeout in milliseconds.
getMaxSize() - Method in class org.apache.giraph.utils.io.BigDataOutput
Get max size for single data output
getMaxSupersteps() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 
getMaxTaskAttempts() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the max task attempts
getMaxTasks(Configuration) - Static method in class org.apache.giraph.bsp.BspInputFormat
Get the correct number of mappers based on the configuration
getMaxVerticesPerTransfer() - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Getter for MAX vertex count to initiate a transfer
getMaxWorkers() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getMbytesPerSecProcessed() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
 
getMbytesPerSecReceived() - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
getMbytesPerSecSent() - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
getMemoryJavaOpts(Configuration) - Static method in class org.apache.giraph.conf.FacebookConfiguration
Get memory java opts to use
getMessage() - Method in class org.apache.giraph.comm.messages.queue.PartitionMessage
Message
getMessage_value() - Method in class org.apache.giraph.jython.JythonJob
 
getMessageBytes() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
Get the message bytes to be used for sending.
getMessageBytesCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getMessageBytesSentCount() - Method in class org.apache.giraph.partition.PartitionStats
Get the message bytes sent count.
getMessageClass() - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify type of the message this Piece sends, if it does send messages.
getMessageClass() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
getMessageClass() - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
getMessageClass() - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
getMessageClass() - Method in interface org.apache.giraph.conf.MessageClasses
Get message class
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Returns MessageClasses definition for messages being sent by this Piece.
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getMessageCombiner(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify message combiner to be used, if any.
getMessageCombiner(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
getMessageCombiner() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getMessageCombiner() - Method in class org.apache.giraph.jython.JythonJob
 
getMessageCombiner() - Method in class org.apache.giraph.master.MasterCompute
Get MessageCombiner class to be used
getMessageCombinerClass() - Method in class org.apache.giraph.master.SuperstepClasses
Get message combiner class
getMessageCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getMessageEncodeAndStoreType() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
getMessageEncodeAndStoreType() - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
getMessageEncodeAndStoreType() - Method in interface org.apache.giraph.conf.MessageClasses
Get MessageEncodeAndStoreType
getMessageFactory(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify message value factory to be used, which creates objects into which messages will be deserialized.
getMessagesAsIterable(DataInputOutput) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
getMessagesAsIterable(M) - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
getMessagesAsIterable(LongArrayList) - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
Get messages as an iterable from message storage
getMessagesAsIterable(T) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
Get messages as an iterable from message storage
getMessagesSentCount() - Method in class org.apache.giraph.partition.PartitionStats
Get the messages sent count.
getMetaPartitionManager() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to meta partition information
getMeter(MeterDesc) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Creates a new Meter and registers it under the given group and name.
getMeter(String, String, TimeUnit) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Creates a new Meter and registers it under the given group and name.
getMetrics() - Method in interface org.apache.giraph.comm.netty.ByteCounter
 
getMetrics() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
 
getMetrics() - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
getMetrics() - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
getMetricsHelper(double, double) - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Helper method used by getMetrics to create its return string
getMetricsWindow(int) - Method in interface org.apache.giraph.comm.netty.ByteCounter
Get the metrics if a given window of time has passed.
getMetricsWindow(int) - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
 
getMetricsWindow(int) - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
getMetricsWindow(int) - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
getMicroseconds() - Method in class org.apache.giraph.time.FakeTime
 
getMicroseconds() - Method in class org.apache.giraph.time.SystemTime
 
getMicroseconds() - Method in interface org.apache.giraph.time.Time
Get the current microseconds
getMicrosSince(Time, long) - Static method in class org.apache.giraph.time.Times
Convenience method to get microseconds since a previous microseconds point.
getMigrationSuperstep() - Method in interface org.apache.giraph.block_app.migration.MigrationSuperstepStage
 
getMigrationSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
getMilliseconds() - Method in class org.apache.giraph.time.FakeTime
 
getMilliseconds() - Method in class org.apache.giraph.time.SystemTime
 
getMilliseconds() - Method in interface org.apache.giraph.time.Time
Get the current milliseconds
getMillisecondsSince(Time, long) - Static method in class org.apache.giraph.time.Times
Convenience method to get milliseconds since a previous milliseconds point.
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
 
getMinKey() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
 
getMinPercentResponded() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getMinSessionTimeout() - Method in class org.apache.giraph.zk.ZookeeperConfig
Minimum session timeout in milliseconds.
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
 
getMinValue() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
 
getMinWorkers() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getMsSince(Time, long) - Static method in class org.apache.giraph.time.Times
Convenience method to get milliseconds since a previous milliseconds point.
getMutableEdges() - Method in class org.apache.giraph.graph.DefaultVertex
 
getMutableEdges() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getMutableEdges() - Method in interface org.apache.giraph.graph.Vertex
Get an iterable of out-edges that can be modified in-place.
getMyAddress() - Method in interface org.apache.giraph.comm.MasterServer
Get server address
getMyAddress() - Method in class org.apache.giraph.comm.netty.NettyMasterServer
 
getMyAddress() - Method in class org.apache.giraph.comm.netty.NettyServer
 
getMyAddress() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
getMyAddress() - Method in interface org.apache.giraph.comm.WorkerServer
Get server address
getMyDependencyWorkerSet() - Method in class org.apache.giraph.partition.PartitionExchange
Get the workers that I must wait for
getMyReducedValuesWhenReady(Set<Integer>) - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
This function will wait until all partial aggregated values from all workers are ready and aggregated, and return final aggregated values afterwards.
getMyWorkerIndex() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getMyWorkerIndex() - Method in class org.apache.giraph.graph.AbstractComputation
 
getMyWorkerIndex() - Method in class org.apache.giraph.worker.AllWorkersInfo
Get index for this worker
getMyWorkerIndex() - Method in class org.apache.giraph.worker.WorkerContext
Get index for this worker
getMyWorkerIndex() - Method in interface org.apache.giraph.worker.WorkerIndexUsage
Get index for this worker
getName() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.BroadcastHandleImpl
 
getName() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
getName() - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Get counter name.
getName() - Method in class org.apache.giraph.jython.JythonJob
 
getName() - Method in enum org.apache.giraph.metrics.MeterDesc
Get name of meter
getName() - Method in enum org.apache.giraph.ooc.persistence.DataIndex.TypeIndexEntry
 
getName() - Method in class org.apache.giraph.zk.ComputationDoneName
 
getNanoseconds() - Method in class org.apache.giraph.time.FakeTime
 
getNanoseconds() - Method in class org.apache.giraph.time.SystemTime
 
getNanoseconds() - Method in interface org.apache.giraph.time.Time
Get the current nanoseconds
getNanosecondsSince(Time, long) - Static method in class org.apache.giraph.time.Times
Convenience method to get nanoseconds since a previous nanoseconds point.
getNanosSince(Time, long) - Static method in class org.apache.giraph.time.Times
Convenience method to get nanoseconds since a previous nanoseconds point.
getNeedsWrapperOption() - Method in class org.apache.giraph.jython.JythonOptions.JythonGraphTypeOptions
 
getNettyAllocator() - Method in class org.apache.giraph.conf.GiraphConfiguration
Used by netty client and server to create ByteBufAllocator
getNettyCompressionDecoder() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get decoder for message decompression in netty
getNettyCompressionEncoder() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get encoder for message compression in netty
getNettyServerExecutionConcurrency() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the netty server execution concurrency.
getNettyServerExecutionThreads() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getNettyServerThreads() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getNettyServerUseExecutionHandler() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getNetworkMetrics() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
 
getNewEdges() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
Get the new OutEdges data structure.
getNextIOActions() - Method in class org.apache.giraph.ooc.policy.FixedPartitionsOracle
 
getNextIOActions() - Method in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
 
getNextIOActions() - Method in interface org.apache.giraph.ooc.policy.OutOfCoreOracle
Get the next set of viable IO actions to help bring memory to a more desired state.
getNextIOActions() - Method in class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
 
getNextIOActions() - Method in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
 
getNextIOCommand(int) - Method in class org.apache.giraph.ooc.OutOfCoreIOScheduler
Generate and return the next appropriate IO command for a given thread
getNextPartition() - Method in interface org.apache.giraph.comm.messages.PartitionSplitInfo
getNextPartition() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
getNextPartition() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Return the id of an unprocessed partition in memory.
getNextPartition() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get the id of the next partition to process in the current iteration over all the partitions.
getNextPartition() - Method in interface org.apache.giraph.partition.PartitionStore
Return the next partition in iteration for the current superstep.
getNextPartition() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
getNextPartition() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getNextPiece() - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getNextRequestId(Integer) - Method in class org.apache.giraph.comm.netty.handler.TaskRequestIdGenerator
Get the next request id for a given destination.
getNextRequestId(int) - Method in class org.apache.giraph.comm.netty.NettyClient
Generate and get the next request id to be used for a given worker
getNextWorkerPieces(WorkerGlobalCommUsage) - Static method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getNontrackingKryo() - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Returns a kryo which doesn't track objects, hence serialization of recursive/nested objects is not supported.
getNoOpCounter() - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
getNumAccessorThreads() - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
 
getNumAccessorThreads() - Method in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
 
getNumAccessorThreads() - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
 
getNumberOfDataOutputs() - Method in class org.apache.giraph.utils.io.BigDataOutput
Get number of DataOutputs which contain written data.
getNumberOfMessagesIn(ConcurrentMap<I, DataInputOutput>) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
getNumberOfMessagesIn(ConcurrentMap<I, M>) - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
getNumberOfMessagesIn(ConcurrentMap<I, LongArrayList>) - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
getNumberOfMessagesIn(ConcurrentMap<I, T>) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
Get number of messages in partition map
getNumberOfOpenRequests() - Method in class org.apache.giraph.comm.netty.NettyClient
 
getNumberOfUnsentRequests() - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
 
getNumberOfUnsentRequests() - Method in interface org.apache.giraph.comm.flow_control.FlowControl
 
getNumberOfUnsentRequests() - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
getNumberOfUnsentRequests() - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
getNumColumns() - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Get the number of the columns in the matrix.
getNumColumns() - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Get the number of the columns in the matrix.
getNumColumns() - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Get the number of the columns in the matrix.
getNumColumns() - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Get the number of the columns in the matrix.
getNumComputeThreads() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getNumEdges() - Method in class org.apache.giraph.graph.DefaultVertex
 
getNumEdges() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getNumEdges() - Method in interface org.apache.giraph.graph.Vertex
Get the number of outgoing edges on this vertex.
getNumInMemoryPartitions() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
 
getNumInputSplitsThreads() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getNumMessagePerEdge() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
Get the number of edges per message.
getNumOfRequests(LongWritable) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
This function retrieves the number of pending requests for the specified tag.
getNumOutputThreads() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the number of threads to use for writing output in the end of the application.
getNumPartiallyInMemoryPartitions() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
 
getNumPartitions() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
getNumPartitions() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get total number of partitions
getNumPartitions() - Method in interface org.apache.giraph.partition.PartitionStore
Return the number of stored partitions.
getNumPartitions() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Get the number of rows in the matrix.
getNumRows() - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrix
Get the number of rows in the matrix.
getNumSplits() - Method in class org.apache.giraph.bsp.BspInputSplit
Get the number of splits for this application.
getNumSupersteps() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
Get the number of supersteps.
getNumWorkers() - Method in class org.apache.giraph.comm.SendDataCache
 
getObjectKryo(String, Configuration) - Static method in class org.apache.giraph.utils.ConfigurationObjectUtils
Get object from a conf option using kryo
getOccurrence() - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics.BytesDuration
 
getOffloadMessageBufferId(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get id of a partition to offload its incoming message buffers on disk
getOffloadMessageId(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get id of a partition to offload its incoming message on disk.
getOffloadPartitionBufferId(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get id of a partition to offload its vertex/edge buffers on disk
getOffloadPartitionId(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get id of a partition to offload to disk.
getOldEdgesIterator() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
Get the iterator over the old edges data structure.
getOocEngine() - Method in class org.apache.giraph.comm.ServerData
Return the out-of-core engine for this worker.
getOocLoadBytesCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getOocStoreBytesCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getOptionFloatValue(CommandLine) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Retrieve the argument of this option as float value
getOptionFloatValue(CommandLine, float) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Retrieve the argument of this option as float value, or default value if option is not set
getOptionIntValue(CommandLine) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Retrieve the argument of this option as integer value
getOptionIntValue(CommandLine, int) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Retrieve the argument of this option as integer value, or default value if option is not set
getOptionLongValue(CommandLine) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Retrieve the argument of this option as long value
getOptions() - Method in class org.apache.giraph.jython.factories.JythonEdgeValueFactory
 
getOptions() - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
Get the options associated with this graph type
getOptions() - Method in class org.apache.giraph.jython.factories.JythonOutgoingMessageValueFactory
 
getOptions() - Method in class org.apache.giraph.jython.factories.JythonVertexIdFactory
 
getOptions() - Method in class org.apache.giraph.jython.factories.JythonVertexValueFactory
 
getOptionValue(CommandLine) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Retrieve the argument, if any, of this option
getOracle() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to out-of-core oracle
getOrCreateList(VertexIdIterator<I>) - Method in class org.apache.giraph.comm.messages.AbstractListPerVertexStore
Get the list of pointers for a vertex Each pointer has information of how to access an encoded message for this vertex
getOrCreateList(I) - Method in class org.apache.giraph.comm.messages.AbstractListPerVertexStore
Get the list of pointers for a vertex Each pointer has information of how to access an encoded message for this vertex This method will take ownership of the vertex id from the iterator if necessary (when used in the partition map entry)
getOrCreatePartitionMap(int) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
If there is already a map of messages related to the partition id return that map, otherwise create a new one, put it in global map and return it.
getOrigEdgeCount() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
getOtherWorkerIdsSet() - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
Get set of all worker task ids except the current one
getOutEdgesClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Vertex edges class
getOutEdgesClass() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the vertex edges class
getOutEdgesClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
getOutgoing_message_value() - Method in class org.apache.giraph.jython.JythonJob
 
getOutgoingMessage() - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
 
getOutgoingMessage() - Method in class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
 
getOutgoingMessage() - Method in class org.apache.giraph.conf.PerGraphTypeEnum
 
getOutgoingMessage() - Method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
 
getOutgoingMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getOutgoingMessageClasses() - Method in class org.apache.giraph.conf.GiraphClasses
 
getOutgoingMessageClasses() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get outgoing message classes
getOutgoingMessageClasses() - Method in class org.apache.giraph.master.SuperstepClasses
 
getOutgoingMessageEncodeAndStoreType() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get outgoing message encode and store type
getOutgoingMessageValueClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed outgoing message value class.
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.bsp.BspOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.GraphvizOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.InMemoryVertexOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.SequenceFileVertexOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedVertexOutputFormat
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.io.OutputFormat
Get the output committer for this output format.
getOutputConfOptions(Configuration) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
Returns an array of output configuration options set in the input configuration.
getOutputDesc(String) - Method in interface org.apache.giraph.block_app.framework.api.BlockOutputApi
 
getOutputDesc(String) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
getOutputDesc(BlockOutputApi) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
getOutputGraph() - Static method in class org.apache.giraph.io.formats.InMemoryVertexOutputFormat
Get graph containing all the vertices
getOutputHandle() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
getOutputHandle() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
getOwner(String, List<WorkerInfo>) - Static method in class org.apache.giraph.comm.aggregators.AggregatorUtils
Get owner of aggregator with selected name from the list of workers
getOwnerAggregatorData() - Method in class org.apache.giraph.comm.ServerData
Get holder for aggregators which current worker owns
getOwnerThreadId(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Get the thread id that is responsible for a particular partition
getPackagePath(Object) - Static method in class org.apache.giraph.utils.ReflectionUtils
Get package path to the object given.
getPackagePath(Class) - Static method in class org.apache.giraph.utils.ReflectionUtils
Get package path to the class given.
getParents() - Method in class org.apache.giraph.examples.scc.SccVertexValue
Returns the list of parent vertices, i.e., vertices that are at the other end of incoming edges.
getParents() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
getPartition() - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
getPartition(LongWritable, int, int) - Method in class org.apache.giraph.mapping.DefaultEmbeddedLongByteOps
 
getPartition(LongWritable, int, int) - Method in class org.apache.giraph.mapping.DefaultLongByteOps
 
getPartition(I, int, int) - Method in interface org.apache.giraph.mapping.MappingStoreOps
Get partition id for a vertex id
getPartition(I, int, int) - Method in class org.apache.giraph.partition.GraphPartitionerFactory
Calculates in which partition current vertex belongs to, from interval [0, partitionCount).
getPartition(I, int, int) - Method in class org.apache.giraph.partition.HashPartitionerFactory
 
getPartition(I, int, int) - Method in class org.apache.giraph.partition.HashRangePartitionerFactory
 
getPartition(LongWritable, int, int) - Method in class org.apache.giraph.partition.LongMappingStorePartitionerFactory
 
getPartition(IntWritable, int, int) - Method in class org.apache.giraph.partition.SimpleIntRangePartitionerFactory
 
getPartition(IntWritable, int) - Method in class org.apache.giraph.partition.SimpleIntRangePartitionerFactory
Calculates in which partition current vertex belongs to, from interval [0, partitionCount).
getPartition(LongWritable, int, int) - Method in class org.apache.giraph.partition.SimpleLongRangePartitionerFactory
 
getPartition(LongWritable, int) - Method in class org.apache.giraph.partition.SimpleLongRangePartitionerFactory
Calculates in which partition current vertex belongs to, from interval [0, partitionCount).
getPartition_filter() - Method in class org.apache.giraph.jython.JythonJob.InputBase
 
getPartitionClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Partition
getPartitionClass() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get Partition class used
getPartitionDestinationVertices(int) - Method in interface org.apache.giraph.comm.messages.MessageStore
Gets vertex ids from selected partition which we have messages for
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
getPartitionDestinationVertices(int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
getPartitionEdgeCount(Integer) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
getPartitionEdgeCount(Integer) - Method in interface org.apache.giraph.partition.PartitionStore
Return the number of edges in a partition.
getPartitionEdgeCount(Integer) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
getPartitionEdges(int) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Get OutEdges for a given partition
getPartitionEdges(Et) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Return the OutEdges for a given partition
getPartitionEdges(Int2ObjectMap.Entry<OutEdges<IntWritable, E>>) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
getPartitionEdges(int) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
getPartitionEdges(Long2ObjectMap.Entry<OutEdges<LongWritable, E>>) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
getPartitionEdges(int) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
getPartitionEdges(int) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
getPartitionEdges(Map.Entry<I, OutEdges<I, E>>) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
getPartitionEdgesIterator(Map<K, OutEdges<I, E>>) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Get iterator for partition edges
getPartitionEdgesIterator(Map<Integer, OutEdges<IntWritable, E>>) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
getPartitionEdgesIterator(Map<Long, OutEdges<LongWritable, E>>) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
getPartitionEdgesIterator(Map<I, OutEdges<I, E>>) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
getPartitionExchangeChildrenChangedEvent() - Method in class org.apache.giraph.worker.BspServiceWorker
Get event when the state of a partition exchange has changed.
getPartitionExchangePath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the "partition exchange" directory path for a superstep
getPartitionExchangeWorkerPath(long, long, WorkerInfo) - Method in class org.apache.giraph.bsp.BspService
Based on the superstep, worker info, and attempt, get the appropriate worker path for the exchange.
getPartitionId(I) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the partition id that a vertex id would belong to.
getPartitionId(I) - Method in interface org.apache.giraph.comm.messages.PartitionSplitInfo
Get the partition id that a vertex id would belong to.
getPartitionId() - Method in class org.apache.giraph.comm.messages.queue.PartitionMessage
Partition id
getPartitionId(I) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
Get id of partition which holds vertex with selected id
getPartitionId() - Method in class org.apache.giraph.ooc.command.IOCommand
Get the id of the partition involved in the IO
getPartitionId() - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
getPartitionId() - Method in interface org.apache.giraph.partition.PartitionOwner
Get the partition id that maps to the relevant Partition object
getPartitionId() - Method in class org.apache.giraph.partition.PartitionStats
Get partition id.
getPartitionId(I) - Method in class org.apache.giraph.worker.BspServiceWorker
 
getPartitionIds() - Method in interface org.apache.giraph.comm.messages.PartitionSplitInfo
Get the ids of all the stored partitions (on current worker) as Iterable
getPartitionIds() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
getPartitionIds() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Return the list of all available partitions as an iterable
getPartitionIds() - Method in interface org.apache.giraph.partition.PartitionStore
Return the ids of all the stored partitions as an Iterable.
getPartitionIds() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
getPartitionIds() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getPartitionIndex(I, int, int) - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
Calculates in which partition current vertex belongs to, from interval [0, partitionCount).
getPartitionInRange(int, int, int) - Static method in class org.apache.giraph.partition.GraphPartitionerFactory
Utility function for calculating in which partition value from interval [0, max) should belong to.
getPartitionInRange(long, long, int) - Static method in class org.apache.giraph.partition.GraphPartitionerFactory
Utility function for calculating in which partition value from interval [0, max) should belong to.
getPartitionMap(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
Get map which holds messages for partition which vertex belongs to.
getPartitionMutations() - Method in class org.apache.giraph.comm.ServerData
Get the vertex mutations (synchronize on the values)
getPartitionOwner(I) - Method in interface org.apache.giraph.partition.WorkerGraphPartitioner
Figure out the owner of a vertex
getPartitionOwner(I) - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
 
getPartitionOwners() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get all partition owners.
getPartitionOwners() - Method in class org.apache.giraph.graph.AddressesAndPartitionsWritable
Get partition owners
getPartitionOwners() - Method in interface org.apache.giraph.partition.WorkerGraphPartitioner
Get a collection of the PartitionOwner objects.
getPartitionOwners() - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
 
getPartitionOwners() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getPartitionsComputed() - Method in class org.apache.giraph.worker.WorkerProgress
 
getPartitionsStored() - Method in class org.apache.giraph.worker.WorkerProgress
 
getPartitionsToCompute() - Method in class org.apache.giraph.worker.WorkerProgress
 
getPartitionStore() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the partition store for this worker.
getPartitionStore() - Method in class org.apache.giraph.comm.ServerData
Return the partition store for this worker.
getPartitionStore() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getPartitionsToStore() - Method in class org.apache.giraph.worker.WorkerProgress
 
getPartitionVertexCount(Integer) - Method in interface org.apache.giraph.comm.messages.PartitionSplitInfo
Return the number of vertices in a partition.
getPartitionVertexCount(Integer) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
getPartitionVertexCount(Integer) - Method in interface org.apache.giraph.partition.PartitionStore
Return the number of vertices in a partition.
getPartitionVertexCount(Integer) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
getPartitionVertexCount(Integer) - Method in class org.apache.giraph.worker.BspServiceWorker
 
getPath() - Method in class org.apache.giraph.scripting.DeployedScript
 
getPath() - Method in class org.apache.giraph.zk.ZooKeeperExt.PathStat
Get the path of the created znode if it was created.
getPhase(IntWritable) - Static method in class org.apache.giraph.examples.scc.SccPhaseMasterCompute
Helper function to convert from internal aggregated value to a Phases enumerator.
getPiece() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getPieceCount() - Method in interface org.apache.giraph.block_app.framework.block.Block
How many pieces are in this block.
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.EmptyBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.FilteringBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getPool() - Method in class org.apache.giraph.jython.JythonJob
 
getPort() - Method in class org.apache.giraph.graph.TaskInfo
Get port that the IPC server of this task is using
getPos() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
getPos() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
getPos() - Method in interface org.apache.giraph.utils.ExtendedDataInput
Get the position of what has been read
getPos() - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Get the position in the output stream
getPos() - Method in class org.apache.giraph.utils.io.BigDataInput
 
getPos() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
getPos() - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
getPos() - Method in class org.apache.giraph.utils.UnsafeReads
What position in the stream?
getPreviousCumulativeProbability() - Method in class org.apache.giraph.examples.RandomWalkComputation
Returns the cumulative probability from dangling vertices.
getPreviousWorkerInfo() - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
getPreviousWorkerInfo() - Method in interface org.apache.giraph.partition.PartitionOwner
Get the worker information that was previously responsible for the partition id.
getPrimitiveIdTypeOps(Class<T>) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Get PrimitiveIdTypeOps for given type.
getPrimitiveIdTypeOpsOrNull(Class<T>) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Get PrimitiveIdTypeOps for given type, or null if there is none.
getPrimitiveTypeOps(Class<T>) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Get PrimitiveTypeOps for given type.
getPrimitiveTypeOpsOrNull(Class<T>) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Get PrimitiveTypeOps for given type, or null if there is none.
getProcessId() - Static method in class org.apache.giraph.utils.JMap
Get the process ID of the current running process
getProgress() - Method in class org.apache.giraph.examples.GeneratedEdgeReader
 
getProgress() - Method in class org.apache.giraph.examples.GeneratedVertexReader
 
getProgress() - Method in class org.apache.giraph.io.EdgeReader
How much of the input has the EdgeReader consumed i.e.
getProgress() - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader
 
getProgress() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
 
getProgress() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
 
getProgress() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
 
getProgress() - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
getProgress() - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
getProgress() - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
getProgress() - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
getProgress() - Method in interface org.apache.giraph.io.iterables.GiraphReader
How much of the input has the GiraphReader consumed i.e.
getProgress() - Method in class org.apache.giraph.io.iterables.MappingReaderWrapper
 
getProgress() - Method in class org.apache.giraph.io.iterables.VertexReaderWrapper
 
getProgress() - Method in class org.apache.giraph.io.MappingReader
How much of the input has the VertexReader consumed i.e.
getProgress() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
 
getProgress() - Method in class org.apache.giraph.io.VertexReader
How much of the input has the VertexReader consumed i.e.
getProgress() - Method in class org.apache.giraph.utils.ThreadLocalProgressCounter
Sums the progress of all counters.
getProgressString() - Method in class org.apache.giraph.job.CombinedWorkerProgress
Get string describing total job progress
getProperties() - Method in class org.apache.giraph.utils.GiraphDepVersions
 
getPyObject() - Method in class org.apache.giraph.jython.wrappers.JythonWrapperBase
 
getRaw(Configuration) - Method in class org.apache.giraph.conf.JsonStringConfOption
Get raw JSON string
getReceiver() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getRecordReader() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
Get the line record reader.
getRecordReader() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
Get the line record reader.
getRecordReader() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
Get the line record reader.
getRecordWriter(TaskAttemptContext) - Method in class org.apache.giraph.bsp.BspOutputFormat
 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.GiraphTextOutputFormat
 
getRecordWriter() - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriter
Get the line record writer.
getRecordWriter() - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriter
Get the line record writer.
getReduced(String) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getReduced(String) - Method in class org.apache.giraph.master.MasterAggregatorHandler
 
getReduced(String) - Method in class org.apache.giraph.master.MasterCompute
 
getReduced(String) - Method in class org.apache.giraph.master.MasterGlobalCommHandler
 
getReduced(String) - Method in interface org.apache.giraph.master.MasterGlobalCommUsageAggregators
Get reduced value from previous worker computation.
getReducedSize(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ReducerArrayHandle
Number of elements that were reduced.
getReducedSize(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.ReducerMapHandle
Number of elements that were reduced.
getReducedSize(BlockMasterApi) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfReducers
 
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Get reduced value
getReducedValue(MasterGlobalCommUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle
Get reduced value
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Get reduced value
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
getReduceOp() - Method in class org.apache.giraph.reducers.Reducer
 
getRemovedEdgeList() - Method in interface org.apache.giraph.graph.VertexChanges
Get the removed edges by their destination vertex index.
getRemovedEdgeList() - Method in class org.apache.giraph.graph.VertexMutations
 
getRemovedVertexCount() - Method in interface org.apache.giraph.graph.VertexChanges
Get the number of times this vertex was removed in the previous superstep.
getRemovedVertexCount() - Method in class org.apache.giraph.graph.VertexMutations
 
getRequest() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
 
getRequestClass() - Method in enum org.apache.giraph.comm.requests.RequestType
Get class of request which this type corresponds to
getRequestId() - Method in class org.apache.giraph.comm.netty.handler.ClientRequestId
 
getRequestId() - Method in class org.apache.giraph.comm.requests.WritableRequest
 
getResolverCreateVertexOnMessages() - Method in class org.apache.giraph.conf.GiraphConfiguration
Whether to create a vertex that doesn't exist when it receives messages.
getRestartedSuperstep() - Method in class org.apache.giraph.bsp.BspService
 
getRestartedSuperstep() - Method in interface org.apache.giraph.bsp.CentralizedService
Get the restarted superstep
getResultsWithNCallables(CallableFactory<R>, int, String, Progressable) - Static method in class org.apache.giraph.utils.ProgressableUtils
Create {#link numThreads} callables from {#link callableFactory}, execute them and gather results.
getRight() - Method in class org.apache.giraph.writable.tuple.PairWritable
 
getRow(int) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Get a specific row of the matrix.
getRow(int) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Get a specific row of the matrix.
getRow(int) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Get a specific row of the matrix.
getRow(int) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Get a specific row of the matrix.
getRowAggregatorName(int) - Method in class org.apache.giraph.aggregators.matrix.MatrixSumAggregator
Get the name of the aggreagator of the row with the index specified.
getRuntimeMemoryStats() - Static method in class org.apache.giraph.utils.MemoryUtils
Get stringified runtime memory stats
getSaslToken() - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
Read accessor for SASL token
getSavedCheckpointBasePath(long) - Method in class org.apache.giraph.bsp.BspService
In case when we restart another job this will give us a path to saved checkpoint.
getScriptsToLoad(Configuration) - Static method in class org.apache.giraph.scripting.ScriptLoader
Get the list of scripts to load on workers
getSecond() - Method in class org.apache.giraph.utils.IntPair
Get the second element.
getSeconds() - Method in class org.apache.giraph.time.FakeTime
 
getSeconds() - Method in class org.apache.giraph.time.SystemTime
 
getSeconds() - Method in interface org.apache.giraph.time.Time
Get the current seconds
getSecondsSince(Time, int) - Static method in class org.apache.giraph.time.Times
Convenience method to get seconds since a previous seconds point.
getSecSince(Time, int) - Static method in class org.apache.giraph.time.Times
Convenience method to get seconds since a previous seconds point.
getSender() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getSenderId() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
 
getSenderTaskId() - Method in class org.apache.giraph.comm.requests.ByteArrayWithSenderTaskIdRequest
 
getSendWorkerInitialBufferSize(int) - Method in class org.apache.giraph.comm.SendDataCache
Get the initial buffer size for the messages sent to a worker.
getSendWorkerPartitionMap() - Method in class org.apache.giraph.partition.PartitionExchange
Get a mapping of worker to list of partition ids I need to send to.
getSentMessageBytes() - Method in class org.apache.giraph.counters.GiraphStats
Get SentMessageBytes counter
getSentMessages() - Method in class org.apache.giraph.counters.GiraphStats
Get SentMessages counter
getSerializedSize() - Method in class org.apache.giraph.comm.requests.ByteArrayRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.ByteArrayWithSenderTaskIdRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SendVertexRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SendWorkerDataRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
 
getSerializedSize() - Method in class org.apache.giraph.comm.requests.WritableRequest
Get the size of the request in serialized form.
getSerializedSize() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
getSerializedSize() - Method in interface org.apache.giraph.utils.VertexIdData
Get the size of this object in serialized form.
getSerializedSplitFor(int) - Method in class org.apache.giraph.master.input.BasicInputSplitsMasterOrganizer
 
getSerializedSplitFor(int) - Method in interface org.apache.giraph.master.input.InputSplitsMasterOrganizer
 
getSerializedSplitFor(int) - Method in class org.apache.giraph.master.input.LocalityAwareInputSplitsMasterOrganizer
 
getSerializedSplitFor(int) - Method in class org.apache.giraph.master.input.MappingInputSplitsMasterOrganizer
 
getServerData() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get server data
getServerData() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
getServerData() - Method in interface org.apache.giraph.comm.WorkerServer
Get server data
getServerData() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to the server data
getServerData() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getService() - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
getServiceWorker() - Method in class org.apache.giraph.comm.SendDataCache
Get the service worker.
getServiceWorker() - Method in class org.apache.giraph.comm.ServerData
Get the reference of the service worker.
getServiceWorker() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to the service worker
getSetupMs() - Method in class org.apache.giraph.counters.GiraphTimers
Get counter for setup time in milliseconds
getShutdownMs() - Method in class org.apache.giraph.counters.GiraphTimers
Get counter for shutdown time in milliseconds.
getSingletonIndex() - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Get the singleton index.
getSingletonIndex() - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Get the singleton index.
getSingletonIndex() - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Get the singleton index.
getSingletonIndex() - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Get the singleton index.
getSingletonValue() - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Get the singleton value.
getSingletonValue() - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Get the singleton value.
getSingletonValue() - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Get the singleton value.
getSingletonValue() - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Get the singleton value.
getSize() - Method in class org.apache.giraph.comm.aggregators.CountingOutputStream
Get the number of bytes in the stream
getSize() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
getSize() - Method in class org.apache.giraph.utils.io.BigDataOutput
Get number of bytes written to this data output
getSize() - Method in class org.apache.giraph.utils.PairList
Get number of pairs in this list.
getSize() - Method in interface org.apache.giraph.utils.VertexIdData
Get the number of bytes used.
getSnapshot() - Method in class com.yammer.metrics.core.NoOpHistogram
 
getSnapshot() - Method in class com.yammer.metrics.core.NoOpTimer
 
getSource_id_column() - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
getSourceVertexId(IntPair) - Method in class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat.IntNullTextEdgeReader
 
getSourceVertexId(Text) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
Reads source vertex id from the current line.
getSourceVertexId(T) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
Reads source vertex id from the preprocessed line.
getSourceVertexId() - Method in class org.apache.giraph.io.iterables.EdgeWithSource
 
getSplitFractionDoneTimestampCounter(InputType, double, Mapper.Context) - Static method in class org.apache.giraph.master.input.MasterInputSplitsHandler
Get counter
getSplitIndex() - Method in class org.apache.giraph.bsp.BspInputSplit
Get the index of this split.
getSplitMasterWorker() - Method in class org.apache.giraph.conf.GiraphConfiguration
Getter for SPLIT_MASTER_WORKER flag.
getSplits(JobContext) - Method in class org.apache.giraph.bsp.BspInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.GeneratedVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
getSplits(JobContext, int, List<? extends GiraphInputFormat>) - Static method in class org.apache.giraph.io.formats.multi.MultiInputUtils
Get the list of input splits for all formats.
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.PseudoRandomEdgeInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.PseudoRandomIntNullVertexInputFormat
 
getSplits(int) - Static method in class org.apache.giraph.io.formats.PseudoRandomUtils
Create desired number of BspInputSplits
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.PseudoRandomVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.formats.WattsStrogatzVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.GiraphInputFormat
Get the list of input splits for the format.
getSplits(JobContext, int) - Method in class org.apache.giraph.io.internal.WrappedEdgeInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.internal.WrappedMappingInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.io.internal.WrappedVertexInputFormat
 
getSplits(JobContext, int) - Method in class org.apache.giraph.utils.InMemoryVertexInputFormat
 
getStartedMsecs() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
Get the started msecs.
getStat() - Method in class org.apache.giraph.zk.ZooKeeperExt.PathStat
Get the stat of the set znode if set
getStaticSize() - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ArrayHandle
Size of this array if defined up front, or throws UnsupportedOperationException if size is dynamic
getStaticSize() - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
getStats() - Method in class org.apache.giraph.mapping.LongByteMappingStore
 
getStats() - Method in interface org.apache.giraph.mapping.MappingStore
Get stats about the MappingStore
getStringVars(String, Mapper.Context) - Method in class org.apache.giraph.conf.GiraphConfiguration
Get string, replacing variables in the output.
getStringVars(String, String, Mapper.Context) - Method in class org.apache.giraph.conf.GiraphConfiguration
Get string, replacing variables in the output.
getSubdir() - Method in class org.apache.giraph.io.formats.GiraphTextOutputFormat
This function is used to provide an additional path level to keep different text outputs into different directories.
getSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationFullAbstractComputation
 
getSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getSuperstep() - Method in class org.apache.giraph.bsp.BspService
Get the latest superstep and cache it.
getSuperstep() - Method in interface org.apache.giraph.bsp.CentralizedService
Get the current global superstep of the application to work on.
getSuperstep() - Method in class org.apache.giraph.graph.AbstractComputation
Retrieves the current superstep.
getSuperstep() - Method in interface org.apache.giraph.graph.Computation
Retrieves the current superstep.
getSuperstep() - Method in class org.apache.giraph.graph.GraphState
 
getSuperstep() - Method in class org.apache.giraph.jython.JythonComputation
Retrieves the current superstep.
getSuperstep() - Method in class org.apache.giraph.master.MasterCompute
Retrieves the current superstep.
getSuperstep() - Method in class org.apache.giraph.metrics.SuperstepMetricsRegistry
Get superstep stored here
getSuperstep() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
 
getSuperstep() - Method in class org.apache.giraph.worker.WorkerContext
Retrieves the current superstep.
getSuperstepCounter() - Method in class org.apache.giraph.counters.GiraphStats
Get SuperstepCounter counter
getSuperstepFinishedEvent() - Method in class org.apache.giraph.bsp.BspService
 
getSuperstepFinishedPath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the "superstep finished" directory path for a superstep
getSuperstepFromPath(String) - Static method in class org.apache.giraph.bsp.BspService
Get the superstep from a ZooKeeper path
getSuperstepGCTime() - Method in class org.apache.giraph.graph.GraphTaskManager
 
getSuperstepLock() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Get a reference to superstep lock
getSuperstepMs(long, String) - Method in class org.apache.giraph.counters.GiraphTimers
Get counter for superstep time in milliseconds
getSuperstepOutput() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the superstep output class
getSuperstepOutput() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getSuperstepPath(long) - Method in class org.apache.giraph.bsp.BspService
Generate the base superstep directory path for a given application attempt
getSupersteps() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
getSuperstepStateChangedEvent() - Method in class org.apache.giraph.master.BspServiceMaster
Event that the master watches that denotes if a worker has done something that changes the state of a superstep (either a worker completed or died)
getSuperstepTimer() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getTable() - Method in class org.apache.giraph.jython.JythonJob.InputBase
 
getTable() - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
getTarget(LongWritable, ByteWritable) - Method in class org.apache.giraph.mapping.LongByteMappingStore
 
getTarget(I, B) - Method in interface org.apache.giraph.mapping.MappingStore
Get target for given vertexId
getTarget_id_column() - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
getTargetVertexId() - Method in class org.apache.giraph.edge.DefaultEdge
 
getTargetVertexId() - Method in interface org.apache.giraph.edge.Edge
Get the target vertex index of this edge
getTargetVertexId() - Method in class org.apache.giraph.edge.EdgeNoValue
 
getTargetVertexId() - Method in class org.apache.giraph.edge.MapMutableEdge
 
getTargetVertexId(IntPair) - Method in class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat.IntNullTextEdgeReader
 
getTargetVertexId(Text) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
Reads target vertex id from the current line.
getTargetVertexId(T) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
Reads target vertex id from the preprocessed line.
getTargetVertexId() - Method in class org.apache.giraph.io.iterables.EdgeWithSource
 
getTaskId() - Method in class org.apache.giraph.bsp.BspService
 
getTaskId() - Method in class org.apache.giraph.comm.netty.ChannelRotater
 
getTaskId() - Method in class org.apache.giraph.graph.TaskInfo
Get task partition id of this task
getTaskId() - Method in class org.apache.giraph.master.MasterInfo
This taskId is used internally as a unique identification of the nettyServer which runs on this task.
getTaskId() - Method in class org.apache.giraph.worker.WorkerProgress
 
getTaskPartition() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the task partition
getTeleportationProbability() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 
getTestGraph() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
getTimer(String, TimeUnit, TimeUnit) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Creates a new Timer and registers it under the given group and name.
getTimeToFirstMsg() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getTimeUnit() - Method in class org.apache.giraph.metrics.GiraphTimer
Get TimeUnit used.
getTimeUnit() - Method in class org.apache.giraph.metrics.LongAndTimeUnit
Get the TimeUnit
getTimeUnit() - Method in enum org.apache.giraph.metrics.MeterDesc
Get TimeUnit of meter
getTimeUnitAbbrev() - Method in class org.apache.giraph.metrics.GiraphTimer
Get abbreviated string of TimeUnit.
getTotalEdges() - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Getter for total edge count for the current InputSplit
getTotalEdgesFilteredCounter() - Static method in class org.apache.giraph.worker.InputSplitsCallable
Get Counter tracking edges filtered
getTotalEdgesLoadedMeter() - Static method in class org.apache.giraph.worker.InputSplitsCallable
Get Meter tracking edges loaded
getTotalMs() - Method in class org.apache.giraph.counters.GiraphTimers
Get counter for total time in milliseconds (doesn't include initialize time).
getTotalNumEdges() - Method in interface org.apache.giraph.block_app.framework.api.BlockApi
Deprecated.
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getTotalNumEdges() - Method in class org.apache.giraph.graph.AbstractComputation
Get the total (all workers) number of edges that existed in the previous superstep.
getTotalNumEdges() - Method in interface org.apache.giraph.graph.Computation
Get the total (all workers) number of edges that existed in the previous superstep.
getTotalNumEdges() - Method in class org.apache.giraph.graph.GraphState
 
getTotalNumEdges() - Method in class org.apache.giraph.jython.JythonComputation
Get the total (all workers) number of edges that existed in the previous superstep.
getTotalNumEdges() - Method in class org.apache.giraph.master.MasterCompute
Get the total (all workers) number of edges that existed in the previous superstep.
getTotalNumEdges() - Method in class org.apache.giraph.worker.WorkerContext
Get the total (all workers) number of edges that existed in the previous superstep.
getTotalNumVertices() - Method in interface org.apache.giraph.block_app.framework.api.BlockApi
Deprecated.
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getTotalNumVertices() - Method in class org.apache.giraph.graph.AbstractComputation
Get the total (all workers) number of vertices that existed in the previous superstep.
getTotalNumVertices() - Method in interface org.apache.giraph.graph.Computation
Get the total (all workers) number of vertices that existed in the previous superstep.
getTotalNumVertices() - Method in class org.apache.giraph.graph.GraphState
 
getTotalNumVertices() - Method in class org.apache.giraph.jython.JythonComputation
Get the total (all workers) number of vertices that existed in the previous superstep.
getTotalNumVertices() - Method in class org.apache.giraph.master.MasterCompute
Get the total (all workers) number of vertices that existed in the previous superstep.
getTotalNumVertices() - Method in class org.apache.giraph.worker.WorkerContext
Get the total (all workers) number of vertices that existed in the previous superstep.
getTotalVertices() - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Getter for total vetex count for the current InputSplit
getTotalVerticesFilteredCounter() - Static method in class org.apache.giraph.worker.InputSplitsCallable
Get Counter tracking vertices filtered
getTotalVerticesLoadedMeter() - Static method in class org.apache.giraph.worker.InputSplitsCallable
Get Meter tracking number of vertices loaded.
getTranslateEdge() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getType() - Method in class org.apache.giraph.comm.requests.AddressesAndPartitionsRequest
 
getType() - Method in class org.apache.giraph.comm.requests.AskForInputSplitRequest
 
getType() - Method in class org.apache.giraph.comm.requests.PartitionStatsRequest
 
getType() - Method in class org.apache.giraph.comm.requests.ReplyWithInputSplitRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SaslCompleteRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendAggregatorsToOwnerRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendAggregatorsToWorkerRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendReducedToMasterRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendResumeRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendVertexRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendWorkerAggregatorsRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendWorkerEdgesRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendWorkerMessagesRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendWorkerToWorkerMessageRequest
 
getType() - Method in class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
 
getType() - Method in class org.apache.giraph.comm.requests.WritableRequest
Get the type of the request
getType() - Method in class org.apache.giraph.conf.AbstractConfOption
Get type this option holds
getType() - Method in class org.apache.giraph.conf.BooleanConfOption
 
getType() - Method in class org.apache.giraph.conf.ClassConfOption
 
getType() - Method in class org.apache.giraph.conf.EnumConfOption
 
getType() - Method in class org.apache.giraph.conf.FloatConfOption
 
getType() - Method in class org.apache.giraph.conf.IntConfOption
 
getType() - Method in class org.apache.giraph.conf.JsonStringConfOption
 
getType() - Method in class org.apache.giraph.conf.LongConfOption
 
getType() - Method in class org.apache.giraph.conf.StrConfOption
 
getType() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
 
getType() - Method in class org.apache.giraph.jython.JythonJob.TypeHolder
 
getType() - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Get type used for new metrics created
getType() - Method in enum org.apache.giraph.metrics.MeterDesc
Get type of meter
getType() - Method in class org.apache.giraph.ooc.command.IOCommand
Get the type of the command.
getType() - Method in class org.apache.giraph.ooc.command.LoadPartitionIOCommand
 
getType() - Method in class org.apache.giraph.ooc.command.StoreDataBufferIOCommand
 
getType() - Method in class org.apache.giraph.ooc.command.StoreIncomingMessageIOCommand
 
getType() - Method in class org.apache.giraph.ooc.command.StorePartitionIOCommand
 
getType() - Method in class org.apache.giraph.ooc.command.WaitIOCommand
 
getTypeArguments(Class<T>, Class<? extends T>) - Static method in class org.apache.giraph.utils.ReflectionUtils
Get the actual type arguments a child class has used to extend a generic base class.
getTypeByName(String) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Get type by class name.
getTypeClass() - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.MapTypeOps
 
getTypeClass() - Method in enum org.apache.giraph.types.ops.TextTypeOps
 
getTypeClass() - Method in interface org.apache.giraph.types.ops.TypeOps
Class object for generic type T.
getTypeOps(Class<T>) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Get TypeOps for given type.
getTypeOpsOrNull(Class<T>) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Get TypeOps for given type, or null if there is none.
getTypesHolderClass(Configuration) - Static method in class org.apache.giraph.utils.ConfigurationUtils
Get a class which is parameterized by the graph types defined by user.
getUniformHistogram(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Creates a new uniform Histogram and registers it under the given group and name
getUnregisteredAggregatorMessage(String, boolean, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.comm.aggregators.AggregatorUtils
Get the warning message about usage of unregistered aggregator to be printed to user.
getUnregisteredBroadcastMessage(String, boolean, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.comm.aggregators.AggregatorUtils
Get the warning message when user tries to access broadcast, without previously setting it, to be printed to user.
getUnregisteredReducerMessage(String, boolean, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.comm.aggregators.AggregatorUtils
Get the warning message about usage of unregistered reducer to be printed to user.
getUnsafeByteArrayInput() - Method in class org.apache.giraph.comm.requests.ByteArrayRequest
Wraps the byte array with UnsafeByteArrayInputStream stream.
getUser() - Method in class org.apache.giraph.jython.JythonJob
 
getUserName() - Method in class org.apache.giraph.comm.netty.SaslNettyServer
 
getUseUnsafeSerialization() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Whether to use an unsafe serialization
getValue() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
getValue(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Get Vertex Value for a given id.
getValue() - Method in class org.apache.giraph.counters.CustomCounter
 
getValue() - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Get counter value
getValue() - Method in class org.apache.giraph.edge.DefaultEdge
 
getValue() - Method in interface org.apache.giraph.edge.Edge
Get the edge value of the edge
getValue() - Method in class org.apache.giraph.edge.EdgeNoValue
 
getValue() - Method in class org.apache.giraph.edge.MapMutableEdge
 
getValue(String[]) - Method in class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat.LongLongNullVertexReader
 
getValue() - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair
value getter
getValue() - Method in class org.apache.giraph.graph.ByteValueVertex
 
getValue() - Method in class org.apache.giraph.graph.DefaultVertex
 
getValue() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
getValue() - Method in interface org.apache.giraph.graph.Vertex
Get the vertex value (data stored with vertex)
getValue(String[]) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
 
getValue(String[]) - Method in class org.apache.giraph.io.formats.IntIntNullTextInputFormat.IntIntNullVertexReader
 
getValue(String[]) - Method in class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat.IntIntNullVertexReader
 
getValue(IntPair) - Method in class org.apache.giraph.io.formats.IntIntTextVertexValueInputFormat.IntIntTextVertexValueReader
 
getValue(String) - Method in class org.apache.giraph.io.formats.IntNullNullTextInputFormat.IntNullNullNullVertexReader
 
getValue(IntPair) - Method in class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat.IntNullTextEdgeReader
 
getValue(JSONObject) - Method in class org.apache.giraph.io.formats.JsonBase64VertexInputFormat.JsonBase64VertexReader
 
getValue(String[]) - Method in class org.apache.giraph.io.formats.LongLongNullTextInputFormat.LongLongNullVertexReader
 
getValue(Text) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
Reads edge value from the current line.
getValue(T) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
Reads edge value from the preprocessed line.
getValue(Text) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLine
Reads vertex value from the current line.
getValue(T) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
Reads vertex value from the preprocessed line.
getValue(T) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
Reads vertex value from the preprocessed line.
getValue(Text) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
Reads vertex value from the current line.
getValue(T) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
Reads vertex value from the preprocessed line.
getValue() - Method in class org.apache.giraph.master.AggregatorBroadcast
 
getValue() - Method in class org.apache.giraph.metrics.LongAndTimeUnit
Get the value
getValue() - Method in class org.apache.giraph.metrics.ValueWithHostname
 
getValue() - Method in class org.apache.giraph.utils.ProgressCounter
Returns counter value.
getValue_column() - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
getValue_column() - Method in class org.apache.giraph.jython.JythonJob.VertexInput
 
getValue_column() - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
getValueClass() - Method in class org.apache.giraph.utils.ArrayWritable
Get element type class
getValueLanguages() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
getValueNeedsWrappers() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
getVertex(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Get Vertex for a given id.
getVertex(I) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
getVertex(I) - Method in interface org.apache.giraph.partition.Partition
Get the vertex for this vertex index.
getVertex(I) - Method in class org.apache.giraph.partition.SimplePartition
 
getVertex(I) - Method in class org.apache.giraph.utils.TestGraph
Return a given vertex
getVertex() - Method in class org.apache.giraph.utils.VertexIterator
 
getVertex_id() - Method in class org.apache.giraph.jython.JythonJob
 
getVertex_inputs() - Method in class org.apache.giraph.jython.JythonJob
 
getVertex_output() - Method in class org.apache.giraph.jython.JythonJob
 
getVertex_value() - Method in class org.apache.giraph.jython.JythonJob
 
getVertexClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Vertex implementation class
getVertexClass() - Method in class org.apache.giraph.conf.GiraphTypes
 
getVertexCount() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Get number of vertices in the graph
getVertexCount() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
getVertexCount() - Method in class org.apache.giraph.graph.GlobalStats
 
getVertexCount() - Method in class org.apache.giraph.graph.VertexEdgeCount
 
getVertexCount() - Method in class org.apache.giraph.partition.ByteArrayPartition
 
getVertexCount() - Method in interface org.apache.giraph.partition.Partition
Get the number of vertices in this partition
getVertexCount() - Method in class org.apache.giraph.partition.PartitionStats
Get the vertex count.
getVertexCount() - Method in class org.apache.giraph.partition.SimplePartition
 
getVertexCount() - Method in class org.apache.giraph.utils.TestGraph
 
getVertexId() - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
 
getVertexId() - Method in class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
 
getVertexId() - Method in class org.apache.giraph.conf.PerGraphTypeEnum
 
getVertexId() - Method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
 
getVertexId(Et, I) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Get vertexId for a given key
getVertexId(Int2ObjectMap.Entry<OutEdges<IntWritable, E>>, IntWritable) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
getVertexId(Long2ObjectMap.Entry<OutEdges<LongWritable, E>>, LongWritable) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
getVertexId(Map.Entry<I, OutEdges<I, E>>, I) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
getVertexId() - Method in class org.apache.giraph.mapping.MappingEntry
 
getVertexIDClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete vertex id class application will use.
getVertexIdClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Vertex ID class
getVertexIdClass() - Method in class org.apache.giraph.conf.GiraphTypes
 
getVertexIdClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed vertex index class.
getVertexIDClass(GiraphConfiguration) - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory
 
getVertexIdDataIterator() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
getVertexIdDataIterator() - Method in interface org.apache.giraph.utils.VertexIdData
Get an iterator over the pairs.
getVertexIdEdgeIterator() - Method in class org.apache.giraph.utils.ByteArrayVertexIdEdges
 
getVertexIdEdgeIterator() - Method in interface org.apache.giraph.utils.VertexIdEdges
Get an iterator over the pairs.
getVertexIdFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get vertex ID factory
getVertexIdFactory() - Method in class org.apache.giraph.factories.ValueFactories
 
getVertexIdMessageBytesIterator() - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
getVertexIdMessageBytesIterator() - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
getVertexIdMessageBytesIterator() - Method in interface org.apache.giraph.utils.VertexIdMessages
Get specialized iterator that will instantiate the vertex id and message of this object.
getVertexIdMessageIterator() - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
getVertexIdMessageIterator() - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
getVertexIdMessageIterator() - Method in interface org.apache.giraph.utils.VertexIdMessages
Get specialized iterator that will instiantiate the vertex id and message of this object.
getVertexInputFilter() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the vertex input filter to use
getVertexInputFilterClass() - Method in class org.apache.giraph.conf.GiraphClasses
 
getVertexInputFilterClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the vertex input filter class
getVertexInputFormatClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get VertexInputFormat held
getVertexInputFormatClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed VertexInputFormat.
getVertexInputFormatDescriptions(Configuration) - Static method in class org.apache.giraph.io.formats.multi.VertexInputFormatDescription
Get descriptions of vertex input formats from configuration.
getVertexInputPaths(JobContext) - Static method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Get the list of vertex input Paths.
getVertexInputSplitCount() - Method in class org.apache.giraph.master.MasterProgress
 
getVertexInputSplitsLoaded() - Method in class org.apache.giraph.worker.WorkerProgress
 
getVertexMessages(I) - Method in class org.apache.giraph.comm.messages.AbstractListPerVertexStore
 
getVertexMessages(I) - Method in interface org.apache.giraph.comm.messages.MessageStore
Gets messages for a vertex.
getVertexMessages(I) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
getVertexMessages(I) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
getVertexMessages(IntWritable) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
getVertexMessages(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
getVertexMessages(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
getVertexMessages(I) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
getVertexMessages(I) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
getVertexMessages(I) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
getVertexOutEdges(VertexIdEdgeIterator<I, E>, Map<K, OutEdges<I, E>>) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Get out-edges for a given vertex
getVertexOutEdges(VertexIdEdgeIterator<IntWritable, E>, Map<Integer, OutEdges<IntWritable, E>>) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
getVertexOutEdges(VertexIdEdgeIterator<LongWritable, E>, Map<Long, OutEdges<LongWritable, E>>) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
getVertexOutEdges(VertexIdEdgeIterator<I, E>, Map<I, OutEdges<I, E>>) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
getVertexOutputFormatClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get VertexOutputFormat set
getVertexOutputFormatClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed VertexOutputFormat.
getVertexPartitionOwner(I) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Every client will need to get a partition owner from a vertex id so that they know which worker to sent the request to.
getVertexPartitionOwner(I) - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
getVertexPartitionOwner(I) - Method in interface org.apache.giraph.comm.WorkerClient
Lookup PartitionOwner for a vertex.
getVertexPartitionOwner(I) - Method in class org.apache.giraph.worker.BspServiceWorker
 
getVertexReceiver(BlockWorkerReceiveApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getVertexReceiver(BlockWorkerReceiveApi<I>, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to do vertex receive processing.
getVertexReceiver(BlockWorkerReceiveApi<I>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getVertexReceiver(BlockWorkerReceiveApi<I>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
getVertexReceiver(BlockWorkerReceiveApi<I>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
getVertexReceiver(BlockWorkerReceiveApi<I>, MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getVertexResolverClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get VertexResolver used
getVertexResolverClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed VertexResolver.
getVertexSender(BlockWorkerSendApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to do vertex send processing.
getVertexSender(BlockWorkerSendApi<I, V, E, M>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
getVertexSender(BlockWorkerSendApi<I, V, E, M>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
getVertexSender(BlockWorkerSendApi<I, V, E, M>, MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getVertexSplits(JobContext) - Method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Generate the list of vertex input splits.
getVertexValue() - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
 
getVertexValue() - Method in class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
 
getVertexValue() - Method in class org.apache.giraph.conf.PerGraphTypeEnum
 
getVertexValue() - Method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
 
getVertexValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete vertex value class application will use.
getVertexValueClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get Vertex Value class
getVertexValueClass() - Method in class org.apache.giraph.conf.GiraphTypes
 
getVertexValueClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed vertex value class.
getVertexValueClass(GiraphConfiguration) - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory
 
getVertexValueCombiner() - Method in class org.apache.giraph.partition.BasicPartition
 
getVertexValueCombinerClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get VertexValueCombiner used
getVertexValueCombinerClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed VertexValueCombiner class.
getVertexValueFactory() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get vertex value factory
getVertexValueFactory() - Method in class org.apache.giraph.factories.ValueFactories
 
getVertexValueFactoryClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed vertex value factory class
getVertexWriter() - Method in class org.apache.giraph.io.superstep_output.MultiThreadedSuperstepOutput
 
getVertexWriter() - Method in class org.apache.giraph.io.superstep_output.NoOpSuperstepOutput
 
getVertexWriter() - Method in interface org.apache.giraph.io.superstep_output.SuperstepOutput
Get the Writer.
getVertexWriter() - Method in class org.apache.giraph.io.superstep_output.SynchronizedSuperstepOutput
 
getVertices() - Method in class org.apache.giraph.counters.GiraphStats
Get Vertices counter
getVertices() - Method in class org.apache.giraph.utils.TestGraph
 
getVerticesComputed() - Method in class org.apache.giraph.job.CombinedWorkerProgress
Get vertices computed
getVerticesComputed() - Method in class org.apache.giraph.worker.WorkerProgress
 
getVerticesLoaded() - Method in class org.apache.giraph.worker.WorkerProgress
 
getVerticesStored() - Method in class org.apache.giraph.worker.WorkerProgress
 
getVerticesToCompute() - Method in class org.apache.giraph.job.CombinedWorkerProgress
Get vertices to compute
getVerticesToCompute() - Method in class org.apache.giraph.worker.WorkerProgress
 
getVerticesToStore() - Method in class org.apache.giraph.worker.WorkerProgress
 
getWaitRequestsTimer() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
getWaitTaskDoneTimeoutMs() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the maximum timeout (in milliseconds) for waiting for all tasks to complete after the job is done.
getWithDefault(Configuration, Class<? extends C>) - Method in class org.apache.giraph.conf.ClassConfOption
Lookup with user specified default value
getWithDefault(Configuration, Class<T>, T) - Method in class org.apache.giraph.conf.JsonStringConfOption
Get JSON value, or default if not present
getWithDefault(Configuration, long) - Method in class org.apache.giraph.conf.LongConfOption
Lookup value, use passed in default value if not found.
getWithDefault(Configuration, String) - Method in class org.apache.giraph.conf.StrConfOption
Lookup value with user defined defaultValue
getWorker(int, int, int) - Method in class org.apache.giraph.partition.GraphPartitionerFactory
Calculates worker that should be responsible for passed partition.
getWorker(int, int, int) - Method in class org.apache.giraph.partition.HashPartitionerFactory
 
getWorker(int, int, int) - Method in class org.apache.giraph.partition.HashRangePartitionerFactory
 
getWorker(int, int, int) - Method in class org.apache.giraph.partition.LongMappingStorePartitionerFactory
 
getWorker(int, int, int) - Method in class org.apache.giraph.partition.SimpleIntRangePartitionerFactory
 
getWorker(int, int, int) - Method in class org.apache.giraph.partition.SimpleLongRangePartitionerFactory
 
getWorkerClient() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the worker client (for instantiating WorkerClientRequestProcessor instances.
getWorkerClient() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getWorkerContext() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
getWorkerContext() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the worker context.
getWorkerContext() - Method in class org.apache.giraph.graph.AbstractComputation
Get the worker context
getWorkerContext() - Method in interface org.apache.giraph.graph.Computation
Get the worker context
getWorkerContext() - Method in class org.apache.giraph.graph.GraphTaskManager
 
getWorkerContext() - Method in class org.apache.giraph.jython.JythonComputation
Get the worker context
getWorkerContext() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getWorkerContextClass() - Method in class org.apache.giraph.conf.GiraphClasses
Get WorkerContext used
getWorkerContextClass() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Get the user's subclassed WorkerContext.
getWorkerContextReceiveApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkerContextSendApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkerContextValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete worker context value class application will use, if overridden.
getWorkerContextValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.migration.MigrationFullBlockFactory
 
getWorkerContextValueClass(GiraphConfiguration) - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory
 
getWorkerCount() - Method in interface org.apache.giraph.block_app.framework.api.BlockApi
Get number of workers
getWorkerCount() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getWorkerCount() - Method in class org.apache.giraph.graph.AbstractComputation
 
getWorkerCount() - Method in class org.apache.giraph.worker.AllWorkersInfo
Get number of workers
getWorkerCount() - Method in class org.apache.giraph.worker.WorkerContext
Get number of workers
getWorkerCount() - Method in interface org.apache.giraph.worker.WorkerIndexUsage
Get number of workers
getWorkerCountersFinishedPath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the worker "finished" directory path for a superstep, for storing the superstep-related counters
getWorkerForVertex(I) - Method in class org.apache.giraph.graph.AbstractComputation
 
getWorkerForVertex(WritableComparable) - Method in class org.apache.giraph.worker.WorkerContext
 
getWorkerForVertex(I) - Method in interface org.apache.giraph.worker.WorkerIndexUsage
Get worker index which will contain vertex with given id, if such vertex exists.
getWorkerHealthRegistrationChangedEvent() - Method in class org.apache.giraph.bsp.BspService
 
getWorkerHostnameId() - Method in class org.apache.giraph.partition.PartitionStats
 
getWorkerId(WorkerInfo) - Method in class org.apache.giraph.bsp.BspService
For every worker this method returns unique number between 0 and N, where N is the total number of workers.
getWorkerId() - Method in class org.apache.giraph.zk.ComputationDoneName
 
getWorkerIndex(int, int, int) - Method in class org.apache.giraph.partition.MasterGraphPartitionerImpl
Calculates worker that should be responsible for passed partition.
getWorkerIndex(WorkerInfo) - Method in class org.apache.giraph.worker.AllWorkersInfo
For every worker this method returns unique number between 0 and N, where N is the total number of workers.
getWorkerInfo() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the worker information
getWorkerInfo() - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
getWorkerInfo() - Method in interface org.apache.giraph.partition.PartitionOwner
Get the worker information that is currently responsible for the partition id.
getWorkerInfo() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getWorkerInfoById(int) - Method in class org.apache.giraph.bsp.BspService
Returns worker info corresponding to specified worker id.
getWorkerInfoHealthyPath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the worker information "healthy" directory path for a superstep
getWorkerInfoList() - Method in interface org.apache.giraph.bsp.CentralizedService
Get list of workers
getWorkerInfoList() - Method in class org.apache.giraph.master.BspServiceMaster
 
getWorkerInfoList() - Method in class org.apache.giraph.master.MasterCompute
Get list of workers
getWorkerInfoList() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getWorkerInfos() - Method in class org.apache.giraph.graph.AddressesAndPartitionsWritable
Get all workers
getWorkerInfoUnhealthyPath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the worker information "unhealthy" directory path for a superstep
getWorkerList() - Method in class org.apache.giraph.worker.AllWorkersInfo
List of WorkerInfos
getWorkerMetricsFinishedPath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the worker "finished" directory path for a superstep, for storing the superstep-related metrics
getWorkerObserverClasses() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get array of WorkerObserver classes set in configuration.
getWorkerObservers() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Get the observers for this Worker.
getWorkerObservers() - Method in class org.apache.giraph.worker.BspServiceWorker
 
getWorkerPartitions() - Method in class org.apache.giraph.comm.SendDataCache
 
getWorkerReceiveApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkers() - Method in class org.apache.giraph.jython.JythonJob
 
getWorkerSendApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkersInSuperstep() - Method in class org.apache.giraph.job.CombinedWorkerProgress
Get workers in superstep
getWorkerValue() - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerValueAccessor
Get global worker value.
getWorkerValue() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
getWorkerValue() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
getWorkerValue(BlockWorkerApi<I>) - Method in class org.apache.giraph.block_app.framework.piece.PieceWithWorkerContext
Get global worker value.
getWorkerWroteCheckpointEvent() - Method in class org.apache.giraph.master.BspServiceMaster
Event that the master watches that denotes when a worker wrote checkpoint
getWorkerWroteCheckpointPath(long, long) - Method in class org.apache.giraph.bsp.BspService
Generate the worker "wrote checkpoint" directory path for a superstep
getWrappedVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Add automatic handling of reducers to getVertexSender.
getWrappedVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
getWrappedVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getWritableClass() - Method in class org.apache.giraph.types.JavaWritablePair
 
getWriteFuture() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
 
getWriter(String) - Method in interface org.apache.giraph.block_app.framework.api.BlockOutputApi
 
getWriter(String) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
getWriter(BlockOutputApi) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
getWrittenCountersToZKEvent() - Method in class org.apache.giraph.bsp.BspService
 
getYarnLibJars() - Method in class org.apache.giraph.conf.GiraphConfiguration
Jars required in "Pure YARN" jobs (names only, no paths) should be listed here in full, including Giraph framework jar(s).
getYarnTaskHeapMb() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get heap size (in MB) for each task in our Giraph job run, assuming this job will run on the "pure YARN" profile.
getYourKitOutputDir(Mapper.Context) - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the output directory to write YourKit snapshots to
getZkExt() - Method in class org.apache.giraph.bsp.BspService
Get the ZooKeeperExt instance.
getZookeeperConnectionAttempts() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getZookeeperList() - Method in class org.apache.giraph.conf.GiraphConfiguration
Get the ZooKeeper list.
getZookeeperList() - Method in class org.apache.giraph.graph.GraphTaskManager
Returns a list of zookeeper servers to connect to.
getZooKeeperMaxSessionTimeout() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getZooKeeperMinSessionTimeout() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getZookeeperOpsMaxAttempts() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getZookeeperOpsRetryWaitMsecs() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
getZooKeeperServerPortString() - Method in class org.apache.giraph.zk.ZooKeeperManager
Users can get the server port string to connect to ZooKeeper
getZooKeeperSessionTimeout() - Method in class org.apache.giraph.conf.GiraphConfiguration
 
GIRAPH_TEXT_OUTPUT_FORMAT_REVERSE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Reverse values in the output
GIRAPH_TEXT_OUTPUT_FORMAT_SEPARATOR - Static variable in interface org.apache.giraph.conf.GiraphConstants
GiraphTextOuputFormat Separator
GIRAPH_TIMERS_COUNTER_GROUP_NAME - Static variable in class org.apache.giraph.master.MasterThread
Counter group name for the Giraph timers
GIRAPH_YARN_CONF_FILE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Name of the XML file that will export our Configuration to YARN workers
GIRAPH_YARN_LIBJARS - Static variable in interface org.apache.giraph.conf.GiraphConstants
conf key for comma-separated list of jars to export to YARN workers
GIRAPH_YARN_PRIORITY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Default priority level in YARN for our task containers
GIRAPH_YARN_TASK_HEAP_MB - Static variable in interface org.apache.giraph.conf.GiraphConstants
Name of Giraph property for user-configurable heap memory per worker
GIRAPH_YARN_TASK_HEAP_MB_DEFAULT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Giraph default heap size for all tasks when running on YARN profile
GiraphApplicationMaster - Class in org.apache.giraph.yarn
The YARN Application Master for Giraph is launched when the GiraphYarnClient successfully requests an execution container from the Resource Manager.
GiraphApplicationMaster(ContainerId, ApplicationAttemptId) - Constructor for class org.apache.giraph.yarn.GiraphApplicationMaster
Construct the GiraphAppMaster, populate fields using env vars set up by YARN framework in this execution container.
GiraphBenchmark - Class in org.apache.giraph.benchmark
Abstract class which benchmarks should extend.
GiraphBenchmark() - Constructor for class org.apache.giraph.benchmark.GiraphBenchmark
 
GiraphClasses<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.conf
Holder for classes used by Giraph.
GiraphClasses() - Constructor for class org.apache.giraph.conf.GiraphClasses
Empty constructor.
GiraphClasses(Configuration) - Constructor for class org.apache.giraph.conf.GiraphClasses
Constructor that reads classes from a Configuration object.
GiraphClassResolver - Class in org.apache.giraph.writable.kryo
In order to avoid writing class names to the stream, this class resolver assigns unique integers to each class name and writes/reads those integers to/from the stream.
GiraphClassResolver() - Constructor for class org.apache.giraph.writable.kryo.GiraphClassResolver
 
GiraphConfiguration - Class in org.apache.giraph.conf
Adds user methods specific to Giraph.
GiraphConfiguration() - Constructor for class org.apache.giraph.conf.GiraphConfiguration
Constructor that creates the configuration
GiraphConfiguration(Configuration) - Constructor for class org.apache.giraph.conf.GiraphConfiguration
Constructor.
GiraphConfigurationSettable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.conf
Can be instantiated with ImmutableClassesGiraphConfiguration
GiraphConfigurationValidator<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.job
GiraphConfigurationValidator attempts to verify the consistency of user-chosen InputFormat, OutputFormat, and Vertex generic type parameters as well as the general Configuration settings before the job run actually begins.
GiraphConfigurationValidator(Configuration) - Constructor for class org.apache.giraph.job.GiraphConfigurationValidator
Constructor to execute the validation test, throws unchecked exception to end job run on failure.
GiraphConstants - Interface in org.apache.giraph.conf
Constants used all over Giraph for configuration.
GiraphCountersThriftStruct - Class in org.apache.giraph.counters
Stores the information about the counter names and values
GiraphCountersThriftStruct() - Constructor for class org.apache.giraph.counters.GiraphCountersThriftStruct
Public constructor for thrift to create us.
GiraphDepVersions - Class in org.apache.giraph.utils
Versions of Giraph dependencies.
GiraphFileInputFormat<K,V> - Class in org.apache.giraph.io.formats
Provides functionality similar to FileInputFormat, but allows for different data sources (vertex and edge data).
GiraphFileInputFormat() - Constructor for class org.apache.giraph.io.formats.GiraphFileInputFormat
 
GiraphHadoopCounter - Class in org.apache.giraph.counters
Wrapper around Hadoop Counter to make it easier to use.
GiraphHadoopCounter(Counter) - Constructor for class org.apache.giraph.counters.GiraphHadoopCounter
Create wrapping a Hadoop Counter.
GiraphInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Common interface for VertexInputFormat and EdgeInputFormat.
GiraphInputFormat() - Constructor for class org.apache.giraph.io.GiraphInputFormat
 
GiraphJob - Class in org.apache.giraph.job
Generates an appropriate internal Job for using Giraph in Hadoop.
GiraphJob(String) - Constructor for class org.apache.giraph.job.GiraphJob
Constructor that will instantiate the configuration
GiraphJob(Configuration, String) - Constructor for class org.apache.giraph.job.GiraphJob
Constructor.
GiraphJob(GiraphConfiguration, String) - Constructor for class org.apache.giraph.job.GiraphJob
Constructor.
GiraphJobObserver - Interface in org.apache.giraph.job
An observer over the job launch lifecycle.
GiraphJobRetryChecker - Interface in org.apache.giraph.job
Class to decide whether a GiraphJob should be restarted after failure.
GiraphMetrics - Class in org.apache.giraph.metrics
Top level metrics class for using Yammer's metrics in Giraph.
GiraphMetricsRegistry - Class in org.apache.giraph.metrics
A holder for MetricsRegistry together with a JmxReporter.
GiraphMetricsRegistry(MetricsRegistry, JmxReporter, String, String) - Constructor for class org.apache.giraph.metrics.GiraphMetricsRegistry
Constructor
GiraphReader<T> - Interface in org.apache.giraph.io.iterables
Reader for some kind of data.
GiraphRunner - Class in org.apache.giraph
Helper class to run Giraph applications by specifying the actual class name to use (i.e.
GiraphRunner() - Constructor for class org.apache.giraph.GiraphRunner
 
GiraphStats - Class in org.apache.giraph.counters
Hadoop Counters in group "Giraph Stats".
GiraphTextInputFormat - Class in org.apache.giraph.io.formats
Provides functionality similar to TextInputFormat, but allows for different data sources (vertex and edge data).
GiraphTextInputFormat() - Constructor for class org.apache.giraph.io.formats.GiraphTextInputFormat
 
GiraphTextOutputFormat - Class in org.apache.giraph.io.formats
The text output format used for Giraph text writing.
GiraphTextOutputFormat() - Constructor for class org.apache.giraph.io.formats.GiraphTextOutputFormat
 
GiraphTimer - Class in org.apache.giraph.metrics
A timer to record duration of an event in a given TimeUnit.
GiraphTimer(GiraphMetricsRegistry, String, TimeUnit) - Constructor for class org.apache.giraph.metrics.GiraphTimer
Create new timer, add it to the registry.
GiraphTimerContext - Class in org.apache.giraph.metrics
Context to use with GiraphTimer for timing an event.
GiraphTimerContext(GiraphTimer) - Constructor for class org.apache.giraph.metrics.GiraphTimerContext
Create with GiraphTimer to callback to.
GiraphTimers - Class in org.apache.giraph.counters
Hadoop Counters in group "Giraph Timers" for timing things.
GiraphTransferRegulator - Class in org.apache.giraph.graph
Utility class to manage data transfers from a local worker reading InputSplits.
GiraphTransferRegulator(Configuration) - Constructor for class org.apache.giraph.graph.GiraphTransferRegulator
Default constructor
giraphTypes - Variable in class org.apache.giraph.conf.GiraphClasses
Generic types used to describe graph
GiraphTypes<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.conf
Holder for the generic types that describe user's graph.
GiraphTypes() - Constructor for class org.apache.giraph.conf.GiraphTypes
Empty Constructor
GiraphTypes(Class<I>, Class<V>, Class<E>, Class<? extends Writable>, Class<? extends Writable>) - Constructor for class org.apache.giraph.conf.GiraphTypes
Constructor taking values
GiraphYarnClient - Class in org.apache.giraph.yarn
The initial launcher for a YARN-based Giraph job.
GiraphYarnClient(GiraphConfiguration, String) - Constructor for class org.apache.giraph.yarn.GiraphYarnClient
Constructor.
GiraphYarnTask<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.yarn
This process will execute the BSP graph tasks alloted to this YARN execution container.
GiraphYarnTask(TaskAttemptID) - Constructor for class org.apache.giraph.yarn.GiraphYarnTask
Constructor.
GiraphZooKeeperAdmin - Class in org.apache.giraph.zk
A Utility class to be used by Giraph admins to occasionally clean up the ZK remnants of jobs that have failed or were killed before finishing.
GiraphZooKeeperAdmin() - Constructor for class org.apache.giraph.zk.GiraphZooKeeperAdmin
 
GlobalCommType - Enum in org.apache.giraph.comm
Type tag distinguishing different global communication messages.
GlobalCommValueOutputStream - Class in org.apache.giraph.comm.aggregators
Implementation of CountingOutputStream which allows writing of reduced values in the form of pair (name, type, value) There are two modes: - when class of the value is written into the stream.
GlobalCommValueOutputStream(boolean) - Constructor for class org.apache.giraph.comm.aggregators.GlobalCommValueOutputStream
Constructor
GlobalReduceHandle(ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
GlobalStats - Class in org.apache.giraph.graph
Aggregated stats by the master.
GlobalStats() - Constructor for class org.apache.giraph.graph.GlobalStats
 
GRANT - Static variable in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
Bracha-Toueg GRANT message.
GRAPH_PARTITIONER_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Graph partitioner factory class - optional
GRAPH_PERCENTAGE_IN_MEMORY - Static variable in class org.apache.giraph.ooc.OutOfCoreEngine
Name of metric for percentage of graph on disk
GRAPH_TYPE_LANGUAGES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Language user's graph types are implemented in
GRAPH_TYPES_NEEDS_WRAPPERS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Whether user graph types need wrappers
GraphFunctions - Enum in org.apache.giraph.graph
Each compute node running on the underlying cluster is marked with this enum to indicate the worker or master task(s) it must perform during job runs.
GraphMapper<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
This mapper that will execute the BSP graph tasks alloted to this worker.
GraphMapper() - Constructor for class org.apache.giraph.graph.GraphMapper
 
GraphPartitionerFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Defines the partitioning framework for this application.
GraphPartitionerFactory() - Constructor for class org.apache.giraph.partition.GraphPartitionerFactory
 
graphPartitionerFactoryClass - Variable in class org.apache.giraph.conf.GiraphClasses
Graph partitioner factory class - cached for fast access
GraphPartitionerFactoryInterface<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.partition
Defines the partitioning framework for this application.
GraphState - Class in org.apache.giraph.graph
Immutable global state of the graph.
GraphState(long, long, long, Mapper<?, ?, ?, ?>.Context) - Constructor for class org.apache.giraph.graph.GraphState
Constructor
GraphTaskManager<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
The Giraph-specific business logic for a single BSP compute node in whatever underlying type of cluster our Giraph job will run on.
GraphTaskManager(Mapper<?, ?, ?, ?>.Context) - Constructor for class org.apache.giraph.graph.GraphTaskManager
Default constructor for GiraphTaskManager.
GraphTaskManager.CheckerIfWorkerShouldFailAfterException - Interface in org.apache.giraph.graph
Interface to check if worker should fail after a thread gets an exception
GraphTaskManager.FailWithEveryExceptionOccurred - Class in org.apache.giraph.graph
Class to use by default, where each exception causes job failure
GraphType - Enum in org.apache.giraph.graph
Enumeration for a user graph type (IVEMM)
GraphvizOutputFormat - Class in org.apache.giraph.io.formats
Writes graph to a dot file (graphviz format).
GraphvizOutputFormat() - Constructor for class org.apache.giraph.io.formats.GraphvizOutputFormat
 
GROUP - Static variable in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
GROUP_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
Counter group name for the Giraph statistics
GROUP_NAME - Static variable in class org.apache.giraph.counters.GiraphTimers
Counter group name for the giraph timers
groupedMetrics() - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
groupedMetrics(MetricPredicate) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 

H

HADOOP_OUTPUT_FORMAT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Output format class for hadoop to use (for committing)
HadoopCountersBase - Class in org.apache.giraph.counters
Base class for groups of Hadoop Counters.
HadoopCountersBase(Mapper.Context, String) - Constructor for class org.apache.giraph.counters.HadoopCountersBase
Initialize with Hadoop Context and group name.
HadoopKryo - Class in org.apache.giraph.writable.kryo
Kryo instance that provides serialization through DataInput/DataOutput that org.apache.hadoop.io.Writable uses.
HadoopUtils - Class in org.apache.giraph.job
Helpers for dealing with Hadoop.
HALT_COMPUTATION_NODE - Static variable in class org.apache.giraph.bsp.BspService
Denotes that computation should be halted
HALT_INSTRUCTIONS_WRITER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Which class to use to write instructions on how to halt the application
HaltApplicationUtils - Class in org.apache.giraph.job
Utility methods for halting application while running
HaltApplicationUtils.DefaultHaltInstructionsWriter - Class in org.apache.giraph.job
Default implementation of HaltApplicationUtils.HaltInstructionsWriter - points to how to use ZooKeeperNodeCreator to halt
HaltApplicationUtils.HaltInstructionsWriter - Interface in org.apache.giraph.job
Writer of instructions about how to halt
haltComputation() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
haltComputation() - Method in class org.apache.giraph.master.MasterCompute
After this is called, the computation will stop, even if there are still messages in the system or vertices that have not voted to halt.
haltComputationPath - Variable in class org.apache.giraph.bsp.BspService
If this path exists computation will be halted
handle(Callback[]) - Method in class org.apache.giraph.comm.netty.SaslNettyServer.SaslDigestCallbackHandler
handleException(Text, T, X) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
Handles exceptions while reading vertex from each line.
handleNegativeArraySize(I) - Static method in class org.apache.giraph.utils.VerboseByteStructMessageWrite
message to present on NegativeArraySizeException
handles - Variable in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
has(long) - Method in class org.apache.giraph.utils.IncreasingBitSet
Check for existence of a key
hasAggregatorWriterClass() - Method in class org.apache.giraph.conf.GiraphClasses
Check if AggregatorWriter is set
hasData() - Method in class org.apache.giraph.conf.GiraphTypes
Check if types are set
hasData() - Method in class org.apache.giraph.metrics.AggregatedMetric
Whether this AggregatedMetric has any data.
hasEdgeAdditions(VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Check if changes contain edge addition requests
hasEdgeInputFormat() - Method in class org.apache.giraph.conf.GiraphClasses
Check if EdgeInputFormat is set
hasEdgeInputFormat() - Method in class org.apache.giraph.conf.GiraphConfiguration
Does the job have a EdgeInputFormat?
hasEdgeInputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
hasEdgeOutputFormat() - Method in class org.apache.giraph.conf.GiraphClasses
Check if EdgeOutputFormat is set
hasEdgeOutputFormat() - Method in class org.apache.giraph.conf.GiraphConfiguration
Does the job have a EdgeOutputFormat?
hasEdgeOutputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
hasEdgeOutputFormatSubdir() - Method in class org.apache.giraph.conf.GiraphConfiguration
Does the job have a EdgeOutputFormat subdir?
hasEdgeRemovals(VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Check if changes contain edge removal requests
hasEdgesForPartition(int) - Method in class org.apache.giraph.edge.AbstractEdgeStore
 
hasEdgesForPartition(int) - Method in interface org.apache.giraph.edge.EdgeStore
Check if edge store has edge for a given partition
hasEdgesForPartition(int) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
hasEmbedding() - Method in class org.apache.giraph.mapping.DefaultEmbeddedLongByteOps
 
hasEmbedding() - Method in class org.apache.giraph.mapping.DefaultLongByteOps
 
hasEmbedding() - Method in interface org.apache.giraph.mapping.MappingStoreOps
True if MappingStoreOps is based on embedding info
hashCode() - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
hashCode() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
hashCode() - Method in class org.apache.giraph.comm.netty.handler.ClientRequestId
 
hashCode() - Method in class org.apache.giraph.conf.AbstractConfOption
 
hashCode() - Method in class org.apache.giraph.counters.CustomCounter
 
hashCode() - Method in class org.apache.giraph.counters.GiraphHadoopCounter
 
hashCode() - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair
 
hashCode() - Method in class org.apache.giraph.graph.TaskInfo
 
hashCode() - Method in class org.apache.giraph.jython.wrappers.JythonWrapperBase
 
hashCode() - Method in class org.apache.giraph.jython.wrappers.JythonWritableWrapper
 
hashCode() - Method in class org.apache.giraph.ooc.persistence.DataIndex
 
hashCode() - Method in class org.apache.giraph.ooc.persistence.DataIndex.NumericIndexEntry
 
hashCode() - Method in class org.apache.giraph.scripting.DeployedScript
 
hashCode() - Method in class org.apache.giraph.types.JavaWritablePair
 
HashMapEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
OutEdges implementation backed by a HashMap.
HashMapEdges() - Constructor for class org.apache.giraph.edge.HashMapEdges
 
HashMultimapEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
OutEdges implementation backed by an ArrayListMultimap.
HashMultimapEdges() - Constructor for class org.apache.giraph.edge.HashMultimapEdges
 
hasHostname() - Method in class org.apache.giraph.metrics.ValueWithHostname
Check if there is any hostname.
HashPartitionerFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Divides the vertices into partitions by their hash code using a simple round-robin hash for great balancing if given a random hash code.
HashPartitionerFactory() - Constructor for class org.apache.giraph.partition.HashPartitionerFactory
 
HashRangePartitionerFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Divides the vertices into partitions by their hash code using ranges of the hash space.
HashRangePartitionerFactory() - Constructor for class org.apache.giraph.partition.HashRangePartitionerFactory
 
hasMappingInputFormat() - Method in class org.apache.giraph.conf.GiraphClasses
Check if MappingInputFormat is set
hasMappingInputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Check if mappingInputFormat is set
hasMasterComputeClass() - Method in class org.apache.giraph.conf.GiraphClasses
Check if MasterCompute is set
hasMessagesForPartition(int) - Method in interface org.apache.giraph.comm.messages.MessageStore
Check if we have messages for some partition
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
hasMessagesForPartition(int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
hasMessagesForVertex(I) - Method in interface org.apache.giraph.comm.messages.MessageStore
Check if we have messages for some vertex
hasMessagesForVertex(I) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
hasMessagesForVertex(I) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
hasMessagesForVertex(IntWritable) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
hasMessagesForVertex(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractListStore
 
hasMessagesForVertex(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
 
hasMessagesForVertex(LongWritable) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
hasMessagesForVertex(I) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
hasMessagesForVertex(I) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
hasMessagesForVertex(I) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
hasNext() - Method in class org.apache.giraph.comm.SendMessageCache.TargetVertexIdIterator
 
hasNext() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.ReusableIterator
 
hasNext() - Method in class org.apache.giraph.utils.ByteStructIterator
 
hasNext() - Method in class org.apache.giraph.utils.ByteStructVertexIdIterator
 
hasNext() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
hasNext() - Method in class org.apache.giraph.utils.PairList.Iterator
Returns true if the iteration has more elements.
hasNext() - Method in interface org.apache.giraph.utils.VertexIdIterator
Returns true if the iteration has more elements.
hasNext() - Method in class org.apache.giraph.utils.VertexIterator
Returns true if the iteration has more elements.
hasPartition(Integer) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Whether a partition with given id exists on this worker.
hasPartition(Integer) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
hasPartition(Integer) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Whether a given partition is available
hasPartition(Integer) - Method in interface org.apache.giraph.partition.PartitionStore
Whether a specific partition is present in the store.
hasPartition(Integer) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
hasPartition(Integer) - Method in class org.apache.giraph.worker.BspServiceWorker
 
hasPartitionClass() - Method in class org.apache.giraph.conf.GiraphClasses
Check if Partition is set
hasPartitionDataOnFile - Variable in class org.apache.giraph.ooc.data.DiskBackedDataStore
Set containing ids of all partitions where the partition data is in some file on disk.
hasPendingRequests() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
hasProcessedOnMemory() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Whether there is any processed partition stored in memory (excluding those that are prefetched to execute in the next superstep).
hasVertexAdditions(VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Check if changes contain vertex addition requests
hasVertexInputFormat() - Method in class org.apache.giraph.conf.GiraphClasses
Check if VertexInputFormat class is set
hasVertexInputFormat() - Method in class org.apache.giraph.conf.GiraphConfiguration
Does the job have a VertexInputFormat?
hasVertexInputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
hasVertexOutputFormat() - Method in class org.apache.giraph.conf.GiraphClasses
Check if VertexOutputFormat is set
hasVertexOutputFormat() - Method in class org.apache.giraph.conf.GiraphConfiguration
Does the job have a VertexOutputFormat?
hasVertexOutputFormat() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
hasVertexOutputFormatSubdir() - Method in class org.apache.giraph.conf.GiraphConfiguration
Does the job have a EdgeOutputFormat subdir?
hasVertexRemovals(VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Check if changes contain vertex removal requests
hasVertexResolverClass() - Method in class org.apache.giraph.conf.GiraphClasses
Check if VertexResolver is set
hasWorkerContextClass() - Method in class org.apache.giraph.conf.GiraphClasses
Check if WorkerContext is set
HDFS_FILE_CREATION_RETRIES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of retries for creating the HDFS files
HDFS_FILE_CREATION_RETRY_WAIT_MS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of milliseconds to wait before retrying HDFS file creation
header() - Static method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
heapHistogramDump(int, boolean, String) - Static method in class org.apache.giraph.utils.JMap
Run jmap, print numLines of output from it to stderr.
heapHistogramDump(int, String) - Static method in class org.apache.giraph.utils.JMap
Run jmap, print numLines of output from it to stderr.
heapHistogramDump(int, PrintStream, String) - Static method in class org.apache.giraph.utils.JMap
Run jmap, print numLines of output from it to stream passed in.
HELP - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for help
HIGH_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
The memory pressure at which the job is suffering from GC overhead.
HISTOGRAM_COMPUTE_PER_PARTITION - Static variable in interface org.apache.giraph.metrics.MetricNames
Name of metric for compute times per partition
HISTOGRAM_LOAD_SIZE - Static variable in class org.apache.giraph.ooc.OutOfCoreIOCallable
Name of Metric for size of loads
HISTOGRAM_STORE_SIZE - Static variable in class org.apache.giraph.ooc.OutOfCoreIOCallable
Name of Metric for size of stores
HugeArrayUtils - Class in org.apache.giraph.block_app.reducers.array
Utility class when we are dealing with huge arrays (i.e.

I

IdAndNullArrayEdges<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.edge
Implementation of OutEdges with IDs and null edge values having their TypeOps.
IdAndNullArrayEdges() - Constructor for class org.apache.giraph.edge.IdAndNullArrayEdges
 
IdAndValueArrayEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Implementation of OutEdges with IDs and Edge values having their TypeOps.
IdAndValueArrayEdges() - Constructor for class org.apache.giraph.edge.IdAndValueArrayEdges
 
IdByteArrayMessageStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages.primitives
Special message store to be used when IDs are primitive and no combiner is used.
IdByteArrayMessageStore(MessageValueFactory<M>, PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
Constructor
IdentityComputation<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.examples
User applications can subclass IdentityComputation, which simply prints the results that have been read for testing IO related jobs under any inputformat
IdentityComputation() - Constructor for class org.apache.giraph.examples.IdentityComputation
 
IdOneMessagePerVertexStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages.primitives
Special message store to be used when IDs are primitive and message doesn't need to be, and message combiner is used.
IdOneMessagePerVertexStore(MessageValueFactory<M>, PartitionSplitInfo<I>, MessageCombiner<? super I, M>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
Constructor
IdWithValueTextOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Write out Vertices' IDs and values, but not their edges nor edges' values.
IdWithValueTextOutputFormat() - Constructor for class org.apache.giraph.io.formats.IdWithValueTextOutputFormat
 
IdWithValueTextOutputFormat.IdWithValueVertexWriter - Class in org.apache.giraph.io.formats
Vertex writer used with IdWithValueTextOutputFormat.
IdWithValueVertexWriter() - Constructor for class org.apache.giraph.io.formats.IdWithValueTextOutputFormat.IdWithValueVertexWriter
 
IfBlock - Class in org.apache.giraph.block_app.framework.block
Block that executes one of two branches based on a condition
IfBlock(Supplier<Boolean>, Block, Block) - Constructor for class org.apache.giraph.block_app.framework.block.IfBlock
 
IfBlock(Supplier<Boolean>, Block) - Constructor for class org.apache.giraph.block_app.framework.block.IfBlock
 
ignoreExistingVertices() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
ignoreExistingVertices() - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
ignoreExistingVertices() - Method in interface org.apache.giraph.conf.MessageClasses
Whether to completely ignore existing vertices, and just process messages
ImmutableBiMapSerializerUtils - Class in org.apache.giraph.writable.kryo.serializers
Helper class used to register serializers for the different classes return by the ImmutableBiMap methods.
ImmutableClassesGiraphConfigurable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.conf
Can be instantiated with ImmutableClassesGiraphConfiguration
ImmutableClassesGiraphConfiguration<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.conf
The classes set here are immutable, the remaining configuration is mutable.
ImmutableClassesGiraphConfiguration(Configuration) - Constructor for class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Constructor.
ImmutableOutputCommitter - Class in org.apache.giraph.bsp
This output committer doesn't do anything, meant for the case where output isn't desired, or as a base for not using FileOutputCommitter.
ImmutableOutputCommitter() - Constructor for class org.apache.giraph.bsp.ImmutableOutputCommitter
 
InboundByteCounter - Class in org.apache.giraph.comm.netty
Keep track of the bytes received and provide some metrics when desired as part of the Netty Channel stack.
InboundByteCounter() - Constructor for class org.apache.giraph.comm.netty.InboundByteCounter
Constructor
inc() - Method in class com.yammer.metrics.core.NoOpCounter
 
inc(long) - Method in class com.yammer.metrics.core.NoOpCounter
 
inc(String, long) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
inc() - Method in class org.apache.giraph.utils.ProgressCounter
Increments counter
incomingMessageClasses - Variable in class org.apache.giraph.conf.GiraphClasses
Incoming message classes
incrCachedSuperstep() - Method in class org.apache.giraph.bsp.BspService
Increment the cached superstep.
incrDataSize(int, int) - Method in class org.apache.giraph.comm.SendDataCache
Increment the data size
increaseEdgesRemoved() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
Increase the number of edges removed by one.
IncreasingBitSet - Class in org.apache.giraph.utils
Bit set optimized for increasing longs to save storage space.
IncreasingBitSet() - Constructor for class org.apache.giraph.utils.IncreasingBitSet
 
increment(long) - Method in interface org.apache.giraph.block_app.framework.api.Counter
Increment this counter by the given value
increment() - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Increment counter value by 1.
increment(long) - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Increment counter value.
incrementCounter(Integer) - Method in class org.apache.giraph.comm.aggregators.CountingCache
Increase count of flushes for worker with desired task id.
incrementCounter() - Method in class org.apache.giraph.comm.aggregators.CountingOutputStream
Subclasses should call this method when an object is written
incrementCounters(PartitionOwner, Vertex<I, V, E>) - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Increment V & E counts for new vertex read, store values for that outgoing _temporary_ Partition, which shares the Partition ID for the actual remote Partition the collection will eventually be processed in.
incrementEdgeInputSplitsLoaded() - Method in class org.apache.giraph.worker.WorkerProgress
Increment number of edge input splits which were loaded
incrementPartitionsComputed() - Method in class org.apache.giraph.worker.WorkerProgress
Increment number of partitions which were computed
incrementPartitionsStored() - Method in class org.apache.giraph.worker.WorkerProgress
Increment number of partitions which were stored
incrementVertexInputSplitsLoaded() - Method in class org.apache.giraph.worker.WorkerProgress
Increment number of vertex input splits which were loaded
incrFinishedVertexCount() - Method in class org.apache.giraph.partition.PartitionStats
Increment the finished vertex count by one.
incrVertexCount() - Method in class org.apache.giraph.partition.PartitionStats
Increment the vertex count by one.
incrVertexEdgeCount(VertexEdgeCount) - Method in class org.apache.giraph.graph.VertexEdgeCount
Increment the both the vertex edge count with a VertexEdgeCount.
incrVertexEdgeCount(long, long) - Method in class org.apache.giraph.graph.VertexEdgeCount
Increment the both the vertex edge count with primitives.
IndexAndDataOut(int, ExtendedDataOutput) - Constructor for class org.apache.giraph.utils.ExtendedByteArrayOutputBuffer.IndexAndDataOut
Constructor
inferFrom(Class<? extends TypesHolder>) - Method in class org.apache.giraph.conf.GiraphTypes
Infer types from Computation class
info(String) - Method in class org.apache.giraph.utils.TimedLogger
Print to the info log level if the minimum waiting time was reached.
init(Mapper.Context) - Static method in class org.apache.giraph.counters.GiraphStats
Initialize with Hadoop Context.
init(Mapper.Context) - Static method in class org.apache.giraph.counters.GiraphTimers
Instantiate with Hadoop Context.
init(GiraphConfiguration) - Method in interface org.apache.giraph.graph.JobProgressTrackerClient
Initialize the client.
init(GiraphConfiguration) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
init(GiraphConfiguration) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
init(GiraphConfiguration, GiraphJobObserver) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
init(GiraphConfiguration, GiraphJobObserver) - Method in interface org.apache.giraph.job.JobProgressTrackerService
Initialize the service
init(Configuration, String) - Static method in class org.apache.giraph.jython.JythonUtils
Sets up the Configuration for using Jython
init(GiraphConfiguration) - Static method in class org.apache.giraph.metrics.GiraphMetrics
Initialize singleton instance of GiraphMetrics.
initAndCheckConfig(GiraphConfiguration) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Initializes configuration, such that running it executes block application.
initConfig(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
initConfig(GiraphConfiguration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Based on provided configuration, updates it, such that all necessary properties are initialized.
initialize(Mapper.Context, long) - Method in interface org.apache.giraph.aggregators.AggregatorWriter
The method is called at the initialization of the AggregatorWriter.
initialize() - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Create a empty matrix with all values set to 0.0
initialize() - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrix
Create a empty matrix with all values set to 0.0
initialize(Mapper.Context, long) - Method in class org.apache.giraph.aggregators.TextAggregatorWriter
 
initialize() - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkMasterCompute
 
initialize() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkMasterCompute
 
initialize() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
initialize(GiraphConfiguration, BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Initialize master logic to execute BlockFactory defined in the configuration.
initialize(Block, S, BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Initialize Master Logic to execute given block, starting with given executionStage.
initialize(Configuration, Progressable) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
initialize() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
initialize(PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore.Factory
 
initialize(PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Method in class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
 
initialize(PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Method in interface org.apache.giraph.comm.messages.MessageStoreFactory
Implementation class should use this method of initialization of any required internal state.
initialize(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.edge.ArrayListEdges
 
initialize(int) - Method in class org.apache.giraph.edge.ArrayListEdges
 
initialize() - Method in class org.apache.giraph.edge.ArrayListEdges
 
initialize(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.edge.ByteArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.ByteArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.ByteArrayEdges
 
initialize(CentralizedServiceWorker<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>, Progressable) - Method in interface org.apache.giraph.edge.EdgeStoreFactory
Implementation class should use this method of initialization of any required internal state.
initialize(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.edge.HashMapEdges
 
initialize(int) - Method in class org.apache.giraph.edge.HashMapEdges
 
initialize() - Method in class org.apache.giraph.edge.HashMapEdges
 
initialize(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
initialize(int, int) - Method in class org.apache.giraph.edge.HashMultimapEdges
Additional initialization method tailored to the underlying multimap implementation.
initialize(int) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
initialize() - Method in class org.apache.giraph.edge.HashMultimapEdges
 
initialize(Iterable<Edge<I, NullWritable>>) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
initialize(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
initialize(CentralizedServiceWorker<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>, Progressable) - Method in class org.apache.giraph.edge.InMemoryEdgeStoreFactory
 
initialize(Iterable<Edge<IntWritable, NullWritable>>) - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
initialize(Iterable<Edge<LongWritable, ByteWritable>>) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
initialize() - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongDiffArray
Initialize with a given capacity
initialize() - Method in class org.apache.giraph.edge.LongDiffArray
Initialize array
initialize(Iterable<Edge<LongWritable, NullWritable>>) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
initialize(Iterable<Edge<LongWritable, DoubleWritable>>) - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
initialize(Iterable<Edge<LongWritable, DoubleWritable>>) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
initialize() - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
initialize(Iterable<Edge<LongWritable, NullWritable>>) - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
initialize() - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
initialize(Iterable<Edge<LongWritable, NullWritable>>) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
initialize(int) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
initialize() - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
initialize(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
initialize(int) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
initialize() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
initialize(Iterable<Edge<I, E>>) - Method in interface org.apache.giraph.edge.OutEdges
Initialize the data structure and set the edges from an iterable.
initialize(int) - Method in interface org.apache.giraph.edge.OutEdges
Initialize the data structure with the specified initial capacity.
initialize() - Method in interface org.apache.giraph.edge.OutEdges
Initialize the data structure with the default initial capacity.
initialize() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.AggregatorsTestMasterCompute
 
initialize() - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterCompute
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.GeneratedEdgeReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.examples.GeneratedVertexReader
 
initialize() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoMasterCompute
 
initialize() - Method in class org.apache.giraph.examples.RandomWalkVertexMasterCompute
 
initialize() - Method in class org.apache.giraph.examples.scc.SccPhaseMasterCompute
 
initialize(Mapper.Context, long) - Method in class org.apache.giraph.examples.SimpleAggregatorWriter
 
initialize() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexMasterCompute
 
initialize() - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterCompute
 
initialize() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankMasterCompute
 
initialize() - Method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageMasterCompute
 
initialize(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in interface org.apache.giraph.factories.ComputationFactory
One time initialization before compute calls.
initialize(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.factories.DefaultComputationFactory
 
initialize(GraphState, WorkerClientRequestProcessor<I, V, E>, CentralizedServiceWorker<I, V, E>, WorkerGlobalCommUsage) - Method in class org.apache.giraph.graph.AbstractComputation
Initialize, called by infrastructure before the superstep starts.
initialize(I, V, Iterable<Edge<I, E>>) - Method in class org.apache.giraph.graph.ByteValueVertex
 
initialize(I, V) - Method in class org.apache.giraph.graph.ByteValueVertex
 
initialize(GraphState, WorkerClientRequestProcessor<I, V, E>, CentralizedServiceWorker<I, V, E>, WorkerGlobalCommUsage) - Method in interface org.apache.giraph.graph.Computation
Initialize, called by infrastructure before the superstep starts.
initialize(I, V, Iterable<Edge<I, E>>) - Method in class org.apache.giraph.graph.DefaultVertex
 
initialize(I, V) - Method in class org.apache.giraph.graph.DefaultVertex
 
initialize(I, Writable, Iterable<Edge<I, Writable>>) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
initialize(I, Writable) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
initialize(I, V, Iterable<Edge<I, E>>) - Method in interface org.apache.giraph.graph.Vertex
Initialize id, value, and edges.
initialize(I, V) - Method in interface org.apache.giraph.graph.Vertex
Initialize id and value.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.EdgeReader
Use the input split and context to setup reading the edges.
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.EdgeWriter
Use the context to setup writing the edges.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
 
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat.AdjacencyListTextVertexWriter
 
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat.IdWithValueVertexWriter
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.JsonBase64VertexInputFormat.JsonBase64VertexReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader
 
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.SrcIdDstIdEdgeValueTextOutputFormat.SrcIdDstIdEdgeValueEdgeWriter
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
 
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriter
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
 
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriter
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
initialize(InputSplit, TaskAttemptContext) - Method in interface org.apache.giraph.io.iterables.GiraphReader
Use the input split and context to setup reading.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.iterables.MappingReaderWrapper
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.iterables.VertexReaderWrapper
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.MappingReader
Use the input split and context to setup reading the vertices.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.VertexReader
Use the input split and context to setup reading the vertices.
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.giraph.io.VertexValueReader
 
initialize(TaskAttemptContext) - Method in class org.apache.giraph.io.VertexWriter
Use the context to setup writing the vertices.
initialize(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.jython.factories.JythonComputationFactory
 
initialize(MappingStore<LongWritable, ByteWritable>) - Method in class org.apache.giraph.mapping.AbstractLongByteOps
 
initialize() - Method in class org.apache.giraph.mapping.LongByteMappingStore
 
initialize() - Method in interface org.apache.giraph.mapping.MappingStore
Must be called before anything else can be done on this instance
initialize(MappingStore<I, B>) - Method in interface org.apache.giraph.mapping.MappingStoreOps
Must be called before anything else can be done on this instance
initialize(BspServiceWorker<LongWritable, ? extends Writable, E>) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge
 
initialize(BspServiceWorker<I, ? extends Writable, E>) - Method in interface org.apache.giraph.mapping.translate.TranslateEdge
Must be called before other methods can be used
initialize() - Method in class org.apache.giraph.master.DefaultMasterCompute
 
initialize(MasterClient, List<WorkerInfo>) - Method in class org.apache.giraph.master.input.MasterInputSplitsHandler
Initialize
initialize(BspService) - Method in class org.apache.giraph.master.MasterAggregatorHandler
Initialize AggregatorWriter
initialize() - Method in class org.apache.giraph.master.MasterCompute
Initialize the MasterCompute class, this is the place to register aggregators.
initialize() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
initialize() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Initialize/Start the out-of-core engine.
initialize() - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
 
initialize() - Method in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
 
initialize() - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
Initialize the DAO
initialize(int, Progressable) - Method in class org.apache.giraph.partition.BasicPartition
 
initialize(int, Progressable) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
initialize(LocalData<I, V, E, ? extends Writable>) - Method in class org.apache.giraph.partition.GraphPartitionerFactory
 
initialize(LocalData<I, V, E, ? extends Writable>) - Method in interface org.apache.giraph.partition.GraphPartitionerFactoryInterface
Use some local data present in the worker
initialize(LocalData<LongWritable, V, E, ? extends Writable>) - Method in class org.apache.giraph.partition.LongMappingStorePartitionerFactory
 
initialize(int, Progressable) - Method in interface org.apache.giraph.partition.Partition
Initialize the partition.
initialize() - Method in interface org.apache.giraph.partition.PartitionStore
Called at the beginning of the computation.
initialize(int, Progressable) - Method in class org.apache.giraph.partition.SimplePartition
 
initialize() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
initialize() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
initialize(int) - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
initialize() - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
initialize(int) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
initialize(OutEdges<I, E>, Iterable<Edge<I, E>>) - Static method in class org.apache.giraph.utils.EdgeIterables
Initialize edges data structure and add the edges from edgesIterable.
initialize() - Method in class org.apache.giraph.utils.PairList
Initialize the inner state.
initialize(int) - Method in class org.apache.giraph.utils.PairList
Initialize the inner state, with a known size.
initialize(byte[], int, int) - Method in class org.apache.giraph.utils.UnsafeReusableByteArrayInput
Initialize the object with all required parameters
initialize() - Method in interface org.apache.giraph.utils.VertexIdData
Initialize the inner state.
initialize(int) - Method in interface org.apache.giraph.utils.VertexIdData
Initialize the inner state, with a known size.
INITIALIZE_MS_NAME - Static variable in class org.apache.giraph.counters.GiraphTimers
Counter name for initialize msec
initializeAfterRead(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Initialize object after deserializing it.
initializeAndCheck(String, Configuration) - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
Initialize output and perform any necessary checks
initializeOutputGraph(GiraphConfiguration) - Static method in class org.apache.giraph.io.formats.InMemoryVertexOutputFormat
Initialize this output format - needs to be called before running the application.
initializeVertex(Vertex<I, V, E>, I, Supplier<V>, List<Edge<I, E>>) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
initialProbability() - Method in class org.apache.giraph.examples.RandomWalkComputation
Compute an initial probability value for the vertex.
initialValue() - Method in class org.apache.giraph.utils.ThreadLocalProgressCounter
Initializes a new counter, adds it to the list of counters and returns it.
initMetrics() - Static method in class org.apache.giraph.utils.MemoryUtils
Initialize metrics tracked by this helper.
initMetrics() - Static method in class org.apache.giraph.worker.InputSplitsCallable
Initialize metrics used by this class and its subclasses.
InMemoryDataAccessor - Class in org.apache.giraph.ooc.persistence
Implementation of data accessor which keeps all the data serialized but in memory.
InMemoryDataAccessor(ImmutableClassesGiraphConfiguration<?, ?, ?>) - Constructor for class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
Constructor
InMemoryDataAccessor.InMemoryDataInputWrapper - Class in org.apache.giraph.ooc.persistence
DataInputWrapper implementation for InMemoryDataAccessor
InMemoryDataAccessor.InMemoryDataOutputWrapper - Class in org.apache.giraph.ooc.persistence
DataOutputWrapper implementation for InMemoryDataAccessor
InMemoryDataInputWrapper(BigDataInput, DataIndex) - Constructor for class org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataInputWrapper
Constructor
InMemoryDataOutputWrapper(BigDataOutput) - Constructor for class org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataOutputWrapper
Constructor
InMemoryEdgeStoreFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Edge store factory which produces message stores which hold all edges in memory.
InMemoryEdgeStoreFactory() - Constructor for class org.apache.giraph.edge.InMemoryEdgeStoreFactory
 
InMemoryMessageStoreFactory<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
Message store factory which produces message stores which hold all messages in memory.
InMemoryMessageStoreFactory() - Constructor for class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
Default constructor allowing class invocation via Reflection.
InMemoryVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
An input format that reads the input graph in memory.
InMemoryVertexInputFormat() - Constructor for class org.apache.giraph.utils.InMemoryVertexInputFormat
 
InMemoryVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
VertexOutputFormat which stores all vertices in memory
InMemoryVertexOutputFormat() - Constructor for class org.apache.giraph.io.formats.InMemoryVertexOutputFormat
 
InnerVertexReceiver() - Constructor for class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexReceiver
 
InnerVertexSender() - Constructor for class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexSender
 
InProcessZooKeeperRunner - Class in org.apache.giraph.zk
Zookeeper wrapper that starts zookeeper withing master process.
InProcessZooKeeperRunner() - Constructor for class org.apache.giraph.zk.InProcessZooKeeperRunner
 
InProcessZooKeeperRunner.ZooKeeperServerRunner - Class in org.apache.giraph.zk
Wrapper around zookeeper service.
INPUT_SPLIT_MAX_EDGES - Static variable in interface org.apache.giraph.conf.GiraphConstants
To limit outlier vertex input splits from producing too many vertices or to help with testing, the number of edges loaded from an input split can be limited.
INPUT_SPLIT_MAX_VERTICES - Static variable in interface org.apache.giraph.conf.GiraphConstants
To limit outlier vertex input splits from producing too many vertices or to help with testing, the number of vertices loaded from an input split can be limited.
INPUT_SPLIT_SAMPLE_PERCENT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Input split sample percent - Used only for sampling and testing, rather than an actual job.
INPUT_SPLITS_ALL_DONE_NODE - Static variable in class org.apache.giraph.bsp.BspService
Input splits all done node
INPUT_SPLITS_WORKER_DONE_DIR - Static variable in class org.apache.giraph.bsp.BspService
Input splits worker done directory
INPUT_SUPERSTEP - Static variable in class org.apache.giraph.bsp.BspService
Input superstep (superstep when loading the vertices happens)
INPUT_VERTEX_EDGES_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex edges class to be used during edge input only - optional
INPUT_VERTEX_EDGES_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
OutEdges for input factory class - optional
InputBase() - Constructor for class org.apache.giraph.jython.JythonJob.InputBase
 
InputFormatDescription<IF extends GiraphInputFormat> - Class in org.apache.giraph.io.formats.multi
Description of the input format - holds input format class and all parameters specifically set for that input format.
InputFormatDescription(Class<? extends IF>) - Constructor for class org.apache.giraph.io.formats.multi.InputFormatDescription
Constructor with input format class
InputFormatDescription(String) - Constructor for class org.apache.giraph.io.formats.multi.InputFormatDescription
Constructor with json string describing this input format
inputOutEdgesClass - Variable in class org.apache.giraph.conf.GiraphClasses
Input vertex edges class - cached for fast access
inputSplit - Variable in class org.apache.giraph.examples.GeneratedEdgeReader
The input split from initialize().
inputSplit - Variable in class org.apache.giraph.examples.GeneratedVertexReader
The input split from initialize().
inputSplitsAllDonePath - Variable in class org.apache.giraph.bsp.BspService
Input splits all done node
InputSplitsCallable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
Abstract base class for loading vertex/edge input splits.
InputSplitsCallable(Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.InputSplitsCallable
Constructor.
InputSplitsMasterOrganizer - Interface in org.apache.giraph.master.input
Interface for different input split organizers on master
inputSplitsWorkerDonePath - Variable in class org.apache.giraph.bsp.BspService
Input splits worker done directory
InputType - Enum in org.apache.giraph.io
Type of input
INSTANCE - Static variable in class com.yammer.metrics.core.NoOpCounter
singleton instance for everyone to use
INSTANCE - Static variable in class com.yammer.metrics.core.NoOpGuage
singleton instance for everyone to use
INSTANCE - Static variable in class com.yammer.metrics.core.NoOpHistogram
singleton instance for everyone to use
INSTANCE - Static variable in class com.yammer.metrics.core.NoOpMeter
singleton instance for everyone to use
INSTANCE - Static variable in class com.yammer.metrics.core.NoOpTimer
singleton instance for everyone to use
INSTANCE - Static variable in class org.apache.giraph.benchmark.ReducersBenchmark.TestLongSumReducer
Singleton
INSTANCE - Static variable in class org.apache.giraph.reducers.impl.AndReduce
Instance
INSTANCE - Static variable in class org.apache.giraph.reducers.impl.LongXorReduce
Long XOR, equivalent to l1 ^ l2
INSTANCE - Static variable in class org.apache.giraph.reducers.impl.OrReduce
Instance
INT - Static variable in class org.apache.giraph.combiner.MaxMessageCombiner
IntWritable specialization
INT - Static variable in class org.apache.giraph.combiner.SumMessageCombiner
IntWritable specialization
INT - Static variable in class org.apache.giraph.reducers.impl.MaxReduce
IntWritable specialization
INT - Static variable in class org.apache.giraph.reducers.impl.MinReduce
IntWritable specialization
INT - Static variable in class org.apache.giraph.reducers.impl.SumReduce
IntWritable specialization
Int2ByteMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Int2ByteMap.Entry>
Int2DoubleMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Int2DoubleMap.Entry>
Int2FloatMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Int2FloatMap.Entry>
Int2IntFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (int) -> int
Int2IntMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Int2IntMap.Entry>
Int2LongMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Int2LongMap.Entry>
Int2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (int) -> T
INT_BYTE_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Integer,ByteWritable
INT_INT_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Integer,IntWritable
INT_LONG_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Integer,LongWritable
IntArrayListWritable() - Constructor for class org.apache.giraph.examples.SimpleTriangleClosingComputation.IntArrayListWritable
Default constructor for reflection
IntBooleanConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, boolean) -> void
IntBooleanPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, boolean) -> boolean
IntByteConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, byte) -> void
IntBytePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, byte) -> boolean
IntConfOption - Class in org.apache.giraph.conf
Integer configuration option
IntConfOption(String, int, String) - Constructor for class org.apache.giraph.conf.IntConfOption
Constructor
IntConfOption(String, long, String) - Constructor for class org.apache.giraph.conf.IntConfOption
Constructor
IntConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (int) -> void
IntDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
A int matrix holds the values of the entries in int vectors.
IntDenseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Create a new matrix with the same number of rows and columns.
IntDenseMatrix(int, int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Create a new matrix with the given number of rows and columns.
IntDenseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The int dense matrix aggregator is used to register and aggregate int dense matrices.
IntDenseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
IntDenseVector - Class in org.apache.giraph.aggregators.matrix.dense
The int dense vector holds the values of a particular row.
IntDenseVector() - Constructor for class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Create a new vector with default size.
IntDenseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Create a new vector with given size.
IntDenseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The double dense vector aggregator is used to aggregate double dense vectors.
IntDenseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.dense.IntDenseVectorSumAggregator
 
IntDoubleConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, double) -> void
IntDoublePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, double) -> boolean
IntDoubleWritable - Class in org.apache.giraph.writable.tuple
Int-Double Pair Writable
IntDoubleWritable() - Constructor for class org.apache.giraph.writable.tuple.IntDoubleWritable
Constructor
IntDoubleWritable(int, double) - Constructor for class org.apache.giraph.writable.tuple.IntDoubleWritable
Constructor
IntEdgeStore<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge.primitives
Special edge store to be used when ids are IntWritable.
IntEdgeStore(CentralizedServiceWorker<IntWritable, V, E>, ImmutableClassesGiraphConfiguration<IntWritable, V, E>, Progressable) - Constructor for class org.apache.giraph.edge.primitives.IntEdgeStore
Constructor.
IntEdgeValue() - Constructor for class org.apache.giraph.mapping.translate.LongByteTranslateEdge.IntEdgeValue
 
interfaceClass() - Method in enum org.apache.giraph.graph.GraphType
Get interface class (Writable or WritableComparable) for this graph type
InternalVertexRunner - Class in org.apache.giraph.utils
A base class for running internal tests on a vertex Extending classes only have to invoke the run() method to test their vertex.
IntFloatConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, float) -> void
IntFloatMessageStore - Class in org.apache.giraph.comm.messages.primitives
Special message store to be used when ids are IntWritable and messages are FloatWritable and messageCombiner is used.
IntFloatMessageStore(PartitionSplitInfo<IntWritable>, MessageCombiner<? super IntWritable, FloatWritable>) - Constructor for class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
Constructor
IntFloatPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, float) -> boolean
IntIntConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, int) -> void
IntIntNullTextInputFormat - Class in org.apache.giraph.io.formats
Simple text-based VertexInputFormat for unweighted graphs with int ids.
IntIntNullTextInputFormat() - Constructor for class org.apache.giraph.io.formats.IntIntNullTextInputFormat
 
IntIntNullTextInputFormat.IntIntNullVertexReader - Class in org.apache.giraph.io.formats
Vertex reader associated with IntIntNullTextInputFormat.
IntIntNullTextVertexInputFormat - Class in org.apache.giraph.io.formats
Simple text-based VertexInputFormat for unweighted graphs with int ids.
IntIntNullTextVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat
 
IntIntNullTextVertexInputFormat.IntIntNullVertexReader - Class in org.apache.giraph.io.formats
Vertex reader associated with IntIntNullTextVertexInputFormat.
IntIntNullVertexReader() - Constructor for class org.apache.giraph.io.formats.IntIntNullTextInputFormat.IntIntNullVertexReader
 
IntIntNullVertexReader() - Constructor for class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat.IntIntNullVertexReader
 
IntIntPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, int) -> boolean
IntIntTextVertexValueInputFormat<E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Simple text-based VertexValueInputFormat for integer ids and values.
IntIntTextVertexValueInputFormat() - Constructor for class org.apache.giraph.io.formats.IntIntTextVertexValueInputFormat
 
IntIntTextVertexValueInputFormat.IntIntTextVertexValueReader - Class in org.apache.giraph.io.formats
IntIntTextVertexValueReader() - Constructor for class org.apache.giraph.io.formats.IntIntTextVertexValueInputFormat.IntIntTextVertexValueReader
 
IntIntWritable - Class in org.apache.giraph.writable.tuple
Int-Int Pair Writable
IntIntWritable() - Constructor for class org.apache.giraph.writable.tuple.IntIntWritable
Constructor
IntIntWritable(int, int) - Constructor for class org.apache.giraph.writable.tuple.IntIntWritable
Constructor
IntLongConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, long) -> void
IntLongPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (int, long) -> boolean
IntLongWritable - Class in org.apache.giraph.writable.tuple
Int-Long Pair Writable
IntLongWritable() - Constructor for class org.apache.giraph.writable.tuple.IntLongWritable
Constructor
IntLongWritable(int, long) - Constructor for class org.apache.giraph.writable.tuple.IntLongWritable
Constructor
IntMaxAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting max integer value.
IntMaxAggregator() - Constructor for class org.apache.giraph.aggregators.IntMaxAggregator
 
IntMinAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting min integer value.
IntMinAggregator() - Constructor for class org.apache.giraph.aggregators.IntMinAggregator
 
IntNullArrayEdges - Class in org.apache.giraph.edge
Implementation of OutEdges with int ids and null edge values, backed by dynamic primitive array.
IntNullArrayEdges() - Constructor for class org.apache.giraph.edge.IntNullArrayEdges
 
IntNullNullNullVertexReader() - Constructor for class org.apache.giraph.io.formats.IntNullNullTextInputFormat.IntNullNullNullVertexReader
 
IntNullNullTextInputFormat - Class in org.apache.giraph.io.formats
Simple text-based VertexInputFormat for unweighted graphs without edges or values, just vertices with ids.
IntNullNullTextInputFormat() - Constructor for class org.apache.giraph.io.formats.IntNullNullTextInputFormat
 
IntNullNullTextInputFormat.IntNullNullNullVertexReader - Class in org.apache.giraph.io.formats
Reader for this InputFormat.
IntNullReverseTextEdgeInputFormat - Class in org.apache.giraph.io.formats
Simple text-based EdgeInputFormat for unweighted graphs with int ids.
IntNullReverseTextEdgeInputFormat() - Constructor for class org.apache.giraph.io.formats.IntNullReverseTextEdgeInputFormat
 
IntNullTextEdgeInputFormat - Class in org.apache.giraph.io.formats
Simple text-based EdgeInputFormat for unweighted graphs with int ids.
IntNullTextEdgeInputFormat() - Constructor for class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat
 
IntNullTextEdgeInputFormat.IntNullTextEdgeReader - Class in org.apache.giraph.io.formats
IntNullTextEdgeReader() - Constructor for class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat.IntNullTextEdgeReader
 
IntOverwriteAggregator - Class in org.apache.giraph.aggregators
Aggregator that stores a value that is overwritten once another value is aggregated.
IntOverwriteAggregator() - Constructor for class org.apache.giraph.aggregators.IntOverwriteAggregator
 
IntPair - Class in org.apache.giraph.utils
A pair of integers.
IntPair(int, int) - Constructor for class org.apache.giraph.utils.IntPair
Constructor.
IntPredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (int) -> boolean
IntProductAggregator - Class in org.apache.giraph.aggregators
Aggregator for calculating products of long and integer values.
IntProductAggregator() - Constructor for class org.apache.giraph.aggregators.IntProductAggregator
 
IntRef(int) - Constructor for class org.apache.giraph.function.primitive.PrimitiveRefs.IntRef
Constructor
IntSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
A int matrix holds the values of the entries in int vectors.
IntSparseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Create a new matrix with the given number of rows.
IntSparseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The int matrix aggregator is used to register and aggregate int matrices.
IntSparseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
IntSparseVector - Class in org.apache.giraph.aggregators.matrix.sparse
The int vector holds the values of a particular row.
IntSparseVector() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
Create a new vector with default size.
IntSparseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
Create a new vector with given size.
IntSparseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The float vector aggregator is used to aggregate float vectors.
IntSparseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.IntSparseVectorSumAggregator
 
IntSumAggregator - Class in org.apache.giraph.aggregators
Aggregator for summing up integer values.
IntSumAggregator() - Constructor for class org.apache.giraph.aggregators.IntSumAggregator
 
IntSupplier - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: () -> int
IntToIntWritableWrapper - Class in org.apache.giraph.types
Converts Integers to IntWritables
IntToIntWritableWrapper() - Constructor for class org.apache.giraph.types.IntToIntWritableWrapper
 
IntToLongWritableWrapper - Class in org.apache.giraph.types
Converts Integers to LongWritables
IntToLongWritableWrapper() - Constructor for class org.apache.giraph.types.IntToLongWritableWrapper
 
IntTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with IntWritable type
IntWritableToIntUnwrapper - Class in org.apache.giraph.types
Converts IntWritables to Integers
IntWritableToIntUnwrapper() - Constructor for class org.apache.giraph.types.IntWritableToIntUnwrapper
 
IntWritableToLongUnwrapper - Class in org.apache.giraph.types
Converts IntWritables to Longs
IntWritableToLongUnwrapper() - Constructor for class org.apache.giraph.types.IntWritableToLongUnwrapper
 
INVALID_ID - Static variable in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
Invalid ID
invokeAll(Collection<? extends Callable<T>>) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
IO_COMMAND_HISTORY_SIZE - Static variable in class org.apache.giraph.ooc.OutOfCoreIOStatistics
How many recent IO operations should we keep track of? Any report given out of this statistics collector is only based on most recent IO operations.
IOCommand - Class in org.apache.giraph.ooc.command
Representation of an IO command (moving data to disk/memory) used in out-of-core mechanism.
IOCommand(OutOfCoreEngine, int) - Constructor for class org.apache.giraph.ooc.command.IOCommand
Constructor
IOCommand.IOCommandType - Enum in org.apache.giraph.ooc.command
Type of IO command
ioCommandCompleted(IOCommand) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Notify out-of-core engine that an IO command is completed by an IO thread
ioCommandCompleted(IOCommand) - Method in class org.apache.giraph.ooc.OutOfCoreIOScheduler
Notify IO scheduler that the IO command is completed
IPC_INITIAL_PORT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Initial port to start using for the IPC communication
IS_PURE_YARN_JOB - Static variable in interface org.apache.giraph.conf.GiraphConstants
Is this a pure YARN job (i.e.
isActive() - Method in class org.apache.giraph.examples.scc.SccVertexValue
Indicates whether the vertex was removed in a Trimming phase.
isCheckpointSupported(GiraphConfiguration, MasterCompute) - Method in interface org.apache.giraph.bsp.checkpoints.CheckpointSupportedChecker
Does the job support checkpoints? It is true by default, set it to false if your job uses some non-checkpointable features: - static variables for storing data between supersteps.
isCheckpointSupported(GiraphConfiguration, MasterCompute) - Method in class org.apache.giraph.bsp.checkpoints.DefaultCheckpointSupportedChecker
 
isCheckpointSupported(GiraphConfiguration, MasterCompute) - Method in class org.apache.giraph.bsp.checkpoints.DisabledCheckpointSupportedChecker
 
isComplete() - Method in class org.apache.giraph.comm.netty.SaslNettyClient
 
isComplete() - Method in class org.apache.giraph.comm.netty.SaslNettyServer
 
isComputationDone() - Method in class org.apache.giraph.worker.WorkerProgress
 
isComputeSuperstep() - Method in class org.apache.giraph.worker.WorkerProgress
 
isComputeSuperstep() - Method in class org.apache.giraph.worker.WorkerProgressStats
 
isConnectionResetByPeer(Throwable) - Static method in class org.apache.giraph.graph.GraphTaskManager
Checks the message of a throwable, and checks whether it is a "connection reset by peer" type of exception.
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.AbstractConfOption
Check if the value set is the same as the default value
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.BooleanConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.ClassConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.EnumConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.FloatConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.IntConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.JsonStringConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.LongConfOption
 
isDefaultValue(Configuration) - Method in class org.apache.giraph.conf.StrConfOption
 
isDone(int) - Method in class org.apache.giraph.job.CombinedWorkerProgress
Is the application done
isEdgeValueNullWritable() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Tell if we are using NullWritable for Edge value.
isEmpty() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
isEmpty() - Method in interface org.apache.giraph.partition.PartitionStore
Whether the partition store is empty.
isEmpty() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Check if the heap is empty
isEmpty() - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
isEmpty() - Method in class org.apache.giraph.utils.PairList
Check if the list is empty.
isEmpty() - Method in interface org.apache.giraph.utils.VertexIdData
Check if the list is empty.
isEqual(Iterable<T>, Iterable<T>) - Static method in class org.apache.giraph.utils.CollectionUtils
Helper method to check if iterables are equal.
isExecutionComplete() - Method in enum org.apache.giraph.bsp.SuperstepState
Returns true if execution has to be stopped after this superstep.
isFalse(Configuration) - Method in class org.apache.giraph.conf.BooleanConfOption
Check if value is true
isFree() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
isHalted() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
isHalted() - Method in class org.apache.giraph.graph.DefaultVertex
 
isHalted() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
isHalted() - Method in interface org.apache.giraph.graph.Vertex
Is this vertex done?
isHalted() - Method in class org.apache.giraph.master.MasterCompute
Has the master halted?
isHealthy() - Method in class org.apache.giraph.worker.BspServiceWorker
Intended to check the health of the node.
isInitialized() - Static method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Return true of the zookeeper is initialized.
isInputSuperstep() - Method in class org.apache.giraph.worker.WorkerProgress
 
isInputSuperstep() - Method in class org.apache.giraph.worker.WorkerProgressStats
 
isJMapHistogramDumpEnabled() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check whether to enable jmap dumping thread.
isKnown() - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
isKnown() - Method in enum org.apache.giraph.graph.GraphFunctions
 
isLoadingEdgesDone() - Method in class org.apache.giraph.worker.WorkerProgress
 
isLoadingVerticesDone() - Method in class org.apache.giraph.worker.WorkerProgress
 
isMaster() - Method in enum org.apache.giraph.graph.GraphFunctions
Tell whether this function acts as a master.
isMaster() - Method in class org.apache.giraph.graph.GraphTaskManager
Get "isMaster" status flag -- we need to know if we're the master in the "finally" block of our GiraphYarnTask#execute() to commit final job output.
isMasterApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isName(String) - Static method in class org.apache.giraph.zk.ComputationDoneName
Is this string a ComputationDoneName?
isNewMessage() - Method in class org.apache.giraph.utils.ByteStructVertexIdMessageIterator
 
isNewMessage() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
isNewMessage() - Method in interface org.apache.giraph.utils.VertexIdMessageIterator
Return true of current message is new
isNotAWorker() - Method in enum org.apache.giraph.graph.GraphFunctions
 
isNotified() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
isOutputSuperstep() - Method in class org.apache.giraph.worker.WorkerProgress
 
isOutputSuperstep() - Method in class org.apache.giraph.worker.WorkerProgressStats
 
isPartitionOnDisk(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Whether a partition is on disk (both its data and its current messages)
isPartitionProcessed(Integer) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Whether a partition is *processed* in the current iteration cycle over partitions.
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
isPointerListEncoding() - Method in interface org.apache.giraph.comm.messages.MessageStore
True if this message-store encodes messages as a list of long pointers to compact serialized messages
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
isPointerListEncoding() - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
isPointerListEncoding() - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
isPrintable() - Method in class org.apache.giraph.utils.TimedLogger
Is the log message printable (minimum interval met)?
isPureYarnJob() - Method in class org.apache.giraph.conf.GiraphConfiguration
Is this a "pure YARN" Giraph job, or is a MapReduce layer (v1 or v2) actually managing our cluster nodes, i.e.
isReactiveJmapHistogramDumpEnabled() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check whether to enable heap memory supervisor thread
isRequired() - Method in class org.apache.giraph.benchmark.BenchmarkOption
Check if the option is required
isShutdown() - Method in class com.yammer.metrics.core.NoOpExecutorService
 
isSource(long) - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
Checks if a vertex is a source.
isSplitable(JobContext, Path) - Method in class org.apache.giraph.io.formats.GiraphTextInputFormat
 
isStaticGraph() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Whether the application with change or not the graph topology.
isStoringDone() - Method in class org.apache.giraph.worker.WorkerProgress
 
isTerminated() - Method in class com.yammer.metrics.core.NoOpExecutorService
 
isTrue(Configuration) - Method in class org.apache.giraph.conf.BooleanConfOption
Check if value is false
isUnknown() - Method in enum org.apache.giraph.graph.GraphFunctions
 
isWaitingForMessage(Long) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
isWorker() - Method in enum org.apache.giraph.graph.GraphFunctions
Tell whether this function acts as a worker.
isWorkerContextReceiveApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerContextSendApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerReceiveApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerSendApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isZooKeeper() - Method in enum org.apache.giraph.graph.GraphFunctions
Tell whether this function acts as a ZooKeeper server.
isZookeeperExternal() - Method in class org.apache.giraph.conf.GiraphConfiguration
Was ZooKeeper provided externally?
iter - Variable in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.ReusableIterator
Primitive Key iterator
IterationCounterPiece - Class in org.apache.giraph.block_app.library.iteration
Piece that increments execution stage iteration.
IterationCounterPiece() - Constructor for class org.apache.giraph.block_app.library.iteration.IterationCounterPiece
 
IterationStage - Interface in org.apache.giraph.block_app.library.iteration
Execution stage that contains iteration information.
IterationStageImpl - Class in org.apache.giraph.block_app.library.iteration
Implementation of IterationStage
IterationStageImpl() - Constructor for class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
IterationStageImpl(int) - Constructor for class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
iterator() - Method in interface org.apache.giraph.block_app.framework.block.Block
Create iterator representing all pieces needed to be executed in this block.
iterator() - Method in class org.apache.giraph.block_app.framework.block.EmptyBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.FilteringBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
iterator() - Method in class org.apache.giraph.comm.messages.PointerListMessagesIterable
 
iterator() - Method in class org.apache.giraph.counters.GiraphStats
 
iterator() - Method in class org.apache.giraph.counters.GiraphTimers
 
iterator() - Method in class org.apache.giraph.edge.ArrayListEdges
 
iterator() - Method in class org.apache.giraph.edge.ByteArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.HashMapEdges
 
iterator() - Method in class org.apache.giraph.edge.HashMultimapEdges
 
iterator() - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
iterator() - Method in class org.apache.giraph.edge.LongDiffArray
Returns an iterator that reuses objects.
iterator() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
iterator() - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
iterator() - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
iterator() - Method in class org.apache.giraph.edge.MutableEdgesIterable
 
iterator() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
iterator() - Method in class org.apache.giraph.partition.ByteArrayPartition
 
iterator() - Method in class org.apache.giraph.partition.SimplePartition
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
 
iterator() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
 
iterator() - Method in interface org.apache.giraph.types.heaps.Int2ByteMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Int2DoubleMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Int2FloatMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Int2IntMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Int2LongMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Long2ByteMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Long2DoubleMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Long2FloatMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Long2IntMapEntryIterable
Get the iterator.
iterator() - Method in interface org.apache.giraph.types.heaps.Long2LongMapEntryIterable
Get the iterator.
iterator() - Method in class org.apache.giraph.utils.ByteStructIterable
 
iterator() - Method in class org.apache.giraph.utils.EmptyIterable
 
Iterator() - Constructor for class org.apache.giraph.utils.PairList.Iterator
 
iterator() - Method in class org.apache.giraph.utils.RepresentativeByteStructIterable
 
iterator() - Method in class org.apache.giraph.utils.TestGraph
An iterator over the vertices
IteratorToReaderWrapper<T> - Class in org.apache.giraph.io.iterables
Wraps Iterator into object which provides iteration like in VertexReader or EdgeReader
IteratorToReaderWrapper(Iterator<T>) - Constructor for class org.apache.giraph.io.iterables.IteratorToReaderWrapper
Constructor

J

JavaWritablePair<W extends org.apache.hadoop.io.Writable,J> - Class in org.apache.giraph.types
Holder for java and writable class pair.
JMap - Class in org.apache.giraph.utils
Helper to run jmap and print the output
JMap() - Constructor for class org.apache.giraph.utils.JMap
Do not construct
JMAP_ENABLE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Configuration key to enable jmap printing
JMAP_LIVE_ONLY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Configuration key for printing live objects only This option will trigger Full GC for every jmap dump and so can significantly hinder performance.
JMAP_PATH - Static variable in interface org.apache.giraph.conf.GiraphConstants
Path where jmap exists
JMAP_PRINT_LINES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Configuration key for how many lines to print
JMAP_SLEEP_MILLIS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Configuration key for msec to sleep between calls
JMapHistoDumper - Class in org.apache.giraph.utils
An observer for both worker and master that periodically dumps the memory usage using jmap tool.
JMapHistoDumper() - Constructor for class org.apache.giraph.utils.JMapHistoDumper
 
JOB_OBSERVER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Observer class to watch over job status - optional
JOB_PROGRESS_TRACKER_CLIENT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Class to use as the job progress client
JOB_PROGRESS_TRACKER_SERVICE_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Class to use to track job progress on client
JOB_RETRY_CHECKER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Observer class to watch over job status - optional
jobCounters() - Method in class org.apache.giraph.counters.GiraphTimers
Get Iterable through job counters.
jobFinished(Job, boolean) - Method in class org.apache.giraph.job.DefaultJobObserver
 
jobFinished(Job, boolean) - Method in interface org.apache.giraph.job.GiraphJobObserver
Callback when job finishes.
jobGotAllMappers(Job) - Method in class org.apache.giraph.job.DefaultJobObserver
 
jobGotAllMappers() - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
Called when job got all mappers, used to check MAX_ALLOWED_JOB_TIME_MS and potentially start a thread which will kill the job after this time
jobGotAllMappers(Job) - Method in interface org.apache.giraph.job.GiraphJobObserver
Called when job gets all mappers and really starts computations.
JobProgressTracker - Interface in org.apache.giraph.job
Interface for job progress tracker on job client
JobProgressTrackerClient - Interface in org.apache.giraph.graph
Wrapper around JobProgressTracker which retries to connect and swallows exceptions so app wouldn't crash if something goes wrong with progress reports.
JobProgressTrackerClientNoOp - Class in org.apache.giraph.graph
Class to use for JobProgressTracker client when progress shouldn't be tracked or something goes wrong
JobProgressTrackerClientNoOp() - Constructor for class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
JobProgressTrackerService - Interface in org.apache.giraph.job
Implementation of job progress tracker service on job client
jobRunning(Job) - Method in class org.apache.giraph.job.DefaultJobObserver
 
jobRunning(Job) - Method in interface org.apache.giraph.job.GiraphJobObserver
Callback after job was submitted.
JsonBase64VertexFormat - Class in org.apache.giraph.io.formats
Keeps the vertex keys for the input/output vertex format
JsonBase64VertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Simple way to represent the structure of the graph with a JSON object.
JsonBase64VertexInputFormat() - Constructor for class org.apache.giraph.io.formats.JsonBase64VertexInputFormat
 
JsonBase64VertexInputFormat.JsonBase64VertexReader - Class in org.apache.giraph.io.formats
Simple reader that supports JsonBase64VertexInputFormat
JsonBase64VertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Simple way to represent the structure of the graph with a JSON object.
JsonBase64VertexOutputFormat() - Constructor for class org.apache.giraph.io.formats.JsonBase64VertexOutputFormat
 
JsonBase64VertexOutputFormat.JsonBase64VertexWriter - Class in org.apache.giraph.io.formats
Simple writer that supports JsonBase64VertexOutputFormat
JsonBase64VertexReader() - Constructor for class org.apache.giraph.io.formats.JsonBase64VertexInputFormat.JsonBase64VertexReader
 
JsonBase64VertexWriter() - Constructor for class org.apache.giraph.io.formats.JsonBase64VertexOutputFormat.JsonBase64VertexWriter
 
JsonLongDoubleFloatDoubleVertexInputFormat - Class in org.apache.giraph.io.formats
VertexInputFormat that features long vertex ID's, double vertex values and float out-edge weights, and double message types, specified in JSON format.
JsonLongDoubleFloatDoubleVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.JsonLongDoubleFloatDoubleVertexInputFormat
 
JsonLongDoubleFloatDoubleVertexOutputFormat - Class in org.apache.giraph.io.formats
VertexOutputFormat that supports JSON encoded vertices featuring double values and float out-edge weights
JsonLongDoubleFloatDoubleVertexOutputFormat() - Constructor for class org.apache.giraph.io.formats.JsonLongDoubleFloatDoubleVertexOutputFormat
 
JSONOBJ_APPLICATION_ATTEMPT_KEY - Static variable in class org.apache.giraph.bsp.BspService
JSON application attempt key
JSONOBJ_METRICS_KEY - Static variable in class org.apache.giraph.bsp.BspService
JSON metrics key
JSONOBJ_NUM_MESSAGE_BYTES_KEY - Static variable in class org.apache.giraph.bsp.BspService
JSON message bytes count key
JSONOBJ_NUM_MESSAGES_KEY - Static variable in class org.apache.giraph.bsp.BspService
JSON message count key
JSONOBJ_STATE_KEY - Static variable in class org.apache.giraph.bsp.BspService
JSON state key
JSONOBJ_SUPERSTEP_KEY - Static variable in class org.apache.giraph.bsp.BspService
JSON superstep key
JsonStringConfOption - Class in org.apache.giraph.conf
JSON String configuration option
JsonStringConfOption(String, String) - Constructor for class org.apache.giraph.conf.JsonStringConfOption
Constructor
JYTHON - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for using Jython
JYTHON_COMPUTATION_CLASS_NAME - Static variable in class org.apache.giraph.jython.JythonOptions
Name of Computation class in Jython script
JYTHON_EDGE_VALUE - Static variable in class org.apache.giraph.jython.JythonOptions
edge value options
JYTHON_OUT_MSG_VALUE - Static variable in class org.apache.giraph.jython.JythonOptions
outgonig message value options
JYTHON_VERTEX_ID - Static variable in class org.apache.giraph.jython.JythonOptions
vertex id options
JYTHON_VERTEX_VALUE - Static variable in class org.apache.giraph.jython.JythonOptions
vertex value options
jythonClassNameOption() - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
The Configuration option for setting the Jython class name in this factory implementation.
JythonComputation - Class in org.apache.giraph.jython
Base class for writing computations in Jython.
JythonComputation() - Constructor for class org.apache.giraph.jython.JythonComputation
 
JythonComputationFactory - Class in org.apache.giraph.jython.factories
Factory for creating Jython Computation from python scripts
JythonComputationFactory() - Constructor for class org.apache.giraph.jython.factories.JythonComputationFactory
 
JythonEdgeValueFactory<E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.jython.factories
EdgeValueFactory that creates edge values which are Jython classes.
JythonEdgeValueFactory() - Constructor for class org.apache.giraph.jython.factories.JythonEdgeValueFactory
 
JythonFactoryBase<W extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.jython.factories
Base class for Jython factories.
JythonFactoryBase() - Constructor for class org.apache.giraph.jython.factories.JythonFactoryBase
 
JythonGiraphComputation<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.jython
The Computation class for using Jython with Giraph.
JythonGiraphComputation(JythonComputation) - Constructor for class org.apache.giraph.jython.JythonGiraphComputation
Constructor
JythonGraphTypeOptions(GraphType) - Constructor for class org.apache.giraph.jython.JythonOptions.JythonGraphTypeOptions
Constructor
JythonJob - Class in org.apache.giraph.jython
Holder of Jython job information.
JythonJob() - Constructor for class org.apache.giraph.jython.JythonJob
Constructor
JythonJob.EdgeInput - Class in org.apache.giraph.jython
Info about edge input
JythonJob.InputBase - Class in org.apache.giraph.jython
Base class for input information
JythonJob.TypeHolder - Class in org.apache.giraph.jython
Holds a Java or Jython type.
JythonJob.TypeWithHive - Class in org.apache.giraph.jython
A type along with its Hive input/output class.
JythonJob.VertexInput - Class in org.apache.giraph.jython
Info about vertex input
JythonJob.VertexOutput - Class in org.apache.giraph.jython
Info about vertex output
JythonMessageValueFactory<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.jython.factories
MessageValueFactory that creates message values which are Jython classes.
JythonMessageValueFactory() - Constructor for class org.apache.giraph.jython.factories.JythonMessageValueFactory
 
JythonOptions - Class in org.apache.giraph.jython
Jython related Configuration options
JythonOptions.JythonGraphTypeOptions - Class in org.apache.giraph.jython
Options for a graph type
JythonOutgoingMessageValueFactory<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.jython.factories
MessageValueFactory that creates outgoing message values which are Jython classes.
JythonOutgoingMessageValueFactory() - Constructor for class org.apache.giraph.jython.factories.JythonOutgoingMessageValueFactory
 
JythonUtils - Class in org.apache.giraph.jython
Helpers for running jobs with Jython.
JythonVertexIdFactory<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.jython.factories
VertexIdFactory that creates vertex IDs which are Jython classes.
JythonVertexIdFactory() - Constructor for class org.apache.giraph.jython.factories.JythonVertexIdFactory
 
JythonVertexValueFactory<V extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.jython.factories
VertexValueFactory that creates vertex IDs which are Jython classes.
JythonVertexValueFactory() - Constructor for class org.apache.giraph.jython.factories.JythonVertexValueFactory
 
JythonWrapperBase - Class in org.apache.giraph.jython.wrappers
Base class for wrapping Jython objects
JythonWrapperBase(PyObject) - Constructor for class org.apache.giraph.jython.wrappers.JythonWrapperBase
Constructor
JythonWritableWrapper - Class in org.apache.giraph.jython.wrappers
Wraps a Jython object, adding WritableComparable interface.
JythonWritableWrapper(PyObject) - Constructor for class org.apache.giraph.jython.wrappers.JythonWritableWrapper
Constructor

K

KEEP_ZOOKEEPER_DATA - Static variable in interface org.apache.giraph.conf.GiraphConstants
Keep the zookeeper output for debugging? Default is to remove it.
killJobWithMessage(String) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
Kill job with message describing why it's being killed
KRYO_REGISTERED_CLASS_DIR - Static variable in class org.apache.giraph.bsp.BspService
Directory to store kryo className-ID assignment
KryoIgnoreWritable - Interface in org.apache.giraph.writable.kryo.markers
Marker interface, specifying that kryo should serialize it on it's own, and ignore actual Writable method implementations.
kryoRegisteredClassPath - Variable in class org.apache.giraph.bsp.BspService
Kryo className-ID mapping directory
KryoSimpleWrapper<T> - Class in org.apache.giraph.writable.kryo
Generic wrapper object, making any object writable.
KryoSimpleWrapper(T) - Constructor for class org.apache.giraph.writable.kryo.KryoSimpleWrapper
Create wrapper given an object.
KryoSimpleWrapper() - Constructor for class org.apache.giraph.writable.kryo.KryoSimpleWrapper
Creates wrapper initialized with null.
KryoSimpleWritable - Class in org.apache.giraph.writable.kryo
Class which you can extend to get all serialization/deserialization done automagically.
KryoSimpleWritable() - Constructor for class org.apache.giraph.writable.kryo.KryoSimpleWritable
 
KryoWrappedReduceOperation<S,R> - Class in org.apache.giraph.reducers.impl
Reduce operation which wraps reduced value in KryoWritableWrapper, so we don't need to worry about it being writable
KryoWrappedReduceOperation() - Constructor for class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
 
KryoWritable - Class in org.apache.giraph.writable.kryo
Class which you can extend to get all serialization/deserialization done automagically
KryoWritable() - Constructor for class org.apache.giraph.writable.kryo.KryoWritable
 
KryoWritableWrapper<T> - Class in org.apache.giraph.writable.kryo
Generic wrapper object, making any object writable.
KryoWritableWrapper(T) - Constructor for class org.apache.giraph.writable.kryo.KryoWritableWrapper
Create wrapper given an object.
KryoWritableWrapper() - Constructor for class org.apache.giraph.writable.kryo.KryoWritableWrapper
Creates wrapper initialized with null.

L

Language - Enum in org.apache.giraph.graph
Programming language that something is implemented in
LAST_CHECKPOINTED_SUPERSTEP_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
last checkpointed superstep counter name
LAST_GC_CALL_INTERVAL - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
Memory observer thread would manually call GC if major/full GC has not been called for a while.
LAST_GCS_TO_KEEP - Static variable in class org.apache.giraph.utils.GcTracker
How many last gcs to keep
LAST_SUPERSTEP - Static variable in interface org.apache.giraph.aggregators.AggregatorWriter
Signal for last superstep
launchingJob(Job) - Method in class org.apache.giraph.job.DefaultJobObserver
 
launchingJob(Job) - Method in interface org.apache.giraph.job.GiraphJobObserver
Callback for job about to start.
LB_MAPPINGSTORE_LOWER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Lower value of LongByteMappingStore
LB_MAPPINGSTORE_UPPER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Upper value of LongByteMappingStore
LIMIT_NUMBER_OF_OPEN_REQUESTS - Static variable in class org.apache.giraph.comm.netty.NettyClient
Do we have a limit on number of open requests we can have
LIMIT_OPEN_REQUESTS_PER_WORKER - Static variable in class org.apache.giraph.comm.netty.NettyClient
Do we have a limit on number of open requests we can have for each worker.
line(int, double, long, String) - Static method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
LINE_TOKENIZE_VALUE - Static variable in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat
Delimiter for split
LINE_TOKENIZE_VALUE - Static variable in class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat
Split delimiter
LINE_TOKENIZE_VALUE - Static variable in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat
Specify the output delimiter
LINE_TOKENIZE_VALUE_DEFAULT - Static variable in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat
Default delimiter for split
LINE_TOKENIZE_VALUE_DEFAULT - Static variable in class org.apache.giraph.io.formats.AdjacencyListTextVertexOutputFormat
Default split delimiter
LINE_TOKENIZE_VALUE_DEFAULT - Static variable in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat
Default output delimiter
listEdgeStatus(JobContext) - Method in class org.apache.giraph.io.formats.GiraphFileInputFormat
List edge input directories.
listVertexStatus(JobContext) - Method in class org.apache.giraph.io.formats.GiraphFileInputFormat
List vertex input directories.
loadCheckpoint(long) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Load the vertices, edges, messages from the beginning of a superstep.
loadCheckpoint(long) - Method in class org.apache.giraph.worker.BspServiceWorker
 
loadingEdgesDone - Variable in class org.apache.giraph.worker.WorkerProgressStats
Whether worker finished loading edges until now
loadingVerticesDone - Variable in class org.apache.giraph.worker.WorkerProgressStats
Whether worker finished loading vertices
loadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Loads data of a partition into data store.
loadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
loadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
loadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
loadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Loads and assembles all data for a given partition, and put it into the data store.
loadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
loadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
loadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
loadPartitionDataProxy(int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
The proxy method that does the actual operation for `loadPartitionData`, but uses the data index given by the caller.
LoadPartitionIOCommand - Class in org.apache.giraph.ooc.command
IOCommand to load partition data, edge data (if in INPUT_SUPERSTEP), and message data (if in compute supersteps).
LoadPartitionIOCommand(OutOfCoreEngine, int, long) - Constructor for class org.apache.giraph.ooc.command.LoadPartitionIOCommand
Constructor
loadScript(Configuration, DeployedScript) - Static method in class org.apache.giraph.scripting.ScriptLoader
Load a single deployed script
loadScripts(Configuration) - Static method in class org.apache.giraph.scripting.ScriptLoader
Load all the scripts deployed in Configuration
LOCAL_EDGES_MIN_RATIO - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for minimum ratio of partition-local edges
LOCAL_EDGES_MIN_RATIO - Static variable in class org.apache.giraph.io.formats.PseudoRandomInputFormatConstants
Minimum ratio of partition-local edges.
LOCAL_EDGES_MIN_RATIO_DEFAULT - Static variable in class org.apache.giraph.io.formats.PseudoRandomInputFormatConstants
Default minimum ratio of partition-local edges.
LOCAL_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter of requests handled locally
LOCAL_TEST_MODE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Indicates whether this job is run in an internal unit test
LocalBlockRunner - Class in org.apache.giraph.block_app.framework.api.local
Local in-memory Block application job runner.
localData - Variable in class org.apache.giraph.partition.LongMappingStorePartitionerFactory
Local Data that supplies the mapping store
LocalData<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
Stores LocalData for each worker
LocalData(ImmutableClassesGiraphConfiguration<I, V, E>) - Constructor for class org.apache.giraph.worker.LocalData
Constructor Set configuration, create & initialize mapping store
LocalDiskDataAccessor - Class in org.apache.giraph.ooc.persistence
Data accessor object to read/write data in local disk.
LocalDiskDataAccessor(ImmutableClassesGiraphConfiguration<?, ?, ?>) - Constructor for class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
Constructor
LocalityAwareInputSplitsMasterOrganizer - Class in org.apache.giraph.master.input
Input splits organizer for vertex and edge input splits on master, which uses locality information
LocalityAwareInputSplitsMasterOrganizer(List<byte[]>, List<InputSplit>, List<WorkerInfo>) - Constructor for class org.apache.giraph.master.input.LocalityAwareInputSplitsMasterOrganizer
Constructor
LocalReduceHandle(ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
LOG - Static variable in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
LOG - Static variable in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
LOG - Static variable in class org.apache.giraph.comm.netty.SaslNettyClient
Class logger
LOG - Static variable in class org.apache.giraph.comm.netty.SaslNettyServer
Logger
LOG - Static variable in class org.apache.giraph.utils.RequestUtils
Logger
LOG_EXECUTION_STATUS - Static variable in class org.apache.giraph.block_app.framework.BlockUtils
Property describing whether to log execution status as application runs
LOG_LEVEL - Static variable in interface org.apache.giraph.conf.GiraphConstants
Override the Hadoop log level and set the desired log level.
LOG_THREAD_LAYOUT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use thread level debugging?
logAggregatedValue(MasterAggregatorUsage, Configuration) - Static method in class org.apache.giraph.utils.MasterLoggingAggregator
Print value of master logging aggregator on the master log, if the option for using it is set in the configuration.
logAndSanityCheck() - Method in class org.apache.giraph.comm.netty.NettyClient
Log information about the requests and check for problems in requests
logError(String, byte[]) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
logError(String, byte[]) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
logError(String, byte[]) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
logError(String, byte[]) - Method in interface org.apache.giraph.job.JobProgressTracker
Call this when you want to log an error line and exception object from any mapper to command line KryoWritableWrapper.convertFromByteArray can be used to get exception object back
logFailure(String) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
logFailure(String) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
logFailure(String) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
logFailure(String) - Method in interface org.apache.giraph.job.JobProgressTracker
Notify that job is failing
LoggerUtils - Class in org.apache.giraph.utils
Logger utils for log4j
logInfo() - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
 
logInfo() - Method in interface org.apache.giraph.comm.flow_control.FlowControl
Log the status of the flow control
logInfo() - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
logInfo() - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
logInfo(String) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
logInfo(String) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
logInfo(String) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
logInfo(String) - Method in interface org.apache.giraph.job.JobProgressTracker
Call this when you want to log an info line from any mapper to command line
LogStacktraceCallable<V> - Class in org.apache.giraph.utils
A wrapper to improve debugging.
LogStacktraceCallable(Callable<V>) - Constructor for class org.apache.giraph.utils.LogStacktraceCallable
Construct an instance that will pass call() to the given callable.
LogStacktraceCallable(Callable<V>, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.utils.LogStacktraceCallable
Construct an instance that will pass call() to the given callable.
logTimeSums() - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
logToCommandLine(String) - Method in interface org.apache.giraph.block_app.framework.api.BlockMasterApi
Call this to log a line to command line of the job.
logToCommandLine(String) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
logToCommandLine(String) - Method in class org.apache.giraph.master.MasterCompute
Call this to log a line to command line of the job.
logToCommandLine(String) - Method in class org.apache.giraph.worker.WorkerContext
Call this to log a line to command line of the job.
LogVersions - Class in org.apache.giraph.utils
Logs versions of Giraph dependencies on job start.
LogVersions() - Constructor for class org.apache.giraph.utils.LogVersions
 
logVersionsUsed() - Method in class org.apache.giraph.utils.GiraphDepVersions
Log the dependency versions we're using
LONG - Static variable in class org.apache.giraph.combiner.MaxMessageCombiner
LongWritable specialization
LONG - Static variable in class org.apache.giraph.combiner.SumMessageCombiner
LongWritable specialization
LONG - Static variable in class org.apache.giraph.reducers.impl.MaxReduce
LongWritable specialization
LONG - Static variable in class org.apache.giraph.reducers.impl.MinReduce
LongWritable specialization
LONG - Static variable in class org.apache.giraph.reducers.impl.SumReduce
LongWritable specialization
Long2ByteMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Long2ByteMap.Entry>
Long2DoubleMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Long2DoubleMap.Entry>
Long2FloatMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Long2FloatMap.Entry>
Long2IntMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Long2IntMap.Entry>
Long2LongFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (long) -> long
Long2LongMapEntryIterable - Interface in org.apache.giraph.types.heaps
Iterable which has its size and ObjectIterator<Long2LongMap.Entry>
Long2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (long) -> T
LONG_BYTE_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Long,ByteWritable
LONG_INT_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Long,IntWritable
LONG_LONG_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Long,LongWritable
LongAbstractListStore<M extends org.apache.hadoop.io.Writable,L extends List> - Class in org.apache.giraph.comm.messages.primitives.long_id
Special message store to be used when ids are LongWritable and no combiner is used.
LongAbstractListStore(MessageValueFactory<M>, PartitionSplitInfo<LongWritable>, ImmutableClassesGiraphConfiguration<LongWritable, Writable, Writable>) - Constructor for class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractListStore
Constructor
LongAbstractStore<M extends org.apache.hadoop.io.Writable,T> - Class in org.apache.giraph.comm.messages.primitives.long_id
Special message store to be used when ids are LongWritable and no combiner is used.
LongAbstractStore(MessageValueFactory<M>, PartitionSplitInfo<LongWritable>, ImmutableClassesGiraphConfiguration<LongWritable, Writable, Writable>) - Constructor for class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
Constructor
LongAndTimeUnit - Class in org.apache.giraph.metrics
Pair of long,TimeUnit
LongAndTimeUnit() - Constructor for class org.apache.giraph.metrics.LongAndTimeUnit
 
LongBooleanConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, boolean) -> void
LongBooleanPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, boolean) -> boolean
LongByteConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, byte) -> void
LongByteHashMapEdges - Class in org.apache.giraph.edge
OutEdges implementation with long ids and byte edge values, backed by a Long2ByteOpenHashMap.
LongByteHashMapEdges() - Constructor for class org.apache.giraph.edge.LongByteHashMapEdges
 
LongByteMappingStore - Class in org.apache.giraph.mapping
An implementation of MappingStore<LongWritable, ByteWritable> Methods implemented here are thread safe by default because it is guaranteed that each entry is written to only once.
LongByteMappingStore() - Constructor for class org.apache.giraph.mapping.LongByteMappingStore
 
LongBytePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, byte) -> boolean
LongByteTranslateEdge<E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.mapping.translate
Basic implementation of Translate Edge where I = LongWritable & B = ByteWritable
LongByteTranslateEdge() - Constructor for class org.apache.giraph.mapping.translate.LongByteTranslateEdge
 
LongByteTranslateEdge.DoubleEdgeValue - Class in org.apache.giraph.mapping.translate
Correct implementation of cloneValue when edgevalue = doublewritable
LongByteTranslateEdge.FloatEdgeValue - Class in org.apache.giraph.mapping.translate
Correct implementation of cloneValue when edgevalue = floatwritable
LongByteTranslateEdge.IntEdgeValue - Class in org.apache.giraph.mapping.translate
Correct implementation of cloneValue when edgevalue = intwritable
LongByteTranslateEdge.LongEdgeValue - Class in org.apache.giraph.mapping.translate
Correct implementation of cloneValue when edgevalue = longwritable
LongByteTranslateEdge.NoEdgeValue - Class in org.apache.giraph.mapping.translate
Correct implementation of cloneValue when edgevalue = nullwritable
LongConfOption - Class in org.apache.giraph.conf
Long configuration option
LongConfOption(String, long, String) - Constructor for class org.apache.giraph.conf.LongConfOption
Constructor
LongConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (long) -> void
LongDenseMatrix - Class in org.apache.giraph.aggregators.matrix.dense
A long matrix holds the values of the entries in long vectors.
LongDenseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Create a new matrix with the same number of rows and columns.
LongDenseMatrix(int, int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Create a new matrix with the given number of rows and columns.
LongDenseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The long dense matrix aggregator is used to register and aggregate long dense matrices.
LongDenseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
LongDenseVector - Class in org.apache.giraph.aggregators.matrix.dense
The long dense vector holds the values of a particular row.
LongDenseVector() - Constructor for class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Create a new vector with default size.
LongDenseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Create a new vector with given size.
LongDenseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.dense
The long dense vector aggregator is used to aggregate long dense vectors.
LongDenseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.dense.LongDenseVectorSumAggregator
 
LongDiffArray - Class in org.apache.giraph.edge
Compressed list array of long ids.
LongDiffArray() - Constructor for class org.apache.giraph.edge.LongDiffArray
 
LongDiffNullArrayEdges - Class in org.apache.giraph.edge
Implementation of OutEdges with long ids and null edge values, backed by a dynamic primitive array.
LongDiffNullArrayEdges() - Constructor for class org.apache.giraph.edge.LongDiffNullArrayEdges
 
LongDoubleArrayEdges - Class in org.apache.giraph.edge
Implementation of OutEdges with long ids and double edge values, backed by dynamic primitive arrays.
LongDoubleArrayEdges() - Constructor for class org.apache.giraph.edge.LongDoubleArrayEdges
 
LongDoubleConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, double) -> void
LongDoubleDoubleAdjacencyListVertexInputFormat - Class in org.apache.giraph.io.formats
InputFormat for reading graphs stored as (ordered) adjacency lists with the vertex ids longs and the vertex values and edges doubles.
LongDoubleDoubleAdjacencyListVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.LongDoubleDoubleAdjacencyListVertexInputFormat
 
LongDoubleDoubleAdjacencyListVertexInputFormat.LongDoubleDoubleAdjacencyListVertexReader - Class in org.apache.giraph.io.formats
LongDoubleDoubleAdjacencyListVertexReader(AdjacencyListTextVertexInputFormat.LineSanitizer) - Constructor for class org.apache.giraph.io.formats.LongDoubleDoubleAdjacencyListVertexInputFormat.LongDoubleDoubleAdjacencyListVertexReader
LongDoubleDoubleDoubleVertexReader() - Constructor for class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat.LongDoubleDoubleDoubleVertexReader
 
LongDoubleDoubleTextInputFormat - Class in org.apache.giraph.examples
Simple text-based VertexInputFormat for unweighted graphs with long ids.
LongDoubleDoubleTextInputFormat() - Constructor for class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat
 
LongDoubleDoubleTextInputFormat.LongDoubleDoubleDoubleVertexReader - Class in org.apache.giraph.examples
Vertex reader associated with LongDoubleDoubleTextInputFormat.
LongDoubleFloatTextInputFormat - Class in org.apache.giraph.examples
Simple text-based VertexInputFormat for weighted graphs with long ids.
LongDoubleFloatTextInputFormat() - Constructor for class org.apache.giraph.examples.LongDoubleFloatTextInputFormat
 
LongDoubleFloatTextInputFormat.LongDoubleFloatVertexReader - Class in org.apache.giraph.examples
Vertex reader associated with LongDoubleDoubleTextInputFormat.
LongDoubleFloatVertexReader() - Constructor for class org.apache.giraph.examples.LongDoubleFloatTextInputFormat.LongDoubleFloatVertexReader
 
LongDoubleHashMapEdges - Class in org.apache.giraph.edge
OutEdges implementation with long ids and double edge values, backed by a Long2DoubleOpenHashMap.
LongDoubleHashMapEdges() - Constructor for class org.apache.giraph.edge.LongDoubleHashMapEdges
 
LongDoubleMessageStore - Class in org.apache.giraph.comm.messages.primitives
Special message store to be used when ids are LongWritable and messages are DoubleWritable and messageCombiner is used.
LongDoubleMessageStore(PartitionSplitInfo<LongWritable>, MessageCombiner<? super LongWritable, DoubleWritable>) - Constructor for class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
Constructor
LongDoubleNullDoubleVertexReader() - Constructor for class org.apache.giraph.examples.LongDoubleNullTextInputFormat.LongDoubleNullDoubleVertexReader
 
LongDoubleNullTextInputFormat - Class in org.apache.giraph.examples
Input format for unweighted graphs with long ids.
LongDoubleNullTextInputFormat() - Constructor for class org.apache.giraph.examples.LongDoubleNullTextInputFormat
 
LongDoubleNullTextInputFormat.LongDoubleNullDoubleVertexReader - Class in org.apache.giraph.examples
Vertex reader associated with LongDoubleNullTextInputFormat.
LongDoublePredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, double) -> boolean
LongDoubleWritable - Class in org.apache.giraph.writable.tuple
Long-Double Pair Writable
LongDoubleWritable() - Constructor for class org.apache.giraph.writable.tuple.LongDoubleWritable
Constructor
LongDoubleWritable(long, double) - Constructor for class org.apache.giraph.writable.tuple.LongDoubleWritable
Constructor
LongEdgeStore<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge.primitives
Special edge store to be used when ids are LongWritable.
LongEdgeStore(CentralizedServiceWorker<LongWritable, V, E>, ImmutableClassesGiraphConfiguration<LongWritable, V, E>, Progressable) - Constructor for class org.apache.giraph.edge.primitives.LongEdgeStore
Constructor.
LongEdgeValue() - Constructor for class org.apache.giraph.mapping.translate.LongByteTranslateEdge.LongEdgeValue
 
LongFloatConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, float) -> void
LongFloatPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, float) -> boolean
LongIntConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, int) -> void
LongIntPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, int) -> boolean
LongIntWritable - Class in org.apache.giraph.writable.tuple
Long-Int Pair Writable
LongIntWritable() - Constructor for class org.apache.giraph.writable.tuple.LongIntWritable
Constructor
LongIntWritable(long, int) - Constructor for class org.apache.giraph.writable.tuple.LongIntWritable
Constructor
LongLongConsumer - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, long) -> void
LongLongNullTextInputFormat - Class in org.apache.giraph.io.formats
Simple text-based VertexInputFormat for unweighted graphs with long ids.
LongLongNullTextInputFormat() - Constructor for class org.apache.giraph.io.formats.LongLongNullTextInputFormat
 
LongLongNullTextInputFormat.LongLongNullVertexReader - Class in org.apache.giraph.io.formats
Vertex reader associated with LongLongNullTextInputFormat.
LongLongNullVertexReader() - Constructor for class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat.LongLongNullVertexReader
 
LongLongNullVertexReader() - Constructor for class org.apache.giraph.io.formats.LongLongNullTextInputFormat.LongLongNullVertexReader
 
LongLongPredicate - Interface in org.apache.giraph.function.primitive.pairs
Primitive specialization of Function: (long, long) -> boolean
LongLongWritable - Class in org.apache.giraph.writable.tuple
Long-Long Pair Writable
LongLongWritable() - Constructor for class org.apache.giraph.writable.tuple.LongLongWritable
Constructor
LongLongWritable(long, long) - Constructor for class org.apache.giraph.writable.tuple.LongLongWritable
Constructor
LongMappingStorePartitionerFactory<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Factory for long-byte mapping based partitioners.
LongMappingStorePartitionerFactory() - Constructor for class org.apache.giraph.partition.LongMappingStorePartitionerFactory
 
LongMaxAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting max long value.
LongMaxAggregator() - Constructor for class org.apache.giraph.aggregators.LongMaxAggregator
 
LongMinAggregator - Class in org.apache.giraph.aggregators
Aggregator for getting min long value.
LongMinAggregator() - Constructor for class org.apache.giraph.aggregators.LongMinAggregator
 
LongNullArrayEdges - Class in org.apache.giraph.edge
Implementation of OutEdges with long ids and null edge values, backed by a dynamic primitive array.
LongNullArrayEdges() - Constructor for class org.apache.giraph.edge.LongNullArrayEdges
 
LongNullHashSetEdges - Class in org.apache.giraph.edge
OutEdges implementation with long ids and null edge values, backed by a LongOpenHashSet.
LongNullHashSetEdges() - Constructor for class org.apache.giraph.edge.LongNullHashSetEdges
 
LongOverwriteAggregator - Class in org.apache.giraph.aggregators
Aggregator that stores a value that is overwritten once another value is aggregated.
LongOverwriteAggregator() - Constructor for class org.apache.giraph.aggregators.LongOverwriteAggregator
 
LongPointerListPerVertexStore<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages.primitives.long_id
This stores messages in ExtendedByteArrayOutputBuffer and stores long pointers that point to serialized messages
LongPointerListPerVertexStore(MessageValueFactory<M>, PartitionSplitInfo<LongWritable>, ImmutableClassesGiraphConfiguration<LongWritable, Writable, Writable>) - Constructor for class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
Constructor
LongPredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (long) -> boolean
LongProductAggregator - Class in org.apache.giraph.aggregators
Aggregator for calculating products of long values.
LongProductAggregator() - Constructor for class org.apache.giraph.aggregators.LongProductAggregator
 
LongRef(long) - Constructor for class org.apache.giraph.function.primitive.PrimitiveRefs.LongRef
Constructor
LongSparseMatrix - Class in org.apache.giraph.aggregators.matrix.sparse
A long matrix holds the values of the entries in long vectors.
LongSparseMatrix(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrix
Create a new matrix with the given number of rows.
LongSparseMatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The long matrix aggregator is used to register and aggregate long matrices.
LongSparseMatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
LongSparseVector - Class in org.apache.giraph.aggregators.matrix.sparse
The long vector holds the values of a particular row.
LongSparseVector() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Create a new vector with default size.
LongSparseVector(int) - Constructor for class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Create a new vector with given size.
LongSparseVectorSumAggregator - Class in org.apache.giraph.aggregators.matrix.sparse
The long vector aggregator is used to aggregate long vectors.
LongSparseVectorSumAggregator() - Constructor for class org.apache.giraph.aggregators.matrix.sparse.LongSparseVectorSumAggregator
 
LongSumAggregator - Class in org.apache.giraph.aggregators
Aggregator for summing up long values.
LongSumAggregator() - Constructor for class org.apache.giraph.aggregators.LongSumAggregator
 
LongToLongWritableWrapper - Class in org.apache.giraph.types
Converts Longs to LongWritables
LongToLongWritableWrapper() - Constructor for class org.apache.giraph.types.LongToLongWritableWrapper
 
LongTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with LongWritable type
LongWritableFunnel - Enum in org.apache.giraph.utils.hashing
Hashing strategy for LongWritable.
LongWritableToLongUnwrapper - Class in org.apache.giraph.types
Converts LongWritables to Longs
LongWritableToLongUnwrapper() - Constructor for class org.apache.giraph.types.LongWritableToLongUnwrapper
 
LongXorReduce - Class in org.apache.giraph.reducers.impl
ReduceOperation that XORs (^) values together.
LongXorReduce() - Constructor for class org.apache.giraph.reducers.impl.LongXorReduce
Constructor used for deserialization only
lookup(Class<W>, Class<J>) - Static method in class org.apache.giraph.types.WritableUnwrappers
Lookup type converter
lookup(JavaWritablePair<W, J>) - Static method in class org.apache.giraph.types.WritableUnwrappers
Lookup type converter
lookup(Class<W>, Class<J>) - Static method in class org.apache.giraph.types.WritableWrappers
Lookup type converter
lookup(JavaWritablePair<W, J>) - Static method in class org.apache.giraph.types.WritableWrappers
Lookup type converter
LOW_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
The memory pressure at/below which the job can use more memory without suffering from GC overhead.
LOWEST_GRAPH_PERCENTAGE_IN_MEMORY_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
lowest percentage of graph in memory throughout the execution
lowestGraphPercentageInMemory - Variable in class org.apache.giraph.worker.WorkerProgressStats
Lowest percentage of graph in memory throughout the execution so far

M

madeProgressFrom(CombinedWorkerProgress) - Method in class org.apache.giraph.job.CombinedWorkerProgress
Check if this instance made progress from another instance
main(String[]) - Static method in class org.apache.giraph.benchmark.AggregatorsBenchmark
Execute the benchmark.
main(String[]) - Static method in class org.apache.giraph.benchmark.PageRankBenchmark
Execute the benchmark.
main(String[]) - Static method in class org.apache.giraph.benchmark.RandomMessageBenchmark
Execute the benchmark.
main(String[]) - Static method in class org.apache.giraph.benchmark.ReducersBenchmark
Execute the benchmark.
main(String[]) - Static method in class org.apache.giraph.benchmark.ShortestPathsBenchmark
Execute the benchmark.
main(String[]) - Static method in class org.apache.giraph.benchmark.WeightedPageRankBenchmark
Execute the benchmark.
main(String[]) - Static method in class org.apache.giraph.conf.AllOptions
Command line utility to dump all Giraph options
main(String[]) - Static method in class org.apache.giraph.examples.SimpleCheckpoint
Executable from the command line.
main(String[]) - Static method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext
Executable from the command line.
main(String[]) - Static method in class org.apache.giraph.GiraphRunner
Execute GiraphRunner.
main(String[]) - Static method in class org.apache.giraph.yarn.GiraphApplicationMaster
Application entry point
main(String[]) - Static method in class org.apache.giraph.yarn.GiraphYarnTask
Task entry point.
main(String[]) - Static method in class org.apache.giraph.zk.GiraphZooKeeperAdmin
Entry point from shell script
main(String[]) - Static method in class org.apache.giraph.zk.ZooKeeperNodeCreator
Entry point from shell script
makeJobContext(Configuration, JobID) - Static method in class org.apache.giraph.job.HadoopUtils
Create a JobContext, supporting many Hadoops.
makeJobContext(Configuration, JobContext) - Static method in class org.apache.giraph.job.HadoopUtils
Create a JobContext, supporting many Hadoops.
makeJobContext(Configuration) - Static method in class org.apache.giraph.job.HadoopUtils
Create a JobContext, supporting many Hadoops.
makeJobContext() - Static method in class org.apache.giraph.job.HadoopUtils
Create a JobContext, supporting many Hadoops.
makeMetricName(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Create a MetricName using the job ID, group, and name.
makeTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class org.apache.giraph.job.HadoopUtils
Create a TaskAttemptContext, supporting many Hadoops.
makeTaskAttemptContext(Configuration, TaskAttemptContext) - Static method in class org.apache.giraph.job.HadoopUtils
Create a TaskAttemptContext, supporting many Hadoops.
makeTaskAttemptContext(Configuration) - Static method in class org.apache.giraph.job.HadoopUtils
Create a TaskAttemptContext, supporting many Hadoops.
makeTaskAttemptContext() - Static method in class org.apache.giraph.job.HadoopUtils
Create a TaskAttemptContext, supporting many Hadoops.
makeVertex(Number, V, Map.Entry<? extends Number, ? extends Number>...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Creates a new Vertex object, without adding it into the graph.
makeVertex(Number, V, Supplier<E>, Number...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Creates a new Vertex object, without adding it into the graph.
makeVertex(Number, Number, Number, Number...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Creates a new Vertex object, without adding it into the graph.
makeVertex(I, V, Map.Entry<I, E>...) - Method in class org.apache.giraph.utils.TestGraph
Create a vertex
MANUAL_GC_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
If mem-usage is above this threshold and no Full GC has been called, we call it manually
map - Variable in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
Map from partition id to map from vertex id to message
map - Variable in class org.apache.giraph.comm.messages.SimpleMessageStore
Map from partition id to map from vertex id to messages for that vertex
map(Object, Object, Mapper<Object, Object, Object, Object>.Context) - Method in class org.apache.giraph.graph.GraphMapper
GraphMapper is designed to host the compute node in a Hadoop Mapper task.
MapHandle<K,V> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.map
Handle to map of handles underneath
MapMutableEdge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Helper class for a mutable edge that modifies the backing map entry.
MapMutableEdge() - Constructor for class org.apache.giraph.edge.MapMutableEdge
 
MAPPER_CORES - Static variable in class org.apache.giraph.conf.FacebookConfiguration
How many cores per mapper should we use
MAPPER_MEMORY - Static variable in class org.apache.giraph.conf.FacebookConfiguration
How much memory per mapper should we use
MAPPER_OBSERVER_CLASSES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Classes for Mapper Observer - optional
MapperObserver - Interface in org.apache.giraph.graph
Mapper observer It can implement ContextSettable if it needs to access job counters.
mapperStarted() - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
mapperStarted() - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
mapperStarted() - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
mapperStarted() - Method in interface org.apache.giraph.job.JobProgressTracker
Notify JobProgressTracker that mapper started
MAPPING_INPUT_FORMAT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
MappingInputFormat class
MAPPING_INPUT_FORMAT_DESCRIPTIONS - Static variable in class org.apache.giraph.io.formats.multi.MappingInputFormatDescription
MappingInputFormats description - JSON array containing a JSON array for each mapping input.
MAPPING_STORE_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Mapping related information
MAPPING_STORE_OPS_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Class to use for performing read operations on mapping store
MappingEntry<I extends org.apache.hadoop.io.WritableComparable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.mapping
An entry in MappingStore
MappingEntry(I, B) - Constructor for class org.apache.giraph.mapping.MappingEntry
Constructor
MappingInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Use this to load data for a BSP application.
MappingInputFormat() - Constructor for class org.apache.giraph.io.MappingInputFormat
 
mappingInputFormatClass - Variable in class org.apache.giraph.conf.GiraphClasses
Mapping input format - cached for fast access
MappingInputFormatDescription<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats.multi
Description of the mapping input format - holds mapping input format class and all parameters specifically set for that mapping input format.
MappingInputFormatDescription(Class<? extends MappingInputFormat<I, V, E, B>>) - Constructor for class org.apache.giraph.io.formats.multi.MappingInputFormatDescription
Constructor with mapping input format class
MappingInputFormatDescription(String) - Constructor for class org.apache.giraph.io.formats.multi.MappingInputFormatDescription
Constructor with json string describing this input format
MappingInputSplitsCallable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
Load as many mapping input splits as possible.
MappingInputSplitsCallable(MappingInputFormat<I, V, E, B>, Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.MappingInputSplitsCallable
Constructor
MappingInputSplitsCallableFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
MappingInputSplitsCallableFactory(MappingInputFormat<I, V, E, B>, Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.MappingInputSplitsCallableFactory
Constructor.
MappingInputSplitsMasterOrganizer - Class in org.apache.giraph.master.input
Organizer for mapping splits on master.
MappingInputSplitsMasterOrganizer(List<byte[]>, List<WorkerInfo>) - Constructor for class org.apache.giraph.master.input.MappingInputSplitsMasterOrganizer
Constructor
MappingReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Will read the mapping from an input split.
MappingReader() - Constructor for class org.apache.giraph.io.MappingReader
 
MappingReaderWrapper<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.iterables
Wraps GiraphReader for mapping into MappingReader
MappingReaderWrapper(GiraphReader<MappingEntry<I, B>>) - Constructor for class org.apache.giraph.io.iterables.MappingReaderWrapper
Constructor
mappingStore - Variable in class org.apache.giraph.mapping.AbstractLongByteOps
Mapping store instance to operate on
MappingStore<I extends org.apache.hadoop.io.WritableComparable,B extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.mapping
MappingStore used to store the vertexId - target map supplied by user Methods implemented in this class need to be thread safe
MappingStoreOps<I extends org.apache.hadoop.io.WritableComparable,B extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.mapping
Interface of operations that can be done on mapping store once it is fully loaded
MAPRED_JAVA_JOB_OPTIONS - Static variable in class org.apache.giraph.conf.FacebookConfiguration
Java options passed to mappers.
MapTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with MapWritable type
mark() - Method in class com.yammer.metrics.core.NoOpMeter
 
mark(long) - Method in class com.yammer.metrics.core.NoOpMeter
 
markPartitionAsInProcess(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Mark a partition as being 'IN_PROCESS'
MASTER_COMPUTE_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Class for Master - optional
MASTER_ELECTION_DIR - Static variable in class org.apache.giraph.bsp.BspService
Where the master election happens
MASTER_JOB_STATE_NODE - Static variable in class org.apache.giraph.bsp.BspService
Master job state znode above base dir
MASTER_LOGGING_AGGREGATOR_NAME - Static variable in class org.apache.giraph.utils.MasterLoggingAggregator
Name of aggregator which will be gathering the logs
MASTER_OBSERVER_CLASSES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Classes for Master Observer - optional
MASTER_SUFFIX - Static variable in class org.apache.giraph.bsp.BspService
Suffix denotes a master
MASTER_TASK_ID - Static variable in class org.apache.giraph.master.MasterInfo
Master task id is always -1
MasterAggregatorHandler - Class in org.apache.giraph.master
Handler for reduce/broadcast on the master
MasterAggregatorHandler(ImmutableClassesGiraphConfiguration<?, ?, ?>, Progressable) - Constructor for class org.apache.giraph.master.MasterAggregatorHandler
Constructor
MasterAggregatorUsage - Interface in org.apache.giraph.master
Master compute can access and change aggregators through this interface
MasterClient - Interface in org.apache.giraph.comm
Interface for master to send messages to workers
masterCompute(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
masterCompute(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Function that is called on master, after send phase, before receive phase.
masterCompute(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
masterCompute(String, Consumer<BlockMasterApi>) - Static method in class org.apache.giraph.block_app.library.Pieces
Execute given function on master.
masterCompute(BlockMasterApi, MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
MasterCompute - Class in org.apache.giraph.master
Interface for defining a master vertex that can perform centralized computation between supersteps.
MasterCompute() - Constructor for class org.apache.giraph.master.MasterCompute
 
masterComputeClass - Variable in class org.apache.giraph.conf.GiraphClasses
Master compute class - cached for fast access
masterElectionPath - Variable in class org.apache.giraph.bsp.BspService
Path to the master election path
MasterGlobalCommHandler - Class in org.apache.giraph.master
Handler for all master communications
MasterGlobalCommHandler(MasterAggregatorHandler, MasterInputSplitsHandler) - Constructor for class org.apache.giraph.master.MasterGlobalCommHandler
Constructor
MasterGlobalCommUsage - Interface in org.apache.giraph.master
All global master communication
MasterGlobalCommUsageAggregators - Interface in org.apache.giraph.master
Master compute can access reduce and broadcast methods through this interface, from masterCompute method.
MasterGraphPartitioner<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.partition
Determines how to divide the graph into partitions, how to manipulate partitions and then how to assign those partitions to workers.
MasterGraphPartitionerImpl<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Abstracts and implements all MasterGraphPartitioner logic on top of a single user function - getWorkerIndex.
MasterGraphPartitionerImpl(ImmutableClassesGiraphConfiguration<I, V, E>) - Constructor for class org.apache.giraph.partition.MasterGraphPartitionerImpl
Constructor.
MasterInfo - Class in org.apache.giraph.master
Information about the master that is sent to other workers.
MasterInfo() - Constructor for class org.apache.giraph.master.MasterInfo
Constructor
MasterInputSplitsHandler - Class in org.apache.giraph.master.input
Handler for input splits on master Since currently Giraph fails if worker fails while reading input, we didn't complicate this part with retries yet, later it could be added by keeping track of which worker got which split and then if worker dies put these splits back to queues.
MasterInputSplitsHandler(boolean, Mapper.Context) - Constructor for class org.apache.giraph.master.input.MasterInputSplitsHandler
Constructor
masterInvolved(int) - Method in class org.apache.giraph.comm.netty.NettyClient
Whether master task is involved in the communication with a given client
masterJobStatePath - Variable in class org.apache.giraph.bsp.BspService
Path to the job state determined by the master (informative only)
MasterLoggingAggregator - Class in org.apache.giraph.utils
Helper class for using aggregator which gathers log messages from workers and prints them on master.
MasterObserver - Interface in org.apache.giraph.master
Observer for Master.
MasterProgress - Class in org.apache.giraph.master
Stores information about master progress
MasterProgress() - Constructor for class org.apache.giraph.master.MasterProgress
Public constructor for thrift to create us.
MasterRequest - Interface in org.apache.giraph.comm.requests
Interface for requests sent to master to extend
MasterRequestServerHandler - Class in org.apache.giraph.comm.netty.handler
Handler for requests on master
MasterRequestServerHandler(WorkerRequestReservedMap, ImmutableClassesGiraphConfiguration, TaskInfo, MasterGlobalCommHandler, Thread.UncaughtExceptionHandler, FlowControl) - Constructor for class org.apache.giraph.comm.netty.handler.MasterRequestServerHandler
Constructor
MasterRequestServerHandler.Factory - Class in org.apache.giraph.comm.netty.handler
MasterServer - Interface in org.apache.giraph.comm
Interface for master to receive messages from workers
MasterThread<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.master
Master thread that will coordinate the activities of the tasks.
MasterThread(CentralizedServiceMaster<I, V, E>, Mapper.Context) - Constructor for class org.apache.giraph.master.MasterThread
Constructor.
MathUtils - Class in org.apache.giraph.utils
A helper class for math related operations with writables
MatrixSumAggregator - Class in org.apache.giraph.aggregators.matrix
The abstract matrix aggregator contains the prefix name of the vector aggregators that have the values of the rows.
MatrixSumAggregator(String) - Constructor for class org.apache.giraph.aggregators.matrix.MatrixSumAggregator
Create a new matrix aggregator with the given prefix name for the vector aggregators.
max() - Method in class com.yammer.metrics.core.NoOpHistogram
 
max() - Method in class com.yammer.metrics.core.NoOpTimer
 
max - Variable in class org.apache.giraph.metrics.AggregatedMetric
Maximum value seen with the host that it came from
max() - Method in class org.apache.giraph.metrics.AggregatedMetric
Get maximum value together with host it came from.
MAX_ALLOWED_JOB_TIME_MS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum allowed time for job to run after getting all resources before it will be killed, in milliseconds (-1 if it has no limit)
MAX_ALLOWED_TIME_WITHOUT_PROGRESS_MS - Static variable in class org.apache.giraph.job.DefaultJobProgressTrackerService
Max time job is allowed to not make progress before getting killed
MAX_BYTES_PER_AGGREGATOR_REQUEST - Static variable in class org.apache.giraph.comm.aggregators.AggregatorUtils
How big a single aggregator request can be (in bytes)
MAX_BYTES_PER_AGGREGATOR_REQUEST_DEFAULT - Static variable in class org.apache.giraph.comm.aggregators.AggregatorUtils
Default max size of single aggregator request (1MB)
MAX_CONNECTION_MILLISECONDS_DEFAULT - Static variable in class org.apache.giraph.comm.netty.NettyClient
30 seconds to connect by default
MAX_COUNTER_WAIT_MSECS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum milliseconds to wait before giving up waiting for the workers to write the counters to the Zookeeper after a superstep
MAX_DESTINATION_TASK_IDS_TO_LIST - Static variable in class org.apache.giraph.comm.netty.NettyClient
Maximum number of destination task ids with open requests to list (for debugging)
MAX_EDGE_REQUEST_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum size of edges (in bytes) per peer before flush
MAX_EDGES_PER_TRANSFER - Static variable in class org.apache.giraph.graph.GiraphTransferRegulator
Maximum edges to read from an InputSplit locally that are to be routed to a remote worker, before sending them.
MAX_EDGES_PER_TRANSFER_DEFAULT - Static variable in class org.apache.giraph.graph.GiraphTransferRegulator
Default maximum number of vertices per temp partition before sending.
MAX_IPC_PORT_BIND_ATTEMPTS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum bind attempts for different IPC ports
MAX_MASTER_SUPERSTEP_WAIT_MSECS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum milliseconds to wait before giving up trying to get the minimum number of workers before a superstep (int).
MAX_MSG_REQUEST_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum size of messages (in bytes) per peer before flush
MAX_MUTATIONS_PER_REQUEST - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum number of mutations per partition before flush
MAX_NUM_OF_OPEN_REQUESTS_PER_WORKER - Static variable in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Maximum number of requests we can have per worker without confirmation (i.e.
MAX_NUM_OF_UNSENT_REQUESTS - Static variable in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Aggregate number of in-memory unsent requests
MAX_NUMBER_OF_OPEN_REQUESTS - Static variable in class org.apache.giraph.comm.flow_control.StaticFlowControl
Maximum number of requests without confirmation we should have
MAX_NUMBER_OF_SUPERSTEPS - Static variable in interface org.apache.giraph.conf.GiraphConstants
The application will halt after this many supersteps is completed.
MAX_OPEN_HASHSET_CAPACITY - Static variable in interface org.apache.giraph.types.ops.collections.BasicSet
Threshold for using OpenHashSet and OpenHashBigSet implementations.
MAX_PARTITIONS_IN_MEMORY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum number of partitions to hold in memory for each worker.
MAX_PRINTABLE_REMAINING_WORKERS - Static variable in class org.apache.giraph.master.BspServiceMaster
Print worker names only if there are 10 workers left
MAX_REQUEST_MILLISECONDS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Milliseconds for a request to complete (or else resend)
MAX_REQUESTS_TO_LIST - Static variable in class org.apache.giraph.comm.netty.NettyClient
Maximum number of requests to list (for debugging)
MAX_RESOLVE_ADDRESS_ATTEMPTS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Max resolve address attempts
MAX_SUPERSTEPS - Static variable in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable
Number of supersteps for this test
MAX_SUPERSTEPS - Static variable in class org.apache.giraph.examples.SimplePageRankComputation
Number of supersteps for this test
MAX_TASK_ATTEMPTS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum number of attempts a master/worker will retry before killing the job.
MAX_VERTEX_REQUEST_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum size of vertices (in bytes) per peer before flush
MAX_VERTICES_PER_TRANSFER - Static variable in class org.apache.giraph.graph.GiraphTransferRegulator
Maximum vertices to read from an InputSplit locally that are to be routed to a remote worker, before sending them.
MAX_VERTICES_PER_TRANSFER_DEFAULT - Static variable in class org.apache.giraph.graph.GiraphTransferRegulator
Default maximum number of vertices per temp partition before sending.
MAX_WORKERS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum number of simultaneous worker tasks started by this job (int).
MaxComputation - Class in org.apache.giraph.examples
Simple algorithm that computes the max value in the graph.
MaxComputation() - Constructor for class org.apache.giraph.examples.MaxComputation
 
MAXIMUM_THREAD_POOL_SIZE_DEFAULT - Static variable in class org.apache.giraph.comm.netty.NettyServer
Default maximum thread pool size
maxMemoryMB() - Static method in class org.apache.giraph.utils.MemoryUtils
Get maximum memory in megabytes
MaxMessageCombiner<M extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.combiner
Message combiner which calculates max of all messages.
MaxMessageCombiner(NumericTypeOps<M>) - Constructor for class org.apache.giraph.combiner.MaxMessageCombiner
Constructor
maxMessagesSizePerWorker - Variable in class org.apache.giraph.comm.SendMessageCache
Max message size sent to a worker
MaxPairReducer<L extends org.apache.hadoop.io.Writable,R extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.reducers.impl
Aggregating PairWritable<L, R>, by taking pair with largest second value.
MaxPairReducer() - Constructor for class org.apache.giraph.reducers.impl.MaxPairReducer
Constructor used for deserialization only
MaxPairReducer(TypeOps<L>, TypeOps<R>) - Constructor for class org.apache.giraph.reducers.impl.MaxPairReducer
Constructor
MaxReduce<T extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.reducers.impl
Reducer for calculating max of values
MaxReduce() - Constructor for class org.apache.giraph.reducers.impl.MaxReduce
Constructor used for deserialization only
MaxReduce(NumericTypeOps<T>) - Constructor for class org.apache.giraph.reducers.impl.MaxReduce
Constructor
mean() - Method in class com.yammer.metrics.core.NoOpHistogram
 
mean() - Method in class com.yammer.metrics.core.NoOpTimer
 
mean() - Method in class org.apache.giraph.metrics.AggregatedMetric
Get average of all the values
mean() - Method in class org.apache.giraph.metrics.AggregatedMetricDouble
 
mean() - Method in class org.apache.giraph.metrics.AggregatedMetricLong
 
meanRate() - Method in class com.yammer.metrics.core.NoOpMeter
 
meanRate() - Method in class com.yammer.metrics.core.NoOpTimer
 
MEGABYTE - Static variable in class org.apache.giraph.comm.netty.ByteCounterDelegate
Megabyte in bytes
MEMORY_FREE_PERCENT - Static variable in interface org.apache.giraph.metrics.MetricNames
PercentGauge of memory free
MEMORY_OBSERVER_DIR - Static variable in class org.apache.giraph.bsp.BspService
Memory observer dir
MemoryEstimatorOracle - Class in org.apache.giraph.ooc.policy
Implementation of OutOfCoreOracle that uses a linear regression model to estimate actual memory usage based on the current state of computation.
MemoryEstimatorOracle(ImmutableClassesGiraphConfiguration, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
Constructor.
MemoryObserver - Class in org.apache.giraph.worker
Memory observer to help synchronize when full gcs are happening across all the workers
MemoryObserver(ZooKeeperExt, String, GiraphConfiguration) - Constructor for class org.apache.giraph.worker.MemoryObserver
Constructor
memoryObserverPath - Variable in class org.apache.giraph.bsp.BspService
Path where memory observer stores data
MemoryUtils - Class in org.apache.giraph.utils
Helper static methods for tracking memory usage.
mergeCounters(Set<CustomCounter>) - Method in class org.apache.giraph.counters.CustomCounters
Merge the incoming counter values with the existing counters This will be called by the master when it gets all the counters from different workers, and needs to aggregate them.
MESSAGE_BYTES_SENT - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter of messages sent in superstep
MESSAGE_COMBINER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Message combiner class - optional
MESSAGE_ENCODE_AND_STORE_TYPE - Static variable in interface org.apache.giraph.conf.GiraphConstants
This option will tell which message encode & store enum to use when combining is not enabled
MESSAGE_ENCODE_AND_STORE_TYPE_MIN_FORCE - Static variable in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
This option will tell which message encode & store enum to force, when combining is not enabled.
MESSAGE_STORE_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Message Store Factory
messageAckReceived(int, long, int) - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
 
messageAckReceived(int, long, int) - Method in interface org.apache.giraph.comm.flow_control.FlowControl
Notify the flow control policy that an open request is completed.
messageAckReceived(int, long, int) - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
messageAckReceived(int, long, int) - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
messageBytes - Variable in class org.apache.giraph.utils.ByteStructVertexIdMessageBytesIterator
Number of bytes in the last message
MessageClasses<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.conf
Interface for containing all items that define message being sent, including it's value factory and combiner.
MessageCombiner<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.combiner
Abstract class to extend for combining messages sent to the same vertex.
MessageEncodeAndStoreType - Enum in org.apache.giraph.comm.messages
There are two types of message-stores currently pointer based, and default byte-array based
messageOffset - Variable in class org.apache.giraph.utils.ByteStructVertexIdMessageBytesIterator
Last message offset
messageReceived(int, long, int, boolean) - Method in class org.apache.giraph.comm.netty.NettyClient
Handle receipt of a message.
MESSAGES_SENT - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter of messages sent in superstep
MessagesIterable<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
Special iterable that recycles the message
MessagesIterable(Factory<? extends ExtendedDataInput>, MessageValueFactory<M>) - Constructor for class org.apache.giraph.comm.messages.MessagesIterable
Constructor
MessageStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.comm.messages
Message store
MessageStoreFactory<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable,MS> - Interface in org.apache.giraph.comm.messages
Factory for message stores
MessageValue() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.MessageValue
Constructor
MessageValue(Double) - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.MessageValue
Constructor
messageValueFactory - Variable in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
Message value factory
messageValueFactory - Variable in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
Message value factory
messageValueFactory - Variable in class org.apache.giraph.comm.messages.SimpleMessageStore
Message class
messageValueFactory - Variable in class org.apache.giraph.comm.SendMessageCache
Cached message value factory
MessageValueFactory<M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.factories
Factory class to create default message values.
MetaPartitionManager - Class in org.apache.giraph.ooc.data
Class to keep meta-information about partition data, edge data, and message data of each partition on a worker.
MetaPartitionManager(int, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.data.MetaPartitionManager
Constructor
MeterDesc - Enum in org.apache.giraph.metrics
Description for Meters used in Giraph.
MetricNames - Interface in org.apache.giraph.metrics
Class holding metric names used in Giraph
METRICS_DIR - Static variable in class org.apache.giraph.bsp.BspService
Metrics sub directory
METRICS_DIRECTORY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Directory in HDFS to write master metrics to, instead of stderr
METRICS_ENABLE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Enable the Metrics system
metricsEnabled() - Method in class org.apache.giraph.conf.GiraphConfiguration
Whether to track, print, and aggregate metrics.
MetricsRegistryDebugger - Class in org.apache.giraph.metrics
A simple MetricsRegistry listener that prints every Metric added/removed.
MetricsRegistryDebugger() - Constructor for class org.apache.giraph.metrics.MetricsRegistryDebugger
 
MigrationAbstractComputation<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.block_app.migration
Replacement for AbstractComputation when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationAbstractComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
MigrationAbstractComputation.MigrationBasicComputation<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.block_app.migration
Drop-in replacement for BasicComputation when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationAbstractComputation.MigrationFullAbstractComputation<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.block_app.migration
Drop-in replacement for AbstractComputation when migrating to Blocks Framework.
MigrationAbstractComputation.MigrationFullBasicComputation<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.block_app.migration
Drop-in replacement for BasicComputation when migrating to Blocks Framework.
MigrationBasicComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationBasicComputation
 
MigrationFullAbstractComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationFullAbstractComputation
 
MigrationFullBasicComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationFullBasicComputation
 
MigrationFullBlockFactory - Class in org.apache.giraph.block_app.migration
BlockFactory to extend when using drop-in migration
MigrationFullBlockFactory() - Constructor for class org.apache.giraph.block_app.migration.MigrationFullBlockFactory
 
MigrationFullMasterCompute() - Constructor for class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
MigrationFullWorkerContext() - Constructor for class org.apache.giraph.block_app.migration.MigrationWorkerContext.MigrationFullWorkerContext
 
MigrationMasterCompute - Class in org.apache.giraph.block_app.migration
Replacement for MasterCompute when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationMasterCompute() - Constructor for class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
MigrationMasterCompute.MigrationFullMasterCompute - Class in org.apache.giraph.block_app.migration
Drop-in replacement for MasterCompute when migrating to Blocks Framework.
MigrationPiece<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,MPrev extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.migration
Piece used when migrating applications to Blocks Framework.
MigrationSuperstepStage - Interface in org.apache.giraph.block_app.migration
Execution stage holding information about migration superstep.
MigrationSuperstepStageImpl - Class in org.apache.giraph.block_app.migration
Implementation of execution stage holding information about migration superstep.
MigrationSuperstepStageImpl() - Constructor for class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
MigrationSuperstepStageImpl(int) - Constructor for class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
MigrationWorkerContext - Class in org.apache.giraph.block_app.migration
Replacement for WorkerContext when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationWorkerContext() - Constructor for class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
MigrationWorkerContext.MigrationFullWorkerContext - Class in org.apache.giraph.block_app.migration
Drop-in replacement for WorkerContext when migrating to Blocks Framework.
min() - Method in class com.yammer.metrics.core.NoOpHistogram
 
min() - Method in class com.yammer.metrics.core.NoOpTimer
 
min - Variable in class org.apache.giraph.metrics.AggregatedMetric
Minimum value seen with the host that it came from
min() - Method in class org.apache.giraph.metrics.AggregatedMetric
Get minimum value together with host it came from.
MIN_BITS_TO_SHIFT - Static variable in class org.apache.giraph.utils.IncreasingBitSet
Minimum number of bits to shift
MIN_FREE_MBS_ON_HEAP - Static variable in interface org.apache.giraph.conf.GiraphConstants
Option used by ReactiveJMapHistoDumper to check for an imminent OOM in worker or master process
MIN_MS_BETWEEN_FULL_GCS - Static variable in class org.apache.giraph.worker.MemoryObserver
Minimum milliseconds between two manual gc calls
MIN_PARTITIONS_PER_COMPUTE_THREAD - Static variable in interface org.apache.giraph.conf.GiraphConstants
Minimum number of partitions to have per compute thread
MIN_PERCENT_RESPONDED - Static variable in interface org.apache.giraph.conf.GiraphConstants
Minimum percent of the maximum number of workers that have responded in order to continue progressing.
MIN_WORKERS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Minimum number of simultaneous workers before this job can run (int)
MINIMUM_BUFFER_SIZE_TO_FLUSH - Static variable in class org.apache.giraph.ooc.data.DiskBackedDataStore
Minimum size of a buffer (in bytes) to flush to disk.
MinimumDoubleMessageCombiner - Class in org.apache.giraph.combiner
MessageCombiner which finds the minimum of DoubleWritable.
MinimumDoubleMessageCombiner() - Constructor for class org.apache.giraph.combiner.MinimumDoubleMessageCombiner
 
MinimumIntMessageCombiner - Class in org.apache.giraph.combiner
MessageCombiner that finds the minimum IntWritable
MinimumIntMessageCombiner() - Constructor for class org.apache.giraph.combiner.MinimumIntMessageCombiner
 
MinMessageCombiner<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.combiner
Keeps only the message with minimum value.
MinMessageCombiner(NumericTypeOps<M>) - Constructor for class org.apache.giraph.combiner.MinMessageCombiner
Combiner
MinReduce<T extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.reducers.impl
Reducer for calculating min of values
MinReduce() - Constructor for class org.apache.giraph.reducers.impl.MinReduce
Constructor used for deserialization only
MinReduce(NumericTypeOps<T>) - Constructor for class org.apache.giraph.reducers.impl.MinReduce
Constructor
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.EachVertexInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in interface org.apache.giraph.block_app.test_setup.TestGraphModifier
 
moveEdgesToVertices() - Method in class org.apache.giraph.edge.AbstractEdgeStore
 
moveEdgesToVertices() - Method in interface org.apache.giraph.edge.EdgeStore
Move all edges from temporary storage to their source vertices.
moveEdgesToVertices() - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
MS_PER_DAY - Static variable in interface org.apache.giraph.time.Time
Milliseconds per day
MS_PER_HOUR - Static variable in interface org.apache.giraph.time.Time
Milliseconds per hour
MS_PER_SECOND - Static variable in interface org.apache.giraph.time.Time
Milliseconds per second
MS_PER_SECOND_AS_FLOAT - Static variable in interface org.apache.giraph.time.Time
Milliseconds per second (as float)
MSG_NUM_FLUSH_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of flush threads per peer
MultiEdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats.multi
Edge input format which wraps several edge input formats.
MultiEdgeInputFormat() - Constructor for class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
MultiInputUtils - Class in org.apache.giraph.io.formats.multi
Utility methods used by MultiVertexInputFormat and MultiEdgeInputFormat
MultiMappingInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats.multi
Mapping input format which wraps several mapping input formats.
MultiMappingInputFormat() - Constructor for class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
Default constructor.
multiply(int) - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
multiplyInto(ByteWritable, ByteWritable) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
multiplyInto(DoubleWritable, DoubleWritable) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
multiplyInto(FloatWritable, FloatWritable) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
multiplyInto(IntWritable, IntWritable) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
multiplyInto(LongWritable, LongWritable) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
multiplyInto(T, T) - Method in interface org.apache.giraph.types.ops.NumericTypeOps
value*=multiplier
MultiRandomAccessOutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Interface for OutEdges implementations that provide efficient random access to the edges given the target vertex id.
MultiSizedReusable<T> - Class in org.apache.giraph.object
Holds reusable objects of multiple sizes.
MultiSizedReusable(Int2ObjFunction<T>, Consumer<T>) - Constructor for class org.apache.giraph.object.MultiSizedReusable
 
MultiThreadedSuperstepOutput<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.superstep_output
Class to use as SuperstepOutput when chosen VertexOutputFormat is thread-safe.
MultiThreadedSuperstepOutput(ImmutableClassesGiraphConfiguration<I, V, E>, Mapper<?, ?, ?, ?>.Context) - Constructor for class org.apache.giraph.io.superstep_output.MultiThreadedSuperstepOutput
Constructor
MultiVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats.multi
Vertex input format which wraps several vertex input formats.
MultiVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
mustLoadCheckpoint() - Method in class org.apache.giraph.graph.FinishedSuperstepStats
Must load the checkpoint?
MutableEdge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
An edge whose value can be modified.
MutableEdgesIterable<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Helper class to provide a mutable iterable over the edges when the chosen OutEdges doesn't offer a specialized one.
MutableEdgesIterable(Vertex<I, ?, E>) - Constructor for class org.apache.giraph.edge.MutableEdgesIterable
Constructor.
MutableEdgesWrapper<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Helper class that wraps the current out-edges and inserts them into a new data structure as they are iterated over.
mutableIterator() - Method in class org.apache.giraph.edge.ArrayListEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.HashMapEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
mutableIterator() - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
mutableIterator() - Method in interface org.apache.giraph.edge.MutableOutEdges
Returns an iterator over edges that can be modified in-place, either by changing the current edge value or by removing the current edge.
MutableOutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Interface for OutEdges implementations that have an optimized mutable edge iterator.

N

needsTaskCommit(TaskAttemptContext) - Method in class org.apache.giraph.bsp.ImmutableOutputCommitter
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
 
negate(ByteWritable) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
negate(DoubleWritable) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
negate(FloatWritable) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
negate(IntWritable) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
negate(LongWritable) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
negate(T) - Method in interface org.apache.giraph.types.ops.NumericTypeOps
-value
NETTY_CLIENT_EXECUTION_AFTER_HANDLER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Where to place the netty client execution handle?
NETTY_CLIENT_EXECUTION_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty client execution threads (execution handler)
NETTY_CLIENT_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty client threads
NETTY_CLIENT_USE_EXECUTION_HANDLER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use the execution handler in netty on the client?
NETTY_COMPRESSION_ALGORITHM - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty - set which compression to use
NETTY_COUNTERS_GROUP - Static variable in class org.apache.giraph.comm.netty.NettyClient
Group name for netty counters
NETTY_MAX_CONNECTION_FAILURES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty max connection failures
NETTY_REQUEST_ENCODER_BUFFER_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
How big to make the encoder buffer?
NETTY_SERVER_EXECUTION_AFTER_HANDLER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Where to place the netty server execution handle?
NETTY_SERVER_EXECUTION_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty server execution threads (execution handler)
NETTY_SERVER_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty server threads
NETTY_SERVER_USE_EXECUTION_HANDLER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use the execution handler in netty on the server?
NETTY_SIMULATE_FIRST_REQUEST_CLOSED - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty simulate a first request closed
NETTY_SIMULATE_FIRST_RESPONSE_FAILED - Static variable in interface org.apache.giraph.conf.GiraphConstants
Netty simulate a first response failed
NETTY_USE_DIRECT_MEMORY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use direct memory buffers in netty
NETTY_USE_POOLED_ALLOCATOR - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use netty pooled memory buffer allocator
NettyClient - Class in org.apache.giraph.comm.netty
Netty client for sending requests.
NettyClient(Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration, TaskInfo, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyClient
Only constructor
NettyMasterClient - Class in org.apache.giraph.comm.netty
Netty implementation of MasterClient
NettyMasterClient(Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration, CentralizedServiceMaster<?, ?, ?>, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyMasterClient
Constructor
NettyMasterServer - Class in org.apache.giraph.comm.netty
Netty implementation of MasterServer
NettyMasterServer(ImmutableClassesGiraphConfiguration, CentralizedServiceMaster<?, ?, ?>, Progressable, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyMasterServer
Constructor
NettyServer - Class in org.apache.giraph.comm.netty
This server uses Netty and will implement all Giraph communication
NettyServer(ImmutableClassesGiraphConfiguration, RequestServerHandler.Factory, TaskInfo, Progressable, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyServer
Constructor for creating the server
NettyServer(ImmutableClassesGiraphConfiguration, RequestServerHandler.Factory, TaskInfo, Progressable, SaslServerHandler.Factory, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyServer
Constructor for creating the server
NettyWorkerAggregatorRequestProcessor - Class in org.apache.giraph.comm.netty
Netty implementation of WorkerAggregatorRequestProcessor
NettyWorkerAggregatorRequestProcessor(Progressable, ImmutableClassesGiraphConfiguration<?, ?, ?>, CentralizedServiceWorker<?, ?, ?>) - Constructor for class org.apache.giraph.comm.netty.NettyWorkerAggregatorRequestProcessor
Constructor.
NettyWorkerClient<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.netty
Takes users facing APIs in WorkerClient and implements them using the available WritableRequest objects.
NettyWorkerClient(Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, CentralizedServiceWorker<I, V, E>, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyWorkerClient
Only constructor.
NettyWorkerClientRequestProcessor<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.netty
Aggregate requests and sends them to the thread-safe NettyClient.
NettyWorkerClientRequestProcessor(Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, CentralizedServiceWorker<I, V, E>, boolean) - Constructor for class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
Constructor.
NettyWorkerServer<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.netty
Netty worker server that implement WorkerServer and contains the actual ServerData.
NettyWorkerServer(ImmutableClassesGiraphConfiguration<I, V, E>, CentralizedServiceWorker<I, V, E>, Mapper<?, ?, ?, ?>.Context, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.NettyWorkerServer
Constructor to start the server.
NETWORK_REQUESTS_RESENT_FOR_CHANNEL_FAILURE_NAME - Static variable in class org.apache.giraph.comm.netty.NettyClient
How many network requests were resent because channel failed
NETWORK_REQUESTS_RESENT_FOR_CONNECTION_FAILURE_NAME - Static variable in class org.apache.giraph.comm.netty.NettyClient
How many network requests were resent because connection failed
NETWORK_REQUESTS_RESENT_FOR_TIMEOUT_NAME - Static variable in class org.apache.giraph.comm.netty.NettyClient
How many network requests were resent because they took too long
NetworkMetrics - Interface in org.apache.giraph.comm
Interface for providing network statistics, such as bytes received etc.
NEVER - Static variable in class org.apache.giraph.aggregators.TextAggregatorWriter
Signal for "never write" frequency
NEW_GEN_MEMORY_FRACTION - Static variable in class org.apache.giraph.conf.FacebookConfiguration
Fraction of FacebookConfiguration.MAPPER_MEMORY to use for new generation
NEW_MAXIMUM - Static variable in class org.apache.giraph.examples.scc.SccPhaseMasterCompute
Flags whether a new maximum was found in the Forward Traversal phase
newCallable(int) - Method in interface org.apache.giraph.utils.CallableFactory
Create new callable
newCallable(int) - Method in class org.apache.giraph.worker.EdgeInputSplitsCallableFactory
 
newCallable(int) - Method in class org.apache.giraph.worker.MappingInputSplitsCallableFactory
 
newCallable(int) - Method in class org.apache.giraph.worker.VertexInputSplitsCallableFactory
 
newCounter(Class<?>, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newCounter(Class<?>, String, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newCounter(MetricName) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newFactory(CentralizedServiceWorker<I, ?, ?>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Static method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
Create new factory for this message store
newFactory(CentralizedServiceWorker<I, ?, ?>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Static method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
Create new factory for this message store
newGauge(Class<?>, String, Gauge<T>) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newGauge(Class<?>, String, String, Gauge<T>) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newGauge(MetricName, Gauge<T>) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newHandler(WorkerRequestReservedMap, ImmutableClassesGiraphConfiguration, TaskInfo, Thread.UncaughtExceptionHandler) - Method in class org.apache.giraph.comm.netty.handler.MasterRequestServerHandler.Factory
 
newHandler(WorkerRequestReservedMap, ImmutableClassesGiraphConfiguration, TaskInfo, Thread.UncaughtExceptionHandler) - Method in interface org.apache.giraph.comm.netty.handler.RequestServerHandler.Factory
newHandler(Configuration) - Method in class org.apache.giraph.comm.netty.handler.SaslServerHandler.Factory
newHandler(WorkerRequestReservedMap, ImmutableClassesGiraphConfiguration, TaskInfo, Thread.UncaughtExceptionHandler) - Method in class org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler.Factory
 
newHistogram(Class<?>, String, boolean) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newHistogram(Class<?>, String, String, boolean) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newHistogram(Class<?>, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newHistogram(Class<?>, String, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newHistogram(MetricName, boolean) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newInstance(Configuration) - Method in class org.apache.giraph.conf.ClassConfOption
Create a new instance
newInstance() - Method in class org.apache.giraph.factories.DefaultEdgeValueFactory
 
newInstance() - Method in class org.apache.giraph.factories.DefaultInputOutEdgesFactory
 
newInstance() - Method in class org.apache.giraph.factories.DefaultMessageValueFactory
 
newInstance() - Method in class org.apache.giraph.factories.DefaultOutEdgesFactory
 
newInstance() - Method in class org.apache.giraph.factories.DefaultVertexIdFactory
 
newInstance() - Method in class org.apache.giraph.factories.DefaultVertexValueFactory
 
newInstance() - Method in interface org.apache.giraph.factories.OutEdgesFactory
Creates a new instance.
newInstance() - Method in class org.apache.giraph.factories.TestMessageValueFactory
 
newInstance() - Method in interface org.apache.giraph.factories.ValueFactory
Create a new value.
newInstance(ImmutableClassesGiraphConfiguration) - Method in enum org.apache.giraph.graph.GraphType
Create a new instance of this value type from configuration
newInstance() - Method in class org.apache.giraph.jython.factories.JythonEdgeValueFactory
 
newInstance() - Method in class org.apache.giraph.jython.factories.JythonMessageValueFactory
 
newInstance() - Method in class org.apache.giraph.jython.factories.JythonVertexIdFactory
 
newInstance() - Method in class org.apache.giraph.jython.factories.JythonVertexValueFactory
 
newInstance(String) - Static method in class org.apache.giraph.jython.JythonUtils
Instantiate new instance of the Jython class
newInstance(String, Class<? extends T>) - Static method in class org.apache.giraph.jython.JythonUtils
Instantiate new instance of the Jython class
newInstance(Class<T>) - Static method in class org.apache.giraph.utils.ReflectionUtils
Instantiate a class, wrap exceptions
newInstance(Class<T>, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.ReflectionUtils
Instantiate classes that are ImmutableClassesGiraphConfigurable
newInstance(Class<T>, ImmutableClassesGiraphConfiguration, Mapper<?, ?, ?, ?>.Context) - Static method in class org.apache.giraph.utils.ReflectionUtils
Instantiate classes that are ImmutableClassesGiraphConfigurable, and optionally set context on them if they are ContextSettable
newJythonClassInstance() - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
Instantiate a new value Jython object.
newMeter(Class<?>, String, String, TimeUnit) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newMeter(Class<?>, String, String, String, TimeUnit) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newMeter(MetricName, String, TimeUnit) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newMetricsMap() - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newScheduledThreadPool(int, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newStore(MessageClasses<I, M>) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore.Factory
 
newStore(MessageClasses<I, M>) - Method in class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
 
newStore(MessageClasses<I, M>) - Method in interface org.apache.giraph.comm.messages.MessageStoreFactory
Creates new message store.
newStore() - Method in interface org.apache.giraph.edge.EdgeStoreFactory
Creates new edge store.
newStore() - Method in class org.apache.giraph.edge.InMemoryEdgeStoreFactory
 
newStoreWithCombiner(Class<M>, MessageValueFactory<M>, MessageCombiner<? super I, M>) - Method in class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
MessageStore to be used when combiner is enabled
newStoreWithoutCombiner(Class<M>, MessageValueFactory<M>, MessageEncodeAndStoreType) - Method in class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
MessageStore to be used when combiner is not enabled
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Called by Inbound/ Outbound counters to refresh meters on a new superstep
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.graph.GraphTaskManager
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.master.BspServiceMaster
 
newSuperstep(SuperstepMetricsRegistry) - Method in interface org.apache.giraph.metrics.ResetSuperstepMetricsObserver
Starting a new superstep.
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.ooc.OutOfCoreIOCallable
 
newSuperstep(SuperstepMetricsRegistry) - Method in class org.apache.giraph.worker.BspServiceWorker
 
newThreadAggregatorUsage() - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
Create new aggregator usage which will be used by one of the compute threads.
newTimer(Class<?>, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newTimer(Class<?>, String, TimeUnit, TimeUnit) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newTimer(Class<?>, String, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newTimer(Class<?>, String, String, TimeUnit, TimeUnit) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
newTimer(MetricName, TimeUnit, TimeUnit) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
next() - Method in class org.apache.giraph.comm.SendMessageCache.TargetVertexIdIterator
 
next() - Method in class org.apache.giraph.utils.ByteStructIterator
 
next() - Method in class org.apache.giraph.utils.ByteStructVertexIdDataIterator
 
next() - Method in class org.apache.giraph.utils.ByteStructVertexIdMessageBytesIterator
Moves to the next element in the iteration.
next() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
next() - Method in class org.apache.giraph.utils.PairList.Iterator
Moves to the next element in the iteration.
next() - Method in class org.apache.giraph.utils.RepresentativeByteStructIterator
 
next() - Method in interface org.apache.giraph.utils.VertexIdIterator
Moves to the next element in the iteration.
next() - Method in class org.apache.giraph.utils.VertexIterator
Moves to the next element in the iteration.
nextChannel() - Method in class org.apache.giraph.comm.netty.ChannelRotater
Get the next channel
nextDouble() - Method in class org.apache.giraph.writable.kryo.TransientRandom
Returns the next pseudorandom, uniformly distributed double value between 0.0 and 1.0 from this random number generator's sequence.
nextEdge() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeReader
 
nextEdge() - Method in class org.apache.giraph.io.EdgeReader
Read the next edge.
nextEdge() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
 
nextEdge() - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
 
nextEdge() - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
nextEdge() - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
nextEdge() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
 
nextEntry() - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
nextEntry() - Method in class org.apache.giraph.io.iterables.MappingReaderWrapper
 
nextEntry() - Method in class org.apache.giraph.io.MappingReader
 
nextExecutionStage() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
nextExecutionStage(S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to provide different next execution stage for Pieces that come after it.
nextExecutionStage(S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
nextExecutionStage(IterationStage) - Method in class org.apache.giraph.block_app.library.iteration.IterationCounterPiece
 
nextExecutionStage(MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
nextInt(int) - Method in class org.apache.giraph.writable.kryo.TransientRandom
Returns a pseudorandom, uniformly distributed int value between 0 (inclusive) and the specified value (exclusive), drawn from this random number generator's sequence.
nextObject() - Method in class org.apache.giraph.io.iterables.IteratorToReaderWrapper
Read next object
nextVertex() - Method in class org.apache.giraph.examples.AggregatorsTestComputation.SimpleVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat.LongDoubleDoubleDoubleVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.LongDoubleFloatTextInputFormat.LongDoubleFloatVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.LongDoubleNullTextInputFormat.LongDoubleNullDoubleVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat.NormalizingLongDoubleDoubleDoubleVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexReader
 
nextVertex() - Method in class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexReader
 
nextVertex() - Method in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader
 
nextVertex() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLine
 
nextVertex() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
 
nextVertex() - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
 
nextVertex() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
 
nextVertex() - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
 
nextVertex() - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
nextVertex() - Method in class org.apache.giraph.io.iterables.VertexReaderWrapper
 
nextVertex() - Method in class org.apache.giraph.io.VertexReader
 
NO_PARTITION_TO_PROCESS - Static variable in class org.apache.giraph.ooc.data.MetaPartitionManager
Flag representing no partitions is left to process in the current iteration cycle over all partitions.
NoEdgeValue() - Constructor for class org.apache.giraph.mapping.translate.LongByteTranslateEdge.NoEdgeValue
 
NoMessage - Class in org.apache.giraph.types
Type marking that in a particular superstep there will not be sent messages.
NoMessage() - Constructor for class org.apache.giraph.types.NoMessage
 
NonKryoWritable - Interface in org.apache.giraph.writable.kryo.markers
Marker interface saying that class should never be serialized, that it is code error for it to be tried to be serialized.
NoOpCounter - Class in com.yammer.metrics.core
A Metrics Counter implementation that does nothing
NoOpExecutorService - Class in com.yammer.metrics.core
An executor service that does nothing.
NoOpExecutorService() - Constructor for class com.yammer.metrics.core.NoOpExecutorService
 
NoOpFlowControl - Class in org.apache.giraph.comm.flow_control
Representation of a flow control policy that does not do anything other than the vanilla network client request transfer mechanism
NoOpFlowControl(NettyClient) - Constructor for class org.apache.giraph.comm.flow_control.NoOpFlowControl
Constructor
NoOpGuage<T> - Class in com.yammer.metrics.core
A Metrics Gauge implementation that always returns null.
NoOpGuage() - Constructor for class com.yammer.metrics.core.NoOpGuage
do not instantiate
NoOpHistogram - Class in com.yammer.metrics.core
An empty Metrics' Histogram that does nothing.
NoOpMeter - Class in com.yammer.metrics.core
An empty Metrics' Meter implementation that does nothing.
NoOpMetricsRegistry - Class in org.apache.giraph.metrics
An empty MetricsRegistry, used to easily turn off all metrics without affecting client code.
NoOpMetricsRegistry() - Constructor for class org.apache.giraph.metrics.NoOpMetricsRegistry
 
NoOpSuperstepOutput<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.superstep_output
Class to use as SuperstepOutput when we don't have output during computation.
NoOpSuperstepOutput() - Constructor for class org.apache.giraph.io.superstep_output.NoOpSuperstepOutput
 
NoOpTimer - Class in com.yammer.metrics.core
An empty Metrics' Timer implementation that does nothing.
NORMAL_FREE_MEMORY_FRACTION - Static variable in class org.apache.giraph.job.CombinedWorkerProgress
If free memory fraction on some worker goes below this value, warning will be printed
NormalizingLongDoubleDoubleDoubleVertexReader() - Constructor for class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat.NormalizingLongDoubleDoubleDoubleVertexReader
 
NormalizingLongDoubleDoubleTextInputFormat - Class in org.apache.giraph.examples
Simple text-based VertexInputFormat for unweighted graphs with long ids.
NormalizingLongDoubleDoubleTextInputFormat() - Constructor for class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat
 
NormalizingLongDoubleDoubleTextInputFormat.NormalizingLongDoubleDoubleDoubleVertexReader - Class in org.apache.giraph.examples
Vertex reader associated with LongDoubleDoubleTextInputFormat.
Notifier<T> - Interface in org.apache.giraph.function
Allows consumer to subscribe to a supplier.
NOTIFY - Static variable in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
Bracha-Toueg NOTICE message.
notifyFinishedCommunication() - Method in class org.apache.giraph.graph.GraphTaskManager
Notification of last message flushed.
notifySentMessages() - Method in class org.apache.giraph.graph.GraphTaskManager
Notification from Vertex that a message has been sent.
NS_PER_MS - Static variable in interface org.apache.giraph.time.Time
Nanoseconds per millisecond
NS_PER_SECOND - Static variable in interface org.apache.giraph.time.Time
Nanoseconds per second
NS_PER_SECOND_AS_FLOAT - Static variable in interface org.apache.giraph.time.Time
Nanoseconds per second (as float)
NS_PER_US - Static variable in interface org.apache.giraph.time.Time
Nanoseconds per microsecond
NullMessageCombiner - Class in org.apache.giraph.combiner
Keeps only one NullMessage.
NullMessageCombiner() - Constructor for class org.apache.giraph.combiner.NullMessageCombiner
 
nullSupplier() - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
 
NUM_BYTES_PER_MESSAGE - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
How many bytes per message
NUM_CHECKPOINT_IO_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of threads for writing and reading checkpoints
NUM_COMMUNITIES - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
NUM_COMPUTE_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of threads for vertex computation
NUM_COMPUTE_THREADS - Static variable in class org.apache.giraph.examples.TestComputationStateComputation
How many compute threads to use in the test
NUM_EDGE_INPUT_FILES - Static variable in class org.apache.giraph.io.formats.GiraphFileInputFormat
Number of edge input files.
NUM_EDGES_PER_VERTEX - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
NUM_INPUT_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of threads for input split loading
NUM_MASTER_ZK_INPUT_SPLIT_THREADS - Static variable in class org.apache.giraph.master.BspServiceMaster
How many threads to use when writing input splits to zookeeper
NUM_MESSAGES_PER_EDGE - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
How many messages per edge
NUM_OUT_OF_CORE_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of IO threads used in out-of-core mechanism.
NUM_OUTPUT_THREADS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of threads for writing output in the end of the application
NUM_PARTITIONS - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Number of vertex partitions
NUM_PARTITIONS - Static variable in class org.apache.giraph.examples.TestComputationStateComputation
How many partitions to have
NUM_THREADS - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Number of threads to use
NUM_VERTEX_INPUT_FILES - Static variable in class org.apache.giraph.io.formats.GiraphFileInputFormat
Number of vertex input files.
NUM_VERTICES - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
NUM_VERTICES - Static variable in class org.apache.giraph.examples.TestComputationStateComputation
How many vertices to create for the test
numberToEdgeValue(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
numberToVertexId(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
numberToVertexValue(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
numBytesTransferred - Variable in class org.apache.giraph.ooc.command.IOCommand
Number of bytes transferred to/from memory (loaded/stored) during the execution of the command
NumericTestGraph<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup
Wraps TestGraph to allow using numbers to create and inspect the graph, instead of needing to have actual Writable values, which don't have auto-boxing.
NumericTestGraph(TestGraph<I, V, E>) - Constructor for class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
NumericTestGraph(GiraphConfiguration) - Constructor for class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
NumericTypeOps<T> - Interface in org.apache.giraph.types.ops
Numeric type operations, allowing working generically with types, but still having efficient code.
numSources() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 

O

Obj2BooleanFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> boolean
Obj2ByteFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> byte
Obj2DoubleFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> double
Obj2FloatFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> float
Obj2IntFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> int
Obj2LongFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> long
Obj2ShortFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (T) -> short
ObjectHolder<T> - Class in org.apache.giraph.function
Default object holder, intermediary between producers and consumers.
ObjectHolder(T) - Constructor for class org.apache.giraph.function.ObjectHolder
Constructor
ObjectHolder() - Constructor for class org.apache.giraph.function.ObjectHolder
Constructor
ObjectMessageClasses<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.messages
MessageClasses implementation that provides factory and combiner instances through a provided supplier.
ObjectMessageClasses() - Constructor for class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
ObjectMessageClasses(Class<M>, SupplierFromConf<MessageValueFactory<M>>, SupplierFromConf<? extends MessageCombiner<? super I, M>>, MessageEncodeAndStoreType, boolean) - Constructor for class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
ObjectNotifier<T> - Class in org.apache.giraph.function
Allows multiple Consumers to be combined into a single Consumer, by having them all subscribe to this object, and then using this object as a group Consumer.
ObjectNotifier() - Constructor for class org.apache.giraph.function.ObjectNotifier
 
ObjectTransfer<T> - Class in org.apache.giraph.function
Default object transfer, intermediary between producers and consumers.
ObjectTransfer(T) - Constructor for class org.apache.giraph.function.ObjectTransfer
Constructor
ObjectTransfer() - Constructor for class org.apache.giraph.function.ObjectTransfer
Constructor
ObjRef(O) - Constructor for class org.apache.giraph.function.primitive.PrimitiveRefs.ObjRef
Constructor
of(L, R) - Static method in class org.apache.giraph.writable.tuple.PairWritable
Obtains an immutable pair of from two objects inferring the generic types.
offer(T) - Method in class org.apache.giraph.utils.BlockingElementsSet
Put an element in the set
offlineZooKeeperServers(ZooKeeperManager.State) - Method in class org.apache.giraph.zk.ZooKeeperManager
Notify the ZooKeeper servers that this partition is done with all ZooKeeper communication.
offloadBuffers(int) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Offloads raw data buffers of a given partition to disk, and returns the number of bytes offloaded from memory to disk.
offloadBuffers(int) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
offloadBuffers(int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
offloadBuffers(int) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
offloadBuffersProxy(int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
The proxy method that does the actual operation for `offloadBuffers`, but uses the data index given by the caller.
offloadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Offloads data of a partition in data store to disk.
offloadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
offloadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
offloadInMemoryPartitionData(int, int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
offloadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Offloads partition data of a given partition in the data store to disk, and returns the number of bytes offloaded from memory to disk.
offloadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
offloadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
offloadPartitionData(int) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
offloadPartitionDataProxy(int, DataIndex) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
The proxy method that does the actual operation for `offloadPartitionData`, but uses the data index given by the caller.
ONE_KB - Static variable in interface org.apache.giraph.conf.GiraphConstants
1KB in bytes
ONE_MB - Static variable in interface org.apache.giraph.conf.GiraphConstants
1MB in bytes
OneMessagePerVertexStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
Implementation of SimpleMessageStore where we have a single message per vertex.
OneMessagePerVertexStore(MessageValueFactory<M>, PartitionSplitInfo<I>, MessageCombiner<? super I, M>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
oneMessageToManyIds - Variable in class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
ByteArrayOneMessageToManyIds encoding of vertexId & messages
OneMessageToManyIdsIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
VertexIdData iterator for ByteArrayOneMessageToManyIds
OneMessageToManyIdsIterator(ByteArrayOneMessageToManyIds<I, M>) - Constructor for class org.apache.giraph.utils.OneMessageToManyIdsIterator
Constructor
oneMinuteRate() - Method in class com.yammer.metrics.core.NoOpMeter
 
oneMinuteRate() - Method in class com.yammer.metrics.core.NoOpTimer
 
onlineZooKeeperServer() - Method in class org.apache.giraph.zk.ZooKeeperManager
If this task has been selected, online a ZooKeeper server.
OnlyIdVertex<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.graph
Vertex which only contains ID.
OnlyIdVertex() - Constructor for class org.apache.giraph.graph.OnlyIdVertex
 
onMetricAdded(MetricName, Metric) - Method in class org.apache.giraph.metrics.MetricsRegistryDebugger
 
onMetricRemoved(MetricName) - Method in class org.apache.giraph.metrics.MetricsRegistryDebugger
 
OOC_BYTES_LOADED_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate bytes loaded from local disks in out-of-core
OOC_BYTES_STORED_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate bytes stored to local disks in out-of-core
OOC_DISK_BUFFER_SIZE - Static variable in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
Size of the buffer used for (de)serializing data when reading/writing from/to disk
OOC_THRESHOLD - Static variable in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
OOC starts if mem-usage is above this threshold
OOC_WAIT_INTERVAL - Static variable in class org.apache.giraph.ooc.OutOfCoreIOScheduler
If an IO thread does not have any command to do, it waits for certain a period and check back again to see if there exist any command to perform.
oocEngine - Variable in class org.apache.giraph.ooc.command.IOCommand
Out-of-core engine
oocEngine - Variable in class org.apache.giraph.ooc.data.DiskBackedDataStore
Out-of-core engine
openConnections() - Method in interface org.apache.giraph.comm.MasterClient
Make sure that all the connections to workers have been established.
openConnections() - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
openConnections() - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
openConnections() - Method in interface org.apache.giraph.comm.WorkerClient
Make sure that all the connections to workers and master have been established.
OPTIMAL_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
The optimal memory pressure at which GC behavior is close to ideal.
OPTIMAL_MEMORY_PRESSURE - Static variable in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
The memory pressure at which we expect GC to perform optimally for a memory intensive job.
optionTurnedOn(CommandLine) - Method in class org.apache.giraph.benchmark.BenchmarkOption
Check if the option is present in CommandLine
org.apache.giraph - package org.apache.giraph
Base giraph package.
org.apache.giraph.aggregators - package org.apache.giraph.aggregators
Package of Giraph aggregators.
org.apache.giraph.aggregators.matrix - package org.apache.giraph.aggregators.matrix
Package of matrix aggregator.
org.apache.giraph.aggregators.matrix.dense - package org.apache.giraph.aggregators.matrix.dense
Package of dense matrix aggregator.
org.apache.giraph.aggregators.matrix.sparse - package org.apache.giraph.aggregators.matrix.sparse
Package of sparce matrix aggregator.
org.apache.giraph.benchmark - package org.apache.giraph.benchmark
Package of benchmarks for performance testing and optimization
org.apache.giraph.block_app.framework - package org.apache.giraph.block_app.framework
Block application abstraction package.
org.apache.giraph.block_app.framework.api - package org.apache.giraph.block_app.framework.api
Interfaces representing full API to the underlying graph processing system.
org.apache.giraph.block_app.framework.api.giraph - package org.apache.giraph.block_app.framework.api.giraph
Giraph implementation of graph processing system API used by Blocks Framework.
org.apache.giraph.block_app.framework.api.local - package org.apache.giraph.block_app.framework.api.local
Local (single machine) implementation of graph processing system API used by Blocks Framework.
org.apache.giraph.block_app.framework.block - package org.apache.giraph.block_app.framework.block
Block interface as a composable unit of execution, and its common implementations.
org.apache.giraph.block_app.framework.internal - package org.apache.giraph.block_app.framework.internal
Implementation of execution logic, guiding internal execution of Block Application.
org.apache.giraph.block_app.framework.output - package org.apache.giraph.block_app.framework.output
Multi-output support for Block Applications
org.apache.giraph.block_app.framework.piece - package org.apache.giraph.block_app.framework.piece
Single execution object - Piece, and related classes.
org.apache.giraph.block_app.framework.piece.delegate - package org.apache.giraph.block_app.framework.piece.delegate
Pieces that delegate their work to a set of one or multiple other Pieces.
org.apache.giraph.block_app.framework.piece.global_comm - package org.apache.giraph.block_app.framework.piece.global_comm
Interfaces for Reducer and Broadcast Handles for automatic handling of global communication within Pieces, hiding a lot of it's complexities.
org.apache.giraph.block_app.framework.piece.global_comm.array - package org.apache.giraph.block_app.framework.piece.global_comm.array
Interfaces representing arrays of individual handles.
org.apache.giraph.block_app.framework.piece.global_comm.internal - package org.apache.giraph.block_app.framework.piece.global_comm.internal
Reducer and Broadcast Handles internal implementation for automatic handling of global communication within Pieces, hiding a lot of it's complexities.
org.apache.giraph.block_app.framework.piece.global_comm.map - package org.apache.giraph.block_app.framework.piece.global_comm.map
Interfaces representing map of individual handles
org.apache.giraph.block_app.framework.piece.interfaces - package org.apache.giraph.block_app.framework.piece.interfaces
Vertex processing functions for Pieces
org.apache.giraph.block_app.framework.piece.messages - package org.apache.giraph.block_app.framework.piece.messages
Utility classes for handling of messages within Pieces
org.apache.giraph.block_app.library - package org.apache.giraph.block_app.library
Core library of Pieces and Suppliers, providing most common usages.
org.apache.giraph.block_app.library.gc - package org.apache.giraph.block_app.library.gc
GC utility pieces.
org.apache.giraph.block_app.library.internal - package org.apache.giraph.block_app.library.internal
Internal implementation of Pieces needed for Pieces utility class.
org.apache.giraph.block_app.library.iteration - package org.apache.giraph.block_app.library.iteration
Utilities for having iteration within execution stage object.
org.apache.giraph.block_app.library.striping - package org.apache.giraph.block_app.library.striping
Utilities for striping.
org.apache.giraph.block_app.migration - package org.apache.giraph.block_app.migration
Migration utility for transforming standard Giraph applications, into Block Applications.
org.apache.giraph.block_app.reducers - package org.apache.giraph.block_app.reducers
Common reducer utilities for Block Applications
org.apache.giraph.block_app.reducers.array - package org.apache.giraph.block_app.reducers.array
Reducers for collecting arrays of objects.
org.apache.giraph.block_app.reducers.collect - package org.apache.giraph.block_app.reducers.collect
Reducers for distributed collection of objects.
org.apache.giraph.block_app.reducers.map - package org.apache.giraph.block_app.reducers.map
Reducers for collecting map of objects.
org.apache.giraph.block_app.test_setup - package org.apache.giraph.block_app.test_setup
Utilities for unit tests.
org.apache.giraph.block_app.test_setup.graphs - package org.apache.giraph.block_app.test_setup.graphs
Common Graphs for unit tests.
org.apache.giraph.bsp - package org.apache.giraph.bsp
Package of generic bulk synchronous processing objects.
org.apache.giraph.bsp.checkpoints - package org.apache.giraph.bsp.checkpoints
Package of generic bulk synchronous processing objects.
org.apache.giraph.combiner - package org.apache.giraph.combiner
Package of Combiners.
org.apache.giraph.comm - package org.apache.giraph.comm
Package of communication related objects, IPC service.
org.apache.giraph.comm.aggregators - package org.apache.giraph.comm.aggregators
Package for classes which are used to handle aggregators.
org.apache.giraph.comm.flow_control - package org.apache.giraph.comm.flow_control
Package for flow-control policies.
org.apache.giraph.comm.messages - package org.apache.giraph.comm.messages
Package of classes for storing messages.
org.apache.giraph.comm.messages.primitives - package org.apache.giraph.comm.messages.primitives
Package of message stores specialized for a certain type of vertex ids, messages and combiner.
org.apache.giraph.comm.messages.primitives.long_id - package org.apache.giraph.comm.messages.primitives.long_id
Message store based off of primitives when I = LongWritable
org.apache.giraph.comm.messages.queue - package org.apache.giraph.comm.messages.queue
Package for message store queue, that decouples netty threads from threads processing messages.
org.apache.giraph.comm.netty - package org.apache.giraph.comm.netty
Package for netty implementations.
org.apache.giraph.comm.netty.handler - package org.apache.giraph.comm.netty.handler
Package for classes which handle requests and responses.
org.apache.giraph.comm.requests - package org.apache.giraph.comm.requests
Package for requests.
org.apache.giraph.conf - package org.apache.giraph.conf
Package of Giraph configuration related things.
org.apache.giraph.counters - package org.apache.giraph.counters
Package of all the Giraph Hadoop counters related data.
org.apache.giraph.edge - package org.apache.giraph.edge
Package of Vertex implementations.
org.apache.giraph.edge.primitives - package org.apache.giraph.edge.primitives
Package of edge stores specialized for certain type of vertex ids.
org.apache.giraph.examples - package org.apache.giraph.examples
Package of Giraph examples.
org.apache.giraph.examples.block_app - package org.apache.giraph.examples.block_app
Package of Giraph examples for Block Applications.
org.apache.giraph.examples.io.formats - package org.apache.giraph.examples.io.formats
IO classes for Giraph examples.
org.apache.giraph.examples.scc - package org.apache.giraph.examples.scc
Classes for Strongly Connected Components computation.
org.apache.giraph.examples.utils - package org.apache.giraph.examples.utils
Utils for Giraph examples.
org.apache.giraph.factories - package org.apache.giraph.factories
Package of factories for creating types, for example the user's graph types.
org.apache.giraph.function - package org.apache.giraph.function
Package for interfaces representing different functions, that all extends Serializable in order for Kryo to be able to serialize them.
org.apache.giraph.function.primitive - package org.apache.giraph.function.primitive
Primitive specializations of interfaces from org.apache.giraph.function package.
org.apache.giraph.function.primitive.pairs - package org.apache.giraph.function.primitive.pairs
Primitive specializations of PairConsumer and PairPredicate
org.apache.giraph.function.vertex - package org.apache.giraph.function.vertex
Package for interfaces representing functions additionally performed on vertex values.
org.apache.giraph.graph - package org.apache.giraph.graph
Package of all the graph related objects, built on the org.apache.bsp package.
org.apache.giraph.io - package org.apache.giraph.io
Input/Output related things.
org.apache.giraph.io.filters - package org.apache.giraph.io.filters
Input/Output filters.
org.apache.giraph.io.formats - package org.apache.giraph.io.formats
Package of reusable library Giraph objects.
org.apache.giraph.io.formats.multi - package org.apache.giraph.io.formats.multi
Package for Input formats which wrap several input formats and allow reading data from multiple sources.
org.apache.giraph.io.internal - package org.apache.giraph.io.internal
Input/Output classes for internal use only.
org.apache.giraph.io.iterables - package org.apache.giraph.io.iterables
Iterable wrappers for IO readers/writers
org.apache.giraph.io.superstep_output - package org.apache.giraph.io.superstep_output
Classes related to output during computation
org.apache.giraph.job - package org.apache.giraph.job
Package of all the classes involved in job launch.
org.apache.giraph.jython - package org.apache.giraph.jython
Jython integration.
org.apache.giraph.jython.factories - package org.apache.giraph.jython.factories
Jython factories.
org.apache.giraph.jython.wrappers - package org.apache.giraph.jython.wrappers
Wrappers for Jython types.
org.apache.giraph.mapping - package org.apache.giraph.mapping
Package contains definition and implementations of MappingStore and related concepts
org.apache.giraph.mapping.translate - package org.apache.giraph.mapping.translate
Definitions & sample implementations of edge translation logic
org.apache.giraph.master - package org.apache.giraph.master
Package of all the master related things.
org.apache.giraph.master.input - package org.apache.giraph.master.input
Input related master classes
org.apache.giraph.metrics - package org.apache.giraph.metrics
Package of all the Giraph metrics related data.
org.apache.giraph.object - package org.apache.giraph.object
Object handling related utilities.
org.apache.giraph.ooc - package org.apache.giraph.ooc
Package of out-of-core related classes.
org.apache.giraph.ooc.command - package org.apache.giraph.ooc.command
Package of classes related to IO commands in out-of-core mechanism
org.apache.giraph.ooc.data - package org.apache.giraph.ooc.data
Package of classes related to data structures used for an out-of-core mechanism
org.apache.giraph.ooc.persistence - package org.apache.giraph.ooc.persistence
Package of classes related to IO abstraction or persistence layer used for out-of-core mechanism
org.apache.giraph.ooc.policy - package org.apache.giraph.ooc.policy
Package of classes related to out-of-core policy
org.apache.giraph.partition - package org.apache.giraph.partition
Package of partitioning related objects.
org.apache.giraph.reducers - package org.apache.giraph.reducers
Package of Giraph reducers.
org.apache.giraph.reducers.impl - package org.apache.giraph.reducers.impl
Package of Giraph reducers.
org.apache.giraph.scripting - package org.apache.giraph.scripting
Scripting with Giraph.
org.apache.giraph.time - package org.apache.giraph.time
Time related things.
org.apache.giraph.types - package org.apache.giraph.types
Type coercion, inference, and reflection.
org.apache.giraph.types.heaps - package org.apache.giraph.types.heaps
Heaps for different types
org.apache.giraph.types.ops - package org.apache.giraph.types.ops
Type coercion, inference, and reflection.
org.apache.giraph.types.ops.collections - package org.apache.giraph.types.ops.collections
Collection interfaces and implementations provided by TypeOps classes.
org.apache.giraph.types.ops.collections.array - package org.apache.giraph.types.ops.collections.array
WArrayList interfaces and implementations that extend fastutil classes, and are provided by TypeOps classes.
org.apache.giraph.utils - package org.apache.giraph.utils
Package of all generic utility classes.
org.apache.giraph.utils.hashing - package org.apache.giraph.utils.hashing
Package of utility classes supporting strong hash functions (currently from Guava).
org.apache.giraph.utils.io - package org.apache.giraph.utils.io
Package of utility classes which add the functionality to the ones from java.io package.
org.apache.giraph.worker - package org.apache.giraph.worker
Package of all the worker related things
org.apache.giraph.writable.kryo - package org.apache.giraph.writable.kryo
Utilities for using Kryo to efficiently serialize objects, and integrate with Writable interface.
org.apache.giraph.writable.kryo.markers - package org.apache.giraph.writable.kryo.markers
Marker interfaces used by HadoopKryo to special-case serialization.
org.apache.giraph.writable.kryo.serializers - package org.apache.giraph.writable.kryo.serializers
Implementations of custom serializers needed for HadoopKryo
org.apache.giraph.writable.tuple - package org.apache.giraph.writable.tuple
Writable tuple utilities
org.apache.giraph.yarn - package org.apache.giraph.yarn
Catch all package for YARN-specific code.
org.apache.giraph.zk - package org.apache.giraph.zk
Package of ZooKeeper related objects.
OrReduce - Class in org.apache.giraph.reducers.impl
ReduceOperation for calculating the OR function over boolean values.
OrReduce() - Constructor for class org.apache.giraph.reducers.impl.OrReduce
 
OUT_OF_CORE_DATA_ACCESSOR - Static variable in interface org.apache.giraph.conf.GiraphConstants
Data accessor resource/object
OUT_OF_CORE_ORACLE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Out-of-core oracle that is to be used for adaptive out-of-core engine.
OutboundByteCounter - Class in org.apache.giraph.comm.netty
Keep track of the bytes sent and provide some metrics when desired as part of the Netty Channel stack.
OutboundByteCounter() - Constructor for class org.apache.giraph.comm.netty.OutboundByteCounter
Constructor
OutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Interface for data structures that store out-edges for a vertex.
outEdgesClass - Variable in class org.apache.giraph.conf.GiraphClasses
Vertex edges class - cached for fast access
OutEdgesFactory<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.factories
Factory interface for creating OutEdges instances.
OUTGOING_MESSAGE_VALUE_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Outgoing message value class
OUTGOING_MESSAGE_VALUE_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Outgoing message value factory class - optional
outgoingMessageClasses - Variable in class org.apache.giraph.conf.GiraphClasses
Outgoing message classes
OutOfCoreDataAccessor - Interface in org.apache.giraph.ooc.persistence
Interface representing data accessor object (DAO) used as persistence layer in out-of-core mechanism.
OutOfCoreDataAccessor.DataInputWrapper - Interface in org.apache.giraph.ooc.persistence
Interface to wrap DataInput
OutOfCoreDataAccessor.DataOutputWrapper - Interface in org.apache.giraph.ooc.persistence
Interface to warp DataOutput
OutOfCoreEngine - Class in org.apache.giraph.ooc
Class to represent an out-of-core engine.
OutOfCoreEngine(ImmutableClassesGiraphConfiguration<?, ?, ?>, CentralizedServiceWorker<?, ?, ?>, NetworkMetrics) - Constructor for class org.apache.giraph.ooc.OutOfCoreEngine
Constructor
OutOfCoreIOCallable - Class in org.apache.giraph.ooc
IO threads for out-of-core mechanism.
OutOfCoreIOCallable(OutOfCoreEngine, int) - Constructor for class org.apache.giraph.ooc.OutOfCoreIOCallable
Constructor
OutOfCoreIOCallableFactory - Class in org.apache.giraph.ooc
Factory class to create IO threads for out-of-core engine.
OutOfCoreIOCallableFactory(OutOfCoreEngine, int, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.ooc.OutOfCoreIOCallableFactory
Constructor
OutOfCoreIOScheduler - Class in org.apache.giraph.ooc
Representation of IO thread scheduler for out-of-core mechanism
OutOfCoreIOStatistics - Class in org.apache.giraph.ooc
Class to collect statistics regarding IO operations done in out-of-core mechanism.
OutOfCoreIOStatistics(ImmutableClassesGiraphConfiguration, int) - Constructor for class org.apache.giraph.ooc.OutOfCoreIOStatistics
Constructor
OutOfCoreIOStatistics.BytesDuration - Class in org.apache.giraph.ooc
Helper class to return results of statistics collector for a certain command type
OutOfCoreOracle - Interface in org.apache.giraph.ooc.policy
Interface for any out-of-core oracle.
OutOfCoreOracle.IOAction - Enum in org.apache.giraph.ooc.policy
Different types of IO actions that can potentially lead to a more desired state of computation for out-of-core mechanism.
output - Variable in class org.apache.giraph.aggregators.TextAggregatorWriter
Handle to the outputfile
OUTPUTDIR - Static variable in class org.apache.giraph.examples.SimpleVertexWithWorkerContext
Directory name of where to write.
OutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Parent class for vertex and edge output formats
OutputFormat() - Constructor for class org.apache.giraph.io.OutputFormat
 
OwnerAggregatorServerData - Class in org.apache.giraph.comm.aggregators
Class for holding aggregators which current worker owns, and aggregating partial aggregator values from workers.
OwnerAggregatorServerData(Progressable) - Constructor for class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Constructor

P

PageRankBenchmark - Class in org.apache.giraph.benchmark
Benchmark for PageRankComputation
PageRankBenchmark() - Constructor for class org.apache.giraph.benchmark.PageRankBenchmark
 
PageRankComputation - Class in org.apache.giraph.benchmark
Implementation of PageRank in which vertex ids are ints, page rank values are floats, and graph is unweighted.
PageRankComputation() - Constructor for class org.apache.giraph.benchmark.PageRankComputation
 
PageRankComputation - Class in org.apache.giraph.examples
The PageRank algorithm, with uniform transition probabilities on the edges http://en.wikipedia.org/wiki/PageRank
PageRankComputation() - Constructor for class org.apache.giraph.examples.PageRankComputation
 
PageRankWithKryoMasterCompute() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoMasterCompute
 
PageRankWithKryoSimpleWritable - Class in org.apache.giraph.examples
Copy of SimplePageRank, modified to test vertex/edge and message values that derives from KryoSimpleWritable.
PageRankWithKryoSimpleWritable() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable
 
PageRankWithKryoSimpleWritable.DoubleMaxWrapperAggregator - Class in org.apache.giraph.examples
Aggregator for getting max double value
PageRankWithKryoSimpleWritable.DoubleMinWrapperAggregator - Class in org.apache.giraph.examples
Aggregator for getting min double value.
PageRankWithKryoSimpleWritable.EdgeValue - Class in org.apache.giraph.examples
Creating a custom edge value class to force kryo to register with a new ID.
PageRankWithKryoSimpleWritable.MessageValue - Class in org.apache.giraph.examples
Creating a custom message value class to force kryo to register with a new ID.
PageRankWithKryoSimpleWritable.PageRankWithKryoMasterCompute - Class in org.apache.giraph.examples
Master compute associated with PageRankWithKryoSimpleWritable.
PageRankWithKryoSimpleWritable.PageRankWithKryoVertexInputFormat - Class in org.apache.giraph.examples
VertexInputFormat that supports PageRankWithKryoSimpleWritable
PageRankWithKryoSimpleWritable.PageRankWithKryoVertexReader - Class in org.apache.giraph.examples
Simple VertexReader that supports PageRankWithKryoSimpleWritable
PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext - Class in org.apache.giraph.examples
Worker context used with PageRankWithKryoSimpleWritable.
PageRankWithKryoSimpleWritable.VertexValue - Class in org.apache.giraph.examples
Creating a custom vertex value class to force kryo to register with a new ID.
PageRankWithKryoVertexInputFormat() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoVertexInputFormat
 
PageRankWithKryoVertexReader() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoVertexReader
 
PageRankWithKryoWorkerContext() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
Pair(IntWritable, Integer) - Constructor for class org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair
Constructor
PairConsumer<T1,T2> - Interface in org.apache.giraph.function
Function: (T1, T2) -> void
PairedPieceAndStage<S> - Class in org.apache.giraph.block_app.framework.internal
Object holding piece with it's corresponding execution stage.
PairedPieceAndStage(AbstractPiece, S) - Constructor for class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
PairFunction<F1,F2,T> - Interface in org.apache.giraph.function
Function: (F1, F2) -> T
PairList<U,V> - Class in org.apache.giraph.utils
Collection to keep pairs in, without creating a wrapper object around each pair of objects.
PairList() - Constructor for class org.apache.giraph.utils.PairList
Constructor
PairList.Iterator - Class in org.apache.giraph.utils
Special iterator class which we'll use to iterate through elements of PairList, without having to create new object as wrapper for each pair.
PairPredicate<T1,T2> - Interface in org.apache.giraph.function
Function: (T) -> boolean
PairReduce<S1,R1 extends org.apache.hadoop.io.Writable,S2,R2 extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.reducers.impl
Combines two individual reducers, to create a single reducer of pairs that reduces each of them individually.
PairReduce() - Constructor for class org.apache.giraph.reducers.impl.PairReduce
Constructor
PairReduce(ReduceOperation<S1, R1>, ReduceOperation<S2, R2>) - Constructor for class org.apache.giraph.reducers.impl.PairReduce
Constructor
PairWritable<L extends org.apache.hadoop.io.Writable,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.writable.tuple
Pair Writable class, that knows types upfront and can deserialize itself.
PairWritable(L, R) - Constructor for class org.apache.giraph.writable.tuple.PairWritable
Create a new pair instance.
parseArgs(GiraphConfiguration, String[]) - Static method in class org.apache.giraph.utils.ConfigurationUtils
Translate CLI arguments to GiraphRunner or 'bin/hadoop jar' into Configuration Key-Value pairs.
Partition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.partition
A generic container that stores vertices.
PARTITION_BALANCE_ALGORITHM - Static variable in class org.apache.giraph.partition.PartitionBalancer
Partition balancing algorithm
PARTITION_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Partition class - optional
PARTITION_COUNT_MULTIPLIER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Multiplier for the current workers squared
PARTITION_EXCHANGE_DIR - Static variable in class org.apache.giraph.bsp.BspService
Helps coordinate the partition exchnages
PARTITION_LONG_TAIL_MIN_PRINT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Minimum stragglers of the superstep before printing them out
PARTITION_VERTEX_KEY_SPACE_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex key space size for WorkerGraphPartitionerImpl
PartitionBalancer - Class in org.apache.giraph.partition
Helper class for balancing partitions across a set of workers.
partitionClass - Variable in class org.apache.giraph.conf.GiraphClasses
Partition class - cached for fast accesss
PartitionExchange - Class in org.apache.giraph.partition
Describes what is required to send and wait for in a potential partition exchange between workers.
PartitionExchange(Set<WorkerInfo>, Map<WorkerInfo, List<Integer>>) - Constructor for class org.apache.giraph.partition.PartitionExchange
Only constructor.
partitionId - Variable in class org.apache.giraph.ooc.command.IOCommand
Id of the partition involved for the IO
partitionInfo - Variable in class org.apache.giraph.comm.messages.InMemoryMessageStoreFactory
Partition info
partitionInfo - Variable in class org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore
Service worker
partitionInfo - Variable in class org.apache.giraph.comm.messages.SimpleMessageStore
Partition split info
PartitionMessage<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages.queue
Small wrapper that holds a reference to vertex message and knows partition id.
PartitionMessage(int, VertexIdMessages<I, M>) - Constructor for class org.apache.giraph.comm.messages.queue.PartitionMessage
Constructs wrapper from partitino id and vertext message object.
PartitionOwner - Interface in org.apache.giraph.partition
Metadata about ownership of a partition.
PARTITIONS_DIRECTORY - Static variable in interface org.apache.giraph.conf.GiraphConstants
Comma-separated list of directories in the local filesystem for out-of-core partitions.
partitionsComputed - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many partitions were computed in current superstep until now
PartitionSplitInfo<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.comm.messages
Interface providing partition split information.
partitionsStored - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many partitions were stored until now
PartitionStats - Class in org.apache.giraph.partition
Used to keep track of statistics of every Partition.
PartitionStats() - Constructor for class org.apache.giraph.partition.PartitionStats
Default constructor for reflection.
PartitionStats(int, long, long, long, long, long, String) - Constructor for class org.apache.giraph.partition.PartitionStats
Constructor with the initial stats.
PartitionStatsRequest - Class in org.apache.giraph.comm.requests
Request for sending partition stats from workers to master
PartitionStatsRequest(Collection<PartitionStats>) - Constructor for class org.apache.giraph.comm.requests.PartitionStatsRequest
Constructor
PartitionStatsRequest() - Constructor for class org.apache.giraph.comm.requests.PartitionStatsRequest
Constructor for reflection
partitionsToCompute - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many partitions are there to compute in current superstep
PartitionStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.partition
Structure that stores partitions for a worker.
partitionsToStore - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many partitions are there to store
PartitionUtils - Class in org.apache.giraph.partition
Helper class for Partition related operations.
partitionVertexData - Variable in class org.apache.giraph.comm.requests.SendWorkerDataRequest
All data for a group of vertices, organized by partition, which are owned by a single (destination) worker.
PathStat(String, Stat) - Constructor for class org.apache.giraph.zk.ZooKeeperExt.PathStat
Put in results from createOrSet()
PERCENT_LOCAL_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
PercentGauge of requests that are handled locally
PerGraphTypeBoolean - Class in org.apache.giraph.conf
A boolean stored per user graph type
PerGraphTypeBoolean() - Constructor for class org.apache.giraph.conf.PerGraphTypeBoolean
 
PerGraphTypeBooleanConfOption - Class in org.apache.giraph.conf
Boolean Configuration option per user graph type (IVEMM)
PerGraphTypeBooleanConfOption(String, boolean, String) - Constructor for class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
Constructor
PerGraphTypeEnum<T extends Enum<T>> - Class in org.apache.giraph.conf
An enum stored per user graph type
PerGraphTypeEnum() - Constructor for class org.apache.giraph.conf.PerGraphTypeEnum
 
PerGraphTypeEnumConfOption<T extends Enum<T>> - Class in org.apache.giraph.conf
Enum Configuration option per user graph type (IVEMM)
PerGraphTypeEnumConfOption(String, Class<T>, T, String) - Constructor for class org.apache.giraph.conf.PerGraphTypeEnumConfOption
Constructor
perJobOptional() - Method in class org.apache.giraph.metrics.GiraphMetrics
Get per-job optional metrics.
perJobRequired() - Method in class org.apache.giraph.metrics.GiraphMetrics
Get per-job required metrics.
perSuperstep() - Method in class org.apache.giraph.metrics.GiraphMetrics
Get per-superstep metrics.
PHASE - Static variable in class org.apache.giraph.examples.scc.SccPhaseMasterCompute
Aggregator that stores the current phase
Piece<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,S> - Class in org.apache.giraph.block_app.framework.piece
Piece that should be extended in common usecases, when we want to be: - sending and then receiving messages from vertices - sending data to be aggregated from workers to master - sending values from master, via aggregators, to workers (basically - we don't want to use WorkerContext)
Piece() - Constructor for class org.apache.giraph.block_app.framework.piece.Piece
 
PieceCount - Class in org.apache.giraph.block_app.framework.block
Number of pieces
PieceCount(int) - Constructor for class org.apache.giraph.block_app.framework.block.PieceCount
 
Pieces - Class in org.apache.giraph.block_app.library
Utility class for creating common Pieces and computations for processing graphs.
PieceWithWorkerContext<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,WV,WM extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece
Piece that should be extended when WorkerContext is used.
PieceWithWorkerContext() - Constructor for class org.apache.giraph.block_app.framework.piece.PieceWithWorkerContext
 
PipelineUtils - Class in org.apache.giraph.utils
Utility class for ChannelPipeline
plusInto(ByteWritable, ByteWritable) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
plusInto(DoubleWritable, DoubleWritable) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
plusInto(FloatWritable, FloatWritable) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
plusInto(IntWritable, IntWritable) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
plusInto(LongWritable, LongWritable) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
plusInto(T, T) - Method in interface org.apache.giraph.types.ops.NumericTypeOps
value+=adder
PointerListMessagesIterable<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
Create an iterable for messages based on a pointer list
PointerListMessagesIterable(MessageValueFactory<M>, LongArrayList, ExtendedByteArrayOutputBuffer) - Constructor for class org.apache.giraph.comm.messages.PointerListMessagesIterable
 
PointerListPerVertexStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.messages
Implementation of SimpleMessageStore where multiple messages are stored as a list of long pointers to extended data output objects Used when there is no combiner provided.
PointerListPerVertexStore(MessageValueFactory<M>, PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.PointerListPerVertexStore
Constructor
popIntoW(T) - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Pop value from the end of the array, storing it into 'to' argument
popIntoW(BooleanWritable) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
popIntoW(ByteWritable) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
popIntoW(DoubleWritable) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
popIntoW(FloatWritable) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
popIntoW(IntWritable) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
popIntoW(LongWritable) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
postApplication() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
 
postApplication() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
postApplication() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
postApplication() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext.MigrationFullWorkerContext
 
postApplication() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Application has finished.
postApplication() - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext.EmitterWorkerContext
 
postApplication() - Method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation.VerifyMessageVertexWorkerContext
 
postApplication() - Method in class org.apache.giraph.io.superstep_output.MultiThreadedSuperstepOutput
 
postApplication() - Method in class org.apache.giraph.io.superstep_output.NoOpSuperstepOutput
 
postApplication() - Method in interface org.apache.giraph.io.superstep_output.SuperstepOutput
Finalize this output in the end of the application
postApplication() - Method in class org.apache.giraph.io.superstep_output.SynchronizedSuperstepOutput
 
postApplication() - Method in class org.apache.giraph.master.BspServiceMaster
 
postApplication() - Method in class org.apache.giraph.master.DefaultMasterObserver
 
postApplication() - Method in interface org.apache.giraph.master.MasterObserver
After application ends.
postApplication() - Method in class org.apache.giraph.utils.JMapHistoDumper
 
postApplication() - Method in class org.apache.giraph.utils.LogVersions
 
postApplication() - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
postApplication() - Method in class org.apache.giraph.worker.DefaultWorkerContext
 
postApplication() - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
postApplication() - Method in class org.apache.giraph.worker.WorkerContext
Finalize the WorkerContext.
postApplication() - Method in interface org.apache.giraph.worker.WorkerObserver
Finalize the observer.
postFilling() - Method in class org.apache.giraph.mapping.LongByteMappingStore
 
postFilling() - Method in interface org.apache.giraph.mapping.MappingStore
Operations to perform after adding entries to the mapping store
postMasterCompute() - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
Called after master compute, to do aggregator->reduce/broadcast translation
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexReceiver
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexSender
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerReceiveFunctions
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerSendFunctions
 
postprocess() - Method in interface org.apache.giraph.block_app.framework.piece.interfaces.VertexPostprocessor
Override to finish computation.
postSave() - Method in class org.apache.giraph.utils.JMapHistoDumper
 
postSave() - Method in class org.apache.giraph.utils.LogVersions
 
postSave() - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
postSave() - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
postSave() - Method in interface org.apache.giraph.worker.WorkerObserver
Finalize the observer.
postSuperstep() - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockComputation
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
postSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
postSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
postSuperstep() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Superstep has finished.
postSuperstep() - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext.EmitterWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.TestComputationStateComputation
 
postSuperstep() - Method in class org.apache.giraph.examples.TestComputationStateComputation.TestComputationStateWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation.VerifyMessageVertexWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.graph.AbstractComputation
Finish computation.
postSuperstep() - Method in interface org.apache.giraph.graph.Computation
Finish computation.
postSuperstep() - Method in class org.apache.giraph.jython.JythonComputation
Finish computation.
postSuperstep() - Method in class org.apache.giraph.master.BspServiceMaster
 
postSuperstep(long) - Method in class org.apache.giraph.master.DefaultMasterObserver
 
postSuperstep(long) - Method in interface org.apache.giraph.master.MasterObserver
After each superstep ends.
postSuperstep(long) - Method in class org.apache.giraph.utils.JMapHistoDumper
 
postSuperstep(long) - Method in class org.apache.giraph.utils.LogVersions
 
postSuperstep(long) - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
postSuperstep() - Method in class org.apache.giraph.worker.DefaultWorkerContext
 
postSuperstep(long) - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
postSuperstep() - Method in class org.apache.giraph.worker.WorkerContext
Execute user code.
postSuperstep(long) - Method in interface org.apache.giraph.worker.WorkerObserver
Execute the observer.
postWriting() - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
This method will be called after all writers are closed
postWriting(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeOutputFormat
 
postWriting(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedVertexOutputFormat
 
postWriting(TaskAttemptContext) - Method in class org.apache.giraph.io.OutputFormat
This method will be called after all writers are closed
preApplication() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
 
preApplication() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
preApplication(BlockWorkerContextApi, BlockOutputHandle) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
preApplication() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext.MigrationFullWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext.EmitterWorkerContext
 
preApplication() - Method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation.VerifyMessageVertexWorkerContext
 
preApplication() - Method in class org.apache.giraph.master.DefaultMasterObserver
 
preApplication() - Method in interface org.apache.giraph.master.MasterObserver
Before application begins.
preApplication() - Method in class org.apache.giraph.utils.JMapHistoDumper
 
preApplication() - Method in class org.apache.giraph.utils.LogVersions
 
preApplication() - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
preApplication() - Method in class org.apache.giraph.worker.DefaultWorkerContext
 
preApplication() - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
preApplication() - Method in class org.apache.giraph.worker.WorkerContext
Initialize the WorkerContext.
preApplication() - Method in interface org.apache.giraph.worker.WorkerObserver
Initialize the observer.
Predicate<T> - Interface in org.apache.giraph.function
Function: (T) -> boolean
Specialization of com.google.common.base.Predicate, that is also Serializable.
PredicateLock - Class in org.apache.giraph.zk
A lock with a predicate that was be used to synchronize events and keep the job context updated while waiting.
PredicateLock(Progressable) - Constructor for class org.apache.giraph.zk.PredicateLock
Constructor with default values.
PredicateLock(Progressable, int, Time) - Constructor for class org.apache.giraph.zk.PredicateLock
Constructor.
PREFER_IP_ADDRESSES - Static variable in interface org.apache.giraph.conf.GiraphConstants
For worker to worker communication we can use IPs or host names, by default prefer IPs.
preLoad() - Method in class org.apache.giraph.utils.JMapHistoDumper
 
preLoad() - Method in class org.apache.giraph.utils.LogVersions
 
preLoad() - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
preLoad() - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
preLoad() - Method in interface org.apache.giraph.worker.WorkerObserver
Initialize the observer.
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark
 
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.GiraphBenchmark
Process options from CommandLine and prepare configuration for running the job.
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.PageRankBenchmark
 
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark
 
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.ReducersBenchmark
 
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.ShortestPathsBenchmark
 
prepareConfiguration(GiraphConfiguration, CommandLine) - Method in class org.apache.giraph.benchmark.WeightedPageRankBenchmark
Set vertex edges, input format, partitioner classes and related parameters based on command-line arguments.
prepareInput(int, DataIndex) - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
 
prepareInput(int, DataIndex) - Method in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
 
prepareInput(int, DataIndex) - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
Prepare a wrapper containing DataInput representation for a given thread involved in persistence for a given index chain for data.
prepareOutput(int, DataIndex, boolean) - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
 
prepareOutput(int, DataIndex, boolean) - Method in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
 
prepareOutput(int, DataIndex, boolean) - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
Prepare a wrapper containing DataOutput representation for a given thread involved in persistence for a given index chain for data.
prepareResolveMutations() - Method in class org.apache.giraph.comm.ServerData
Prepare resolving mutation.
prepareSuperstep() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Final preparation for superstep, called after startSuperstep and potential loading from checkpoint, right before the computation started TODO how to avoid this additional function
prepareSuperstep() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
prepareSuperstep() - Method in class org.apache.giraph.comm.ServerData
Prepare for next superstep
prepareSuperstep() - Method in interface org.apache.giraph.comm.WorkerServer
Prepare incoming messages for computation, and resolve mutation requests.
prepareSuperstep() - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
Prepare before calling master compute
prepareSuperstep() - Method in class org.apache.giraph.master.MasterAggregatorHandler
Prepare reduced values for current superstep's master compute
prepareSuperstep() - Method in class org.apache.giraph.worker.BspServiceWorker
 
prepareSuperstep(WorkerAggregatorRequestProcessor) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
Prepare aggregators for current superstep
preprocessLine(Text) - Method in class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat.LongLongNullVertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.IntIntNullTextInputFormat.IntIntNullVertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat.IntIntNullVertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.IntIntTextVertexValueInputFormat.IntIntTextVertexValueReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.IntNullNullTextInputFormat.IntNullNullNullVertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.IntNullTextEdgeInputFormat.IntNullTextEdgeReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.JsonBase64VertexInputFormat.JsonBase64VertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.LongLongNullTextInputFormat.LongLongNullVertexReader
 
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
Preprocess the line so other methods can easily read necessary information for creating edge
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
Preprocess the line so other methods can easily read necessary information for creating vertex.
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
Preprocess the line so other methods can easily read necessary information for creating vertex.
preprocessLine(Text) - Method in class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
Preprocess the line so other methods can easily read necessary information for creating vertex.
preSuperstep() - Method in class org.apache.giraph.benchmark.AggregatorsBenchmark.AggregatorsBenchmarkWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockComputation
 
preSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
preSuperstep(BlockWorkerContextReceiveApi, BlockWorkerContextSendApi, BlockWorkerPieces, long, List<Writable>) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
preSuperstep(BlockWorkerReceiveApi, BlockWorkerSendApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
preSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
preSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.PageRankWithKryoWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.RandomWalkWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.scc.SccComputation
 
preSuperstep() - Method in class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext.EmitterWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.TestComputationStateComputation
 
preSuperstep() - Method in class org.apache.giraph.examples.TestComputationStateComputation.TestComputationStateWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation.VerifyMessageVertexWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.graph.AbstractComputation
Prepare for computation.
preSuperstep() - Method in interface org.apache.giraph.graph.Computation
Prepare for computation.
preSuperstep() - Method in class org.apache.giraph.jython.JythonComputation
Prepare for computation.
preSuperstep(long) - Method in class org.apache.giraph.master.DefaultMasterObserver
 
preSuperstep(long) - Method in interface org.apache.giraph.master.MasterObserver
Before each superstep starts.
preSuperstep(long) - Method in class org.apache.giraph.utils.JMapHistoDumper
 
preSuperstep(long) - Method in class org.apache.giraph.utils.LogVersions
 
preSuperstep(long) - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
preSuperstep() - Method in class org.apache.giraph.worker.DefaultWorkerContext
 
preSuperstep(long) - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
preSuperstep() - Method in class org.apache.giraph.worker.WorkerContext
Execute user code.
preSuperstep(long) - Method in interface org.apache.giraph.worker.WorkerObserver
Execute the observer.
preWriting() - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
This method will be called before creating any writers
preWriting(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedEdgeOutputFormat
 
preWriting(TaskAttemptContext) - Method in class org.apache.giraph.io.internal.WrappedVertexOutputFormat
 
preWriting(TaskAttemptContext) - Method in class org.apache.giraph.io.OutputFormat
This method will be called before creating any writers
PrimitiveIdTypeOps<T> - Interface in org.apache.giraph.types.ops
Additional type operations to TypeOps for types that can be IDs, and so can be used as keys in maps and values in sets.
PrimitiveRefs - Interface in org.apache.giraph.function.primitive
Convenience classes holding primitive values - a reference to a mutable value.
PrimitiveRefs.DoubleRef - Class in org.apache.giraph.function.primitive
Convenience class holding double value, for use when lambdas need to mutate capturing double local variable.
PrimitiveRefs.FloatRef - Class in org.apache.giraph.function.primitive
Convenience class holding float value, for use when lambdas need to mutate capturing float local variable.
PrimitiveRefs.IntRef - Class in org.apache.giraph.function.primitive
Convenience class holding int value, for use when lambdas need to mutate capturing int local variable.
PrimitiveRefs.LongRef - Class in org.apache.giraph.function.primitive
Convenience class holding long value, for use when lambdas need to mutate capturing long local variable.
PrimitiveRefs.ObjRef<O> - Class in org.apache.giraph.function.primitive
Convenience class holding object values, for use when lambdas need to mutate capturing object local variable.
PrimitiveRefs.ShortRef - Class in org.apache.giraph.function.primitive
Convenience class holding int value, for use when lambdas need to mutate capturing int local variable.
PrimitiveTypeOps<T> - Interface in org.apache.giraph.types.ops
Type operations, allowing working generically with types, but still having efficient code.
print(long, PrintStream) - Method in class org.apache.giraph.metrics.AggregatedMetrics
Print the aggregated metrics to the stream provided.
print(long, PrintStream) - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
Human readable dump of metrics stored here.
printHaltInfo(Job, GiraphConfiguration) - Static method in class org.apache.giraph.job.HaltApplicationUtils
Wait for halt info to become available and print instructions on how to halt
printStats() - Method in class org.apache.giraph.worker.LocalData
Prints Stats of individual data it stores
printSummary(PrintStream) - Method in class org.apache.giraph.metrics.SuperstepMetricsRegistry
Print human readable summary of superstep metrics.
printToStream(PrintStream) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Dump all the metrics to the PrintStream provided.
process(WatchedEvent) - Method in class org.apache.giraph.bsp.BspService
 
process(WatchedEvent) - Method in class org.apache.giraph.zk.GiraphZooKeeperAdmin
Implement watcher to receive event at the end of the cleaner run
process(WatchedEvent) - Method in class org.apache.giraph.zk.ZooKeeperNodeCreator
 
processEvent(WatchedEvent) - Method in class org.apache.giraph.bsp.BspService
Derived classes that want additional ZooKeeper events to take action should override this.
processEvent(WatchedEvent) - Method in class org.apache.giraph.master.BspServiceMaster
 
processEvent(WatchedEvent) - Method in class org.apache.giraph.worker.BspServiceWorker
 
processingThreadFinish() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Notify the out-of-core engine that a processing (input/compute) thread has finished.
processingThreadStart() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Notify the out-of-core engine that a processing (input/compute) thread has started.
processRequest(MasterRequest) - Method in class org.apache.giraph.comm.netty.handler.MasterRequestServerHandler
 
processRequest(R) - Method in class org.apache.giraph.comm.netty.handler.RequestServerHandler
Process request
processRequest(WorkerRequest<I, V, E>) - Method in class org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler
 
processResumeSignal(int, short, long) - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Process a resume signal came from a given worker
processToken(SaslNettyServer) - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
Update server's token in response to the SASL token received from client.
processWith(MetricProcessor<T>, MetricName, T) - Method in class com.yammer.metrics.core.NoOpCounter
 
processWith(MetricProcessor<T>, MetricName, T) - Method in class com.yammer.metrics.core.NoOpHistogram
 
processWith(MetricProcessor<T>, MetricName, T) - Method in class com.yammer.metrics.core.NoOpMeter
 
processWith(MetricProcessor<T>, MetricName, T) - Method in class com.yammer.metrics.core.NoOpTimer
 
progress() - Method in interface org.apache.giraph.block_app.framework.api.StatusReporter
Report progress to the Hadoop framework.
progress() - Method in class org.apache.giraph.partition.BasicPartition
 
progress() - Method in interface org.apache.giraph.partition.Partition
Report progress.
PROGRESS_COUNTER - Static variable in class org.apache.giraph.edge.AbstractEdgeStore
Used to keep track of progress during the move-edges process
progressable - Variable in class org.apache.giraph.edge.AbstractEdgeStore
Progressable to report progress.
progressable - Variable in class org.apache.giraph.edge.InMemoryEdgeStoreFactory
Progressable to report progress.
progressable - Variable in class org.apache.giraph.zk.PredicateLock
Progressable for reporting progress (Job context)
ProgressableUtils - Class in org.apache.giraph.utils
Functions for waiting on some events to happen while reporting progress
ProgressCounter - Class in org.apache.giraph.utils
Used to keep track of a metric.
ProgressCounter() - Constructor for class org.apache.giraph.utils.ProgressCounter
 
PseudoRandomEdgeInputFormat - Class in org.apache.giraph.io.formats
This EdgeInputFormat generates pseudo-random edges on the fly.
PseudoRandomEdgeInputFormat() - Constructor for class org.apache.giraph.io.formats.PseudoRandomEdgeInputFormat
 
PseudoRandomInputFormatConstants - Class in org.apache.giraph.io.formats
Contains constants for configuring pseudo-random input formats.
PseudoRandomIntNullLocalEdgesHelper - Class in org.apache.giraph.io.formats
Helper class to generate pseudo-random local edges.
PseudoRandomIntNullLocalEdgesHelper(int, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.io.formats.PseudoRandomIntNullLocalEdgesHelper
Constructor.
PseudoRandomIntNullVertexInputFormat - Class in org.apache.giraph.io.formats
VertexInputFormat for large scale testing, like PseudoRandomVertexInputFormat, but for the unweighted graphs where vertex ids are integers.
PseudoRandomIntNullVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.PseudoRandomIntNullVertexInputFormat
 
PseudoRandomLocalEdgesHelper - Class in org.apache.giraph.io.formats
Helper class to generate pseudo-random local edges.
PseudoRandomLocalEdgesHelper(long, float, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.io.formats.PseudoRandomLocalEdgesHelper
Constructor.
PseudoRandomUtils - Class in org.apache.giraph.io.formats
Utility methods for PseudoRandom input formats
PseudoRandomVertexInputFormat - Class in org.apache.giraph.io.formats
This VertexInputFormat is meant for large scale testing.
PseudoRandomVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.PseudoRandomVertexInputFormat
 
put(IntWritable, V) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
put(LongWritable, V) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
put(K, V) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
put(K, V) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Adds a pair to the map.
putOrCombine(Vertex<I, V, E>) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
putOrCombine(Vertex<I, V, E>) - Method in interface org.apache.giraph.partition.Partition
Put this vertex or combine it
putOrCombine(Vertex<I, V, E>) - Method in class org.apache.giraph.partition.SimplePartition
 
putParametersToConfiguration(Configuration) - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
Put parameters from this input format description to configuration
putPartition(Partition) - Method in interface org.apache.giraph.comm.messages.PartitionSplitInfo
putPartition(Partition<I, V, E>) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
putPartition(Partition<I, V, E>) - Method in interface org.apache.giraph.partition.PartitionStore
Put a partition back to the store.
putPartition(Partition<I, V, E>) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
putPartition(Partition) - Method in class org.apache.giraph.worker.BspServiceWorker
 
putVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
putVertex(Vertex<I, V, E>) - Method in interface org.apache.giraph.partition.Partition
Put a vertex into the Partition
putVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.partition.SimplePartition
 

R

random - Variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
randomizeMessageBytes() - Method in class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
Randomize the message bytes.
RandomMessageBenchmark - Class in org.apache.giraph.benchmark
Random Message Benchmark for evaluating the messaging performance.
RandomMessageBenchmark() - Constructor for class org.apache.giraph.benchmark.RandomMessageBenchmark
 
RandomMessageBenchmark.RandomMessageBenchmarkMasterCompute - Class in org.apache.giraph.benchmark
Master compute associated with RandomMessageBenchmark.
RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext - Class in org.apache.giraph.benchmark
WorkerContext forRandomMessageBenchmark.
RandomMessageBenchmark.RandomMessageComputation - Class in org.apache.giraph.benchmark
Actual message computation (messaging in this case)
RandomMessageBenchmarkMasterCompute() - Constructor for class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkMasterCompute
 
RandomMessageBenchmarkWorkerContext() - Constructor for class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
 
RandomMessageComputation() - Constructor for class org.apache.giraph.benchmark.RandomMessageBenchmark.RandomMessageComputation
 
RandomWalkComputation<E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.examples
Base class for executing a random walk on a graph
RandomWalkComputation() - Constructor for class org.apache.giraph.examples.RandomWalkComputation
 
RandomWalkVertexMasterCompute - Class in org.apache.giraph.examples
Master compute associated with RandomWalkComputation.
RandomWalkVertexMasterCompute() - Constructor for class org.apache.giraph.examples.RandomWalkVertexMasterCompute
 
RandomWalkWithRestartComputation - Class in org.apache.giraph.examples
Executes "RandomWalkWithRestart", a random walk on the graph which is biased towards a source vertex.
RandomWalkWithRestartComputation() - Constructor for class org.apache.giraph.examples.RandomWalkWithRestartComputation
 
RandomWalkWorkerContext - Class in org.apache.giraph.examples
Worker context for random walks.
RandomWalkWorkerContext() - Constructor for class org.apache.giraph.examples.RandomWalkWorkerContext
 
REACTIVE_JMAP_ENABLE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Option can be used to enable reactively dumping jmap histo when OOM is imminent
ReactiveJMapHistoDumper - Class in org.apache.giraph.utils
An observer for both worker and master that periodically checks if available memory on heap is below certain threshold, and if found to be the case dumps jmap -histo for the process
ReactiveJMapHistoDumper() - Constructor for class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
read(FixedCapacityIntByteMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Deserializes an object from data input.
read(FixedCapacityIntDoubleMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Deserializes an object from data input.
read(FixedCapacityIntFloatMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Deserializes an object from data input.
read(FixedCapacityIntIntMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Deserializes an object from data input.
read(FixedCapacityIntLongMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Deserializes an object from data input.
read(FixedCapacityLongByteMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Deserializes an object from data input.
read(FixedCapacityLongDoubleMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Deserializes an object from data input.
read(FixedCapacityLongFloatMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Deserializes an object from data input.
read(FixedCapacityLongIntMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Deserializes an object from data input.
read(FixedCapacityLongLongMinHeap, DataInput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Deserializes an object from data input.
read() - Method in class org.apache.giraph.writable.kryo.DataInputWrapperStream
 
read(byte[], int, int) - Method in class org.apache.giraph.writable.kryo.DataInputWrapperStream
 
read(Kryo, Input, Class<List>) - Method in class org.apache.giraph.writable.kryo.serializers.ArraysAsListSerializer
 
read(Kryo, Input, Class<List<T>>) - Method in class org.apache.giraph.writable.kryo.serializers.CollectionsNCopiesSerializer
 
read(Kryo, Input, Class<T>) - Method in class org.apache.giraph.writable.kryo.serializers.DirectWritableSerializer
 
read(Kryo, Input, Class<T>) - Method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
 
readBoolean() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readBoolean() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readBoolean() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readBoolean() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readByte() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readByte() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readByte() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readByte() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readChar() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readChar() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readChar() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readChar() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readClass(DataInput) - Static method in class org.apache.giraph.utils.WritableUtils
Read class from data input.
readClass(Input) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
 
readClassAndObj(DataInput) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Read object from the input stream, by reading first type of the object, and then all of its fields.
readData(ExtendedDataInput, M) - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
readData(ExtendedDataInput, Edge<I, E>) - Method in class org.apache.giraph.utils.ByteArrayVertexIdEdges
 
readData(ExtendedDataInput, M) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
readData(ExtendedDataInput, T) - Method in interface org.apache.giraph.utils.VertexIdData
Read a data object's fields from an ExtendedDataInput.
readDouble() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readDouble() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readDouble() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readDouble() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readEdge(DataInput, Edge<I, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Read an edge from an input stream.
readElements(DataInput, int) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
readElements(DataInput, int) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
readElements(DataInput, int) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
readElements(DataInput, int) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
readElements(DataInput, int) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
readElements(DataInput, int) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
readElements(DataInput, int) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Read elements from DataInput stream, with passing the size instead reading it from the stream.
readEnum(DataInput) - Static method in class org.apache.giraph.utils.WritableUtils
Reads enum from the stream, serialized by writeEnum
READER_VERTICES - Static variable in class org.apache.giraph.examples.GeneratedVertexReader
Vertices produced by this reader
readExtendedDataOutput(DataInput, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.WritableUtils
Read ExtendedDataOutput from DataInput
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
 
readFields(DataInput) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
 
readFields(DataInput) - Method in class org.apache.giraph.benchmark.ReducersBenchmark.TestLongSumReducer
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
readFields(DataInput) - Method in class org.apache.giraph.bsp.BspInputSplit
 
readFields(DataInput) - Method in class org.apache.giraph.comm.requests.WritableRequest
 
readFields(DataInput) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
readFields(DataInput) - Method in class org.apache.giraph.counters.CustomCounter
 
readFields(DataInput) - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Read from Hadoop input.
readFields(DataInput) - Method in class org.apache.giraph.edge.ArrayListEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.ByteArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.HashMapEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongDiffArray
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
readFields(DataInput) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
readFields(DataInput) - Method in class org.apache.giraph.examples.scc.SccVertexValue
 
readFields(DataInput) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
 
readFields(DataInput) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
readFields(DataInput) - Method in class org.apache.giraph.examples.VerifyMessage.VerifiableMessage
 
readFields(DataInput) - Method in class org.apache.giraph.graph.AddressesAndPartitionsWritable
 
readFields(DataInput) - Method in class org.apache.giraph.graph.GlobalStats
 
readFields(DataInput) - Method in class org.apache.giraph.graph.TaskInfo
 
readFields(DataInput) - Method in class org.apache.giraph.graph.VertexMutations
 
readFields(DataInput) - Method in class org.apache.giraph.jython.wrappers.JythonWritableWrapper
 
readFields(DataInput) - Method in class org.apache.giraph.master.AggregatorBroadcast
 
readFields(DataInput) - Method in class org.apache.giraph.master.AggregatorReduceOperation
 
readFields(DataInput) - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
 
readFields(DataInput) - Method in class org.apache.giraph.master.DefaultMasterCompute
 
readFields(DataInput) - Method in class org.apache.giraph.master.MasterAggregatorHandler
 
readFields(DataInput) - Method in class org.apache.giraph.master.SuperstepClasses
 
readFields(DataInput) - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
readFields(DataInput) - Method in class org.apache.giraph.partition.BasicPartition
 
readFields(DataInput) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
readFields(DataInput) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
readFields(DataInput) - Method in class org.apache.giraph.partition.PartitionStats
 
readFields(DataInput) - Method in class org.apache.giraph.partition.SimplePartition
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.AndReduce
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.LongXorReduce
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.MaxPairReducer
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.MaxReduce
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.MinReduce
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.OrReduce
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.PairReduce
 
readFields(DataInput) - Method in class org.apache.giraph.reducers.impl.SumReduce
 
readFields(DataInput, ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.reducers.Reducer
Deserialize the fields of this object from in.
readFields(DataInput) - Method in class org.apache.giraph.types.NoMessage
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
readFields(DataInput) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
readFields(DataInput) - Method in interface org.apache.giraph.types.ops.collections.WritableWriter
Deserialize the fields of object from in.
readFields(DataInput) - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
readFields(DataInput) - Method in class org.apache.giraph.utils.ArrayListWritable
 
readFields(DataInput) - Method in class org.apache.giraph.utils.ArrayWritable
 
readFields(DataInput) - Method in class org.apache.giraph.utils.ByteArrayVertexIdData
 
readFields(DataInput) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
readFields(DataInput) - Method in class org.apache.giraph.utils.io.BigDataInputOutput
 
readFields(DataInput) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
readFields(DataInput) - Method in class org.apache.giraph.utils.io.ExtendedDataInputOutput
 
readFields(DataInput) - Method in class org.apache.giraph.worker.WorkerContext
 
readFields(DataInput) - Method in class org.apache.giraph.writable.kryo.KryoSimpleWrapper
 
readFields(DataInput) - Method in class org.apache.giraph.writable.kryo.KryoSimpleWritable
 
readFields(DataInput) - Method in class org.apache.giraph.writable.kryo.KryoWritable
 
readFields(DataInput) - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
 
readFields(DataInput) - Method in class org.apache.giraph.writable.tuple.PairWritable
 
readFieldsForMessages(DataInput) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
readFieldsForMessages(DataInput) - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
readFieldsForMessages(DataInput) - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
readFieldsForMessages(DataInput) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
Read message storage from DataInput
readFieldsForPartition(DataInput, int) - Method in interface org.apache.giraph.comm.messages.MessageStore
Deserialize messages for one partition
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
readFieldsForPartition(DataInput, int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
readFieldsFromByteArray(byte[], Writable...) - Static method in class org.apache.giraph.utils.WritableUtils
Read fields from byteArray to a Writeable object.
readFieldsFromByteArrayWithSize(byte[], Writable, boolean) - Static method in class org.apache.giraph.utils.WritableUtils
Read fields from byteArray to a Writeable object, skipping the size.
readFieldsFromZnode(ZooKeeperExt, String, boolean, Stat, Writable...) - Static method in class org.apache.giraph.utils.WritableUtils
Read fields from a ZooKeeper znode.
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SaslCompleteRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SendVertexRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SendWorkerDataRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
 
readFieldsRequest(DataInput) - Method in class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
 
readFieldsWithWorkerIds(DataInput, Map<Integer, WorkerInfo>) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
readFieldsWithWorkerIds(DataInput, Map<Integer, WorkerInfo>) - Method in interface org.apache.giraph.partition.PartitionOwner
A match for writeWithWorkerIds method - for WorkerInfos it will read just task ids from input and then find the matching WorkerInfo in the provided map and set it
readFloat() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readFloat() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readFloat() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readFloat() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readFrom(Configuration) - Static method in class org.apache.giraph.conf.GiraphTypes
Read types from a Configuration.
readFromConf(PerGraphTypeBooleanConfOption, Configuration) - Static method in class org.apache.giraph.conf.PerGraphTypeBoolean
Create from options and configuration
readFromConf(PerGraphTypeEnumConfOption<T>, Configuration) - Static method in class org.apache.giraph.conf.PerGraphTypeEnum
Create from options and configuration
readFromRegistry() - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
Read metric values from global MetricsRegistry.
readFully(byte[]) - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readFully(byte[], int, int) - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readFully(byte[]) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readFully(byte[], int, int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readFully(byte[]) - Method in class org.apache.giraph.utils.io.BigDataInput
 
readFully(byte[], int, int) - Method in class org.apache.giraph.utils.io.BigDataInput
 
readFully(byte[]) - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readFully(byte[], int, int) - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readIfNotNullAndObject(T, Class<T>, DataInput) - Static method in class org.apache.giraph.utils.WritableUtils
First read a boolean saying whether an object is not null, and if it's not read the object
readInputSplit(DataInput) - Method in class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
readInputSplit(DataInput, List<? extends GiraphInputFormat>) - Static method in class org.apache.giraph.io.formats.multi.MultiInputUtils
Read input split info from DataInput.
readInputSplit(DataInput) - Method in class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
 
readInputSplit(DataInput) - Method in class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
readInputSplit(DataInput) - Method in class org.apache.giraph.io.GiraphInputFormat
Read input split info from DataInput.
readInputSplit(DataInput) - Method in class org.apache.giraph.io.internal.WrappedEdgeInputFormat
 
readInputSplit(DataInput) - Method in class org.apache.giraph.io.internal.WrappedMappingInputFormat
 
readInputSplit(DataInput) - Method in class org.apache.giraph.io.internal.WrappedVertexInputFormat
 
readInputSplit(InputSplit) - Method in class org.apache.giraph.worker.EdgeInputSplitsCallable
Read edges from input split.
readInputSplit(InputSplit) - Method in class org.apache.giraph.worker.InputSplitsCallable
Load vertices/edges from the given input split.
readInputSplit(InputSplit) - Method in class org.apache.giraph.worker.MappingInputSplitsCallable
 
readInputSplit(InputSplit) - Method in class org.apache.giraph.worker.VertexInputSplitsCallable
Read vertices from input split.
readInt() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readInt() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readInt() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readInt() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readIntArray(DataInput) - Static method in class org.apache.giraph.utils.WritableUtils
Reads primitive int array from input stream.
readIntoObject(DataInput, Object) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Reads an object, from input, into a given object, allowing object reuse.
readIntoOrCreate(WBooleanArrayList.WReusableBooleanArrayList, DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList.WReusableBooleanArrayList
Read array list from DataInput stream, into a given list if not null, or creating a new list if given list is null.
readIntoOrCreate(WByteArrayList.WReusableByteArrayList, DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WByteArrayList.WReusableByteArrayList
Read array list from DataInput stream, into a given list if not null, or creating a new list if given list is null.
readIntoOrCreate(WDoubleArrayList.WReusableDoubleArrayList, DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList.WReusableDoubleArrayList
Read array list from DataInput stream, into a given list if not null, or creating a new list if given list is null.
readIntoOrCreate(WFloatArrayList.WReusableFloatArrayList, DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList.WReusableFloatArrayList
Read array list from DataInput stream, into a given list if not null, or creating a new list if given list is null.
readIntoOrCreate(WIntArrayList.WReusableIntArrayList, DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WIntArrayList.WReusableIntArrayList
Read array list from DataInput stream, into a given list if not null, or creating a new list if given list is null.
readIntoOrCreate(WLongArrayList.WReusableLongArrayList, DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WLongArrayList.WReusableLongArrayList
Read array list from DataInput stream, into a given list if not null, or creating a new list if given list is null.
readLine() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readLine() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readLine() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readLine() - Method in class org.apache.giraph.utils.UnsafeReads
 
readList(DataInput) - Static method in class org.apache.giraph.utils.WritableUtils
Reads list of Writable objects from data input stream.
readListFieldsFromByteArray(byte[], Class<? extends T>, Configuration) - Static method in class org.apache.giraph.utils.WritableUtils
Read fields from byteArray to a list of objects.
readListFieldsFromZnode(ZooKeeperExt, String, boolean, Stat, Class<? extends T>, Configuration) - Static method in class org.apache.giraph.utils.WritableUtils
Read fields from a ZooKeeper znode into a list of objects.
readLong() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readLong() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readLong() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readLong() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readLongArray(DataInput) - Static method in class org.apache.giraph.utils.WritableUtils
Reads primitive long array from input stream.
readName(Input) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
This method reads the class name for the first encountered non-explicitly registered class.
readNew(DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Read array list from the DataInput stream into a newly created object.
readNew(DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
Read array list from the DataInput stream into a newly created object.
readNew(DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Read array list from the DataInput stream into a newly created object.
readNew(DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Read array list from the DataInput stream into a newly created object.
readNew(DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
Read array list from the DataInput stream into a newly created object.
readNew(DataInput) - Static method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
Read array list from the DataInput stream into a newly created object.
readNewArrayList(DataInput) - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
readNewArrayList(DataInput) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
readNewArrayList(DataInput) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
readNewArrayList(DataInput) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
readNewArrayList(DataInput) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
readNewArrayList(DataInput) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
readNewArrayList(DataInput) - Method in interface org.apache.giraph.types.ops.PrimitiveTypeOps
Create WArrayList of type T by reading it from given input.
readNextEntry(DataInput) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Reads the next available raw entry from a given input stream.
readNextEntry(DataInput) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
readNextEntry(DataInput) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
readNextEntry(DataInput) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
readPartitionEdgeStore(int, DataInput) - Method in class org.apache.giraph.edge.AbstractEdgeStore
 
readPartitionEdgeStore(int, DataInput) - Method in interface org.apache.giraph.edge.EdgeStore
Serialize the edges of a given partition, and adds it to the partition store (assumes that the edge store does not have any edge from the partition already).
readPartitionEdgeStore(int, DataInput) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
readShort() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readShort() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readShort() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readShort() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readSignedVarInt(DataInput) - Static method in class org.apache.giraph.utils.Varint
 
readSignedVarLong(DataInput) - Static method in class org.apache.giraph.utils.Varint
 
readTypeOps(DataInput) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Read TypeOps object from the stream
readUnsignedByte() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readUnsignedByte() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readUnsignedByte() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readUnsignedByte() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readUnsignedShort() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readUnsignedShort() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readUnsignedShort() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readUnsignedShort() - Method in class org.apache.giraph.utils.UnsafeArrayReads
 
readUnsignedVarInt(DataInput) - Static method in class org.apache.giraph.utils.Varint
 
readUnsignedVarLong(DataInput) - Static method in class org.apache.giraph.utils.Varint
 
readUTF() - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
readUTF() - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
readUTF() - Method in class org.apache.giraph.utils.io.BigDataInput
 
readUTF() - Method in class org.apache.giraph.utils.UnsafeReads
 
readVertexFromDataInput(DataInput, ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Reads data from input stream to initialize Vertex.
readVertexKey(DataInput) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Reads the given key from the input
readVertexKey(DataInput) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
readVertexKey(DataInput) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
readVertexKey(DataInput) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
readWithKryo(HadoopKryo, Input) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Reads class and object from specified input stream with specified kryo object.
readWithKryoIntoObject(HadoopKryo, Input, Object) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Read into object with given kryo.
readWritableObject(DataInput, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.utils.WritableUtils
Reads object from input stream
RECEIVED_BYTES - Static variable in interface org.apache.giraph.metrics.MetricNames
Number of bytes received in superstep
receivedInputSplit(InputType, byte[]) - Method in class org.apache.giraph.worker.WorkerInputSplitsHandler
Called when an input split has been received from master, adding it to the map
receivedMessage(Long, Long) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
Each time a message is received, it has to be removed from the queue that keeps track of the waited messages.
receivedPartitionStats(List<PartitionStats>) - Method in class org.apache.giraph.master.MasterGlobalCommHandler
Received partition stats from a worker
receivedRequestCountFromMaster(long, int) - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
Notify this object about the total number of requests which should arrive from master.
receivedRequestCountFromWorker(long, int) - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
Notify this object about the total number of requests which should arrive from one of the workers.
receivedRequestCountFromWorker(long, int) - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Notify this object about the total number of requests which should arrive from one of the workers.
receivedRequestFromMaster(byte[]) - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
Notify this object that an aggregator request from master has been received.
receivedRequestFromWorker() - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
Notify this object that an aggregator request from some worker has been received.
receivedRequestFromWorker() - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Notify this object that a partial aggregated values request from some worker have been received.
receiveIgnoreExistingVertices() - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify that receive of this Piece (and send of next Piece) ignore existing vertices, and just process received messages.
receiveValueFromMaster(String, GlobalCommType, Writable) - Method in class org.apache.giraph.comm.aggregators.AllAggregatorServerData
Received value through global communication from master.
recompute(Vertex<LongWritable, DoubleWritable, NullWritable>, Iterable<DoubleWritable>, double) - Method in class org.apache.giraph.examples.PageRankComputation
 
recompute(Vertex<LongWritable, DoubleWritable, E>, Iterable<DoubleWritable>, double) - Method in class org.apache.giraph.examples.RandomWalkComputation
Perform a single step of a random walk computation.
recompute(Vertex<LongWritable, DoubleWritable, DoubleWritable>, Iterable<DoubleWritable>, double) - Method in class org.apache.giraph.examples.RandomWalkWithRestartComputation
 
recordsRead - Variable in class org.apache.giraph.examples.GeneratedEdgeReader
Records read so far
recordsRead - Variable in class org.apache.giraph.examples.GeneratedVertexReader
Records read so far
reduce(LongWritable, LongWritable) - Method in class org.apache.giraph.benchmark.ReducersBenchmark.TestLongSumReducer
 
reduce(S) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
reduce(S) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
reduce(S) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Reduce single value
reduce(S) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle
Reduce single value
reduce(String, ReduceOperation<S, R>, SupplierFromVertex<I, V, E, S>, Consumer<R>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates single reducer piece - given reduce class, supplier of values on worker, reduces and passes the result to given consumer on master.
reduce(ArrayWritable<R>, Pair<PrimitiveRefs.IntRef, S>) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
reduce(WArrayList<R>, Pair<PrimitiveRefs.IntRef, S>) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
reduce(WArrayList<S>, S) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
reduce(List<S>, S) - Method in class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
reduce(List<Object>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Reduce single value
reduce(List<WArrayList>, List<Object>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
reduce(S) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
reduce(Basic2ObjectMap<K, R>, Pair<K, S>) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
reduce(PriorityQueue<S>, S) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
reduce(String, Writable) - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Reduce partial value of one of current worker's reducers.
reduce(A, A) - Method in class org.apache.giraph.master.AggregatorReduceOperation
 
reduce(BooleanWritable, BooleanWritable) - Method in class org.apache.giraph.reducers.impl.AndReduce
 
reduce(R, S) - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
Look at ReduceOperation.reduce.
reduce(KryoWritableWrapper<R>, S) - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
 
reduce(LongWritable, LongWritable) - Method in class org.apache.giraph.reducers.impl.LongXorReduce
 
reduce(PairWritable<L, R>, PairWritable<L, R>) - Method in class org.apache.giraph.reducers.impl.MaxPairReducer
 
reduce(T, T) - Method in class org.apache.giraph.reducers.impl.MaxReduce
 
reduce(T, T) - Method in class org.apache.giraph.reducers.impl.MinReduce
 
reduce(BooleanWritable, BooleanWritable) - Method in class org.apache.giraph.reducers.impl.OrReduce
 
reduce(PairWritable<R1, R2>, Pair<S1, S2>) - Method in class org.apache.giraph.reducers.impl.PairReduce
 
reduce(T, T) - Method in class org.apache.giraph.reducers.impl.SumReduce
 
reduce(R, S) - Method in interface org.apache.giraph.reducers.ReduceOperation
Add a new value.
reduce(S) - Method in class org.apache.giraph.reducers.Reducer
Reduce given value into current reduced value.
reduce(String, Object) - Method in class org.apache.giraph.worker.WorkerAggregatorDelegator
 
reduce(String, Object) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
 
reduce(String, Object) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage
 
reduce(String, Object) - Method in interface org.apache.giraph.worker.WorkerReduceUsage
Reduce given value.
reduceAndBroadcast(String, ReduceOperation<S, R>, SupplierFromVertex<I, V, E, S>, ConsumerWithVertex<I, V, E, R>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates single reducer and broadcast piece - given reduce class, supplier of values on worker, reduces and broadcasts the value, passing it to the consumer on worker for each vertex.
reduceAndBroadcastWithArrayOfHandles(String, int, Supplier<ReduceOperation<S, R>>, SupplierFromVertex<I, V, E, Long>, SupplierFromVertex<I, V, E, S>, ConsumerWithVertex<I, V, E, R>) - Static method in class org.apache.giraph.block_app.library.Pieces
Like reduceAndBroadcast, but uses array of handles for reducers and broadcasts, to make it feasible and performant when values are large.
reduceDouble(ReducerHandle<DoubleWritable, ?>, double) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceDouble(ReducerHandle<DoubleWritable, ?>, double) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceFloat(ReducerHandle<FloatWritable, ?>, float) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceFloat(ReducerHandle<FloatWritable, ?>, float) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceInt(ReducerHandle<IntWritable, ?>, int) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceInt(ReducerHandle<IntWritable, ?>, int) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceLong(ReducerHandle<LongWritable, ?>, long) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceLong(ReducerHandle<LongWritable, ?>, long) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceMerge(ArrayWritable<R>, ArrayWritable<R>) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
reduceMerge(WArrayList<R>, WArrayList<R>) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
reduceMerge(WArrayList<S>, WArrayList<S>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
reduceMerge(List<S>, List<S>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
reduceMerge(List<WArrayList>, List<WArrayList>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
reduceMerge(Basic2ObjectMap<K, R>, Basic2ObjectMap<K, R>) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
reduceMerge(PriorityQueue<S>, PriorityQueue<S>) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
reduceMerge(R, R) - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
Look at ReduceOperation.reduceMerge.
reduceMerge(KryoWritableWrapper<R>, KryoWritableWrapper<R>) - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
 
reduceMerge(PairWritable<R1, R2>, PairWritable<R1, R2>) - Method in class org.apache.giraph.reducers.impl.PairReduce
 
reduceMerge(R, R) - Method in interface org.apache.giraph.reducers.ReduceOperation
Add partially reduced value to current partially reduced value.
reduceMerge(R) - Method in class org.apache.giraph.reducers.Reducer
Reduce given partially reduced value into current reduced value.
reduceMerge(R, R) - Method in class org.apache.giraph.reducers.ReduceSameTypeOperation
 
reduceMerge(String, Writable) - Method in class org.apache.giraph.worker.WorkerAggregatorDelegator
 
reduceMerge(String, Writable) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler
Combine partially reduced value into currently reduced value.
reduceMerge(String, Writable) - Method in class org.apache.giraph.worker.WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage
 
reduceMerge(String, Writable) - Method in interface org.apache.giraph.worker.WorkerReduceUsage
Reduce given partial value.
reduceOp - Variable in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
ReduceOperation<S,R extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.reducers
Reduce operations defining how to reduce single values passed on workers, into partial values on workers, and then into a single global reduced value.
Reducer<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.reducers
Object responsible for performing reducing operation.
Reducer() - Constructor for class org.apache.giraph.reducers.Reducer
Constructor
Reducer(ReduceOperation<S, R>) - Constructor for class org.apache.giraph.reducers.Reducer
Constructor
Reducer(ReduceOperation<S, R>, R) - Constructor for class org.apache.giraph.reducers.Reducer
Constructor
REDUCER_COUNT - Static variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
ReducerAndBroadcastWrapperHandle<S,R> - Class in org.apache.giraph.block_app.framework.piece.global_comm
Handle that wraps both reducerHandle and broadcastHandle, so callers don't need to have two fields.
ReducerAndBroadcastWrapperHandle() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
 
ReducerArrayHandle<S,R> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.array
Handle to array of reducers
ReducerHandle<S,R> - Interface in org.apache.giraph.block_app.framework.piece.global_comm
Handle to a reducer.
ReducerMapHandle<I,S,R> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.map
Handle to array of reducers
reducers - Variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
ReducersBenchmark - Class in org.apache.giraph.benchmark
Benchmark for reducers.
ReducersBenchmark() - Constructor for class org.apache.giraph.benchmark.ReducersBenchmark
 
ReducersBenchmark.ReducersBenchmarkComputation - Class in org.apache.giraph.benchmark
Vertex class for ReducersBenchmark
ReducersBenchmark.ReducersBenchmarkMasterCompute - Class in org.apache.giraph.benchmark
MasterCompute class for ReducersBenchmark
ReducersBenchmark.ReducersBenchmarkWorkerContext - Class in org.apache.giraph.benchmark
WorkerContext class for ReducersBenchmark
ReducersBenchmark.TestLongSumReducer - Class in org.apache.giraph.benchmark
LongSumReducer
ReducersBenchmarkComputation() - Constructor for class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkComputation
 
ReducersBenchmarkMasterCompute() - Constructor for class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkMasterCompute
 
ReducersBenchmarkWorkerContext() - Constructor for class org.apache.giraph.benchmark.ReducersBenchmark.ReducersBenchmarkWorkerContext
 
ReducersForPieceHandler - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
All logic for transforming Giraph's reducer API to reducer handles.
ReducersForPieceHandler() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
ReducersForPieceHandler.BroadcastHandleImpl<T> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Implementation of BroadcastHandle
ReducersForPieceHandler.GlobalReduceHandle<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Global Reduce Handle is implementation of ReducerHandle, that will keep only one value for each worker, and each call to reduce will have to obtain a global lock, and incur synchronization costs.
ReducersForPieceHandler.LocalReduceHandle<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Local Reduce Handle is implementation of ReducerHandle, that will make a partially reduced value on each worker thread, which are at the end reduced all together.
ReducersForPieceHandler.ReduceHandleImpl<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Parent implementation of ReducerHandle
ReducersForPieceHandler.WrappedReducedValue<R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Wrapper that makes reduced values self-serializable, and allows them to be broadcasted.
ReduceSameTypeOperation<R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.reducers
ReduceOperation object when single object being reduced is of same type as reduced value.
ReduceSameTypeOperation() - Constructor for class org.apache.giraph.reducers.ReduceSameTypeOperation
 
ReduceUtilsObject - Class in org.apache.giraph.block_app.framework.piece.global_comm
Utility object with common primitive reduce operations, without need to create reusable objects within the piece.
ReduceUtilsObject() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceWithMaster(String, ReduceOperation<S, R>, SupplierFromVertex<I, V, E, S>, PairConsumer<R, BlockMasterApi>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates single reducer piece - given reduce class, supplier of values on worker, reduces and passes the result to given consumer on master.
ReflectionUtils - Class in org.apache.giraph.utils
Helper methods to get type arguments to generic classes.
refreshCache() - Static method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Refreshes class-ID mapping from zookeeper.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrixSumAggregator
Register the double vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrixSumAggregator
Register the float vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrixSumAggregator
Register the int vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrixSumAggregator
Register the long vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrixSumAggregator
Register the double vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrixSumAggregator
Register the float vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrixSumAggregator
Register the int vector aggregators, one for each row of the matrix.
register(int, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrixSumAggregator
Register the long vector aggregators, one for each row of the matrix.
register(OD, GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
register(CreateReducersApi) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
register(Registration) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
 
register(Kryo, Class<?>) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register serializer for a given fastutil class.
registerAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
 
registerAggregator(String, Class<? extends Aggregator<A>>) - Method in interface org.apache.giraph.master.MasterAggregatorUsage
Register an aggregator in preSuperstep() and/or preApplication().
registerAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.master.MasterCompute
 
registerAggregator(MasterAggregatorUsage, Configuration) - Static method in class org.apache.giraph.utils.MasterLoggingAggregator
Register master logging aggregator, if the option for using it is set in the configuration.
registerAggregators(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Deprecated.
Use registerReducers instead.
registerAggregators(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
registerAggregators(BlockMasterApi) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
registerAll(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Registers serializers for all possible fastutil classes.
registerArrayBigList(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil ArrayBigLists.
registerArrayLists(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil ArrayLists.
registerArraySets(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil ArraySets.
registerAVLTreeMaps(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil AVLTreeMaps.
registerAVLTreeSets(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil AVLTreeSets.
registerBspEvent(BspEvent) - Method in class org.apache.giraph.bsp.BspService
Register a BspEvent.
registeredReducer(ReducerHandle<S, R>) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Set reducer handle to just registered handle
registeredReducer(CreateReducersApi, Class<?>...) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Set reducer handle to just registered handle
registerImplicit(Class) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
 
registerOpenHashMaps(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil OpenHashMaps.
registerOpenHashSets(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil OpenHashSets.
registerOutputs(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
registerOutputs(GiraphConfiguration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Register outputs to use during the application (vs output at the end of the application), based on provided configuration.
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in interface org.apache.giraph.block_app.framework.api.BlockMasterApi
Deprecated.
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
 
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in interface org.apache.giraph.master.MasterAggregatorUsage
Register persistent aggregator in preSuperstep() and/or preApplication().
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.master.MasterCompute
 
registerRBTreeMaps(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil RBTreeMaps.
registerRBTreeSets(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
Register all Fastutil RBTreeSets.
registerReducer(String, ReduceOperation<S, R>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerReducer(String, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerReducer(String, ReduceOperation<Object, Writable>) - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Register a reducer which current worker owns.
registerReducer(String, ReduceOperation<S, R>) - Method in class org.apache.giraph.master.MasterAggregatorHandler
 
registerReducer(String, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.master.MasterAggregatorHandler
 
registerReducer(String, ReduceOperation<S, R>) - Method in class org.apache.giraph.master.MasterCompute
 
registerReducer(String, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.master.MasterCompute
 
registerReducer(String, ReduceOperation<S, R>) - Method in class org.apache.giraph.master.MasterGlobalCommHandler
 
registerReducer(String, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.master.MasterGlobalCommHandler
 
registerReducer(String, ReduceOperation<S, R>) - Method in interface org.apache.giraph.master.MasterGlobalCommUsageAggregators
Register reducer to be reduced in the next worker computation, using given name and operations.
registerReducer(String, ReduceOperation<S, R>, R) - Method in interface org.apache.giraph.master.MasterGlobalCommUsageAggregators
Register reducer to be reduced in the next worker computation, using given name and operations, starting globally from globalInitialValue.
registerReducers(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
registerReducers(CreateReducersApi, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to register any potential reducers used by this piece, through calls to reduceApi, which will return reducer handles for simple.
registerSerializers(Kryo) - Static method in class org.apache.giraph.writable.kryo.serializers.ImmutableBiMapSerializerUtils
Registers different ImmutableBiMap implementations with Kryo.
reinitializeVertexFromByteArray(byte[], Vertex<I, V, E>, boolean, ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Read vertex data from byteArray to a Writeable object, skipping the size.
reinitializeVertexFromDataInput(DataInput, Vertex<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Reads data from input stream to initialize Vertex.
releaseCurrentData() - Method in class org.apache.giraph.utils.ByteStructVertexIdDataIterator
 
releaseCurrentData() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
releaseCurrentData() - Method in interface org.apache.giraph.utils.VertexIdDataIterator
Release the current data object.
releaseCurrentEdge() - Method in class org.apache.giraph.utils.ByteStructVertexIdEdgeIterator
 
releaseCurrentEdge() - Method in interface org.apache.giraph.utils.VertexIdEdgeIterator
Release the current edge.
releaseCurrentVertexId() - Method in class org.apache.giraph.utils.ByteStructVertexIdIterator
 
releaseCurrentVertexId() - Method in class org.apache.giraph.utils.OneMessageToManyIdsIterator
 
releaseCurrentVertexId() - Method in interface org.apache.giraph.utils.VertexIdIterator
The backing store of the current vertex id is now released.
releaseCurrentVertexId() - Method in class org.apache.giraph.utils.VertexIterator
The backing store of the current vertex id is now released.
releaseOnePermit() - Method in class org.apache.giraph.utils.TaskIdsPermitsBarrier
Release one permit.
releasePermits(long) - Method in class org.apache.giraph.utils.TaskIdsPermitsBarrier
Release some permits.
releaseVertex() - Method in class org.apache.giraph.utils.VertexIterator
Release the ownership of the Vertex object to the caller
REMOTE_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter of requets sent on the wire
remove() - Method in class org.apache.giraph.comm.SendMessageCache.TargetVertexIdIterator
 
remove(I) - Method in class org.apache.giraph.edge.ArrayListEdges
 
remove(I) - Method in class org.apache.giraph.edge.ByteArrayEdges
 
remove(I) - Method in class org.apache.giraph.edge.HashMapEdges
 
remove(I) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
remove(I) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
remove(I) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
remove(IntWritable) - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
remove(LongWritable) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
remove(long) - Method in class org.apache.giraph.edge.LongDiffArray
Remove a given value
remove(LongWritable) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
remove(LongWritable) - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
remove(LongWritable) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
remove(LongWritable) - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
remove(LongWritable) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
remove(I) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
remove(I) - Method in interface org.apache.giraph.edge.OutEdges
Remove all edges to the given target vertex.
remove(IntWritable) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
remove(LongWritable) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
remove(K) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
remove(K) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Removes the mapping with the given key.
remove() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.ReusableIterator
 
remove() - Method in class org.apache.giraph.utils.ByteStructIterator
 
removeAllData() - Method in class org.apache.giraph.comm.SendDataCache
Gets all the data and removes it from the cache.
removeAllEdges() - Method in class org.apache.giraph.comm.SendEdgeCache
Gets all the edges and removes them from the cache.
removeAllPartitionMutations() - Method in class org.apache.giraph.comm.SendMutationsCache
Gets all the mutations and removes them from the cache.
removeChannel(Channel) - Method in class org.apache.giraph.comm.netty.ChannelRotater
Remove the a channel
removeEdge(I) - Method in class org.apache.giraph.graph.VertexMutations
Remove an edge on this vertex
removeEdgeMutation(Integer, I, I) - Method in class org.apache.giraph.comm.SendMutationsCache
Add a remove edge mutation to the cache.
removeEdges(I) - Method in class org.apache.giraph.graph.DefaultVertex
 
removeEdges(Vertex<I, V, E>, VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Remove edges as specifed in changes given.
removeEdges(I) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
removeEdges(I) - Method in interface org.apache.giraph.graph.Vertex
Removes all edges pointing to the given vertex id.
removeEdgesRequest(I, I) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Request to remove all edges from a given source vertex to a given target vertex (processed just prior to the next receive phase).
removeEdgesRequest(I, I) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
removeEdgesRequest(I, I) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
removeEdgesRequest(I, I) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a request to the appropriate vertex range owner to remove all edges pointing to a given vertex.
removeEdgesRequest(I, I) - Method in class org.apache.giraph.graph.AbstractComputation
Request to remove all edges from a given source vertex to a given target vertex (processed just prior to the next superstep).
removeEdgesRequest(I, I) - Method in interface org.apache.giraph.graph.Computation
Request to remove all edges from a given source vertex to a given target vertex (processed just prior to the next superstep).
removeEdgesRequest(Object, Object) - Method in class org.apache.giraph.jython.JythonComputation
Request to remove all edges from a given source vertex to a given target vertex (processed just prior to the next superstep).
removeLastIndex() - Method in class org.apache.giraph.ooc.persistence.DataIndex
Remove/Pop the last index in the index chain
removeListener(MetricsRegistryListener) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
removeMappingStoreIfPossible() - Method in class org.apache.giraph.worker.LocalData
Remove mapping store from localData if mapping data is already embedded into vertexIds
removeMetric(Class<?>, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
removeMetric(Class<?>, String, String) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
removeMetric(MetricName) - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removeMin() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Removes the (key, value) pair that corresponds to the minimum value currently in the heap.
removePartition(Integer) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
removePartition(Integer) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Remove a partition.
removePartition(Integer) - Method in interface org.apache.giraph.partition.PartitionStore
Remove a partition and return it.
removePartition(Integer) - Method in class org.apache.giraph.partition.SimplePartitionStore
 
removePartitionMutations(int) - Method in class org.apache.giraph.comm.SendMutationsCache
Gets the mutations for a partition and removes it from the cache.
removeRequest(LongWritable, LongWritable) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
remove the expected request from the edge on which the message arrived
removeSerialized(Integer) - Method in class org.apache.giraph.comm.aggregators.SendGlobalCommCache
Remove and get values for certain worker
removeTargetInfo(LongWritable) - Method in class org.apache.giraph.mapping.DefaultEmbeddedLongByteOps
 
removeTargetInfo(LongWritable) - Method in class org.apache.giraph.mapping.DefaultLongByteOps
 
removeTargetInfo(I) - Method in interface org.apache.giraph.mapping.MappingStoreOps
Remove target information from vertexId
removeVertex() - Method in class org.apache.giraph.graph.VertexMutations
Removed a vertex mutation (increments a count)
removeVertex(I) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
removeVertex(I) - Method in interface org.apache.giraph.partition.Partition
Remove a vertex from the Partition
removeVertex(I) - Method in class org.apache.giraph.partition.SimplePartition
 
removeVertexIfDesired(Vertex<I, V, E>, VertexChanges<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
Remove the vertex itself if the changes desire it.
removeVertexMutation(Integer, I) - Method in class org.apache.giraph.comm.SendMutationsCache
Add a remove vertex mutation to the cache.
removeVertexRequest(I) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Request to remove a vertex from the graph (applied just prior to the next receive phase).
removeVertexRequest(I) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
removeVertexRequest(I) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
removeVertexRequest(I) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a request to the appropriate vertex range owner to remove a vertex
removeVertexRequest(I) - Method in class org.apache.giraph.graph.AbstractComputation
Request to remove a vertex from the graph (applied just prior to the next superstep).
removeVertexRequest(I) - Method in interface org.apache.giraph.graph.Computation
Request to remove a vertex from the graph (applied just prior to the next superstep).
removeVertexRequest(Object) - Method in class org.apache.giraph.jython.JythonComputation
Request to remove a vertex from the graph (applied just prior to the next superstep).
removeVertices(String, SupplierFromVertex<I, V, E, Boolean>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece which removes vertices for which supplier returns true.
removeWorkerData(WorkerInfo) - Method in class org.apache.giraph.comm.SendDataCache
Gets the data for a worker and removes it from the cache.
removeWorkerEdges(WorkerInfo) - Method in class org.apache.giraph.comm.SendEdgeCache
Gets the edges for a worker and removes it from the cache.
removeWorkerMessages(WorkerInfo) - Method in class org.apache.giraph.comm.SendMessageCache
Gets the messages for a worker and removes it from the cache.
RepeatBlock - Class in org.apache.giraph.block_app.framework.block
Block that repeats another block given number of times.
RepeatBlock(int, Block) - Constructor for class org.apache.giraph.block_app.framework.block.RepeatBlock
 
RepeatBlock(IntSupplier, Block) - Constructor for class org.apache.giraph.block_app.framework.block.RepeatBlock
Creates a repeat block, that before starting execution takes number of iterations from the given supplier.
RepeatUntilBlock - Class in org.apache.giraph.block_app.framework.block
Block that repeats another block until toQuit supplier returns true, but at most given number of times.
RepeatUntilBlock(int, Block, Supplier<Boolean>) - Constructor for class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
ReplyWithInputSplitRequest - Class in org.apache.giraph.comm.requests
A request which master will send to workers to give them splits
ReplyWithInputSplitRequest(InputType, byte[]) - Constructor for class org.apache.giraph.comm.requests.ReplyWithInputSplitRequest
Constructor
ReplyWithInputSplitRequest() - Constructor for class org.apache.giraph.comm.requests.ReplyWithInputSplitRequest
Constructor used for reflection only
RepresentativeByteStructIterable<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
The objects provided by the iterators generated from this object have lifetimes only until next() is called.
RepresentativeByteStructIterable(Factory<? extends ExtendedDataInput>) - Constructor for class org.apache.giraph.utils.RepresentativeByteStructIterable
Constructor
RepresentativeByteStructIterator<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
The objects provided by this iterator have lifetimes only until next() is called.
RepresentativeByteStructIterator(ExtendedDataInput) - Constructor for class org.apache.giraph.utils.RepresentativeByteStructIterator
Wrap ExtendedDataInput in ByteArrayIterator
REQUEST_SIZE_WARNING_THRESHOLD - Static variable in interface org.apache.giraph.conf.GiraphConstants
Warn if msg request size exceeds default size by this factor
RequestDecoder - Class in org.apache.giraph.comm.netty.handler
Decodes encoded requests from the client.
RequestDecoder(ImmutableClassesGiraphConfiguration, InboundByteCounter) - Constructor for class org.apache.giraph.comm.netty.handler.RequestDecoder
Constructor.
RequestEncoder - Class in org.apache.giraph.comm.netty.handler
Requests have a request type and an encoded request.
RequestEncoder(GiraphConfiguration) - Constructor for class org.apache.giraph.comm.netty.handler.RequestEncoder
Constructor.
RequestInfo - Class in org.apache.giraph.comm.netty.handler
Help track requests throughout the system
RequestInfo(InetSocketAddress, WritableRequest) - Constructor for class org.apache.giraph.comm.netty.handler.RequestInfo
Constructor.
RequestServerHandler<R> - Class in org.apache.giraph.comm.netty.handler
Generic handler of requests.
RequestServerHandler(WorkerRequestReservedMap, ImmutableClassesGiraphConfiguration, TaskInfo, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.giraph.comm.netty.handler.RequestServerHandler
Constructor
RequestServerHandler.Factory - Interface in org.apache.giraph.comm.netty.handler
RequestType - Enum in org.apache.giraph.comm.requests
Type of the request
RequestUtils - Class in org.apache.giraph.utils
RequestUtils utility class
require(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
Ensure that this buffer has enough remaining space to add the size.
require(int) - Method in class org.apache.giraph.utils.UnsafeReads
Check whether there are enough remaining bytes for an operation
requirePermits(long, int) - Method in class org.apache.giraph.utils.TaskIdsPermitsBarrier
Require more permits.
RESEND_TIMED_OUT_REQUESTS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Whether to resend request which timed out or fail the job if timeout happens
reserveInputSplit(InputType, boolean) - Method in class org.apache.giraph.worker.WorkerInputSplitsHandler
Try to reserve an InputSplit for loading.
reserveRequest(Integer, long) - Method in class org.apache.giraph.comm.netty.handler.WorkerRequestReservedMap
Reserve the request (before the request starts to insure that it is only executed once).
reset() - Method in interface org.apache.giraph.aggregators.Aggregator
Reset the value of aggregator to neutral value
reset() - Method in class org.apache.giraph.aggregators.BasicAggregator
 
reset() - Method in class org.apache.giraph.comm.aggregators.CountingCache
Reset the counts
reset() - Method in class org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
Prepare for next superstep
reset() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Reset partitions and messages meta data.
reset() - Method in interface org.apache.giraph.types.ops.collections.ResettableIterator
Rewinds iterator to the beginning.
reset() - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Clears the buffer
reset() - Method in class org.apache.giraph.utils.ThreadLocalProgressCounter
Removes all counters.
reset() - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
reset() - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Reset the internal state Reset clears two hash tables: 1 - Class name to ID: Every non-explicitly registered class takes the ID agreed by all kryo instances, and it doesn't change across serializations, so this reset is not required.
reset() - Method in interface org.apache.giraph.zk.BspEvent
Reset the permanent signal.
reset() - Method in class org.apache.giraph.zk.PredicateLock
 
resetAll() - Method in interface org.apache.giraph.comm.netty.ByteCounter
Reset everything this object keeps track of
resetAll() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
 
resetAll() - Method in class org.apache.giraph.comm.netty.InboundByteCounter
 
resetAll() - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
resetBytes() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Reset all the bytes kept track of.
resetBytesProcessedPerSuperstep() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Set bytes processed per superstep to 0.
resetBytesReceivedPerSuperstep() - Method in class org.apache.giraph.comm.netty.InboundByteCounter
Set bytes received per superstep to 0.
resetBytesReceivedPerSuperstep() - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
resetBytesReceivedPerSuperstep() - Method in interface org.apache.giraph.comm.NetworkMetrics
Resets the counter for bytes received per superstep.
resetMessageBytesCount() - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
resetMessageBytesCount() - Method in class org.apache.giraph.comm.SendMessageCache
Reset the message bytes count per superstep.
resetMessageBytesCount() - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Get the message bytes sent during this superstep and clear them.
resetMessageCount() - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
resetMessageCount() - Method in class org.apache.giraph.comm.SendMessageCache
Reset the message count per superstep.
resetMessageCount() - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Get the messages sent during this superstep and clear them.
resetMessages() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Reset messages in the meta store.
resetMessageStores() - Method in class org.apache.giraph.comm.ServerData
Re-initialize message stores.
resetPartitions() - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Reset the meta store for a new iteration cycle over all partitions.
resetStartMsecs() - Method in class org.apache.giraph.comm.netty.ByteCounterDelegate
Reset the start msecs.
resetSuperstepMetrics(long) - Method in class org.apache.giraph.metrics.GiraphMetrics
Reset the per-superstep MetricsRegistry
ResetSuperstepMetricsObserver - Interface in org.apache.giraph.metrics
Observer for users of per-superstep counters.
ResettableIterator<T> - Interface in org.apache.giraph.types.ops.collections
Defines an iterator that can iterated over multiple times, by rewinding it via reset() function.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Resize array for reading given number of elements.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList.WReusableBooleanArrayList
 
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
Resize array for reading given number of elements.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList.WReusableByteArrayList
 
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Resize array for reading given number of elements.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList.WReusableDoubleArrayList
 
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Resize array for reading given number of elements.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList.WReusableFloatArrayList
 
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
Resize array for reading given number of elements.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList.WReusableIntArrayList
 
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
Resize array for reading given number of elements.
resizeArrayForRead(int) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList.WReusableLongArrayList
 
resolve(I, Vertex<I, V, E>, VertexChanges<I, V, E>, boolean) - Method in class org.apache.giraph.graph.DefaultVertexResolver
 
resolve(I, Vertex<I, V, E>, VertexChanges<I, V, E>, boolean) - Method in interface org.apache.giraph.graph.VertexResolver
A vertex may have been removed, created zero or more times and had zero or more messages sent to it.
resolvePartitionMutation(Partition<I, V, E>) - Method in class org.apache.giraph.comm.ServerData
Resolve mutations specific for a partition.
RESOLVER_CREATE_VERTEX_ON_MSGS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Option of whether to create vertexes that were not existent before but received messages
response(byte[]) - Method in class org.apache.giraph.comm.netty.SaslNettyServer
Used by SaslTokenMessage::processToken() to respond to server SASL tokens.
RESPONSE_BYTES - Static variable in class org.apache.giraph.comm.netty.handler.RequestServerHandler
Number of bytes in the encoded response
ResponseClientHandler - Class in org.apache.giraph.comm.netty.handler
Generic handler of responses.
ResponseClientHandler(NettyClient, Configuration) - Constructor for class org.apache.giraph.comm.netty.handler.ResponseClientHandler
Constructor.
ResponseEncoder - Class in org.apache.giraph.comm.netty.handler
How a server should respond to a client.
ResponseEncoder() - Constructor for class org.apache.giraph.comm.netty.handler.ResponseEncoder
 
RESTART_JOB_ID - Static variable in interface org.apache.giraph.conf.GiraphConstants
If application is restarted manually we need to specify job ID to restart from.
RESTART_SUPERSTEP - Static variable in interface org.apache.giraph.conf.GiraphConstants
An application can be restarted manually by selecting a superstep.
restartFromCheckpoint(long) - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Master can decide to restart from the last good checkpoint if a worker fails during a superstep.
restartFromCheckpoint(long) - Method in class org.apache.giraph.master.BspServiceMaster
 
retrievePartition(int) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Retrieve a particular partition.
RETRYABLE_JOB_PROGRESS_CLIENT_NUM_RETRIES - Static variable in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
Conf option for number of retries
RETRYABLE_JOB_PROGRESS_CLIENT_RETRY_WAIT_MS - Static variable in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
Conf option for wait time between retries
RetryableJobProgressTrackerClient - Class in org.apache.giraph.graph
Wrapper around JobProgressTracker which retries to connect and swallows exceptions so app wouldn't crash if something goes wrong with progress reports.
RetryableJobProgressTrackerClient() - Constructor for class org.apache.giraph.graph.RetryableJobProgressTrackerClient
Default constructor.
RetryableJobProgressTrackerClient(GiraphConfiguration) - Constructor for class org.apache.giraph.graph.RetryableJobProgressTrackerClient
Constructor
returnAllWriters() - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
returnVertexWriter(SimpleVertexWriter<I, V, E>) - Method in class org.apache.giraph.io.superstep_output.MultiThreadedSuperstepOutput
 
returnVertexWriter(SimpleVertexWriter<I, V, E>) - Method in class org.apache.giraph.io.superstep_output.NoOpSuperstepOutput
 
returnVertexWriter(SimpleVertexWriter<I, V, E>) - Method in interface org.apache.giraph.io.superstep_output.SuperstepOutput
Return the Writer after usage, which you got by calling SuperstepOutput.getVertexWriter()
returnVertexWriter(SimpleVertexWriter<I, V, E>) - Method in class org.apache.giraph.io.superstep_output.SynchronizedSuperstepOutput
 
ReusableEdge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
A complete edge, the target vertex and the edge value.
ReusableFieldSerializer<T> - Class in org.apache.giraph.writable.kryo.serializers
Serializer used to deserialize data into object, instead of creating a new value readIntoObject needs to be set right before deserialization is called on it.
ReusableFieldSerializer(Kryo, Class) - Constructor for class org.apache.giraph.writable.kryo.serializers.ReusableFieldSerializer
Creates new reusable field serializer for a given type.
ReusableIterator(Iter) - Constructor for class org.apache.giraph.types.ops.collections.Basic2ObjectMap.ReusableIterator
Constructor
reusableKey - Variable in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.ReusableIterator
Reusable key object
reuseEdgeObjects() - Method in class org.apache.giraph.conf.GiraphConfiguration
True if the OutEdges implementation copies the passed edges to its own data structure, i.e.
reuseEdgeObjects - Variable in class org.apache.giraph.edge.AbstractEdgeStore
Whether the chosen OutEdges implementation allows for Edge reuse.
ReuseObjectsOutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Empty interface to characterize OutEdges implementations that don't keep references to the Edge (or id and value) objects they are passed.
ReusesObjectsPartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.partition
Empty interface to characterize Partition implementations that don't keep references to the Vertex objects they are passed.
reuseVertexObjects() - Method in class org.apache.giraph.conf.GiraphConfiguration
True if the Partition implementation copies the passed vertices to its own data structure, i.e.
REVERSE_ID_AND_VALUE - Static variable in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat
Reverse id and value order?
REVERSE_ID_AND_VALUE_DEFAULT - Static variable in class org.apache.giraph.io.formats.IdWithValueTextOutputFormat
Default is to not reverse id and value order.
REVERSE_ID_ORDER - Static variable in class org.apache.giraph.examples.GeneratedVertexReader
Reverse the order of the vertices?
ReverseEdgeDuplicator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
An EdgeReader that creates the opposite direction edge for each edge read.
ReverseEdgeDuplicator(EdgeReader<I, E>) - Constructor for class org.apache.giraph.io.ReverseEdgeDuplicator
Constructor
reverseIdOrder - Variable in class org.apache.giraph.examples.GeneratedVertexReader
Reverse the id order?
run(String[]) - Method in class org.apache.giraph.benchmark.GiraphBenchmark
 
run(String[]) - Method in class org.apache.giraph.examples.SimpleCheckpoint
 
run(String[]) - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext
 
run(String[]) - Method in class org.apache.giraph.GiraphRunner
 
run(Mapper<Object, Object, Object, Object>.Context) - Method in class org.apache.giraph.graph.GraphMapper
 
run(boolean) - Method in class org.apache.giraph.job.GiraphJob
Runs the actual graph application through Hadoop Map-Reduce.
run() - Method in class org.apache.giraph.master.MasterThread
The master algorithm.
run(GiraphConfiguration, String[]) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading from and writing to a temporary folder on local disk.
run(GiraphConfiguration, String[], String[]) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading from and writing to a temporary folder on local disk.
run(GiraphConfiguration, String[], String[], String, File) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading from and writing to a temporary folder on local disk.
run(GiraphConfiguration, TestGraph<I, V, E>) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading from an in-memory graph.
run(GiraphConfiguration, TestGraph<I, V, E>, File, String) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading from an in-memory graph.
run(boolean) - Method in class org.apache.giraph.yarn.GiraphYarnClient
Submit a request to the Hadoop YARN cluster's ResourceManager to obtain an application container.
run() - Method in class org.apache.giraph.yarn.GiraphYarnTask
Run one Giraph worker (or master) task, hosted in this execution container.
run(String[]) - Method in class org.apache.giraph.zk.GiraphZooKeeperAdmin
Clean the ZooKeeper of all failed and cancelled in-memory job remnants that pile up on the ZK quorum over time.
run(String[]) - Method in class org.apache.giraph.zk.ZooKeeperNodeCreator
 
RUN_ALL_CHECKS - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Whether to run all supported checks.
runApp(TestGraph<I, V, E>, boolean) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block Application specified within the conf, on a given graph, locally, in-memory.
runApp(TestGraph<I, V, E>) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block Application specified within the conf, on a given graph, locally, in-memory.
runAppWithVertexOutput(TestGraph<I, V, E>, SimpleVertexWriter<I, V, E>) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block Application specified within the conf, on a given graph, locally, in-memory, with a given vertexSaver.
runBlock(TestGraph<I, V, E>, Block, Object) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block from a specified execution stage on a given graph, locally, in-memory.
runBlockWithVertexOutput(Block, Object, TestGraph<I, V, E>, SimpleVertexWriter<I, V, E>) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block from a specified execution stage on a given graph, locally, in-memory, with a given vertexSaver.
runFromConfig(ZookeeperConfig) - Method in class org.apache.giraph.zk.InProcessZooKeeperRunner.ZooKeeperServerRunner
Run from a ServerConfig.
runsZooKeeper() - Method in class org.apache.giraph.zk.ZooKeeperManager
Is this task running a ZooKeeper server? Only could be true if called after onlineZooKeeperServers().
runTest(TestGraphModifier<? super I, ? super V, ? super E>, TestGraphChecker<? super I, ? super V, ? super E>, BulkConfigurator) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Creates configuration using configurator, initializes the graph using graphInitializer, and checks it via graphChecker.
runTest(TestGraphModifier<? super I, ? super V, ? super E>, TestGraphChecker<? super I, ? super V, ? super E>, GiraphConfiguration) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Uses provided configuration, initializes the graph using graphInitializer, and checks it via graphChecker.
runTest(NumericTestGraph<I, V, E>, TestGraphChecker<? super I, ? super V, ? super E>) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Base of runTest.
runWithInMemoryOutput(GiraphConfiguration, TestGraph<I, V, E>) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading and writing to an in-memory graph.
runWithInMemoryOutput(GiraphConfiguration, TestGraph<I, V, E>, File, String) - Static method in class org.apache.giraph.utils.InternalVertexRunner
Attempts to run the vertex internally in the current JVM, reading and writing to an in-memory graph.

S

sameEdges(Iterable<Edge<I, E>>, Iterable<Edge<I, E>>) - Static method in class org.apache.giraph.utils.EdgeIterables
Compare two edge iterables up to reordering.
sanitize(String) - Method in interface org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.LineSanitizer
Clean string s before attempting to tokenize it.
SASL - Static variable in class org.apache.giraph.comm.netty.NettyClient
Used to authenticate with other workers acting as servers
SaslClientHandler - Class in org.apache.giraph.comm.netty.handler
Client-side Netty pipeline component that allows authentication with a server.
SaslClientHandler(Configuration) - Constructor for class org.apache.giraph.comm.netty.handler.SaslClientHandler
Constructor.
SaslCompleteRequest - Class in org.apache.giraph.comm.requests
Reply from server to client after SASL authentication completes.
SaslCompleteRequest() - Constructor for class org.apache.giraph.comm.requests.SaslCompleteRequest
Constructor used for reflection and sending.
SaslDigestCallbackHandler(JobTokenSecretManager) - Constructor for class org.apache.giraph.comm.netty.SaslNettyServer.SaslDigestCallbackHandler
Constructor
SaslNettyClient - Class in org.apache.giraph.comm.netty
Implements SASL logic for Giraph BSP worker clients.
SaslNettyClient() - Constructor for class org.apache.giraph.comm.netty.SaslNettyClient
Create a SaslNettyClient for authentication with BSP servers.
SaslNettyServer - Class in org.apache.giraph.comm.netty
Encapsulates SASL server logic for Giraph BSP worker servers.
SaslNettyServer(JobTokenSecretManager) - Constructor for class org.apache.giraph.comm.netty.SaslNettyServer
Constructor
SaslNettyServer(JobTokenSecretManager, SaslRpcServer.AuthMethod) - Constructor for class org.apache.giraph.comm.netty.SaslNettyServer
Constructor
SaslNettyServer.SaslDigestCallbackHandler - Class in org.apache.giraph.comm.netty
CallbackHandler for SASL DIGEST-MD5 mechanism
saslResponse(SaslTokenMessageRequest) - Method in class org.apache.giraph.comm.netty.SaslNettyClient
Respond to server's SASL token.
SaslServerHandler - Class in org.apache.giraph.comm.netty.handler
Generate SASL response tokens to client SASL tokens, allowing clients to authenticate themselves with this server.
SaslServerHandler(Configuration) - Constructor for class org.apache.giraph.comm.netty.handler.SaslServerHandler
Constructor
SaslServerHandler.Factory - Class in org.apache.giraph.comm.netty.handler
Factory for SaslServerHandler
SaslTokenMessageRequest - Class in org.apache.giraph.comm.requests
Send and receive SASL tokens.
SaslTokenMessageRequest() - Constructor for class org.apache.giraph.comm.requests.SaslTokenMessageRequest
Constructor used for reflection only.
SaslTokenMessageRequest(byte[]) - Constructor for class org.apache.giraph.comm.requests.SaslTokenMessageRequest
Constructor used to send request.
savedCheckpointBasePath - Variable in class org.apache.giraph.bsp.BspService
Old checkpoint in case we want to restart some job
saveVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
saveVertex(Vertex<I, V, E>) - Method in interface org.apache.giraph.partition.Partition
Save potentially modified vertex back to the partition.
saveVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.partition.SimplePartition
 
SccComputation - Class in org.apache.giraph.examples.scc
Finds strongly connected components of the graph.
SccComputation() - Constructor for class org.apache.giraph.examples.scc.SccComputation
 
SccLongLongNullTextInputFormat - Class in org.apache.giraph.examples.scc
Simple text-based VertexInputFormat for unweighted graphs with long ids.
SccLongLongNullTextInputFormat() - Constructor for class org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat
 
SccLongLongNullTextInputFormat.LongLongNullVertexReader - Class in org.apache.giraph.examples.scc
Vertex reader associated with SccLongLongNullTextInputFormat.
SccPhaseMasterCompute - Class in org.apache.giraph.examples.scc
This master compute keeps track of what phase is being currently executed by the Strongly Connected Components computation.
SccPhaseMasterCompute() - Constructor for class org.apache.giraph.examples.scc.SccPhaseMasterCompute
 
SccPhaseMasterCompute.Phases - Enum in org.apache.giraph.examples.scc
Enumerates the possible phases of the algorithm.
SccVertexValue - Class in org.apache.giraph.examples.scc
Vertex value for the Strongly Connected Components algorithm.
SccVertexValue() - Constructor for class org.apache.giraph.examples.scc.SccVertexValue
Public constructor required for serialization.
SccVertexValue(long) - Constructor for class org.apache.giraph.examples.scc.SccVertexValue
Constructor
schedule(Runnable, long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
SCRIPT_PATH - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for path to script for computation
ScriptLoader - Class in org.apache.giraph.scripting
Loads scripts written by user in other languages, for example Jython.
SCRIPTS_TO_LOAD - Static variable in class org.apache.giraph.scripting.ScriptLoader
Option for scripts to load on workers
secondList - Variable in class org.apache.giraph.utils.PairList
List to keep second elements of pairs in
SECONDS_PER_DAY - Static variable in interface org.apache.giraph.time.Time
Seconds per day
SECONDS_PER_HOUR - Static variable in interface org.apache.giraph.time.Time
Seconds per hour
SEND_AGGREGATORS_TO_MASTER_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending aggregated values from worker owner to master
SEND_AGGREGATORS_TO_OWNER_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending aggregators from master to worker owners
SEND_AGGREGATORS_TO_WORKER_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending aggregators from worker owner to other workers
SEND_PARTITION_CURRENT_MESSAGES_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending a partition of messages for current superstep (used during partition exchange)
SEND_PARTITION_MUTATIONS_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending a partition of mutations
SEND_VERTEX_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending vertices requests
SEND_WORKER_AGGREGATORS_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending aggregated values from one worker's vertices
SEND_WORKER_MESSAGES_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for sending a partition of messages for next superstep
SendAggregatorsToOwnerRequest - Class in org.apache.giraph.comm.requests
Request to send final aggregatd values from master to worker which owns the aggregators
SendAggregatorsToOwnerRequest(byte[], int) - Constructor for class org.apache.giraph.comm.requests.SendAggregatorsToOwnerRequest
Constructor
SendAggregatorsToOwnerRequest() - Constructor for class org.apache.giraph.comm.requests.SendAggregatorsToOwnerRequest
Constructor used for reflection only
SendAggregatorsToWorkerRequest - Class in org.apache.giraph.comm.requests
Request to send final aggregated values from worker which owns them to other workers
SendAggregatorsToWorkerRequest(byte[], int) - Constructor for class org.apache.giraph.comm.requests.SendAggregatorsToWorkerRequest
Constructor
SendAggregatorsToWorkerRequest() - Constructor for class org.apache.giraph.comm.requests.SendAggregatorsToWorkerRequest
Constructor used for reflection only
SendDataCache<D> - Class in org.apache.giraph.comm
An abstract structure for caching data by partitions to be sent to workers in bulk.
SendDataCache(ImmutableClassesGiraphConfiguration, CentralizedServiceWorker<?, ?, ?>, int, float) - Constructor for class org.apache.giraph.comm.SendDataCache
Constructor.
sendDataToOwners(MasterClient) - Method in class org.apache.giraph.master.MasterAggregatorHandler
Send data to workers (through owner workers)
SendEdgeCache<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm
Aggregates the edges to be sent to workers so they can be sent in bulk.
SendEdgeCache(ImmutableClassesGiraphConfiguration, CentralizedServiceWorker<?, ?, ?>) - Constructor for class org.apache.giraph.comm.SendEdgeCache
Constructor
sendEdgeRequest(I, Edge<I, E>) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
sendEdgeRequest(I, Edge<I, E>) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a request to the source vertex owner to add an edge.
SendGlobalCommCache - Class in org.apache.giraph.comm.aggregators
Takes and serializes global communication values and keeps them grouped by owner partition id, to be sent in bulk.
SendGlobalCommCache(boolean) - Constructor for class org.apache.giraph.comm.aggregators.SendGlobalCommCache
Constructor
sendMasterCounters(GiraphCountersThriftStruct) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
sendMasterCounters(GiraphCountersThriftStruct) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
sendMasterCounters(GiraphCountersThriftStruct) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
sendMasterCounters(GiraphCountersThriftStruct) - Method in interface org.apache.giraph.job.JobProgressTracker
Master should call this method after all supersteps are finished, and send the aggregated counters to the job client
sendMessage(I, M) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Send a message to a vertex id.
sendMessage(String, Class<M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, Iterable<M>>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all targets provided by targetsSupplier.
sendMessage(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all targets provided by targetsSupplier, and uses given messageCombiner to combine messages together.
sendMessage(I, M2) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
sendMessage(I, M2) - Method in class org.apache.giraph.graph.AbstractComputation
Send a message to a vertex id.
sendMessage(I, M2) - Method in interface org.apache.giraph.graph.Computation
Send a message to a vertex id.
sendMessage(Object, Object) - Method in class org.apache.giraph.jython.JythonComputation
Send a message to a vertex id.
SendMessageCache<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm
Aggregates the messages to be sent to workers so they can be sent in bulk.
SendMessageCache(ImmutableClassesGiraphConfiguration, CentralizedServiceWorker<?, ?, ?>, NettyWorkerClientRequestProcessor<I, ?, ?>, int) - Constructor for class org.apache.giraph.comm.SendMessageCache
Constructor
SendMessageCache.TargetVertexIdIterator<I extends org.apache.hadoop.io.WritableComparable> - Class in org.apache.giraph.comm
An iterator wrapper on edges to return target vertex ids.
SendMessageChain<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,P> - Class in org.apache.giraph.block_app.library
Utility class for creating sequences of sending replies to received messages.
SendMessagePiece<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.block_app.library.internal
Piece that sends a message provided through messageProducer to given set of neighbors, and passes them to messagesConsumer.
SendMessagePiece(String, Class<M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, Iterable<M>>) - Constructor for class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
sendMessageRequest(I, Writable) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
sendMessageRequest(I, M) - Method in class org.apache.giraph.comm.SendMessageCache
Send a message to a target vertex id.
sendMessageRequest(I, Writable) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a message to destination vertex.
sendMessageToAllEdges(Vertex<I, V, E>, M) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Send a message to all edges.
sendMessageToAllEdges(Vertex<I, V, E>, M2) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
sendMessageToAllEdges(Vertex<I, V, E>, M2) - Method in class org.apache.giraph.graph.AbstractComputation
Send a message to all edges.
sendMessageToAllEdges(Vertex<I, V, E>, M2) - Method in interface org.apache.giraph.graph.Computation
Send a message to all edges.
sendMessageToAllEdges(Vertex, Object) - Method in class org.apache.giraph.jython.JythonComputation
Send a message to all edges.
sendMessageToAllRequest(Vertex<I, V, E>, Writable) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
sendMessageToAllRequest(Iterator<I>, Writable) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
sendMessageToAllRequest(Vertex<I, ?, ?>, M) - Method in class org.apache.giraph.comm.SendMessageCache
Send message to all its neighbors
sendMessageToAllRequest(Iterator<I>, M) - Method in class org.apache.giraph.comm.SendMessageCache
Send message to the target ids in the iterator
sendMessageToAllRequest(Iterator<I>, M) - Method in class org.apache.giraph.comm.SendOneMessageToManyCache
 
sendMessageToAllRequest(Vertex<I, V, E>, Writable) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a message through all edges to all destinations.
sendMessageToAllRequest(Iterator<I>, Writable) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a message to the targets in the iterator.
sendMessageToMultipleEdges(Iterator<I>, M) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Send a message to multiple target vertex ids in the iterator.
sendMessageToMultipleEdges(Iterator<I>, M2) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
sendMessageToMultipleEdges(Iterator<I>, M2) - Method in class org.apache.giraph.graph.AbstractComputation
Send a message to multiple target vertex ids in the iterator.
sendMessageToMultipleEdges(Iterator<I>, M2) - Method in interface org.apache.giraph.graph.Computation
Send a message to multiple target vertex ids in the iterator.
sendMessageToMultipleEdges(Iterator, Object) - Method in class org.apache.giraph.jython.JythonComputation
Send a message to multiple target vertex ids in the iterator.
sendMessageToNeighbors(String, Class<M>, SupplierFromVertex<I, V, E, M>, ConsumerWithVertex<I, V, E, Iterable<M>>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all neighbors of current vertex.
sendMessageToNeighbors(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, ConsumerWithVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all neighbors of current vertex, and uses given messageCombiner to combine messages together.
sendMessageToWorker(WM, int) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi
Send message to another worker
sendMessageToWorker(Writable, int) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
sendMessageToWorker(Writable, int) - Method in class org.apache.giraph.worker.WorkerContext
Send message to another worker
SendMessageWithCombinerPiece<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.block_app.library.internal
Piece that sends a message provided through messageProducer to given set of neighbors, uses a message combiner and passes them to messagesConsumer.
SendMessageWithCombinerPiece(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, M>) - Constructor for class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
SendMutationsCache<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm
Aggregates the mutations to be sent to partitions so they can be sent in bulk.
SendMutationsCache() - Constructor for class org.apache.giraph.comm.SendMutationsCache
 
SendOneMessageToManyCache<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm
Aggregates the messages to be sent to workers so they can be sent in bulk.
SendOneMessageToManyCache(ImmutableClassesGiraphConfiguration, CentralizedServiceWorker<?, ?, ?>, NettyWorkerClientRequestProcessor<I, ?, ?>, int) - Constructor for class org.apache.giraph.comm.SendOneMessageToManyCache
Constructor
SendPartitionCache<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm
Caches partition vertices prior to sending.
SendPartitionCache(ImmutableClassesGiraphConfiguration<I, V, E>, CentralizedServiceWorker<?, ?, ?>) - Constructor for class org.apache.giraph.comm.SendPartitionCache
Constructor.
SendPartitionCurrentMessagesRequest<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.comm.requests
Send a collection of vertex messages for a partition.
SendPartitionCurrentMessagesRequest() - Constructor for class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
Constructor used for reflection only
SendPartitionCurrentMessagesRequest(int, ByteArrayVertexIdMessages<I, M>) - Constructor for class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
Constructor used to send request.
SendPartitionMutationsRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Send a collection of vertex mutations for a partition.
SendPartitionMutationsRequest() - Constructor for class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
Constructor used for reflection only
SendPartitionMutationsRequest(int, Map<I, VertexMutations<I, V, E>>) - Constructor for class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
Constructor used to send request.
sendPartitionRequest(WorkerInfo, Partition<I, V, E>) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
sendPartitionRequest(WorkerInfo, Partition<I, V, E>) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Send a partition request (no batching).
SendReducedToMasterRequest - Class in org.apache.giraph.comm.requests
Request to send final aggregated values from worker which owns aggregators to the master
SendReducedToMasterRequest(byte[]) - Constructor for class org.apache.giraph.comm.requests.SendReducedToMasterRequest
Constructor
SendReducedToMasterRequest() - Constructor for class org.apache.giraph.comm.requests.SendReducedToMasterRequest
Constructor used for reflection only
sendReducedValue(String, Writable) - Method in interface org.apache.giraph.comm.aggregators.WorkerAggregatorRequestProcessor
Sends worker reduced value to the owner of reducer
sendReducedValue(String, Writable) - Method in class org.apache.giraph.comm.netty.NettyWorkerAggregatorRequestProcessor
 
sendReducedValuesToMaster(byte[]) - Method in interface org.apache.giraph.comm.aggregators.WorkerAggregatorRequestProcessor
Sends reduced values to the master.
sendReducedValuesToMaster(byte[]) - Method in class org.apache.giraph.comm.netty.NettyWorkerAggregatorRequestProcessor
 
sendRequest(int, WritableRequest) - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
 
sendRequest(int, WritableRequest) - Method in interface org.apache.giraph.comm.flow_control.FlowControl
This method is called by a network client for all requests that should be handled by a *remote* task.
sendRequest(int, WritableRequest) - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
sendRequest(int, WritableRequest) - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
SendResumeRequest - Class in org.apache.giraph.comm.requests
Send to a worker a signal to resume sending messages to sender worker.
SendResumeRequest() - Constructor for class org.apache.giraph.comm.requests.SendResumeRequest
Constructor used for reflection only
SendResumeRequest(short) - Constructor for class org.apache.giraph.comm.requests.SendResumeRequest
Constructor
sendSplitTo(InputType, int, boolean) - Method in class org.apache.giraph.master.input.MasterInputSplitsHandler
Called after we receive a split request from some worker, should send split back to it if available, or send it information that there is no more available
sendToOwner(String, GlobalCommType, Writable) - Method in interface org.apache.giraph.comm.MasterClient
Sends aggregator to its owner
sendToOwner(String, GlobalCommType, Writable) - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
SendVertexIdDataCache<I extends org.apache.hadoop.io.WritableComparable,T,B extends VertexIdData<I,T>> - Class in org.apache.giraph.comm
An abstract structure for caching data indexed by vertex id, to be sent to workers in bulk.
SendVertexIdDataCache(ImmutableClassesGiraphConfiguration, CentralizedServiceWorker<?, ?, ?>, int, float) - Constructor for class org.apache.giraph.comm.SendVertexIdDataCache
Constructor.
sendVertexRequest(PartitionOwner, Vertex<I, V, E>) - Method in class org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor
 
SendVertexRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Send a collection of vertices for a partition.
SendVertexRequest() - Constructor for class org.apache.giraph.comm.requests.SendVertexRequest
Constructor used for reflection only
SendVertexRequest(Partition<I, V, E>) - Constructor for class org.apache.giraph.comm.requests.SendVertexRequest
Constructor for sending a request.
sendVertexRequest(PartitionOwner, Vertex<I, V, E>) - Method in interface org.apache.giraph.comm.WorkerClientRequestProcessor
Sends a vertex to the appropriate partition owner
SendWorkerAggregatorsRequest - Class in org.apache.giraph.comm.requests
Request to send partial aggregated values for current superstep (values which were computed by one worker's vertices)
SendWorkerAggregatorsRequest(byte[], int) - Constructor for class org.apache.giraph.comm.requests.SendWorkerAggregatorsRequest
Constructor
SendWorkerAggregatorsRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerAggregatorsRequest
Constructor used for reflection only
sendWorkerCountersAndFinishCleanup() - Method in class org.apache.giraph.graph.GraphTaskManager
Method to send the counter values from the worker to the master, after all supersteps are done, and finish cleanup
SendWorkerDataRequest<I extends org.apache.hadoop.io.WritableComparable,T,B extends VertexIdData<I,T>> - Class in org.apache.giraph.comm.requests
Abstract request to send a collection of data, indexed by vertex id, for a partition.
SendWorkerDataRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerDataRequest
Constructor used for reflection only
SendWorkerDataRequest(PairList<Integer, B>) - Constructor for class org.apache.giraph.comm.requests.SendWorkerDataRequest
Constructor used to send request.
SendWorkerEdgesRequest<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Send a collection of edges for a partition.
SendWorkerEdgesRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerEdgesRequest
Constructor used for reflection only
SendWorkerEdgesRequest(PairList<Integer, VertexIdEdges<I, E>>) - Constructor for class org.apache.giraph.comm.requests.SendWorkerEdgesRequest
Constructor used to send request.
SendWorkerMessagesRequest<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Send a collection of vertex messages for a partition.
SendWorkerMessagesRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerMessagesRequest
Default constructor
SendWorkerMessagesRequest(PairList<Integer, VertexIdMessages<I, M>>) - Constructor for class org.apache.giraph.comm.requests.SendWorkerMessagesRequest
Constructor used to send request.
SendWorkerOneMessageToManyRequest<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Send a collection of ByteArrayOneMessageToManyIds messages to a worker.
SendWorkerOneMessageToManyRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
Constructor used for reflection only.
SendWorkerOneMessageToManyRequest(ByteArrayOneMessageToManyIds<I, M>, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
Constructor used to send request.
SendWorkerToWorkerMessageRequest - Class in org.apache.giraph.comm.requests
Request which sends any Writable message from one worker to another
SendWorkerToWorkerMessageRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerToWorkerMessageRequest
Default constructor, for reflection
SendWorkerToWorkerMessageRequest(Writable) - Constructor for class org.apache.giraph.comm.requests.SendWorkerToWorkerMessageRequest
Constructor with message
SendWorkerVerticesRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Send to a worker one or more partitions of vertices
SendWorkerVerticesRequest() - Constructor for class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
Constructor used for reflection only
SendWorkerVerticesRequest(ImmutableClassesGiraphConfiguration<I, V, E>, PairList<Integer, ExtendedDataOutput>) - Constructor for class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
Constructor for sending a request.
sendWritableRequest(int, WritableRequest) - Method in interface org.apache.giraph.comm.MasterClient
Send a request to a remote server (should be already connected)
sendWritableRequest(int, WritableRequest) - Method in class org.apache.giraph.comm.netty.NettyClient
Send a request to a remote server honoring the flow control mechanism (should be already connected)
sendWritableRequest(int, WritableRequest) - Method in class org.apache.giraph.comm.netty.NettyMasterClient
 
sendWritableRequest(int, WritableRequest) - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
sendWritableRequest(int, WritableRequest) - Method in interface org.apache.giraph.comm.WorkerClient
Send a request to a remote server (should be already connected)
SENT_BYTES - Static variable in interface org.apache.giraph.metrics.MetricNames
Number of bytes sent in superstep
SENT_MESSAGE_BYTES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
sent message bytes counter name
SENT_MESSAGES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
sent messages counter name
SEQUENCE_NUMBER_LENGTH - Static variable in class org.apache.giraph.zk.ZooKeeperExt
Length of the ZK sequence number
SequenceBlock - Class in org.apache.giraph.block_app.framework.block
Block that executes provided blocks sequentially.
SequenceBlock(Block...) - Constructor for class org.apache.giraph.block_app.framework.block.SequenceBlock
 
SequenceBlock(List<? extends Block>) - Constructor for class org.apache.giraph.block_app.framework.block.SequenceBlock
 
sequenceFileInputFormat - Variable in class org.apache.giraph.io.formats.SequenceFileVertexInputFormat
Internal input format
SequenceFileVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,X extends Vertex<I,V,E>> - Class in org.apache.giraph.io.formats
Sequence file vertex input format based on SequenceFileInputFormat.
SequenceFileVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.SequenceFileVertexInputFormat
 
SequenceFileVertexInputFormat.SequenceFileVertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,X extends Vertex<I,V,E>> - Class in org.apache.giraph.io.formats
Vertex reader used with SequenceFileVertexInputFormat.
SequenceFileVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,OK extends org.apache.hadoop.io.Writable,OV extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Sequence file vertex output format.
SequenceFileVertexOutputFormat() - Constructor for class org.apache.giraph.io.formats.SequenceFileVertexOutputFormat
 
SequenceFileVertexReader(RecordReader<I, X>) - Constructor for class org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader
Constructor with record reader.
SERIALIZE_MASTER - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
 
SERVER_RECEIVE_BUFFER_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Server receive buffer size
SERVER_SEND_BUFFER_SIZE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Server send buffer size
ServerData<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm
Anything that the server stores
ServerData(CentralizedServiceWorker<I, V, E>, WorkerServer, ImmutableClassesGiraphConfiguration<I, V, E>, Mapper<?, ?, ?, ?>.Context) - Constructor for class org.apache.giraph.comm.ServerData
Constructor.
service - Variable in class org.apache.giraph.edge.AbstractEdgeStore
Service worker.
service - Variable in class org.apache.giraph.edge.InMemoryEdgeStoreFactory
Service worker.
set(int, int, double) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
Set a specific entry of the matrix.
set(int, double) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Set the given value to the entry with the index specified.
set(int, int, float) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
Set a specific entry of the matrix.
set(int, float) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Set the given value to the entry with the index specified.
set(int, int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
Set a specific entry of the matrix.
set(int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Set the given value to the entry with the index specified.
set(int, int, long) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
Set a specific entry of the matrix.
set(int, long) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Set the given value to the entry with the index specified.
set(int, int, double) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrix
Set a specific entry of the matrix.
set(int, double) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
Set the given value to the entry specified.
set(int, int, float) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Set a specific entry of the matrix.
set(int, float) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
Set the given value to the entry specified.
set(int, int, int) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Set a specific entry of the matrix.
set(int, int) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
Set the given value to the entry specified.
set(int, int, long) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrix
Set a specific entry of the matrix.
set(int, long) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
Set the given value to the entry specified.
set(Configuration, boolean) - Method in class org.apache.giraph.conf.BooleanConfOption
Set value in configuration for this key
set(Configuration, Class<? extends C>) - Method in class org.apache.giraph.conf.ClassConfOption
Set value for key
set(Configuration, Enum<T>) - Method in class org.apache.giraph.conf.EnumConfOption
Set value
set(Configuration, float) - Method in class org.apache.giraph.conf.FloatConfOption
Set value
set(Configuration, int) - Method in class org.apache.giraph.conf.IntConfOption
Set value
set(Configuration, Object) - Method in class org.apache.giraph.conf.JsonStringConfOption
Set JSON value
set(Configuration, long) - Method in class org.apache.giraph.conf.LongConfOption
Set value for key
set(Configuration, GraphType, boolean) - Method in class org.apache.giraph.conf.PerGraphTypeBooleanConfOption
Set value for given GraphType
set(Configuration, GraphType, T) - Method in class org.apache.giraph.conf.PerGraphTypeEnumConfOption
Set value for given GraphType
set(Configuration, String) - Method in class org.apache.giraph.conf.StrConfOption
Set value for key
set(Float) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.EdgeValue
Set edge value
set(Double) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.MessageValue
Set message value
set(Double) - Method in class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.VertexValue
Set vertex value.
set(long) - Method in class org.apache.giraph.examples.scc.SccVertexValue
Sets the vertex value.
set(long, TimeUnit) - Method in class org.apache.giraph.metrics.GiraphTimer
Set value from a given TimeUnit, converting to our TimeUnit.
set(T) - Method in class org.apache.giraph.metrics.ValueGauge
Set value held by this object.
set(T, String) - Method in class org.apache.giraph.metrics.ValueWithHostname
Set value and partition together.
set(BooleanWritable, BooleanWritable) - Method in enum org.apache.giraph.types.ops.BooleanTypeOps
 
set(ByteWritable, ByteWritable) - Method in enum org.apache.giraph.types.ops.ByteTypeOps
 
set(DoubleWritable, DoubleWritable) - Method in enum org.apache.giraph.types.ops.DoubleTypeOps
 
set(FloatWritable, FloatWritable) - Method in enum org.apache.giraph.types.ops.FloatTypeOps
 
set(IntWritable, IntWritable) - Method in enum org.apache.giraph.types.ops.IntTypeOps
 
set(LongWritable, LongWritable) - Method in enum org.apache.giraph.types.ops.LongTypeOps
 
set(MapWritable, MapWritable) - Method in enum org.apache.giraph.types.ops.MapTypeOps
 
set(Text, Text) - Method in enum org.apache.giraph.types.ops.TextTypeOps
 
set(T, T) - Method in interface org.apache.giraph.types.ops.TypeOps
Copies the value from the second argument into the first.
set(T[]) - Method in class org.apache.giraph.utils.ArrayWritable
Set array
set(T) - Method in interface org.apache.giraph.writable.kryo.Boxed
Sets the boxed value.
set(T) - Method in class org.apache.giraph.writable.kryo.KryoSimpleWrapper
Set wrapped object value
set(T) - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Set wrapped object value
setAggregatedValue(A) - Method in interface org.apache.giraph.aggregators.Aggregator
Set aggregated value.
setAggregatedValue(A) - Method in class org.apache.giraph.aggregators.BasicAggregator
 
setAggregatedValue(String, A) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
setAggregatedValue(String, A) - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
 
setAggregatedValue(String, A) - Method in interface org.apache.giraph.master.MasterAggregatorUsage
Sets value of an aggregator.
setAggregatedValue(String, A) - Method in class org.apache.giraph.master.MasterCompute
 
setAggregation(CustomCounter.Aggregation) - Method in class org.apache.giraph.counters.CustomCounter
 
setAggregatorWriterClass(Class<? extends AggregatorWriter>) - Method in class org.apache.giraph.conf.GiraphClasses
Set AggregatorWriter class used
setAggregatorWriterClass(Class<? extends AggregatorWriter>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the aggregator writer class (optional)
setAndInitBlockFactoryClass(GiraphConfiguration, Class<? extends BlockFactory<?>>) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Set block factory, and initialize configs with it.
setApi(BlockWorkerContextApi) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
setApplicationAttempt(long) - Method in class org.apache.giraph.bsp.BspService
Set the cached application attempt (should only be used for restart from failure by the master)
setBlockFactoryClass(Configuration, Class<? extends BlockFactory<?>>) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Set which BlockFactory class to be used for the application.
setByteArray(byte[], String, Configuration) - Static method in class org.apache.giraph.utils.ConfigurationObjectUtils
Set byte array to a conf option
setCachedSuperstep(long) - Method in class org.apache.giraph.bsp.BspService
Set the cached superstep (should only be used for loading checkpoints or recovering from failure).
setCapacity(int) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
setCapacity(int) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
setCapacity(int) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
setCapacity(int) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
setCapacity(int) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
setCapacity(int) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
setCapacity(int) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Forces allocated memory to hold exactly N values
setCheckpointFrequency(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the checkpoint frequeuncy of how many supersteps to wait before checkpointing
setCheckpointStatus(CheckpointStatus) - Method in class org.apache.giraph.graph.GlobalStats
 
setCheckpointSupportedChecker(Class<? extends CheckpointSupportedChecker>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set runtime checkpoint support checker.
setClass() - Method in class org.apache.giraph.examples.SimpleTriangleClosingComputation.IntArrayListWritable
Set storage type for this ArrayListWritable
setClass(Class<M>) - Method in class org.apache.giraph.utils.ArrayListWritable
This is a one-time operation to set the class type
setClass() - Method in class org.apache.giraph.utils.ArrayListWritable
Subclasses must set the class type appropriately and can use setClass(Class<M> refClass) to do it.
setClasses(String, Class<?>, Class<?>...) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set mapping from a key name to a list of classes.
setClientId(int) - Method in class org.apache.giraph.comm.requests.WritableRequest
 
setClientPortAddress(InetSocketAddress) - Method in class org.apache.giraph.zk.ZookeeperConfig
Set zookeeper server address
setComputation(Class<? extends MigrationAbstractComputation.MigrationFullAbstractComputation>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setComputation(Class<? extends Computation>) - Method in class org.apache.giraph.master.MasterCompute
Set Computation class to be used
setComputation_name(String) - Method in class org.apache.giraph.jython.JythonJob
 
setComputationClass(Class<? extends Computation<I, V, E, ? extends Writable, ? extends Writable>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set Computation class held, and update message types
setComputationClass(Class<? extends Computation>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the computation class (required)
setComputationClass(Class<? extends Computation>) - Method in class org.apache.giraph.master.SuperstepClasses
Set computation class
setComputationDone(boolean) - Method in class org.apache.giraph.worker.WorkerProgress
 
setComputeMs(long) - Method in class org.apache.giraph.partition.PartitionStats
 
setConf(Configuration) - Method in class org.apache.giraph.benchmark.GiraphBenchmark
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.comm.requests.WritableRequest
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.conf.DefaultImmutableClassesGiraphConfigurable
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in interface org.apache.giraph.conf.GiraphConfigurationSettable
Set the configuration to be used by this object.
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.edge.DefaultCreateSourceVertexCallback
 
setConf(ImmutableClassesGiraphConfiguration<I, Writable, NullWritable>) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
setConf(ImmutableClassesGiraphConfiguration<I, Writable, E>) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
setConf(ImmutableClassesGiraphConfiguration<LongWritable, Writable, NullWritable>) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
setConf(ImmutableClassesGiraphConfiguration<LongWritable, DoubleWritable, DoubleWritable>) - Method in class org.apache.giraph.examples.LongDoubleDoubleTextInputFormat
 
setConf(ImmutableClassesGiraphConfiguration<LongWritable, DoubleWritable, FloatWritable>) - Method in class org.apache.giraph.examples.LongDoubleFloatTextInputFormat
 
setConf(ImmutableClassesGiraphConfiguration<LongWritable, DoubleWritable, NullWritable>) - Method in class org.apache.giraph.examples.LongDoubleNullTextInputFormat
 
setConf(ImmutableClassesGiraphConfiguration<LongWritable, DoubleWritable, DoubleWritable>) - Method in class org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat
 
setConf(Configuration) - Method in class org.apache.giraph.examples.SimpleCheckpoint
 
setConf(Configuration) - Method in class org.apache.giraph.examples.SimpleVertexWithWorkerContext
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.factories.DefaultEdgeValueFactory
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.factories.DefaultInputOutEdgesFactory
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.factories.DefaultOutEdgesFactory
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.factories.DefaultVertexIdFactory
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.factories.DefaultVertexValueFactory
 
setConf(Configuration) - Method in class org.apache.giraph.GiraphRunner
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.graph.DefaultVertexResolver
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.graph.VertexMutations
 
setConf(ImmutableClassesGiraphConfiguration<I, Writable, E>) - Method in class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
setConf(ImmutableClassesGiraphConfiguration<I, Writable, E>) - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
setConf(ImmutableClassesGiraphConfiguration<I, Writable, E>) - Method in class org.apache.giraph.io.iterables.EdgeReaderWrapper
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.io.iterables.MappingReaderWrapper
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.io.iterables.VertexReaderWrapper
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.job.DefaultJobObserver
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.master.AggregatorReduceOperation
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.master.DefaultMasterObserver
 
setConf(ImmutableClassesGiraphConfiguration<I, V, E>) - Method in class org.apache.giraph.partition.BasicPartition
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.partition.SimpleIntRangePartitionerFactory
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.partition.SimpleLongRangePartitionerFactory
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
setConf(Configuration) - Method in class org.apache.giraph.utils.ArrayListWritable
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.utils.JMapHistoDumper
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.utils.LogVersions
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
setConf(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.worker.DefaultWorkerObserver
 
setConf(Configuration) - Method in class org.apache.giraph.zk.GiraphZooKeeperAdmin
 
setConf(Configuration) - Method in class org.apache.giraph.zk.ZooKeeperNodeCreator
 
setContext(Mapper<?, ?, ?, ?>.Context) - Method in interface org.apache.giraph.conf.ContextSettable
Set context
setCounterName(String) - Method in class org.apache.giraph.counters.CustomCounter
 
setCounters(List<CustomCounter>) - Method in class org.apache.giraph.counters.GiraphCountersThriftStruct
 
setCreateSourceVertex(boolean) - Method in class org.apache.giraph.conf.GiraphConfiguration
set option whether to create a source vertex present only in edge input
setCurrentEdge(MutableEdge<I, E>) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
Set the last edge returned by the mutable iterator.
setCurrentSuperstep(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setCurrentValue(R) - Method in class org.apache.giraph.reducers.Reducer
 
setData(int, D) - Method in class org.apache.giraph.comm.SendDataCache
Set the data cache for a partition id
setDataDir(String) - Method in class org.apache.giraph.zk.ZookeeperConfig
Set snapshot log dir
setDataInput(DataInput) - Method in class org.apache.giraph.writable.kryo.DataInputWrapperStream
 
setDataLogDir(String) - Method in class org.apache.giraph.zk.ZookeeperConfig
Transaction log dir
setDataOutput(DataOutput) - Method in class org.apache.giraph.writable.kryo.DataOutputWrapperStream
 
setDoOutputDuringComputation(boolean) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set whether or not we should do output during computation
setEdge(ReusableEdge<I, E>) - Method in class org.apache.giraph.io.iterables.EdgeWithSource
 
setEdgeInputFilterClass(Class<? extends EdgeInputFilter>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the edge input filter class
setEdgeInputFormatClass(Class<? extends EdgeInputFormat<I, E>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set EdgeInputFormat class held
setEdgeInputFormatClass(Class<? extends EdgeInputFormat>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the edge input format class (required)
setEdgeInputFormatClass(Class<? extends EdgeInputFormat>) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
setEdgeInputPath(Configuration, Path) - Static method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Set the Path for edge input.
setEdgeInputSplitsCount(int) - Method in class org.apache.giraph.master.MasterProgress
 
setEdgeInputSplitsLoaded(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setEdgeOutputFormatClass(Class<? extends EdgeOutputFormat>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the edge output format class (optional)
setEdgeOutputFormatSubdir(String) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the edge output format path
setEdges(Iterable<Edge<I, E>>) - Method in class org.apache.giraph.graph.DefaultVertex
 
setEdges(Iterable<Edge<I, Writable>>) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
setEdges(Iterable<Edge<I, E>>) - Method in interface org.apache.giraph.graph.Vertex
Set the outgoing edges for this vertex.
setEdgesLoaded(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setEdgeValue(BooleanConfOption, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
Set the edge value data from the option
setEdgeValue(EnumConfOption<T>, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeEnum
Set the edge value data from the option
setEdgeValue(I, E) - Method in class org.apache.giraph.edge.HashMapEdges
 
setEdgeValue(LongWritable, ByteWritable) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
setEdgeValue(LongWritable, DoubleWritable) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
setEdgeValue(LongWritable, NullWritable) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
setEdgeValue(I, E) - Method in interface org.apache.giraph.edge.StrictRandomAccessOutEdges
Set the edge value for the given target vertex id (if an edge to that vertex exists).
setEdgeValue(I, E) - Method in class org.apache.giraph.graph.DefaultVertex
 
setEdgeValue(I, Writable) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
setEdgeValue(I, E) - Method in interface org.apache.giraph.graph.Vertex
If an edge to the target vertex exists, set it to the given edge value.
setEdgeValue(E) - Method in class org.apache.giraph.io.iterables.EdgeWithSource
Set the value of this edge
setEdgeValueClass(Class<E>) - Method in class org.apache.giraph.conf.GiraphClasses
Set Edge Value class held
setEdgeValueClass(Class<E>) - Method in class org.apache.giraph.conf.GiraphTypes
 
setEntry(Map.Entry<I, E>) - Method in class org.apache.giraph.edge.MapMutableEdge
Set the backing entry for this edge in the map.
setEventWaitMsecs(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the number of milliseconds to wait for an event before continuing on
setFinalSum(double) - Static method in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
setFinalSum(double) - Static method in class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
setFirst(int) - Method in class org.apache.giraph.utils.IntPair
Set the first element.
setFlowControl(FlowControl) - Method in interface org.apache.giraph.comm.MasterServer
Inform the server about the flow control policy used in sending requests
setFlowControl(FlowControl) - Method in class org.apache.giraph.comm.netty.handler.MasterRequestServerHandler.Factory
 
setFlowControl(FlowControl) - Method in interface org.apache.giraph.comm.netty.handler.RequestServerHandler.Factory
Inform the factory about the flow control policy used (this method should be called before any call to `#newHandle()`)
setFlowControl(FlowControl) - Method in class org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler.Factory
 
setFlowControl(FlowControl) - Method in class org.apache.giraph.comm.netty.NettyMasterServer
 
setFlowControl(FlowControl) - Method in class org.apache.giraph.comm.netty.NettyServer
Inform the server about the flow control policy used in sending requests
setFlowControl(FlowControl) - Method in class org.apache.giraph.comm.netty.NettyWorkerServer
 
setFlowControl(FlowControl) - Method in interface org.apache.giraph.comm.WorkerServer
Inform this server about the flow control used in sending requests
setFlowControl(FlowControl) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
 
setFree() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
the vertex is free from deadlocks
setFreeMemoryFraction(double) - Method in class org.apache.giraph.worker.WorkerProgress
 
setFreeMemoryMB(double) - Method in class org.apache.giraph.worker.WorkerProgress
 
setFrom(PerGraphTypeBooleanConfOption, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
Set data from per user graph type set of options
setFrom(PerGraphTypeEnumConfOption<T>, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeEnum
Set data from per user graph type set of options
setGiraphCompute(JythonGiraphComputation) - Method in class org.apache.giraph.jython.JythonComputation
 
setGraph(TestGraph) - Static method in class org.apache.giraph.utils.InMemoryVertexInputFormat
 
setGraphPartitionerFactoryClass(Class<? extends GraphPartitionerFactory<I, V, E>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set GraphPartitionerFactory class held
setGraphPartitionerFactoryClass(Class<? extends GraphPartitionerFactory>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the graph partitioner class (optional)
setGraphState(GraphState) - Method in class org.apache.giraph.master.MasterCompute
 
setGraphState(GraphState) - Method in class org.apache.giraph.worker.WorkerContext
Set the graph state.
setGroupName(String) - Method in class org.apache.giraph.counters.CustomCounter
 
setGroupName(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Set group name used by this MetricsRegistry.
setHaltComputation(boolean) - Method in class org.apache.giraph.graph.GlobalStats
 
setHive_database(String) - Method in class org.apache.giraph.jython.JythonJob
 
setHive_io(Object) - Method in class org.apache.giraph.jython.JythonJob.TypeWithHive
 
setHive_reader(Object) - Method in class org.apache.giraph.jython.JythonJob.TypeWithHive
 
setHive_writer(Object) - Method in class org.apache.giraph.jython.JythonJob.TypeWithHive
 
setId(I) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
setId(int) - Method in class org.apache.giraph.partition.BasicPartition
 
setId(int) - Method in interface org.apache.giraph.partition.Partition
Set the partition id.
setId_column(String) - Method in class org.apache.giraph.jython.JythonJob.VertexInput
 
setId_column(String) - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
setIdWithInHoldAck(Long) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
setIdWithInHoldDone(Long) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
setIfNotModifiedMessageClass(Class<M>) - Method in class org.apache.giraph.conf.DefaultMessageClasses
Set message class if not set already in this superstep
setIfUnset(Configuration, boolean) - Method in class org.apache.giraph.conf.BooleanConfOption
Set value in configuration if it hasn't been set already
setIfUnset(Configuration, Class<? extends C>) - Method in class org.apache.giraph.conf.ClassConfOption
Set value for key if it is not already set
setIfUnset(Configuration, Enum<T>) - Method in class org.apache.giraph.conf.EnumConfOption
Set value if it's not already present
setIfUnset(Configuration, float) - Method in class org.apache.giraph.conf.FloatConfOption
Set value if it's not already present
setIfUnset(Configuration, int) - Method in class org.apache.giraph.conf.IntConfOption
Set value if it's not already present
setIfUnset(Configuration, long) - Method in class org.apache.giraph.conf.LongConfOption
Set value if it's not already present
setIfUnset(Configuration, String) - Method in class org.apache.giraph.conf.StrConfOption
Set value if not already present
setIncomingMessage(Class<? extends Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setIncomingMessage(Class<? extends Writable>) - Method in class org.apache.giraph.master.MasterCompute
Deprecated.
setIncomingMessageClass(Class<? extends Writable>) - Method in class org.apache.giraph.master.SuperstepClasses
Deprecated.
setIncomingMessageClasses(MessageClasses<I, ? extends Writable>) - Method in class org.apache.giraph.conf.GiraphClasses
Set incoming Message Value class held - messages which have been sent in the previous superstep and are processed in the current one
setInetSocketAddress(InetSocketAddress, String) - Method in class org.apache.giraph.graph.TaskInfo
Set address that the IPC server of this task is using
setInputFormatClass(Class<? extends IF>) - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
 
setInputOutEdgesClass(Class<? extends OutEdges>) - Method in class org.apache.giraph.conf.GiraphClasses
Set OutEdges class used during edge-input (if different from the one used for computation)
setInputOutEdgesClass(Class<? extends OutEdges>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex edges class used during edge-based input (if different from the one used during computation)
setIsMaster(boolean) - Method in class org.apache.giraph.graph.GraphTaskManager
Sets the "isMaster" flag for final output commit to happen on master.
setJob(Job) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
setJob(Job) - Method in interface org.apache.giraph.job.JobProgressTrackerService
Set job
setJobName(String) - Method in class org.apache.giraph.job.GiraphJob
 
setJobObserverClass(Class<? extends GiraphJobObserver>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set job observer class
setJobRetryCheckerClass(Class<? extends GiraphJobRetryChecker>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set job retry checker class
setJobState(ApplicationState, long, long) - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
If the master decides that this job doesn't have the resources to continue, it can fail the job.
setJobState(ApplicationState, long, long) - Method in class org.apache.giraph.master.BspServiceMaster
 
setLoadingEdgesDone(boolean) - Method in class org.apache.giraph.worker.WorkerProgress
 
setLoadingVerticesDone(boolean) - Method in class org.apache.giraph.worker.WorkerProgress
 
setLocalTestMode(boolean) - Method in class org.apache.giraph.conf.GiraphConfiguration
Flag this job as a local test run.
setLowestGraphPercentageInMemory(int) - Method in class org.apache.giraph.graph.GlobalStats
 
setLowestGraphPercentageInMemory(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setMany(Configuration, Class<? extends C>...) - Method in class org.apache.giraph.conf.ClassConfOption
Set classes for this key
setMappingInputFormatClass(Class<? extends MappingInputFormat<I, V, E, Writable>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set MappingInputFormat held
setMappingInputFormatClass(Class<? extends MappingInputFormat>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the mapping input format class (optional)
setMappingInputFormatClass(Class<? extends MappingInputFormat>) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Set MappingInputFormatClass
setMappingTarget(B) - Method in class org.apache.giraph.mapping.MappingEntry
 
setMasterApi(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setMasterComputeClass(Class<? extends MasterCompute>) - Method in class org.apache.giraph.conf.GiraphClasses
Set MasterCompute class used
setMasterComputeClass(Class<? extends MasterCompute>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the master class (optional)
setMasterService(CentralizedServiceMaster) - Method in class org.apache.giraph.master.MasterCompute
 
setMasterTimeCounter(PairedPieceAndStage<?>, long, long, StatusReporter, BlockMasterLogic.TimeStatsPerEvent) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
setMatrix(DoubleDenseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(FloatDenseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(IntDenseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(LongDenseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(DoubleSparseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(FloatSparseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(IntSparseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMatrix(LongSparseMatrix, MasterAggregatorUsage) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrixSumAggregator
Set the values of the matrix to the master specified.
setMaxMasterSuperstepWaitMsecs(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the maximum milliseconds to wait before giving up trying to get the minimum number of workers before a superstep.
setMaxNumberOfSupersteps(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the maximum number of supersteps of this application.
setMaxPermits(int) - Method in class org.apache.giraph.utils.AdjustableSemaphore
Adjusts the maximum number of available permits.
setMaxSessionTimeout(int) - Method in class org.apache.giraph.zk.ZookeeperConfig
Set maximum session timeout in milliseconds
setMaxTaskAttempts(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the max task attempts
setMessageClass(Class<M>) - Method in class org.apache.giraph.conf.DefaultMessageClasses
Set message class
setMessageCombiner(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setMessageCombiner(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.jython.JythonJob
 
setMessageCombiner(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.master.MasterCompute
Set MessageCombiner class to be used
setMessageCombinerClass(Class<? extends MessageCombiner<? super I, M>>) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
setMessageCombinerClass(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the message combiner class (optional)
setMessageCombinerClass(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
setMessageCombinerClass(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.master.SuperstepClasses
Set message combiner class.
setMessageEncodeAndStoreType(MessageEncodeAndStoreType) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
setMessageValueFactoryClass(Class<? extends MessageValueFactory<M>>) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
setMinSessionTimeout(int) - Method in class org.apache.giraph.zk.ZookeeperConfig
Set minimum session timeout in milliseconds
setName(String) - Method in class org.apache.giraph.jython.JythonJob
 
setNextWorkerPieces(MasterCompute, BlockWorkerPieces<S>) - Static method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
Sets which WorkerComputation is going to be executed in the next superstep.
setNotified() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
the vertex got a notification
setNumComputeThreads(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the number of compute threads
setNumInputSplitsThreads(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the number of input split threads
setNumOutputThreads(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the number of threads to use for writing output in the end of the application.
setObjectKryo(T, String, Configuration) - Static method in class org.apache.giraph.utils.ConfigurationObjectUtils
Set object in a conf option using kryo
setOutEdgesClass(Class<? extends OutEdges>) - Method in class org.apache.giraph.conf.GiraphClasses
Set OutEdges class held
setOutEdgesClass(Class<? extends OutEdges>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex edges class
setOutgoingMessage(Class<? extends Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setOutgoingMessage(BooleanConfOption, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
Set the outgoing message value data from the option
setOutgoingMessage(EnumConfOption<T>, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeEnum
Set the outgoing message value data from the option
setOutgoingMessage(Class<? extends Writable>) - Method in class org.apache.giraph.master.MasterCompute
Set outgoing message class to be used
setOutgoingMessageClass(Class<? extends Writable>) - Method in class org.apache.giraph.master.SuperstepClasses
Set outgoing message class.
setOutgoingMessageClasses(MessageClasses<I, ? extends Writable>) - Method in class org.apache.giraph.conf.GiraphClasses
Set outgoing Message Value class held - messages which are going to be sent during current superstep
setOutgoingMessageClasses(MessageClasses<? extends WritableComparable, ? extends Writable>) - Method in class org.apache.giraph.master.MasterCompute
Set outgoing message classes to be used
setOutgoingMessageClasses(MessageClasses<? extends WritableComparable, ? extends Writable>) - Method in class org.apache.giraph.master.SuperstepClasses
Set's outgoing MessageClasses for next superstep.
setOutgoingMessageValueClass(Class<? extends Writable>) - Method in class org.apache.giraph.conf.GiraphTypes
 
setOutputPath(Job, Path) - Static method in class org.apache.giraph.io.formats.FileOutputFormatUtil
Set the Path of the output directory for the map-reduce job.
setPartition_filter(String) - Method in class org.apache.giraph.jython.JythonJob.InputBase
 
setPartitionClass(Class<? extends Partition<I, V, E>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set Partition class to use
setPartitionClass(Class<? extends Partition>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the partition class (optional)
setPartitionId(int) - Method in class org.apache.giraph.partition.PartitionStats
Set the partition id.
setPartitionIsProcessed(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Mark a partition as 'PROCESSED'
setPartitionOwners(Collection<PartitionOwner>) - Method in interface org.apache.giraph.partition.MasterGraphPartitioner
Sets partition owners for the graph.
setPartitionOwners(Collection<PartitionOwner>) - Method in class org.apache.giraph.partition.MasterGraphPartitionerImpl
 
setPartitionsComputed(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setPartitionsStored(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setPartitionsToCompute(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setPartitionsToStore(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setPool(String) - Method in class org.apache.giraph.jython.JythonJob
 
setPreviousWorkerInfo(WorkerInfo) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
setPreviousWorkerInfo(WorkerInfo) - Method in interface org.apache.giraph.partition.PartitionOwner
Set the previous worker info.
setProgressable(Progressable) - Method in class org.apache.giraph.partition.BasicPartition
 
setProgressable(Progressable) - Method in interface org.apache.giraph.partition.Partition
Set the context.
setPyObject(PyObject) - Method in class org.apache.giraph.jython.wrappers.JythonWrapperBase
 
setReadIntoObject(T) - Method in class org.apache.giraph.writable.kryo.serializers.ReusableFieldSerializer
 
setReceivedMessages(List<Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
setRequestId(long) - Method in class org.apache.giraph.comm.requests.WritableRequest
 
setResolverCreateVertexOnMessages(boolean) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set whether to create non existent vertices when they receive messages.
setRestartedSuperstep(long) - Method in class org.apache.giraph.bsp.BspService
Set the restarted superstep
setRow(int, FloatSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
Set the float vector as the row specified.
setRow(int, IntSparseVector) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
Set the int vector as the row specified.
setSaslToken(byte[]) - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
Write accessor for SASL token
setScriptsToLoad(Configuration, String, DeployType, Language) - Static method in class org.apache.giraph.scripting.ScriptLoader
Deploy a script
setScriptsToLoad(Configuration, String, DeployType, Language, String, DeployType, Language) - Static method in class org.apache.giraph.scripting.ScriptLoader
Deploy pair of scripts
setScriptsToLoad(Configuration, DeployedScript...) - Static method in class org.apache.giraph.scripting.ScriptLoader
Deploy scripts
setSecond(int) - Method in class org.apache.giraph.utils.IntPair
Set the second element.
setSingleton(int, double) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
Set the singleton index and value.
setSingleton(int, float) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
Set the singleton index and value.
setSingleton(int, int) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
Set the singleton index and value.
setSingleton(int, long) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
Set the singleton index and value.
setSource_id_column(String) - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
setSourceVertexId(I) - Method in class org.apache.giraph.io.iterables.EdgeWithSource
 
setStageCounters(String, Object, StatusReporter) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
Takes all fields from stage object, and puts them into counters, if possible.
setStatus(String) - Method in interface org.apache.giraph.block_app.framework.api.StatusReporter
Set the current status of the task to the given string.
setStatusAndLog(TaskAttemptContext, Logger, Level, String) - Static method in class org.apache.giraph.utils.LoggerUtils
Helper method to set the status and log message together.
setStoringDone(boolean) - Method in class org.apache.giraph.worker.WorkerProgress
 
setSuperstep(long) - Method in class org.apache.giraph.metrics.SuperstepMetricsRegistry
Set superstep number used.
setSuperstepClasses(SuperstepClasses) - Method in class org.apache.giraph.master.MasterCompute
 
setTable(String) - Method in class org.apache.giraph.jython.JythonJob.InputBase
 
setTable(String) - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
setTarget_id_column(String) - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
setTargetVertexId(I) - Method in class org.apache.giraph.edge.DefaultEdge
 
setTargetVertexId(I) - Method in class org.apache.giraph.edge.EdgeNoValue
 
setTargetVertexId(I) - Method in interface org.apache.giraph.edge.ReusableEdge
Set the destination vertex index of this edge.
setTargetVertexId(I) - Method in class org.apache.giraph.io.iterables.EdgeWithSource
Set target vertex id of this edge
setTaskId(int) - Method in class org.apache.giraph.graph.TaskInfo
Set task partition id of this task
setTaskId(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setTestRepeatTimes(int) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
 
setTimeUnit(TimeUnit) - Method in class org.apache.giraph.metrics.LongAndTimeUnit
Set the TimeUnit
setType(Object) - Method in class org.apache.giraph.jython.JythonJob.TypeHolder
 
setType(String) - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Set type to use for new metrics
setup() - Method in interface org.apache.giraph.bsp.CentralizedServiceMaster
Setup (must be called prior to any other function)
setup() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Setup (must be called prior to any other function)
setup(boolean) - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
setup(boolean) - Method in interface org.apache.giraph.comm.WorkerClient
Setup the client.
setup(Mapper<Object, Object, Object, Object>.Context) - Method in class org.apache.giraph.graph.GraphMapper
 
setup(Path[]) - Method in class org.apache.giraph.graph.GraphTaskManager
Called by owner of this GraphTaskManager on each compute node
setup() - Method in interface org.apache.giraph.graph.MapperObserver
Setup mapper.
setup() - Method in class org.apache.giraph.master.BspServiceMaster
 
setup() - Method in class org.apache.giraph.worker.BspServiceWorker
 
setup() - Method in class org.apache.giraph.zk.ZooKeeperManager
Create the candidate stamps and decide on the servers to start if you are partition 0.
SETUP_MS_NAME - Static variable in class org.apache.giraph.counters.GiraphTimers
Counter name for setup msec
setupJob(JobContext) - Method in class org.apache.giraph.bsp.ImmutableOutputCommitter
 
setupJob(JobContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
 
setupMapperObservers() - Method in class org.apache.giraph.graph.GraphTaskManager
Setup mapper observers
setupSuperstep(CentralizedServiceWorker<?, ?, ?>) - Method in class org.apache.giraph.worker.WorkerContext
Setup superstep.
setupTask(TaskAttemptContext) - Method in class org.apache.giraph.bsp.ImmutableOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.giraph.utils.DefaultOutputCommitter
 
setUseMasterLoggingAggregator(boolean, Configuration) - Static method in class org.apache.giraph.utils.MasterLoggingAggregator
Set whether or not master logging aggregator should be used
setUseUnsafeSerialization(boolean) - Method in class org.apache.giraph.edge.LongDiffArray
Set whether to use unsafe serailization
setValue(long) - Method in interface org.apache.giraph.block_app.framework.api.Counter
Set this counter by the given value
setValue(long) - Method in class org.apache.giraph.counters.CustomCounter
 
setValue(long) - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Set counter to value.
setValue(E) - Method in class org.apache.giraph.edge.DefaultEdge
 
setValue(NullWritable) - Method in class org.apache.giraph.edge.EdgeNoValue
 
setValue(E) - Method in class org.apache.giraph.edge.MapMutableEdge
 
setValue(E) - Method in interface org.apache.giraph.edge.MutableEdge
Set the value for this edge.
setValue(V) - Method in class org.apache.giraph.graph.ByteValueVertex
 
setValue(V) - Method in class org.apache.giraph.graph.DefaultVertex
 
setValue(Writable) - Method in class org.apache.giraph.graph.OnlyIdVertex
 
setValue(V) - Method in interface org.apache.giraph.graph.Vertex
Set the vertex data (immediately visible in the computation)
setValue(long) - Method in class org.apache.giraph.metrics.LongAndTimeUnit
Set the value
setValue(R) - Method in class org.apache.giraph.writable.tuple.PairWritable
Throws UnsupportedOperationException.
setValue_column(String) - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
setValue_column(String) - Method in class org.apache.giraph.jython.JythonJob.VertexInput
 
setValue_column(String) - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
setVertex(Vertex<I, V, E>) - Method in class org.apache.giraph.utils.TestGraph
Set vertex, replace if there was already a vertex with same id added
setVertex(I, V, Map.Entry<I, E>...) - Method in class org.apache.giraph.utils.TestGraph
Set vertex, replace if there was already a vertex with same id added
setVertexClass(Class<? extends Vertex>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex implementation class
setVertexId(BooleanConfOption, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
Set the vertex id data from the option
setVertexId(EnumConfOption<T>, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeEnum
Set the vertex id data from the option
setVertexId(I) - Method in class org.apache.giraph.mapping.MappingEntry
 
setVertexIdClass(Class<I>) - Method in class org.apache.giraph.conf.GiraphClasses
Set Vertex ID class held
setVertexIdClass(Class<I>) - Method in class org.apache.giraph.conf.GiraphTypes
 
setVertexInputFilterClass(Class<? extends VertexInputFilter>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex input filter class
setVertexInputFormatClass(Class<? extends VertexInputFormat<I, V, E>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set VertexInputFormat held
setVertexInputFormatClass(Class<? extends VertexInputFormat>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex input format class (required)
setVertexInputFormatClass(Class<? extends VertexInputFormat>) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
 
setVertexInputPath(Configuration, Path) - Static method in class org.apache.giraph.io.formats.GiraphFileInputFormat
Set the Path for vertex input.
setVertexInputSplitCount(int) - Method in class org.apache.giraph.master.MasterProgress
 
setVertexInputSplitsLoaded(int) - Method in class org.apache.giraph.worker.WorkerProgress
 
setVertexOutputFormatClass(Class<? extends VertexOutputFormat<I, V, E>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set VertexOutputFormat held
setVertexOutputFormatClass(Class<? extends VertexOutputFormat>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex output format class (optional)
setVertexOutputFormatSubdir(String) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex output format path
setVertexOutputFormatThreadSafe(boolean) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set whether or not selected VertexOutputFormat is thread-safe
setVertexResolverClass(Class<? extends VertexResolver<I, V, E>>) - Method in class org.apache.giraph.conf.GiraphClasses
Set VertexResolver used
setVertexResolverClass(Class<? extends VertexResolver>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex resolver class (optional)
setVertexValue(BooleanConfOption, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeBoolean
Set the vertex value data from the option
setVertexValue(EnumConfOption<T>, Configuration) - Method in class org.apache.giraph.conf.PerGraphTypeEnum
Set the vertex value data from the option
setVertexValueClass(Class<V>) - Method in class org.apache.giraph.conf.GiraphClasses
Set Vertex Value class held
setVertexValueClass(Class<V>) - Method in class org.apache.giraph.conf.GiraphTypes
 
setVertexValueCombinerClass(Class<? extends VertexValueCombiner>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex value combiner class (optional)
setVertexValueFactoryClass(Class<? extends VertexValueFactory>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the vertex value factory class
setVerticesComputed(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setVerticesLoaded(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setVerticesStored(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setVerticesToCompute(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setVerticesToStore(long) - Method in class org.apache.giraph.worker.WorkerProgress
 
setW(int, T) - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Set element at given index in the array
setW(int, BooleanWritable) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
setW(int, ByteWritable) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
setW(int, DoubleWritable) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
setW(int, FloatWritable) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
setW(int, IntWritable) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
setW(int, LongWritable) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
setWaitTaskDoneTimeoutMs(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the maximum timeout (in milliseconds) for waiting for all tasks to complete after the job is done.
setWorkerConfiguration(int, int, float) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set worker configuration for determining what is required for a superstep.
setWorkerContextClass(Class<? extends WorkerContext>) - Method in class org.apache.giraph.conf.GiraphClasses
Set WorkerContext used
setWorkerContextClass(Class<? extends WorkerContext>) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the worker context class (optional)
setWorkerContextReceiveApi(BlockWorkerContextReceiveApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerContextSendApi(BlockWorkerContextSendApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerGlobalCommUsage(WorkerGlobalCommUsage) - Method in class org.apache.giraph.io.internal.WrappedEdgeReader
 
setWorkerGlobalCommUsage(WorkerGlobalCommUsage) - Method in class org.apache.giraph.io.internal.WrappedMappingReader
 
setWorkerGlobalCommUsage(WorkerGlobalCommUsage) - Method in class org.apache.giraph.io.internal.WrappedVertexReader
 
setWorkerGlobalCommUsage(WorkerGlobalCommUsage) - Method in class org.apache.giraph.worker.WorkerAggregatorDelegator
Set worker global communication usage
setWorkerInfo(WorkerInfo) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
setWorkerInfo(WorkerInfo) - Method in interface org.apache.giraph.partition.PartitionOwner
Set the current worker info.
setWorkerReceiveApi(BlockWorkerReceiveApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkers(int) - Method in class org.apache.giraph.jython.JythonJob
 
setWorkerSendApi(BlockWorkerSendApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerTimeCounter(BlockWorkerPieces<?>, long, long, StatusReporter, BlockMasterLogic.TimeStatsPerEvent) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
setWriteFuture(ChannelFuture) - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
 
setYarnLibJars(String) - Method in class org.apache.giraph.conf.GiraphConfiguration
Populate jar list for Pure YARN jobs.
setYarnTaskHeapMb(int) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set heap size for Giraph tasks in our job run, assuming the job will run on the "pure YARN" profile.
setZooKeeperConfiguration(String) - Method in class org.apache.giraph.conf.GiraphConfiguration
Utilize an existing ZooKeeper service.
setZookeeperInfo(ZooKeeperExt, String) - Static method in class org.apache.giraph.writable.kryo.GiraphClassResolver
Sets zookeeper informaton.
setZookeeperList(String) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set the ZooKeeper list to the provided list.
ShardedBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<R>>) - Constructor for class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle
 
ShardedReducerHandle<S,R> - Class in org.apache.giraph.block_app.reducers.collect
Reducing values into a list of reducers, randomly, and getting the results of all reducers together
ShardedReducerHandle() - Constructor for class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
ShardedReducerHandle.ShardedBroadcastHandle - Class in org.apache.giraph.block_app.reducers.collect
Broadcast for ShardedReducerHandle
Short2ObjFunction<T> - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (short) -> T
Short2ShortFunction - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (short) -> short
SHORT_BYTE_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Short,ByteWritable
SHORT_INT_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Short,IntWritable
SHORT_LONG_WRITABLE - Static variable in class org.apache.giraph.types.JavaWritablePair
Short,LongWritable
ShortConsumer - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (short) -> void
ShortestPathsBenchmark - Class in org.apache.giraph.benchmark
Single-source shortest paths benchmark.
ShortestPathsBenchmark() - Constructor for class org.apache.giraph.benchmark.ShortestPathsBenchmark
 
ShortestPathsComputation - Class in org.apache.giraph.benchmark
Shortest paths algorithm.
ShortestPathsComputation() - Constructor for class org.apache.giraph.benchmark.ShortestPathsComputation
 
ShortPredicate - Interface in org.apache.giraph.function.primitive
Primitive specialization of Function: (short) -> boolean
ShortRef(short) - Constructor for class org.apache.giraph.function.primitive.PrimitiveRefs.ShortRef
Constructor
ShortToIntWritableWrapper - Class in org.apache.giraph.types
Converts IntWritables to Shorts
ShortToIntWritableWrapper() - Constructor for class org.apache.giraph.types.ShortToIntWritableWrapper
 
ShortToLongWritableWrapper - Class in org.apache.giraph.types
Converts Shorts to LongWritables
ShortToLongWritableWrapper() - Constructor for class org.apache.giraph.types.ShortToLongWritableWrapper
 
shouldCreateSourceVertex(I) - Method in interface org.apache.giraph.edge.CreateSourceVertexCallback
Should we create a vertex that doesn't exist in vertex input but only exists in edge input
shouldCreateSourceVertex(I) - Method in class org.apache.giraph.edge.DefaultCreateSourceVertexCallback
 
shouldCreateVertexOnMsgs(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Override if vertices shouldn't be created by default, if message is sent to a vertex that doesn't exist.
shouldRestartCheckpoint(Job) - Method in class org.apache.giraph.job.DefaultGiraphJobRetryChecker
 
shouldRestartCheckpoint(Job) - Method in interface org.apache.giraph.job.GiraphJobRetryChecker
The job has been checkpointed and halted.
shouldRetry(Job, int) - Method in class org.apache.giraph.job.DefaultGiraphJobRetryChecker
 
shouldRetry(Job, int) - Method in interface org.apache.giraph.job.GiraphJobRetryChecker
Check if the job should be retried
shouldSendOneMessageToAll(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
shutdown() - Method in class com.yammer.metrics.core.NoOpExecutorService
 
shutdown() - Method in class org.apache.giraph.metrics.GiraphMetrics
Stop using metrics (for cleanup)
shutdown() - Method in class org.apache.giraph.metrics.GiraphMetricsRegistry
Nothing will be captured after this is called.
shutdown() - Method in class org.apache.giraph.metrics.NoOpMetricsRegistry
 
shutdown() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
shutdown() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Shutdown/Stop the out-of-core engine.
shutdown() - Method in class org.apache.giraph.ooc.OutOfCoreIOCallableFactory
Check whether all IO threads terminated gracefully.
shutdown() - Method in class org.apache.giraph.ooc.OutOfCoreIOScheduler
Shutdown/Terminate the IO scheduler, and notify all IO threads to halt
shutdown() - Method in class org.apache.giraph.ooc.persistence.InMemoryDataAccessor
 
shutdown() - Method in class org.apache.giraph.ooc.persistence.LocalDiskDataAccessor
 
shutdown() - Method in interface org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
Shut down the DAO
shutdown() - Method in interface org.apache.giraph.partition.PartitionStore
Called at the end of the computation.
shutdown() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
SHUTDOWN_MS_NAME - Static variable in class org.apache.giraph.counters.GiraphTimers
Counter name for shutdown msec
shutdownNow() - Method in class com.yammer.metrics.core.NoOpExecutorService
 
signal() - Method in interface org.apache.giraph.zk.BspEvent
The event occurred and the occurrence has been logged for future waiters.
signal() - Method in class org.apache.giraph.zk.PredicateLock
 
SimpleAggregatorWriter - Class in org.apache.giraph.examples
This is a simple example for an aggregator writer.
SimpleAggregatorWriter() - Constructor for class org.apache.giraph.examples.SimpleAggregatorWriter
 
SimpleCheckpoint - Class in org.apache.giraph.examples
An example that simply uses its id, value, and edges to compute new data every iteration to verify that checkpoint restarting works.
SimpleCheckpoint() - Constructor for class org.apache.giraph.examples.SimpleCheckpoint
 
SimpleCheckpoint.SimpleCheckpointComputation - Class in org.apache.giraph.examples
Actual computation.
SimpleCheckpoint.SimpleCheckpointVertexMasterCompute - Class in org.apache.giraph.examples
Master compute associated with SimpleCheckpoint.
SimpleCheckpoint.SimpleCheckpointVertexWorkerContext - Class in org.apache.giraph.examples
Worker context associated with SimpleCheckpoint.
SimpleCheckpointComputation() - Constructor for class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointComputation
 
SimpleCheckpointVertexMasterCompute() - Constructor for class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexMasterCompute
 
SimpleCheckpointVertexWorkerContext() - Constructor for class org.apache.giraph.examples.SimpleCheckpoint.SimpleCheckpointVertexWorkerContext
 
SimpleCombinerComputation - Class in org.apache.giraph.examples
Test whether messages can go through a combiner.
SimpleCombinerComputation() - Constructor for class org.apache.giraph.examples.SimpleCombinerComputation
 
SimpleComputation() - Constructor for class org.apache.giraph.examples.SimpleVertexWithWorkerContext.SimpleComputation
 
SimpleEdgeInputFormat() - Constructor for class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeInputFormat
 
SimpleEdgeReader() - Constructor for class org.apache.giraph.examples.AggregatorsTestComputation.SimpleEdgeReader
 
SimpleEdgeStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.edge
Simple in memory edge store which supports any type of ids.
SimpleEdgeStore(CentralizedServiceWorker<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>, Progressable) - Constructor for class org.apache.giraph.edge.SimpleEdgeStore
Constructor.
SimpleFailComputation - Class in org.apache.giraph.examples
Vertex to allow unit testing of failure detection
SimpleFailComputation() - Constructor for class org.apache.giraph.examples.SimpleFailComputation
 
SimpleGCMonitoringOracle - Class in org.apache.giraph.ooc.policy
Out-of-core oracle to adaptively control data kept in memory, with the goal of keeping the memory state constantly at a desired state.
SimpleGCMonitoringOracle(ImmutableClassesGiraphConfiguration, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
Constructor
SimpleInDegreeCountComputation - Class in org.apache.giraph.examples
Simple function to return the out degree for each vertex.
SimpleInDegreeCountComputation() - Constructor for class org.apache.giraph.examples.SimpleInDegreeCountComputation
 
SimpleIntRangePartitionerFactory<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Factory for simple range-based partitioners based on integer vertex ids.
SimpleIntRangePartitionerFactory() - Constructor for class org.apache.giraph.partition.SimpleIntRangePartitionerFactory
 
SimpleLongDoubleDoubleDoubleIdentityComputation - Class in org.apache.giraph.examples
A simple use of the Identity Vertex for taking care of Long, Double, Double, Double type Inputformat Good for use with io.LongDoubleDoubleAdjacencyListVertexInputFormat
SimpleLongDoubleDoubleDoubleIdentityComputation() - Constructor for class org.apache.giraph.examples.SimpleLongDoubleDoubleDoubleIdentityComputation
 
SimpleLongRangePartitionerFactory<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Factory for simple range-based partitioners based on long vertex ids.
SimpleLongRangePartitionerFactory() - Constructor for class org.apache.giraph.partition.SimpleLongRangePartitionerFactory
 
SimpleMasterCompute() - Constructor for class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterCompute
 
SimpleMasterComputeComputation - Class in org.apache.giraph.examples
Demonstrates a computation with a centralized part implemented via a MasterCompute.
SimpleMasterComputeComputation() - Constructor for class org.apache.giraph.examples.SimpleMasterComputeComputation
 
SimpleMasterComputeComputation.SimpleMasterCompute - Class in org.apache.giraph.examples
MasterCompute used with SimpleMasterComputeComputation.
SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext - Class in org.apache.giraph.examples
Worker context used with SimpleMasterComputeComputation.
SimpleMasterComputeWorkerContext() - Constructor for class org.apache.giraph.examples.SimpleMasterComputeComputation.SimpleMasterComputeWorkerContext
 
SimpleMessageStore<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable,T> - Class in org.apache.giraph.comm.messages
Abstract class for MessageStore which allows any kind of object to hold messages for one vertex.
SimpleMessageStore(MessageValueFactory<M>, PartitionSplitInfo<I>, ImmutableClassesGiraphConfiguration<I, ?, ?>) - Constructor for class org.apache.giraph.comm.messages.SimpleMessageStore
Constructor
SimpleMigrationMasterBlockFactory - Class in org.apache.giraph.examples.block_app
Demonstrates using migration library for Blocks Framework, as an drop-in replacement, without any changes.
SimpleMigrationMasterBlockFactory() - Constructor for class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory
 
SimpleMigrationMasterBlockFactory.SimpleMigrationMasterComputation - Class in org.apache.giraph.examples.block_app
Demonstrates a computation with a centralized part implemented via a MasterCompute.
SimpleMigrationMasterBlockFactory.SimpleMigrationMasterCompute - Class in org.apache.giraph.examples.block_app
SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext - Class in org.apache.giraph.examples.block_app
SimpleMigrationMasterComputation() - Constructor for class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterComputation
 
SimpleMigrationMasterCompute() - Constructor for class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterCompute
 
SimpleMigrationMasterWorkerContext() - Constructor for class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterWorkerContext
 
SimpleMsgComputation - Class in org.apache.giraph.examples
Test whether messages can be sent and received by vertices.
SimpleMsgComputation() - Constructor for class org.apache.giraph.examples.SimpleMsgComputation
 
SimpleMutateGraphComputation - Class in org.apache.giraph.examples
Vertex to allow unit testing of graph mutations.
SimpleMutateGraphComputation() - Constructor for class org.apache.giraph.examples.SimpleMutateGraphComputation
 
SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext - Class in org.apache.giraph.examples
Worker context used with SimpleMutateGraphComputation.
SimpleMutateGraphVertexWorkerContext() - Constructor for class org.apache.giraph.examples.SimpleMutateGraphComputation.SimpleMutateGraphVertexWorkerContext
 
SimpleOutDegreeCountComputation - Class in org.apache.giraph.examples
Simple function to return the out degree for each vertex.
SimpleOutDegreeCountComputation() - Constructor for class org.apache.giraph.examples.SimpleOutDegreeCountComputation
 
SimplePageRankComputation - Class in org.apache.giraph.examples
Demonstrates the basic Pregel PageRank implementation.
SimplePageRankComputation() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation
 
SimplePageRankComputation.SimplePageRankMasterCompute - Class in org.apache.giraph.examples
Master compute associated with SimplePageRankComputation.
SimplePageRankComputation.SimplePageRankVertexInputFormat - Class in org.apache.giraph.examples
Simple VertexInputFormat that supports SimplePageRankComputation
SimplePageRankComputation.SimplePageRankVertexOutputFormat - Class in org.apache.giraph.examples
Simple VertexOutputFormat that supports SimplePageRankComputation
SimplePageRankComputation.SimplePageRankVertexOutputFormat.SimplePageRankVertexWriter - Class in org.apache.giraph.examples
Simple VertexWriter that supports SimplePageRankComputation
SimplePageRankComputation.SimplePageRankVertexReader - Class in org.apache.giraph.examples
Simple VertexReader that supports SimplePageRankComputation
SimplePageRankComputation.SimplePageRankWorkerContext - Class in org.apache.giraph.examples
Worker context used with SimplePageRankComputation.
SimplePageRankMasterCompute() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankMasterCompute
 
SimplePageRankVertexInputFormat() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexInputFormat
 
SimplePageRankVertexOutputFormat() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexOutputFormat
 
SimplePageRankVertexReader() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexReader
 
SimplePageRankVertexWriter() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexOutputFormat.SimplePageRankVertexWriter
 
SimplePageRankWorkerContext() - Constructor for class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankWorkerContext
 
SimplePartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
A simple map-based container that stores vertices.
SimplePartition() - Constructor for class org.apache.giraph.partition.SimplePartition
Constructor for reflection.
SimplePartitionStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
A simple in-memory partition store.
SimplePartitionStore(ImmutableClassesGiraphConfiguration<I, V, E>, Mapper<?, ?, ?, ?>.Context) - Constructor for class org.apache.giraph.partition.SimplePartitionStore
Constructor.
SimpleShortestPathsComputation - Class in org.apache.giraph.examples
Demonstrates the basic Pregel shortest paths implementation.
SimpleShortestPathsComputation() - Constructor for class org.apache.giraph.examples.SimpleShortestPathsComputation
 
SimpleSumMessageCombiner - Class in org.apache.giraph.combiner
Deprecated.
SimpleSumMessageCombiner() - Constructor for class org.apache.giraph.combiner.SimpleSumMessageCombiner
Deprecated.
 
SimpleSuperstepComputation - Class in org.apache.giraph.examples
Just a simple Vertex compute implementation that executes 3 supersteps, then finishes.
SimpleSuperstepComputation() - Constructor for class org.apache.giraph.examples.SimpleSuperstepComputation
 
SimpleSuperstepComputation.SimpleSuperstepVertexInputFormat - Class in org.apache.giraph.examples
Simple VertexInputFormat that supports SimpleSuperstepComputation
SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat - Class in org.apache.giraph.examples
Simple VertexOutputFormat that supports SimpleSuperstepComputation
SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat.SimpleSuperstepVertexWriter - Class in org.apache.giraph.examples
Simple VertexWriter that supports SimpleSuperstepComputation
SimpleSuperstepComputation.SimpleSuperstepVertexReader - Class in org.apache.giraph.examples
Simple VertexReader that supports SimpleSuperstepComputation
SimpleSuperstepVertexInputFormat() - Constructor for class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexInputFormat
 
SimpleSuperstepVertexOutputFormat() - Constructor for class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat
 
SimpleSuperstepVertexReader() - Constructor for class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexReader
 
SimpleSuperstepVertexWriter() - Constructor for class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat.SimpleSuperstepVertexWriter
 
SimpleTextVertexOutputFormat - Class in org.apache.giraph.examples
Simple text based vertex output format example.
SimpleTextVertexOutputFormat() - Constructor for class org.apache.giraph.examples.SimpleTextVertexOutputFormat
 
SimpleTriangleClosingComputation - Class in org.apache.giraph.examples
Demonstrates triangle closing in simple, unweighted graphs for Giraph.
SimpleTriangleClosingComputation() - Constructor for class org.apache.giraph.examples.SimpleTriangleClosingComputation
 
SimpleTriangleClosingComputation.IntArrayListWritable - Class in org.apache.giraph.examples
Utility class for delivering the array of vertices THIS vertex should connect with to close triangles with neighbors
SimpleTriangleClosingComputation.Pair - Class in org.apache.giraph.examples
Quick, immutable K,V storage for sorting in tree set
SimpleVertexInputFormat() - Constructor for class org.apache.giraph.examples.AggregatorsTestComputation.SimpleVertexInputFormat
 
SimpleVertexReader() - Constructor for class org.apache.giraph.examples.AggregatorsTestComputation.SimpleVertexReader
 
SimpleVertexWithWorkerContext - Class in org.apache.giraph.examples
Fully runnable example of how to emit worker data to HDFS during a graph computation.
SimpleVertexWithWorkerContext() - Constructor for class org.apache.giraph.examples.SimpleVertexWithWorkerContext
 
SimpleVertexWithWorkerContext.EmitterWorkerContext - Class in org.apache.giraph.examples
Example worker context to emit data as part of a superstep.
SimpleVertexWithWorkerContext.SimpleComputation - Class in org.apache.giraph.examples
Actual vetex implementation
SimpleVertexWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.io
Interface which can only write vertices
size() - Method in class org.apache.giraph.comm.netty.ChannelRotater
Get the number of channels in this object
size() - Method in class org.apache.giraph.edge.ArrayListEdges
 
size() - Method in class org.apache.giraph.edge.ByteArrayEdges
 
size() - Method in class org.apache.giraph.edge.HashMapEdges
 
size() - Method in class org.apache.giraph.edge.HashMultimapEdges
 
size() - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
size() - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
size() - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
size() - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
size() - Method in class org.apache.giraph.edge.LongDiffArray
The number of stored ids
size() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
size() - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
size() - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
size() - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
size() - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
size() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
size() - Method in interface org.apache.giraph.edge.OutEdges
Return the number of edges.
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
 
size() - Method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
 
size() - Method in interface org.apache.giraph.types.heaps.Int2ByteMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Int2DoubleMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Int2FloatMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Int2IntMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Int2LongMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Long2ByteMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Long2DoubleMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Long2FloatMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Long2IntMapEntryIterable
Get the size of this iterable
size() - Method in interface org.apache.giraph.types.heaps.Long2LongMapEntryIterable
Get the size of this iterable
size(int) - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Sets the size of this
size() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
size() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
size() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
size() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Number of elements in this list
size() - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
size() - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
size() - Method in interface org.apache.giraph.types.ops.collections.BasicSet
Number of elements in this list
size() - Method in interface org.apache.giraph.types.ops.collections.WCollection
Number of elements in this list
size(Iterable<Edge<I, E>>) - Static method in class org.apache.giraph.utils.EdgeIterables
Get the size of edges.
size() - Method in class org.apache.giraph.utils.IncreasingBitSet
Get the size of the bit set
size(Writable) - Static method in class org.apache.giraph.utils.WritableUtils
Serialize given writable object, and return it's size.
SIZE_OF_BOOLEAN - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a boolean
SIZE_OF_BYTE - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a byte
SIZE_OF_CHAR - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a char
SIZE_OF_DOUBLE - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a double
SIZE_OF_FLOAT - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a float
SIZE_OF_INT - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in an int
SIZE_OF_LONG - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a long
SIZE_OF_SHORT - Static variable in class org.apache.giraph.utils.ByteUtils
Bytes used in a short
sizeOfSignedVarInt(int) - Static method in class org.apache.giraph.utils.Varint
Simulation for what will happen when writing a signed int value as varint.
sizeOfSignedVarLong(long) - Static method in class org.apache.giraph.utils.Varint
Simulation for what will happen when writing a signed long value as varlong.
sizeOfUnsignedVarInt(int) - Static method in class org.apache.giraph.utils.Varint
Simulation for what will happen when writing an unsigned int value as varint.
sizeOfUnsignedVarLong(long) - Static method in class org.apache.giraph.utils.Varint
Simulation for what will happen when writing an unsigned long value as varlong.
skipBytes(int) - Method in class org.apache.giraph.utils.DynamicChannelBufferInputStream
 
skipBytes(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataInput
 
skipBytes(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
skipBytes(int) - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Skip some number of bytes.
skipBytes(int) - Method in class org.apache.giraph.utils.io.BigDataInput
 
skipBytes(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
skipBytes(int) - Method in class org.apache.giraph.utils.UnsafeReads
 
sleep(long) - Method in class org.apache.giraph.time.FakeTime
 
sleep(long) - Method in class org.apache.giraph.time.SystemTime
 
sleep(long) - Method in interface org.apache.giraph.time.Time
Current thread should sleep for some number of milliseconds.
Small1GraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a network that looks like: 1 5 / \ / \ 6 0---2--3---4 where 6 is disconnected from the rest of the network.
Small1GraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit
 
Small1GraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit
 
Small2GraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a network that looks like: 1 5 / \ / \ 6 0---2 3---4 where 6 is disconnected from the rest of the network.
Small2GraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit
 
Small2GraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit
 
SmallDirectedForestGraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a directed forest that looks like: 0 4 6 / \ | / \ 1 2 5 7 8 | 3 Edges are directed from top to bottom.
SmallDirectedForestGraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit
 
SmallDirectedForestGraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit
 
SmallDirectedTreeGraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a directed tree that looks like: 0 __ / \ \ 1 2 6 | |\ 3 4 5 Edges are directed from top to bottom.
SmallDirectedTreeGraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit
 
SmallDirectedTreeGraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit
 
SMC_AGG - Static variable in class org.apache.giraph.examples.block_app.SimpleMigrationMasterBlockFactory.SimpleMigrationMasterComputation
Aggregator to get values from the master to the workers
SMC_AGG - Static variable in class org.apache.giraph.examples.SimpleMasterComputeComputation
Aggregator to get values from the master to the workers
snapshotCPUOnly(String) - Method in class org.apache.giraph.utils.YourKitContext
Capture snapshot with all recorded data except for heap dump.
snapshotCPUOnly(Mapper.Context, String) - Method in class org.apache.giraph.utils.YourKitContext
Capture snapshot with all recorded data except for heap dump.
snapshotWithMemory(String) - Method in class org.apache.giraph.utils.YourKitContext
Capture snapshot with all recorded data including heap dump.
snapshotWithMemory(Mapper.Context, String) - Method in class org.apache.giraph.utils.YourKitContext
Capture snapshot with all recorded data including heap dump.
sort() - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Sort the array in ascending order
sort() - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
sort() - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
sort() - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
sort() - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
sort() - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
sort() - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
SOURCE_ID - Static variable in class org.apache.giraph.benchmark.ShortestPathsComputation
Source id.
SOURCE_ID - Static variable in class org.apache.giraph.examples.SimpleShortestPathsComputation
The shortest paths id
SOURCE_ID_DEFAULT - Static variable in class org.apache.giraph.benchmark.ShortestPathsComputation
Default source id.
spaceString() - Method in enum org.apache.giraph.graph.GraphType
Name of graph type with spaces, like "vertex id" or "vertex value"
SPLIT_MASTER_WORKER - Static variable in interface org.apache.giraph.conf.GiraphConstants
Separate the workers and the master tasks.
SrcIdDstIdEdgeValueEdgeWriter() - Constructor for class org.apache.giraph.io.formats.SrcIdDstIdEdgeValueTextOutputFormat.SrcIdDstIdEdgeValueEdgeWriter
 
SrcIdDstIdEdgeValueTextOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Write out Edge Value with Source and Destination ID, but not the vertex value.
SrcIdDstIdEdgeValueTextOutputFormat() - Constructor for class org.apache.giraph.io.formats.SrcIdDstIdEdgeValueTextOutputFormat
 
SrcIdDstIdEdgeValueTextOutputFormat.SrcIdDstIdEdgeValueEdgeWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
start() - Method in class org.apache.giraph.comm.netty.NettyServer
Start the server with the appropriate port
start(String, ZookeeperConfig) - Method in class org.apache.giraph.zk.InProcessZooKeeperRunner
 
start(ZookeeperConfig) - Method in class org.apache.giraph.zk.InProcessZooKeeperRunner.ZooKeeperServerRunner
Start zookeeper service.
start(String, ZookeeperConfig) - Method in interface org.apache.giraph.zk.ZooKeeperRunner
Starts zookeeper service in specified working directory with specified config file.
startCustom(Function<ConsumerWithVertex<I, V, E, P>, Block>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain by providing a function that will produce Block representing beginning of the chain, given a consumer of messages send by the last link in the created block.
startIteration() - Method in interface org.apache.giraph.comm.messages.PartitionSplitInfo
startIteration() - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
startIteration() - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Notify out-of-core engine that iteration cycle over all partitions is about to begin.
startIteration() - Method in class org.apache.giraph.ooc.policy.FixedPartitionsOracle
 
startIteration() - Method in class org.apache.giraph.ooc.policy.MemoryEstimatorOracle
Resets all the counters used in the memory estimation.
startIteration() - Method in interface org.apache.giraph.ooc.policy.OutOfCoreOracle
Called at the beginning of a superstep.
startIteration() - Method in class org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle
 
startIteration() - Method in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
 
startIteration() - Method in interface org.apache.giraph.partition.PartitionStore
Start the iteration cycle to iterate over partitions.
startIteration() - Method in class org.apache.giraph.partition.SimplePartitionStore
 
startIteration() - Method in class org.apache.giraph.worker.BspServiceWorker
 
startJMapThread() - Method in class org.apache.giraph.utils.JMapHistoDumper
Start the jmap thread
startLoadingPartition(int, long) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that load of a partition for a specific superstep is about to start.
startOffloadingBuffer(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that offload of raw data buffers (vertex/edges/ messages) of a particular partition is about to start.
startOffloadingMessages(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that offload of messages for a particular partition is about to start.
startOffloadingPartition(int) - Method in class org.apache.giraph.ooc.data.MetaPartitionManager
Notify this meta store that offload of a partition (partition data and its current messages) is about to start.
startProfile(boolean, boolean, boolean) - Static method in class org.apache.giraph.utils.YourKitProfiler
Create a YourKit controller and do some or all of Controller.enableExceptionTelemetry() Controller.startCPUProfiling(long, String, String) Controller.startAllocationRecording(boolean, int, boolean, int, boolean, boolean) based on boolean config options passed as method parameters
startSend(String, Class<M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all targets provided by targetsSupplier.
startSend(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all targets provided by targetsSupplier, and use given messageCombiner to combine messages together.
startSendToNeighbors(String, Class<M>, SupplierFromVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all neighbors of a current vertex.
startSendToNeighbors(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all neighbors of a current vertex, and use given messageCombiner to combine messages together.
startStoring(long, int) - Method in class org.apache.giraph.worker.WorkerProgress
Notify this class that worker is starting to store data
startSuperstep() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Take all steps prior to actually beginning the computation of a superstep.
startSuperstep() - Method in class org.apache.giraph.worker.BspServiceWorker
 
startSuperstep(long, long, int) - Method in class org.apache.giraph.worker.WorkerProgress
Notify this class that next computation superstep is starting
startSupervisorThread() - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
Start the supervisor thread
startThread(Runnable, String) - Static method in class org.apache.giraph.utils.ThreadUtils
Start thread with specified name and runnable, and make it daemon
startThread(Runnable, String, Thread.UncaughtExceptionHandler) - Static method in class org.apache.giraph.utils.ThreadUtils
Start thread with specified name, runnable and exception handler, and make it daemon
STATIC_BALANCE_ALGORITHM - Static variable in class org.apache.giraph.partition.PartitionBalancer
No rebalancing during the supersteps
STATIC_GRAPH - Static variable in interface org.apache.giraph.conf.GiraphConstants
The application will not mutate the graph topology (the edges).
StaticFlowControl - Class in org.apache.giraph.comm.flow_control
Representation of a flow control that limits the aggregate number of open requests to all other workers to a constant user-defined value
StaticFlowControl(ImmutableClassesGiraphConfiguration, NettyClient) - Constructor for class org.apache.giraph.comm.flow_control.StaticFlowControl
Constructor
STATS_PRINT_FREQUENCY - Static variable in class org.apache.giraph.ooc.OutOfCoreIOStatistics
Use this option to control how frequently to print OOC statistics.
StatusReporter - Interface in org.apache.giraph.block_app.framework.api
Interface wrapping around functions from org.appache.hadoop.mapreduce.StatusReporter
stdDev() - Method in class com.yammer.metrics.core.NoOpHistogram
 
stdDev() - Method in class com.yammer.metrics.core.NoOpTimer
 
stop() - Method in class com.yammer.metrics.core.NoOpMeter
 
stop() - Method in class com.yammer.metrics.core.NoOpTimer
 
stop() - Method in class org.apache.giraph.comm.netty.NettyClient
Stop the client.
stop() - Method in class org.apache.giraph.comm.netty.NettyServer
Stop the server.
stop(boolean) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
stop(boolean) - Method in interface org.apache.giraph.job.JobProgressTrackerService
Stop the thread which logs application progress and server
stop() - Method in class org.apache.giraph.metrics.GiraphTimerContext
End timing.
stop() - Method in class org.apache.giraph.utils.YourKitContext
Stop recording
stop() - Method in class org.apache.giraph.worker.WorkerProgressWriter
Stop the thread which writes worker's progress
stop() - Method in class org.apache.giraph.zk.InProcessZooKeeperRunner
 
stop() - Method in class org.apache.giraph.zk.InProcessZooKeeperRunner.ZooKeeperServerRunner
Stop zookeeper service.
stop() - Method in interface org.apache.giraph.zk.ZooKeeperRunner
Stops zookeeper.
stopThriftServer() - Method in class org.apache.giraph.job.ClientThriftServer
Stop the Thrift server.
storeCheckpoint() - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Both the vertices and the messages need to be checkpointed in order for them to be used.
storeCheckpoint() - Method in class org.apache.giraph.worker.BspServiceWorker
 
storeCountersInZooKeeper(boolean) - Method in interface org.apache.giraph.bsp.CentralizedServiceWorker
Store the counter values in the zookeeper after every superstep and also after all supersteps are done.
storeCountersInZooKeeper(boolean) - Method in class org.apache.giraph.worker.BspServiceWorker
Method to store the counter values in the zookeeper This is called at the end of each superstep and after finishing all the supersteps
StoreDataBufferIOCommand - Class in org.apache.giraph.ooc.command
IOCommand to store raw data buffers on disk.
StoreDataBufferIOCommand(OutOfCoreEngine, int, StoreDataBufferIOCommand.DataBufferType) - Constructor for class org.apache.giraph.ooc.command.StoreDataBufferIOCommand
Constructor
StoreDataBufferIOCommand.DataBufferType - Enum in org.apache.giraph.ooc.command
Types of raw data buffer to offload to disk (either vertices/edges buffer in INPUT_SUPERSTEP or incoming message buffer).
StoreIncomingMessageIOCommand - Class in org.apache.giraph.ooc.command
IOCommand to store incoming message of a particular partition.
StoreIncomingMessageIOCommand(OutOfCoreEngine, int) - Constructor for class org.apache.giraph.ooc.command.StoreIncomingMessageIOCommand
Constructor
StorePartitionIOCommand - Class in org.apache.giraph.ooc.command
IOCommand to store partition data, edge data (if in INPUT_SUPERSTEP), and message data (if in compute supersteps).
StorePartitionIOCommand(OutOfCoreEngine, int) - Constructor for class org.apache.giraph.ooc.command.StorePartitionIOCommand
Constructor
storingDone - Variable in class org.apache.giraph.worker.WorkerProgressStats
Whether worker finished storing data
StrConfOption - Class in org.apache.giraph.conf
String Configuration option
StrConfOption(String, String, String) - Constructor for class org.apache.giraph.conf.StrConfOption
Constructor
StrictRandomAccessOutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.edge
Interface for OutEdges implementations that provide efficient random access to the edges given the target vertex id.
stripeBlockBySenders(int, Block) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Stripe given block, by calling vertexSend only in it's corresponding stripe.
stripeByReceiver(int, Int2ObjFunction<Int2ObjFunction<Predicate<I>>>) - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
Stripe message sending computation across multiple stripes, in each stripe only part of the vertices will receive messages.
stripeByReceiver(int, Int2ObjFunction<Int2ObjFunction<Predicate<I>>>) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
Stripe message sending computation across multiple stripes, in each stripe only part of the vertices will receive messages.
StripingUtils - Class in org.apache.giraph.block_app.library.striping
Utility functions for doing superstep striping.
submit(Callable<T>) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
submit(Runnable, T) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
submit(Runnable) - Method in class com.yammer.metrics.core.NoOpExecutorService
 
submitToExecutor(ExecutorService, Callable<T>, Thread.UncaughtExceptionHandler) - Static method in class org.apache.giraph.utils.ThreadUtils
Submit a callable to executor service, ensuring any exceptions are caught with provided exception handler.
subscribe(Consumer<T>) - Method in interface org.apache.giraph.function.Notifier
Subscribe consumer to notifications on the given object.
subscribe(Consumer<T>) - Method in class org.apache.giraph.function.ObjectNotifier
 
sum() - Method in class com.yammer.metrics.core.NoOpHistogram
 
sum() - Method in class com.yammer.metrics.core.NoOpTimer
 
sum - Variable in class org.apache.giraph.metrics.AggregatedMetric
Total of all the values seen
sum() - Method in class org.apache.giraph.metrics.AggregatedMetric
Get total of all the values seen
sum(Iterable<DoubleWritable>) - Static method in class org.apache.giraph.utils.MathUtils
Sums up a sequence of double values
sum(Iterator<DoubleWritable>) - Static method in class org.apache.giraph.utils.MathUtils
Sums up a sequence of double values
SumMessageCombiner<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.combiner
Message combiner which sums all messages.
SumMessageCombiner(NumericTypeOps<M>) - Constructor for class org.apache.giraph.combiner.SumMessageCombiner
Constructor
SumReduce<T extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.reducers.impl
Reducer for calculating sum of values
SumReduce() - Constructor for class org.apache.giraph.reducers.impl.SumReduce
Constructor used for deserialization only
SumReduce(NumericTypeOps<T>) - Constructor for class org.apache.giraph.reducers.impl.SumReduce
Constructor
SUPERSTEP_COUNT - Static variable in class org.apache.giraph.benchmark.PageRankComputation
Number of supersteps
SUPERSTEP_COUNT - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
How many supersteps to run
SUPERSTEP_COUNT - Static variable in class org.apache.giraph.benchmark.WeightedPageRankComputation
Number of supersteps
SUPERSTEP_COUNT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of supersteps job will run for
SUPERSTEP_COUNT - Static variable in class org.apache.giraph.examples.SimpleCheckpoint
Dynamically set number of supersteps
SUPERSTEP_COUNT - Static variable in class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation
Dynamically set number of SUPERSTEPS
SUPERSTEP_DIR - Static variable in class org.apache.giraph.bsp.BspService
Superstep scope
SUPERSTEP_FINISHED_NODE - Static variable in class org.apache.giraph.bsp.BspService
Denotes that the superstep is done
SUPERSTEP_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
superstep counter name
SuperstepClasses - Class in org.apache.giraph.master
Holds Computation and MessageCombiner class.
SuperstepClasses(ImmutableClassesGiraphConfiguration, Class<? extends Computation>, MessageClasses<? extends WritableComparable, ? extends Writable>, MessageClasses<? extends WritableComparable, ? extends Writable>) - Constructor for class org.apache.giraph.master.SuperstepClasses
Constructor
superstepCounters() - Method in class org.apache.giraph.counters.GiraphTimers
Get map of superstep to msec counter.
SuperstepMetricsRegistry - Class in org.apache.giraph.metrics
Wrapper around MetricsRegistry for per-superstep metrics.
SuperstepMetricsRegistry(MetricsRegistry, JmxReporter, String, String) - Constructor for class org.apache.giraph.metrics.SuperstepMetricsRegistry
Constructor
superstepMetricsUpdate(long, AggregatedMetrics, List<PartitionStats>) - Method in class org.apache.giraph.master.DefaultMasterObserver
 
superstepMetricsUpdate(long, AggregatedMetrics, List<PartitionStats>) - Method in interface org.apache.giraph.master.MasterObserver
Called after each superstep with aggregated metrics from workers
superstepMetricsUpdate(long, AggregatedMetrics, List<PartitionStats>) - Method in class org.apache.giraph.utils.JMapHistoDumper
 
superstepMetricsUpdate(long, AggregatedMetrics, List<PartitionStats>) - Method in class org.apache.giraph.utils.LogVersions
 
superstepMetricsUpdate(long, AggregatedMetrics, List<PartitionStats>) - Method in class org.apache.giraph.utils.ReactiveJMapHistoDumper
 
SuperstepOutput<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.io.superstep_output
Interface for outputing data during the computation.
SUPERSTEPS - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for number of supersteps
SuperstepState - Enum in org.apache.giraph.bsp
State of a coordinated superstep
Supplier<T> - Interface in org.apache.giraph.function
Function: () -> T
Specialization of com.google.common.base.Supplier, that is also Serializable.
SupplierFromConf<T> - Interface in org.apache.giraph.block_app.framework.piece.messages
Supplier from configuration
SupplierFromConf.DefaultMessageFactorySupplierFromConf<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.messages
Supplier from configuration returning DefaultMessageValueFactory instances.
SupplierFromConf.SupplierFromConfByCopy<T> - Class in org.apache.giraph.block_app.framework.piece.messages
Supplier from configuration, by copying given instance every time.
SupplierFromConfByCopy(T) - Constructor for class org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.SupplierFromConfByCopy
 
SupplierFromVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,T> - Interface in org.apache.giraph.function.vertex
Function: (vertex) -> T A class that can supply objects of a single type, when given a vertex.
SynchronizedSuperstepOutput<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.superstep_output
Class to use as SuperstepOutput when chosen VertexOutputFormat is not thread-safe.
SynchronizedSuperstepOutput(ImmutableClassesGiraphConfiguration<I, V, E>, Mapper<?, ?, ?, ?>.Context) - Constructor for class org.apache.giraph.io.superstep_output.SynchronizedSuperstepOutput
Constructor
SyntheticGraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Creates synthetic graphs, that can have community structure.
SyntheticGraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
SyntheticGraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
SystemTime - Class in org.apache.giraph.time
Implementation of Time that is thread-safe and should be used in production.
SystemTime() - Constructor for class org.apache.giraph.time.SystemTime
 

T

TargetVertexIdIterator(Vertex<I, ?, ?>) - Constructor for class org.apache.giraph.comm.SendMessageCache.TargetVertexIdIterator
Constructor.
taskId - Variable in class org.apache.giraph.worker.WorkerProgressStats
Id of the mapper
TaskIdsPermitsBarrier - Class in org.apache.giraph.utils
This barrier is used when we don't know how many events are we waiting on from the start.
TaskIdsPermitsBarrier(Progressable) - Constructor for class org.apache.giraph.utils.TaskIdsPermitsBarrier
Constructor
TaskInfo - Class in org.apache.giraph.graph
Abstract class for information about any task - worker or master.
TaskInfo() - Constructor for class org.apache.giraph.graph.TaskInfo
Constructor
TaskRequestIdGenerator - Class in org.apache.giraph.comm.netty.handler
Generate different request ids based on the task id.
TaskRequestIdGenerator() - Constructor for class org.apache.giraph.comm.netty.handler.TaskRequestIdGenerator
 
TCP_BACKLOG - Static variable in interface org.apache.giraph.conf.GiraphConstants
TCP backlog (defaults to number of workers)
teleportationProbability() - Method in class org.apache.giraph.examples.RandomWalkComputation
Reads the teleportation probability from the configuration
TestComputationStateComputation - Class in org.apache.giraph.examples
Vertex to test the local variables in Computation, and pre/postSuperstep methods
TestComputationStateComputation() - Constructor for class org.apache.giraph.examples.TestComputationStateComputation
 
TestComputationStateComputation.TestComputationStateWorkerContext - Class in org.apache.giraph.examples
WorkerContext for TestComputationState
TestComputationStateWorkerContext() - Constructor for class org.apache.giraph.examples.TestComputationStateComputation.TestComputationStateWorkerContext
 
TestGraph<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
TestGraph class for in-memory testing.
TestGraph(GiraphConfiguration) - Constructor for class org.apache.giraph.utils.TestGraph
Constructor requiring classes
TestGraphChecker<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.test_setup
Test graph checker, function that checks whether output of a test is correct.
TestGraphModifier<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.test_setup
Test graph modifier, function that initializes graph (i.e.
TestGraphUtils - Class in org.apache.giraph.block_app.test_setup
Utility functions for running TestGraph unit tests.
TestLongSumReducer() - Constructor for class org.apache.giraph.benchmark.ReducersBenchmark.TestLongSumReducer
 
TestMessageValueFactory<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Message Factory class that allows setting the message value class
TestMessageValueFactory(Class<M>) - Constructor for class org.apache.giraph.factories.TestMessageValueFactory
Constructor
TextAggregatorWriter - Class in org.apache.giraph.aggregators
Default implementation of AggregatorWriter.
TextAggregatorWriter() - Constructor for class org.apache.giraph.aggregators.TextAggregatorWriter
 
TextAppendAggregator - Class in org.apache.giraph.aggregators
Aggregator with Text as its value which keeps appending text to it
TextAppendAggregator() - Constructor for class org.apache.giraph.aggregators.TextAppendAggregator
 
TextDoubleDoubleAdjacencyListVertexInputFormat - Class in org.apache.giraph.io.formats
Class to read graphs stored as adjacency lists with ids represented by Strings and values as doubles.
TextDoubleDoubleAdjacencyListVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.TextDoubleDoubleAdjacencyListVertexInputFormat
 
TextDoubleDoubleAdjacencyListVertexInputFormat.TextDoubleDoubleAdjacencyListVertexReader - Class in org.apache.giraph.io.formats
TextDoubleDoubleAdjacencyListVertexReader(AdjacencyListTextVertexInputFormat.LineSanitizer) - Constructor for class org.apache.giraph.io.formats.TextDoubleDoubleAdjacencyListVertexInputFormat.TextDoubleDoubleAdjacencyListVertexReader
TextEdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class that users should subclass to use their own text based edge output format.
TextEdgeInputFormat() - Constructor for class org.apache.giraph.io.formats.TextEdgeInputFormat
 
TextEdgeInputFormat.TextEdgeReader - Class in org.apache.giraph.io.formats
TextEdgeInputFormat.TextEdgeReaderFromEachLine - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read an edge from each text line.
TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed<T> - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read an edge from each text line after preprocessing it.
TextEdgeOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class that users should subclass to use their own text based edge output format.
TextEdgeOutputFormat() - Constructor for class org.apache.giraph.io.formats.TextEdgeOutputFormat
 
TextEdgeOutputFormat.TextEdgeWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user based on their specific edge output.
TextEdgeOutputFormat.TextEdgeWriterToEachLine<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to write a line for each edge.
TextEdgeReader() - Constructor for class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReader
 
TextEdgeReaderFromEachLine() - Constructor for class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLine
 
TextEdgeReaderFromEachLineProcessed() - Constructor for class org.apache.giraph.io.formats.TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed
 
TextEdgeWriter() - Constructor for class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriter
 
TextEdgeWriterToEachLine() - Constructor for class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriterToEachLine
 
textInputFormat - Variable in class org.apache.giraph.io.formats.TextEdgeInputFormat
Underlying GiraphTextInputFormat.
textInputFormat - Variable in class org.apache.giraph.io.formats.TextVertexInputFormat
Uses the GiraphTextInputFormat to do everything
textInputFormat - Variable in class org.apache.giraph.io.formats.TextVertexValueInputFormat
Uses the GiraphTextInputFormat to do everything
textOutputFormat - Variable in class org.apache.giraph.io.formats.TextEdgeOutputFormat
Uses the TextOutputFormat to do everything
textOutputFormat - Variable in class org.apache.giraph.io.formats.TextVertexOutputFormat
Uses the TextOutputFormat to do everything
TextTypeOps - Enum in org.apache.giraph.types.ops
TypeOps implementation for working with Text type
TextVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class that users should subclass to use their own text based vertex input format.
TextVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.TextVertexInputFormat
 
TextVertexInputFormat.TextVertexReader - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user based on their specific vertex input.
TextVertexInputFormat.TextVertexReaderFromEachLine - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read a vertex from each text line.
TextVertexInputFormat.TextVertexReaderFromEachLineProcessed<T> - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read a vertex from each text line after preprocessing it.
TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions<T,X extends Throwable> - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read a vertex from each text line after preprocessing it with exception handling.
TextVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class that users should subclass to use their own text based vertex output format.
TextVertexOutputFormat() - Constructor for class org.apache.giraph.io.formats.TextVertexOutputFormat
 
TextVertexOutputFormat.TextVertexWriter - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user based on their specific vertex output.
TextVertexOutputFormat.TextVertexWriterToEachLine - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to write a line for each vertex.
TextVertexReader() - Constructor for class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
 
TextVertexReaderFromEachLine() - Constructor for class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLine
 
TextVertexReaderFromEachLineProcessed() - Constructor for class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessed
 
TextVertexReaderFromEachLineProcessedHandlingExceptions() - Constructor for class org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions
 
TextVertexValueInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats
Abstract class that users should subclass to use their own text based vertex value input format.
TextVertexValueInputFormat() - Constructor for class org.apache.giraph.io.formats.TextVertexValueInputFormat
 
TextVertexValueInputFormat.TextVertexValueReader - Class in org.apache.giraph.io.formats
TextVertexValueInputFormat.TextVertexValueReaderFromEachLine - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read a vertex value from each text line.
TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed<T> - Class in org.apache.giraph.io.formats
Abstract class to be implemented by the user to read a vertex value from each text line after preprocessing it.
TextVertexValueReader() - Constructor for class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReader
 
TextVertexValueReaderFromEachLine() - Constructor for class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
 
TextVertexValueReaderFromEachLineProcessed() - Constructor for class org.apache.giraph.io.formats.TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed
 
TextVertexWriter() - Constructor for class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriter
 
TextVertexWriterToEachLine() - Constructor for class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriterToEachLine
 
thenSend(String, Class<M>, FunctionWithVertex<I, V, E, P, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all targets provided by targetsSupplier.
thenSend(String, MessageCombiner<? super I, M>, FunctionWithVertex<I, V, E, P, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all targets provided by targetsSupplier, and use given messageCombiner to combine messages together.
thenSendToNeighbors(String, Class<M>, FunctionWithVertex<I, V, E, P, M>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all neighbors of current vertex.
thenSendToNeighbors(String, MessageCombiner<? super I, M>, FunctionWithVertex<I, V, E, P, M>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all neighbors of current vertex, and use given messageCombiner to combine messages together.
ThreadLocalProgressCounter - Class in org.apache.giraph.utils
Makes a list of ProgressCounter accessible through a ThreadLocal.
ThreadLocalProgressCounter() - Constructor for class org.apache.giraph.utils.ThreadLocalProgressCounter
 
ThreadLocalWorkerGlobalCommUsage() - Constructor for class org.apache.giraph.worker.WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage
Constructor Creates new instances of all reducers from WorkerAggregatorHandler
ThreadUtils - Class in org.apache.giraph.utils
Utility class for thread related functions.
ThresholdBasedOracle - Class in org.apache.giraph.ooc.policy
Out-of-core oracle to adaptively control data kept in memory, with the goal of keeping the memory usage at a desired state.
ThresholdBasedOracle(ImmutableClassesGiraphConfiguration, OutOfCoreEngine) - Constructor for class org.apache.giraph.ooc.policy.ThresholdBasedOracle
Constructor
time(Callable<T>) - Method in class com.yammer.metrics.core.NoOpTimer
 
time() - Method in class org.apache.giraph.metrics.GiraphTimer
Begin timing an event.
Time - Interface in org.apache.giraph.time
Interface for handling Time related operations so that they can be mocked for testing.
TIME_SPENT_WAITING_ON_TOO_MANY_OPEN_REQUESTS_MS - Static variable in interface org.apache.giraph.metrics.MetricNames
Counter for time spent waiting on too many open requests
TimedLogger - Class in org.apache.giraph.utils
Print log messages only if the time is met.
TimedLogger(int, Logger) - Constructor for class org.apache.giraph.utils.TimedLogger
Constructor of the timed logger
TIMER_COMMUNICATION_TIME - Static variable in class org.apache.giraph.graph.GraphTaskManager
Name of metric for time from first message till last message flushed
TIMER_COMPUTE_ALL - Static variable in class org.apache.giraph.graph.GraphTaskManager
Name of metric for compute on all vertices in msec
TIMER_SUPERSTEP_GC_TIME - Static variable in class org.apache.giraph.graph.GraphTaskManager
Name of metric for time spent doing GC per superstep in msec
TIMER_SUPERSTEP_TIME - Static variable in class org.apache.giraph.graph.GraphTaskManager
Name of metric for superstep time in msec
TIMER_TIME_TO_FIRST_MSG - Static variable in class org.apache.giraph.graph.GraphTaskManager
Name of metric for time from begin compute to first message sent
TIMER_WAIT_REQUESTS - Static variable in class org.apache.giraph.worker.BspServiceWorker
Name of gauge for time spent waiting on other workers
Times - Class in org.apache.giraph.time
Utility methods for Time classes.
TimeStatsPerEvent(String) - Constructor for class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
toByteArray(int, int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
toByteArray() - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Copies the internal byte array
toByteArray(int, int) - Method in interface org.apache.giraph.utils.ExtendedDataOutput
Return a copy of slice of byte array
toByteArray() - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
toByteArray(int, int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
toByteArray(T) - Static method in class org.apache.giraph.utils.WritableUtils
Serialize given writable to byte array, using new instance of ExtendedByteArrayDataOutput.
toByteArrayUnsafe(T) - Static method in class org.apache.giraph.utils.WritableUtils
Serialize given writable to byte array, using new instance of UnsafeByteArrayOutputStream.
toJsonArray() - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
Convert input format description to json array
toJsonString(Iterable<? extends InputFormatDescription>) - Static method in class org.apache.giraph.io.formats.multi.InputFormatDescription
Create JSON string for the InputFormatDescriptions
TopNReduce<S extends Comparable<S>> - Class in org.apache.giraph.block_app.reducers
Extracts top N largest elements
TopNReduce(int) - Constructor for class org.apache.giraph.block_app.reducers.TopNReduce
 
TopNReduce() - Constructor for class org.apache.giraph.block_app.reducers.TopNReduce
 
toString() - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
toString() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
toString() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
toString() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
toString() - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
toString() - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
toString() - Method in class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
toString() - Method in class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
toString() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
toString() - Method in class org.apache.giraph.bsp.BspInputSplit
 
toString() - Method in class org.apache.giraph.comm.messages.queue.PartitionMessage
 
toString() - Method in class org.apache.giraph.comm.netty.handler.ClientRequestId
 
toString() - Method in class org.apache.giraph.comm.netty.handler.RequestInfo
 
toString() - Method in class org.apache.giraph.conf.AbstractConfOption
 
toString() - Method in class org.apache.giraph.conf.ClassConfOption
 
toString() - Method in class org.apache.giraph.edge.DefaultEdge
 
toString() - Method in class org.apache.giraph.edge.EdgeNoValue
 
toString() - Method in class org.apache.giraph.examples.scc.SccVertexValue
 
toString() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
 
toString() - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
toString() - Method in class org.apache.giraph.examples.VerifyMessage.VerifiableMessage
 
toString() - Method in class org.apache.giraph.factories.DefaultMessageValueFactory
 
toString() - Method in class org.apache.giraph.function.ObjectHolder
 
toString() - Method in class org.apache.giraph.function.ObjectNotifier
 
toString() - Method in class org.apache.giraph.function.ObjectTransfer
 
toString() - Method in class org.apache.giraph.graph.DefaultVertex
 
toString() - Method in class org.apache.giraph.graph.GlobalStats
 
toString() - Method in class org.apache.giraph.graph.GraphState
 
toString() - Method in enum org.apache.giraph.graph.GraphType
 
toString() - Method in class org.apache.giraph.graph.TaskInfo
 
toString() - Method in class org.apache.giraph.graph.VertexEdgeCount
 
toString() - Method in class org.apache.giraph.graph.VertexMutations
 
toString() - Method in class org.apache.giraph.io.formats.multi.InputFormatDescription
 
toString() - Method in class org.apache.giraph.job.CombinedWorkerProgress
 
toString() - Method in class org.apache.giraph.jython.JythonJob.EdgeInput
 
toString() - Method in class org.apache.giraph.jython.JythonJob.InputBase
 
toString() - Method in class org.apache.giraph.jython.JythonJob.VertexInput
 
toString() - Method in class org.apache.giraph.jython.JythonJob.VertexOutput
 
toString() - Method in class org.apache.giraph.master.MasterInfo
 
toString() - Method in class org.apache.giraph.master.SuperstepClasses
 
toString() - Method in class org.apache.giraph.metrics.LongAndTimeUnit
 
toString() - Method in class org.apache.giraph.ooc.command.LoadPartitionIOCommand
 
toString() - Method in class org.apache.giraph.ooc.command.StoreDataBufferIOCommand
 
toString() - Method in class org.apache.giraph.ooc.command.StoreIncomingMessageIOCommand
 
toString() - Method in class org.apache.giraph.ooc.command.StorePartitionIOCommand
 
toString() - Method in class org.apache.giraph.ooc.command.WaitIOCommand
 
toString() - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics
 
toString() - Method in class org.apache.giraph.ooc.persistence.DataIndex.NumericIndexEntry
 
toString() - Method in class org.apache.giraph.ooc.persistence.DataIndex
 
toString() - Method in enum org.apache.giraph.ooc.persistence.DataIndex.TypeIndexEntry
 
toString() - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
toString() - Method in class org.apache.giraph.partition.PartitionStats
 
toString() - Method in class org.apache.giraph.partition.SimplePartition
 
toString() - Method in class org.apache.giraph.scripting.DeployedScript
 
toString() - Method in class org.apache.giraph.types.JavaWritablePair
 
toString() - Method in class org.apache.giraph.utils.TestGraph
 
toString() - Method in class org.apache.giraph.worker.WorkerInfo
 
toStringShort() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
TOTAL_MS_NAME - Static variable in class org.apache.giraph.counters.GiraphTimers
Counter name for total msec
TOTAL_REQUESTS - Static variable in interface org.apache.giraph.metrics.MetricNames
Guage of total requests
totalMemoryMB() - Static method in class org.apache.giraph.utils.MemoryUtils
Get total memory in megabytes
totalMsgBytesSentInSuperstep - Variable in class org.apache.giraph.comm.SendMessageCache
Message bytes sent during the last superstep
totalMsgsSentInSuperstep - Variable in class org.apache.giraph.comm.SendMessageCache
Messages sent during the last superstep
totalRecords - Variable in class org.apache.giraph.examples.GeneratedEdgeReader
Total records to read (on this split alone)
totalRecords - Variable in class org.apache.giraph.examples.GeneratedVertexReader
Total records to read (on this split alone)
TRACK_JOB_PROGRESS_ON_CLIENT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Whether to track job progress on client or not
trackJobProgressOnClient() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check whether to track job progress on client or not
transferThisPartition(PartitionOwner) - Method in class org.apache.giraph.graph.GiraphTransferRegulator
Is this outbound data Collection full, and ready to transfer?
transientEdges - Variable in class org.apache.giraph.edge.AbstractEdgeStore
Map used to temporarily store incoming edges.
TransientRandom - Class in org.apache.giraph.writable.kryo
Transient Random class.
TransientRandom() - Constructor for class org.apache.giraph.writable.kryo.TransientRandom
 
transitionProbability(Vertex<LongWritable, DoubleWritable, NullWritable>, double, Edge<LongWritable, NullWritable>) - Method in class org.apache.giraph.examples.PageRankComputation
 
transitionProbability(Vertex<LongWritable, DoubleWritable, E>, double, Edge<LongWritable, E>) - Method in class org.apache.giraph.examples.RandomWalkComputation
Compute the probability of transitioning to a neighbor vertex
transitionProbability(Vertex<LongWritable, DoubleWritable, DoubleWritable>, double, Edge<LongWritable, DoubleWritable>) - Method in class org.apache.giraph.examples.RandomWalkWithRestartComputation
 
TranslateEdge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.mapping.translate
Used to conduct expensive translation of edges during vertex input phase
translateId(LongWritable) - Method in class org.apache.giraph.mapping.translate.LongByteTranslateEdge
 
translateId(I) - Method in interface org.apache.giraph.mapping.translate.TranslateEdge
Translate Id & return a new instance
trim() - Method in class org.apache.giraph.edge.ArrayListEdges
 
trim() - Method in class org.apache.giraph.edge.ByteArrayEdges
 
trim() - Method in class org.apache.giraph.edge.HashMultimapEdges
 
trim() - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
trim() - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
trim() - Method in class org.apache.giraph.edge.LongDiffArray
This function takes all recent updates and stores them efficiently.
trim() - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
This function takes all recent updates and stores them efficiently.
trim() - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
trim() - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
trim() - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
trim() - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
trim() - Method in class org.apache.giraph.graph.DefaultVertex
 
trim() - Method in interface org.apache.giraph.types.ops.collections.array.WArrayList
Trims this array list so that the capacity is equal to the size.
trim(long) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
trim(long) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
trim(long) - Method in interface org.apache.giraph.types.ops.collections.BasicSet
Makes sure set is not using space with capacity more than max(n,size()) entries.
trim() - Method in interface org.apache.giraph.utils.Trimmable
Compacts all recent updates to this object.
Trimmable - Interface in org.apache.giraph.utils
Interface for OutEdges and Vertex implementations capable to optimize in-memory data representation.
TripleFunction<F1,F2,F3,T> - Interface in org.apache.giraph.function
Function: (F1, F2, F3) -> T
trySleep(long) - Static method in class org.apache.giraph.utils.ThreadUtils
Sleep for specified milliseconds, logging and ignoring interrupted exceptions
TypeHolder() - Constructor for class org.apache.giraph.jython.JythonJob.TypeHolder
 
TypeOps<T> - Interface in org.apache.giraph.types.ops
Type operations, allowing working generically with mutable types, but still having efficient code.
TypeOpsUtils - Class in org.apache.giraph.types.ops
Utility functions for getting TypeOps instances from class types.
TYPES_HOLDER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
TypesHolder, used if Computation not set - optional
TypesHolder<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> - Interface in org.apache.giraph.conf
Interface for classes that are parameterized by all of the Giraph types.
TypeWithHive() - Constructor for class org.apache.giraph.jython.JythonJob.TypeWithHive
 

U

UNKNOWN_SIZE - Static variable in class org.apache.giraph.comm.requests.WritableRequest
Value to use when size of the request in serialized form is not known or too expensive to calculate
unlimited(Block) - Static method in class org.apache.giraph.block_app.framework.block.RepeatBlock
Create a repeat block that executes unlimited number of times.
unlimited(Block, Supplier<Boolean>) - Static method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
Repeat unlimited number of times, until toQuit supplier returns true.
UnsafeArrayReads - Class in org.apache.giraph.utils
Byte array input stream that uses Unsafe methods to deserialize much faster
UnsafeArrayReads(byte[]) - Constructor for class org.apache.giraph.utils.UnsafeArrayReads
Constructor
UnsafeArrayReads(byte[], int, int) - Constructor for class org.apache.giraph.utils.UnsafeArrayReads
Constructor.
UnsafeByteArrayInputStream - Class in org.apache.giraph.utils
UnsafeByteArrayInputStream This stream now extends com.esotericsoftware.kryo.io.Input so that kryo serialization can directly read from this stream without using an additional buffer, providing a faster serialization.
UnsafeByteArrayInputStream(byte[]) - Constructor for class org.apache.giraph.utils.UnsafeByteArrayInputStream
Constructor
UnsafeByteArrayInputStream(byte[], int, int) - Constructor for class org.apache.giraph.utils.UnsafeByteArrayInputStream
Constructor.
UnsafeByteArrayOutputStream - Class in org.apache.giraph.utils
Byte array output stream that uses Unsafe methods to serialize/deserialize much faster.
UnsafeByteArrayOutputStream() - Constructor for class org.apache.giraph.utils.UnsafeByteArrayOutputStream
Constructor
UnsafeByteArrayOutputStream(int) - Constructor for class org.apache.giraph.utils.UnsafeByteArrayOutputStream
Constructor
UnsafeByteArrayOutputStream(byte[]) - Constructor for class org.apache.giraph.utils.UnsafeByteArrayOutputStream
Constructor to take in a buffer
UnsafeByteArrayOutputStream(byte[], int) - Constructor for class org.apache.giraph.utils.UnsafeByteArrayOutputStream
Constructor to take in a buffer with a given position into that buffer
UnsafeReads - Class in org.apache.giraph.utils
Byte array input stream that uses Unsafe methods to deserialize much faster
UnsafeReads(int) - Constructor for class org.apache.giraph.utils.UnsafeReads
Constructor
UnsafeReads(long, int) - Constructor for class org.apache.giraph.utils.UnsafeReads
Constructor with offset
UnsafeReusableByteArrayInput - Class in org.apache.giraph.utils
UnsafeReusableByteArrayInput is a data structure to read from a byte buffer with a read pointer that can be moved to desired location
UnsafeReusableByteArrayInput() - Constructor for class org.apache.giraph.utils.UnsafeReusableByteArrayInput
Default Constructor
UNSENT_CACHE_WAIT_INTERVAL - Static variable in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Time interval to wait on unsent requests cahce until we find a spot in it
UNSET_APPLICATION_ATTEMPT - Static variable in class org.apache.giraph.bsp.BspService
Unset application attempt
UNSET_SUPERSTEP - Static variable in class org.apache.giraph.bsp.BspService
Unset superstep
unwrap() - Method in class org.apache.giraph.edge.MutableEdgesWrapper
Moves all the remaining edges to the new data structure, and returns it.
unwrap(BooleanWritable) - Method in class org.apache.giraph.types.BooleanWritableToBooleanUnwrapper
 
unwrap(ByteWritable) - Method in class org.apache.giraph.types.ByteWritableToByteUnwrapper
 
unwrap(ByteWritable) - Method in class org.apache.giraph.types.ByteWritableToIntUnwrapper
 
unwrap(ByteWritable) - Method in class org.apache.giraph.types.ByteWritableToLongUnwrapper
 
unwrap(ByteWritable) - Method in class org.apache.giraph.types.ByteWritableToShortUnwrapper
 
unwrap(DoubleWritable) - Method in class org.apache.giraph.types.DoubleWritableToDoubleUnwrapper
 
unwrap(FloatWritable) - Method in class org.apache.giraph.types.FloatWritableToDoubleUnwrapper
 
unwrap(FloatWritable) - Method in class org.apache.giraph.types.FloatWritableToFloatUnwrapper
 
unwrap(IntWritable) - Method in class org.apache.giraph.types.IntWritableToIntUnwrapper
 
unwrap(IntWritable) - Method in class org.apache.giraph.types.IntWritableToLongUnwrapper
 
unwrap(LongWritable) - Method in class org.apache.giraph.types.LongWritableToLongUnwrapper
 
unwrap(W) - Method in interface org.apache.giraph.types.WritableUnwrapper
Convert from writable type to java type
unwrapIfNeeded(Writable) - Static method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Unwrap Writable object if it was wrapped initially, inverse of wrapIfNeeded function.
unwrapMutableEdges() - Method in class org.apache.giraph.graph.ByteValueVertex
 
unwrapMutableEdges() - Method in class org.apache.giraph.graph.DefaultVertex
 
unwrapMutableEdges() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
unwrapMutableEdges() - Method in interface org.apache.giraph.graph.Vertex
If a MutableEdgesWrapper was used to provide a mutable iterator, copy any remaining edges to the new OutEdges data structure and keep a direct reference to it (thus discarding the wrapper).
update(int) - Method in class com.yammer.metrics.core.NoOpHistogram
 
update(long) - Method in class com.yammer.metrics.core.NoOpHistogram
 
update(long, TimeUnit) - Method in class com.yammer.metrics.core.NoOpTimer
 
update(IOCommand.IOCommandType, long, long) - Method in class org.apache.giraph.ooc.OutOfCoreIOStatistics
Update statistics with the last IO command that is executed.
updateActiveThreadsFraction(double) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Update the fraction of processing threads that should remain active.
updateCredit(short) - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
Update the max credit that is announced to other workers
updateGiraphClasses(GiraphClasses) - Method in class org.apache.giraph.master.SuperstepClasses
Update GiraphClasses with updated types
updateLowestGraphPercentageInMemory(int) - Method in class org.apache.giraph.worker.WorkerProgress
Update lowest percentage of graph which stayed in memory so far in the execution
updateMasterProgress(MasterProgress) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
updateMasterProgress(MasterProgress) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
updateMasterProgress(MasterProgress) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
updateMasterProgress(MasterProgress) - Method in interface org.apache.giraph.job.JobProgressTracker
Master should call this method to update its progress
updateMemory() - Method in class org.apache.giraph.worker.WorkerProgress
Update memory info
updatePartitionOwners(List<PartitionOwner>, WorkerInfo, Collection<? extends PartitionOwner>) - Static method in class org.apache.giraph.partition.PartitionBalancer
Helper function to update partition owners and determine which partitions need to be sent from a specific worker.
updatePartitionOwners(WorkerInfo, Collection<? extends PartitionOwner>) - Method in interface org.apache.giraph.partition.WorkerGraphPartitioner
Get the partitions owners and update locally.
updatePartitionOwners(WorkerInfo, Collection<? extends PartitionOwner>) - Method in class org.apache.giraph.partition.WorkerGraphPartitionerImpl
 
updateProgress(WorkerProgress) - Method in class org.apache.giraph.graph.JobProgressTrackerClientNoOp
 
updateProgress(WorkerProgress) - Method in class org.apache.giraph.graph.RetryableJobProgressTrackerClient
 
updateProgress(WorkerProgress) - Method in class org.apache.giraph.job.DefaultJobProgressTrackerService
 
updateProgress(WorkerProgress) - Method in interface org.apache.giraph.job.JobProgressTracker
Workers should call this method to update their progress
updateRates(double) - Method in class org.apache.giraph.ooc.policy.ThresholdBasedOracle
Update statistics and rate regarding communication credits and number of active threads.
updateRequestsCreditFraction(double) - Method in class org.apache.giraph.ooc.OutOfCoreEngine
Update the credit announced for this worker in Netty.
updateSuperstepClasses(SuperstepClasses) - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Update Computation and MessageCombiner class used
US_PER_MS - Static variable in interface org.apache.giraph.time.Time
Microseconds per millisecond
US_PER_SECOND - Static variable in interface org.apache.giraph.time.Time
Microseconds per second
US_PER_SECOND_AS_FLOAT - Static variable in interface org.apache.giraph.time.Time
Microseconds per second (as float)
USE_BIG_DATA_IO_FOR_MESSAGES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use BigDataIO for messages? If there are super-vertices in the graph which receive a lot of messages (total serialized size of messages goes beyond the maximum size of a byte array), setting this option to true will remove that limit.
USE_FULL_GIRAPH_ENV_IN_TESTS - Static variable in class org.apache.giraph.block_app.test_setup.TestGraphUtils
modify locally for running full Digraph tests from IDE
USE_G1_COLLECTOR - Static variable in class org.apache.giraph.conf.FacebookConfiguration
Note: using G1 is often faster, but we've seen it add off heap memory overhead which can cause issues.
USE_INPUT_SPLIT_LOCALITY - Static variable in interface org.apache.giraph.conf.GiraphConstants
To minimize network usage when reading input splits, each worker can prioritize splits that reside on its host.
USE_MASTER_LOGGING_AGGREGATOR - Static variable in class org.apache.giraph.utils.MasterLoggingAggregator
Whether or not to use master logging aggregator
USE_MASTER_LOGGING_AGGREGATOR_DEFAULT - Static variable in class org.apache.giraph.utils.MasterLoggingAggregator
Default is not using master logging aggregator
USE_MEMORY_OBSERVER - Static variable in class org.apache.giraph.worker.MemoryObserver
Whether or not to use memory observer
USE_MESSAGE_SIZE_ENCODING - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use message size encoding (typically better for complex objects, not meant for primitive wrapped messages)
USE_OUT_OF_CORE_GRAPH - Static variable in interface org.apache.giraph.conf.GiraphConstants
Enable out-of-core graph.
USE_SUPERSTEP_COUNTERS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use superstep counters? (boolean)
USE_THREAD_LOCAL_AGGREGATORS - Static variable in class org.apache.giraph.comm.aggregators.AggregatorUtils
Whether or not to have a copy of aggregators for each compute thread.
USE_THREAD_LOCAL_AGGREGATORS_DEFAULT - Static variable in class org.apache.giraph.comm.aggregators.AggregatorUtils
Default is not to have a copy of aggregators for each thread
USE_UNSAFE_SERIALIZATION - Static variable in interface org.apache.giraph.conf.GiraphConstants
Use unsafe serialization?
useCheckpointing() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check if checkpointing is used
useInputOutEdges() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Check whether the user has specified a different OutEdges class to be used during edge-based input.
useInputOutEdges - Variable in class org.apache.giraph.edge.AbstractEdgeStore
Whether the OutEdges class used during input is different from the one used during computation.
useInputSplitLocality() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check if we want to prioritize input splits which reside on the host.
useLogThreadLayout() - Method in class org.apache.giraph.conf.GiraphConfiguration
Use the log thread layout option?
useMasterLoggingAggregator(Configuration) - Static method in class org.apache.giraph.utils.MasterLoggingAggregator
Check if master logging aggregator is used.
useMessageCombiner() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
useMessageCombiner() - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
useMessageCombiner() - Method in interface org.apache.giraph.conf.MessageClasses
Has message combiner been specified
useMessageSizeEncoding() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Use message size encoding? This feature may help with complex message objects.
useOneMessageToManyIdsEncoding() - Method in enum org.apache.giraph.comm.messages.MessageEncodeAndStoreType
True if one message to many ids encoding is set
useOutgoingMessageCombiner() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Check if user set a combiner
USER_PARTITION_COUNT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Overrides default partition count calculation if not -1
useThisFactory(Configuration, String) - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
Use this factory in the Configuration
useThreadLocalAggregators(ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.comm.aggregators.AggregatorUtils
Check if we should use thread local aggregators.
useUnsafeSerialization(boolean) - Method in class org.apache.giraph.conf.GiraphConfiguration
Set whether to use unsafe serialization
useUnsafeSerialization() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
Use unsafe serialization?

V

validateConfiguration() - Method in class org.apache.giraph.job.GiraphConfigurationValidator
Make sure that all registered classes have matching types.
value() - Method in class com.yammer.metrics.core.NoOpGuage
 
value - Variable in class org.apache.giraph.function.primitive.PrimitiveRefs.DoubleRef
value
value - Variable in class org.apache.giraph.function.primitive.PrimitiveRefs.FloatRef
value
value - Variable in class org.apache.giraph.function.primitive.PrimitiveRefs.IntRef
value
value - Variable in class org.apache.giraph.function.primitive.PrimitiveRefs.LongRef
value
value - Variable in class org.apache.giraph.function.primitive.PrimitiveRefs.ObjRef
value
value - Variable in class org.apache.giraph.function.primitive.PrimitiveRefs.ShortRef
value
value() - Method in class org.apache.giraph.metrics.ValueGauge
 
valueAndUnit() - Method in class org.apache.giraph.metrics.GiraphTimer
Get string representation of value
ValueFactories<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.factories
Holder for factories to create user types.
ValueFactories(Configuration) - Constructor for class org.apache.giraph.factories.ValueFactories
Constructor reading from Configuration
ValueFactory<W extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.factories
Base interface for factories creating user graph value types (IVEMM)
ValueGauge<T extends Number> - Class in org.apache.giraph.metrics
A Gauge that holds a value.
ValueGauge(GiraphMetricsRegistry, String) - Constructor for class org.apache.giraph.metrics.ValueGauge
Constructor that registers Gauge in MetricsRegistry.
valueIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
valueIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
valueIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
valueIterator() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
Iterator over map values.
valueOf(String) - Static method in enum org.apache.giraph.bsp.ApplicationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.bsp.checkpoints.CheckpointStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.bsp.SuperstepState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.comm.GlobalCommType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.comm.messages.MessageEncodeAndStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.comm.netty.handler.AckSignalFlag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.comm.requests.RequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.conf.ConfOptionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.counters.CustomCounter.Aggregation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.examples.scc.SccPhaseMasterCompute.Phases
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.graph.GraphFunctions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.graph.GraphType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.graph.Language
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.io.InputType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.metrics.MeterDesc
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.ooc.command.IOCommand.IOCommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.ooc.command.StoreDataBufferIOCommand.DataBufferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.ooc.persistence.DataIndex.TypeIndexEntry
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.ooc.policy.OutOfCoreOracle.IOAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.scripting.DeployType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.BooleanTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.ByteTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.DoubleTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.FloatTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.IntTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.LongTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.MapTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.types.ops.TextTypeOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.utils.hashing.LongWritableFunnel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.giraph.zk.ZooKeeperManager.State
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.giraph.bsp.ApplicationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.bsp.checkpoints.CheckpointStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.bsp.SuperstepState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.comm.GlobalCommType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.comm.messages.MessageEncodeAndStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.comm.netty.handler.AckSignalFlag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.comm.requests.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.conf.ConfOptionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.counters.CustomCounter.Aggregation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.examples.scc.SccPhaseMasterCompute.Phases
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.graph.GraphFunctions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.graph.GraphType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.graph.Language
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.io.InputType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.metrics.MeterDesc
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.ooc.command.IOCommand.IOCommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.ooc.command.StoreDataBufferIOCommand.DataBufferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.ooc.persistence.DataIndex.TypeIndexEntry
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.ooc.policy.OutOfCoreOracle.IOAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.scripting.DeployType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.BooleanTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.ByteTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
values() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
values() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
values() - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap
A collection of all values.
values() - Static method in enum org.apache.giraph.types.ops.DoubleTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.FloatTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.IntTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.LongTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.MapTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.types.ops.TextTypeOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.utils.hashing.LongWritableFunnel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.giraph.zk.ZooKeeperManager.State
Returns an array containing the constants of this enum type, in the order they are declared.
ValueWithHostname<T extends Number> - Class in org.apache.giraph.metrics
Pair of value with host it came from.
ValueWithHostname(T) - Constructor for class org.apache.giraph.metrics.ValueWithHostname
Create with initial value
Varint - Class in org.apache.giraph.utils
Encodes signed and unsigned values using a common variable-length scheme, found for example in Google's Protocol Buffers.
VERBOSE - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for verbose
VerboseByteStructMessageWrite - Class in org.apache.giraph.utils
Verbose Error mesage for ByteArray based messages
verboseWriteCurrentMessage(VertexIdMessageIterator<I, M>, DataOutput) - Static method in class org.apache.giraph.utils.VerboseByteStructMessageWrite
verboseWriteCurrentMessage de-serialize, then write messages
verboseWriteCurrentMessage(I, M, DataOutput) - Static method in class org.apache.giraph.utils.VerboseByteStructMessageWrite
verboseWriteCurrentMessage de-serialize, then write messages
VerifiableMessage() - Constructor for class org.apache.giraph.examples.VerifyMessage.VerifiableMessage
Default constructor used with reflection.
VerifiableMessage(long, long, float) - Constructor for class org.apache.giraph.examples.VerifyMessage.VerifiableMessage
Constructor with verifiable arguments.
verifyConcrete(Class<?>, String) - Static method in class org.apache.giraph.utils.ReflectionUtils
Verify that given type is a concrete type that can be instantiated.
verifyConsistent(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
verifyConsistent(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
verifyConsistent(ImmutableClassesGiraphConfiguration) - Method in interface org.apache.giraph.conf.MessageClasses
Verify if types are internally consistent
VerifyMessage - Class in org.apache.giraph.examples
An example that simply uses its id, value, and edges to compute new data every iteration to verify that messages are sent and received at the appropriate location and superstep.
VerifyMessage() - Constructor for class org.apache.giraph.examples.VerifyMessage
 
VerifyMessage.VerifiableMessage - Class in org.apache.giraph.examples
Message that will be sent in VerifyMessage.VerifyMessageComputation.
VerifyMessage.VerifyMessageComputation - Class in org.apache.giraph.examples
Send and verify messages.
VerifyMessage.VerifyMessageComputation.VerifyMessageVertexWorkerContext - Class in org.apache.giraph.examples
Worker context used with VerifyMessage.VerifyMessageComputation.
VerifyMessage.VerifyMessageMasterCompute - Class in org.apache.giraph.examples
Master compute associated with VerifyMessage.VerifyMessageComputation.
VerifyMessageComputation() - Constructor for class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation
 
VerifyMessageMasterCompute() - Constructor for class org.apache.giraph.examples.VerifyMessage.VerifyMessageMasterCompute
 
VerifyMessageVertexWorkerContext() - Constructor for class org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation.VerifyMessageVertexWorkerContext
 
verifyTypes(Class<?>, Class<?>, String, Class<?>) - Static method in class org.apache.giraph.utils.ReflectionUtils
Verify that found type matches the expected type.
verifyTypesMatch(boolean) - Method in class org.apache.giraph.master.SuperstepClasses
Verify that types of current Computation and MessageCombiner are valid.
versionOf(String) - Method in class org.apache.giraph.utils.GiraphDepVersions
Get version of the named dependency, or null if not found
Vertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.graph
Class which holds vertex id, data and edges.
VERTEX_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex class
VERTEX_EDGES_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex edges class - optional
VERTEX_EDGES_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
OutEdges factory class - optional
VERTEX_ID_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex index class
VERTEX_ID_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex id factory class - optional
VERTEX_ID_KEY - Static variable in class org.apache.giraph.io.formats.JsonBase64VertexFormat
Vertex id key
VERTEX_INPUT_DIR - Static variable in class org.apache.giraph.io.formats.GiraphFileInputFormat
Vertex input file paths.
VERTEX_INPUT_FILTER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
VertexInputFilter class
VERTEX_INPUT_FORMAT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
VertexInputFormat class
VERTEX_INPUT_FORMAT_DESCRIPTIONS - Static variable in class org.apache.giraph.io.formats.multi.VertexInputFormatDescription
VertexInputFormats description - JSON array containing a JSON array for each vertex input.
VERTEX_OUTPUT_FORMAT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
VertexOutputFormat class
VERTEX_OUTPUT_FORMAT_SUBDIR - Static variable in interface org.apache.giraph.conf.GiraphConstants
EdgeOutputFormat sub-directory
VERTEX_OUTPUT_FORMAT_THREAD_SAFE - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex output format thread-safe - if your VertexOutputFormat allows several vertexWriters to be created and written to in parallel, you should set this to true.
VERTEX_RESOLVER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex resolver class - optional
VERTEX_VALUE_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex value class
VERTEX_VALUE_COMBINER_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex value combiner class - optional
VERTEX_VALUE_FACTORY_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Vertex value factory class - optional
VERTEX_VALUE_KEY - Static variable in class org.apache.giraph.io.formats.JsonBase64VertexFormat
Vertex value key
VertexChanges<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.graph
Structure to hold all the possible graph mutations that can occur during a superstep.
VertexEdgeCount - Class in org.apache.giraph.graph
Simple immutable structure for storing a final vertex and edge count.
VertexEdgeCount() - Constructor for class org.apache.giraph.graph.VertexEdgeCount
Default constructor.
VertexEdgeCount(long, long, long) - Constructor for class org.apache.giraph.graph.VertexEdgeCount
Constructor with initial values.
vertexEdgesSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns edges object.
vertexId - Variable in class org.apache.giraph.utils.ByteStructVertexIdIterator
Current vertex id
vertexIdData - Variable in class org.apache.giraph.utils.ByteStructVertexIdDataIterator
VertexIdData to iterate over
VertexIdData<I extends org.apache.hadoop.io.WritableComparable,T> - Interface in org.apache.giraph.utils
Stores vertex ids and data associated with a vertex
VertexIdDataIterator<I extends org.apache.hadoop.io.WritableComparable,T> - Interface in org.apache.giraph.utils
Special iterator that reuses vertex ids and data objects so that the lifetime of the object is only until next() is called.
VertexIdEdgeIterator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.utils
Special iterator that reuses vertex ids and edge objects so that the lifetime of the object is only until next() is called.
VertexIdEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.utils
Stores vertex id and out-edges of a vertex
VertexIdFactory<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.factories
Factory class to create default vertex IDs.
VertexIdIterator<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.utils
Common implementation for VertexIdEdgeIterator, VertexIdMessageIterator and VertexIdMessageBytesIterator.
VertexIdMessageBytesIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.utils
Special iterator that reuses vertex ids and messages bytes so that the lifetime of the object is only until next() is called.
VertexIdMessageIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.utils
Special iterator that reuses vertex ids and message objects so that the lifetime of the object is only until next() is called.
VertexIdMessages<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.utils
VertexIdMessages
vertexIdSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns vertex ID.
VertexInput() - Constructor for class org.apache.giraph.jython.JythonJob.VertexInput
 
VertexInputFilter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.io.filters
Filters vertices on input.
vertexInputFilterClass - Variable in class org.apache.giraph.conf.GiraphClasses
Vertex Input Filter class
VertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Use this to load data for a BSP application.
VertexInputFormat() - Constructor for class org.apache.giraph.io.VertexInputFormat
 
vertexInputFormatClass - Variable in class org.apache.giraph.conf.GiraphClasses
Vertex input format class - cached for fast access
VertexInputFormatDescription<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.formats.multi
Description of the vertex input format - holds vertex input format class and all parameters specifically set for that vertex input format.
VertexInputFormatDescription(Class<? extends VertexInputFormat<I, V, E>>) - Constructor for class org.apache.giraph.io.formats.multi.VertexInputFormatDescription
Constructor with vertex input format class
VertexInputFormatDescription(String) - Constructor for class org.apache.giraph.io.formats.multi.VertexInputFormatDescription
Constructor with json string describing this input format
VertexInputSplitsCallable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
Load as many vertex input splits as possible.
VertexInputSplitsCallable(VertexInputFormat<I, V, E>, Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.VertexInputSplitsCallable
Constructor.
VertexInputSplitsCallableFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
VertexInputSplitsCallableFactory(VertexInputFormat<I, V, E>, Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration<I, V, E>, BspServiceWorker<I, V, E>, WorkerInputSplitsHandler) - Constructor for class org.apache.giraph.worker.VertexInputSplitsCallableFactory
Constructor.
vertexInputSplitsLoaded - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many vertex input splits were loaded until now
vertexInputSplitsSet() - Method in class org.apache.giraph.master.MasterProgress
Whether or not number of vertex input splits was set yet
VertexIterator<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.utils
Iterates over vertices stored in an ExtendedDataOutput such that the ownership of the vertex id can be transferred to another object.
VertexIterator(ExtendedDataOutput, ImmutableClassesGiraphConfiguration<I, V, E>) - Constructor for class org.apache.giraph.utils.VertexIterator
Constructor.
VertexMutations<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.graph
Structure to hold all the possible graph mutations that can occur during a superstep.
VertexMutations() - Constructor for class org.apache.giraph.graph.VertexMutations
 
vertexNeighborsSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns Iterator over all neighbor IDs.
vertexNeighborsSupplier(Predicate<I>) - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns Iterator over neighbor IDs that return true for given predicate.
vertexNeighborsSupplierWithIndex(PairPredicate<PrimitiveRefs.IntRef, I>) - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which gives Iterator over neighbor IDs that return true for given predicate over (index, target) Note - iterator returns reused object, so you need to "use" them, before calling next() again.
VertexOutput() - Constructor for class org.apache.giraph.jython.JythonJob.VertexOutput
 
VertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Implement to output the graph after the computation.
VertexOutputFormat() - Constructor for class org.apache.giraph.io.VertexOutputFormat
 
vertexOutputFormatClass - Variable in class org.apache.giraph.conf.GiraphClasses
Vertex output format class - cached for fast access
vertexOutputFormatThreadSafe() - Method in class org.apache.giraph.conf.GiraphConfiguration
Check if VertexOutputFormat is thread-safe
VertexPostprocessor - Interface in org.apache.giraph.block_app.framework.piece.interfaces
Interface containing a single function - postprocess.
VertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Analogous to Hadoop's RecordReader for vertices.
VertexReader() - Constructor for class org.apache.giraph.io.VertexReader
 
VertexReaderWrapper<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.iterables
Wraps GiraphReader for vertices into VertexReader
VertexReaderWrapper(GiraphReader<Vertex<I, V, E>>) - Constructor for class org.apache.giraph.io.iterables.VertexReaderWrapper
Constructor
vertexReceive(Vertex<I, V, E>, Iterable<M>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerReceiveFunctions
 
vertexReceive(Vertex<I, V, E>, Iterable<M>) - Method in interface org.apache.giraph.block_app.framework.piece.interfaces.VertexReceiver
Must be defined by user to do computation on a single Vertex.
VertexReceiver<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> - Interface in org.apache.giraph.block_app.framework.piece.interfaces
Interface representing actions that happen on worker, for each vertex, during receive phase: to receive messages from vertices to receive data from master through aggregators Marked to not allow seriazliation, as it should be created on the worker, so should never be serialiized, disallow only for catching problems early.
VertexResolver<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.graph
Handles all the situations that can arise upon creation/removal of vertices and edges.
vertexResolverClass - Variable in class org.apache.giraph.conf.GiraphClasses
Vertex resolver class - cached for fast access
vertexSend(Vertex<I, V, E>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerSendFunctions
 
vertexSend(Vertex<I, V, E>) - Method in interface org.apache.giraph.block_app.framework.piece.interfaces.VertexSender
Must be defined by user to do computation on a single Vertex.
VertexSender<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.framework.piece.interfaces
Interface representing actions that happen on worker, for each vertex, during send phase: to send messages to vertices to send data for aggregation on master Marked to not allow seriazliation, as it should be created on the worker, so should never be serialiized, disallow only for catching problems early.
VertexSenderObserver - Interface in org.apache.giraph.block_app.framework.piece.global_comm.internal
Observer able to hook into vertex sender pre/post processing
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver
 
VertexSuppliers - Class in org.apache.giraph.block_app.library
SupplierFromVertex that extract common information from vertex itself.
VertexValue() - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.VertexValue
Constructor
VertexValue(Double) - Constructor for class org.apache.giraph.examples.PageRankWithKryoSimpleWritable.VertexValue
Constructor
VertexValueCombiner<V extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.graph
When vertex values with the same vertex id are loaded, this class specifies how to combine their vertex values.
vertexValueCombiner - Variable in class org.apache.giraph.utils.TestGraph
Vertex value combiner
vertexValueCombinerClass - Variable in class org.apache.giraph.conf.GiraphClasses
Vertex value combiner class - cached for fast access
VertexValueFactory<V extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.factories
Factory class to create default vertex values.
VertexValueInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Vertex input format that only allows setting vertex id and value.
VertexValueInputFormat() - Constructor for class org.apache.giraph.io.VertexValueInputFormat
 
VertexValueReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Vertex reader for VertexValueInputFormat.
VertexValueReader() - Constructor for class org.apache.giraph.io.VertexValueReader
 
vertexValueSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns vertex value.
VertexWithDoubleValueDoubleEdgeTextOutputFormat - Class in org.apache.giraph.examples
Simple vertex output format for weighted graphs.
VertexWithDoubleValueDoubleEdgeTextOutputFormat() - Constructor for class org.apache.giraph.examples.VertexWithDoubleValueDoubleEdgeTextOutputFormat
 
VertexWithDoubleValueDoubleEdgeTextOutputFormat.VertexWithDoubleValueWriter - Class in org.apache.giraph.examples
VertexWithDoubleValueNullEdgeTextOutputFormat - Class in org.apache.giraph.examples
Output format for vertices with a long as id, a double as value and null edges
VertexWithDoubleValueNullEdgeTextOutputFormat() - Constructor for class org.apache.giraph.examples.VertexWithDoubleValueNullEdgeTextOutputFormat
 
VertexWithDoubleValueNullEdgeTextOutputFormat.VertexWithDoubleValueWriter - Class in org.apache.giraph.examples
VertexWithDoubleValueWriter() - Constructor for class org.apache.giraph.examples.VertexWithDoubleValueDoubleEdgeTextOutputFormat.VertexWithDoubleValueWriter
 
VertexWithDoubleValueWriter() - Constructor for class org.apache.giraph.examples.VertexWithDoubleValueNullEdgeTextOutputFormat.VertexWithDoubleValueWriter
 
VertexWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io
Implement to output a vertex range of the graph after the computation
VertexWriter() - Constructor for class org.apache.giraph.io.VertexWriter
 
VERTICES - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for number of vertices
vertices - Variable in class org.apache.giraph.utils.TestGraph
The vertex values
VERTICES_BALANCE_ALGORITHM - Static variable in class org.apache.giraph.partition.PartitionBalancer
Rebalance across supersteps by vertices
VERTICES_FILTERED - Static variable in interface org.apache.giraph.metrics.MetricNames
Total vertices filtered
VERTICES_FILTERED_PCT - Static variable in interface org.apache.giraph.metrics.MetricNames
Percent of vertices filtered out
VERTICES_FILTERED_UPDATE_PERIOD - Static variable in class org.apache.giraph.worker.VertexInputSplitsCallable
How often to update filtered out metrics
VERTICES_IN_MUTATION_REQUEST - Static variable in interface org.apache.giraph.metrics.MetricNames
Histogram for vertices in mutations requests
VERTICES_NAME - Static variable in class org.apache.giraph.counters.GiraphStats
aggregate vertices counter name
VERTICES_TO_UPDATE_PROGRESS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Minimum number of vertices to compute before adding to worker progress.
VERTICES_UPDATE_PERIOD - Static variable in class org.apache.giraph.worker.VertexInputSplitsCallable
How often to update metrics and print info
verticesComputed - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many vertices were computed in current superstep until now
verticesLoaded - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many vertices were loaded until now
verticesStored - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many vertices were stored until now
verticesToCompute - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many vertices are there to compute in current superstep
verticesToStore - Variable in class org.apache.giraph.worker.WorkerProgressStats
How many vertices are there to store
voteToHalt() - Method in class org.apache.giraph.graph.DefaultVertex
 
voteToHalt() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
voteToHalt() - Method in interface org.apache.giraph.graph.Vertex
After this is called, the compute() code will no longer be called for this vertex unless a message is sent to it.

W

WAIT_FOR_OTHER_WORKERS_TIMEOUT_MSEC - Static variable in interface org.apache.giraph.conf.GiraphConstants
Timeout for "waitForever", when we need to wait for other workers to complete their job.
WAIT_TASK_DONE_TIMEOUT_MS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Maximum timeout (in milliseconds) for waiting for all tasks to complete after the job is done.
WAIT_TIME_BETWEEN_CONNECTION_RETRIES_MS - Static variable in interface org.apache.giraph.conf.GiraphConstants
How long to wait before trying to reconnect failed connections
WAIT_ZOOKEEPER_TIMEOUT_MSEC - Static variable in interface org.apache.giraph.conf.GiraphConstants
Timeout for "waitForever", when we need to wait for zookeeper.
waitAllRequests() - Method in class org.apache.giraph.comm.flow_control.CreditBasedFlowControl
 
waitAllRequests() - Method in interface org.apache.giraph.comm.flow_control.FlowControl
There may be requests in possession of the flow control mechanism, as the mechanism controls whether a task should send a request or not.
waitAllRequests() - Method in class org.apache.giraph.comm.flow_control.NoOpFlowControl
 
waitAllRequests() - Method in class org.apache.giraph.comm.flow_control.StaticFlowControl
 
waitAllRequests() - Method in class org.apache.giraph.comm.netty.NettyClient
Ensure all the request sent so far are complete.
waitAllRequests() - Method in class org.apache.giraph.comm.netty.NettyWorkerClient
 
waitAllRequests() - Method in interface org.apache.giraph.comm.WorkerClient
Wait until all the outstanding requests are completed.
waitAndGetCounterNameFromGroup(Job, String) - Static method in class org.apache.giraph.utils.CounterUtils
Wait for a counter to appear in a group and then return the name of that counter.
waitForComplete() - Method in class org.apache.giraph.comm.ServerData
In case of async message store we have to wait for all messages to be processed before going into next superstep.
waitForMessage(Long, Long) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
Add a new message that must be expected by the node
waitForRequiredPermits(Set<Integer>) - Method in class org.apache.giraph.utils.TaskIdsPermitsBarrier
Wait until permits have been required desired number of times, and all required permits are available
waitForTimeoutOrFail(long) - Method in interface org.apache.giraph.zk.BspEvent
Waits until timeout or fails with runtime exception.
waitForTimeoutOrFail(long) - Method in class org.apache.giraph.zk.PredicateLock
 
WAITING_REQUEST_MSECS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Msecs to wait between waiting for all requests to finish
WaitIOCommand - Class in org.apache.giraph.ooc.command
IOCommand to do nothing regarding moving data to/from disk.
WaitIOCommand(OutOfCoreEngine, long) - Constructor for class org.apache.giraph.ooc.command.WaitIOCommand
Constructor
waitMsecs(int) - Method in interface org.apache.giraph.zk.BspEvent
Wait until the event occurred or waiting timed out.
waitMsecs(int) - Method in class org.apache.giraph.zk.PredicateLock
 
waitToComplete() - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
Wait till all messages are processed and all queues are empty.
wakeUp() - Method in class org.apache.giraph.graph.DefaultVertex
 
wakeUp() - Method in class org.apache.giraph.graph.OnlyIdVertex
 
wakeUp() - Method in interface org.apache.giraph.graph.Vertex
Re-activate vertex if halted.
WArrayList<T> - Interface in org.apache.giraph.types.ops.collections.array
Array list over mutable elements, which are probably internally stored differently/efficiently, and are accessed through methods providing "return" value.
WattsStrogatzVertexInputFormat - Class in org.apache.giraph.io.formats
Generates a random Watts-Strogatz graph by re-wiring a ring lattice.
WattsStrogatzVertexInputFormat() - Constructor for class org.apache.giraph.io.formats.WattsStrogatzVertexInputFormat
 
WBooleanArrayList - Class in org.apache.giraph.types.ops.collections.array
Writable extension of BooleanArrayList, as well as BooleanWritable implementation of WArrayList.
WBooleanArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Creates a new array list with BooleanArrayList.DEFAULT_INITIAL_CAPACITY capacity.
WBooleanArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Creates a new array list with given capacity.
WBooleanArrayList(BooleanCollection) - Constructor for class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Creates a new array list and fills it with a given type-specific collection.
WBooleanArrayList(BooleanList) - Constructor for class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Creates a new array list and fills it with a given type-specific list.
WBooleanArrayList.WReusableBooleanArrayList - Class in org.apache.giraph.types.ops.collections.array
Variant of WBooleanArrayList that doesn't reallocate smaller backing array on consecutive readFields/readElements calls, and so is suitable for reusable use.
WBooleanCollection - Interface in org.apache.giraph.types.ops.collections
Long specialization of WCollection
WByteArrayList - Class in org.apache.giraph.types.ops.collections.array
Writable extension of ByteArrayList, as well as ByteWritable implementation of WArrayList.
WByteArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WByteArrayList
Creates a new array list with ByteArrayList.DEFAULT_INITIAL_CAPACITY capacity.
WByteArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WByteArrayList
Creates a new array list with given capacity.
WByteArrayList(ByteCollection) - Constructor for class org.apache.giraph.types.ops.collections.array.WByteArrayList
Creates a new array list and fills it with a given type-specific collection.
WByteArrayList(ByteList) - Constructor for class org.apache.giraph.types.ops.collections.array.WByteArrayList
Creates a new array list and fills it with a given type-specific list.
WByteArrayList.WReusableByteArrayList - Class in org.apache.giraph.types.ops.collections.array
Variant of WByteArrayList that doesn't reallocate smaller backing array on consecutive readFields/readElements calls, and so is suitable for reusable use.
WByteCollection - Interface in org.apache.giraph.types.ops.collections
Long specialization of WCollection
WCollection<T> - Interface in org.apache.giraph.types.ops.collections
Collection over mutable elements, which are probably internally stored differently/efficiently, and are accessed through methods providing "return" value.
WDoubleArrayList - Class in org.apache.giraph.types.ops.collections.array
Writable extension of DoubleArrayList, as well as DoubleWritable implementation of WArrayList.
WDoubleArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Creates a new array list with DoubleArrayList.DEFAULT_INITIAL_CAPACITY capacity.
WDoubleArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Creates a new array list with given capacity.
WDoubleArrayList(DoubleCollection) - Constructor for class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Creates a new array list and fills it with a given type-specific collection.
WDoubleArrayList(DoubleList) - Constructor for class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Creates a new array list and fills it with a given type-specific list.
WDoubleArrayList.WReusableDoubleArrayList - Class in org.apache.giraph.types.ops.collections.array
Variant of WDoubleArrayList that doesn't reallocate smaller backing array on consecutive readFields/readElements calls, and so is suitable for reusable use.
WDoubleCollection - Interface in org.apache.giraph.types.ops.collections
Long specialization of WCollection
WeightedPageRankBenchmark - Class in org.apache.giraph.benchmark
WeightedPageRankBenchmark() - Constructor for class org.apache.giraph.benchmark.WeightedPageRankBenchmark
 
WeightedPageRankComputation - Class in org.apache.giraph.benchmark
Implementation of Page Rank algorithm on a weighted graph.
WeightedPageRankComputation() - Constructor for class org.apache.giraph.benchmark.WeightedPageRankComputation
 
WFloatArrayList - Class in org.apache.giraph.types.ops.collections.array
Writable extension of FloatArrayList, as well as FloatWritable implementation of WArrayList.
WFloatArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Creates a new array list with FloatArrayList.DEFAULT_INITIAL_CAPACITY capacity.
WFloatArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Creates a new array list with given capacity.
WFloatArrayList(FloatCollection) - Constructor for class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Creates a new array list and fills it with a given type-specific collection.
WFloatArrayList(FloatList) - Constructor for class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Creates a new array list and fills it with a given type-specific list.
WFloatArrayList.WReusableFloatArrayList - Class in org.apache.giraph.types.ops.collections.array
Variant of WFloatArrayList that doesn't reallocate smaller backing array on consecutive readFields/readElements calls, and so is suitable for reusable use.
WFloatCollection - Interface in org.apache.giraph.types.ops.collections
Long specialization of WCollection
WIntArrayList - Class in org.apache.giraph.types.ops.collections.array
Writable extension of IntArrayList, as well as IntWritable implementation of WArrayList.
WIntArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WIntArrayList
Creates a new array list with IntArrayList.DEFAULT_INITIAL_CAPACITY capacity.
WIntArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WIntArrayList
Creates a new array list with given capacity.
WIntArrayList(IntCollection) - Constructor for class org.apache.giraph.types.ops.collections.array.WIntArrayList
Creates a new array list and fills it with a given type-specific collection.
WIntArrayList(IntList) - Constructor for class org.apache.giraph.types.ops.collections.array.WIntArrayList
Creates a new array list and fills it with a given type-specific list.
WIntArrayList.WReusableIntArrayList - Class in org.apache.giraph.types.ops.collections.array
Variant of WIntArrayList that doesn't reallocate smaller backing array on consecutive readFields/readElements calls, and so is suitable for reusable use.
WIntCollection - Interface in org.apache.giraph.types.ops.collections
Long specialization of WCollection
WLongArrayList - Class in org.apache.giraph.types.ops.collections.array
Writable extension of LongArrayList, as well as LongWritable implementation of WArrayList.
WLongArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WLongArrayList
Creates a new array list with LongArrayList.DEFAULT_INITIAL_CAPACITY capacity.
WLongArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WLongArrayList
Creates a new array list with given capacity.
WLongArrayList(LongCollection) - Constructor for class org.apache.giraph.types.ops.collections.array.WLongArrayList
Creates a new array list and fills it with a given type-specific collection.
WLongArrayList(LongList) - Constructor for class org.apache.giraph.types.ops.collections.array.WLongArrayList
Creates a new array list and fills it with a given type-specific list.
WLongArrayList.WReusableLongArrayList - Class in org.apache.giraph.types.ops.collections.array
Variant of WLongArrayList that doesn't reallocate smaller backing array on consecutive readFields/readElements calls, and so is suitable for reusable use.
WLongCollection - Interface in org.apache.giraph.types.ops.collections
Long specialization of WCollection
WORKER_CONTEXT_CLASS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Worker context class
WORKER_FINISHED_DIR - Static variable in class org.apache.giraph.bsp.BspService
Finished workers notify here
WORKER_HEALTHY_DIR - Static variable in class org.apache.giraph.bsp.BspService
Healthy workers register here.
WORKER_OBSERVER_CLASSES - Static variable in interface org.apache.giraph.conf.GiraphConstants
Classes for Worker Observer - optional
WORKER_SUFFIX - Static variable in class org.apache.giraph.bsp.BspService
Suffix denotes a worker
WORKER_UNHEALTHY_DIR - Static variable in class org.apache.giraph.bsp.BspService
Unhealthy workers register here.
WORKER_WROTE_CHECKPOINT_DIR - Static variable in class org.apache.giraph.bsp.BspService
Workers which wrote checkpoint notify here
WorkerAggregatorDelegator<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.worker
Class for delegating WorkerAggregatorUsage and WorkerGlobalCommUsage methods to corresponding interface.
WorkerAggregatorDelegator() - Constructor for class org.apache.giraph.worker.WorkerAggregatorDelegator
 
WorkerAggregatorHandler - Class in org.apache.giraph.worker
Handler for reduce/broadcast on the workers
WorkerAggregatorHandler(CentralizedServiceWorker<?, ?, ?>, ImmutableClassesGiraphConfiguration, Progressable) - Constructor for class org.apache.giraph.worker.WorkerAggregatorHandler
Constructor
WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage - Class in org.apache.giraph.worker
Not thread-safe implementation of WorkerThreadGlobalCommUsage.
WorkerAggregatorRequestProcessor - Interface in org.apache.giraph.comm.aggregators
Aggregates worker aggregator requests and sends them off
WorkerAggregatorUsage - Interface in org.apache.giraph.worker
Vertex classes can access and change aggregators through this interface
WorkerBroadcastUsage - Interface in org.apache.giraph.worker
Methods on worker can access broadcasted values through this interface
WorkerClient<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.comm
Public interface for workers to establish connections and send aggregated requests.
WorkerClientRequestProcessor<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.comm
Aggregates IPC requests and sends them off
workerClientRequestProcessor - Variable in class org.apache.giraph.worker.InputSplitsCallable
Handles IPC communication
WorkerContext - Class in org.apache.giraph.worker
WorkerContext allows for the execution of user code on a per-worker basis.
WorkerContext() - Constructor for class org.apache.giraph.worker.WorkerContext
 
workerContextClass - Variable in class org.apache.giraph.conf.GiraphClasses
Worker context class - cached for fast access
workerContextReceive(BlockWorkerContextReceiveApi, Object, List<Writable>) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
workerContextReceive(BlockWorkerContextReceiveApi, S, WV, List<WM>) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to have worker context receive computation.
workerContextReceive(BlockWorkerContextReceiveApi, S, WV, List<WM>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
workerContextReceive(BlockWorkerContextReceiveApi, S, Object, List<NoMessage>) - Method in class org.apache.giraph.block_app.framework.piece.Piece
 
workerContextReceive(BlockWorkerContextReceiveApi, MigrationSuperstepStage, MigrationWorkerContext, List<Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
workerContextSend(BlockWorkerContextSendApi, Object) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
workerContextSend(BlockWorkerContextSendApi<I, WM>, S, WV) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to have worker context send computation.
workerContextSend(BlockWorkerContextSendApi<I, WM>, S, WV) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
workerContextSend(BlockWorkerContextSendApi<I, NoMessage>, S, Object) - Method in class org.apache.giraph.block_app.framework.piece.Piece
 
workerContextSend(BlockWorkerContextSendApi<WritableComparable, NoMessage>, Object, Object) - Method in class org.apache.giraph.block_app.library.gc.WorkerGCPiece
 
workerContextSend(BlockWorkerContextSendApi<I, Writable>, MigrationSuperstepStage, MigrationWorkerContext) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
workerFailureCleanup() - Method in class org.apache.giraph.graph.GraphTaskManager
Cleanup all of Giraph's framework-agnostic resources regardless of which type of cluster Giraph is running on.
WorkerGCPiece - Class in org.apache.giraph.block_app.library.gc
Dummy piece to hint System.gc()
WorkerGCPiece() - Constructor for class org.apache.giraph.block_app.library.gc.WorkerGCPiece
 
WorkerGlobalCommUsage - Interface in org.apache.giraph.worker
Methods on worker can access broadcasted values and provide values to reduce through this interface
WorkerGraphPartitioner<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.partition
Stores the PartitionOwner objects from the master and provides the mapping of vertex to PartitionOwner.
WorkerGraphPartitionerImpl<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.partition
Abstracts and implements all WorkerGraphPartitioner logic on top of a single user function - getPartitionIndex.
WorkerGraphPartitionerImpl() - Constructor for class org.apache.giraph.partition.WorkerGraphPartitionerImpl
 
WorkerIndexUsage<I> - Interface in org.apache.giraph.worker
Interface providing utilities for using worker index.
WorkerInfo - Class in org.apache.giraph.worker
Information about a worker that is sent to the master and other workers.
WorkerInfo() - Constructor for class org.apache.giraph.worker.WorkerInfo
Constructor for reflection
WorkerInputSplitsHandler - Class in org.apache.giraph.worker
Requests splits from master and keeps track of them
WorkerInputSplitsHandler(WorkerInfo, int, WorkerClient) - Constructor for class org.apache.giraph.worker.WorkerInputSplitsHandler
Constructor
WorkerObserver - Interface in org.apache.giraph.worker
Observer for worker.
WorkerProgress - Class in org.apache.giraph.worker
Stores information about a worker's progress that is periodically written to ZooKeeper with WorkerProgressWriter.
WorkerProgress() - Constructor for class org.apache.giraph.worker.WorkerProgress
Public constructor for thrift to create us.
WorkerProgressStats - Class in org.apache.giraph.worker
Stats about a worker's progress
WorkerProgressStats() - Constructor for class org.apache.giraph.worker.WorkerProgressStats
 
WorkerProgressWriter - Class in org.apache.giraph.worker
Class which periodically writes worker's progress to zookeeper
WorkerProgressWriter(JobProgressTracker) - Constructor for class org.apache.giraph.worker.WorkerProgressWriter
Constructor, starts separate thread to periodically update worker's progress
WorkerReduceUsage - Interface in org.apache.giraph.worker
Methods on worker can provide values to reduce through this interface
WorkerRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.comm.requests
Interface for requests sent to worker to extend
WorkerRequestReservedMap - Class in org.apache.giraph.comm.netty.handler
Provides a thread-safe map for checking worker and request id pairs
WorkerRequestReservedMap(Configuration) - Constructor for class org.apache.giraph.comm.netty.handler.WorkerRequestReservedMap
Constructor
WorkerRequestServerHandler<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.comm.netty.handler
Handler for requests on worker
WorkerRequestServerHandler(ServerData<I, V, E>, WorkerRequestReservedMap, ImmutableClassesGiraphConfiguration, TaskInfo, Thread.UncaughtExceptionHandler, FlowControl) - Constructor for class org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler
Constructor with external server data
WorkerRequestServerHandler.Factory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.netty.handler
WORKERS - Static variable in class org.apache.giraph.benchmark.BenchmarkOption
Option for number of workers
WORKERS_NUM - Static variable in class org.apache.giraph.benchmark.RandomMessageBenchmark
Workers for that superstep
WorkerServer<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.comm
Interface for message communication server.
WorkerSuperstepMetrics - Class in org.apache.giraph.metrics
Per-superstep metrics for a Worker.
WorkerSuperstepMetrics() - Constructor for class org.apache.giraph.metrics.WorkerSuperstepMetrics
Constructor
WorkerThreadGlobalCommUsage - Interface in org.apache.giraph.worker
WorkerAggregatorUsage which can be used in each of the computation threads.
wrap(OutEdges<I, E>, ImmutableClassesGiraphConfiguration<I, ?, E>) - Static method in class org.apache.giraph.edge.MutableEdgesWrapper
Factory method to create a new wrapper over the existing out-edges.
wrap(Boolean, BooleanWritable) - Method in class org.apache.giraph.types.BooleanToBooleanWritableWrapper
 
wrap(Byte, ByteWritable) - Method in class org.apache.giraph.types.ByteToByteWritableWrapper
 
wrap(Byte, IntWritable) - Method in class org.apache.giraph.types.ByteToIntWritableWrapper
 
wrap(Byte, LongWritable) - Method in class org.apache.giraph.types.ByteToLongWritableWrapper
 
wrap(Double, DoubleWritable) - Method in class org.apache.giraph.types.DoubleToDoubleWritableWrapper
 
wrap(Float, DoubleWritable) - Method in class org.apache.giraph.types.FloatToDoubleWritableWrapper
 
wrap(Float, FloatWritable) - Method in class org.apache.giraph.types.FloatToFloatWritableWrapper
 
wrap(Integer, IntWritable) - Method in class org.apache.giraph.types.IntToIntWritableWrapper
 
wrap(Integer, LongWritable) - Method in class org.apache.giraph.types.IntToLongWritableWrapper
 
wrap(Long, LongWritable) - Method in class org.apache.giraph.types.LongToLongWritableWrapper
 
wrap(Short, IntWritable) - Method in class org.apache.giraph.types.ShortToIntWritableWrapper
 
wrap(Short, LongWritable) - Method in class org.apache.giraph.types.ShortToLongWritableWrapper
 
wrap(J, W) - Method in interface org.apache.giraph.types.WritableWrapper
Convert from java type to writable type
wrapAndCopy(T) - Static method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Wrap object with KryoWritableWrapper, create a writable copy of it, and then unwrap it, allowing any object to be copied.
wrapIdIfNecessary(Object) - Method in class org.apache.giraph.jython.JythonGiraphComputation
Wrap a vertex id in a WritableComparable wrapper if necessary
wrapIfNecessary(Object, GraphType) - Method in class org.apache.giraph.jython.JythonGiraphComputation
Wrap a user value (IVEMM) in a Writable wrapper if necessary
wrapIfNeeded(Object) - Static method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
Returns Writable instance, wrapping given object only if it is not already writable.
WrappedEdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedEdgeInputFormat(EdgeInputFormat<I, E>) - Constructor for class org.apache.giraph.io.internal.WrappedEdgeInputFormat
Constructor
WrappedEdgeOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedEdgeOutputFormat(EdgeOutputFormat<I, V, E>) - Constructor for class org.apache.giraph.io.internal.WrappedEdgeOutputFormat
Constructor
WrappedEdgeReader<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedEdgeReader(EdgeReader<I, E>, ImmutableClassesGiraphConfiguration<I, Writable, E>) - Constructor for class org.apache.giraph.io.internal.WrappedEdgeReader
Constructor
WrappedMappingInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedMappingInputFormat(MappingInputFormat<I, V, E, B>) - Constructor for class org.apache.giraph.io.internal.WrappedMappingInputFormat
Constructor
WrappedMappingReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedMappingReader(MappingReader<I, V, E, B>, ImmutableClassesGiraphConfiguration<I, V, E>) - Constructor for class org.apache.giraph.io.internal.WrappedMappingReader
Constructor
WrappedReducedValue() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
WrappedReducedValue(ReduceOperation<?, R>, R) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
wrappedRegisterReducers(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Add automatic handling of reducers to registerReducers.
wrappedRegisterReducers(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
wrappedRegisterReducers(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
WrappedVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedVertexInputFormat(VertexInputFormat<I, V, E>) - Constructor for class org.apache.giraph.io.internal.WrappedVertexInputFormat
Constructor
WrappedVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedVertexOutputFormat(VertexOutputFormat<I, V, E>) - Constructor for class org.apache.giraph.io.internal.WrappedVertexOutputFormat
Constructor
WrappedVertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.io.internal
For internal use only.
WrappedVertexReader(VertexReader<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>) - Constructor for class org.apache.giraph.io.internal.WrappedVertexReader
Constructor
WReusableBooleanArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WBooleanArrayList.WReusableBooleanArrayList
Constructor
WReusableBooleanArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WBooleanArrayList.WReusableBooleanArrayList
Constructor
WReusableByteArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WByteArrayList.WReusableByteArrayList
Constructor
WReusableByteArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WByteArrayList.WReusableByteArrayList
Constructor
WReusableDoubleArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WDoubleArrayList.WReusableDoubleArrayList
Constructor
WReusableDoubleArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WDoubleArrayList.WReusableDoubleArrayList
Constructor
WReusableFloatArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WFloatArrayList.WReusableFloatArrayList
Constructor
WReusableFloatArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WFloatArrayList.WReusableFloatArrayList
Constructor
WReusableIntArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WIntArrayList.WReusableIntArrayList
Constructor
WReusableIntArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WIntArrayList.WReusableIntArrayList
Constructor
WReusableLongArrayList() - Constructor for class org.apache.giraph.types.ops.collections.array.WLongArrayList.WReusableLongArrayList
Constructor
WReusableLongArrayList(int) - Constructor for class org.apache.giraph.types.ops.collections.array.WLongArrayList.WReusableLongArrayList
Constructor
writableConfOption() - Method in enum org.apache.giraph.graph.GraphType
Get the class option for this graph type
WritableRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.comm.requests
Interface for requests to implement
WritableRequest() - Constructor for class org.apache.giraph.comm.requests.WritableRequest
 
WritableUnwrapper<W extends org.apache.hadoop.io.Writable,J> - Interface in org.apache.giraph.types
Converts from Writable type to Java type
WritableUnwrappers - Class in org.apache.giraph.types
Mapping of all the known Writable wrappers.
WritableUtils - Class in org.apache.giraph.utils
Helper static methods for working with Writable objects.
writableValueClass() - Method in class org.apache.giraph.jython.factories.JythonFactoryBase
The interface class for the value type.
WritableWrapper<W extends org.apache.hadoop.io.Writable,J> - Interface in org.apache.giraph.types
Converts from Java type to Writable type
WritableWrappers - Class in org.apache.giraph.types
Mapping of all the known Writable wrappers.
WritableWriter<T> - Interface in org.apache.giraph.types.ops.collections
Handler for knowing how to serialize/deserialize type T
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.dense.FloatDenseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.dense.IntDenseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.dense.LongDenseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.sparse.IntSparseVector
 
write(DataOutput) - Method in class org.apache.giraph.aggregators.matrix.sparse.LongSparseVector
 
write(DataOutput) - Method in class org.apache.giraph.benchmark.ReducersBenchmark.TestLongSumReducer
 
write(DataOutput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
write(DataOutput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
write(DataOutput) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
write(DataOutput) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
write(DataOutput) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
write(DataOutput) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
write(DataOutput) - Method in class org.apache.giraph.bsp.BspInputSplit
 
write(Text, Text) - Method in class org.apache.giraph.bsp.BspRecordWriter
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.giraph.comm.netty.handler.RequestEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.giraph.comm.netty.handler.ResponseEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class org.apache.giraph.comm.netty.OutboundByteCounter
 
write(DataOutput) - Method in class org.apache.giraph.comm.requests.WritableRequest
 
write(DataOutput) - Method in class org.apache.giraph.conf.DefaultMessageClasses
 
write(DataOutput) - Method in class org.apache.giraph.counters.CustomCounter
 
write(DataOutput) - Method in class org.apache.giraph.counters.GiraphHadoopCounter
Write to Hadoop output.
write(DataOutput) - Method in class org.apache.giraph.edge.ArrayListEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.ByteArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.HashMapEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.HashMultimapEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.IdAndNullArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.IdAndValueArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.IntNullArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongByteHashMapEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongDiffArray
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongDiffNullArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongDoubleArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongDoubleHashMapEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongNullArrayEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.LongNullHashSetEdges
 
write(DataOutput) - Method in class org.apache.giraph.edge.MutableEdgesWrapper
 
write(DataOutput) - Method in class org.apache.giraph.examples.scc.SccVertexValue
 
write(DataOutput) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage
 
write(DataOutput) - Method in class org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue
 
write(DataOutput) - Method in class org.apache.giraph.examples.VerifyMessage.VerifiableMessage
 
write(DataOutput) - Method in class org.apache.giraph.graph.AddressesAndPartitionsWritable
 
write(DataOutput) - Method in class org.apache.giraph.graph.GlobalStats
 
write(DataOutput) - Method in class org.apache.giraph.graph.TaskInfo
 
write(DataOutput) - Method in class org.apache.giraph.graph.VertexMutations
 
write(DataOutput) - Method in class org.apache.giraph.jython.wrappers.JythonWritableWrapper
 
write(DataOutput) - Method in class org.apache.giraph.master.AggregatorBroadcast
 
write(DataOutput) - Method in class org.apache.giraph.master.AggregatorReduceOperation
 
write(DataOutput) - Method in class org.apache.giraph.master.AggregatorToGlobalCommTranslation
 
write(DataOutput) - Method in class org.apache.giraph.master.DefaultMasterCompute
 
write(DataOutput) - Method in class org.apache.giraph.master.MasterAggregatorHandler
 
write(DataOutput) - Method in class org.apache.giraph.master.SuperstepClasses
 
write(DataOutput) - Method in class org.apache.giraph.metrics.WorkerSuperstepMetrics
 
write(DataOutput) - Method in class org.apache.giraph.partition.BasicPartition
 
write(DataOutput) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
write(DataOutput) - Method in class org.apache.giraph.partition.ByteArrayPartition
 
write(DataOutput) - Method in class org.apache.giraph.partition.PartitionStats
 
write(DataOutput) - Method in class org.apache.giraph.partition.SimplePartition
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.AndReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.KryoWrappedReduceOperation
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.LongXorReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.MaxPairReducer
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.MaxReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.MinReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.OrReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.PairReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.impl.SumReduce
 
write(DataOutput) - Method in class org.apache.giraph.reducers.Reducer
Serialize the fields of this object to out.
write(FixedCapacityIntByteMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap
Serializes an object into data output.
write(FixedCapacityIntDoubleMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap
Serializes an object into data output.
write(FixedCapacityIntFloatMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap
Serializes an object into data output.
write(FixedCapacityIntIntMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap
Serializes an object into data output.
write(FixedCapacityIntLongMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap
Serializes an object into data output.
write(FixedCapacityLongByteMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap
Serializes an object into data output.
write(FixedCapacityLongDoubleMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap
Serializes an object into data output.
write(FixedCapacityLongFloatMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap
Serializes an object into data output.
write(FixedCapacityLongIntMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap
Serializes an object into data output.
write(FixedCapacityLongLongMinHeap, DataOutput) - Static method in class org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap
Serializes an object into data output.
write(DataOutput) - Method in class org.apache.giraph.types.NoMessage
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicInt2ObjectOpenHashMap
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicLong2ObjectOpenHashMap
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.Basic2ObjectMap.BasicObject2ObjectOpenHashMap
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet
 
write(DataOutput) - Method in class org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet
 
write(DataOutput, T) - Method in interface org.apache.giraph.types.ops.collections.WritableWriter
Serialize the fields of value to out.
write(DataOutput) - Method in class org.apache.giraph.utils.AbstractVertexIdData
 
write(DataOutput) - Method in class org.apache.giraph.utils.ArrayListWritable
 
write(DataOutput) - Method in class org.apache.giraph.utils.ArrayWritable
 
write(DataOutput) - Method in class org.apache.giraph.utils.ByteArrayVertexIdData
 
write(DataOutput) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
write(int) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
write(byte[]) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
write(byte[], int, int) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
write(DataOutput) - Method in class org.apache.giraph.utils.io.BigDataInputOutput
 
write(int) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
write(byte[]) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
write(byte[], int, int) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
write(DataOutput) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
write(DataOutput) - Method in class org.apache.giraph.utils.io.ExtendedDataInputOutput
 
write(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
write(byte[]) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
write(byte[], int, int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
write(DataOutput) - Method in class org.apache.giraph.worker.WorkerContext
 
write(int) - Method in class org.apache.giraph.writable.kryo.DataOutputWrapperStream
 
write(byte[], int, int) - Method in class org.apache.giraph.writable.kryo.DataOutputWrapperStream
 
write(DataOutput) - Method in class org.apache.giraph.writable.kryo.KryoSimpleWrapper
 
write(DataOutput) - Method in class org.apache.giraph.writable.kryo.KryoSimpleWritable
 
write(DataOutput) - Method in class org.apache.giraph.writable.kryo.KryoWritable
 
write(DataOutput) - Method in class org.apache.giraph.writable.kryo.KryoWritableWrapper
 
write(Kryo, Output, List) - Method in class org.apache.giraph.writable.kryo.serializers.ArraysAsListSerializer
 
write(Kryo, Output, List<T>) - Method in class org.apache.giraph.writable.kryo.serializers.CollectionsNCopiesSerializer
 
write(Kryo, Output, T) - Method in class org.apache.giraph.writable.kryo.serializers.DirectWritableSerializer
 
write(Kryo, Output, T) - Method in class org.apache.giraph.writable.kryo.serializers.FastUtilSerializer
 
write(DataOutput) - Method in class org.apache.giraph.writable.tuple.PairWritable
 
writeAggregator(Iterable<Map.Entry<String, Writable>>, long) - Method in interface org.apache.giraph.aggregators.AggregatorWriter
The method is called at the end of each superstep.
writeAggregator(Iterable<Map.Entry<String, Writable>>, long) - Method in class org.apache.giraph.aggregators.TextAggregatorWriter
 
writeAggregator(Iterable<Map.Entry<String, Writable>>, long) - Method in class org.apache.giraph.examples.SimpleAggregatorWriter
 
writeAggregators(long, SuperstepState) - Method in class org.apache.giraph.master.MasterAggregatorHandler
Write aggregators to AggregatorWriter
writeBoolean(boolean) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeBoolean(boolean) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeBoolean(boolean) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeBoolean(boolean) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeByte(int) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeByte(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeByte(int) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeByte(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeBytes(String) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeBytes(String) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeBytes(String) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeBytes(String) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeChar(int) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeChar(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeChar(int) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeChar(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeChar(char) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeChars(String) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeChars(String) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeChars(String) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeChars(String) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeClass(Class<T>, DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
Write class to data output.
writeClass(Output, Class) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
 
writeClassAndObj(DataOutput, Object) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Write type of given object and the object itself to the output stream.
writeCurrentMessageBytes(DataOutput) - Method in interface org.apache.giraph.utils.VertexIdMessageBytesIterator
Write the current message to an ExtendedDataOutput object
writeData(ExtendedDataOutput, M) - Method in class org.apache.giraph.utils.ByteArrayOneMessageToManyIds
 
writeData(ExtendedDataOutput, Edge<I, E>) - Method in class org.apache.giraph.utils.ByteArrayVertexIdEdges
 
writeData(ExtendedDataOutput, M) - Method in class org.apache.giraph.utils.ByteArrayVertexIdMessages
 
writeData(ExtendedDataOutput, T) - Method in interface org.apache.giraph.utils.VertexIdData
Write a data object to an ExtendedDataOutput.
writeDouble(double) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeDouble(double) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeDouble(double) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeDouble(double) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeEdge(I, V, Edge<I, E>) - Method in class org.apache.giraph.io.EdgeWriter
Writes the next vertex and associated data
writeEdge(I, V, Edge<I, E>) - Method in class org.apache.giraph.io.formats.TextEdgeOutputFormat.TextEdgeWriterToEachLine
 
writeEdge(DataOutput, Edge<I, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Write an edge to an output stream.
writeElements(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
 
writeElements(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
 
writeElements(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
 
writeElements(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
 
writeElements(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
 
writeElements(DataOutput) - Method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
 
writeElements(DataOutput) - Method in interface org.apache.giraph.types.ops.collections.WCollection
Write elements to the DataOutput stream, without the size itself.
writeEntry(T, DataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedDataStore
Writes a single raw entry to a given output stream.
writeEntry(VertexIdEdges<I, E>, DataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
writeEntry(VertexIdMessages<I, M>, DataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
writeEntry(ExtendedDataOutput, DataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedPartitionStore
 
writeEnum(T, DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
Writes enum into a stream, by serializing class name and it's index
writeExtendedDataOutput(ExtendedDataOutput, DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
Write ExtendedDataOutput to DataOutput
writeFloat(float) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeFloat(float) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeFloat(float) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeFloat(float) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeHaltInstructions(String, String) - Method in class org.apache.giraph.job.HaltApplicationUtils.DefaultHaltInstructionsWriter
 
writeHaltInstructions(String, String) - Method in interface org.apache.giraph.job.HaltApplicationUtils.HaltInstructionsWriter
Write instructions about how to halt
writeIfNotNullAndObject(T, DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
First write a boolean saying whether an object is not null, and if it's not write the object
writeIfUnset(Configuration) - Method in class org.apache.giraph.conf.GiraphTypes
Write types to Configuration if not already set
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.formats.multi.MultiEdgeInputFormat
 
writeInputSplit(InputSplit, DataOutput, List<? extends GiraphInputFormat>) - Static method in class org.apache.giraph.io.formats.multi.MultiInputUtils
Write input split info to DataOutput.
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.formats.multi.MultiMappingInputFormat
 
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.formats.multi.MultiVertexInputFormat
 
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.GiraphInputFormat
Write input split info to DataOutput.
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.internal.WrappedEdgeInputFormat
 
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.internal.WrappedMappingInputFormat
 
writeInputSplit(InputSplit, DataOutput) - Method in class org.apache.giraph.io.internal.WrappedVertexInputFormat
 
writeInt(int) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeInt(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeInt(int, int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeInt(int, int) - Method in interface org.apache.giraph.utils.ExtendedDataOutput
In order to write a size as a first part of an data output, it is useful to be able to write an int at an arbitrary location in the stream
writeInt(int) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeInt(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeInt(int, int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeIntArray(int[], DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
Writes primitive int array of ints into output stream.
writeLines(File, String[]) - Static method in class org.apache.giraph.utils.FileUtils
Write lines to a file.
writeList(List<? extends Writable>, DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
Writes a list of Writable objects into output stream.
writeListToByteArray(List<? extends Writable>) - Static method in class org.apache.giraph.utils.WritableUtils
Write list of object to a byte array.
writeListToZnode(ZooKeeperExt, String, int, List<? extends Writable>) - Static method in class org.apache.giraph.utils.WritableUtils
Write list of objects to a ZooKeeper znode.
writeLong(long) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeLong(long) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeLong(long) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeLong(long) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeLongArray(DataOutput, long[]) - Static method in class org.apache.giraph.utils.WritableUtils
Writes primitive long array of ints into output stream.
writeMessages(DataInputOutput, DataOutput) - Method in class org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore
 
writeMessages(M, DataOutput) - Method in class org.apache.giraph.comm.messages.OneMessagePerVertexStore
 
writeMessages(LongArrayList, DataOutput) - Method in class org.apache.giraph.comm.messages.PointerListPerVertexStore
 
writeMessages(T, DataOutput) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
Write message storage to DataOutput
writeName(Output, Class, Registration) - Method in class org.apache.giraph.writable.kryo.GiraphClassResolver
This method writes the class name for the first encountered non-explicitly registered class.
writeOrNull(WBooleanArrayList, DataOutput) - Static method in class org.apache.giraph.types.ops.collections.array.WBooleanArrayList
Write a potentially null list to a DataOutput.
writeOrNull(WByteArrayList, DataOutput) - Static method in class org.apache.giraph.types.ops.collections.array.WByteArrayList
Write a potentially null list to a DataOutput.
writeOrNull(WDoubleArrayList, DataOutput) - Static method in class org.apache.giraph.types.ops.collections.array.WDoubleArrayList
Write a potentially null list to a DataOutput.
writeOrNull(WFloatArrayList, DataOutput) - Static method in class org.apache.giraph.types.ops.collections.array.WFloatArrayList
Write a potentially null list to a DataOutput.
writeOrNull(WIntArrayList, DataOutput) - Static method in class org.apache.giraph.types.ops.collections.array.WIntArrayList
Write a potentially null list to a DataOutput.
writeOrNull(WLongArrayList, DataOutput) - Static method in class org.apache.giraph.types.ops.collections.array.WLongArrayList
Write a potentially null list to a DataOutput.
writeOutOfObject(DataOutput, Object) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Write an object to output, in a way that can be read by readIntoObject.
writePartition(DataOutput, int) - Method in interface org.apache.giraph.comm.messages.MessageStore
Serialize messages for one partition.
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.primitives.IntFloatMessageStore
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.primitives.long_id.LongPointerListPerVertexStore
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.comm.messages.SimpleMessageStore
 
writePartition(DataOutput, int) - Method in class org.apache.giraph.ooc.data.DiskBackedMessageStore
 
writePartitionEdgeStore(int, DataOutput) - Method in class org.apache.giraph.edge.AbstractEdgeStore
 
writePartitionEdgeStore(int, DataOutput) - Method in interface org.apache.giraph.edge.EdgeStore
Deserialize the edges of a given partition, and removes the associated data from the store.
writePartitionEdgeStore(int, DataOutput) - Method in class org.apache.giraph.ooc.data.DiskBackedEdgeStore
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SaslCompleteRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SaslTokenMessageRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SendPartitionMutationsRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SendVertexRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SendWorkerDataRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest
 
writeRequest(DataOutput) - Method in class org.apache.giraph.comm.requests.SendWorkerVerticesRequest
 
writeShort(int) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeShort(int) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeShort(int) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeShort(int) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeSignedVarInt(int, DataOutput) - Static method in class org.apache.giraph.utils.Varint
Zig-zag encoding for signed ints
writeSignedVarLong(long, DataOutput) - Static method in class org.apache.giraph.utils.Varint
Zig-zag encoding for signed longs
writeTo(Configuration) - Method in class org.apache.giraph.conf.GiraphTypes
Write types to Configuration
writeToByteArray(Writable...) - Static method in class org.apache.giraph.utils.WritableUtils
Write object to a byte array.
writeToByteArrayWithSize(Writable, boolean) - Static method in class org.apache.giraph.utils.WritableUtils
Write object to a byte array with the first 4 bytes as the size of the entire buffer (including the size).
writeToByteArrayWithSize(Writable, byte[], boolean) - Static method in class org.apache.giraph.utils.WritableUtils
Write object to a byte array with the first 4 bytes as the size of the entire buffer (including the size).
writeToZnode(ZooKeeperExt, String, int, Writable...) - Static method in class org.apache.giraph.utils.WritableUtils
Write object to a ZooKeeper znode.
writeTypeOps(TypeOps<T>, DataOutput) - Static method in class org.apache.giraph.types.ops.TypeOpsUtils
Write TypeOps object into a stream
writeUnsignedVarInt(int, DataOutput) - Static method in class org.apache.giraph.utils.Varint
 
writeUnsignedVarLong(long, DataOutput) - Static method in class org.apache.giraph.utils.Varint
Encodes a value using the variable-length encoding from Google Protocol Buffers.
writeUTF(String) - Method in class org.apache.giraph.utils.DynamicChannelBufferOutputStream
 
writeUTF(String) - Method in class org.apache.giraph.utils.ExtendedByteArrayDataOutput
 
writeUTF(String) - Method in class org.apache.giraph.utils.io.BigDataOutput
 
writeUTF(String) - Method in class org.apache.giraph.utils.UnsafeByteArrayOutputStream
 
writeVertex(Vertex<LongWritable, DoubleWritable, FloatWritable>) - Method in class org.apache.giraph.examples.SimplePageRankComputation.SimplePageRankVertexOutputFormat.SimplePageRankVertexWriter
 
writeVertex(Vertex<LongWritable, IntWritable, FloatWritable>) - Method in class org.apache.giraph.examples.SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat.SimpleSuperstepVertexWriter
 
writeVertex(Vertex<LongWritable, DoubleWritable, DoubleWritable>) - Method in class org.apache.giraph.examples.VertexWithDoubleValueDoubleEdgeTextOutputFormat.VertexWithDoubleValueWriter
 
writeVertex(Vertex<LongWritable, DoubleWritable, NullWritable>) - Method in class org.apache.giraph.examples.VertexWithDoubleValueNullEdgeTextOutputFormat.VertexWithDoubleValueWriter
 
writeVertex(Vertex) - Method in class org.apache.giraph.io.formats.TextVertexOutputFormat.TextVertexWriterToEachLine
 
writeVertex(Vertex<I, V, E>) - Method in interface org.apache.giraph.io.SimpleVertexWriter
Writes the next vertex and associated data
writeVertexKey(K, DataOutput) - Method in class org.apache.giraph.edge.AbstractEdgeStore
Writes the given key to the output
writeVertexKey(Integer, DataOutput) - Method in class org.apache.giraph.edge.primitives.IntEdgeStore
 
writeVertexKey(Long, DataOutput) - Method in class org.apache.giraph.edge.primitives.LongEdgeStore
 
writeVertexKey(I, DataOutput) - Method in class org.apache.giraph.edge.SimpleEdgeStore
 
writeVertexToByteArray(Vertex<I, V, E>, byte[], boolean, ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Write vertex data to byte array with the first 4 bytes as the size of the entire buffer (including the size).
writeVertexToByteArray(Vertex<I, V, E>, boolean, ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Write vertex data to byte array with the first 4 bytes as the size of the entire buffer (including the size).
writeVertexToDataOutput(DataOutput, Vertex<I, V, E>, ImmutableClassesGiraphConfiguration<I, V, E>) - Static method in class org.apache.giraph.utils.WritableUtils
Writes Vertex data to output stream.
writeWithKryo(HadoopKryo, Output, Object) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Writes class and object to specified output stream with specified Kryo object.
writeWithKryoOutOfObject(HadoopKryo, Output, Object) - Static method in class org.apache.giraph.writable.kryo.HadoopKryo
Write out of object with given kryo
writeWithWorkerIds(DataOutput) - Method in class org.apache.giraph.partition.BasicPartitionOwner
 
writeWithWorkerIds(DataOutput) - Method in interface org.apache.giraph.partition.PartitionOwner
Write to the output, but don't serialize the whole WorkerInfo, instead use just the task id
writeWritableObject(Writable, DataOutput) - Static method in class org.apache.giraph.utils.WritableUtils
Write object to output stream

Y

YarnUtils - Class in org.apache.giraph.yarn
Utilities that can only compile with versions of Hadoop that support YARN, so they live here instead of o.a.g.utils package.
YOURKIT_OUTPUT_DIR - Static variable in interface org.apache.giraph.conf.GiraphConstants
Directory to write YourKit snapshots to
YOURKIT_OUTPUT_DIR_DEFAULT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Default directory to write YourKit snapshots to
YourKitContext - Class in org.apache.giraph.utils
Convenience context for profiling.
YourKitProfiler - Class in org.apache.giraph.utils
Helper for YourKit profiling from within the code.
YourKitProfiler() - Constructor for class org.apache.giraph.utils.YourKitProfiler
Don't construct, allow inheritance

Z

ZOOKEEPER_BASE_PATH_COUNTER_GROUP - Static variable in interface org.apache.giraph.conf.GiraphConstants
This counter group will contain one counter whose name is the ZooKeeper node path which contains all data about this job
ZOOKEEPER_CONNECTION_ATTEMPTS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of ZooKeeper client connection attempts before giving up.
ZOOKEEPER_DIR - Static variable in interface org.apache.giraph.conf.GiraphConstants
Local ZooKeeper directory to use
ZOOKEEPER_FORCE_SYNC - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper force sync
ZOOKEEPER_HALT_NODE_COUNTER_GROUP - Static variable in interface org.apache.giraph.conf.GiraphConstants
This counter group will contain one counter whose name is the ZooKeeper node path which should be created to trigger computation halt
ZOOKEEPER_IS_EXTERNAL - Static variable in interface org.apache.giraph.conf.GiraphConstants
Zookeeper List will always hold a value during the computation while this option provides information regarding whether the zookeeper was internally started or externally provided.
ZOOKEEPER_LIST - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper comma-separated list (if not set, will start up ZooKeeper locally).
ZOOKEEPER_MANAGER_DIRECTORY - Static variable in interface org.apache.giraph.conf.GiraphConstants
If ZOOKEEPER_LIST is not set, then use this directory to manage ZooKeeper
ZOOKEEPER_MAX_SESSION_TIMEOUT - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper maximum session timeout
ZOOKEEPER_MIN_SESSION_TIMEOUT - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper minimum session timeout
ZOOKEEPER_OPS_MAX_ATTEMPTS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Max attempts for handling ZooKeeper connection loss
ZOOKEEPER_OPS_RETRY_WAIT_MSECS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Msecs to wait before retrying a failed ZooKeeper op due to connection loss.
ZOOKEEPER_PURGE_INTERVAL - Static variable in interface org.apache.giraph.conf.GiraphConstants
Zookeeper purge interval in hours
ZOOKEEPER_SERVER_PORT - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper port to use
ZOOKEEPER_SERVER_PORT_COUNTER_GROUP - Static variable in interface org.apache.giraph.conf.GiraphConstants
This counter group will contain one counter whose name is the ZooKeeper server:port which this job is using
ZOOKEEPER_SERVERLIST_POLL_MSECS - Static variable in interface org.apache.giraph.conf.GiraphConstants
Polling interval to check for the ZooKeeper server data
ZOOKEEPER_SESSION_TIMEOUT - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper session millisecond timeout
ZOOKEEPER_SKIP_ACL - Static variable in interface org.apache.giraph.conf.GiraphConstants
ZooKeeper skip ACLs
ZOOKEEPER_SNAP_RETAIN_COUNT - Static variable in interface org.apache.giraph.conf.GiraphConstants
Number of snapshots to be retained after purge
zooKeeperCleanup() - Method in class org.apache.giraph.graph.GraphTaskManager
Cleanup a ZooKeeper instance managed by this GiraphWorker upon job run failure.
ZookeeperConfig - Class in org.apache.giraph.zk
Zookeeper configuration file.
ZookeeperConfig() - Constructor for class org.apache.giraph.zk.ZookeeperConfig
 
ZooKeeperExt - Class in org.apache.giraph.zk
ZooKeeper provides only atomic operations.
ZooKeeperExt(String, int, int, int, Watcher) - Constructor for class org.apache.giraph.zk.ZooKeeperExt
Constructor to connect to ZooKeeper, does not make progress
ZooKeeperExt(String, int, int, int, Watcher, Progressable) - Constructor for class org.apache.giraph.zk.ZooKeeperExt
Constructor to connect to ZooKeeper, make progress
ZooKeeperExt.PathStat - Class in org.apache.giraph.zk
Data structure for handling the output of createOrSet()
ZooKeeperManager - Class in org.apache.giraph.zk
Manages the election of ZooKeeper servers, starting/stopping the services, etc.
ZooKeeperManager(Mapper<?, ?, ?, ?>.Context, ImmutableClassesGiraphConfiguration) - Constructor for class org.apache.giraph.zk.ZooKeeperManager
Constructor with context.
ZooKeeperManager.State - Enum in org.apache.giraph.zk
State of the application
ZooKeeperNodeCreator - Class in org.apache.giraph.zk
A utility class to be used to create a ZooKeeper node
ZooKeeperNodeCreator() - Constructor for class org.apache.giraph.zk.ZooKeeperNodeCreator
 
ZooKeeperRunner - Interface in org.apache.giraph.zk
ZooKeeper wrapper interface.
ZooKeeperServerRunner() - Constructor for class org.apache.giraph.zk.InProcessZooKeeperRunner.ZooKeeperServerRunner
 

_

__findattr_ex__(String) - Method in class org.apache.giraph.jython.wrappers.JythonWrapperBase
 
__setattr__(String, PyObject) - Method in class org.apache.giraph.jython.wrappers.JythonWrapperBase
 
A B C D E F G H I J K L M N O P R S T U V W Y Z _ 
Skip navigation links

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