Package | Description |
---|---|
org.apache.giraph.aggregators |
Package of Giraph aggregators.
|
org.apache.giraph.benchmark |
Package of benchmarks for performance testing and optimization
|
org.apache.giraph.comm.requests |
Package for requests.
|
org.apache.giraph.conf |
Package of Giraph configuration related things.
|
org.apache.giraph.edge |
Package of Vertex implementations.
|
org.apache.giraph.edge.primitives |
Package of edge stores specialized for certain type of vertex ids.
|
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.formats.multi |
Package for Input formats which wrap several input formats and allow
reading data from multiple sources.
|
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.job |
Package of all the classes involved in job launch.
|
org.apache.giraph.jython |
Jython integration.
|
org.apache.giraph.mapping |
Package contains definition and implementations of MappingStore and
related concepts
|
org.apache.giraph.mapping.translate |
Definitions & sample implementations of edge translation logic
|
org.apache.giraph.master |
Package of all the master related things.
|
org.apache.giraph.partition |
Package of partitioning related objects.
|
org.apache.giraph.utils |
Package of all generic utility classes.
|
org.apache.giraph.worker |
Package of all the worker related things
|
org.apache.giraph.zk |
Package of
ZooKeeper related objects. |
Modifier and Type | Interface and Description |
---|---|
interface |
AggregatorWriter
An AggregatorWriter is used to export Aggregators during or at the end of
each computation.
|
Modifier and Type | Class and Description |
---|---|
class |
TextAggregatorWriter
Default implementation of
AggregatorWriter . |
Modifier and Type | Class and Description |
---|---|
static class |
AggregatorsBenchmark.AggregatorsBenchmarkComputation
Vertex class for AggregatorsBenchmark
|
static class |
AggregatorsBenchmark.AggregatorsBenchmarkMasterCompute
MasterCompute class for AggregatorsBenchmark
|
static class |
AggregatorsBenchmark.AggregatorsBenchmarkWorkerContext
WorkerContext class for AggregatorsBenchmark
|
class |
PageRankComputation
Implementation of PageRank in which vertex ids are ints, page rank values
are floats, and graph is unweighted.
|
static class |
RandomMessageBenchmark.RandomMessageBenchmarkMasterCompute
Master compute associated with
RandomMessageBenchmark . |
static class |
RandomMessageBenchmark.RandomMessageBenchmarkWorkerContext
WorkerContext forRandomMessageBenchmark. |
static class |
RandomMessageBenchmark.RandomMessageComputation
Actual message computation (messaging in this case)
|
static class |
ReducersBenchmark.ReducersBenchmarkComputation
Vertex class for ReducersBenchmark
|
static class |
ReducersBenchmark.ReducersBenchmarkMasterCompute
MasterCompute class for ReducersBenchmark
|
static class |
ReducersBenchmark.ReducersBenchmarkWorkerContext
WorkerContext class for ReducersBenchmark
|
class |
ShortestPathsComputation
Shortest paths algorithm.
|
class |
WeightedPageRankComputation
Implementation of Page Rank algorithm on a weighted graph.
|
Modifier and Type | Class and Description |
---|---|
class |
AddressesAndPartitionsRequest
Request for master sending addresses and partitions to workers
|
class |
AskForInputSplitRequest
A request which workers will send to master to ask it to give them splits
|
class |
ByteArrayRequest
Abstract request which has a byte array as its data
|
class |
ByteArrayWithSenderTaskIdRequest
Abstract request which has a byte array and task id of the sender as its
data
|
class |
PartitionStatsRequest
Request for sending partition stats from workers to master
|
class |
ReplyWithInputSplitRequest
A request which master will send to workers to give them splits
|
class |
SaslCompleteRequest
Reply from server to client after SASL authentication completes.
|
class |
SaslTokenMessageRequest
Send and receive SASL tokens.
|
class |
SendAggregatorsToOwnerRequest
Request to send final aggregatd values from master to worker which owns
the aggregators
|
class |
SendAggregatorsToWorkerRequest
Request to send final aggregated values from worker which owns them to
other workers
|
class |
SendPartitionCurrentMessagesRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable>
Send a collection of vertex messages for a partition.
|
class |
SendPartitionMutationsRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Send a collection of vertex mutations for a partition.
|
class |
SendReducedToMasterRequest
Request to send final aggregated values from worker which owns
aggregators to the master
|
class |
SendResumeRequest
Send to a worker a signal to resume sending messages to sender worker.
|
class |
SendVertexRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Send a collection of vertices for a partition.
|
class |
SendWorkerAggregatorsRequest
Request to send partial aggregated values for current superstep (values
which were computed by one worker's vertices)
|
class |
SendWorkerDataRequest<I extends org.apache.hadoop.io.WritableComparable,T,B extends VertexIdData<I,T>>
Abstract request to send a collection of data, indexed by vertex id,
for a partition.
|
class |
SendWorkerEdgesRequest<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Send a collection of edges for a partition.
|
class |
SendWorkerMessagesRequest<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable>
Send a collection of vertex messages for a partition.
|
class |
SendWorkerOneMessageToManyRequest<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable>
Send a collection of ByteArrayOneMessageToManyIds messages to a worker.
|
class |
SendWorkerToWorkerMessageRequest
Request which sends any Writable message from one worker to another
|
class |
SendWorkerVerticesRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Send to a worker one or more partitions of vertices
|
class |
WritableRequest<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Interface for requests to implement
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultImmutableClassesGiraphConfigurable<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Default implementation of ImmutableClassesGiraphConfigurable
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractEdgeStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,K,Et>
Basic implementation of edges store, extended this to easily define simple
and primitive edge stores
|
class |
ArrayListEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
|
class |
ByteArrayEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
OutEdges implementation backed by a byte array. |
class |
ConfigurableOutEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Common base class for
OutEdges implementations that require a
configuration. |
class |
HashMapEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
|
class |
HashMultimapEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
OutEdges implementation backed by an ArrayListMultimap . |
class |
IdAndNullArrayEdges<I extends org.apache.hadoop.io.WritableComparable>
Implementation of
OutEdges with IDs and null edge values having
their TypeOps. |
class |
IdAndValueArrayEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Implementation of
OutEdges with IDs and Edge values having their
TypeOps. |
class |
LongDiffNullArrayEdges
Implementation of
OutEdges with long ids
and null edge values, backed by a dynamic primitive array. |
class |
SimpleEdgeStore<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Simple in memory edge store which supports any type of ids.
|
Modifier and Type | Class and Description |
---|---|
class |
IntEdgeStore<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Special edge store to be used when ids are IntWritable.
|
class |
LongEdgeStore<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Special edge store to be used when ids are LongWritable.
|
Modifier and Type | Interface and Description |
---|---|
interface |
Computation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M1 extends org.apache.hadoop.io.Writable,M2 extends org.apache.hadoop.io.Writable>
Interface for an application for computation.
|
interface |
Vertex<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.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M1 extends org.apache.hadoop.io.Writable,M2 extends org.apache.hadoop.io.Writable>
See
Computation for explanation of the interface. |
class |
BasicComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable>
Computation in which both incoming and outgoing message types are the same.
|
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 |
DefaultVertexResolver<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Default implementation of how to resolve vertex creation/removal, messages
to nonexistent vertices, etc.
|
class |
OnlyIdVertex<I extends org.apache.hadoop.io.WritableComparable>
Vertex which only contains ID.
|
class |
VertexMutations<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Structure to hold all the possible graph mutations that can occur during a
superstep.
|
Modifier and Type | Class and Description |
---|---|
class |
BasicVertexValueReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable>
Abstract base class for VertexValueReader.
|
class |
EdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Input format for reading single edges.
|
class |
EdgeOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
abstract class which can only write edges
|
class |
EdgeReader<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Analogous to org.apache.giraph.bsp.BspRecordReader for edges.
|
class |
EdgeWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
class |
GiraphInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Common interface for
VertexInputFormat and EdgeInputFormat . |
class |
MappingInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
Use this to load data for a BSP application.
|
class |
MappingReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
Will read the mapping from an input split.
|
class |
OutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Parent class for vertex and edge output formats
|
class |
ReverseEdgeDuplicator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
An EdgeReader that creates the opposite direction edge for each edge read.
|
class |
VertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Use this to load data for a BSP application.
|
class |
VertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Implement to output the graph after the computation.
|
class |
VertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Analogous to Hadoop's RecordReader for vertices.
|
class |
VertexValueInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable>
Vertex input format that only allows setting vertex id and value.
|
class |
VertexValueReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable>
Vertex reader for
VertexValueInputFormat . |
class |
VertexWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Implement to output a vertex range of the graph after the computation
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultEdgeInputFilter<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Default edge filter that lets in all edges.
|
class |
DefaultVertexInputFilter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M extends org.apache.hadoop.io.Writable>
Default vertex filter that lets in all vertices.
|
Modifier and Type | Class and Description |
---|---|
class |
AdjacencyListTextVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
VertexReader that readers lines of text with vertices encoded as adjacency
lists and converts each token to the correct type.
|
protected class |
AdjacencyListTextVertexInputFormat.AdjacencyListTextVertexReader
Vertex reader associated with
AdjacencyListTextVertexInputFormat . |
class |
AdjacencyListTextVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
OutputFormat to write out the graph nodes as text, value-separated (by
tabs, by default).
|
protected class |
AdjacencyListTextVertexOutputFormat.AdjacencyListTextVertexWriter
Vertex writer associated with
AdjacencyListTextVertexOutputFormat . |
class |
GeneratedVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
This VertexInputFormat is meant for testing/debugging.
|
class |
GraphvizOutputFormat
Writes graph to a dot file (graphviz format).
|
class |
IdWithValueTextOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Write out Vertices' IDs and values, but not their edges nor edges' values.
|
protected class |
IdWithValueTextOutputFormat.IdWithValueVertexWriter
Vertex writer used with
IdWithValueTextOutputFormat . |
class |
InMemoryVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
VertexOutputFormat which stores all vertices in memory
|
class |
IntIntNullTextInputFormat
Simple text-based
VertexInputFormat for
unweighted graphs with int ids. |
class |
IntIntNullTextInputFormat.IntIntNullVertexReader
Vertex reader associated with
IntIntNullTextInputFormat . |
class |
IntIntNullTextVertexInputFormat
Simple text-based
VertexInputFormat for
unweighted graphs with int ids. |
class |
IntIntNullTextVertexInputFormat.IntIntNullVertexReader
Vertex reader associated with
IntIntNullTextVertexInputFormat . |
class |
IntIntTextVertexValueInputFormat<E extends org.apache.hadoop.io.Writable>
Simple text-based
VertexValueInputFormat
for integer ids and values. |
class |
IntIntTextVertexValueInputFormat.IntIntTextVertexValueReader
VertexValueReader associated with
IntIntTextVertexValueInputFormat . |
class |
IntNullNullTextInputFormat
Simple text-based
VertexInputFormat for
unweighted graphs without edges or values, just vertices with ids. |
class |
IntNullNullTextInputFormat.IntNullNullNullVertexReader
Reader for this InputFormat.
|
class |
IntNullReverseTextEdgeInputFormat
Simple text-based
EdgeInputFormat for
unweighted graphs with int ids. |
class |
IntNullTextEdgeInputFormat
Simple text-based
EdgeInputFormat for
unweighted graphs with int ids. |
class |
IntNullTextEdgeInputFormat.IntNullTextEdgeReader
EdgeReader associated with
IntNullTextEdgeInputFormat . |
class |
JsonBase64VertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Simple way to represent the structure of the graph with a JSON object.
|
protected class |
JsonBase64VertexInputFormat.JsonBase64VertexReader
Simple reader that supports
JsonBase64VertexInputFormat |
class |
JsonBase64VertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Simple way to represent the structure of the graph with a JSON object.
|
protected class |
JsonBase64VertexOutputFormat.JsonBase64VertexWriter
Simple writer that supports
JsonBase64VertexOutputFormat |
class |
JsonLongDoubleFloatDoubleVertexInputFormat
VertexInputFormat that features
long vertex ID's,
double vertex values and float
out-edge weights, and double message types,
specified in JSON format. |
class |
JsonLongDoubleFloatDoubleVertexOutputFormat
VertexOutputFormat that supports JSON encoded vertices featuring
double values and float out-edge weights |
class |
LongDoubleDoubleAdjacencyListVertexInputFormat
InputFormat for reading graphs stored as (ordered) adjacency lists
with the vertex ids longs and the vertex values and edges doubles.
|
protected class |
LongDoubleDoubleAdjacencyListVertexInputFormat.LongDoubleDoubleAdjacencyListVertexReader
VertexReader associated with
LongDoubleDoubleAdjacencyListVertexInputFormat . |
class |
LongLongNullTextInputFormat
Simple text-based
VertexInputFormat for
unweighted graphs with long ids. |
class |
LongLongNullTextInputFormat.LongLongNullVertexReader
Vertex reader associated with
LongLongNullTextInputFormat . |
class |
PseudoRandomEdgeInputFormat
This
EdgeInputFormat generates pseudo-random edges on the fly. |
class |
PseudoRandomIntNullVertexInputFormat
VertexInputFormat for large scale testing,
like
PseudoRandomVertexInputFormat , but for the unweighted graphs
where vertex ids are integers. |
class |
PseudoRandomVertexInputFormat
This VertexInputFormat is meant for large scale testing.
|
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 . |
class |
SequenceFileVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,OK extends org.apache.hadoop.io.Writable,OV extends org.apache.hadoop.io.Writable>
Sequence file vertex output format.
|
class |
SrcIdDstIdEdgeValueTextOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Write out Edge Value with Source and Destination ID, but not the vertex
value.
|
protected class |
SrcIdDstIdEdgeValueTextOutputFormat.SrcIdDstIdEdgeValueEdgeWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Edge writer used with
SrcIdDstIdEdgeValueTextOutputFormat . |
class |
TextDoubleDoubleAdjacencyListVertexInputFormat
Class to read graphs stored as adjacency lists with ids represented by
Strings and values as doubles.
|
protected class |
TextDoubleDoubleAdjacencyListVertexInputFormat.TextDoubleDoubleAdjacencyListVertexReader
Vertex reader used with
TextDoubleDoubleAdjacencyListVertexInputFormat |
class |
TextEdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Abstract class that users should subclass to use their own text based
edge output format.
|
protected class |
TextEdgeInputFormat.TextEdgeReader
|
protected class |
TextEdgeInputFormat.TextEdgeReaderFromEachLine
Abstract class to be implemented by the user to read an edge from each
text line.
|
protected class |
TextEdgeInputFormat.TextEdgeReaderFromEachLineProcessed<T>
Abstract class to be implemented by the user to read an edge from each
text line after preprocessing it.
|
class |
TextEdgeOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Abstract class that users should subclass to use their own text based
edge output format.
|
protected class |
TextEdgeOutputFormat.TextEdgeWriter<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Abstract class to be implemented by the user based on their specific
edge output.
|
protected class |
TextEdgeOutputFormat.TextEdgeWriterToEachLine<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Abstract class to be implemented by the user to write a line for each
edge.
|
class |
TextVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Abstract class that users should subclass to use their own text based
vertex input format.
|
protected class |
TextVertexInputFormat.TextVertexReader
Abstract class to be implemented by the user based on their specific
vertex input.
|
protected class |
TextVertexInputFormat.TextVertexReaderFromEachLine
Abstract class to be implemented by the user to read a vertex from each
text line.
|
protected class |
TextVertexInputFormat.TextVertexReaderFromEachLineProcessed<T>
Abstract class to be implemented by the user to read a vertex from each
text line after preprocessing it.
|
protected class |
TextVertexInputFormat.TextVertexReaderFromEachLineProcessedHandlingExceptions<T,X extends Throwable>
Abstract class to be implemented by the user to read a vertex from each
text line after preprocessing it with exception handling.
|
class |
TextVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Abstract class that users should subclass to use their own text based
vertex output format.
|
protected class |
TextVertexOutputFormat.TextVertexWriter
Abstract class to be implemented by the user based on their specific
vertex output.
|
protected class |
TextVertexOutputFormat.TextVertexWriterToEachLine
Abstract class to be implemented by the user to write a line for each
vertex.
|
class |
TextVertexValueInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Abstract class that users should subclass to use their own text based
vertex value input format.
|
protected class |
TextVertexValueInputFormat.TextVertexValueReader
|
protected class |
TextVertexValueInputFormat.TextVertexValueReaderFromEachLine
Abstract class to be implemented by the user to read a vertex value from
each text line.
|
protected class |
TextVertexValueInputFormat.TextVertexValueReaderFromEachLineProcessed<T>
Abstract class to be implemented by the user to read a vertex value from
each text line after preprocessing it.
|
class |
WattsStrogatzVertexInputFormat
Generates a random Watts-Strogatz graph by re-wiring a ring lattice.
|
Modifier and Type | Class and Description |
---|---|
class |
MultiEdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Edge input format which wraps several edge input formats.
|
class |
MultiMappingInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
Mapping input format which wraps several mapping input formats.
|
class |
MultiVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Vertex input format which wraps several vertex input formats.
|
Modifier and Type | Class and Description |
---|---|
class |
WrappedEdgeInputFormat<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedEdgeOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedEdgeReader<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedMappingInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedMappingReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedVertexOutputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
For internal use only.
|
class |
WrappedVertexReader<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
For internal use only.
|
Modifier and Type | Class and Description |
---|---|
class |
EdgeReaderWrapper<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Wraps
GiraphReader for edges into EdgeReader |
class |
MappingReaderWrapper<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
Wraps
GiraphReader for mapping into
MappingReader |
class |
VertexReaderWrapper<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Wraps
GiraphReader for vertices into VertexReader |
Modifier and Type | Class and Description |
---|---|
class |
DefaultJobObserver
Default implementation of job observer that does nothing.
|
Modifier and Type | Class and Description |
---|---|
class |
JythonComputation
Base class for writing computations in Jython.
|
class |
JythonGiraphComputation<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,M1 extends org.apache.hadoop.io.Writable,M2 extends org.apache.hadoop.io.Writable>
The
Computation class for using
Jython with Giraph. |
Modifier and Type | Interface and Description |
---|---|
interface |
MappingStore<I extends org.apache.hadoop.io.WritableComparable,B extends org.apache.hadoop.io.Writable>
MappingStore used to store the vertexId - target map supplied by user
Methods implemented in this class need to be thread safe
|
Modifier and Type | Class and Description |
---|---|
class |
LongByteMappingStore
An implementation of MappingStore<LongWritable, ByteWritable>
Methods implemented here are thread safe by default because it is guaranteed
that each entry is written to only once.
|
Modifier and Type | Interface and Description |
---|---|
interface |
TranslateEdge<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Used to conduct expensive translation of edges
during vertex input phase
|
Modifier and Type | Class and Description |
---|---|
class |
LongByteTranslateEdge<E extends org.apache.hadoop.io.Writable>
Basic implementation of Translate Edge
where I = LongWritable & B = ByteWritable
|
static class |
LongByteTranslateEdge.DoubleEdgeValue
Correct implementation of cloneValue when edgevalue = doublewritable
|
static class |
LongByteTranslateEdge.FloatEdgeValue
Correct implementation of cloneValue when edgevalue = floatwritable
|
static class |
LongByteTranslateEdge.IntEdgeValue
Correct implementation of cloneValue when edgevalue = intwritable
|
static class |
LongByteTranslateEdge.LongEdgeValue
Correct implementation of cloneValue when edgevalue = longwritable
|
static class |
LongByteTranslateEdge.NoEdgeValue
Correct implementation of cloneValue when edgevalue = nullwritable
|
Modifier and Type | Interface and Description |
---|---|
interface |
MasterObserver
Observer for Master.
|
Modifier and Type | Class and Description |
---|---|
class |
AggregatorBroadcast<A extends org.apache.hadoop.io.Writable>
Writable representation of aggregated value
|
class |
DefaultMasterCompute
A dumb implementation of
MasterCompute . |
class |
DefaultMasterObserver
A no-op implementation of MasterObserver to make it easier for users.
|
class |
MasterCompute
Interface for defining a master vertex that can perform centralized
computation between supersteps.
|
Modifier and Type | Interface and Description |
---|---|
interface |
GraphPartitionerFactoryInterface<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Defines the partitioning framework for this application.
|
interface |
Partition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
A generic container that stores vertices.
|
interface |
ReusesObjectsPartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Empty interface to characterize
Partition implementations that
don't keep references to the Vertex objects they are passed. |
Modifier and Type | Class and Description |
---|---|
class |
BasicPartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Basic partition class for other partitions to extend.
|
class |
BasicPartitionOwner
Basic partition owner, can be subclassed for more complicated partition
owner implementations.
|
class |
ByteArrayPartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Byte array based partition.
|
class |
GraphPartitionerFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Defines the partitioning framework for this application.
|
class |
HashPartitionerFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Divides the vertices into partitions by their hash code using a simple
round-robin hash for great balancing if given a random hash code.
|
class |
HashRangePartitionerFactory<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Divides the vertices into partitions by their hash code using ranges of the
hash space.
|
class |
LongMappingStorePartitionerFactory<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Factory for long-byte mapping based partitioners.
|
class |
SimpleIntRangePartitionerFactory<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Factory for simple range-based partitioners based on integer vertex ids.
|
class |
SimpleLongRangePartitionerFactory<V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Factory for simple range-based partitioners based on long vertex ids.
|
class |
SimplePartition<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
A simple map-based container that stores vertices.
|
Modifier and Type | Interface and Description |
---|---|
interface |
VertexIdData<I extends org.apache.hadoop.io.WritableComparable,T>
Stores vertex ids and data associated with a vertex
|
interface |
VertexIdEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Stores vertex id and out-edges of a vertex
|
interface |
VertexIdMessages<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable>
VertexIdMessages
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractVertexIdData<I extends org.apache.hadoop.io.WritableComparable,T>
Partial implementation of vertexIdData
|
class |
ByteArrayOneMessageToManyIds<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable>
Stores a message and a list of target vertex ids.
|
class |
ByteArrayVertexIdData<I extends org.apache.hadoop.io.WritableComparable,T>
Stores pairs of vertex id and generic data in a single byte array
|
class |
ByteArrayVertexIdEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable>
Stores vertex id and edge pairs in a single byte array.
|
class |
ByteArrayVertexIdMessages<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable>
Stores vertex id and message pairs in a single byte array.
|
class |
InMemoryVertexInputFormat<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
An input format that reads the input graph in memory.
|
class |
JMapHistoDumper
An observer for both worker and master that periodically dumps the memory
usage using jmap tool.
|
class |
LogVersions
Logs versions of Giraph dependencies on job start.
|
class |
ReactiveJMapHistoDumper
An observer for both worker and master that periodically checks if available
memory on heap is below certain threshold, and if found to be the case
dumps jmap -histo for the process
|
Modifier and Type | Interface and Description |
---|---|
interface |
WorkerObserver
Observer for worker.
|
Modifier and Type | Class and Description |
---|---|
class |
DefaultWorkerContext
A dummy implementation of
WorkerContext . |
class |
DefaultWorkerObserver
Default Observer for Worker that does nothing.
|
class |
LocalData<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable>
Stores LocalData for each worker
|
class |
WorkerAggregatorDelegator<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable>
Class for delegating WorkerAggregatorUsage and
WorkerGlobalCommUsage methods to corresponding interface.
|
class |
WorkerContext
WorkerContext allows for the execution of user code
on a per-worker basis.
|
Modifier and Type | Interface and Description |
---|---|
interface |
ZooKeeperRunner
ZooKeeper wrapper interface.
|
Modifier and Type | Class and Description |
---|---|
class |
InProcessZooKeeperRunner
Zookeeper wrapper that starts zookeeper withing master process.
|
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.