Skip navigation links
A B C D E F G H I L M N O P R S T U V W 

A

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
 
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
ACTUAL_LOCALITY_RATIO - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
add(PieceCount) - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
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.
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
 
additionalInitConfig(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Additional configuration initialization, other then overriding class specification.
addOutputDesc(OD, String, GiraphConfiguration) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
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.
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.
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
 
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.
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(int) - Method in class org.apache.giraph.object.MultiSizedReusable
 
ArrayHandle<T> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.array
Handle to array of handles underneath
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.

B

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.
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.
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.
BlockMasterApi - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for the master methods.
BlockMasterCompute<S> - Class in org.apache.giraph.block_app.framework.api.giraph
MasterCompute class which executes block computation.
BlockMasterCompute() - Constructor for class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
BlockMasterLogic<S> - Class in org.apache.giraph.block_app.framework.internal
Block execution logic on master, iterating over Pieces of the application Block, executing master logic, and providing what needs to be executed on the workers.
BlockMasterLogic() - Constructor for class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
 
BlockMasterLogic.TimeStatsPerEvent - Class in org.apache.giraph.block_app.framework.internal
Class tracking invocation count and elapsed time for a set of events, each event being having a String name.
BlockOutputApi - Interface in org.apache.giraph.block_app.framework.api
Block worker output api
BlockOutputDesc<OW extends BlockOutputWriter> - Interface in org.apache.giraph.block_app.framework.output
Output description
BlockOutputFormat - Class in org.apache.giraph.block_app.framework.output
Hadoop output format to use with block output.
BlockOutputFormat() - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
BlockOutputHandle - Class in org.apache.giraph.block_app.framework.output
Handler for blocks output - keeps track of outputs and writers created
BlockOutputHandle() - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
BlockOutputHandle(String, Configuration, Progressable) - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
BlockOutputHandleAccessor - Interface in org.apache.giraph.block_app.framework.api
Function for accessing BlockOutputHandle.
BlockOutputOption<OD extends BlockOutputDesc<OW>,OW extends BlockOutputWriter> - Class in org.apache.giraph.block_app.framework.output
Block output option, with apis to use from application code
BlockOutputOption(String) - Constructor for class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
BlockOutputWriter - Interface in org.apache.giraph.block_app.framework.output
Block output writer
BlockUtils - Class in org.apache.giraph.block_app.framework
Utility functions for block applications
BlockWithApiHandle - Interface in org.apache.giraph.block_app.framework.block
Applications that need access to a BlockApiHandle should return a Block of this type.
BlockWorkerApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker methods.
BlockWorkerContext - Class in org.apache.giraph.block_app.framework.api.giraph
WorkerContext that executes receiver and sender blocks passed into BlockWorkerPieces.
BlockWorkerContext() - Constructor for class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
BlockWorkerContextApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker context methods.
BlockWorkerContextLogic - Class in org.apache.giraph.block_app.framework.internal
Block execution logic on WorkerContext.
BlockWorkerContextLogic() - Constructor for class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
BlockWorkerContextReceiveApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker context receive methods.
BlockWorkerContextSendApi<I extends org.apache.hadoop.io.WritableComparable,WM extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker send methods.
BlockWorkerLogic - Class in org.apache.giraph.block_app.framework.internal
Block execution logic on workers.
BlockWorkerLogic(BlockWorkerPieces) - Constructor for class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
BlockWorkerPieces<S> - Class in org.apache.giraph.block_app.framework.internal
Pair of pieces to be executed on workers in a superstep
BlockWorkerPieces(PairedPieceAndStage<S>, PairedPieceAndStage<S>, BlockApiHandle) - Constructor for class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
BlockWorkerReceiveApi<I extends org.apache.hadoop.io.WritableComparable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker receive methods.
BlockWorkerSendApi<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.framework.api
Block computation API available for worker send methods.
BlockWorkerValueAccessor - Interface in org.apache.giraph.block_app.framework.api
Function for accessing WorkerValue.
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.
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
 

C

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
 
checkBlockTypes(Block, Object, ImmutableClassesGiraphConfiguration) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
 
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
 
closeAllWriters() - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
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
 
commit() - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
Commit everything
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
 
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.
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.
Counter - Interface in org.apache.giraph.block_app.framework.api
Interface wrapping around org.appache.hadoop.mapreduce.Counter
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.
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.
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
 
createCopyForNewSuperstep() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
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
 
createForBasic2ObjectMap(PrimitiveIdTypeOps<K>) - Static method in class org.apache.giraph.object.MultiSizedReusable
 
createForBasicSet(PrimitiveIdTypeOps<I>) - Static method in class org.apache.giraph.object.MultiSizedReusable
 
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.
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
 
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
 
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
 
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.
createMessageCombiner(ImmutableClassesGiraphConfiguration<I, ? extends Writable, ? extends Writable>) - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
createMessageValueFactory(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
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
 
createOutputWriter(Configuration, Progressable) - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
Create writer
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.
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
 
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
 
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
 
createVertex() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 

D

DefaultMessageFactorySupplierFromConf(Class<M>) - Constructor for class org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.DefaultMessageFactorySupplierFromConf
 
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
 
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
 
doubleSupplier(double) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
 

E

EachVertexInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Traverse each Vertex in the graph, and initialize it with a given consumer function.
EachVertexInit(Consumer<Vertex<I, V, E>>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.EachVertexInit
 
edgeSupplier - Variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
edgeValueOrCreate(E) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
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
 
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.
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.
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
 

F

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.
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.
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.
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in interface org.apache.giraph.block_app.framework.block.Block
Calls consumer for each Piece: - in no particular order - potentially calling multiple times on same Piece - even if Piece might never be returned in the iterator - it will be called at least once for every piece that is going to be returned by iterator Can be used for static analysis/introspection of the block, without actually executing them.
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.EmptyBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.FilteringBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
forAllPossiblePieces(Consumer<AbstractPiece>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
forAllVertices(String, Consumer<Vertex<I, V, E>>) - Static method in class org.apache.giraph.block_app.library.Pieces
For each vertex execute given process function.
forAllVerticesOnReceive(String, Consumer<Vertex<I, V, E>>) - Static method in class org.apache.giraph.block_app.library.Pieces
For each vertex execute given process function.

G

generateStripedBlock(int, Function<Predicate<LongWritable>, Block>) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Generate striped block, with given number of stripes, using given blockGenerator to generate block for each stripe.
generateStripedBlock(int, Function<Predicate<I>, Block>, Int2ObjFunction<Int2ObjFunction<Predicate<I>>>) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Generate striped block, with given number of stripes, using given blockGenerator to generate block for each stripe, and using striping based on given stripeSupplier.
get(int) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ArrayHandle
Get value at index.
get(K) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.MapHandle
Get value for key.
get(int) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
getAggregatedValue(String) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getAndClearMessagesFromOtherWorkers() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getBlockApiHandle() - Method in interface org.apache.giraph.block_app.framework.block.BlockWithApiHandle
 
getBlockApiHandle() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getBlockOutputHandle() - Method in interface org.apache.giraph.block_app.framework.api.BlockOutputHandleAccessor
Get global block output handle.
getBroadcast(WorkerBroadcastUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.BroadcastHandle
Get broadcasted value
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.BroadcastHandleImpl
 
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Get broadcasted value
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Get broadcasted value
getBroadcast(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle
 
getBroadcastedSize(WorkerBroadcastUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.BroadcastArrayHandle
Number of elements that were broadcasted.
getBroadcastedSize(WorkerBroadcastUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.BroadcastMapHandle
Number of elements that were broadcasted.
getBroadcastedSize(WorkerBroadcastUsage) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfBroadcasts
 
getComputation() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getConf() - Method in interface org.apache.giraph.block_app.framework.api.BlockConfApi
Return the configuration used by this object.
getConf() - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerApi
 
getConf() - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
 
getConf() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper
 
getConf() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
getContext() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getConvenienceConfiguratorPackages() - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Provide list of strings representing packages where configurators will be searched for, allowing that full path is not required for CONFIGURATORS option.
getCount() - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
getCounter(String, String) - Method in interface org.apache.giraph.block_app.framework.api.StatusReporter
Get specified counter handler
getCounter(Mapper.Context, String, String) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
getEdgeValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete edge value class application will use.
getExecutionStage() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getGcJavaOpts(Configuration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
getGcJavaOpts(Configuration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Get special GC Java options.
getIteration() - Method in interface org.apache.giraph.block_app.library.iteration.IterationStage
 
getIteration() - Method in class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
getKey() - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
getMasterApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getMessageClass() - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify type of the message this Piece sends, if it does send messages.
getMessageClass() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
getMessageClass() - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Returns MessageClasses definition for messages being sent by this Piece.
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getMessageCombiner(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify message combiner to be used, if any.
getMessageCombiner(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
getMessageCombiner() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getMessageEncodeAndStoreType() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
getMessageFactory(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify message value factory to be used, which creates objects into which messages will be deserialized.
getMigrationSuperstep() - Method in interface org.apache.giraph.block_app.migration.MigrationSuperstepStage
 
getMigrationSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
getMyWorkerIndex() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getName() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.BroadcastHandleImpl
 
getName() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
getNextPiece() - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getNextWorkerPieces(WorkerGlobalCommUsage) - Static method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getNoOpCounter() - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
getOutgoingMessageClasses(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
 
getOutputConfOptions(Configuration) - Static method in class org.apache.giraph.block_app.framework.output.BlockOutputFormat
Returns an array of output configuration options set in the input configuration.
getOutputDesc(String) - Method in interface org.apache.giraph.block_app.framework.api.BlockOutputApi
 
getOutputDesc(String) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
getOutputDesc(BlockOutputApi) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
getOutputHandle() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
getOutputHandle() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
getPiece() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getPieceCount() - Method in interface org.apache.giraph.block_app.framework.block.Block
How many pieces are in this block.
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.EmptyBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.FilteringBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
getPieceCount() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getReceiver() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getReduced(String) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getReducedSize(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ReducerArrayHandle
Number of elements that were reduced.
getReducedSize(BlockMasterApi) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.map.ReducerMapHandle
Number of elements that were reduced.
getReducedSize(BlockMasterApi) - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles.ArrayOfReducers
 
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Get reduced value
getReducedValue(MasterGlobalCommUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle
Get reduced value
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Get reduced value
getReducedValue(MasterGlobalCommUsage) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
getSender() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
getStaticSize() - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.array.ArrayHandle
Size of this array if defined up front, or throws UnsupportedOperationException if size is dynamic
getStaticSize() - Method in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
getSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationFullAbstractComputation
 
getSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getTestGraph() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
getTotalNumEdges() - Method in interface org.apache.giraph.block_app.framework.api.BlockApi
Deprecated.
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getTotalNumEdges() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getTotalNumVertices() - Method in interface org.apache.giraph.block_app.framework.api.BlockApi
Deprecated.
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
getTotalNumVertices() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getValue() - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
getValue(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Get Vertex Value for a given id.
getVertex(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Get Vertex for a given id.
getVertexCount() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Get number of vertices in the graph
getVertexIDClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete vertex id class application will use.
getVertexReceiver(BlockWorkerReceiveApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getVertexReceiver(BlockWorkerReceiveApi<I>, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to do vertex receive processing.
getVertexReceiver(BlockWorkerReceiveApi<I>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getVertexReceiver(BlockWorkerReceiveApi<I>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
getVertexReceiver(BlockWorkerReceiveApi<I>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
getVertexReceiver(BlockWorkerReceiveApi<I>, MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getVertexSender(BlockWorkerSendApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
getVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to do vertex send processing.
getVertexSender(BlockWorkerSendApi<I, V, E, M>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
getVertexSender(BlockWorkerSendApi<I, V, E, M>, Object) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
getVertexSender(BlockWorkerSendApi<I, V, E, M>, MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
getVertexValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete vertex value class application will use.
getWorkerContext() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
getWorkerContextReceiveApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkerContextSendApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkerContextValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Concrete worker context value class application will use, if overridden.
getWorkerContextValueClass(GiraphConfiguration) - Method in class org.apache.giraph.block_app.migration.MigrationFullBlockFactory
 
getWorkerCount() - Method in interface org.apache.giraph.block_app.framework.api.BlockApi
Get number of workers
getWorkerCount() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
getWorkerReceiveApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkerSendApi() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
getWorkerValue() - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerValueAccessor
Get global worker value.
getWorkerValue() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
getWorkerValue() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
getWorkerValue(BlockWorkerApi<I>) - Method in class org.apache.giraph.block_app.framework.piece.PieceWithWorkerContext
Get global worker value.
getWrappedVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Add automatic handling of reducers to getVertexSender.
getWrappedVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
getWrappedVertexSender(BlockWorkerSendApi<I, V, E, M>, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
getWriter(String) - Method in interface org.apache.giraph.block_app.framework.api.BlockOutputApi
 
getWriter(String) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
getWriter(BlockOutputApi) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
GlobalReduceHandle(ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
GROUP - Static variable in class org.apache.giraph.block_app.framework.internal.BlockCounters
 

H

haltComputation() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
handles - Variable in class org.apache.giraph.block_app.reducers.array.ArrayOfHandles
 
hashCode() - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
hashCode() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
header() - Static method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
HugeArrayUtils - Class in org.apache.giraph.block_app.reducers.array
Utility class when we are dealing with huge arrays (i.e.

I

IfBlock - Class in org.apache.giraph.block_app.framework.block
Block that executes one of two branches based on a condition
IfBlock(Supplier<Boolean>, Block, Block) - Constructor for class org.apache.giraph.block_app.framework.block.IfBlock
 
IfBlock(Supplier<Boolean>, Block) - Constructor for class org.apache.giraph.block_app.framework.block.IfBlock
 
ignoreExistingVertices() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
inc(String, long) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
increment(long) - Method in interface org.apache.giraph.block_app.framework.api.Counter
Increment this counter by the given value
initAndCheckConfig(GiraphConfiguration) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Initializes configuration, such that running it executes block application.
initConfig(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
initConfig(GiraphConfiguration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Based on provided configuration, updates it, such that all necessary properties are initialized.
initialize() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
initialize(GiraphConfiguration, BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Initialize master logic to execute BlockFactory defined in the configuration.
initialize(Block, S, BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Initialize Master Logic to execute given block, starting with given executionStage.
initialize(Configuration, Progressable) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
initialize() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
initializeAfterRead(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic
Initialize object after deserializing it.
initializeAndCheck(String, Configuration) - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
Initialize output and perform any necessary checks
initializeVertex(Vertex<I, V, E>, I, Supplier<V>, List<Edge<I, E>>) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
InnerVertexReceiver() - Constructor for class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexReceiver
 
InnerVertexSender() - Constructor for class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexSender
 
isHalted() - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
isKnown() - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
isMasterApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerContextReceiveApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerContextSendApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerReceiveApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
isWorkerSendApiSet() - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
IterationCounterPiece - Class in org.apache.giraph.block_app.library.iteration
Piece that increments execution stage iteration.
IterationCounterPiece() - Constructor for class org.apache.giraph.block_app.library.iteration.IterationCounterPiece
 
IterationStage - Interface in org.apache.giraph.block_app.library.iteration
Execution stage that contains iteration information.
IterationStageImpl - Class in org.apache.giraph.block_app.library.iteration
Implementation of IterationStage
IterationStageImpl() - Constructor for class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
IterationStageImpl(int) - Constructor for class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
iterator() - Method in interface org.apache.giraph.block_app.framework.block.Block
Create iterator representing all pieces needed to be executed in this block.
iterator() - Method in class org.apache.giraph.block_app.framework.block.EmptyBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.FilteringBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
iterator() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 

L

line(int, double, long, String) - Static method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
LocalBlockRunner - Class in org.apache.giraph.block_app.framework.api.local
Local in-memory Block application job runner.
LocalReduceHandle(ReduceOperation<S, R>) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
LOG - Static variable in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
LOG - Static variable in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
LOG_EXECUTION_STATUS - Static variable in class org.apache.giraph.block_app.framework.BlockUtils
Property describing whether to log execution status as application runs
logTimeSums() - Method in class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
logToCommandLine(String) - Method in interface org.apache.giraph.block_app.framework.api.BlockMasterApi
Call this to log a line to command line of the job.
logToCommandLine(String) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 

M

makeVertex(Number, V, Map.Entry<? extends Number, ? extends Number>...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Creates a new Vertex object, without adding it into the graph.
makeVertex(Number, V, Supplier<E>, Number...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Creates a new Vertex object, without adding it into the graph.
makeVertex(Number, Number, Number, Number...) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
Creates a new Vertex object, without adding it into the graph.
MapHandle<K,V> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.map
Handle to map of handles underneath
masterCompute(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
masterCompute(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Function that is called on master, after send phase, before receive phase.
masterCompute(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
masterCompute(String, Consumer<BlockMasterApi>) - Static method in class org.apache.giraph.block_app.library.Pieces
Execute given function on master.
masterCompute(BlockMasterApi, MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
MESSAGE_ENCODE_AND_STORE_TYPE_MIN_FORCE - Static variable in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
This option will tell which message encode & store enum to force, when combining is not enabled.
MigrationAbstractComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M1 extends org.apache.hadoop.io.Writable,M2 extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.migration
Replacement for AbstractComputation when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationAbstractComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
MigrationAbstractComputation.MigrationBasicComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.migration
Drop-in replacement for BasicComputation when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationAbstractComputation.MigrationFullAbstractComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M1 extends org.apache.hadoop.io.Writable,M2 extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.migration
Drop-in replacement for AbstractComputation when migrating to Blocks Framework.
MigrationAbstractComputation.MigrationFullBasicComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.migration
Drop-in replacement for BasicComputation when migrating to Blocks Framework.
MigrationBasicComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationBasicComputation
 
MigrationFullAbstractComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationFullAbstractComputation
 
MigrationFullBasicComputation() - Constructor for class org.apache.giraph.block_app.migration.MigrationAbstractComputation.MigrationFullBasicComputation
 
MigrationFullBlockFactory - Class in org.apache.giraph.block_app.migration
BlockFactory to extend when using drop-in migration
MigrationFullBlockFactory() - Constructor for class org.apache.giraph.block_app.migration.MigrationFullBlockFactory
 
MigrationFullMasterCompute() - Constructor for class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
MigrationFullWorkerContext() - Constructor for class org.apache.giraph.block_app.migration.MigrationWorkerContext.MigrationFullWorkerContext
 
MigrationMasterCompute - Class in org.apache.giraph.block_app.migration
Replacement for MasterCompute when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationMasterCompute() - Constructor for class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
MigrationMasterCompute.MigrationFullMasterCompute - Class in org.apache.giraph.block_app.migration
Drop-in replacement for MasterCompute when migrating to Blocks Framework.
MigrationPiece<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,MPrev extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.migration
Piece used when migrating applications to Blocks Framework.
MigrationSuperstepStage - Interface in org.apache.giraph.block_app.migration
Execution stage holding information about migration superstep.
MigrationSuperstepStageImpl - Class in org.apache.giraph.block_app.migration
Implementation of execution stage holding information about migration superstep.
MigrationSuperstepStageImpl() - Constructor for class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
MigrationSuperstepStageImpl(int) - Constructor for class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
MigrationWorkerContext - Class in org.apache.giraph.block_app.migration
Replacement for WorkerContext when migrating to Blocks Framework, disallowing functions that are tied to execution order.
MigrationWorkerContext() - Constructor for class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
MigrationWorkerContext.MigrationFullWorkerContext - Class in org.apache.giraph.block_app.migration
Drop-in replacement for WorkerContext when migrating to Blocks Framework.
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.EachVertexInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
modifyGraph(NumericTestGraph<I, V, E>) - Method in interface org.apache.giraph.block_app.test_setup.TestGraphModifier
 
multiply(int) - Method in class org.apache.giraph.block_app.framework.block.PieceCount
 
MultiSizedReusable<T> - Class in org.apache.giraph.object
Holds reusable objects of multiple sizes.
MultiSizedReusable(Int2ObjFunction<T>, Consumer<T>) - Constructor for class org.apache.giraph.object.MultiSizedReusable
 

N

nextExecutionStage() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
nextExecutionStage(S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to provide different next execution stage for Pieces that come after it.
nextExecutionStage(S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
nextExecutionStage(IterationStage) - Method in class org.apache.giraph.block_app.library.iteration.IterationCounterPiece
 
nextExecutionStage(MigrationSuperstepStage) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
nullSupplier() - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
 
NUM_COMMUNITIES - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
NUM_EDGES_PER_VERTEX - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
NUM_PARTITIONS - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Number of vertex partitions
NUM_THREADS - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Number of threads to use
NUM_VERTICES - Static variable in class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
numberToEdgeValue(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
numberToVertexId(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
numberToVertexValue(Number) - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
NumericTestGraph<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup
Wraps TestGraph to allow using numbers to create and inspect the graph, instead of needing to have actual Writable values, which don't have auto-boxing.
NumericTestGraph(TestGraph<I, V, E>) - Constructor for class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
NumericTestGraph(GiraphConfiguration) - Constructor for class org.apache.giraph.block_app.test_setup.NumericTestGraph
 

O

ObjectMessageClasses<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.messages
MessageClasses implementation that provides factory and combiner instances through a provided supplier.
ObjectMessageClasses() - Constructor for class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
ObjectMessageClasses(Class<M>, SupplierFromConf<MessageValueFactory<M>>, SupplierFromConf<? extends MessageCombiner<? super I, M>>, MessageEncodeAndStoreType, boolean) - Constructor for class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
org.apache.giraph.block_app.framework - package org.apache.giraph.block_app.framework
Block application abstraction package.
org.apache.giraph.block_app.framework.api - package org.apache.giraph.block_app.framework.api
Interfaces representing full API to the underlying graph processing system.
org.apache.giraph.block_app.framework.api.giraph - package org.apache.giraph.block_app.framework.api.giraph
Giraph implementation of graph processing system API used by Blocks Framework.
org.apache.giraph.block_app.framework.api.local - package org.apache.giraph.block_app.framework.api.local
Local (single machine) implementation of graph processing system API used by Blocks Framework.
org.apache.giraph.block_app.framework.block - package org.apache.giraph.block_app.framework.block
Block interface as a composable unit of execution, and its common implementations.
org.apache.giraph.block_app.framework.internal - package org.apache.giraph.block_app.framework.internal
Implementation of execution logic, guiding internal execution of Block Application.
org.apache.giraph.block_app.framework.output - package org.apache.giraph.block_app.framework.output
Multi-output support for Block Applications
org.apache.giraph.block_app.framework.piece - package org.apache.giraph.block_app.framework.piece
Single execution object - Piece, and related classes.
org.apache.giraph.block_app.framework.piece.delegate - package org.apache.giraph.block_app.framework.piece.delegate
Pieces that delegate their work to a set of one or multiple other Pieces.
org.apache.giraph.block_app.framework.piece.global_comm - package org.apache.giraph.block_app.framework.piece.global_comm
Interfaces for Reducer and Broadcast Handles for automatic handling of global communication within Pieces, hiding a lot of it's complexities.
org.apache.giraph.block_app.framework.piece.global_comm.array - package org.apache.giraph.block_app.framework.piece.global_comm.array
Interfaces representing arrays of individual handles.
org.apache.giraph.block_app.framework.piece.global_comm.internal - package org.apache.giraph.block_app.framework.piece.global_comm.internal
Reducer and Broadcast Handles internal implementation for automatic handling of global communication within Pieces, hiding a lot of it's complexities.
org.apache.giraph.block_app.framework.piece.global_comm.map - package org.apache.giraph.block_app.framework.piece.global_comm.map
Interfaces representing map of individual handles
org.apache.giraph.block_app.framework.piece.interfaces - package org.apache.giraph.block_app.framework.piece.interfaces
Vertex processing functions for Pieces
org.apache.giraph.block_app.framework.piece.messages - package org.apache.giraph.block_app.framework.piece.messages
Utility classes for handling of messages within Pieces
org.apache.giraph.block_app.library - package org.apache.giraph.block_app.library
Core library of Pieces and Suppliers, providing most common usages.
org.apache.giraph.block_app.library.gc - package org.apache.giraph.block_app.library.gc
GC utility pieces.
org.apache.giraph.block_app.library.internal - package org.apache.giraph.block_app.library.internal
Internal implementation of Pieces needed for Pieces utility class.
org.apache.giraph.block_app.library.iteration - package org.apache.giraph.block_app.library.iteration
Utilities for having iteration within execution stage object.
org.apache.giraph.block_app.library.striping - package org.apache.giraph.block_app.library.striping
Utilities for striping.
org.apache.giraph.block_app.migration - package org.apache.giraph.block_app.migration
Migration utility for transforming standard Giraph applications, into Block Applications.
org.apache.giraph.block_app.reducers - package org.apache.giraph.block_app.reducers
Common reducer utilities for Block Applications
org.apache.giraph.block_app.reducers.array - package org.apache.giraph.block_app.reducers.array
Reducers for collecting arrays of objects.
org.apache.giraph.block_app.reducers.collect - package org.apache.giraph.block_app.reducers.collect
Reducers for distributed collection of objects.
org.apache.giraph.block_app.reducers.map - package org.apache.giraph.block_app.reducers.map
Reducers for collecting map of objects.
org.apache.giraph.block_app.test_setup - package org.apache.giraph.block_app.test_setup
Utilities for unit tests.
org.apache.giraph.block_app.test_setup.graphs - package org.apache.giraph.block_app.test_setup.graphs
Common Graphs for unit tests.
org.apache.giraph.object - package org.apache.giraph.object
Object handling related utilities.

P

PairedPieceAndStage<S> - Class in org.apache.giraph.block_app.framework.internal
Object holding piece with it's corresponding execution stage.
PairedPieceAndStage(AbstractPiece, S) - Constructor for class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
Piece<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece
Piece that should be extended in common usecases, when we want to be: - sending and then receiving messages from vertices - sending data to be aggregated from workers to master - sending values from master, via aggregators, to workers (basically - we don't want to use WorkerContext)
Piece() - Constructor for class org.apache.giraph.block_app.framework.piece.Piece
 
PieceCount - Class in org.apache.giraph.block_app.framework.block
Number of pieces
PieceCount(int) - Constructor for class org.apache.giraph.block_app.framework.block.PieceCount
 
Pieces - Class in org.apache.giraph.block_app.library
Utility class for creating common Pieces and computations for processing graphs.
PieceWithWorkerContext<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable,WV,WM extends org.apache.hadoop.io.Writable,S> - Class in org.apache.giraph.block_app.framework.piece
Piece that should be extended when WorkerContext is used.
PieceWithWorkerContext() - Constructor for class org.apache.giraph.block_app.framework.piece.PieceWithWorkerContext
 
postApplication() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
postApplication() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
postApplication() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext.MigrationFullWorkerContext
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexReceiver
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexSender
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerReceiveFunctions
 
postprocess() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerSendFunctions
 
postprocess() - Method in interface org.apache.giraph.block_app.framework.piece.interfaces.VertexPostprocessor
Override to finish computation.
postSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockComputation
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
postSuperstep() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
postSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
postSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
postWriting() - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
This method will be called after all writers are closed
preApplication() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
preApplication(BlockWorkerContextApi, BlockOutputHandle) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
preApplication() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext.MigrationFullWorkerContext
 
preSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockComputation
 
preSuperstep() - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
preSuperstep(BlockWorkerContextReceiveApi, BlockWorkerContextSendApi, BlockWorkerPieces, long, List<Writable>) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
 
preSuperstep(BlockWorkerReceiveApi, BlockWorkerSendApi) - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
 
preSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
preSuperstep() - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
preWriting() - Method in interface org.apache.giraph.block_app.framework.output.BlockOutputDesc
This method will be called before creating any writers
progress() - Method in interface org.apache.giraph.block_app.framework.api.StatusReporter
Report progress to the Hadoop framework.

R

random - Variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
readFields(DataInput) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
receiveIgnoreExistingVertices() - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to specify that receive of this Piece (and send of next Piece) ignore existing vertices, and just process received messages.
reduce(S) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
reduce(S) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
reduce(S) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Reduce single value
reduce(S) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle
Reduce single value
reduce(String, ReduceOperation<S, R>, SupplierFromVertex<I, V, E, S>, Consumer<R>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates single reducer piece - given reduce class, supplier of values on worker, reduces and passes the result to given consumer on master.
reduce(ArrayWritable<R>, Pair<PrimitiveRefs.IntRef, S>) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
reduce(WArrayList<R>, Pair<PrimitiveRefs.IntRef, S>) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
reduce(WArrayList<S>, S) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
reduce(List<S>, S) - Method in class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
reduce(List<Object>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Reduce single value
reduce(List<WArrayList>, List<Object>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
reduce(S) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
reduce(Basic2ObjectMap<K, R>, Pair<K, S>) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
reduce(PriorityQueue<S>, S) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
reduceAndBroadcast(String, ReduceOperation<S, R>, SupplierFromVertex<I, V, E, S>, ConsumerWithVertex<I, V, E, R>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates single reducer and broadcast piece - given reduce class, supplier of values on worker, reduces and broadcasts the value, passing it to the consumer on worker for each vertex.
reduceAndBroadcastWithArrayOfHandles(String, int, Supplier<ReduceOperation<S, R>>, SupplierFromVertex<I, V, E, Long>, SupplierFromVertex<I, V, E, S>, ConsumerWithVertex<I, V, E, R>) - Static method in class org.apache.giraph.block_app.library.Pieces
Like reduceAndBroadcast, but uses array of handles for reducers and broadcasts, to make it feasible and performant when values are large.
reduceDouble(ReducerHandle<DoubleWritable, ?>, double) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceDouble(ReducerHandle<DoubleWritable, ?>, double) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceFloat(ReducerHandle<FloatWritable, ?>, float) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceFloat(ReducerHandle<FloatWritable, ?>, float) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceInt(ReducerHandle<IntWritable, ?>, int) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceInt(ReducerHandle<IntWritable, ?>, int) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceLong(ReducerHandle<LongWritable, ?>, long) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
reduceLong(ReducerHandle<LongWritable, ?>, long) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceMerge(ArrayWritable<R>, ArrayWritable<R>) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
reduceMerge(WArrayList<R>, WArrayList<R>) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
reduceMerge(WArrayList<S>, WArrayList<S>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
reduceMerge(List<S>, List<S>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectReduceOperation
 
reduceMerge(List<WArrayList>, List<WArrayList>) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
reduceMerge(Basic2ObjectMap<K, R>, Basic2ObjectMap<K, R>) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
reduceMerge(PriorityQueue<S>, PriorityQueue<S>) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
reduceOp - Variable in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl
 
REDUCER_COUNT - Static variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
ReducerAndBroadcastWrapperHandle<S,R> - Class in org.apache.giraph.block_app.framework.piece.global_comm
Handle that wraps both reducerHandle and broadcastHandle, so callers don't need to have two fields.
ReducerAndBroadcastWrapperHandle() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
 
ReducerArrayHandle<S,R> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.array
Handle to array of reducers
ReducerHandle<S,R> - Interface in org.apache.giraph.block_app.framework.piece.global_comm
Handle to a reducer.
ReducerMapHandle<I,S,R> - Interface in org.apache.giraph.block_app.framework.piece.global_comm.map
Handle to array of reducers
reducers - Variable in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
ReducersForPieceHandler - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
All logic for transforming Giraph's reducer API to reducer handles.
ReducersForPieceHandler() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
ReducersForPieceHandler.BroadcastHandleImpl<T> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Implementation of BroadcastHandle
ReducersForPieceHandler.GlobalReduceHandle<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Global Reduce Handle is implementation of ReducerHandle, that will keep only one value for each worker, and each call to reduce will have to obtain a global lock, and incur synchronization costs.
ReducersForPieceHandler.LocalReduceHandle<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Local Reduce Handle is implementation of ReducerHandle, that will make a partially reduced value on each worker thread, which are at the end reduced all together.
ReducersForPieceHandler.ReduceHandleImpl<S,R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Parent implementation of ReducerHandle
ReducersForPieceHandler.WrappedReducedValue<R extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.global_comm.internal
Wrapper that makes reduced values self-serializable, and allows them to be broadcasted.
ReduceUtilsObject - Class in org.apache.giraph.block_app.framework.piece.global_comm
Utility object with common primitive reduce operations, without need to create reusable objects within the piece.
ReduceUtilsObject() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
 
reduceWithMaster(String, ReduceOperation<S, R>, SupplierFromVertex<I, V, E, S>, PairConsumer<R, BlockMasterApi>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates single reducer piece - given reduce class, supplier of values on worker, reduces and passes the result to given consumer on master.
register(OD, GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.output.BlockOutputOption
 
register(CreateReducersApi) - Method in class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
registerAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerAggregators(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Deprecated.
Use registerReducers instead.
registerAggregators(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
registerAggregators(BlockMasterApi) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
registeredReducer(ReducerHandle<S, R>) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle
Set reducer handle to just registered handle
registeredReducer(CreateReducersApi, Class<?>...) - Method in class org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
Set reducer handle to just registered handle
registerOutputs(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
registerOutputs(GiraphConfiguration) - Method in interface org.apache.giraph.block_app.framework.BlockFactory
Register outputs to use during the application (vs output at the end of the application), based on provided configuration.
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in interface org.apache.giraph.block_app.framework.api.BlockMasterApi
Deprecated.
registerPersistentAggregator(String, Class<? extends Aggregator<A>>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerReducer(String, ReduceOperation<S, R>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerReducer(String, ReduceOperation<S, R>, R) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
registerReducers(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
registerReducers(CreateReducersApi, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
Override to register any potential reducers used by this piece, through calls to reduceApi, which will return reducer handles for simple.
removeEdgesRequest(I, I) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Request to remove all edges from a given source vertex to a given target vertex (processed just prior to the next receive phase).
removeEdgesRequest(I, I) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
removeVertexRequest(I) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Request to remove a vertex from the graph (applied just prior to the next receive phase).
removeVertexRequest(I) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
removeVertices(String, SupplierFromVertex<I, V, E, Boolean>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece which removes vertices for which supplier returns true.
RepeatBlock - Class in org.apache.giraph.block_app.framework.block
Block that repeats another block given number of times.
RepeatBlock(int, Block) - Constructor for class org.apache.giraph.block_app.framework.block.RepeatBlock
 
RepeatBlock(IntSupplier, Block) - Constructor for class org.apache.giraph.block_app.framework.block.RepeatBlock
Creates a repeat block, that before starting execution takes number of iterations from the given supplier.
RepeatUntilBlock - Class in org.apache.giraph.block_app.framework.block
Block that repeats another block until toQuit supplier returns true, but at most given number of times.
RepeatUntilBlock(int, Block, Supplier<Boolean>) - Constructor for class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
returnAllWriters() - Method in class org.apache.giraph.block_app.framework.output.BlockOutputHandle
 
RUN_ALL_CHECKS - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Whether to run all supported checks.
runApp(TestGraph<I, V, E>, boolean) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block Application specified within the conf, on a given graph, locally, in-memory.
runApp(TestGraph<I, V, E>) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block Application specified within the conf, on a given graph, locally, in-memory.
runAppWithVertexOutput(TestGraph<I, V, E>, SimpleVertexWriter<I, V, E>) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block Application specified within the conf, on a given graph, locally, in-memory, with a given vertexSaver.
runBlock(TestGraph<I, V, E>, Block, Object) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block from a specified execution stage on a given graph, locally, in-memory.
runBlockWithVertexOutput(Block, Object, TestGraph<I, V, E>, SimpleVertexWriter<I, V, E>) - Static method in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
Run Block from a specified execution stage on a given graph, locally, in-memory, with a given vertexSaver.
runTest(TestGraphModifier<? super I, ? super V, ? super E>, TestGraphChecker<? super I, ? super V, ? super E>, BulkConfigurator) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Creates configuration using configurator, initializes the graph using graphInitializer, and checks it via graphChecker.
runTest(TestGraphModifier<? super I, ? super V, ? super E>, TestGraphChecker<? super I, ? super V, ? super E>, GiraphConfiguration) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Uses provided configuration, initializes the graph using graphInitializer, and checks it via graphChecker.
runTest(NumericTestGraph<I, V, E>, TestGraphChecker<? super I, ? super V, ? super E>) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
Base of runTest.

S

sendMessage(I, M) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Send a message to a vertex id.
sendMessage(String, Class<M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, Iterable<M>>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all targets provided by targetsSupplier.
sendMessage(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all targets provided by targetsSupplier, and uses given messageCombiner to combine messages together.
sendMessage(I, M2) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
SendMessageChain<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,P> - Class in org.apache.giraph.block_app.library
Utility class for creating sequences of sending replies to received messages.
SendMessagePiece<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.library.internal
Piece that sends a message provided through messageProducer to given set of neighbors, and passes them to messagesConsumer.
SendMessagePiece(String, Class<M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, Iterable<M>>) - Constructor for class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
sendMessageToAllEdges(Vertex<I, V, E>, M) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Send a message to all edges.
sendMessageToAllEdges(Vertex<I, V, E>, M2) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
sendMessageToMultipleEdges(Iterator<I>, M) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerSendApi
Send a message to multiple target vertex ids in the iterator.
sendMessageToMultipleEdges(Iterator<I>, M2) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
sendMessageToNeighbors(String, Class<M>, SupplierFromVertex<I, V, E, M>, ConsumerWithVertex<I, V, E, Iterable<M>>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all neighbors of current vertex.
sendMessageToNeighbors(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, ConsumerWithVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.Pieces
Creates Piece that for each vertex, sends message provided by messageSupplier to all neighbors of current vertex, and uses given messageCombiner to combine messages together.
sendMessageToWorker(WM, int) - Method in interface org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi
Send message to another worker
sendMessageToWorker(Writable, int) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
SendMessageWithCombinerPiece<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.library.internal
Piece that sends a message provided through messageProducer to given set of neighbors, uses a message combiner and passes them to messagesConsumer.
SendMessageWithCombinerPiece(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>, ConsumerWithVertex<I, V, E, M>) - Constructor for class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
SequenceBlock - Class in org.apache.giraph.block_app.framework.block
Block that executes provided blocks sequentially.
SequenceBlock(Block...) - Constructor for class org.apache.giraph.block_app.framework.block.SequenceBlock
 
SequenceBlock(List<? extends Block>) - Constructor for class org.apache.giraph.block_app.framework.block.SequenceBlock
 
SERIALIZE_MASTER - Static variable in class org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
 
setAggregatedValue(String, A) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
setAndInitBlockFactoryClass(GiraphConfiguration, Class<? extends BlockFactory<?>>) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Set block factory, and initialize configs with it.
setApi(BlockWorkerContextApi) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
setBlockFactoryClass(Configuration, Class<? extends BlockFactory<?>>) - Static method in class org.apache.giraph.block_app.framework.BlockUtils
Set which BlockFactory class to be used for the application.
setComputation(Class<? extends MigrationAbstractComputation.MigrationFullAbstractComputation>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setIncomingMessage(Class<? extends Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setMasterApi(BlockMasterApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setMasterTimeCounter(PairedPieceAndStage<?>, long, long, StatusReporter, BlockMasterLogic.TimeStatsPerEvent) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
setMessageCombiner(Class<? extends MessageCombiner>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setNextWorkerPieces(MasterCompute, BlockWorkerPieces<S>) - Static method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
Sets which WorkerComputation is going to be executed in the next superstep.
setOutgoingMessage(Class<? extends Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute.MigrationFullMasterCompute
 
setReceivedMessages(List<Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
setStageCounters(String, Object, StatusReporter) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
Takes all fields from stage object, and puts them into counters, if possible.
setStatus(String) - Method in interface org.apache.giraph.block_app.framework.api.StatusReporter
Set the current status of the task to the given string.
setTestRepeatTimes(int) - Static method in class org.apache.giraph.block_app.test_setup.TestGraphUtils
 
setValue(long) - Method in interface org.apache.giraph.block_app.framework.api.Counter
Set this counter by the given value
setWorkerContextReceiveApi(BlockWorkerContextReceiveApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerContextSendApi(BlockWorkerContextSendApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerReceiveApi(BlockWorkerReceiveApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerSendApi(BlockWorkerSendApi) - Method in class org.apache.giraph.block_app.framework.api.BlockApiHandle
 
setWorkerTimeCounter(BlockWorkerPieces<?>, long, long, StatusReporter, BlockMasterLogic.TimeStatsPerEvent) - Static method in class org.apache.giraph.block_app.framework.internal.BlockCounters
 
ShardedBroadcastHandle(BroadcastArrayHandle<KryoWritableWrapper<R>>) - Constructor for class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle
 
ShardedReducerHandle<S,R> - Class in org.apache.giraph.block_app.reducers.collect
Reducing values into a list of reducers, randomly, and getting the results of all reducers together
ShardedReducerHandle() - Constructor for class org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle
 
ShardedReducerHandle.ShardedBroadcastHandle - Class in org.apache.giraph.block_app.reducers.collect
Broadcast for ShardedReducerHandle
shouldCreateVertexOnMsgs(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
Override if vertices shouldn't be created by default, if message is sent to a vertex that doesn't exist.
shouldSendOneMessageToAll(GiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.AbstractBlockFactory
 
Small1GraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a network that looks like: 1 5 / \ / \ 6 0---2--3---4 where 6 is disconnected from the rest of the network.
Small1GraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit
 
Small1GraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit
 
Small2GraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a network that looks like: 1 5 / \ / \ 6 0---2 3---4 where 6 is disconnected from the rest of the network.
Small2GraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit
 
Small2GraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit
 
SmallDirectedForestGraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a directed forest that looks like: 0 4 6 / \ | / \ 1 2 5 7 8 | 3 Edges are directed from top to bottom.
SmallDirectedForestGraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit
 
SmallDirectedForestGraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit
 
SmallDirectedTreeGraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Create a directed tree that looks like: 0 __ / \ \ 1 2 6 | |\ 3 4 5 Edges are directed from top to bottom.
SmallDirectedTreeGraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit
 
SmallDirectedTreeGraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit
 
startCustom(Function<ConsumerWithVertex<I, V, E, P>, Block>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain by providing a function that will produce Block representing beginning of the chain, given a consumer of messages send by the last link in the created block.
startSend(String, Class<M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all targets provided by targetsSupplier.
startSend(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all targets provided by targetsSupplier, and use given messageCombiner to combine messages together.
startSendToNeighbors(String, Class<M>, SupplierFromVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all neighbors of a current vertex.
startSendToNeighbors(String, MessageCombiner<? super I, M>, SupplierFromVertex<I, V, E, M>) - Static method in class org.apache.giraph.block_app.library.SendMessageChain
Start chain with sending message provided by messageSupplier to all neighbors of a current vertex, and use given messageCombiner to combine messages together.
StatusReporter - Interface in org.apache.giraph.block_app.framework.api
Interface wrapping around functions from org.appache.hadoop.mapreduce.StatusReporter
stripeBlockBySenders(int, Block) - Static method in class org.apache.giraph.block_app.library.striping.StripingUtils
Stripe given block, by calling vertexSend only in it's corresponding stripe.
stripeByReceiver(int, Int2ObjFunction<Int2ObjFunction<Predicate<I>>>) - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
Stripe message sending computation across multiple stripes, in each stripe only part of the vertices will receive messages.
stripeByReceiver(int, Int2ObjFunction<Int2ObjFunction<Predicate<I>>>) - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
Stripe message sending computation across multiple stripes, in each stripe only part of the vertices will receive messages.
StripingUtils - Class in org.apache.giraph.block_app.library.striping
Utility functions for doing superstep striping.
SupplierFromConf<T> - Interface in org.apache.giraph.block_app.framework.piece.messages
Supplier from configuration
SupplierFromConf.DefaultMessageFactorySupplierFromConf<M extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.framework.piece.messages
Supplier from configuration returning DefaultMessageValueFactory instances.
SupplierFromConf.SupplierFromConfByCopy<T> - Class in org.apache.giraph.block_app.framework.piece.messages
Supplier from configuration, by copying given instance every time.
SupplierFromConfByCopy(T) - Constructor for class org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.SupplierFromConfByCopy
 
SyntheticGraphInit<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Class in org.apache.giraph.block_app.test_setup.graphs
Creates synthetic graphs, that can have community structure.
SyntheticGraphInit(Supplier<E>) - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 
SyntheticGraphInit() - Constructor for class org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit
 

T

TestGraphChecker<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.test_setup
Test graph checker, function that checks whether output of a test is correct.
TestGraphModifier<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.test_setup
Test graph modifier, function that initializes graph (i.e.
TestGraphUtils - Class in org.apache.giraph.block_app.test_setup
Utility functions for running TestGraph unit tests.
thenSend(String, Class<M>, FunctionWithVertex<I, V, E, P, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all targets provided by targetsSupplier.
thenSend(String, MessageCombiner<? super I, M>, FunctionWithVertex<I, V, E, P, M>, SupplierFromVertex<I, V, E, Iterator<I>>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all targets provided by targetsSupplier, and use given messageCombiner to combine messages together.
thenSendToNeighbors(String, Class<M>, FunctionWithVertex<I, V, E, P, M>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all neighbors of current vertex.
thenSendToNeighbors(String, MessageCombiner<? super I, M>, FunctionWithVertex<I, V, E, P, M>) - Method in class org.apache.giraph.block_app.library.SendMessageChain
Give previously received message(s) to messageSupplier, and send message it returns to all neighbors of current vertex, and use given messageCombiner to combine messages together.
TimeStatsPerEvent(String) - Constructor for class org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
 
TopNReduce<S extends Comparable<S>> - Class in org.apache.giraph.block_app.reducers
Extracts top N largest elements
TopNReduce(int) - Constructor for class org.apache.giraph.block_app.reducers.TopNReduce
 
TopNReduce() - Constructor for class org.apache.giraph.block_app.reducers.TopNReduce
 
toString() - Method in class org.apache.giraph.block_app.framework.block.IfBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.block.RepeatBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.block.SequenceBlock
 
toString() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 
toString() - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
toString() - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
 
toString() - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
toString() - Method in class org.apache.giraph.block_app.library.internal.SendMessagePiece
 
toString() - Method in class org.apache.giraph.block_app.library.internal.SendMessageWithCombinerPiece
 
toString() - Method in class org.apache.giraph.block_app.library.iteration.IterationStageImpl
 
toString() - Method in class org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl
 
toString() - Method in class org.apache.giraph.block_app.test_setup.NumericTestGraph
 
toStringShort() - Method in class org.apache.giraph.block_app.framework.internal.BlockWorkerPieces
 

U

unlimited(Block) - Static method in class org.apache.giraph.block_app.framework.block.RepeatBlock
Create a repeat block that executes unlimited number of times.
unlimited(Block, Supplier<Boolean>) - Static method in class org.apache.giraph.block_app.framework.block.RepeatUntilBlock
Repeat unlimited number of times, until toQuit supplier returns true.
USE_FULL_GIRAPH_ENV_IN_TESTS - Static variable in class org.apache.giraph.block_app.test_setup.TestGraphUtils
modify locally for running full Digraph tests from IDE
useMessageCombiner() - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 

V

verifyConsistent(ImmutableClassesGiraphConfiguration) - Method in class org.apache.giraph.block_app.framework.piece.messages.ObjectMessageClasses
 
vertexEdgesSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns edges object.
vertexIdSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns vertex ID.
vertexNeighborsSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns Iterator over all neighbor IDs.
vertexNeighborsSupplier(Predicate<I>) - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns Iterator over neighbor IDs that return true for given predicate.
vertexNeighborsSupplierWithIndex(PairPredicate<PrimitiveRefs.IntRef, I>) - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which gives Iterator over neighbor IDs that return true for given predicate over (index, target) Note - iterator returns reused object, so you need to "use" them, before calling next() again.
VertexPostprocessor - Interface in org.apache.giraph.block_app.framework.piece.interfaces
Interface containing a single function - postprocess.
vertexReceive(Vertex<I, V, E>, Iterable<M>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerReceiveFunctions
 
vertexReceive(Vertex<I, V, E>, Iterable<M>) - Method in interface org.apache.giraph.block_app.framework.piece.interfaces.VertexReceiver
Must be defined by user to do computation on a single Vertex.
VertexReceiver<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.framework.piece.interfaces
Interface representing actions that happen on worker, for each vertex, during receive phase: to receive messages from vertices to receive data from master through aggregators Marked to not allow seriazliation, as it should be created on the worker, so should never be serialiized, disallow only for catching problems early.
vertexSend(Vertex<I, V, E>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece.DelegateWorkerSendFunctions
 
vertexSend(Vertex<I, V, E>) - Method in interface org.apache.giraph.block_app.framework.piece.interfaces.VertexSender
Must be defined by user to do computation on a single Vertex.
VertexSender<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> - Interface in org.apache.giraph.block_app.framework.piece.interfaces
Interface representing actions that happen on worker, for each vertex, during send phase: to send messages to vertices to send data for aggregation on master Marked to not allow seriazliation, as it should be created on the worker, so should never be serialiized, disallow only for catching problems early.
VertexSenderObserver - Interface in org.apache.giraph.block_app.framework.piece.global_comm.internal
Observer able to hook into vertex sender pre/post processing
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
vertexSenderWorkerPostprocess(WorkerReduceUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.GlobalReduceHandle
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.LocalReduceHandle
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler
 
vertexSenderWorkerPreprocess(WorkerReduceUsage) - Method in interface org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver
 
VertexSuppliers - Class in org.apache.giraph.block_app.library
SupplierFromVertex that extract common information from vertex itself.
vertexValueSupplier() - Static method in class org.apache.giraph.block_app.library.VertexSuppliers
Supplier which extracts and returns vertex value.

W

workerContextReceive(BlockWorkerContextReceiveApi, Object, List<Writable>) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
workerContextReceive(BlockWorkerContextReceiveApi, S, WV, List<WM>) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to have worker context receive computation.
workerContextReceive(BlockWorkerContextReceiveApi, S, WV, List<WM>) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
workerContextReceive(BlockWorkerContextReceiveApi, S, Object, List<NoMessage>) - Method in class org.apache.giraph.block_app.framework.piece.Piece
 
workerContextReceive(BlockWorkerContextReceiveApi, MigrationSuperstepStage, MigrationWorkerContext, List<Writable>) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
workerContextSend(BlockWorkerContextSendApi, Object) - Method in class org.apache.giraph.block_app.framework.internal.PairedPieceAndStage
 
workerContextSend(BlockWorkerContextSendApi<I, WM>, S, WV) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Override to have worker context send computation.
workerContextSend(BlockWorkerContextSendApi<I, WM>, S, WV) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
workerContextSend(BlockWorkerContextSendApi<I, NoMessage>, S, Object) - Method in class org.apache.giraph.block_app.framework.piece.Piece
 
workerContextSend(BlockWorkerContextSendApi<WritableComparable, NoMessage>, Object, Object) - Method in class org.apache.giraph.block_app.library.gc.WorkerGCPiece
 
workerContextSend(BlockWorkerContextSendApi<I, Writable>, MigrationSuperstepStage, MigrationWorkerContext) - Method in class org.apache.giraph.block_app.migration.MigrationPiece
 
WorkerGCPiece - Class in org.apache.giraph.block_app.library.gc
Dummy piece to hint System.gc()
WorkerGCPiece() - Constructor for class org.apache.giraph.block_app.library.gc.WorkerGCPiece
 
WrappedReducedValue() - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
WrappedReducedValue(ReduceOperation<?, R>, R) - Constructor for class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
wrappedRegisterReducers(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.AbstractPiece
Add automatic handling of reducers to registerReducers.
wrappedRegisterReducers(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.DefaultParentPiece
 
wrappedRegisterReducers(BlockMasterApi, S) - Method in class org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece
 
write(DataOutput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockMasterCompute
 
write(DataOutput) - Method in class org.apache.giraph.block_app.framework.api.giraph.BlockWorkerContext
 
write(DataOutput) - Method in class org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue
 
write(DataOutput) - Method in class org.apache.giraph.block_app.migration.MigrationAbstractComputation
 
write(DataOutput) - Method in class org.apache.giraph.block_app.migration.MigrationMasterCompute
 
write(DataOutput) - Method in class org.apache.giraph.block_app.migration.MigrationWorkerContext
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.array.ArrayReduce
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.array.BasicArrayReduce
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectPrimitiveReduceOperation
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.collect.CollectTuplesOfPrimitivesReduceOperation
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.map.BasicMapReduce
 
write(DataOutput) - Method in class org.apache.giraph.block_app.reducers.TopNReduce
 
A B C D E F G H I L M N O P R S T U V W 
Skip navigation links

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