- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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(TaskAttemptContext) - Method in class org.apache.giraph.io.EdgeWriter
-
- 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() - 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() - Method in class org.apache.giraph.io.ReverseEdgeDuplicator
-
- close() - Method in class org.apache.giraph.io.VertexReader
-
- close(TaskAttemptContext) - Method in class org.apache.giraph.io.VertexWriter
-
- 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
-
- 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
-
- 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
-
- 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
-
- createMappingStoreOps() - Method in class org.apache.giraph.conf.ImmutableClassesGiraphConfiguration
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
-
- 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
- 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
-
- 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
-
- 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
-
- 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
- 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
-
- 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
-
- 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
- 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
-
- 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 Funct