| Name | Description | Type | Package | Framework |
| AbstractComputation | See Computation for explanation of the interface. | Class | org.apache.giraph.graph | Giraph |
|
| AbstractConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| AbstractEdgeStore | Basic implementation of edges store, extended this to easily define simple and primitive edge stores | Class | org.apache.giraph.edge | Giraph |
|
| AbstractHiveToEdge | | Class | org.apache.giraph.hive.input.edge | Giraph |
|
| AbstractHiveToMapping | | Class | org.apache.giraph.hive.input.mapping | Giraph |
|
| AbstractHiveToVertex | | Class | org.apache.giraph.hive.input.vertex | Giraph |
|
| AbstractListPerVertexStore | Abstract Implementation of SimpleMessageStore where multiple messages are stored per vertex as a list | Class | org.apache.giraph.comm.messages | Giraph |
|
| AbstractLongByteOps | | Class | org.apache.giraph.mapping | Giraph |
|
| AbstractMessageValueFactory | Factory class to create default message values. | Class | org.apache.giraph.factories | Giraph |
|
| AbstractVertexIdData | | Class | org.apache.giraph.utils | Giraph |
|
| AbstractVertexToHive | | Class | org.apache.giraph.hive.output | Giraph |
|
| AccumuloVertexInputFormat | Class which wraps the AccumuloInputFormat. | Class | org.apache.giraph.io.accumulo | Giraph |
|
| AccumuloVertexInputFormat .AccumuloVertexReader | Abstract class which provides a template for instantiating vertices from Accumulo Key/Value pairs. | Class | org.apache.giraph.io.accumulo.AccumuloVertexInputFormat | Giraph |
|
| AccumuloVertexOutputFormat | Class which wraps the AccumuloOutputFormat. | Class | org.apache.giraph.io.accumulo | Giraph |
|
| AccumuloVertexOutputFormat .AccumuloVertexWriter | Main abstraction point for vertex writers to persist back to Accumulo tables. | Class | org.apache.giraph.io.accumulo.AccumuloVertexOutputFormat | Giraph |
|
| AddressesAndPartitionsWritable | | Class | org.apache.giraph.graph | Giraph |
|
| AddressRequestIdGenerator | Generate different request ids based on the address of the well known port on the workers. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| AdjacencyListTextVertexInputFormat | VertexReader that readers lines of text with vertices encoded as adjacency lists and converts each token to the correct type. | Class | org.apache.giraph.io.formats | Giraph |
|
| AdjacencyListTextVertexInputFormat .LineSanitizer | Utility for doing any cleaning of each line before it is tokenized. | Interface | org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat | Giraph |
|
| AdjacencyListTextVertexOutputFormat | OutputFormat to write out the graph nodes as text, value-separated (by tabs, by default). | Class | org.apache.giraph.io.formats | Giraph |
|
| AggregatedMetric | An aggregator over metrics from multiple hosts. | Class | org.apache.giraph.metrics | Giraph |
|
| AggregatedMetrics | | Class | org.apache.giraph.metrics | Giraph |
|
| Aggregator | Interface for Aggregator. | Interface | org.apache.giraph.aggregators | Giraph |
|
| AggregatorBroadcast | | Class | org.apache.giraph.master | Giraph |
|
| AggregatorReduceOperation | Translates aggregation operation to reduce operations. | Class | org.apache.giraph.master | Giraph |
|
| AggregatorsBenchmark | Benchmark for aggregators. | Class | org.apache.giraph.benchmark | Giraph |
|
| AggregatorsBenchmark .AggregatorsBenchmarkComputation | | Class | org.apache.giraph.benchmark.AggregatorsBenchmark | Giraph |
|
| AggregatorsBenchmark .AggregatorsBenchmarkMasterCompute | | Class | org.apache.giraph.benchmark.AggregatorsBenchmark | Giraph |
|
| AggregatorsBenchmark .AggregatorsBenchmarkWorkerContext | | Class | org.apache.giraph.benchmark.AggregatorsBenchmark | Giraph |
|
| AggregatorsTestComputation | Computation which uses aggrergators. | Class | org.apache.giraph.examples | Giraph |
|
| AggregatorsTestComputation .AggregatorsTestMasterCompute | Master compute which uses aggregators. | Class | org.apache.giraph.examples.AggregatorsTestComputation | Giraph |
|
| AggregatorsTestComputation .SimpleEdgeInputFormat | | Class | org.apache.giraph.examples.AggregatorsTestComputation | Giraph |
|
| AggregatorsTestComputation .SimpleEdgeReader | | Class | org.apache.giraph.examples.AggregatorsTestComputation | Giraph |
|
| AggregatorsTestComputation .SimpleVertexInputFormat | | Class | org.apache.giraph.examples.AggregatorsTestComputation | Giraph |
|
| AggregatorsTestComputation .SimpleVertexReader | | Class | org.apache.giraph.examples.AggregatorsTestComputation | Giraph |
|
| AggregatorToGlobalCommTranslation | Class that translates aggregator handling on the master to reduce and broadcast operations supported by the MasterAggregatorHandler. | Class | org.apache.giraph.master | Giraph |
|
| AggregatorUsage | Master and workers can access aggregators through this interface. | Interface | org.apache.giraph.aggregators | Giraph |
|
| AggregatorUtils | | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| AggregatorWriter | An AggregatorWriter is used to export Aggregators during or at the end of each computation. | Interface | org.apache.giraph.aggregators | Giraph |
|
| Algorithm | This annotation should be used to annotate built-in algorithms. | Class | org.apache.giraph | Giraph |
|
| Algorithm | This annotation should be used to annotate built-in algorithms. | Class | org.apache.giraph.examples | Giraph |
|
| AllAggregatorServerData | Accepts aggregators and their values from previous superstep from master and workers which own aggregators. | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| AllOptions | | Class | org.apache.giraph.conf | Giraph |
|
| AnnotationUtils | Helper class to deal with annotations in runtime. | Class | org.apache.giraph.utils | Giraph |
|
| ApplicationState | enum ApplicationStateState of the BSP application | Class | org.apache.giraph.bsp | Giraph |
|
| ArrayListEdges | OutEdges implementation backed by an ArrayList. | Class | org.apache.giraph.edge | Giraph |
|
| ArrayListWritable | A Writable for ListArray containing instances of a class. | Class | org.apache.giraph.utils | Giraph |
|
| ArrayWritable | A Writable for arrays containing instances of a class. | Class | org.apache.giraph.utils | Giraph |
|
| AsyncMessageStoreWrapper | This class decouples message receiving and processing into separate threads thus reducing contention. | Class | org.apache.giraph.comm.messages.queue | Giraph |
|
| AuthorizeServerHandler | Authorize or deny client requests based on existence and completeness of client's SASL authentication. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| Basic2ObjectMap | Basic2ObjectMap with only basic set of operations. | Class | org.apache.giraph.types.ops.collections | Giraph |
|
| Basic2ObjectMap .BasicInt2ObjectOpenHashMap | | Class | org.apache.giraph.types.ops.collections.Basic2ObjectMap | Giraph |
|
| Basic2ObjectMap .BasicLong2ObjectOpenHashMap | | Class | org.apache.giraph.types.ops.collections.Basic2ObjectMap | Giraph |
|
| BasicAggregator | Abstract class for Aggregator. | Class | org.apache.giraph.aggregators | Giraph |
|
| BasicArrayList | BasicArrayList with only basic set of operations. | Class | org.apache.giraph.types.ops.collections | Giraph |
|
| BasicArrayList .BasicBooleanArrayList | | Class | org.apache.giraph.types.ops.collections.BasicArrayList | Giraph |
|
| BasicArrayList .BasicByteArrayList | | Class | org.apache.giraph.types.ops.collections.BasicArrayList | Giraph |
|
| BasicArrayList .BasicDoubleArrayList | | Class | org.apache.giraph.types.ops.collections.BasicArrayList | Giraph |
|
| BasicArrayList .BasicFloatArrayList | | Class | org.apache.giraph.types.ops.collections.BasicArrayList | Giraph |
|
| BasicArrayList .BasicIntArrayList | | Class | org.apache.giraph.types.ops.collections.BasicArrayList | Giraph |
|
| BasicArrayList .BasicLongArrayList | | Class | org.apache.giraph.types.ops.collections.BasicArrayList | Giraph |
|
| BasicComputation | Computation in which both incoming and outgoing message types are the same. | Class | org.apache.giraph.graph | Giraph |
|
| BasicPartition | Basic partition class for other partitions to extend. | Class | org.apache.giraph.partition | Giraph |
|
| BasicPartitionOwner | Basic partition owner, can be subclassed for more complicated partition owner implementations. | Class | org.apache.giraph.partition | Giraph |
|
| BasicSet | BasicSet with only basic set of operations. | Interface | org.apache.giraph.types.ops.collections | Giraph |
|
| BasicSet .BasicIntOpenHashSet | | Class | org.apache.giraph.types.ops.collections.BasicSet | Giraph |
|
| BasicSet .BasicLongOpenHashSet | | Class | org.apache.giraph.types.ops.collections.BasicSet | Giraph |
|
| BasicVertexValueReader | Abstract base class for VertexValueReader. | Class | org.apache.giraph.io | Giraph |
|
| BenchmarkOption | | Class | org.apache.giraph.benchmark | Giraph |
|
| BigDataInput | only handle up to 1GB of data. | Class | org.apache.giraph.utils.io | Giraph |
|
| BigDataInputOutput | DataInputOutput which uses BigDataInput and BigDataOutput to support larger than allowed array size streams. | Class | org.apache.giraph.utils.io | Giraph |
|
| BigDataOutput | only handle up to 1GB of data. | Class | org.apache.giraph.utils.io | Giraph |
|
| BooleanAndAggregator | Aggregator for calculating the AND function over boolean values. | Class | org.apache.giraph.aggregators | Giraph |
|
| BooleanConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| BooleanOrAggregator | Aggregator for calculating the OR function over boolean values. | Class | org.apache.giraph.aggregators | Giraph |
|
| BooleanOverwriteAggregator | Aggregator that stores a value that is overwritten once another value is aggregated. | Class | org.apache.giraph.aggregators | Giraph |
|
| BooleanToBooleanWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| BooleanTypeOps | TypeOps implementation for working with BooleanWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| BooleanWritableToBooleanUnwrapper | Converts BooleanWritables to Booleans. | Class | org.apache.giraph.types | Giraph |
|
| BrachaTouegDeadlockComputation | This code demonstrates the Bracha Toueg deadlock detection algorithm. | Class | org.apache.giraph.examples | Giraph |
|
| BrachaTouegDeadlockInputFormat | VertexInputFormat for the Bracha Toueg Deadlock Detection algorithm specified in JSON format. | Class | org.apache.giraph.examples.io.formats | Giraph |
|
| BrachaTouegDeadlockMessage | Data sent via a message that includes the source vertex id. | Class | org.apache.giraph.examples.utils | Giraph |
|
| BrachaTouegDeadlockVertexValue | | Class | org.apache.giraph.examples.utils | Giraph |
|
| BspEvent | Synchronize on waiting for an event to have happened. | Interface | org.apache.giraph.zk | Giraph |
|
| BspInputFormat | This InputFormat supports the BSP model by ensuring that the user specifies how many splits (number of mappers) should be started simultaneously. | Class | org.apache.giraph.bsp | Giraph |
|
| BspInputSplit | This InputSplit will not give any ordering or location data. | Class | org.apache.giraph.bsp | Giraph |
|
| BspOutputFormat | This is for internal use only. | Class | org.apache.giraph.bsp | Giraph |
|
| BspRecordWriter | Used by BspOutputFormat since some versions of Hadoop require that a RecordWriter is returned from getRecordWriter. | Class | org.apache.giraph.bsp | Giraph |
|
| BspService | Zookeeper-based implementation of CentralizedService. | Class | org.apache.giraph.bsp | Giraph |
|
| BspServiceMaster | ZooKeeper-based implementation of CentralizedServiceMaster. | Class | org.apache.giraph.master | Giraph |
|
| BspServiceWorker | ZooKeeper-based implementation of CentralizedServiceWorker. | Class | org.apache.giraph.worker | Giraph |
|
| ByteArrayEdges | OutEdges implementation backed by a byte array. | Class | org.apache.giraph.edge | Giraph |
|
| ByteArrayMessagesPerVertexStore | stored per vertex as byte backed datastructures. | Class | org.apache.giraph.comm.messages | Giraph |
|
| ByteArrayOneMessageToManyIds | Stores a message and a list of target vertex ids. | Class | org.apache.giraph.utils | Giraph |
|
| ByteArrayPartition | Byte array based partition. | Class | org.apache.giraph.partition | Giraph |
|
| ByteArrayRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| ByteArrayVertexIdData | | Class | org.apache.giraph.utils | Giraph |
|
| ByteArrayVertexIdEdges | Stores vertex id and edge pairs in a single byte array. | Class | org.apache.giraph.utils | Giraph |
|
| ByteArrayVertexIdMessages | Stores vertex id and message pairs in a single byte array. | Class | org.apache.giraph.utils | Giraph |
|
| ByteArrayWithSenderTaskIdRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| ByteCounter | | Interface | org.apache.giraph.comm.netty | Giraph |
|
| ByteCounterDelegate | Delegate Object to help keep track of the bytes processed and provide some metrics when desired as part of the Netty Channel stack. | Class | org.apache.giraph.comm.netty | Giraph |
|
| ByteStructIterable | This iterable is designed to deserialize a byte array on the fly to provide new copies of writable objects when desired. | Class | org.apache.giraph.utils | Giraph |
|
| ByteStructIterator | This iterator is designed to deserialize a byte array on the fly to provide new copies of writable objects when desired. | Class | org.apache.giraph.utils | Giraph |
|
| ByteStructVertexIdDataIterator | Special iterator that reuses vertex ids and data objects so that the lifetime of the object is only until next() is called. | Class | org.apache.giraph.utils | Giraph |
|
| ByteStructVertexIdEdgeIterator | Special iterator that reuses vertex ids and edge objects so that the lifetime of the object is only until next() is called. | Class | org.apache.giraph.utils | Giraph |
|
| ByteStructVertexIdIterator | Common implementation for VertexIdEdgeIterator, VertexIdMessageIterator and VertexIdMessageBytesIterator. | Class | org.apache.giraph.utils | Giraph |
|
| ByteStructVertexIdMessageBytesIterator | Special iterator that reuses vertex ids and messages bytes so that the lifetime of the object is only until next() is called. | Class | org.apache.giraph.utils | Giraph |
|
| ByteStructVertexIdMessageIterator | Special iterator that reuses vertex ids and message objects so that the lifetime of the object is only until next() is called. | Class | org.apache.giraph.utils | Giraph |
|
| ByteToByteWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| ByteToIntWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| ByteToLongWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| ByteTypeOps | TypeOps implementation for working with ByteWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| ByteUtils | | Class | org.apache.giraph.utils | Giraph |
|
| ByteValueVertex | | Class | org.apache.giraph.graph | Giraph |
|
| ByteWritableToByteUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| ByteWritableToIntUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| ByteWritableToLongUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| ByteWritableToShortUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| CallableFactory | | Interface | org.apache.giraph.utils | Giraph |
|
| CentralizedService | Basic service interface shared by both CentralizedServiceMaster and CentralizedServiceWorker. | Interface | org.apache.giraph.bsp | Giraph |
|
| CentralizedServiceMaster | At most, there will be one active master at a time, but many threads can be trying to be the active master. | Interface | org.apache.giraph.bsp | Giraph |
|
| CentralizedServiceWorker | All workers should have access to this centralized service to execute the following methods. | Interface | org.apache.giraph.bsp | Giraph |
|
| ChannelRotater | Maintains multiple channels and rotates between them. | Class | org.apache.giraph.comm.netty | Giraph |
|
| CheckpointingUtils | | Class | org.apache.giraph.utils | Giraph |
|
| CheckpointStatus | enum CheckpointStatusEnum represents possible checkpoint state. | Class | org.apache.giraph.bsp | Giraph |
|
| ClassConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| ClientRequestId | Simple immutable object to use for tracking requests uniquely. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| CollectionUtils | | Class | org.apache.giraph.utils | Giraph |
|
| CombinedWorkerProgress | Class which combines multiple workers' progresses to get overall application progress | Class | org.apache.giraph.job | Giraph |
|
| Computation | Interface for an application for computation. | Interface | org.apache.giraph.graph | Giraph |
|
| ComputationDoneName | This name is used by each worker as a file to let the ZooKeeper servers know that they can shutdown. | Class | org.apache.giraph.zk | Giraph |
|
| ComputationFactory | | Interface | org.apache.giraph.factories | Giraph |
|
| ComputeCallable | Compute as many vertex partitions as possible. | Class | org.apache.giraph.graph | Giraph |
|
| ConfigurableOutEdges | | Class | org.apache.giraph.edge | Giraph |
|
| ConfigurationUtils | Translate command line args into Configuration Key-Value pairs. | Class | org.apache.giraph.utils | Giraph |
|
| ConfOptionType | Type of value for a Configuration optionEnum Constant Summary | Class | org.apache.giraph.conf | Giraph |
|
| ConnectedComponentsComputation | assigns each vertex its component identifier (the smallest vertex id The idea behind the algorithm is very simple: propagate the smallest | Class | org.apache.giraph.examples | Giraph |
|
| CounterUtils | | Class | org.apache.giraph.utils | Giraph |
|
| CountingCache | Cache which counts the number of flushes per task id (destination worker id), so we know how many requests were sent to the worker | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| CountingOutputStream | Wrapper for output stream which keeps the place in the beginning for the count of objects which were written to it | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| DataInputOutput | Provides both DataOutput which we can write to and DataInputs which are going to read data which was written to DataOutput. | Class | org.apache.giraph.utils.io | Giraph |
|
| DefaultComputationFactory | | Class | org.apache.giraph.factories | Giraph |
|
| DefaultConfigurableAndTableSchemaAware | Default implementation of HiveTableSchemaAware and ImmutableClassesGiraphConfigurable | Class | org.apache.giraph.hive.common | Giraph |
|
| DefaultEdge | A complete edge, the target vertex and the edge value. | Class | org.apache.giraph.edge | Giraph |
|
| DefaultEdgeInputFilter | Default edge filter that lets in all edges. | Class | org.apache.giraph.io.filters | Giraph |
|
| DefaultEdgeValueFactory | Factory class to create default edge values. | Class | org.apache.giraph.factories | Giraph |
|
| DefaultEmbeddedLongByteOps | MappingStoreOps implementation used to embed target information into vertex id. | Class | org.apache.giraph.mapping | Giraph |
|
| DefaultGiraphJobRetryChecker | Default implementation of GiraphJobRetryChecker, which never retries the job. | Class | org.apache.giraph.job | Giraph |
|
| DefaultImmutableClassesGiraphConfigurable | | Class | org.apache.giraph.conf | Giraph |
|
| DefaultIncomingMessageValueFactory | Factory class to create default incoming message values. | Class | org.apache.giraph.factories | Giraph |
|
| DefaultJobObserver | Default implementation of job observer that does nothing. | Class | org.apache.giraph.job | Giraph |
|
| DefaultKeyFactory | Example class for defining a way to construct Gora keys. | Class | org.apache.giraph.io.gora.utils | Giraph |
|
| DefaultLongByteOps | | Class | org.apache.giraph.mapping | Giraph |
|
| DefaultMasterCompute | A dumb implementation of MasterCompute. | Class | org.apache.giraph.master | Giraph |
|
| DefaultMasterObserver | A no-op implementation of MasterObserver to make it easier for users. | Class | org.apache.giraph.master | Giraph |
|
| DefaultOutgoingMessageValueFactory | Factory class to create default outgoing message values. | Class | org.apache.giraph.factories | Giraph |
|
| DefaultVertex | Class which holds vertex id, data and edges. | Class | org.apache.giraph.graph | Giraph |
|
| DefaultVertexIdFactory | Default VertexIdFactory that simply uses the default constructor for the vertex ID class. | Class | org.apache.giraph.factories | Giraph |
|
| DefaultVertexInputFilter | Default vertex filter that lets in all vertices. | Class | org.apache.giraph.io.filters | Giraph |
|
| DefaultVertexResolver | Default implementation of how to resolve vertex creation/removal, messages to nonexistent vertices, etc. | Class | org.apache.giraph.graph | Giraph |
|
| DefaultVertexValueCombiner | | Class | org.apache.giraph.graph | Giraph |
|
| DefaultVertexValueFactory | Default VertexValueFactory that simply uses the default constructor for the vertex value class. | Class | org.apache.giraph.factories | Giraph |
|
| DefaultWorkerContext | A dummy implementation of WorkerContext. | Class | org.apache.giraph.worker | Giraph |
|
| DefaultWorkerObserver | Default Observer for Worker that does nothing. | Class | org.apache.giraph.worker | Giraph |
|
| DeployedScript | A script that was deployed to the cluster. | Class | org.apache.giraph.scripting | Giraph |
|
| DeployType | Type of deployment for a fileEnum Constant Summary | Class | org.apache.giraph.scripting | Giraph |
|
| DiskBackedMessageStore | Message store which separates data by partitions, and submits them to underlying message store. | Class | org.apache.giraph.comm.messages.out_of_core | Giraph |
|
| DiskBackedMessageStoreFactory | Message store factory which persist the messages on the disk. | Class | org.apache.giraph.comm.messages.out_of_core | Giraph |
|
| DiskBackedPartitionStore | Disk-backed PartitionStore. | Class | org.apache.giraph.partition | Giraph |
|
| DistributedCacheUtils | | Class | org.apache.giraph.utils | Giraph |
|
| DoubleDenseMatrix | A double matrix holds the values of the entries in double vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| DoubleDenseMatrixSumAggregator | | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| DoubleDenseVector | The double dense vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| DoubleDenseVectorSumAggregator | The double dense vector aggregator is used to aggregate double dense vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| DoubleMaxAggregator | Aggregator for getting max double value. | Class | org.apache.giraph.aggregators | Giraph |
|
| DoubleMinAggregator | Aggregator for getting min double value. | Class | org.apache.giraph.aggregators | Giraph |
|
| DoubleOverwriteAggregator | Aggregator that stores a value that is overwritten once another value is aggregated. | Class | org.apache.giraph.aggregators | Giraph |
|
| DoubleProductAggregator | Aggregator for calculating products of double values. | Class | org.apache.giraph.aggregators | Giraph |
|
| DoubleSparseMatrix | A double matrix holds the values of the entries in double vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| DoubleSparseMatrixSumAggregator | | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| DoubleSparseVector | The double vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| DoubleSparseVectorSumAggregator | The double vector aggregator is used to aggregate double vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| DoubleSumAggregator | Aggregator for summing up double values. | Class | org.apache.giraph.aggregators | Giraph |
|
| DoubleSumMessageCombiner | | Class | org.apache.giraph.combiner | Giraph |
|
| DoubleToDoubleWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| DoubleTypeOps | TypeOps implementation for working with DoubleWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| DoubleWritableToDoubleUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| DynamicChannelBufferInputStream | Special input that reads from a DynamicChannelBuffer. | Class | org.apache.giraph.utils | Giraph |
|
| DynamicChannelBufferOutputStream | Special output stream that can grow as needed and dumps to a DynamicChannelBuffer. | Class | org.apache.giraph.utils | Giraph |
|
| Edge | A complete edge, the target vertex and the edge value. | Interface | org.apache.giraph.edge | Giraph |
|
| EdgeComparator | Comparator for edges. | Class | org.apache.giraph.utils | Giraph |
|
| EdgeFactory | | Class | org.apache.giraph.edge | Giraph |
|
| EdgeInputFilter | Filters edges on input. | Interface | org.apache.giraph.io.filters | Giraph |
|
| EdgeInputFormat | Input format for reading single edges. | Class | org.apache.giraph.io | Giraph |
|
| EdgeInputFormatDescription | Description of the edge input format - holds edge input format class and all parameters specifically set for that edge input format. | Class | org.apache.giraph.io.formats.multi | Giraph |
|
| EdgeInputSplitsCallable | Load as many edge input splits as possible. | Class | org.apache.giraph.worker | Giraph |
|
| EdgeInputSplitsCallableFactory | Factory for EdgeInputSplitsCallables. | Class | org.apache.giraph.worker | Giraph |
|
| EdgeIterables | Utility methods for iterables of edges. | Class | org.apache.giraph.utils | Giraph |
|
| EdgeNoValue | An edge that has no value. | Class | org.apache.giraph.edge | Giraph |
|
| EdgeOutputFormat | | Class | org.apache.giraph.io | Giraph |
|
| EdgeReader | Analogous to BspRecordReader for edges. | Class | org.apache.giraph.io | Giraph |
|
| EdgeReaderWrapper | | Class | org.apache.giraph.io.iterables | Giraph |
|
| EdgeStore | Collects incoming edges for vertices owned by this worker. | Interface | org.apache.giraph.edge | Giraph |
|
| EdgeStoreFactory | | Interface | org.apache.giraph.edge | Giraph |
|
| EdgeValueFactory | Factory class to create default edge values. | Interface | org.apache.giraph.factories | Giraph |
|
| EdgeWithSource | | Class | org.apache.giraph.io.iterables | Giraph |
|
| EdgeWriter | | Class | org.apache.giraph.io | Giraph |
|
| EmptyIterable | Singleton class for empty iterables. | Class | org.apache.giraph.utils | Giraph |
|
| EnumConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| ExtendedByteArrayDataInput | | Class | org.apache.giraph.utils | Giraph |
|
| ExtendedByteArrayDataOutput | Adds some functionality to ByteArrayOutputStream, such as an option to write int value over previously written data | Class | org.apache.giraph.utils | Giraph |
|
| ExtendedByteArrayOutputBuffer | Wraps a list of byte array outputs and provides convenient utilities on top of it | Class | org.apache.giraph.utils | Giraph |
|
| ExtendedByteArrayOutputBuffer .IndexAndDataOut | | Class | org.apache.giraph.utils.ExtendedByteArrayOutputBuffer | Giraph |
|
| ExtendedDataInput | | Interface | org.apache.giraph.utils | Giraph |
|
| ExtendedDataInputOutput | Wraps ExtendedDataOutput and ExtendedDataOutput to be able to write data and later read data from the same place | Class | org.apache.giraph.utils.io | Giraph |
|
| ExtendedDataOutput | | Interface | org.apache.giraph.utils | Giraph |
|
| ExtraGoraInputFormat | InputFormat to fetch the input from Gora data stores. | Class | org.apache.giraph.io.gora.utils | Giraph |
|
| Factory | | Interface | org.apache.giraph.utils | Giraph |
|
| FakeTime | Thread-safe implementation of Time for testing that can help get time based ordering of events when desired. | Class | org.apache.giraph.time | Giraph |
|
| FileUtils | | Class | org.apache.giraph.utils | Giraph |
|
| FinishedSuperstepStats | | Class | org.apache.giraph.graph | Giraph |
|
| FloatConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| FloatDenseMatrix | A float matrix holds the values of the entries in float vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| FloatDenseMatrixSumAggregator | | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| FloatDenseVector | The float dense vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| FloatDenseVectorSumAggregator | The float dense vector aggregator is used to aggregate float dense vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| FloatMaxAggregator | Aggregator for getting max float value. | Class | org.apache.giraph.aggregators | Giraph |
|
| FloatMinAggregator | Aggregator for getting min float value. | Class | org.apache.giraph.aggregators | Giraph |
|
| FloatOverwriteAggregator | Aggregator that stores a value that is overwritten once another value is aggregated. | Class | org.apache.giraph.aggregators | Giraph |
|
| FloatProductAggregator | Aggregator for calculating products of float values. | Class | org.apache.giraph.aggregators | Giraph |
|
| FloatSparseMatrix | A float matrix holds the values of the entries in float vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| FloatSparseMatrixSumAggregator | The float matrix aggregator is used to register and aggregate float matrices. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| FloatSparseVector | The float vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| FloatSparseVectorSumAggregator | The float vector aggregator is used to aggregate float vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| FloatSumAggregator | Aggregator for summing up float values. | Class | org.apache.giraph.aggregators | Giraph |
|
| FloatSumMessageCombiner | | Class | org.apache.giraph.combiner | Giraph |
|
| FloatToDoubleWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| FloatToFloatWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| FloatTypeOps | TypeOps implementation for working with FloatWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| FloatWritableToDoubleUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| FloatWritableToFloatUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| FullInputSplitCallable | | Class | org.apache.giraph.worker | Giraph |
|
| GEdge | Example class for defining a Giraph-Edge. | Class | org.apache.giraph.io.gora.generated | Giraph |
|
| GEdge .Builder | RecordBuilder for GEdge instances. | Class | org.apache.giraph.io.gora.generated.GEdge | Giraph |
|
| GEdge .Field | Edge vertex source id. | Class | org.apache.giraph.io.gora.generated.GEdge | Giraph |
|
| GEdge .Tombstone | | Class | org.apache.giraph.io.gora.generated.GEdge | Giraph |
|
| GEdgeResult | Example class for defining a Giraph-Edge result. | Class | org.apache.giraph.io.gora.generated | Giraph |
|
| GEdgeResult .Builder | RecordBuilder for GEdgeResult instances. | Class | org.apache.giraph.io.gora.generated.GEdgeResult | Giraph |
|
| GEdgeResult .Field | Edge vertex source id. | Class | org.apache.giraph.io.gora.generated.GEdgeResult | Giraph |
|
| GEdgeResult .Tombstone | | Class | org.apache.giraph.io.gora.generated.GEdgeResult | Giraph |
|
| GeneratedEdgeReader | Used by GeneratedEdgeInputFormat to read some generated data | Class | org.apache.giraph.examples | Giraph |
|
| GeneratedVertexInputFormat | This VertexInputFormat is meant for testing/debugging. | Class | org.apache.giraph.io.formats | Giraph |
|
| GeneratedVertexReader | | Class | org.apache.giraph.examples | Giraph |
|
| GiraphApplicationMaster | The YARN Application Master for Giraph is launched when the GiraphYarnClient successfully requests an execution container from the Resource Manager. | Class | org.apache.giraph.yarn | Giraph |
|
| GiraphBenchmark | Abstract class which benchmarks should extend. | Class | org.apache.giraph.benchmark | Giraph |
|
| GiraphClasses | Holder for classes used by Giraph. | Class | org.apache.giraph.conf | Giraph |
|
| GiraphConfiguration | Adds user methods specific to Giraph. | Class | org.apache.giraph.conf | Giraph |
|
| GiraphConfigurationSettable | | Interface | org.apache.giraph.conf | Giraph |
|
| GiraphConfigurationValidator | GiraphConfigurationValidator attempts to verify the consistency of user-chosen InputFormat, OutputFormat, and Vertex generic type | Class | org.apache.giraph.job | Giraph |
|
| GiraphConstants | Constants used all over Giraph for configuration. | Interface | org.apache.giraph.conf | Giraph |
|
| GiraphDepVersions | Versions of Giraph dependencies. | Class | org.apache.giraph.utils | Giraph |
|
| GiraphExtension | This extension allows batch/transactional operations on a graph. | Class | org.apache.giraph.rexster.kibble | Giraph |
|
| GiraphFileInputFormat | Provides functionality similar to FileInputFormat, but allows for different data sources (vertex and edge data). | Class | org.apache.giraph.io.formats | Giraph |
|
| GiraphGoraConstants | | Interface | org.apache.giraph.io.gora.constants | Giraph |
|
| GiraphHadoopCounter | Wrapper around Hadoop Counter to make it easier to use. | Class | org.apache.giraph.counters | Giraph |
|
| GiraphHCatInputFormat | Provides functionality similar to but allows for different data sources (vertex and edge data). | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| GiraphHiveConstants | | Class | org.apache.giraph.hive.common | Giraph |
|
| GiraphInputFormat | Common interface for VertexInputFormat and EdgeInputFormat. | Class | org.apache.giraph.io | Giraph |
|
| GiraphJob | Generates an appropriate internal Job for using Giraph in Hadoop. | Class | org.apache.giraph.job | Giraph |
|
| GiraphJobObserver | An observer over the job launch lifecycle. | Interface | org.apache.giraph.job | Giraph |
|
| GiraphJobRetryChecker | Class to decide whether a GiraphJob should be restarted after failure. | Interface | org.apache.giraph.job | Giraph |
|
| GiraphMetrics | Top level metrics class for using Yammer's metrics in Giraph. | Class | org.apache.giraph.metrics | Giraph |
|
| GiraphMetricsRegistry | A holder for MetricsRegistry together with a JmxReporter. | Class | org.apache.giraph.metrics | Giraph |
|
| GiraphReader | Reader for some kind of data. | Interface | org.apache.giraph.io.iterables | Giraph |
|
| GiraphRexsterConstants | | Interface | org.apache.giraph.rexster.conf | Giraph |
|
| GiraphRunner | Helper class to run Giraph applications by specifying the actual class name to use (i. | Class | org.apache.giraph | Giraph |
|
| GiraphStats | Hadoop Counters in group Giraph Stats. | Class | org.apache.giraph.counters | Giraph |
|
| GiraphTextInputFormat | Provides functionality similar to but allows for different data sources (vertex and edge data). | Class | org.apache.giraph.io.formats | Giraph |
|
| GiraphTextOutputFormat | The text output format used for Giraph text writing. | Class | org.apache.giraph.io.formats | Giraph |
|
| GiraphTimer | A timer to record duration of an event in a given TimeUnit. | Class | org.apache.giraph.metrics | Giraph |
|
| GiraphTimerContext | Context to use with GiraphTimer for timing an event. | Class | org.apache.giraph.metrics | Giraph |
|
| GiraphTimers | Hadoop Counters in group Giraph Timers for timing things. | Class | org.apache.giraph.counters | Giraph |
|
| GiraphTransferRegulator | Utility class to manage data transfers from a local worker reading InputSplits. | Class | org.apache.giraph.graph | Giraph |
|
| GiraphTypes | Holder for the generic types that describe user's graph. | Class | org.apache.giraph.conf | Giraph |
|
| GiraphYarnClient | The initial launcher for a YARN-based Giraph job. | Class | org.apache.giraph.yarn | Giraph |
|
| GiraphYarnTask | This process will execute the BSP graph tasks alloted to this YARN execution container. | Class | org.apache.giraph.yarn | Giraph |
|
| GiraphZooKeeperAdmin | A Utility class to be used by Giraph admins to occasionally clean up the ZK remnants of jobs that have failed or were killed before finishing. | Class | org.apache.giraph.zk | Giraph |
|
| GlobalCommType | Type tag distinguishing different global communication messages. | Class | org.apache.giraph.comm | Giraph |
|
| GlobalCommValueOutputStream | reduced values in the form of pair (name, type, value) There are two modes: | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| GlobalStats | Aggregated stats by the master. | Class | org.apache.giraph.graph | Giraph |
|
| GoraEdgeInputFormat | Class which wraps the GoraInputFormat. | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraEdgeOutputFormat | Class which wraps the GoraInputFormat. | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraGEdgeEdgeInputFormat | Example implementation of a specific reader for a generated data bean. | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraGEdgeEdgeOutputFormat | | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraGVertexVertexInputFormat | Example implementation of a specific reader for a generated data bean. | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraGVertexVertexOutputFormat | | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraUtils | Class used to handle the creation and querying of data stores through Gora. | Class | org.apache.giraph.io.gora.utils | Giraph |
|
| GoraVertexInputFormat | Class which wraps the GoraInputFormat. | Class | org.apache.giraph.io.gora | Giraph |
|
| GoraVertexOutputFormat | Class which wraps the GoraOutputFormat. | Class | org.apache.giraph.io.gora | Giraph |
|
| GraphFunctions | Each compute node running on the underlying cluster is marked with this enum to indicate the worker or | Class | org.apache.giraph.graph | Giraph |
|
| GraphMapper | This mapper that will execute the BSP graph tasks alloted to this worker. | Class | org.apache.giraph.graph | Giraph |
|
| GraphPartitionerFactory | Defines the partitioning framework for this application. | Interface | org.apache.giraph.partition | Giraph |
|
| GraphState | Immutable global state of the graph. | Class | org.apache.giraph.graph | Giraph |
|
| GraphTaskManager | The Giraph-specific business logic for a single BSP compute node in whatever underlying type of cluster | Class | org.apache.giraph.graph | Giraph |
|
| GraphType | Enumeration for a user graph type (IVEMM)Enum Constant Summary | Class | org.apache.giraph.graph | Giraph |
|
| GraphvizOutputFormat | Writes graph to a dot file (graphviz format). | Class | org.apache.giraph.io.formats | Giraph |
|
| GVertex | Example class for defining a Giraph-vertex. | Class | org.apache.giraph.io.gora.generated | Giraph |
|
| GVertex .Builder | RecordBuilder for GVertex instances. | Class | org.apache.giraph.io.gora.generated.GVertex | Giraph |
|
| GVertex .Field | | Class | org.apache.giraph.io.gora.generated.GVertex | Giraph |
|
| GVertex .Tombstone | | Class | org.apache.giraph.io.gora.generated.GVertex | Giraph |
|
| GVertexResult | Example class for defining a Giraph-vertex result. | Class | org.apache.giraph.io.gora.generated | Giraph |
|
| GVertexResult .Builder | RecordBuilder for GVertexResult instances. | Class | org.apache.giraph.io.gora.generated.GVertexResult | Giraph |
|
| GVertexResult .Field | | Class | org.apache.giraph.io.gora.generated.GVertexResult | Giraph |
|
| GVertexResult .Tombstone | | Class | org.apache.giraph.io.gora.generated.GVertexResult | Giraph |
|
| HadoopCountersBase | Base class for groups of Hadoop Counters. | Class | org.apache.giraph.counters | Giraph |
|
| HadoopUtils | Helpers for dealing with Hadoop. | Class | org.apache.giraph.job | Giraph |
|
| HaltApplicationUtils | | Class | org.apache.giraph.job | Giraph |
|
| HaltApplicationUtils .DefaultHaltInstructionsWriter | Default implementation of HaltApplicationUtils. | Class | org.apache.giraph.job.HaltApplicationUtils | Giraph |
|
| HaltApplicationUtils .HaltInstructionsWriter | | Interface | org.apache.giraph.job.HaltApplicationUtils | Giraph |
|
| HashMapEdges | OutEdges implementation backed by a HashMap. | Class | org.apache.giraph.edge | Giraph |
|
| HashMasterPartitioner | Master will execute a hash based partitioning. | Class | org.apache.giraph.partition | Giraph |
|
| HashMultimapEdges | OutEdges implementation backed by an ArrayListMultimap. | Class | org.apache.giraph.edge | Giraph |
|
| HashPartitionerFactory | 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 | org.apache.giraph.partition | Giraph |
|
| HashRangePartitionerFactory | | Class | org.apache.giraph.partition | Giraph |
|
| HashRangeWorkerPartitioner | | Class | org.apache.giraph.partition | Giraph |
|
| HashWorkerPartitioner | | Class | org.apache.giraph.partition | Giraph |
|
| HBaseVertexInputFormat | Base class that wraps an HBase TableInputFormat and underlying Scan object to help instantiate vertices from an HBase table. | Class | org.apache.giraph.io.hbase | Giraph |
|
| HBaseVertexInputFormat .HBaseVertexReader | Takes an instance of RecordReader that supports HBase row-key, result records. | Class | org.apache.giraph.io.hbase.HBaseVertexInputFormat | Giraph |
|
| HBaseVertexOutputFormat | Base class for writing Vertex mutations back to specific rows in an HBase table. | Class | org.apache.giraph.io.hbase | Giraph |
|
| HBaseVertexOutputFormat .HBaseVertexWriter | Simple class which takes an instance of RecordWriter over Writable objects. | Class | org.apache.giraph.io.hbase.HBaseVertexOutputFormat | Giraph |
|
| HCatalogEdgeInputFormat | HCatalog EdgeInputFormat for reading edges from Hive/Pig. | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| HCatalogEdgeInputFormat .HCatalogEdgeReader | EdgeReader for HCatalogEdgeInputFormat. | Class | org.apache.giraph.io.hcatalog.HCatalogEdgeInputFormat | Giraph |
|
| HCatalogEdgeInputFormat .SingleRowHCatalogEdgeNoValueReader | HCatalogEdgeInputFormat. | Class | org.apache.giraph.io.hcatalog.HCatalogEdgeInputFormat | Giraph |
|
| HCatalogEdgeInputFormat .SingleRowHCatalogEdgeReader | HCatalogEdgeInputFormat. | Class | org.apache.giraph.io.hcatalog.HCatalogEdgeInputFormat | Giraph |
|
| HCatalogVertexInputFormat | Abstract class that users should subclass to load data from a Hive or Pig table. | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| HCatalogVertexOutputFormat | Abstract class that users should subclass to store data to Hive or Pig table. | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| HCatalogVertexOutputFormat .HCatalogVertexWriter | Abstract class that users should subclass based on their specific vertex | Class | org.apache.giraph.io.hcatalog.HCatalogVertexOutputFormat | Giraph |
|
| HCatalogVertexOutputFormat .MultiRowHCatalogVertexWriter | HCatalogVertexWriter to write each vertex in multiple rows. | Class | org.apache.giraph.io.hcatalog.HCatalogVertexOutputFormat | Giraph |
|
| HCatalogVertexOutputFormat .SingleRowHCatalogVertexWriter | HCatalogVertexWriter to write each vertex in each row. | Class | org.apache.giraph.io.hcatalog.HCatalogVertexOutputFormat | Giraph |
|
| HCatalogVertexValueInputFormat | | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| HCatGiraphRunner | | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| HiveEdgeInputFormat | EdgeInputFormat for reading edges from Hive. | Class | org.apache.giraph.hive.input.edge | Giraph |
|
| HiveEdgeReader | A reader for reading edges from Hive. | Class | org.apache.giraph.hive.input.edge | Giraph |
|
| HiveGiraphRunner | | Class | org.apache.giraph.hive | Giraph |
|
| HiveInputChecker | Interface to check the validity of a Hive input configuration. | Interface | org.apache.giraph.hive.input | Giraph |
|
| HiveInputOptions | Holder for Hive Input Configuration options. | Class | org.apache.giraph.hive.common | Giraph |
|
| HiveIntDoubleDoubleVertex | Simple HiveToVertex that reads vertices with integer IDs, Double vertex values, and edges with Double values. | Class | org.apache.giraph.hive.input.vertex.examples | Giraph |
|
| HiveIntDoubleEdge | A simple HiveToEdge with integer IDs and double edge values. | Class | org.apache.giraph.hive.input.edge.examples | Giraph |
|
| HiveIntIntNullVertex | Simple HiveToVertex that reads vertices with integer IDs, no vertex values, and edges with no values. | Class | org.apache.giraph.hive.input.vertex.examples | Giraph |
|
| HiveIntNullEdge | A simple HiveToEdge with integer IDs, no edge value, that assumes the Hive table is made up of [source,target] columns. | Class | org.apache.giraph.hive.input.edge.examples | Giraph |
|
| HiveIntNullNullVertex | Simple HiveToVertex that reads vertices with integer IDs, no vertex values, and edges with no values. | Class | org.apache.giraph.hive.input.vertex.examples | Giraph |
|
| HiveJythonRunner | | Class | org.apache.giraph.hive.jython | Giraph |
|
| HiveJythonUtils | Plugin to HiveJythonRunner to use Hive. | Class | org.apache.giraph.hive.jython | Giraph |
|
| HiveMappingInputFormat | | Class | org.apache.giraph.hive.input.mapping | Giraph |
|
| HiveMappingReader | | Class | org.apache.giraph.hive.input.mapping | Giraph |
|
| HiveOutputIntIntVertex | | Class | org.apache.giraph.hive.output.examples | Giraph |
|
| HiveParsing | Helpers for parsing with Hive. | Class | org.apache.giraph.hive.common | Giraph |
|
| HiveReadableColumn | A single column from a Hive record. | Class | org.apache.giraph.hive.column | Giraph |
|
| HiveRecordSaver | Interface which can save HiveWritableRecords. | Interface | org.apache.giraph.hive.output | Giraph |
|
| HiveToEdge | An interface used to create edges from Hive records. | Interface | org.apache.giraph.hive.input.edge | Giraph |
|
| HiveToMapping | | Interface | org.apache.giraph.hive.input.mapping | Giraph |
|
| HiveToVertex | An interface used to create vertices from Hive records. | Interface | org.apache.giraph.hive.input.vertex | Giraph |
|
| HiveUtils | | Class | org.apache.giraph.hive.common | Giraph |
|
| HiveUtils | Utilities and helpers for working with Hive tables. | Class | org.apache.giraph.io.hcatalog | Giraph |
|
| HiveValueReader | | Interface | org.apache.giraph.hive.values | Giraph |
|
| HiveValueReader .Null | | Class | org.apache.giraph.hive.values.HiveValueReader | Giraph |
|
| HiveValueWriter | | Interface | org.apache.giraph.hive.values | Giraph |
|
| HiveValueWriter .Null | | Class | org.apache.giraph.hive.values.HiveValueWriter | Giraph |
|
| HiveVertexInputFormat | VertexInputFormat for reading vertices from Hive. | Class | org.apache.giraph.hive.input.vertex | Giraph |
|
| HiveVertexOutputFormat | | Class | org.apache.giraph.hive.output | Giraph |
|
| HiveVertexReader | | Class | org.apache.giraph.hive.input.vertex | Giraph |
|
| HiveVertexWriter | Vertex writer using Hive. | Class | org.apache.giraph.hive.output | Giraph |
|
| HiveWritableColumn | A single column to write to a Hive record. | Class | org.apache.giraph.hive.column | Giraph |
|
| IdAndNullArrayEdges | Backed by a dynamic primitive array. | Class | org.apache.giraph.edge | Giraph |
|
| IdAndValueArrayEdges | Data is backed by a dynamic primitive array. | Class | org.apache.giraph.edge | Giraph |
|
| IdByteArrayMessageStore | Special message store to be used when IDs are primitive and no combiner is Data is backed by primitive maps in order to decrease number of objects and | Class | org.apache.giraph.comm.messages.primitives | Giraph |
|
| IdentityComputation | User applications can subclass IdentityComputation, which simply prints the results that have been read for testing IO related | Class | org.apache.giraph.examples | Giraph |
|
| IdOneMessagePerVertexStore | Special message store to be used when IDs are primitive and message doesn't need to be, and message combiner is used. | Class | org.apache.giraph.comm.messages.primitives | Giraph |
|
| IdWithValueTextOutputFormat | Write out Vertices' IDs and values, but not their edges nor edges' values. | Class | org.apache.giraph.io.formats | Giraph |
|
| ImmutableClassesGiraphConfigurable | | Interface | org.apache.giraph.conf | Giraph |
|
| ImmutableClassesGiraphConfiguration | The classes set here are immutable, the remaining configuration is mutable. | Class | org.apache.giraph.conf | Giraph |
|
| ImmutableOutputCommitter | This output committer doesn't do anything, meant for the case where output isn't desired, or as a base for not using | Class | org.apache.giraph.bsp | Giraph |
|
| InboundByteCounter | Keep track of the bytes received and provide some metrics when desired as part of the Netty Channel stack. | Class | org.apache.giraph.comm.netty | Giraph |
|
| IncreasingBitSet | Bit set optimized for increasing longs to save storage space. | Class | org.apache.giraph.utils | Giraph |
|
| InMemoryEdgeStoreFactory | Edge store factory which produces message stores which hold all edges in memory. | Class | org.apache.giraph.edge | Giraph |
|
| InMemoryMessageStoreFactory | Message store factory which produces message stores which hold all messages in memory. | Class | org.apache.giraph.comm.messages | Giraph |
|
| InMemoryVertexInputFormat | An input format that reads the input graph in memory. | Class | org.apache.giraph.utils | Giraph |
|
| InMemoryVertexOutputFormat | | Class | org.apache.giraph.io.formats | Giraph |
|
| InputFormatDescription | Description of the input format - holds input format class and all parameters specifically set for that input format. | Class | org.apache.giraph.io.formats.multi | Giraph |
|
| InputSplitEvents | Simple container of input split events. | Class | org.apache.giraph.graph | Giraph |
|
| InputSplitPathOrganizer | Utility class to extract the list of InputSplits from the ZooKeeper tree of claimable splits the master created, | Class | org.apache.giraph.worker | Giraph |
|
| InputSplitPaths | Simple container of input split paths for coordination via ZooKeeper. | Class | org.apache.giraph.graph | Giraph |
|
| InputSplitsCallable | Abstract base class for loading vertex/edge input splits. | Class | org.apache.giraph.worker | Giraph |
|
| InputSplitsHandler | Stores the list of input split paths, and provides thread-safe way for reserving input splits. | Class | org.apache.giraph.worker | Giraph |
|
| IntByteArrayMessageStore | Special message store to be used when ids are IntWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects and | Class | org.apache.giraph.comm.messages.primitives | Giraph |
|
| IntConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| IntDenseMatrix | A int matrix holds the values of the entries in int vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| IntDenseMatrixSumAggregator | | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| IntDenseVector | The int dense vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| IntDenseVectorSumAggregator | | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| IntEdgeStore | Special edge store to be used when ids are IntWritable. | Class | org.apache.giraph.edge.primitives | Giraph |
|
| InternalVertexRunner | A base class for running internal tests on a vertex Extending classes only have to invoke the run() method to test their vertex. | Class | org.apache.giraph.utils | Giraph |
|
| IntFloatMessageStore | Special message store to be used when ids are IntWritable and messages are FloatWritable and messageCombiner is used. | Class | org.apache.giraph.comm.messages.primitives | Giraph |
|
| IntIntNullTextInputFormat | Simple text-based VertexInputFormat for unweighted graphs with int ids. | Class | org.apache.giraph.io.formats | Giraph |
|
| IntIntNullTextVertexInputFormat | Simple text-based VertexInputFormat for unweighted graphs with int ids. | Class | org.apache.giraph.io.formats | Giraph |
|
| IntIntTextVertexValueInputFormat | Simple text-based VertexValueInputFormat for integer ids and values. | Class | org.apache.giraph.io.formats | Giraph |
|
| IntMaxAggregator | Aggregator for getting max integer value. | Class | org.apache.giraph.aggregators | Giraph |
|
| IntMinAggregator | Aggregator for getting min integer value. | Class | org.apache.giraph.aggregators | Giraph |
|
| IntNullArrayEdges | values, backed by dynamic primitive array. | Class | org.apache.giraph.edge | Giraph |
|
| IntNullNullTextInputFormat | Simple text-based VertexInputFormat for unweighted graphs without edges or values, just vertices with ids. | Class | org.apache.giraph.io.formats | Giraph |
|
| IntNullReverseTextEdgeInputFormat | Simple text-based EdgeInputFormat for unweighted graphs with int ids. | Class | org.apache.giraph.io.formats | Giraph |
|
| IntNullTextEdgeInputFormat | Simple text-based EdgeInputFormat for unweighted graphs with int ids. | Class | org.apache.giraph.io.formats | Giraph |
|
| IntOverwriteAggregator | Aggregator that stores a value that is overwritten once another value is aggregated. | Class | org.apache.giraph.aggregators | Giraph |
|
| IntPair | | Class | org.apache.giraph.utils | Giraph |
|
| IntProductAggregator | Aggregator for calculating products of long and integer values. | Class | org.apache.giraph.aggregators | Giraph |
|
| IntSparseMatrix | A int matrix holds the values of the entries in int vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| IntSparseMatrixSumAggregator | The int matrix aggregator is used to register and aggregate int matrices. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| IntSparseVector | The int vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| IntSparseVectorSumAggregator | The float vector aggregator is used to aggregate float vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| IntSumAggregator | Aggregator for summing up integer values. | Class | org.apache.giraph.aggregators | Giraph |
|
| IntToIntWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| IntToLongWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| IntTypeOps | TypeOps implementation for working with IntWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| IntWritableToIntUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| IntWritableToLongUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| IteratorToReaderWrapper | | Class | org.apache.giraph.io.iterables | Giraph |
|
| JavaWritablePair | Holder for java and writable class pair. | Class | org.apache.giraph.types | Giraph |
|
| JMap | | Class | org.apache.giraph.utils | Giraph |
|
| JMapHistoDumper | An observer for both worker and master that periodically dumps the memory usage using jmap tool. | Class | org.apache.giraph.utils | Giraph |
|
| JobProgressTracker | | Interface | org.apache.giraph.job | Giraph |
|
| JobProgressTrackerClient | Wrapper around JobProgressTracker which retries to connect and swallows exceptions so app wouldn't crash if something goes wrong with progress | Interface | org.apache.giraph.graph | Giraph |
|
| JobProgressTrackerClientNoOp | Class to use for JobProgressTracker client when progress shouldn't be tracked or something goes wrong | Class | org.apache.giraph.graph | Giraph |
|
| JobProgressTrackerService | | Class | org.apache.giraph.job | Giraph |
|
| JsonBase64VertexFormat | | Class | org.apache.giraph.io.formats | Giraph |
|
| JsonBase64VertexInputFormat | Simple way to represent the structure of the graph with a JSON object. | Class | org.apache.giraph.io.formats | Giraph |
|
| JsonBase64VertexOutputFormat | Simple way to represent the structure of the graph with a JSON object. | Class | org.apache.giraph.io.formats | Giraph |
|
| JsonLongDoubleFloatDoubleVertexInputFormat | VertexInputFormat that features long vertex ID's, double vertex values and float | Class | org.apache.giraph.io.formats | Giraph |
|
| JsonLongDoubleFloatDoubleVertexOutputFormat | VertexOutputFormat that supports JSON encoded vertices featuring double values and float out-edge weights | Class | org.apache.giraph.io.formats | Giraph |
|
| JsonStringConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| JythonColumnReader | A Vertex ID reader from a single Hive column. | Class | org.apache.giraph.hive.jython | Giraph |
|
| JythonColumnWriter | | Class | org.apache.giraph.hive.jython | Giraph |
|
| JythonComputation | Base class for writing computations in Jython. | Class | org.apache.giraph.jython | Giraph |
|
| JythonComputationFactory | | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonEdgeValueFactory | EdgeValueFactory that creates edge values which are Jython classes. | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonFactoryBase | Base class for Jython factories. | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonGiraphComputation | The Computation class for using Jython with Giraph. | Class | org.apache.giraph.jython | Giraph |
|
| JythonHiveIO | A type that can read and write itself using a Hive column. | Interface | org.apache.giraph.hive.jython | Giraph |
|
| JythonHiveReader | Interface for reading user graph type (IVEMM) from Hive columns. | Interface | org.apache.giraph.hive.jython | Giraph |
|
| JythonHiveToEdge | A HiveToEdge that reads each part (vertex ID, edge value) using separate readers. | Class | org.apache.giraph.hive.jython | Giraph |
|
| JythonHiveToVertex | A HiveToVertex that writes each part (vertex ID, vertex value, edges) using separate writers. | Class | org.apache.giraph.hive.jython | Giraph |
|
| JythonHiveWriter | | Interface | org.apache.giraph.hive.jython | Giraph |
|
| JythonIncomingMessageValueFactory | | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonJob | Holder of Jython job information. | Class | org.apache.giraph.jython | Giraph |
|
| JythonJob .EdgeInput | | Class | org.apache.giraph.jython.JythonJob | Giraph |
|
| JythonJob .InputBase | | Class | org.apache.giraph.jython.JythonJob | Giraph |
|
| JythonJob .TypeHolder | Holds a Java or Jython type. | Class | org.apache.giraph.jython.JythonJob | Giraph |
|
| JythonJob .TypeWithHive | A type along with its Hive input/output class. | Class | org.apache.giraph.jython.JythonJob | Giraph |
|
| JythonJob .VertexInput | | Class | org.apache.giraph.jython.JythonJob | Giraph |
|
| JythonJob .VertexOutput | | Class | org.apache.giraph.jython.JythonJob | Giraph |
|
| JythonMessageValueFactory | MessageValueFactory that creates message values which are Jython classes. | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonOptions | | Class | org.apache.giraph.jython | Giraph |
|
| JythonOptions .JythonGraphTypeOptions | | Class | org.apache.giraph.jython.JythonOptions | Giraph |
|
| JythonOutgoingMessageValueFactory | | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonReadableColumn | | Class | org.apache.giraph.hive.jython | Giraph |
|
| JythonUtils | Helpers for running jobs with Jython. | Class | org.apache.giraph.jython | Giraph |
|
| JythonVertexIdFactory | VertexIdFactory that creates vertex IDs which are Jython classes. | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonVertexToHive | A VertexToHive that writes each part (vertex ID, vertex value, edge value) using separate writers. | Class | org.apache.giraph.hive.jython | Giraph |
|
| JythonVertexValueFactory | VertexValueFactory that creates vertex IDs which are Jython classes. | Class | org.apache.giraph.jython.factories | Giraph |
|
| JythonWrapperBase | Base class for wrapping Jython objectsSee Also:Serialized Form | Class | org.apache.giraph.jython.wrappers | Giraph |
|
| JythonWritableWrapper | Wraps a Jython object, adding WritableComparable interface. | Class | org.apache.giraph.jython.wrappers | Giraph |
|
| KeyFactory | Class used to convert strings into more complex keys. | Class | org.apache.giraph.io.gora.utils | Giraph |
|
| Language | Programming language that something is implemented inEnum Constant Summary | Class | org.apache.giraph.graph | Giraph |
|
| LanguageAndType | A class/type with the language. | Class | org.apache.giraph.hive.common | Giraph |
|
| LocalData | | Class | org.apache.giraph.worker | Giraph |
|
| LoggerUtils | | Class | org.apache.giraph.utils | Giraph |
|
| LogStacktraceCallable | A wrapper to improve debugging. | Class | org.apache.giraph.utils | Giraph |
|
| LogVersions | Logs versions of Giraph dependencies on job start. | Class | org.apache.giraph.utils | Giraph |
|
| LongAbstractListMessageStore | Special message store to be used when ids are LongWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects and | Class | org.apache.giraph.comm.messages.primitives.long_id | Giraph |
|
| LongAbstractMessageStore | Special message store to be used when ids are LongWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects and | Class | org.apache.giraph.comm.messages.primitives.long_id | Giraph |
|
| LongAndTimeUnit | | Class | org.apache.giraph.metrics | Giraph |
|
| LongByteArrayMessageStore | Special message store to be used when ids are LongWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects and | Class | org.apache.giraph.comm.messages.primitives.long_id | Giraph |
|
| LongByteHiveToMapping | | Class | org.apache.giraph.hive.input.mapping.examples | Giraph |
|
| LongByteMappingStore | An implementation of MappingStore Methods implemented here are thread safe by default because it is guaranteed | Class | org.apache.giraph.mapping | Giraph |
|
| LongByteTranslateEdge | Basic implementation of Translate Edge where I = LongWritable & B = ByteWritable | Class | org.apache.giraph.mapping.translate | Giraph |
|
| LongByteTranslateEdge .DoubleEdgeValue | | Class | org.apache.giraph.mapping.translate.LongByteTranslateEdge | Giraph |
|
| LongByteTranslateEdge .FloatEdgeValue | | Class | org.apache.giraph.mapping.translate.LongByteTranslateEdge | Giraph |
|
| LongByteTranslateEdge .IntEdgeValue | | Class | org.apache.giraph.mapping.translate.LongByteTranslateEdge | Giraph |
|
| LongByteTranslateEdge .LongEdgeValue | | Class | org.apache.giraph.mapping.translate.LongByteTranslateEdge | Giraph |
|
| LongByteTranslateEdge .NoEdgeValue | | Class | org.apache.giraph.mapping.translate.LongByteTranslateEdge | Giraph |
|
| LongConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| LongDenseMatrix | A long matrix holds the values of the entries in long vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| LongDenseMatrixSumAggregator | | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| LongDenseVector | The long dense vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| LongDenseVectorSumAggregator | The long dense vector aggregator is used to aggregate long dense vectors. | Class | org.apache.giraph.aggregators.matrix.dense | Giraph |
|
| LongDoubleArrayEdges | values, backed by dynamic primitive arrays. | Class | org.apache.giraph.edge | Giraph |
|
| LongDoubleDoubleAdjacencyListVertexInputFormat | InputFormat for reading graphs stored as (ordered) adjacency lists with the vertex ids longs and the vertex values and edges doubles. | Class | org.apache.giraph.io.formats | Giraph |
|
| LongDoubleDoubleTextInputFormat | Simple text-based VertexInputFormat for unweighted graphs with long ids. | Class | org.apache.giraph.examples | Giraph |
|
| LongDoubleFloatTextInputFormat | Simple text-based VertexInputFormat for weighted graphs with long ids. | Class | org.apache.giraph.examples | Giraph |
|
| LongDoubleHashMapEdges | OutEdges implementation with long ids and double edge values, backed by a Long2DoubleOpenHashMap. | Class | org.apache.giraph.edge | Giraph |
|
| LongDoubleMessageStore | Special message store to be used when ids are LongWritable and messages are DoubleWritable and messageCombiner is used. | Class | org.apache.giraph.comm.messages.primitives | Giraph |
|
| LongDoubleNullTextInputFormat | Input format for unweighted graphs with long ids. | Class | org.apache.giraph.examples | Giraph |
|
| LongEdgeStore | Special edge store to be used when ids are LongWritable. | Class | org.apache.giraph.edge.primitives | Giraph |
|
| LongInt2ByteHiveToMapping | Long VertexId, Int Mapping target -> Byte MappingTarget implementation of HiveToMapping | Class | org.apache.giraph.hive.input.mapping.examples | Giraph |
|
| LongLongNullTextInputFormat | Simple text-based VertexInputFormat for unweighted graphs with long ids. | Class | org.apache.giraph.io.formats | Giraph |
|
| LongMappingStorePartitionerFactory | Factory for long-byte mapping based partitioners. | Class | org.apache.giraph.partition | Giraph |
|
| LongMaxAggregator | Aggregator for getting max long value. | Class | org.apache.giraph.aggregators | Giraph |
|
| LongMinAggregator | Aggregator for getting min long value. | Class | org.apache.giraph.aggregators | Giraph |
|
| LongNullArrayEdges | values, backed by a dynamic primitive array. | Class | org.apache.giraph.edge | Giraph |
|
| LongNullHashSetEdges | OutEdges implementation with long ids and null edge values, backed by a LongOpenHashSet. | Class | org.apache.giraph.edge | Giraph |
|
| LongOverwriteAggregator | Aggregator that stores a value that is overwritten once another value is aggregated. | Class | org.apache.giraph.aggregators | Giraph |
|
| LongPointerListMessageStore | This stores messages in ExtendedByteArrayOutputBuffer | Class | org.apache.giraph.comm.messages.primitives.long_id | Giraph |
|
| LongProductAggregator | Aggregator for calculating products of long values. | Class | org.apache.giraph.aggregators | Giraph |
|
| LongSparseMatrix | A long matrix holds the values of the entries in long vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| LongSparseMatrixSumAggregator | The long matrix aggregator is used to register and aggregate long matrices. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| LongSparseVector | The long vector holds the values of a particular row. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| LongSparseVectorSumAggregator | The long vector aggregator is used to aggregate long vectors. | Class | org.apache.giraph.aggregators.matrix.sparse | Giraph |
|
| LongSumAggregator | Aggregator for summing up long values. | Class | org.apache.giraph.aggregators | Giraph |
|
| LongToLongWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| LongTypeOps | TypeOps implementation for working with LongWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| LongWritableToLongUnwrapper | | Class | org.apache.giraph.types | Giraph |
|
| MapMutableEdge | Helper class for a mutable edge that modifies the backing map entry. | Class | org.apache.giraph.edge | Giraph |
|
| MappingEntry | | Class | org.apache.giraph.mapping | Giraph |
|
| MappingInputFormat | Use this to load data for a BSP application. | Class | org.apache.giraph.io | Giraph |
|
| MappingInputSplitsCallable | Load as many mapping input splits as possible. | Class | org.apache.giraph.worker | Giraph |
|
| MappingInputSplitsCallableFactory | Factory for MappingInputSplitsCallables. | Class | org.apache.giraph.worker | Giraph |
|
| MappingReader | Will read the mapping from an input split. | Class | org.apache.giraph.io | Giraph |
|
| MappingReaderWrapper | | Class | org.apache.giraph.io.iterables | Giraph |
|
| MappingStore | MappingStore used to store the vertexId - target map supplied by user Methods implemented in this class need to be thread safe | Interface | org.apache.giraph.mapping | Giraph |
|
| MappingStoreOps | Interface of operations that can be done on mapping store once it is fully loaded | Interface | org.apache.giraph.mapping | Giraph |
|
| MapTypeOps | TypeOps implementation for working with MapWritable typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| MasterAggregatorHandler | | Class | org.apache.giraph.master | Giraph |
|
| MasterAggregatorUsage | | Interface | org.apache.giraph.master | Giraph |
|
| MasterClient | | Interface | org.apache.giraph.comm | Giraph |
|
| MasterCompute | Interface for defining a master vertex that can perform centralized computation between supersteps. | Class | org.apache.giraph.master | Giraph |
|
| MasterGlobalCommUsage | Master compute can access reduce and broadcast methods through this interface, from masterCompute method. | Interface | org.apache.giraph.master | Giraph |
|
| MasterGraphPartitioner | Determines how to divide the graph into partitions, how to manipulate partitions and then how to assign those partitions to workers. | Interface | org.apache.giraph.partition | Giraph |
|
| MasterInfo | Information about the master that is sent to other workers. | Class | org.apache.giraph.master | Giraph |
|
| MasterLoggingAggregator | Helper class for using aggregator which gathers log messages from workers and prints them on master. | Class | org.apache.giraph.utils | Giraph |
|
| MasterObserver | Observer for Master. | Interface | org.apache.giraph.master | Giraph |
|
| MasterRequest | | Interface | org.apache.giraph.comm.requests | Giraph |
|
| MasterRequestServerHandler | | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| MasterRequestServerHandler .Factory | | Class | org.apache.giraph.comm.netty.handler.MasterRequestServerHandler | Giraph |
|
| MasterServer | | Interface | org.apache.giraph.comm | Giraph |
|
| MasterThread | Master thread that will coordinate the activities of the tasks. | Class | org.apache.giraph.master | Giraph |
|
| MathUtils | | Class | org.apache.giraph.utils | Giraph |
|
| MatrixSumAggregator | The abstract matrix aggregator contains the prefix name of the vector aggregators that have the values of the rows. | Class | org.apache.giraph.aggregators.matrix | Giraph |
|
| MaxComputation | Simple algorithm that computes the max value in the graph. | Class | org.apache.giraph.examples | Giraph |
|
| MemoryUtils | Helper static methods for tracking memory usage. | Class | org.apache.giraph.utils | Giraph |
|
| MessageCombiner | Abstract class to extend for combining messages sent to the same vertex. | Class | org.apache.giraph.combiner | Giraph |
|
| MessageEncodeAndStoreType | enum MessageEncodeAndStoreTypeThere are two types of message-stores currently | Class | org.apache.giraph.comm.messages | Giraph |
|
| MessagesIterable | | Class | org.apache.giraph.comm.messages | Giraph |
|
| MessageStore | | Interface | org.apache.giraph.comm.messages | Giraph |
|
| MessageStoreFactory | | Interface | org.apache.giraph.comm.messages | Giraph |
|
| MessageValueFactory | Factory class to create default message values. | Interface | org.apache.giraph.factories | Giraph |
|
| MeterDesc | Description for Meters used in Giraph. | Class | org.apache.giraph.metrics | Giraph |
|
| MetricNames | | Interface | org.apache.giraph.metrics | Giraph |
|
| MetricsRegistryDebugger | A simple MetricsRegistry listener that prints every Metric added/removed. | Class | org.apache.giraph.metrics | Giraph |
|
| MinimumDoubleMessageCombiner | MessageCombiner which finds the minimum of DoubleWritable. | Class | org.apache.giraph.combiner | Giraph |
|
| MinimumIntMessageCombiner | | Class | org.apache.giraph.combiner | Giraph |
|
| MultiEdgeInputFormat | Edge input format which wraps several edge input formats. | Class | org.apache.giraph.io.formats.multi | Giraph |
|
| MultiInputUtils | Utility methods used by MultiVertexInputFormat and MultiEdgeInputFormat | Class | org.apache.giraph.io.formats.multi | Giraph |
|
| MultiRandomAccessOutEdges | Interface for OutEdges implementations that provide efficient random access to the edges given the target vertex id. | Interface | org.apache.giraph.edge | Giraph |
|
| MultiThreadedSuperstepOutput | | Class | org.apache.giraph.io.superstep_output | Giraph |
|
| MultiVertexInputFormat | Vertex input format which wraps several vertex input formats. | Class | org.apache.giraph.io.formats.multi | Giraph |
|
| MutableEdge | An edge whose value can be modified. | Interface | org.apache.giraph.edge | Giraph |
|
| MutableEdgesIterable | Helper class to provide a mutable iterable over the edges when the chosen OutEdges doesn't offer a specialized one. | Class | org.apache.giraph.edge | Giraph |
|
| MutableEdgesWrapper | Helper class that wraps the current out-edges and inserts them into a new data structure as they are iterated over. | Class | org.apache.giraph.edge | Giraph |
|
| MutableOutEdges | Interface for OutEdges implementations that have an optimized mutable edge iterator. | Interface | org.apache.giraph.edge | Giraph |
|
| NettyClient | Netty client for sending requests. | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyMasterClient | | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyMasterServer | | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyServer | | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyWorkerAggregatorRequestProcessor | | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyWorkerClient | Takes users facing APIs in WorkerClient and implements them using the available WritableRequest objects. | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyWorkerClientRequestProcessor | Aggregate requests and sends them to the thread-safe NettyClient. | Class | org.apache.giraph.comm.netty | Giraph |
|
| NettyWorkerServer | Netty worker server that implement WorkerServer and contains the actual ServerData. | Class | org.apache.giraph.comm.netty | Giraph |
|
| NoOpMetricsRegistry | An empty MetricsRegistry, used to easily turn off all metrics without affecting client code. | Class | org.apache.giraph.metrics | Giraph |
|
| NoOpSuperstepOutput | Class to use as SuperstepOutput when we don't have output during computation. | Class | org.apache.giraph.io.superstep_output | Giraph |
|
| NormalizingLongDoubleDoubleTextInputFormat | Simple text-based VertexInputFormat for unweighted graphs with long ids. | Class | org.apache.giraph.examples | Giraph |
|
| OneMessagePerVertexStore | message per vertex. | Class | org.apache.giraph.comm.messages | Giraph |
|
| OneMessageToManyIdsIterator | VertexIdData iterator for ByteArrayOneMessageToManyIds | Class | org.apache.giraph.utils | Giraph |
|
| OnSameReduceOperation | ReduceOperation object when single object being reduced is of same type as reduced value. | Class | org.apache.giraph.reducers | Giraph |
|
| OutboundByteCounter | Keep track of the bytes sent and provide some metrics when desired as part of the Netty Channel stack. | Class | org.apache.giraph.comm.netty | Giraph |
|
| OutEdges | Interface for data structures that store out-edges for a vertex. | Interface | org.apache.giraph.edge | Giraph |
|
| OwnerAggregatorServerData | Class for holding aggregators which current worker owns, and aggregating partial aggregator values from workers. | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| PageRankBenchmark | | Class | org.apache.giraph.benchmark | Giraph |
|
| PageRankComputation | are floats, and graph is unweighted. | Class | org.apache.giraph.benchmark | Giraph |
|
| PageRankComputation | The PageRank algorithm, with uniform transition probabilities on the edges http://en. | Class | org.apache.giraph.examples | Giraph |
|
| PairList | Collection to keep pairs in, without creating a wrapper object around each pair of objects. | Class | org.apache.giraph.utils | Giraph |
|
| Partition | A generic container that stores vertices. | Interface | org.apache.giraph.partition | Giraph |
|
| PartitionBalancer | Helper class for balancing partitions across a set of workers. | Class | org.apache.giraph.partition | Giraph |
|
| PartitionDiskBackedMessageStore | Message storage with in-memory map of messages and with support for flushing all the messages to the disk. | Class | org.apache.giraph.comm.messages.out_of_core | Giraph |
|
| PartitionExchange | Describes what is required to send and wait for in a potential partition exchange between workers. | Class | org.apache.giraph.partition | Giraph |
|
| PartitionMessage | Small wrapper that holds a reference to vertex message and knows partition id. | Class | org.apache.giraph.comm.messages.queue | Giraph |
|
| PartitionOwner | Metadata about ownership of a partition. | Interface | org.apache.giraph.partition | Giraph |
|
| PartitionStats | Used to keep track of statistics of every Partition. | Class | org.apache.giraph.partition | Giraph |
|
| PartitionStore | Structure that stores partitions for a worker. | Class | org.apache.giraph.partition | Giraph |
|
| PartitionUtils | Helper class for Partition related operations. | Class | org.apache.giraph.partition | Giraph |
|
| PerGraphTypeBoolean | | Class | org.apache.giraph.conf | Giraph |
|
| PerGraphTypeBooleanConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| PerGraphTypeEnum | | Class | org.apache.giraph.conf | Giraph |
|
| PerGraphTypeEnumConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| PipelineUtils | | Class | org.apache.giraph.utils | Giraph |
|
| PointerListMessagesIterable | | Class | org.apache.giraph.comm.messages | Giraph |
|
| PointerListPerVertexStore | stored as a list of long pointers to extended data output objects Used when there is no combiner provided. | Class | org.apache.giraph.comm.messages | Giraph |
|
| PredicateLock | A lock with a predicate that was be used to synchronize events and keep the job context updated while waiting. | Class | org.apache.giraph.zk | Giraph |
|
| PrimitiveIdTypeOps | Additional type operations to TypeOps for types that can be IDs, and so can be used as keys in maps and values in sets. | Interface | org.apache.giraph.types.ops | Giraph |
|
| PrimitiveTypeOps | Type operations, allowing working generically with types, but still having efficient code. | Interface | org.apache.giraph.types.ops | Giraph |
|
| PrimitiveValueReader | | Class | org.apache.giraph.hive.primitives | Giraph |
|
| PrimitiveValueWriter | | Class | org.apache.giraph.hive.primitives | Giraph |
|
| ProgressableUtils | | Class | org.apache.giraph.utils | Giraph |
|
| PseudoRandomEdgeInputFormat | This EdgeInputFormat generates pseudo-random edges on the fly. | Class | org.apache.giraph.io.formats | Giraph |
|
| PseudoRandomInputFormatConstants | Contains constants for configuring pseudo-random input formats. | Class | org.apache.giraph.io.formats | Giraph |
|
| PseudoRandomIntNullLocalEdgesHelper | Helper class to generate pseudo-random local edges. | Class | org.apache.giraph.io.formats | Giraph |
|
| PseudoRandomIntNullVertexInputFormat | VertexInputFormat for large scale testing, like PseudoRandomVertexInputFormat, but for the unweighted graphs | Class | org.apache.giraph.io.formats | Giraph |
|
| PseudoRandomLocalEdgesHelper | Helper class to generate pseudo-random local edges. | Class | org.apache.giraph.io.formats | Giraph |
|
| PseudoRandomUtils | | Class | org.apache.giraph.io.formats | Giraph |
|
| PseudoRandomVertexInputFormat | This VertexInputFormat is meant for large scale testing. | Class | org.apache.giraph.io.formats | Giraph |
|
| RandomMessageBenchmark | Random Message Benchmark for evaluating the messaging performance. | Class | org.apache.giraph.benchmark | Giraph |
|
| RandomMessageBenchmark .RandomMessageBenchmarkMasterCompute | Master compute associated with RandomMessageBenchmark. | Class | org.apache.giraph.benchmark.RandomMessageBenchmark | Giraph |
|
| RandomMessageBenchmark .RandomMessageBenchmarkWorkerContext | WorkerContext forRandomMessageBenchmark. | Class | org.apache.giraph.benchmark.RandomMessageBenchmark | Giraph |
|
| RandomMessageBenchmark .RandomMessageComputation | | Class | org.apache.giraph.benchmark.RandomMessageBenchmark | Giraph |
|
| RandomWalkComputation | | Class | org.apache.giraph.examples | Giraph |
|
| RandomWalkVertexMasterCompute | Master compute associated with RandomWalkComputation. | Class | org.apache.giraph.examples | Giraph |
|
| RandomWalkWithRestartComputation | Executes RandomWalkWithRestart, a random walk on the graph which is biased towards a source vertex. | Class | org.apache.giraph.examples | Giraph |
|
| RandomWalkWorkerContext | Worker context for random walks. | Class | org.apache.giraph.examples | Giraph |
|
| 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 | Class | org.apache.giraph.utils | Giraph |
|
| RecordReaderWrapper | | Class | org.apache.giraph.hive.input | Giraph |
|
| ReduceOperation | Reduce operations defining how to reduce single values passed on workers, into partial values on workers, and then | Interface | org.apache.giraph.reducers | Giraph |
|
| Reducer | Object responsible for performing reducing operation. | Class | org.apache.giraph.reducers | Giraph |
|
| ReducersBenchmark | Benchmark for reducers. | Class | org.apache.giraph.benchmark | Giraph |
|
| ReducersBenchmark .ReducersBenchmarkComputation | | Class | org.apache.giraph.benchmark.ReducersBenchmark | Giraph |
|
| ReducersBenchmark .ReducersBenchmarkMasterCompute | | Class | org.apache.giraph.benchmark.ReducersBenchmark | Giraph |
|
| ReducersBenchmark .ReducersBenchmarkWorkerContext | | Class | org.apache.giraph.benchmark.ReducersBenchmark | Giraph |
|
| ReducersBenchmark .TestLongSumReducer | | Class | org.apache.giraph.benchmark.ReducersBenchmark | Giraph |
|
| ReflectionUtils | Helper methods to get type arguments to generic classes. | Class | org.apache.giraph.utils | Giraph |
|
| RepresentativeByteStructIterable | The objects provided by the iterators generated from this object have lifetimes only until next() is called. | Class | org.apache.giraph.utils | Giraph |
|
| RepresentativeByteStructIterator | The objects provided by this iterator have lifetimes only until next() is called. | Class | org.apache.giraph.utils | Giraph |
|
| RequestDecoder | Decodes encoded requests from the client. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| RequestEncoder | Requests have a request type and an encoded request. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| RequestInfo | | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| RequestServerHandler | Generic handler of requests. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| RequestServerHandler .Factory | | Interface | org.apache.giraph.comm.netty.handler.RequestServerHandler | Giraph |
|
| RequestType | | Class | org.apache.giraph.comm.requests | Giraph |
|
| RequestUtils | | Class | org.apache.giraph.utils | Giraph |
|
| ResetSuperstepMetricsObserver | Observer for users of per-superstep counters. | Interface | org.apache.giraph.metrics | Giraph |
|
| ResettableIterator | Defines an iterator that can iterated over multiple times, by rewinding it via reset() function. | Interface | org.apache.giraph.types.ops.collections | Giraph |
|
| ResponseClientHandler | Generic handler of responses. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| ResponseEncoder | How a server should respond to a client. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| RetryableJobProgressTrackerClient | Wrapper around JobProgressTracker which retires to connect and swallows exceptions so app wouldn't crash if something goes wrong with progress | Class | org.apache.giraph.graph | Giraph |
|
| ReusableEdge | A complete edge, the target vertex and the edge value. | Interface | org.apache.giraph.edge | Giraph |
|
| ReuseObjectsOutEdges | Empty interface to characterize OutEdges implementations that don't keep references to the Edge (or id and value) objects they are passed. | Interface | org.apache.giraph.edge | Giraph |
|
| ReusesObjectsPartition | Empty interface to characterize Partition implementations that don't keep references to the Vertex objects they are passed. | Interface | org.apache.giraph.partition | Giraph |
|
| ReverseEdgeDuplicator | An EdgeReader that creates the opposite direction edge for each edge read. | Class | org.apache.giraph.io | Giraph |
|
| RexsterEdgeInputFormat | Abstract class that users should subclass to use their own Rexster based vertex input format. | Class | org.apache.giraph.rexster.io | Giraph |
|
| RexsterEdgeOutputFormat | Abstract class that users should subclass to use their own Rexster based edge output format. | Class | org.apache.giraph.rexster.io | Giraph |
|
| RexsterInputSplit | A InputSplit that spans a set of vertices. | Class | org.apache.giraph.rexster.io | Giraph |
|
| RexsterLongDoubleDoubleEdgeOutputFormat | Rexster Edge Output Format for Long ID's, Double Vertex values and Double edge values. | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongDoubleDoubleVertexInputFormat | | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongDoubleDoubleVertexOutputFormat | Rexster Vertex Output Format for Long ID's, Double Vertex values and Double edge values. | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongDoubleEdgeInputFormat | | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongDoubleFloatEdgeOutputFormat | | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongDoubleFloatVertexInputFormat | | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongDoubleFloatVertexOutputFormat | | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterLongFloatEdgeInputFormat | | Class | org.apache.giraph.rexster.io.formats | Giraph |
|
| RexsterUtils | | Class | org.apache.giraph.rexster.utils | Giraph |
|
| RexsterUtils .Edge | | Class | org.apache.giraph.rexster.utils.RexsterUtils | Giraph |
|
| RexsterUtils .Vertex | | Class | org.apache.giraph.rexster.utils.RexsterUtils | Giraph |
|
| RexsterVertexInputFormat | Abstract class that users should subclass to use their own Rexster based vertex input format. | Class | org.apache.giraph.rexster.io | Giraph |
|
| RexsterVertexOutputFormat | Abstract class that users should subclass to use their own Rexster based vertex onput format. | Class | org.apache.giraph.rexster.io | Giraph |
|
| SaslClientHandler | | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| SaslCompleteRequest | Reply from server to client after SASL authentication completes. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SaslNettyClient | | Class | org.apache.giraph.comm.netty | Giraph |
|
| SaslNettyServer | Encapsulates SASL server logic for Giraph BSP worker servers. | Class | org.apache.giraph.comm.netty | Giraph |
|
| SaslNettyServer .SaslDigestCallbackHandler | | Class | org.apache.giraph.comm.netty.SaslNettyServer | Giraph |
|
| SaslServerHandler | Generate SASL response tokens to client SASL tokens, allowing clients to authenticate themselves with this server. | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| SaslServerHandler .Factory | | Class | org.apache.giraph.comm.netty.handler.SaslServerHandler | Giraph |
|
| SaslTokenMessageRequest | Send and receive SASL tokens. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SccComputation | Finds strongly connected components of the graph. | Class | org.apache.giraph.examples.scc | Giraph |
|
| SccLongLongNullTextInputFormat | Simple text-based VertexInputFormat for unweighted graphs with long ids. | Class | org.apache.giraph.examples.scc | Giraph |
|
| SccPhaseMasterCompute | This master compute keeps track of what phase is being currently executed by the Strongly Connected Components computation. | Class | org.apache.giraph.examples.scc | Giraph |
|
| SccPhaseMasterCompute .Phases | Vertex convergence in SCCMaximum id propagation | Class | org.apache.giraph.examples.scc.SccPhaseMasterCompute | Giraph |
|
| SccVertexValue | Vertex value for the Strongly Connected Components algorithm. | Class | org.apache.giraph.examples.scc | Giraph |
|
| ScriptLoader | Loads scripts written by user in other languages, for example Jython. | Class | org.apache.giraph.scripting | Giraph |
|
| SendAggregatorsToOwnerRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendAggregatorsToWorkerRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendDataCache | An abstract structure for caching data by partitions to be sent to workers in bulk. | Class | org.apache.giraph.comm | Giraph |
|
| SendEdgeCache | Aggregates the edges to be sent to workers so they can be sent in bulk. | Class | org.apache.giraph.comm | Giraph |
|
| SendGlobalCommCache | Takes and serializes global communication values and keeps them grouped by owner partition id, to be sent in bulk. | Class | org.apache.giraph.comm.aggregators | Giraph |
|
| SendMessageCache | Aggregates the messages to be sent to workers so they can be sent in bulk. | Class | org.apache.giraph.comm | Giraph |
|
| SendMutationsCache | | Class | org.apache.giraph.comm | Giraph |
|
| SendOneMessageToManyCache | | Class | org.apache.giraph.comm | Giraph |
|
| SendPartitionCache | Caches partition vertices prior to sending. | Class | org.apache.giraph.comm | Giraph |
|
| SendPartitionCurrentMessagesRequest | Send a collection of vertex messages for a partition. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendPartitionMutationsRequest | Send a collection of vertex mutations for a partition. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendReducedToMasterRequest | Request to send final aggregated values from worker which owns aggregators to the master | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendVertexIdDataCache | An abstract structure for caching data indexed by vertex id, to be sent to workers in bulk. | Class | org.apache.giraph.comm | Giraph |
|
| SendVertexRequest | Send a collection of vertices for a partition. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerAggregatorsRequest | Request to send partial aggregated values for current superstep (values which were computed by one worker's vertices) | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerDataRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerEdgesRequest | Send a collection of edges for a partition. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerMessagesRequest | Send a collection of vertex messages for a partition. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerOneMessageToManyRequest | Send a collection of ByteArrayOneMessageToManyIds messages to a worker. | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerToWorkerMessageRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| SendWorkerVerticesRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| SequenceFileVertexInputFormat | Sequence file vertex input format based on SequenceFileInputFormat. | Class | org.apache.giraph.io.formats | Giraph |
|
| SequenceFileVertexInputFormat .SequenceFileVertexReader | Vertex reader used with SequenceFileVertexInputFormat. | Class | org.apache.giraph.io.formats.SequenceFileVertexInputFormat | Giraph |
|
| SequenceFileVertexOutputFormat | Sequence file vertex output format. | Class | org.apache.giraph.io.formats | Giraph |
|
| SequentialFileMessageStore | Used for writing and reading collection of messages to the disk. | Class | org.apache.giraph.comm.messages.out_of_core | Giraph |
|
| ServerData | | Class | org.apache.giraph.comm | Giraph |
|
| ShortestPathsBenchmark | Single-source shortest paths benchmark. | Class | org.apache.giraph.benchmark | Giraph |
|
| ShortestPathsComputation | Shortest paths algorithm. | Class | org.apache.giraph.benchmark | Giraph |
|
| ShortToIntWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| ShortToLongWritableWrapper | | Class | org.apache.giraph.types | Giraph |
|
| SimpleAggregatorWriter | This is a simple example for an aggregator writer. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleCheckpoint | An example that simply uses its id, value, and edges to compute new data every iteration to verify that checkpoint restarting works. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleCheckpoint .SimpleCheckpointComputation | | Class | org.apache.giraph.examples.SimpleCheckpoint | Giraph |
|
| SimpleCheckpoint .SimpleCheckpointVertexMasterCompute | Master compute associated with SimpleCheckpoint. | Class | org.apache.giraph.examples.SimpleCheckpoint | Giraph |
|
| SimpleCheckpoint .SimpleCheckpointVertexWorkerContext | Worker context associated with SimpleCheckpoint. | Class | org.apache.giraph.examples.SimpleCheckpoint | Giraph |
|
| SimpleCombinerComputation | Test whether messages can go through a combiner. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleEdgeStore | Simple in memory edge store which supports any type of ids. | Class | org.apache.giraph.edge | Giraph |
|
| SimpleFailComputation | | Class | org.apache.giraph.examples | Giraph |
|
| SimpleHiveToEdge | | Class | org.apache.giraph.hive.input.edge | Giraph |
|
| SimpleHiveToMapping | | Class | org.apache.giraph.hive.input.mapping | Giraph |
|
| SimpleHiveToVertex | | Class | org.apache.giraph.hive.input.vertex | Giraph |
|
| SimpleInDegreeCountComputation | Simple function to return the out degree for each vertex. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleIntRangePartitionerFactory | Factory for simple range-based partitioners based on integer vertex ids. | Class | org.apache.giraph.partition | Giraph |
|
| SimpleLongDoubleDoubleDoubleIdentityComputation | A simple use of the Identity Vertex for taking care of Long, Double, Double, Double type Inputformat Good for use with | Class | org.apache.giraph.examples | Giraph |
|
| SimpleLongRangePartitionerFactory | Factory for simple range-based partitioners based on long vertex ids. | Class | org.apache.giraph.partition | Giraph |
|
| SimpleMasterComputeComputation | | Class | org.apache.giraph.examples | Giraph |
|
| SimpleMasterComputeComputation .SimpleMasterCompute | MasterCompute used with SimpleMasterComputeComputation. | Class | org.apache.giraph.examples.SimpleMasterComputeComputation | Giraph |
|
| SimpleMasterComputeComputation .SimpleMasterComputeWorkerContext | Worker context used with SimpleMasterComputeComputation. | Class | org.apache.giraph.examples.SimpleMasterComputeComputation | Giraph |
|
| SimpleMasterPartitioner | Abstracts and implements all MasterGraphPartitioner logic on top of a single user function - getWorkerIndex. | Class | org.apache.giraph.partition | Giraph |
|
| SimpleMessageStore | Abstract class for MessageStore which allows any kind of object to hold messages for one vertex. | Class | org.apache.giraph.comm.messages | Giraph |
|
| SimpleMsgComputation | Test whether messages can be sent and received by vertices. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleMutateGraphComputation | Vertex to allow unit testing of graph mutations. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleMutateGraphComputation .SimpleMutateGraphVertexWorkerContext | Worker context used with SimpleMutateGraphComputation. | Class | org.apache.giraph.examples.SimpleMutateGraphComputation | Giraph |
|
| SimpleNoEdgesHiveToVertex | Simple implementation of HiveToVertex when each vertex is in the one row of the input, and there are no edges in vertex input. | Class | org.apache.giraph.hive.input.vertex | Giraph |
|
| SimpleOutDegreeCountComputation | Simple function to return the out degree for each vertex. | Class | org.apache.giraph.examples | Giraph |
|
| SimplePageRankComputation | Demonstrates the basic Pregel PageRank implementation. | Class | org.apache.giraph.examples | Giraph |
|
| SimplePageRankComputation .SimplePageRankMasterCompute | Master compute associated with SimplePageRankComputation. | Class | org.apache.giraph.examples.SimplePageRankComputation | Giraph |
|
| SimplePageRankComputation .SimplePageRankVertexInputFormat | | Class | org.apache.giraph.examples.SimplePageRankComputation | Giraph |
|
| SimplePageRankComputation .SimplePageRankVertexOutputFormat | | Class | org.apache.giraph.examples.SimplePageRankComputation | Giraph |
|
| SimplePageRankComputation .SimplePageRankVertexReader | | Class | org.apache.giraph.examples.SimplePageRankComputation | Giraph |
|
| SimplePageRankComputation .SimplePageRankWorkerContext | Worker context used with SimplePageRankComputation. | Class | org.apache.giraph.examples.SimplePageRankComputation | Giraph |
|
| SimplePartition | A simple map-based container that stores vertices. | Class | org.apache.giraph.partition | Giraph |
|
| SimplePartitionerFactory | Abstracts and implements all GraphPartitionerFactory logic on top of two functions which define partitioning scheme: | Class | org.apache.giraph.partition | Giraph |
|
| SimplePartitionStore | A simple in-memory partition store. | Class | org.apache.giraph.partition | Giraph |
|
| SimpleShortestPathsComputation | Demonstrates the basic Pregel shortest paths implementation. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleSumMessageCombiner | MessageCombiner which sums up IntWritable message values. | Class | org.apache.giraph.combiner | Giraph |
|
| SimpleSuperstepComputation | | Class | org.apache.giraph.examples | Giraph |
|
| SimpleSuperstepComputation .SimpleSuperstepVertexInputFormat | | Class | org.apache.giraph.examples.SimpleSuperstepComputation | Giraph |
|
| SimpleSuperstepComputation .SimpleSuperstepVertexOutputFormat | | Class | org.apache.giraph.examples.SimpleSuperstepComputation | Giraph |
|
| SimpleSuperstepComputation .SimpleSuperstepVertexReader | | Class | org.apache.giraph.examples.SimpleSuperstepComputation | Giraph |
|
| SimpleTextVertexOutputFormat | Simple text based vertex output format example. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleTriangleClosingComputation | Demonstrates triangle closing in simple, unweighted graphs for Giraph. | Class | org.apache.giraph.examples | Giraph |
|
| SimpleTriangleClosingComputation .IntArrayListWritable | Utility class for delivering the array of vertices THIS vertex should connect with to close triangles with neighbors | Class | org.apache.giraph.examples.SimpleTriangleClosingComputation | Giraph |
|
| SimpleTriangleClosingComputation .Pair | | Class | org.apache.giraph.examples.SimpleTriangleClosingComputation | Giraph |
|
| SimpleVertexToHive | Simple implementation of VertexToHive when each Vertex is stored to one row in the output. | Class | org.apache.giraph.hive.output | Giraph |
|
| SimpleVertexWithWorkerContext | Fully runnable example of how to emit worker data to HDFS during a graph | Class | org.apache.giraph.examples | Giraph |
|
| SimpleVertexWithWorkerContext .EmitterWorkerContext | Example worker context to emit data as part of a superstep. | Class | org.apache.giraph.examples.SimpleVertexWithWorkerContext | Giraph |
|
| SimpleVertexWithWorkerContext .SimpleComputation | | Class | org.apache.giraph.examples.SimpleVertexWithWorkerContext | Giraph |
|
| SimpleVertexWriter | | Interface | org.apache.giraph.io | Giraph |
|
| SimpleWorkerPartitioner | Abstracts and implements all WorkerGraphPartitioner logic on top of a single user function - getPartitionIndex. | Class | org.apache.giraph.partition | Giraph |
|
| SrcIdDstIdEdgeValueTextOutputFormat | Write out Edge Value with Source and Destination ID, but not the vertex This is a demostration output format to show the possibility to separately | Class | org.apache.giraph.io.formats | Giraph |
|
| StrConfOption | | Class | org.apache.giraph.conf | Giraph |
|
| StrictRandomAccessOutEdges | Interface for OutEdges implementations that provide efficient random access to the edges given the target vertex id. | Interface | org.apache.giraph.edge | Giraph |
|
| SuperstepClasses | Holds Computation and MessageCombiner class. | Class | org.apache.giraph.master | Giraph |
|
| SuperstepHashPartitionerFactory | Example graph partitioner that builds on HashMasterPartitioner to send the partitions to the worker that matches the superstep. | Class | org.apache.giraph.integration | Giraph |
|
| SuperstepMetricsRegistry | Wrapper around MetricsRegistry for per-superstep metrics. | Class | org.apache.giraph.metrics | Giraph |
|
| SuperstepOutput | Interface for outputing data during the computation. | Interface | org.apache.giraph.io.superstep_output | Giraph |
|
| SuperstepState | State of a coordinated superstepEnum Constant Summary | Class | org.apache.giraph.bsp | Giraph |
|
| SynchronizedSuperstepOutput | | Class | org.apache.giraph.io.superstep_output | Giraph |
|
| SystemTime | | Class | org.apache.giraph.time | Giraph |
|
| TaskIdsPermitsBarrier | This barrier is used when we don't know how many events are we waiting on from the start. | Class | org.apache.giraph.utils | Giraph |
|
| TaskInfo | Abstract class for information about any task - worker or master. | Class | org.apache.giraph.graph | Giraph |
|
| TestComputationStateComputation | | Class | org.apache.giraph.examples | Giraph |
|
| TestComputationStateComputation .TestComputationStateWorkerContext | | Class | org.apache.giraph.examples.TestComputationStateComputation | Giraph |
|
| TestGraph | TestGraph class for in-memory testing. | Class | org.apache.giraph.utils | Giraph |
|
| TestMessageValueFactory | | Class | org.apache.giraph.factories | Giraph |
|
| TextAggregatorWriter | Default implementation of AggregatorWriter. | Class | org.apache.giraph.aggregators | Giraph |
|
| TextAppendAggregator | | Class | org.apache.giraph.aggregators | Giraph |
|
| TextDoubleDoubleAdjacencyListVertexInputFormat | Class to read graphs stored as adjacency lists with ids represented by Strings and values as doubles. | Class | org.apache.giraph.io.formats | Giraph |
|
| TextEdgeInputFormat | Abstract class that users should subclass to use their own text based edge output format. | Class | org.apache.giraph.io.formats | Giraph |
|
| TextEdgeOutputFormat | Abstract class that users should subclass to use their own text based edge output format. | Class | org.apache.giraph.io.formats | Giraph |
|
| TextTypeOps | TypeOps implementation for working with Text typeEnum Constant Summary | Class | org.apache.giraph.types.ops | Giraph |
|
| TextVertexInputFormat | Abstract class that users should subclass to use their own text based vertex input format. | Class | org.apache.giraph.io.formats | Giraph |
|
| TextVertexOutputFormat | Abstract class that users should subclass to use their own text based vertex output format. | Class | org.apache.giraph.io.formats | Giraph |
|
| TextVertexValueInputFormat | Abstract class that users should subclass to use their own text based vertex value input format. | Class | org.apache.giraph.io.formats | Giraph |
|
| ThreadUtils | Utility class for thread related functions. | Class | org.apache.giraph.utils | Giraph |
|
| Time | | Interface | org.apache.giraph.time | Giraph |
|
| TimedLogger | Print log messages only if the time is met. | Class | org.apache.giraph.utils | Giraph |
|
| Times | Utility methods for Time classes. | Class | org.apache.giraph.time | Giraph |
|
| TranslateEdge | Used to conduct expensive translation of edges during vertex input phase | Interface | org.apache.giraph.mapping.translate | Giraph |
|
| Trimmable | Interface for OutEdges and Vertex implementations capable to optimize | Interface | org.apache.giraph.utils | Giraph |
|
| TypeOps | Type operations, allowing working generically with mutable types, but still having efficient code. | Interface | org.apache.giraph.types.ops | Giraph |
|
| TypeOpsUtils | Utility functions for getting TypeOps instances from class types. | Class | org.apache.giraph.types.ops | Giraph |
|
| TypesHolder | Interface for classes that are parameterized by all of the Giraph types. | Interface | org.apache.giraph.conf | Giraph |
|
| UnsafeArrayReads | | Class | org.apache.giraph.utils | Giraph |
|
| UnsafeByteArrayInputStream | | Class | org.apache.giraph.utils | Giraph |
|
| UnsafeByteArrayOutputStream | | Class | org.apache.giraph.utils | Giraph |
|
| UnsafeReads | | Class | org.apache.giraph.utils | Giraph |
|
| UnsafeReusableByteArrayInput | UnsafeReusableByteArrayInput is a data structure to read from a byte buffer with a read pointer that can be moved to desired location | Class | org.apache.giraph.utils | Giraph |
|
| ValueFactories | Holder for factories to create user types. | Class | org.apache.giraph.factories | Giraph |
|
| ValueFactory | | Interface | org.apache.giraph.factories | Giraph |
|
| ValueGauge | A Gauge that holds a value. | Class | org.apache.giraph.metrics | Giraph |
|
| VerboseByteStructMessageWrite | | Class | org.apache.giraph.utils | Giraph |
|
| VerifyMessage | An example that simply uses its id, value, and edges to compute new data every iteration to verify that messages are sent and received at the | Class | org.apache.giraph.examples | Giraph |
|
| VerifyMessage .VerifiableMessage | Message that will be sent in VerifyMessage. | Class | org.apache.giraph.examples.VerifyMessage | Giraph |
|
| VerifyMessage .VerifyMessageComputation | Send and verify messages. | Class | org.apache.giraph.examples.VerifyMessage | Giraph |
|
| VerifyMessage .VerifyMessageComputation .VerifyMessageVertexWorkerContext | Worker context used with VerifyMessage. | Class | org.apache.giraph.examples.VerifyMessage.VerifyMessageComputation | Giraph |
|
| VerifyMessage .VerifyMessageMasterCompute | Master compute associated with VerifyMessage. | Class | org.apache.giraph.examples.VerifyMessage | Giraph |
|
| Vertex | Class which holds vertex id, data and edges. | Interface | org.apache.giraph.graph | Giraph |
|
| VertexChanges | | Interface | org.apache.giraph.graph | Giraph |
|
| VertexEdgeCount | Simple immutable structure for storing a final vertex and edge count. | Class | org.apache.giraph.graph | Giraph |
|
| VertexIdData | | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdDataIterator | Special iterator that reuses vertex ids and data objects so that the lifetime of the object is only until next() is called. | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdEdgeIterator | Special iterator that reuses vertex ids and edge objects so that the lifetime of the object is only until next() is called. | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdEdges | | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdFactory | Factory class to create default vertex IDs. | Interface | org.apache.giraph.factories | Giraph |
|
| VertexIdIterator | Common implementation for VertexIdEdgeIterator, VertexIdMessageIterator and VertexIdMessageBytesIterator. | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdMessageBytesIterator | Special iterator that reuses vertex ids and messages bytes so that the lifetime of the object is only until next() is called. | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdMessageIterator | Special iterator that reuses vertex ids and message objects so that the lifetime of the object is only until next() is called. | Interface | org.apache.giraph.utils | Giraph |
|
| VertexIdMessages | | Interface | org.apache.giraph.utils | Giraph |
|
| VertexInputFilter | Filters vertices on input. | Interface | org.apache.giraph.io.filters | Giraph |
|
| VertexInputFormat | Use this to load data for a BSP application. | Class | org.apache.giraph.io | Giraph |
|
| VertexInputFormatDescription | Description of the vertex input format - holds vertex input format class and all parameters specifically set for that vertex input format. | Class | org.apache.giraph.io.formats.multi | Giraph |
|
| VertexInputSplitsCallable | Load as many vertex input splits as possible. | Class | org.apache.giraph.worker | Giraph |
|
| VertexInputSplitsCallableFactory | Factory for VertexInputSplitsCallables. | Class | org.apache.giraph.worker | Giraph |
|
| VertexIterator | Iterates over vertices stored in an ExtendedDataOutput such that the ownership of the vertex id can be transferred to another object. | Class | org.apache.giraph.utils | Giraph |
|
| VertexMutations | | Class | org.apache.giraph.graph | Giraph |
|
| VertexOutputFormat | directly after the Hadoop OutputFormat. | Class | org.apache.giraph.io | Giraph |
|
| VertexReader | Analogous to Hadoop's RecordReader for vertices. | Class | org.apache.giraph.io | Giraph |
|
| VertexReaderWrapper | | Class | org.apache.giraph.io.iterables | Giraph |
|
| VertexResolver | Handles all the situations that can arise upon creation/removal of vertices and edges. | Interface | org.apache.giraph.graph | Giraph |
|
| VertexToHive | Interface for writing vertices to Hive. | Interface | org.apache.giraph.hive.output | Giraph |
|
| VertexValueCombiner | When vertex values with the same vertex id are loaded, this class specifies how to combine their vertex values. | Interface | org.apache.giraph.graph | Giraph |
|
| VertexValueFactory | Factory class to create default vertex values. | Interface | org.apache.giraph.factories | Giraph |
|
| VertexValueInputFormat | Vertex input format that only allows setting vertex id and value. | Class | org.apache.giraph.io | Giraph |
|
| VertexValueReader | Vertex reader for VertexValueInputFormat. | Class | org.apache.giraph.io | Giraph |
|
| VertexWithDoubleValueDoubleEdgeTextOutputFormat | Simple vertex output format for weighted graphs. | Class | org.apache.giraph.examples | Giraph |
|
| VertexWithDoubleValueNullEdgeTextOutputFormat | | Class | org.apache.giraph.examples | Giraph |
|
| VertexWriter | | Class | org.apache.giraph.io | Giraph |
|
| WattsStrogatzVertexInputFormat | Generates a random Watts-Strogatz graph by re-wiring a ring lattice. | Class | org.apache.giraph.io.formats | Giraph |
|
| WeightedPageRankBenchmark | | Class | org.apache.giraph.benchmark | Giraph |
|
| WeightedPageRankComputation | | Class | org.apache.giraph.benchmark | Giraph |
|
| WorkerAggregatorDelegator | Class for delegating WorkerAggregatorUsage and WorkerGlobalCommUsage methods to corresponding interface. | Class | org.apache.giraph.worker | Giraph |
|
| WorkerAggregatorHandler | | Class | org.apache.giraph.worker | Giraph |
|
| WorkerAggregatorRequestProcessor | | Interface | org.apache.giraph.comm.aggregators | Giraph |
|
| WorkerAggregatorUsage | | Interface | org.apache.giraph.worker | Giraph |
|
| WorkerBroadcastUsage | | Interface | org.apache.giraph.worker | Giraph |
|
| WorkerClient | | Interface | org.apache.giraph.comm | Giraph |
|
| WorkerClientRequestProcessor | | Interface | org.apache.giraph.comm | Giraph |
|
| WorkerContext | WorkerContext allows for the execution of user code on a per-worker basis. | Class | org.apache.giraph.worker | Giraph |
|
| WorkerGlobalCommUsage | Methods on worker can access broadcasted values and provide values to reduce through this interface | Interface | org.apache.giraph.worker | Giraph |
|
| WorkerGraphPartitioner | Stores the PartitionOwner objects from the master and provides the mapping of vertex to PartitionOwner. | Interface | org.apache.giraph.partition | Giraph |
|
| WorkerInfo | Information about a worker that is sent to the master and other workers. | Class | org.apache.giraph.worker | Giraph |
|
| WorkerObserver | Observer for worker. | Interface | org.apache.giraph.worker | Giraph |
|
| WorkerProgress | Stores information about a worker's progress that is periodically written to ZooKeeper with WorkerProgressWriter. | Class | org.apache.giraph.worker | Giraph |
|
| WorkerProgressWriter | | Class | org.apache.giraph.worker | Giraph |
|
| WorkerReduceUsage | | Interface | org.apache.giraph.worker | Giraph |
|
| WorkerRequest | | Interface | org.apache.giraph.comm.requests | Giraph |
|
| WorkerRequestReservedMap | | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| WorkerRequestServerHandler | | Class | org.apache.giraph.comm.netty.handler | Giraph |
|
| WorkerRequestServerHandler .Factory | | Class | org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler | Giraph |
|
| WorkerServer | Interface for message communication server. | Interface | org.apache.giraph.comm | Giraph |
|
| WorkerSuperstepMetrics | Per-superstep metrics for a Worker. | Class | org.apache.giraph.metrics | Giraph |
|
| WorkerThreadGlobalCommUsage | WorkerAggregatorUsage which can be used in each of the computation threads. | Interface | org.apache.giraph.worker | Giraph |
|
| WrappedEdgeInputFormat | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedEdgeOutputFormat | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedEdgeReader | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedMappingInputFormat | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedMappingReader | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedVertexInputFormat | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedVertexOutputFormat | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WrappedVertexReader | For internal use only. | Class | org.apache.giraph.io.internal | Giraph |
|
| WritableRequest | | Class | org.apache.giraph.comm.requests | Giraph |
|
| WritableUnwrapper | | Interface | org.apache.giraph.types | Giraph |
|
| WritableUnwrappers | Mapping of all the known Writable wrappers. | Class | org.apache.giraph.types | Giraph |
|
| WritableUtils | Helper static methods for working with Writable objects. | Class | org.apache.giraph.utils | Giraph |
|
| WritableWrapper | | Interface | org.apache.giraph.types | Giraph |
|
| WritableWrappers | Mapping of all the known Writable wrappers. | Class | org.apache.giraph.types | Giraph |
|
| WritableWriter | | Interface | org.apache.giraph.types.ops.collections | Giraph |
|
| YarnUtils | Utilities that can only compile with versions of Hadoop that support YARN, so they live here instead of o. | Class | org.apache.giraph.yarn | Giraph |
|
| YourKitContext | Convenience context for profiling. | Class | org.apache.giraph.utils | Giraph |
|
| YourKitProfiler | Helper for YourKit profiling from within the code. | Class | org.apache.giraph.utils | Giraph |
|
| ZooKeeperExt | ZooKeeper provides only atomic operations. | Class | org.apache.giraph.zk | Giraph |
|
| ZooKeeperExt .PathStat | | Class | org.apache.giraph.zk.ZooKeeperExt | Giraph |
|
| ZooKeeperManager | | Class | org.apache.giraph.zk | Giraph |
|
| ZooKeeperManager .State | State of the applicationApplication finished | Class | org.apache.giraph.zk.ZooKeeperManager | Giraph |
|
| ZooKeeperNodeCreator | | Class | org.apache.giraph.zk | Giraph |