Package | Description |
---|---|
org.apache.giraph.benchmark |
Package of benchmarks for performance testing and optimization
|
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 |
Giraph implementation of graph processing system API used by
Blocks Framework.
|
org.apache.giraph.block_app.framework.internal |
Implementation of execution logic, guiding internal execution of
Block Application.
|
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.interfaces |
Vertex processing functions for Pieces
|
org.apache.giraph.block_app.library |
Core library of Pieces and Suppliers, providing most common usages.
|
org.apache.giraph.block_app.migration |
Migration utility for transforming standard Giraph applications, into
Block Applications.
|
org.apache.giraph.block_app.test_setup |
Utilities for unit tests.
|
org.apache.giraph.block_app.test_setup.graphs |
Common Graphs for unit tests.
|
org.apache.giraph.comm |
Package of communication related objects, IPC service.
|
org.apache.giraph.comm.netty |
Package for netty implementations.
|
org.apache.giraph.conf |
Package of Giraph configuration related things.
|
org.apache.giraph.edge |
Package of Vertex implementations.
|
org.apache.giraph.examples |
Package of Giraph examples.
|
org.apache.giraph.examples.block_app |
Package of Giraph examples for Block Applications.
|
org.apache.giraph.examples.scc |
Classes for Strongly Connected Components computation.
|
org.apache.giraph.function.vertex |
Package for interfaces representing functions additionally
performed on vertex values.
|
org.apache.giraph.graph |
Package of all the graph related objects, built on the
org.apache.bsp package.
|
org.apache.giraph.io |
Input/Output related things.
|
org.apache.giraph.io.filters |
Input/Output filters.
|
org.apache.giraph.io.formats |
Package of reusable library Giraph objects.
|
org.apache.giraph.io.internal |
Input/Output classes for internal use only.
|
org.apache.giraph.io.iterables |
Iterable wrappers for IO readers/writers
|
org.apache.giraph.jython |
Jython integration.
|
org.apache.giraph.partition |
Package of partitioning related objects.
|
org.apache.giraph.utils |
Package of all generic utility classes.
|
Modifier and Type | Method and Description |
---|---|
void |
PageRankComputation.compute(Vertex<org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable,org.apache.hadoop.io.NullWritable> vertex,
Iterable<org.apache.hadoop.io.FloatWritable> messages) |
void |
RandomMessageBenchmark.RandomMessageComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.BytesWritable> messages) |
void |
WeightedPageRankComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
ReducersBenchmark.ReducersBenchmarkComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
ShortestPathsComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
AggregatorsBenchmark.AggregatorsBenchmarkComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
Modifier and Type | Method and Description |
---|---|
void |
BlockWorkerSendApi.sendMessageToAllEdges(Vertex<I,V,E> vertex,
M message)
Send a message to all edges.
|
Modifier and Type | Method and Description |
---|---|
void |
BlockComputation.compute(Vertex vertex,
Iterable messages) |
Modifier and Type | Method and Description |
---|---|
void |
BlockWorkerLogic.compute(Vertex vertex,
Iterable messages) |
Modifier and Type | Method and Description |
---|---|
void |
DelegatePiece.DelegateWorkerReceiveFunctions.vertexReceive(Vertex<I,V,E> vertex,
Iterable<M> messages) |
void |
DelegatePiece.DelegateWorkerSendFunctions.vertexSend(Vertex<I,V,E> vertex) |
Modifier and Type | Method and Description |
---|---|
void |
VertexReceiver.vertexReceive(Vertex<I,V,E> vertex,
Iterable<M> messages)
Must be defined by user to do computation on a single Vertex.
|
void |
VertexSender.vertexSend(Vertex<I,V,E> vertex)
Must be defined by user to do computation on a single Vertex.
|
Modifier and Type | Method and Description |
---|---|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
Pieces.forAllVertices(String pieceName,
Consumer<Vertex<I,V,E>> process)
For each vertex execute given process function.
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
Pieces.forAllVerticesOnReceive(String pieceName,
Consumer<Vertex<I,V,E>> process)
For each vertex execute given process function.
|
Modifier and Type | Method and Description |
---|---|
void |
MigrationAbstractComputation.compute(Vertex<I,V,E> vertex,
Iterable<M1> messages) |
void |
MigrationAbstractComputation.sendMessageToAllEdges(Vertex<I,V,E> vertex,
M2 message) |
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
NumericTestGraph.createVertex() |
Vertex<I,V,E> |
NumericTestGraph.getVertex(Number vertexId)
Get Vertex for a given id.
|
Vertex<I,V,E> |
NumericTestGraph.makeVertex(Number vertexId,
Number value,
Number edgeValue,
Number... edges)
Creates a new Vertex object, without adding it into the graph.
|
Vertex<I,V,E> |
NumericTestGraph.makeVertex(Number vertexId,
V vertexValue,
Map.Entry<? extends Number,? extends Number>... edges)
Creates a new Vertex object, without adding it into the graph.
|
Vertex<I,V,E> |
NumericTestGraph.makeVertex(Number vertexId,
V vertexValue,
Supplier<E> edgeSupplier,
Number... edges)
Creates a new Vertex object, without adding it into the graph.
|
Modifier and Type | Method and Description |
---|---|
void |
NumericTestGraph.initializeVertex(Vertex<I,V,E> v,
I id,
Supplier<V> valueSupplier,
List<Edge<I,E>> edgesList) |
Constructor and Description |
---|
EachVertexInit(Consumer<Vertex<I,V,E>> vertexConsumer) |
Modifier and Type | Method and Description |
---|---|
int |
SendPartitionCache.addVertex(PartitionOwner partitionOwner,
Vertex<I,V,E> vertex)
Add a vertex to the cache.
|
int |
SendMutationsCache.addVertexMutation(Integer partitionId,
Vertex<I,V,E> vertex)
Add a add vertex mutation to the cache.
|
void |
WorkerClientRequestProcessor.addVertexRequest(Vertex<I,V,E> vertex)
Sends a request to the appropriate vertex range owner to add a vertex
|
void |
SendMessageCache.sendMessageToAllRequest(Vertex<I,?,?> vertex,
M message)
Send message to all its neighbors
|
void |
WorkerClientRequestProcessor.sendMessageToAllRequest(Vertex<I,V,E> vertex,
org.apache.hadoop.io.Writable message)
Sends a message through all edges to all destinations.
|
boolean |
WorkerClientRequestProcessor.sendVertexRequest(PartitionOwner partitionOwner,
Vertex<I,V,E> vertex)
Sends a vertex to the appropriate partition owner
|
Constructor and Description |
---|
TargetVertexIdIterator(Vertex<I,?,?> vertex)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
NettyWorkerClientRequestProcessor.addVertexRequest(Vertex<I,V,E> vertex) |
void |
NettyWorkerClientRequestProcessor.sendMessageToAllRequest(Vertex<I,V,E> vertex,
org.apache.hadoop.io.Writable message) |
boolean |
NettyWorkerClientRequestProcessor.sendVertexRequest(PartitionOwner partitionOwner,
Vertex<I,V,E> vertex) |
Modifier and Type | Field and Description |
---|---|
static ClassConfOption<Vertex> |
GiraphConstants.VERTEX_CLASS
Vertex class
|
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
ImmutableClassesGiraphConfiguration.createVertex()
Create a vertex
|
Modifier and Type | Method and Description |
---|---|
Class<? extends Vertex> |
GiraphTypes.getVertexClass() |
Class<? extends Vertex> |
GiraphClasses.getVertexClass()
Get Vertex implementation class
|
Modifier and Type | Method and Description |
---|---|
void |
GiraphConfiguration.setVertexClass(Class<? extends Vertex> vertexClass)
Set the vertex implementation class
|
Constructor and Description |
---|
MutableEdgesIterable(Vertex<I,?,E> vertex)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.NullWritable> |
LongDoubleNullTextInputFormat.LongDoubleNullDoubleVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,PageRankWithKryoSimpleWritable.VertexValue,PageRankWithKryoSimpleWritable.EdgeValue> |
PageRankWithKryoSimpleWritable.PageRankWithKryoVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> |
NormalizingLongDoubleDoubleTextInputFormat.NormalizingLongDoubleDoubleDoubleVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> |
AggregatorsTestComputation.SimpleVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> |
SimplePageRankComputation.SimplePageRankVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> |
LongDoubleDoubleTextInputFormat.LongDoubleDoubleDoubleVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> |
SimpleSuperstepComputation.SimpleSuperstepVertexReader.getCurrentVertex() |
Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> |
LongDoubleFloatTextInputFormat.LongDoubleFloatVertexReader.getCurrentVertex() |
Modifier and Type | Method and Description |
---|---|
void |
ConnectedComponentsComputation.compute(Vertex<org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.NullWritable> vertex,
Iterable<org.apache.hadoop.io.IntWritable> messages)
Propagates the smallest vertex id to all neighbors.
|
void |
MaxComputation.compute(Vertex<org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.NullWritable> vertex,
Iterable<org.apache.hadoop.io.IntWritable> messages) |
void |
SimpleTriangleClosingComputation.compute(Vertex<org.apache.hadoop.io.IntWritable,SimpleTriangleClosingComputation.IntArrayListWritable,org.apache.hadoop.io.NullWritable> vertex,
Iterable<org.apache.hadoop.io.IntWritable> messages) |
void |
IdentityComputation.compute(Vertex<I,V,E> vertex,
Iterable<M> messages) |
void |
BrachaTouegDeadlockComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,BrachaTouegDeadlockVertexValue,org.apache.hadoop.io.LongWritable> vertex,
Iterable<BrachaTouegDeadlockMessage> messages) |
void |
RandomWalkComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,E> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleMasterComputeComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
TestComputationStateComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
AggregatorsTestComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimplePageRankComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleMutateGraphComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleShortestPathsComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleFailComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleVertexWithWorkerContext.SimpleComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleCheckpoint.SimpleCheckpointComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.FloatWritable> messages) |
void |
SimpleMsgComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.IntWritable> messages) |
void |
SimpleCombinerComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.IntWritable> messages) |
void |
SimpleSuperstepComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.IntWritable> messages) |
void |
VerifyMessage.VerifyMessageComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<VerifyMessage.VerifiableMessage> messages) |
void |
SimpleOutDegreeCountComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
SimpleInDegreeCountComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
void |
PageRankWithKryoSimpleWritable.compute(Vertex<org.apache.hadoop.io.LongWritable,PageRankWithKryoSimpleWritable.VertexValue,PageRankWithKryoSimpleWritable.EdgeValue> vertex,
Iterable<PageRankWithKryoSimpleWritable.MessageValue> messages) |
protected double |
RandomWalkWithRestartComputation.recompute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> transitionProbabilities,
double teleportationProbability) |
protected abstract double |
RandomWalkComputation.recompute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,E> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages,
double teleportationProbability)
Perform a single step of a random walk computation.
|
protected double |
PageRankComputation.recompute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.NullWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> partialRanks,
double teleportationProbability) |
protected double |
RandomWalkWithRestartComputation.transitionProbability(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex,
double stateProbability,
Edge<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable> edge) |
protected abstract double |
RandomWalkComputation.transitionProbability(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,E> vertex,
double stateProbability,
Edge<org.apache.hadoop.io.LongWritable,E> edge)
Compute the probability of transitioning to a neighbor vertex
|
protected double |
PageRankComputation.transitionProbability(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.NullWritable> vertex,
double stateProbability,
Edge<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.NullWritable> edge) |
void |
VertexWithDoubleValueDoubleEdgeTextOutputFormat.VertexWithDoubleValueWriter.writeVertex(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> vertex) |
void |
SimplePageRankComputation.SimplePageRankVertexOutputFormat.SimplePageRankVertexWriter.writeVertex(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex) |
void |
VertexWithDoubleValueNullEdgeTextOutputFormat.VertexWithDoubleValueWriter.writeVertex(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.NullWritable> vertex) |
void |
SimpleSuperstepComputation.SimpleSuperstepVertexOutputFormat.SimpleSuperstepVertexWriter.writeVertex(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.IntWritable,org.apache.hadoop.io.FloatWritable> vertex) |
Modifier and Type | Method and Description |
---|---|
void |
SimpleMigrationMasterBlockFactory.SimpleMigrationMasterComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> vertex,
Iterable<org.apache.hadoop.io.DoubleWritable> messages) |
Modifier and Type | Method and Description |
---|---|
void |
SccComputation.compute(Vertex<org.apache.hadoop.io.LongWritable,SccVertexValue,org.apache.hadoop.io.NullWritable> vertex,
Iterable<org.apache.hadoop.io.LongWritable> messages) |
Modifier and Type | Method and Description |
---|---|
T |
FunctionWithVertex.apply(Vertex<I,V,E> vertex,
F input)
Returns the result of applying this function to given
vertex and input . |
void |
ConsumerWithVertex.apply(Vertex<I,V,E> vertex,
T value)
Applies this function to
vertex and input |
T |
SupplierFromVertex.get(Vertex<I,V,E> vertex)
Retrieves an instance of the appropriate type, given a vertex.
|
Modifier and Type | Class and Description |
---|---|
class |
ByteValueVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Special version of vertex that holds the value in raw byte form to save
memory.
|
class |
DefaultVertex<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Class which holds vertex id, data and edges.
|
class |
OnlyIdVertex<I extends org.apache.hadoop.io.WritableComparable>
Vertex which only contains ID.
|
Modifier and Type | Method and Description |
---|---|
protected Vertex<I,V,E> |
DefaultVertexResolver.addVertexIfDesired(I vertexId,
Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges,
boolean hasMessages)
Add the Vertex if desired.
|
protected Vertex<I,V,E> |
DefaultVertexResolver.removeVertexIfDesired(Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges)
Remove the vertex itself if the changes desire it.
|
Vertex<I,V,E> |
DefaultVertexResolver.resolve(I vertexId,
Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges,
boolean hasMessages) |
Vertex<I,V,E> |
VertexResolver.resolve(I vertexId,
Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges,
boolean hasMessages)
A vertex may have been removed, created zero or more times and had
zero or more messages sent to it.
|
Modifier and Type | Method and Description |
---|---|
List<Vertex<I,V,E>> |
VertexMutations.getAddedVertexList() |
List<Vertex<I,V,E>> |
VertexChanges.getAddedVertexList()
Get the added vertices for this particular vertex index from the previous
superstep.
|
Modifier and Type | Method and Description |
---|---|
protected void |
DefaultVertexResolver.addEdges(Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges)
Add edges to the Vertex.
|
void |
VertexMutations.addVertex(Vertex<I,V,E> vertex)
Add a vertex mutation
|
protected Vertex<I,V,E> |
DefaultVertexResolver.addVertexIfDesired(I vertexId,
Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges,
boolean hasMessages)
Add the Vertex if desired.
|
abstract void |
AbstractComputation.compute(Vertex<I,V,E> vertex,
Iterable<M1> messages)
Must be defined by user to do computation on a single Vertex.
|
void |
Computation.compute(Vertex<I,V,E> vertex,
Iterable<M1> messages)
Must be defined by user to do computation on a single Vertex.
|
<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
GiraphTransferRegulator.incrementCounters(PartitionOwner partitionOwner,
Vertex<I,V,E> vertex)
Increment V & E counts for new vertex read, store values
for that outgoing _temporary_ Partition, which shares the
Partition ID for the actual remote Partition the collection
will eventually be processed in.
|
protected void |
DefaultVertexResolver.removeEdges(Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges)
Remove edges as specifed in changes given.
|
protected Vertex<I,V,E> |
DefaultVertexResolver.removeVertexIfDesired(Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges)
Remove the vertex itself if the changes desire it.
|
Vertex<I,V,E> |
DefaultVertexResolver.resolve(I vertexId,
Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges,
boolean hasMessages) |
Vertex<I,V,E> |
VertexResolver.resolve(I vertexId,
Vertex<I,V,E> vertex,
VertexChanges<I,V,E> vertexChanges,
boolean hasMessages)
A vertex may have been removed, created zero or more times and had
zero or more messages sent to it.
|
void |
AbstractComputation.sendMessageToAllEdges(Vertex<I,V,E> vertex,
M2 message)
Send a message to all edges.
|
void |
Computation.sendMessageToAllEdges(Vertex<I,V,E> vertex,
M2 message)
Send a message to all edges.
|
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,org.apache.hadoop.io.Writable> |
VertexValueReader.getCurrentVertex() |
abstract Vertex<I,V,E> |
VertexReader.getCurrentVertex()
Get the current vertex.
|
Modifier and Type | Method and Description |
---|---|
void |
SimpleVertexWriter.writeVertex(Vertex<I,V,E> vertex)
Writes the next vertex and associated data
|
Modifier and Type | Method and Description |
---|---|
boolean |
DefaultVertexInputFilter.dropVertex(Vertex<I,V,E> vertex) |
boolean |
VertexInputFilter.dropVertex(Vertex<I,V,E> vertex)
Whether to drop a vertex on input.
|
Modifier and Type | Class and Description |
---|---|
class |
SequenceFileVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,X extends Vertex<I,V,E>>
Sequence file vertex input format based on
SequenceFileInputFormat . |
static class |
SequenceFileVertexInputFormat.SequenceFileVertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,X extends Vertex<I,V,E>>
Vertex reader used with
SequenceFileVertexInputFormat . |
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
SequenceFileVertexInputFormat.SequenceFileVertexReader.getCurrentVertex() |
Vertex<I,V,E> |
TextVertexInputFormat.TextVertexReaderFromEachLine.getCurrentVertex() |
Vertex<I,V,E> |
TextVertexInputFormat.TextVertexReaderFromEachLineProcessed.getCurrentVertex() |
Vertex<I,V,E> |
TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions.getCurrentVertex() |
protected Vertex<I,V,E> |
TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions.handleException(org.apache.hadoop.io.Text line,
T processed,
X e)
Handles exceptions while reading vertex from each line.
|
Modifier and Type | Method and Description |
---|---|
protected org.apache.hadoop.io.Text |
JsonBase64VertexOutputFormat.JsonBase64VertexWriter.convertVertexToLine(Vertex<I,V,E> vertex) |
org.apache.hadoop.io.Text |
AdjacencyListTextVertexOutputFormat.AdjacencyListTextVertexWriter.convertVertexToLine(Vertex<I,V,E> vertex) |
protected abstract org.apache.hadoop.io.Text |
TextVertexOutputFormat.TextVertexWriterToEachLine.convertVertexToLine(Vertex<I,V,E> vertex)
Writes a line for the given vertex.
|
protected org.apache.hadoop.io.Text |
IdWithValueTextOutputFormat.IdWithValueVertexWriter.convertVertexToLine(Vertex<I,V,E> vertex) |
void |
TextVertexOutputFormat.TextVertexWriterToEachLine.writeVertex(Vertex vertex) |
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
WrappedVertexReader.getCurrentVertex() |
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
VertexReaderWrapper.getCurrentVertex() |
Constructor and Description |
---|
VertexReaderWrapper(GiraphReader<Vertex<I,V,E>> vertexReader)
Constructor
|
Modifier and Type | Method and Description |
---|---|
void |
JythonGiraphComputation.compute(Vertex<I,V,E> vertex,
Iterable<M1> messages) |
void |
JythonComputation.sendMessageToAllEdges(Vertex vertex,
Object message)
Send a message to all edges.
|
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
ByteArrayPartition.getVertex(I vertexIndex) |
Vertex<I,V,E> |
SimplePartition.getVertex(I vertexIndex) |
Vertex<I,V,E> |
Partition.getVertex(I vertexIndex)
Get the vertex for this vertex index.
|
Vertex<I,V,E> |
ByteArrayPartition.putVertex(Vertex<I,V,E> vertex) |
Vertex<I,V,E> |
SimplePartition.putVertex(Vertex<I,V,E> vertex) |
Vertex<I,V,E> |
Partition.putVertex(Vertex<I,V,E> vertex)
Put a vertex into the Partition
|
Vertex<I,V,E> |
ByteArrayPartition.removeVertex(I vertexIndex) |
Vertex<I,V,E> |
SimplePartition.removeVertex(I vertexIndex) |
Vertex<I,V,E> |
Partition.removeVertex(I vertexIndex)
Remove a vertex from the Partition
|
Modifier and Type | Method and Description |
---|---|
Iterator<Vertex<I,V,E>> |
ByteArrayPartition.iterator() |
Iterator<Vertex<I,V,E>> |
SimplePartition.iterator() |
Modifier and Type | Method and Description |
---|---|
boolean |
ByteArrayPartition.putOrCombine(Vertex<I,V,E> vertex) |
boolean |
SimplePartition.putOrCombine(Vertex<I,V,E> vertex) |
boolean |
Partition.putOrCombine(Vertex<I,V,E> vertex)
Put this vertex or combine it
|
Vertex<I,V,E> |
ByteArrayPartition.putVertex(Vertex<I,V,E> vertex) |
Vertex<I,V,E> |
SimplePartition.putVertex(Vertex<I,V,E> vertex) |
Vertex<I,V,E> |
Partition.putVertex(Vertex<I,V,E> vertex)
Put a vertex into the Partition
|
void |
ByteArrayPartition.saveVertex(Vertex<I,V,E> vertex) |
void |
SimplePartition.saveVertex(Vertex<I,V,E> vertex) |
void |
Partition.saveVertex(Vertex<I,V,E> vertex)
Save potentially modified vertex back to the partition.
|
Modifier and Type | Field and Description |
---|---|
protected Basic2ObjectMap<I,Vertex<I,V,E>> |
TestGraph.vertices
The vertex values
|
Modifier and Type | Method and Description |
---|---|
Vertex<I,V,E> |
VertexIterator.getVertex() |
Vertex<I,V,E> |
TestGraph.getVertex(I id)
Return a given vertex
|
protected Vertex<I,V,E> |
TestGraph.makeVertex(I id,
V value,
Map.Entry<I,E>... edges)
Create a vertex
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.readVertexFromDataInput(DataInput input,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Reads data from input stream to initialize Vertex.
|
Vertex<I,V,E> |
VertexIterator.releaseVertex()
Release the ownership of the Vertex object to the caller
|
Modifier and Type | Method and Description |
---|---|
Collection<Vertex<I,V,E>> |
TestGraph.getVertices() |
Iterator<Vertex<I,V,E>> |
TestGraph.iterator()
An iterator over the vertices
|
Modifier and Type | Method and Description |
---|---|
TestGraph<I,V,E> |
TestGraph.addVertex(Vertex<I,V,E> vertex)
Add vertex
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.reinitializeVertexFromByteArray(byte[] byteArray,
Vertex<I,V,E> vertex,
boolean unsafe,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Read vertex data from byteArray to a Writeable object, skipping the size.
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.reinitializeVertexFromDataInput(DataInput input,
Vertex<I,V,E> vertex,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Reads data from input stream to initialize Vertex.
|
TestGraph<I,V,E> |
TestGraph.setVertex(Vertex<I,V,E> vertex)
Set vertex, replace if there was already a vertex with same id added
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.writeVertexToByteArray(Vertex<I,V,E> vertex,
boolean unsafe,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Write vertex data to byte array with the first 4 bytes as the size of the
entire buffer (including the size).
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.writeVertexToByteArray(Vertex<I,V,E> vertex,
byte[] buffer,
boolean unsafe,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Write vertex data to byte array with the first 4 bytes as the size of the
entire buffer (including the size).
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.writeVertexToDataOutput(DataOutput output,
Vertex<I,V,E> vertex,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Writes Vertex data to output stream.
|
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.