Interface | Description |
---|---|
CallableFactory<R> |
Factory for creating
Callable s |
ExtendedDataInput |
Add some functionality to data input
|
ExtendedDataOutput |
Add a few features to data output
|
Factory<T> |
Factory for any kind of objects
|
GcObserver |
Observer for when GCs occur
|
Trimmable | |
VertexIdData<I extends org.apache.hadoop.io.WritableComparable,T> |
Stores vertex ids and data associated with a vertex
|
VertexIdDataIterator<I extends org.apache.hadoop.io.WritableComparable,T> |
Special iterator that reuses vertex ids and data objects so that the
lifetime of the object is only until next() is called.
|
VertexIdEdgeIterator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> |
Special iterator that reuses vertex ids and edge objects so that the
lifetime of the object is only until next() is called.
|
VertexIdEdges<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> |
Stores vertex id and out-edges of a vertex
|
VertexIdIterator<I extends org.apache.hadoop.io.WritableComparable> |
Common implementation for VertexIdEdgeIterator, VertexIdMessageIterator
and VertexIdMessageBytesIterator.
|
VertexIdMessageBytesIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
Special iterator that reuses vertex ids and messages bytes so that the
lifetime of the object is only until next() is called.
|
VertexIdMessageIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
Special iterator that reuses vertex ids and message objects so that the
lifetime of the object is only until next() is called.
|
VertexIdMessages<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
VertexIdMessages
|
Class | Description |
---|---|
AbstractVertexIdData<I extends org.apache.hadoop.io.WritableComparable,T> |
Partial implementation of vertexIdData
|
AdjustableSemaphore |
Implementation of a semaphore where number of available permits can change
|
AnnotationUtils |
Helper class to deal with annotations in runtime.
|
ArrayListWritable<M extends org.apache.hadoop.io.Writable> |
A Writable for ListArray containing instances of a class.
|
ArrayWritable<T extends org.apache.hadoop.io.Writable> |
A Writable for arrays containing instances of a class.
|
BlockingElementsSet<T> |
Keeps a set of elements, and allows for waiting on certain number of
elements to become available.
|
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.
|
ByteArrayVertexIdData<I extends org.apache.hadoop.io.WritableComparable,T> |
Stores pairs of vertex id and generic data in a single byte array
|
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.
|
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.
|
ByteStructIterable<T extends org.apache.hadoop.io.Writable> |
This iterable is designed to deserialize a byte array on the fly to
provide new copies of writable objects when desired.
|
ByteStructIterator<T extends org.apache.hadoop.io.Writable> |
This iterator is designed to deserialize a byte array on the fly to
provide new copies of writable objects when desired.
|
ByteStructVertexIdDataIterator<I extends org.apache.hadoop.io.WritableComparable,T> |
Special iterator that reuses vertex ids and data objects so that the
lifetime of the object is only until next() is called.
|
ByteStructVertexIdEdgeIterator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> |
Special iterator that reuses vertex ids and edge objects so that the
lifetime of the object is only until next() is called.
|
ByteStructVertexIdIterator<I extends org.apache.hadoop.io.WritableComparable> |
Common implementation for VertexIdEdgeIterator, VertexIdMessageIterator
and VertexIdMessageBytesIterator.
|
ByteStructVertexIdMessageBytesIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
Special iterator that reuses vertex ids and messages bytes so that the
lifetime of the object is only until next() is called.
|
ByteStructVertexIdMessageIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
Special iterator that reuses vertex ids and message objects so that the
lifetime of the object is only until next() is called.
|
ByteUtils |
Utilities class for byte operations and constants
|
CheckpointingUtils |
Holds useful functions to get checkpoint paths
in hdfs.
|
CollectionUtils |
Helper methods for Collections
|
ConfigurationObjectUtils |
Utility methods for dealing with Hadoop configuration
|
ConfigurationUtils |
Translate command line args into Configuration Key-Value pairs.
|
CounterUtils |
Utility methods for dealing with counters
|
DefaultOutputCommitter |
Output committer which has abstract commit method
|
DistributedCacheUtils |
Helpers for dealing with
DistributedCache |
DynamicChannelBufferInputStream |
Special input that reads from a DynamicChannelBuffer.
|
DynamicChannelBufferOutputStream |
Special output stream that can grow as needed and dumps to a
DynamicChannelBuffer.
|
EdgeComparator<I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.WritableComparable> |
Comparator for edges.
|
EdgeIterables |
Utility methods for iterables of edges.
|
EmptyIterable<T> |
Singleton class for empty iterables.
|
ExtendedByteArrayDataInput |
Provides access to a internals of ByteArrayInputStream
|
ExtendedByteArrayDataOutput |
Adds some functionality to ByteArrayOutputStream,
such as an option to write int value over previously written data
and directly get the byte array.
|
ExtendedByteArrayOutputBuffer |
Wraps a list of byte array outputs and provides convenient
utilities on top of it
|
ExtendedByteArrayOutputBuffer.IndexAndDataOut |
Holder for index & DataOutput objects
|
FileUtils |
Helper class for filesystem operations during testing
|
GcTracker |
Tracks last k GC pauses and is able to tell how much time was spent doing
GC since some point in time.
|
GiraphDepVersions |
Versions of Giraph dependencies.
|
IncreasingBitSet |
Bit set optimized for increasing longs to save storage space.
|
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.
|
InternalVertexRunner |
A base class for running internal tests on a vertex
Extending classes only have to invoke the run() method to test their vertex.
|
IntPair |
A pair of integers.
|
JMap |
Helper to run jmap and print the output
|
JMapHistoDumper |
An observer for both worker and master that periodically dumps the memory
usage using jmap tool.
|
LoggerUtils |
Logger utils for log4j
|
LogStacktraceCallable<V> |
A wrapper to improve debugging.
|
LogVersions |
Logs versions of Giraph dependencies on job start.
|
MasterLoggingAggregator |
Helper class for using aggregator which gathers log messages from workers
and prints them on master.
|
MathUtils |
A helper class for math related operations with writables
|
MemoryUtils |
Helper static methods for tracking memory usage.
|
OneMessageToManyIdsIterator<I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
VertexIdData iterator for
ByteArrayOneMessageToManyIds |
PairList<U,V> |
Collection to keep pairs in, without creating a wrapper object around
each pair of objects.
|
PipelineUtils |
Utility class for ChannelPipeline
|
ProgressableUtils |
Functions for waiting on some events to happen while reporting progress
|
ProgressCounter |
Used to keep track of a metric.
|
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
|
ReflectionUtils |
Helper methods to get type arguments to generic classes.
|
RepresentativeByteStructIterable<T extends org.apache.hadoop.io.Writable> |
The objects provided by the iterators generated from this object have
lifetimes only until next() is called.
|
RepresentativeByteStructIterator<T extends org.apache.hadoop.io.Writable> |
The objects provided by this iterator have lifetimes only until next() is
called.
|
RequestUtils |
RequestUtils utility class
|
TaskIdsPermitsBarrier |
This barrier is used when we don't know how many events are we waiting on
from the start.
|
TestGraph<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
TestGraph class for in-memory testing.
|
ThreadLocalProgressCounter |
Makes a list of
ProgressCounter accessible through
a ThreadLocal . |
ThreadUtils |
Utility class for thread related functions.
|
TimedLogger |
Print log messages only if the time is met.
|
UnsafeArrayReads |
Byte array input stream that uses Unsafe methods to deserialize
much faster
|
UnsafeByteArrayInputStream |
UnsafeByteArrayInputStream
This stream now extends com.esotericsoftware.kryo.io.Input so that kryo
serialization can directly read from this stream without using an
additional buffer, providing a faster serialization.
|
UnsafeByteArrayOutputStream |
Byte array output stream that uses Unsafe methods to serialize/deserialize
much faster.
|
UnsafeReads |
Byte array input stream that uses Unsafe methods to deserialize
much faster
|
UnsafeReusableByteArrayInput |
UnsafeReusableByteArrayInput is a data structure to read from a
byte buffer with a read pointer that can be moved to desired location
|
Varint |
Encodes signed and unsigned values using a common variable-length scheme,
found for example in
Google's Protocol Buffers.
|
VerboseByteStructMessageWrite |
Verbose Error mesage for ByteArray based messages
|
VertexIterator<I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
Iterates over vertices stored in an ExtendedDataOutput such that
the ownership of the vertex id can be transferred to another object.
|
WritableUtils |
Helper static methods for working with Writable objects.
|
YourKitContext |
Convenience context for profiling.
|
YourKitProfiler |
Helper for YourKit profiling from within the code.
|
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.