Search Java Classes and Packages

Search Java Frameworks and Libraries

255581 classes and counting ...
Search Tips Index Status



# Classes and Interfaces in #Giraph - 800 results found.
NameDescriptionTypePackageFramework
AbstractComputationSee Computation for explanation of the interface.Classorg.apache.giraph.graphGiraph
AbstractConfOptionClassorg.apache.giraph.confGiraph
AbstractEdgeStoreBasic implementation of edges store, extended this to easily define simple and primitive edge storesClassorg.apache.giraph.edgeGiraph
AbstractHiveToEdgeClassorg.apache.giraph.hive.input.edgeGiraph
AbstractHiveToMappingClassorg.apache.giraph.hive.input.mappingGiraph
AbstractHiveToVertexClassorg.apache.giraph.hive.input.vertexGiraph
AbstractListPerVertexStoreAbstract Implementation of SimpleMessageStore where multiple messages are stored per vertex as a listClassorg.apache.giraph.comm.messagesGiraph
AbstractLongByteOpsClassorg.apache.giraph.mappingGiraph
AbstractMessageValueFactoryFactory class to create default message values.Classorg.apache.giraph.factoriesGiraph
AbstractVertexIdDataClassorg.apache.giraph.utilsGiraph
AbstractVertexToHiveClassorg.apache.giraph.hive.outputGiraph
AccumuloVertexInputFormatClass which wraps the AccumuloInputFormat.Classorg.apache.giraph.io.accumuloGiraph
AccumuloVertexOutputFormatClass which wraps the AccumuloOutputFormat.Classorg.apache.giraph.io.accumuloGiraph
AddressesAndPartitionsWritableClassorg.apache.giraph.graphGiraph
AddressRequestIdGeneratorGenerate different request ids based on the address of the well known port on the workers.Classorg.apache.giraph.comm.netty.handlerGiraph
AdjacencyListTextVertexInputFormatVertexReader that readers lines of text with vertices encoded as adjacency lists and converts each token to the correct type.Classorg.apache.giraph.io.formatsGiraph
AdjacencyListTextVertexOutputFormatOutputFormat to write out the graph nodes as text, value-separated (by tabs, by default).Classorg.apache.giraph.io.formatsGiraph
AggregatedMetricAn aggregator over metrics from multiple hosts.Classorg.apache.giraph.metricsGiraph
AggregatedMetricsClassorg.apache.giraph.metricsGiraph
AggregatorInterface for Aggregator.Interfaceorg.apache.giraph.aggregatorsGiraph
AggregatorBroadcastClassorg.apache.giraph.masterGiraph
AggregatorReduceOperationTranslates aggregation operation to reduce operations.Classorg.apache.giraph.masterGiraph
AggregatorsBenchmarkBenchmark for aggregators.Classorg.apache.giraph.benchmarkGiraph
AggregatorsTestComputationComputation which uses aggrergators.Classorg.apache.giraph.examplesGiraph
AggregatorToGlobalCommTranslationClass that translates aggregator handling on the master to reduce and broadcast operations supported by the MasterAggregatorHandler.Classorg.apache.giraph.masterGiraph
AggregatorUsageMaster and workers can access aggregators through this interface.Interfaceorg.apache.giraph.aggregatorsGiraph
AggregatorUtilsClassorg.apache.giraph.comm.aggregatorsGiraph
AggregatorWriterAn AggregatorWriter is used to export Aggregators during or at the end of each computation.Interfaceorg.apache.giraph.aggregatorsGiraph
AlgorithmThis annotation should be used to annotate built-in algorithms.Classorg.apache.giraphGiraph
AlgorithmThis annotation should be used to annotate built-in algorithms.Classorg.apache.giraph.examplesGiraph
AllAggregatorServerDataAccepts aggregators and their values from previous superstep from master and workers which own aggregators.Classorg.apache.giraph.comm.aggregatorsGiraph
AllOptionsClassorg.apache.giraph.confGiraph
AnnotationUtilsHelper class to deal with annotations in runtime.Classorg.apache.giraph.utilsGiraph
ApplicationStateenum ApplicationStateState of the BSP applicationClassorg.apache.giraph.bspGiraph
ArrayListEdgesOutEdges implementation backed by an ArrayList.Classorg.apache.giraph.edgeGiraph
ArrayListWritableA Writable for ListArray containing instances of a class.Classorg.apache.giraph.utilsGiraph
ArrayWritableA Writable for arrays containing instances of a class.Classorg.apache.giraph.utilsGiraph
AsyncMessageStoreWrapperThis class decouples message receiving and processing into separate threads thus reducing contention.Classorg.apache.giraph.comm.messages.queueGiraph
AuthorizeServerHandlerAuthorize or deny client requests based on existence and completeness of client's SASL authentication.Classorg.apache.giraph.comm.netty.handlerGiraph
Basic2ObjectMapBasic2ObjectMap with only basic set of operations.Classorg.apache.giraph.types.ops.collectionsGiraph
BasicAggregatorAbstract class for Aggregator.Classorg.apache.giraph.aggregatorsGiraph
BasicArrayListBasicArrayList with only basic set of operations.Classorg.apache.giraph.types.ops.collectionsGiraph
BasicComputationComputation in which both incoming and outgoing message types are the same.Classorg.apache.giraph.graphGiraph
BasicPartitionBasic partition class for other partitions to extend.Classorg.apache.giraph.partitionGiraph
BasicPartitionOwnerBasic partition owner, can be subclassed for more complicated partition owner implementations.Classorg.apache.giraph.partitionGiraph
BasicSetBasicSet with only basic set of operations.Interfaceorg.apache.giraph.types.ops.collectionsGiraph
BasicVertexValueReaderAbstract base class for VertexValueReader.Classorg.apache.giraph.ioGiraph
BenchmarkOptionClassorg.apache.giraph.benchmarkGiraph
BigDataInput only handle up to 1GB of data.Classorg.apache.giraph.utils.ioGiraph
BigDataInputOutputDataInputOutput which uses BigDataInput and BigDataOutput to support larger than allowed array size streams.Classorg.apache.giraph.utils.ioGiraph
BigDataOutput only handle up to 1GB of data.Classorg.apache.giraph.utils.ioGiraph
BooleanAndAggregatorAggregator for calculating the AND function over boolean values.Classorg.apache.giraph.aggregatorsGiraph
BooleanConfOptionClassorg.apache.giraph.confGiraph
BooleanOrAggregatorAggregator for calculating the OR function over boolean values.Classorg.apache.giraph.aggregatorsGiraph
BooleanOverwriteAggregatorAggregator that stores a value that is overwritten once another value is aggregated.Classorg.apache.giraph.aggregatorsGiraph
BooleanToBooleanWritableWrapperClassorg.apache.giraph.typesGiraph
BooleanTypeOpsTypeOps implementation for working with BooleanWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
BooleanWritableToBooleanUnwrapperConverts BooleanWritables to Booleans.Classorg.apache.giraph.typesGiraph
BrachaTouegDeadlockComputationThis code demonstrates the Bracha Toueg deadlock detection algorithm.Classorg.apache.giraph.examplesGiraph
BrachaTouegDeadlockInputFormatVertexInputFormat for the Bracha Toueg Deadlock Detection algorithm specified in JSON format.Classorg.apache.giraph.examples.io.formatsGiraph
BrachaTouegDeadlockMessageData sent via a message that includes the source vertex id.Classorg.apache.giraph.examples.utilsGiraph
BrachaTouegDeadlockVertexValueClassorg.apache.giraph.examples.utilsGiraph
BspEventSynchronize on waiting for an event to have happened.Interfaceorg.apache.giraph.zkGiraph
BspInputFormatThis InputFormat supports the BSP model by ensuring that the user specifies how many splits (number of mappers) should be started simultaneously.Classorg.apache.giraph.bspGiraph
BspInputSplitThis InputSplit will not give any ordering or location data.Classorg.apache.giraph.bspGiraph
BspOutputFormatThis is for internal use only.Classorg.apache.giraph.bspGiraph
BspRecordWriterUsed by BspOutputFormat since some versions of Hadoop require that a RecordWriter is returned from getRecordWriter.Classorg.apache.giraph.bspGiraph
BspServiceZookeeper-based implementation of CentralizedService.Classorg.apache.giraph.bspGiraph
BspServiceMasterZooKeeper-based implementation of CentralizedServiceMaster.Classorg.apache.giraph.masterGiraph
BspServiceWorkerZooKeeper-based implementation of CentralizedServiceWorker.Classorg.apache.giraph.workerGiraph
ByteArrayEdgesOutEdges implementation backed by a byte array.Classorg.apache.giraph.edgeGiraph
ByteArrayMessagesPerVertexStore stored per vertex as byte backed datastructures.Classorg.apache.giraph.comm.messagesGiraph
ByteArrayOneMessageToManyIdsStores a message and a list of target vertex ids.Classorg.apache.giraph.utilsGiraph
ByteArrayPartitionByte array based partition.Classorg.apache.giraph.partitionGiraph
ByteArrayRequestClassorg.apache.giraph.comm.requestsGiraph
ByteArrayVertexIdDataClassorg.apache.giraph.utilsGiraph
ByteArrayVertexIdEdgesStores vertex id and edge pairs in a single byte array.Classorg.apache.giraph.utilsGiraph
ByteArrayVertexIdMessagesStores vertex id and message pairs in a single byte array.Classorg.apache.giraph.utilsGiraph
ByteArrayWithSenderTaskIdRequestClassorg.apache.giraph.comm.requestsGiraph
ByteCounterInterfaceorg.apache.giraph.comm.nettyGiraph
ByteCounterDelegateDelegate Object to help keep track of the bytes processed and provide some metrics when desired as part of the Netty Channel stack.Classorg.apache.giraph.comm.nettyGiraph
ByteStructIterableThis iterable is designed to deserialize a byte array on the fly to provide new copies of writable objects when desired.Classorg.apache.giraph.utilsGiraph
ByteStructIteratorThis iterator is designed to deserialize a byte array on the fly to provide new copies of writable objects when desired.Classorg.apache.giraph.utilsGiraph
ByteStructVertexIdDataIteratorSpecial iterator that reuses vertex ids and data objects so that the lifetime of the object is only until next() is called.Classorg.apache.giraph.utilsGiraph
ByteStructVertexIdEdgeIteratorSpecial iterator that reuses vertex ids and edge objects so that the lifetime of the object is only until next() is called.Classorg.apache.giraph.utilsGiraph
ByteStructVertexIdIteratorCommon implementation for VertexIdEdgeIterator, VertexIdMessageIterator and VertexIdMessageBytesIterator.Classorg.apache.giraph.utilsGiraph
ByteStructVertexIdMessageBytesIteratorSpecial iterator that reuses vertex ids and messages bytes so that the lifetime of the object is only until next() is called.Classorg.apache.giraph.utilsGiraph
ByteStructVertexIdMessageIteratorSpecial iterator that reuses vertex ids and message objects so that the lifetime of the object is only until next() is called.Classorg.apache.giraph.utilsGiraph
ByteToByteWritableWrapperClassorg.apache.giraph.typesGiraph
ByteToIntWritableWrapperClassorg.apache.giraph.typesGiraph
ByteToLongWritableWrapperClassorg.apache.giraph.typesGiraph
ByteTypeOpsTypeOps implementation for working with ByteWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
ByteUtilsClassorg.apache.giraph.utilsGiraph
ByteValueVertexClassorg.apache.giraph.graphGiraph
ByteWritableToByteUnwrapperClassorg.apache.giraph.typesGiraph
ByteWritableToIntUnwrapperClassorg.apache.giraph.typesGiraph
ByteWritableToLongUnwrapperClassorg.apache.giraph.typesGiraph
ByteWritableToShortUnwrapperClassorg.apache.giraph.typesGiraph
CallableFactoryInterfaceorg.apache.giraph.utilsGiraph
CentralizedServiceBasic service interface shared by both CentralizedServiceMaster and CentralizedServiceWorker.Interfaceorg.apache.giraph.bspGiraph
CentralizedServiceMasterAt most, there will be one active master at a time, but many threads can be trying to be the active master.Interfaceorg.apache.giraph.bspGiraph
CentralizedServiceWorkerAll workers should have access to this centralized service to execute the following methods.Interfaceorg.apache.giraph.bspGiraph
ChannelRotaterMaintains multiple channels and rotates between them.Classorg.apache.giraph.comm.nettyGiraph
CheckpointingUtilsClassorg.apache.giraph.utilsGiraph
CheckpointStatusenum CheckpointStatusEnum represents possible checkpoint state.Classorg.apache.giraph.bspGiraph
ClassConfOptionClassorg.apache.giraph.confGiraph
ClientRequestIdSimple immutable object to use for tracking requests uniquely.Classorg.apache.giraph.comm.netty.handlerGiraph
CollectionUtilsClassorg.apache.giraph.utilsGiraph
CombinedWorkerProgressClass which combines multiple workers' progresses to get overall application progressClassorg.apache.giraph.jobGiraph
ComputationInterface for an application for computation.Interfaceorg.apache.giraph.graphGiraph
ComputationDoneNameThis name is used by each worker as a file to let the ZooKeeper servers know that they can shutdown.Classorg.apache.giraph.zkGiraph
ComputationFactoryInterfaceorg.apache.giraph.factoriesGiraph
ComputeCallableCompute as many vertex partitions as possible.Classorg.apache.giraph.graphGiraph
ConfigurableOutEdgesClassorg.apache.giraph.edgeGiraph
ConfigurationUtilsTranslate command line args into Configuration Key-Value pairs.Classorg.apache.giraph.utilsGiraph
ConfOptionTypeType of value for a Configuration optionEnum Constant SummaryClassorg.apache.giraph.confGiraph
ConnectedComponentsComputation assigns each vertex its component identifier (the smallest vertex id The idea behind the algorithm is very simple: propagate the smallestClassorg.apache.giraph.examplesGiraph
CounterUtilsClassorg.apache.giraph.utilsGiraph
CountingCacheCache which counts the number of flushes per task id (destination worker id), so we know how many requests were sent to the workerClassorg.apache.giraph.comm.aggregatorsGiraph
CountingOutputStreamWrapper for output stream which keeps the place in the beginning for the count of objects which were written to itClassorg.apache.giraph.comm.aggregatorsGiraph
DataInputOutputProvides both DataOutput which we can write to and DataInputs which are going to read data which was written to DataOutput.Classorg.apache.giraph.utils.ioGiraph
DefaultComputationFactoryClassorg.apache.giraph.factoriesGiraph
DefaultConfigurableAndTableSchemaAwareDefault implementation of HiveTableSchemaAware and ImmutableClassesGiraphConfigurableClassorg.apache.giraph.hive.commonGiraph
DefaultEdgeA complete edge, the target vertex and the edge value.Classorg.apache.giraph.edgeGiraph
DefaultEdgeInputFilterDefault edge filter that lets in all edges.Classorg.apache.giraph.io.filtersGiraph
DefaultEdgeValueFactoryFactory class to create default edge values.Classorg.apache.giraph.factoriesGiraph
DefaultEmbeddedLongByteOpsMappingStoreOps implementation used to embed target information into vertex id.Classorg.apache.giraph.mappingGiraph
DefaultGiraphJobRetryCheckerDefault implementation of GiraphJobRetryChecker, which never retries the job.Classorg.apache.giraph.jobGiraph
DefaultImmutableClassesGiraphConfigurableClassorg.apache.giraph.confGiraph
DefaultIncomingMessageValueFactoryFactory class to create default incoming message values.Classorg.apache.giraph.factoriesGiraph
DefaultJobObserverDefault implementation of job observer that does nothing.Classorg.apache.giraph.jobGiraph
DefaultKeyFactoryExample class for defining a way to construct Gora keys.Classorg.apache.giraph.io.gora.utilsGiraph
DefaultLongByteOpsClassorg.apache.giraph.mappingGiraph
DefaultMasterComputeA dumb implementation of MasterCompute.Classorg.apache.giraph.masterGiraph
DefaultMasterObserverA no-op implementation of MasterObserver to make it easier for users.Classorg.apache.giraph.masterGiraph
DefaultOutgoingMessageValueFactoryFactory class to create default outgoing message values.Classorg.apache.giraph.factoriesGiraph
DefaultVertexClass which holds vertex id, data and edges.Classorg.apache.giraph.graphGiraph
DefaultVertexIdFactoryDefault VertexIdFactory that simply uses the default constructor for the vertex ID class.Classorg.apache.giraph.factoriesGiraph
DefaultVertexInputFilterDefault vertex filter that lets in all vertices.Classorg.apache.giraph.io.filtersGiraph
DefaultVertexResolverDefault implementation of how to resolve vertex creation/removal, messages to nonexistent vertices, etc.Classorg.apache.giraph.graphGiraph
DefaultVertexValueCombinerClassorg.apache.giraph.graphGiraph
DefaultVertexValueFactoryDefault VertexValueFactory that simply uses the default constructor for the vertex value class.Classorg.apache.giraph.factoriesGiraph
DefaultWorkerContextA dummy implementation of WorkerContext.Classorg.apache.giraph.workerGiraph
DefaultWorkerObserverDefault Observer for Worker that does nothing.Classorg.apache.giraph.workerGiraph
DeployedScriptA script that was deployed to the cluster.Classorg.apache.giraph.scriptingGiraph
DeployTypeType of deployment for a fileEnum Constant SummaryClassorg.apache.giraph.scriptingGiraph
DiskBackedMessageStoreMessage store which separates data by partitions, and submits them to underlying message store.Classorg.apache.giraph.comm.messages.out_of_coreGiraph
DiskBackedMessageStoreFactoryMessage store factory which persist the messages on the disk.Classorg.apache.giraph.comm.messages.out_of_coreGiraph
DiskBackedPartitionStoreDisk-backed PartitionStore.Classorg.apache.giraph.partitionGiraph
DistributedCacheUtilsClassorg.apache.giraph.utilsGiraph
DoubleDenseMatrixA double matrix holds the values of the entries in double vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
DoubleDenseMatrixSumAggregatorClassorg.apache.giraph.aggregators.matrix.denseGiraph
DoubleDenseVectorThe double dense vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.denseGiraph
DoubleDenseVectorSumAggregatorThe double dense vector aggregator is used to aggregate double dense vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
DoubleMaxAggregatorAggregator for getting max double value.Classorg.apache.giraph.aggregatorsGiraph
DoubleMinAggregatorAggregator for getting min double value.Classorg.apache.giraph.aggregatorsGiraph
DoubleOverwriteAggregatorAggregator that stores a value that is overwritten once another value is aggregated.Classorg.apache.giraph.aggregatorsGiraph
DoubleProductAggregatorAggregator for calculating products of double values.Classorg.apache.giraph.aggregatorsGiraph
DoubleSparseMatrixA double matrix holds the values of the entries in double vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
DoubleSparseMatrixSumAggregatorClassorg.apache.giraph.aggregators.matrix.sparseGiraph
DoubleSparseVectorThe double vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
DoubleSparseVectorSumAggregatorThe double vector aggregator is used to aggregate double vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
DoubleSumAggregatorAggregator for summing up double values.Classorg.apache.giraph.aggregatorsGiraph
DoubleSumMessageCombinerClassorg.apache.giraph.combinerGiraph
DoubleToDoubleWritableWrapperClassorg.apache.giraph.typesGiraph
DoubleTypeOpsTypeOps implementation for working with DoubleWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
DoubleWritableToDoubleUnwrapperClassorg.apache.giraph.typesGiraph
DynamicChannelBufferInputStreamSpecial input that reads from a DynamicChannelBuffer.Classorg.apache.giraph.utilsGiraph
DynamicChannelBufferOutputStreamSpecial output stream that can grow as needed and dumps to a DynamicChannelBuffer.Classorg.apache.giraph.utilsGiraph
EdgeA complete edge, the target vertex and the edge value.Interfaceorg.apache.giraph.edgeGiraph
EdgeComparatorComparator for edges.Classorg.apache.giraph.utilsGiraph
EdgeFactoryClassorg.apache.giraph.edgeGiraph
EdgeInputFilterFilters edges on input.Interfaceorg.apache.giraph.io.filtersGiraph
EdgeInputFormatInput format for reading single edges.Classorg.apache.giraph.ioGiraph
EdgeInputFormatDescriptionDescription of the edge input format - holds edge input format class and all parameters specifically set for that edge input format.Classorg.apache.giraph.io.formats.multiGiraph
EdgeInputSplitsCallableLoad as many edge input splits as possible.Classorg.apache.giraph.workerGiraph
EdgeInputSplitsCallableFactoryFactory for EdgeInputSplitsCallables.Classorg.apache.giraph.workerGiraph
EdgeIterablesUtility methods for iterables of edges.Classorg.apache.giraph.utilsGiraph
EdgeNoValueAn edge that has no value.Classorg.apache.giraph.edgeGiraph
EdgeOutputFormatClassorg.apache.giraph.ioGiraph
EdgeReaderAnalogous to BspRecordReader for edges.Classorg.apache.giraph.ioGiraph
EdgeReaderWrapperClassorg.apache.giraph.io.iterablesGiraph
EdgeStoreCollects incoming edges for vertices owned by this worker.Interfaceorg.apache.giraph.edgeGiraph
EdgeStoreFactoryInterfaceorg.apache.giraph.edgeGiraph
EdgeValueFactoryFactory class to create default edge values.Interfaceorg.apache.giraph.factoriesGiraph
EdgeWithSourceClassorg.apache.giraph.io.iterablesGiraph
EdgeWriterClassorg.apache.giraph.ioGiraph
EmptyIterableSingleton class for empty iterables.Classorg.apache.giraph.utilsGiraph
EnumConfOptionClassorg.apache.giraph.confGiraph
ExtendedByteArrayDataInputClassorg.apache.giraph.utilsGiraph
ExtendedByteArrayDataOutputAdds some functionality to ByteArrayOutputStream, such as an option to write int value over previously written dataClassorg.apache.giraph.utilsGiraph
ExtendedByteArrayOutputBufferWraps a list of byte array outputs and provides convenient utilities on top of itClassorg.apache.giraph.utilsGiraph
ExtendedDataInputInterfaceorg.apache.giraph.utilsGiraph
ExtendedDataInputOutputWraps ExtendedDataOutput and ExtendedDataOutput to be able to write data and later read data from the same placeClassorg.apache.giraph.utils.ioGiraph
ExtendedDataOutputInterfaceorg.apache.giraph.utilsGiraph
ExtraGoraInputFormatInputFormat to fetch the input from Gora data stores.Classorg.apache.giraph.io.gora.utilsGiraph
FactoryInterfaceorg.apache.giraph.utilsGiraph
FakeTimeThread-safe implementation of Time for testing that can help get time based ordering of events when desired.Classorg.apache.giraph.timeGiraph
FileUtilsClassorg.apache.giraph.utilsGiraph
FinishedSuperstepStatsClassorg.apache.giraph.graphGiraph
FloatConfOptionClassorg.apache.giraph.confGiraph
FloatDenseMatrixA float matrix holds the values of the entries in float vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
FloatDenseMatrixSumAggregatorClassorg.apache.giraph.aggregators.matrix.denseGiraph
FloatDenseVectorThe float dense vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.denseGiraph
FloatDenseVectorSumAggregatorThe float dense vector aggregator is used to aggregate float dense vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
FloatMaxAggregatorAggregator for getting max float value.Classorg.apache.giraph.aggregatorsGiraph
FloatMinAggregatorAggregator for getting min float value.Classorg.apache.giraph.aggregatorsGiraph
FloatOverwriteAggregatorAggregator that stores a value that is overwritten once another value is aggregated.Classorg.apache.giraph.aggregatorsGiraph
FloatProductAggregatorAggregator for calculating products of float values.Classorg.apache.giraph.aggregatorsGiraph
FloatSparseMatrixA float matrix holds the values of the entries in float vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
FloatSparseMatrixSumAggregatorThe float matrix aggregator is used to register and aggregate float matrices.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
FloatSparseVectorThe float vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
FloatSparseVectorSumAggregatorThe float vector aggregator is used to aggregate float vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
FloatSumAggregatorAggregator for summing up float values.Classorg.apache.giraph.aggregatorsGiraph
FloatSumMessageCombinerClassorg.apache.giraph.combinerGiraph
FloatToDoubleWritableWrapperClassorg.apache.giraph.typesGiraph
FloatToFloatWritableWrapperClassorg.apache.giraph.typesGiraph
FloatTypeOpsTypeOps implementation for working with FloatWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
FloatWritableToDoubleUnwrapperClassorg.apache.giraph.typesGiraph
FloatWritableToFloatUnwrapperClassorg.apache.giraph.typesGiraph
FullInputSplitCallableClassorg.apache.giraph.workerGiraph
GEdgeExample class for defining a Giraph-Edge.Classorg.apache.giraph.io.gora.generatedGiraph
GEdgeResultExample class for defining a Giraph-Edge result.Classorg.apache.giraph.io.gora.generatedGiraph
GeneratedEdgeReaderUsed by GeneratedEdgeInputFormat to read some generated dataClassorg.apache.giraph.examplesGiraph
GeneratedVertexInputFormatThis VertexInputFormat is meant for testing/debugging.Classorg.apache.giraph.io.formatsGiraph
GeneratedVertexReaderClassorg.apache.giraph.examplesGiraph
GiraphApplicationMasterThe YARN Application Master for Giraph is launched when the GiraphYarnClient successfully requests an execution container from the Resource Manager.Classorg.apache.giraph.yarnGiraph
GiraphBenchmarkAbstract class which benchmarks should extend.Classorg.apache.giraph.benchmarkGiraph
GiraphClassesHolder for classes used by Giraph.Classorg.apache.giraph.confGiraph
GiraphConfigurationAdds user methods specific to Giraph.Classorg.apache.giraph.confGiraph
GiraphConfigurationSettableInterfaceorg.apache.giraph.confGiraph
GiraphConfigurationValidatorGiraphConfigurationValidator attempts to verify the consistency of user-chosen InputFormat, OutputFormat, and Vertex generic typeClassorg.apache.giraph.jobGiraph
GiraphConstantsConstants used all over Giraph for configuration.Interfaceorg.apache.giraph.confGiraph
GiraphDepVersionsVersions of Giraph dependencies.Classorg.apache.giraph.utilsGiraph
GiraphExtensionThis extension allows batch/transactional operations on a graph.Classorg.apache.giraph.rexster.kibbleGiraph
GiraphFileInputFormatProvides functionality similar to FileInputFormat, but allows for different data sources (vertex and edge data).Classorg.apache.giraph.io.formatsGiraph
GiraphGoraConstantsInterfaceorg.apache.giraph.io.gora.constantsGiraph
GiraphHadoopCounterWrapper around Hadoop Counter to make it easier to use.Classorg.apache.giraph.countersGiraph
GiraphHCatInputFormatProvides functionality similar to but allows for different data sources (vertex and edge data).Classorg.apache.giraph.io.hcatalogGiraph
GiraphHiveConstantsClassorg.apache.giraph.hive.commonGiraph
GiraphInputFormatCommon interface for VertexInputFormat and EdgeInputFormat.Classorg.apache.giraph.ioGiraph
GiraphJobGenerates an appropriate internal Job for using Giraph in Hadoop.Classorg.apache.giraph.jobGiraph
GiraphJobObserverAn observer over the job launch lifecycle.Interfaceorg.apache.giraph.jobGiraph
GiraphJobRetryCheckerClass to decide whether a GiraphJob should be restarted after failure.Interfaceorg.apache.giraph.jobGiraph
GiraphMetricsTop level metrics class for using Yammer's metrics in Giraph.Classorg.apache.giraph.metricsGiraph
GiraphMetricsRegistryA holder for MetricsRegistry together with a JmxReporter.Classorg.apache.giraph.metricsGiraph
GiraphReaderReader for some kind of data.Interfaceorg.apache.giraph.io.iterablesGiraph
GiraphRexsterConstantsInterfaceorg.apache.giraph.rexster.confGiraph
GiraphRunnerHelper class to run Giraph applications by specifying the actual class name to use (i.Classorg.apache.giraphGiraph
GiraphStatsHadoop Counters in group Giraph Stats.Classorg.apache.giraph.countersGiraph
GiraphTextInputFormatProvides functionality similar to but allows for different data sources (vertex and edge data).Classorg.apache.giraph.io.formatsGiraph
GiraphTextOutputFormatThe text output format used for Giraph text writing.Classorg.apache.giraph.io.formatsGiraph
GiraphTimerA timer to record duration of an event in a given TimeUnit.Classorg.apache.giraph.metricsGiraph
GiraphTimerContextContext to use with GiraphTimer for timing an event.Classorg.apache.giraph.metricsGiraph
GiraphTimersHadoop Counters in group Giraph Timers for timing things.Classorg.apache.giraph.countersGiraph
GiraphTransferRegulatorUtility class to manage data transfers from a local worker reading InputSplits.Classorg.apache.giraph.graphGiraph
GiraphTypesHolder for the generic types that describe user's graph.Classorg.apache.giraph.confGiraph
GiraphYarnClientThe initial launcher for a YARN-based Giraph job.Classorg.apache.giraph.yarnGiraph
GiraphYarnTaskThis process will execute the BSP graph tasks alloted to this YARN execution container.Classorg.apache.giraph.yarnGiraph
GiraphZooKeeperAdminA 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.Classorg.apache.giraph.zkGiraph
GlobalCommTypeType tag distinguishing different global communication messages.Classorg.apache.giraph.commGiraph
GlobalCommValueOutputStream reduced values in the form of pair (name, type, value) There are two modes:Classorg.apache.giraph.comm.aggregatorsGiraph
GlobalStatsAggregated stats by the master.Classorg.apache.giraph.graphGiraph
GoraEdgeInputFormatClass which wraps the GoraInputFormat.Classorg.apache.giraph.io.goraGiraph
GoraEdgeOutputFormatClass which wraps the GoraInputFormat.Classorg.apache.giraph.io.goraGiraph
GoraGEdgeEdgeInputFormatExample implementation of a specific reader for a generated data bean.Classorg.apache.giraph.io.goraGiraph
GoraGEdgeEdgeOutputFormatClassorg.apache.giraph.io.goraGiraph
GoraGVertexVertexInputFormatExample implementation of a specific reader for a generated data bean.Classorg.apache.giraph.io.goraGiraph
GoraGVertexVertexOutputFormatClassorg.apache.giraph.io.goraGiraph
GoraUtilsClass used to handle the creation and querying of data stores through Gora.Classorg.apache.giraph.io.gora.utilsGiraph
GoraVertexInputFormatClass which wraps the GoraInputFormat.Classorg.apache.giraph.io.goraGiraph
GoraVertexOutputFormatClass which wraps the GoraOutputFormat.Classorg.apache.giraph.io.goraGiraph
GraphFunctionsEach compute node running on the underlying cluster is marked with this enum to indicate the worker orClassorg.apache.giraph.graphGiraph
GraphMapperThis mapper that will execute the BSP graph tasks alloted to this worker.Classorg.apache.giraph.graphGiraph
GraphPartitionerFactoryDefines the partitioning framework for this application.Interfaceorg.apache.giraph.partitionGiraph
GraphStateImmutable global state of the graph.Classorg.apache.giraph.graphGiraph
GraphTaskManagerThe Giraph-specific business logic for a single BSP compute node in whatever underlying type of clusterClassorg.apache.giraph.graphGiraph
GraphTypeEnumeration for a user graph type (IVEMM)Enum Constant SummaryClassorg.apache.giraph.graphGiraph
GraphvizOutputFormatWrites graph to a dot file (graphviz format).Classorg.apache.giraph.io.formatsGiraph
GVertexExample class for defining a Giraph-vertex.Classorg.apache.giraph.io.gora.generatedGiraph
GVertexResultExample class for defining a Giraph-vertex result.Classorg.apache.giraph.io.gora.generatedGiraph
HadoopCountersBaseBase class for groups of Hadoop Counters.Classorg.apache.giraph.countersGiraph
HadoopUtilsHelpers for dealing with Hadoop.Classorg.apache.giraph.jobGiraph
HaltApplicationUtilsClassorg.apache.giraph.jobGiraph
HashMapEdgesOutEdges implementation backed by a HashMap.Classorg.apache.giraph.edgeGiraph
HashMasterPartitionerMaster will execute a hash based partitioning.Classorg.apache.giraph.partitionGiraph
HashMultimapEdgesOutEdges implementation backed by an ArrayListMultimap.Classorg.apache.giraph.edgeGiraph
HashPartitionerFactoryDivides the vertices into partitions by their hash code using a simple round-robin hash for great balancing if given a random hash code.Classorg.apache.giraph.partitionGiraph
HashRangePartitionerFactoryClassorg.apache.giraph.partitionGiraph
HashRangeWorkerPartitionerClassorg.apache.giraph.partitionGiraph
HashWorkerPartitionerClassorg.apache.giraph.partitionGiraph
HBaseVertexInputFormatBase class that wraps an HBase TableInputFormat and underlying Scan object to help instantiate vertices from an HBase table.Classorg.apache.giraph.io.hbaseGiraph
HBaseVertexOutputFormatBase class for writing Vertex mutations back to specific rows in an HBase table.Classorg.apache.giraph.io.hbaseGiraph
HCatalogEdgeInputFormatHCatalog EdgeInputFormat for reading edges from Hive/Pig.Classorg.apache.giraph.io.hcatalogGiraph
HCatalogVertexInputFormatAbstract class that users should subclass to load data from a Hive or Pig table.Classorg.apache.giraph.io.hcatalogGiraph
HCatalogVertexOutputFormatAbstract class that users should subclass to store data to Hive or Pig table.Classorg.apache.giraph.io.hcatalogGiraph
HCatalogVertexValueInputFormatClassorg.apache.giraph.io.hcatalogGiraph
HCatGiraphRunnerClassorg.apache.giraph.io.hcatalogGiraph
HCatUtilsUtility methods copied from HCatalog because of visibility restrictions.Classorg.apache.hcatalog.mapreduceGiraph
HiveEdgeInputFormatEdgeInputFormat for reading edges from Hive.Classorg.apache.giraph.hive.input.edgeGiraph
HiveEdgeReaderA reader for reading edges from Hive.Classorg.apache.giraph.hive.input.edgeGiraph
HiveGiraphRunnerClassorg.apache.giraph.hiveGiraph
HiveInputCheckerInterface to check the validity of a Hive input configuration.Interfaceorg.apache.giraph.hive.inputGiraph
HiveInputOptionsHolder for Hive Input Configuration options.Classorg.apache.giraph.hive.commonGiraph
HiveIntDoubleDoubleVertexSimple HiveToVertex that reads vertices with integer IDs, Double vertex values, and edges with Double values.Classorg.apache.giraph.hive.input.vertex.examplesGiraph
HiveIntDoubleEdgeA simple HiveToEdge with integer IDs and double edge values.Classorg.apache.giraph.hive.input.edge.examplesGiraph
HiveIntIntNullVertexSimple HiveToVertex that reads vertices with integer IDs, no vertex values, and edges with no values.Classorg.apache.giraph.hive.input.vertex.examplesGiraph
HiveIntNullEdgeA simple HiveToEdge with integer IDs, no edge value, that assumes the Hive table is made up of [source,target] columns.Classorg.apache.giraph.hive.input.edge.examplesGiraph
HiveIntNullNullVertexSimple HiveToVertex that reads vertices with integer IDs, no vertex values, and edges with no values.Classorg.apache.giraph.hive.input.vertex.examplesGiraph
HiveJythonRunnerClassorg.apache.giraph.hive.jythonGiraph
HiveJythonUtilsPlugin to HiveJythonRunner to use Hive.Classorg.apache.giraph.hive.jythonGiraph
HiveMappingInputFormatClassorg.apache.giraph.hive.input.mappingGiraph
HiveMappingReaderClassorg.apache.giraph.hive.input.mappingGiraph
HiveOutputIntIntVertexClassorg.apache.giraph.hive.output.examplesGiraph
HiveParsingHelpers for parsing with Hive.Classorg.apache.giraph.hive.commonGiraph
HiveReadableColumnA single column from a Hive record.Classorg.apache.giraph.hive.columnGiraph
HiveRecordSaverInterface which can save HiveWritableRecords.Interfaceorg.apache.giraph.hive.outputGiraph
HiveToEdgeAn interface used to create edges from Hive records.Interfaceorg.apache.giraph.hive.input.edgeGiraph
HiveToMappingInterfaceorg.apache.giraph.hive.input.mappingGiraph
HiveToVertexAn interface used to create vertices from Hive records.Interfaceorg.apache.giraph.hive.input.vertexGiraph
HiveUtilsClassorg.apache.giraph.hive.commonGiraph
HiveUtilsUtilities and helpers for working with Hive tables.Classorg.apache.giraph.io.hcatalogGiraph
HiveValueReaderInterfaceorg.apache.giraph.hive.valuesGiraph
HiveValueWriterInterfaceorg.apache.giraph.hive.valuesGiraph
HiveVertexInputFormatVertexInputFormat for reading vertices from Hive.Classorg.apache.giraph.hive.input.vertexGiraph
HiveVertexOutputFormatClassorg.apache.giraph.hive.outputGiraph
HiveVertexReaderClassorg.apache.giraph.hive.input.vertexGiraph
HiveVertexWriterVertex writer using Hive.Classorg.apache.giraph.hive.outputGiraph
HiveWritableColumnA single column to write to a Hive record.Classorg.apache.giraph.hive.columnGiraph
IdAndNullArrayEdges Backed by a dynamic primitive array.Classorg.apache.giraph.edgeGiraph
IdAndValueArrayEdges Data is backed by a dynamic primitive array.Classorg.apache.giraph.edgeGiraph
IdByteArrayMessageStoreSpecial 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 andClassorg.apache.giraph.comm.messages.primitivesGiraph
IdentityComputationUser applications can subclass IdentityComputation, which simply prints the results that have been read for testing IO relatedClassorg.apache.giraph.examplesGiraph
IdOneMessagePerVertexStoreSpecial message store to be used when IDs are primitive and message doesn't need to be, and message combiner is used.Classorg.apache.giraph.comm.messages.primitivesGiraph
IdWithValueTextOutputFormatWrite out Vertices' IDs and values, but not their edges nor edges' values.Classorg.apache.giraph.io.formatsGiraph
ImmutableClassesGiraphConfigurableInterfaceorg.apache.giraph.confGiraph
ImmutableClassesGiraphConfigurationThe classes set here are immutable, the remaining configuration is mutable.Classorg.apache.giraph.confGiraph
ImmutableOutputCommitterThis output committer doesn't do anything, meant for the case where output isn't desired, or as a base for not usingClassorg.apache.giraph.bspGiraph
InboundByteCounterKeep track of the bytes received and provide some metrics when desired as part of the Netty Channel stack.Classorg.apache.giraph.comm.nettyGiraph
IncreasingBitSetBit set optimized for increasing longs to save storage space.Classorg.apache.giraph.utilsGiraph
InMemoryEdgeStoreFactoryEdge store factory which produces message stores which hold all edges in memory.Classorg.apache.giraph.edgeGiraph
InMemoryMessageStoreFactoryMessage store factory which produces message stores which hold all messages in memory.Classorg.apache.giraph.comm.messagesGiraph
InMemoryVertexInputFormatAn input format that reads the input graph in memory.Classorg.apache.giraph.utilsGiraph
InMemoryVertexOutputFormatClassorg.apache.giraph.io.formatsGiraph
InputFormatDescriptionDescription of the input format - holds input format class and all parameters specifically set for that input format.Classorg.apache.giraph.io.formats.multiGiraph
InputSplitEventsSimple container of input split events.Classorg.apache.giraph.graphGiraph
InputSplitPathOrganizerUtility class to extract the list of InputSplits from the ZooKeeper tree of claimable splits the master created,Classorg.apache.giraph.workerGiraph
InputSplitPathsSimple container of input split paths for coordination via ZooKeeper.Classorg.apache.giraph.graphGiraph
InputSplitsCallableAbstract base class for loading vertex/edge input splits.Classorg.apache.giraph.workerGiraph
InputSplitsHandlerStores the list of input split paths, and provides thread-safe way for reserving input splits.Classorg.apache.giraph.workerGiraph
IntByteArrayMessageStoreSpecial message store to be used when ids are IntWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects andClassorg.apache.giraph.comm.messages.primitivesGiraph
IntConfOptionClassorg.apache.giraph.confGiraph
IntDenseMatrixA int matrix holds the values of the entries in int vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
IntDenseMatrixSumAggregatorClassorg.apache.giraph.aggregators.matrix.denseGiraph
IntDenseVectorThe int dense vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.denseGiraph
IntDenseVectorSumAggregatorClassorg.apache.giraph.aggregators.matrix.denseGiraph
IntEdgeStoreSpecial edge store to be used when ids are IntWritable.Classorg.apache.giraph.edge.primitivesGiraph
InternalVertexRunnerA base class for running internal tests on a vertex Extending classes only have to invoke the run() method to test their vertex.Classorg.apache.giraph.utilsGiraph
IntFloatMessageStoreSpecial message store to be used when ids are IntWritable and messages are FloatWritable and messageCombiner is used.Classorg.apache.giraph.comm.messages.primitivesGiraph
IntIntNullTextInputFormatSimple text-based VertexInputFormat for unweighted graphs with int ids.Classorg.apache.giraph.io.formatsGiraph
IntIntNullTextVertexInputFormatSimple text-based VertexInputFormat for unweighted graphs with int ids.Classorg.apache.giraph.io.formatsGiraph
IntIntTextVertexValueInputFormatSimple text-based VertexValueInputFormat for integer ids and values.Classorg.apache.giraph.io.formatsGiraph
IntMaxAggregatorAggregator for getting max integer value.Classorg.apache.giraph.aggregatorsGiraph
IntMinAggregatorAggregator for getting min integer value.Classorg.apache.giraph.aggregatorsGiraph
IntNullArrayEdges values, backed by dynamic primitive array.Classorg.apache.giraph.edgeGiraph
IntNullNullTextInputFormatSimple text-based VertexInputFormat for unweighted graphs without edges or values, just vertices with ids.Classorg.apache.giraph.io.formatsGiraph
IntNullReverseTextEdgeInputFormatSimple text-based EdgeInputFormat for unweighted graphs with int ids.Classorg.apache.giraph.io.formatsGiraph
IntNullTextEdgeInputFormatSimple text-based EdgeInputFormat for unweighted graphs with int ids.Classorg.apache.giraph.io.formatsGiraph
IntOverwriteAggregatorAggregator that stores a value that is overwritten once another value is aggregated.Classorg.apache.giraph.aggregatorsGiraph
IntPairClassorg.apache.giraph.utilsGiraph
IntProductAggregatorAggregator for calculating products of long and integer values.Classorg.apache.giraph.aggregatorsGiraph
IntSparseMatrixA int matrix holds the values of the entries in int vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
IntSparseMatrixSumAggregatorThe int matrix aggregator is used to register and aggregate int matrices.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
IntSparseVectorThe int vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
IntSparseVectorSumAggregatorThe float vector aggregator is used to aggregate float vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
IntSumAggregatorAggregator for summing up integer values.Classorg.apache.giraph.aggregatorsGiraph
IntToIntWritableWrapperClassorg.apache.giraph.typesGiraph
IntToLongWritableWrapperClassorg.apache.giraph.typesGiraph
IntTypeOpsTypeOps implementation for working with IntWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
IntWritableToIntUnwrapperClassorg.apache.giraph.typesGiraph
IntWritableToLongUnwrapperClassorg.apache.giraph.typesGiraph
IteratorToReaderWrapperClassorg.apache.giraph.io.iterablesGiraph
JavaWritablePairHolder for java and writable class pair.Classorg.apache.giraph.typesGiraph
JMapClassorg.apache.giraph.utilsGiraph
JMapHistoDumperAn observer for both worker and master that periodically dumps the memory usage using jmap tool.Classorg.apache.giraph.utilsGiraph
JobProgressTrackerInterfaceorg.apache.giraph.jobGiraph
JobProgressTrackerClientWrapper around JobProgressTracker which retries to connect and swallows exceptions so app wouldn't crash if something goes wrong with progressInterfaceorg.apache.giraph.graphGiraph
JobProgressTrackerClientNoOpClass to use for JobProgressTracker client when progress shouldn't be tracked or something goes wrongClassorg.apache.giraph.graphGiraph
JobProgressTrackerServiceClassorg.apache.giraph.jobGiraph
JsonBase64VertexFormatClassorg.apache.giraph.io.formatsGiraph
JsonBase64VertexInputFormatSimple way to represent the structure of the graph with a JSON object.Classorg.apache.giraph.io.formatsGiraph
JsonBase64VertexOutputFormatSimple way to represent the structure of the graph with a JSON object.Classorg.apache.giraph.io.formatsGiraph
JsonLongDoubleFloatDoubleVertexInputFormatVertexInputFormat that features long vertex ID's, double vertex values and floatClassorg.apache.giraph.io.formatsGiraph
JsonLongDoubleFloatDoubleVertexOutputFormatVertexOutputFormat that supports JSON encoded vertices featuring double values and float out-edge weightsClassorg.apache.giraph.io.formatsGiraph
JsonStringConfOptionClassorg.apache.giraph.confGiraph
JythonColumnReaderA Vertex ID reader from a single Hive column.Classorg.apache.giraph.hive.jythonGiraph
JythonColumnWriterClassorg.apache.giraph.hive.jythonGiraph
JythonComputationBase class for writing computations in Jython.Classorg.apache.giraph.jythonGiraph
JythonComputationFactoryClassorg.apache.giraph.jython.factoriesGiraph
JythonEdgeValueFactoryEdgeValueFactory that creates edge values which are Jython classes.Classorg.apache.giraph.jython.factoriesGiraph
JythonFactoryBaseBase class for Jython factories.Classorg.apache.giraph.jython.factoriesGiraph
JythonGiraphComputationThe Computation class for using Jython with Giraph.Classorg.apache.giraph.jythonGiraph
JythonHiveIOA type that can read and write itself using a Hive column.Interfaceorg.apache.giraph.hive.jythonGiraph
JythonHiveReaderInterface for reading user graph type (IVEMM) from Hive columns.Interfaceorg.apache.giraph.hive.jythonGiraph
JythonHiveToEdgeA HiveToEdge that reads each part (vertex ID, edge value) using separate readers.Classorg.apache.giraph.hive.jythonGiraph
JythonHiveToVertexA HiveToVertex that writes each part (vertex ID, vertex value, edges) using separate writers.Classorg.apache.giraph.hive.jythonGiraph
JythonHiveWriterInterfaceorg.apache.giraph.hive.jythonGiraph
JythonIncomingMessageValueFactoryClassorg.apache.giraph.jython.factoriesGiraph
JythonJobHolder of Jython job information.Classorg.apache.giraph.jythonGiraph
JythonMessageValueFactoryMessageValueFactory that creates message values which are Jython classes.Classorg.apache.giraph.jython.factoriesGiraph
JythonOptionsClassorg.apache.giraph.jythonGiraph
JythonOutgoingMessageValueFactoryClassorg.apache.giraph.jython.factoriesGiraph
JythonReadableColumnClassorg.apache.giraph.hive.jythonGiraph
JythonUtilsHelpers for running jobs with Jython.Classorg.apache.giraph.jythonGiraph
JythonVertexIdFactoryVertexIdFactory that creates vertex IDs which are Jython classes.Classorg.apache.giraph.jython.factoriesGiraph
JythonVertexToHiveA VertexToHive that writes each part (vertex ID, vertex value, edge value) using separate writers.Classorg.apache.giraph.hive.jythonGiraph
JythonVertexValueFactoryVertexValueFactory that creates vertex IDs which are Jython classes.Classorg.apache.giraph.jython.factoriesGiraph
JythonWrapperBaseBase class for wrapping Jython objectsSee Also:Serialized FormClassorg.apache.giraph.jython.wrappersGiraph
JythonWritableWrapperWraps a Jython object, adding WritableComparable interface.Classorg.apache.giraph.jython.wrappersGiraph
KeyFactoryClass used to convert strings into more complex keys.Classorg.apache.giraph.io.gora.utilsGiraph
LanguageProgramming language that something is implemented inEnum Constant SummaryClassorg.apache.giraph.graphGiraph
LanguageAndTypeA class/type with the language.Classorg.apache.giraph.hive.commonGiraph
LocalDataClassorg.apache.giraph.workerGiraph
LoggerUtilsClassorg.apache.giraph.utilsGiraph
LogStacktraceCallableA wrapper to improve debugging.Classorg.apache.giraph.utilsGiraph
LogVersionsLogs versions of Giraph dependencies on job start.Classorg.apache.giraph.utilsGiraph
LongAbstractListMessageStoreSpecial message store to be used when ids are LongWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects andClassorg.apache.giraph.comm.messages.primitives.long_idGiraph
LongAbstractMessageStoreSpecial message store to be used when ids are LongWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects andClassorg.apache.giraph.comm.messages.primitives.long_idGiraph
LongAndTimeUnitClassorg.apache.giraph.metricsGiraph
LongByteArrayMessageStoreSpecial message store to be used when ids are LongWritable and no combiner Uses fastutil primitive maps in order to decrease number of objects andClassorg.apache.giraph.comm.messages.primitives.long_idGiraph
LongByteHiveToMappingClassorg.apache.giraph.hive.input.mapping.examplesGiraph
LongByteMappingStoreAn implementation of MappingStore Methods implemented here are thread safe by default because it is guaranteedClassorg.apache.giraph.mappingGiraph
LongByteTranslateEdgeBasic implementation of Translate Edge where I = LongWritable & B = ByteWritableClassorg.apache.giraph.mapping.translateGiraph
LongConfOptionClassorg.apache.giraph.confGiraph
LongDenseMatrixA long matrix holds the values of the entries in long vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
LongDenseMatrixSumAggregatorClassorg.apache.giraph.aggregators.matrix.denseGiraph
LongDenseVectorThe long dense vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.denseGiraph
LongDenseVectorSumAggregatorThe long dense vector aggregator is used to aggregate long dense vectors.Classorg.apache.giraph.aggregators.matrix.denseGiraph
LongDoubleArrayEdges values, backed by dynamic primitive arrays.Classorg.apache.giraph.edgeGiraph
LongDoubleDoubleAdjacencyListVertexInputFormatInputFormat for reading graphs stored as (ordered) adjacency lists with the vertex ids longs and the vertex values and edges doubles.Classorg.apache.giraph.io.formatsGiraph
LongDoubleDoubleTextInputFormatSimple text-based VertexInputFormat for unweighted graphs with long ids.Classorg.apache.giraph.examplesGiraph
LongDoubleFloatTextInputFormatSimple text-based VertexInputFormat for weighted graphs with long ids.Classorg.apache.giraph.examplesGiraph
LongDoubleHashMapEdgesOutEdges implementation with long ids and double edge values, backed by a Long2DoubleOpenHashMap.Classorg.apache.giraph.edgeGiraph
LongDoubleMessageStoreSpecial message store to be used when ids are LongWritable and messages are DoubleWritable and messageCombiner is used.Classorg.apache.giraph.comm.messages.primitivesGiraph
LongDoubleNullTextInputFormatInput format for unweighted graphs with long ids.Classorg.apache.giraph.examplesGiraph
LongEdgeStoreSpecial edge store to be used when ids are LongWritable.Classorg.apache.giraph.edge.primitivesGiraph
LongInt2ByteHiveToMappingLong VertexId, Int Mapping target -> Byte MappingTarget implementation of HiveToMappingClassorg.apache.giraph.hive.input.mapping.examplesGiraph
LongLongNullTextInputFormatSimple text-based VertexInputFormat for unweighted graphs with long ids.Classorg.apache.giraph.io.formatsGiraph
LongMappingStorePartitionerFactoryFactory for long-byte mapping based partitioners.Classorg.apache.giraph.partitionGiraph
LongMaxAggregatorAggregator for getting max long value.Classorg.apache.giraph.aggregatorsGiraph
LongMinAggregatorAggregator for getting min long value.Classorg.apache.giraph.aggregatorsGiraph
LongNullArrayEdges values, backed by a dynamic primitive array.Classorg.apache.giraph.edgeGiraph
LongNullHashSetEdgesOutEdges implementation with long ids and null edge values, backed by a LongOpenHashSet.Classorg.apache.giraph.edgeGiraph
LongOverwriteAggregatorAggregator that stores a value that is overwritten once another value is aggregated.Classorg.apache.giraph.aggregatorsGiraph
LongPointerListMessageStoreThis stores messages in ExtendedByteArrayOutputBufferClassorg.apache.giraph.comm.messages.primitives.long_idGiraph
LongProductAggregatorAggregator for calculating products of long values.Classorg.apache.giraph.aggregatorsGiraph
LongSparseMatrixA long matrix holds the values of the entries in long vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
LongSparseMatrixSumAggregatorThe long matrix aggregator is used to register and aggregate long matrices.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
LongSparseVectorThe long vector holds the values of a particular row.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
LongSparseVectorSumAggregatorThe long vector aggregator is used to aggregate long vectors.Classorg.apache.giraph.aggregators.matrix.sparseGiraph
LongSumAggregatorAggregator for summing up long values.Classorg.apache.giraph.aggregatorsGiraph
LongToLongWritableWrapperClassorg.apache.giraph.typesGiraph
LongTypeOpsTypeOps implementation for working with LongWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
LongWritableToLongUnwrapperClassorg.apache.giraph.typesGiraph
MapMutableEdgeHelper class for a mutable edge that modifies the backing map entry.Classorg.apache.giraph.edgeGiraph
MappingEntryClassorg.apache.giraph.mappingGiraph
MappingInputFormatUse this to load data for a BSP application.Classorg.apache.giraph.ioGiraph
MappingInputSplitsCallableLoad as many mapping input splits as possible.Classorg.apache.giraph.workerGiraph
MappingInputSplitsCallableFactoryFactory for MappingInputSplitsCallables.Classorg.apache.giraph.workerGiraph
MappingReaderWill read the mapping from an input split.Classorg.apache.giraph.ioGiraph
MappingReaderWrapperClassorg.apache.giraph.io.iterablesGiraph
MappingStoreMappingStore used to store the vertexId - target map supplied by user Methods implemented in this class need to be thread safeInterfaceorg.apache.giraph.mappingGiraph
MappingStoreOpsInterface of operations that can be done on mapping store once it is fully loadedInterfaceorg.apache.giraph.mappingGiraph
MapTypeOpsTypeOps implementation for working with MapWritable typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
MasterAggregatorHandlerClassorg.apache.giraph.masterGiraph
MasterAggregatorUsageInterfaceorg.apache.giraph.masterGiraph
MasterClientInterfaceorg.apache.giraph.commGiraph
MasterComputeInterface for defining a master vertex that can perform centralized computation between supersteps.Classorg.apache.giraph.masterGiraph
MasterGlobalCommUsageMaster compute can access reduce and broadcast methods through this interface, from masterCompute method.Interfaceorg.apache.giraph.masterGiraph
MasterGraphPartitionerDetermines how to divide the graph into partitions, how to manipulate partitions and then how to assign those partitions to workers.Interfaceorg.apache.giraph.partitionGiraph
MasterInfoInformation about the master that is sent to other workers.Classorg.apache.giraph.masterGiraph
MasterLoggingAggregatorHelper class for using aggregator which gathers log messages from workers and prints them on master.Classorg.apache.giraph.utilsGiraph
MasterObserverObserver for Master.Interfaceorg.apache.giraph.masterGiraph
MasterRequestInterfaceorg.apache.giraph.comm.requestsGiraph
MasterRequestServerHandlerClassorg.apache.giraph.comm.netty.handlerGiraph
MasterServerInterfaceorg.apache.giraph.commGiraph
MasterThreadMaster thread that will coordinate the activities of the tasks.Classorg.apache.giraph.masterGiraph
MathUtilsClassorg.apache.giraph.utilsGiraph
MatrixSumAggregatorThe abstract matrix aggregator contains the prefix name of the vector aggregators that have the values of the rows.Classorg.apache.giraph.aggregators.matrixGiraph
MaxComputationSimple algorithm that computes the max value in the graph.Classorg.apache.giraph.examplesGiraph
MemoryUtilsHelper static methods for tracking memory usage.Classorg.apache.giraph.utilsGiraph
MessageCombinerAbstract class to extend for combining messages sent to the same vertex.Classorg.apache.giraph.combinerGiraph
MessageEncodeAndStoreTypeenum MessageEncodeAndStoreTypeThere are two types of message-stores currentlyClassorg.apache.giraph.comm.messagesGiraph
MessagesIterableClassorg.apache.giraph.comm.messagesGiraph
MessageStoreInterfaceorg.apache.giraph.comm.messagesGiraph
MessageStoreFactoryInterfaceorg.apache.giraph.comm.messagesGiraph
MessageValueFactoryFactory class to create default message values.Interfaceorg.apache.giraph.factoriesGiraph
MeterDescDescription for Meters used in Giraph.Classorg.apache.giraph.metricsGiraph
MetricNamesInterfaceorg.apache.giraph.metricsGiraph
MetricsRegistryDebuggerA simple MetricsRegistry listener that prints every Metric added/removed.Classorg.apache.giraph.metricsGiraph
MinimumDoubleMessageCombinerMessageCombiner which finds the minimum of DoubleWritable.Classorg.apache.giraph.combinerGiraph
MinimumIntMessageCombinerClassorg.apache.giraph.combinerGiraph
MultiEdgeInputFormatEdge input format which wraps several edge input formats.Classorg.apache.giraph.io.formats.multiGiraph
MultiInputUtilsUtility methods used by MultiVertexInputFormat and MultiEdgeInputFormatClassorg.apache.giraph.io.formats.multiGiraph
MultiRandomAccessOutEdgesInterface for OutEdges implementations that provide efficient random access to the edges given the target vertex id.Interfaceorg.apache.giraph.edgeGiraph
MultiThreadedSuperstepOutputClassorg.apache.giraph.io.superstep_outputGiraph
MultiVertexInputFormatVertex input format which wraps several vertex input formats.Classorg.apache.giraph.io.formats.multiGiraph
MutableEdgeAn edge whose value can be modified.Interfaceorg.apache.giraph.edgeGiraph
MutableEdgesIterableHelper class to provide a mutable iterable over the edges when the chosen OutEdges doesn't offer a specialized one.Classorg.apache.giraph.edgeGiraph
MutableEdgesWrapperHelper class that wraps the current out-edges and inserts them into a new data structure as they are iterated over.Classorg.apache.giraph.edgeGiraph
MutableOutEdgesInterface for OutEdges implementations that have an optimized mutable edge iterator.Interfaceorg.apache.giraph.edgeGiraph
NettyClientNetty client for sending requests.Classorg.apache.giraph.comm.nettyGiraph
NettyMasterClientClassorg.apache.giraph.comm.nettyGiraph
NettyMasterServerClassorg.apache.giraph.comm.nettyGiraph
NettyServerClassorg.apache.giraph.comm.nettyGiraph
NettyWorkerAggregatorRequestProcessorClassorg.apache.giraph.comm.nettyGiraph
NettyWorkerClientTakes users facing APIs in WorkerClient and implements them using the available WritableRequest objects.Classorg.apache.giraph.comm.nettyGiraph
NettyWorkerClientRequestProcessorAggregate requests and sends them to the thread-safe NettyClient.Classorg.apache.giraph.comm.nettyGiraph
NettyWorkerServerNetty worker server that implement WorkerServer and contains the actual ServerData.Classorg.apache.giraph.comm.nettyGiraph
NoOpCounterClasscom.yammer.metrics.coreGiraph
NoOpExecutorServiceAn executor service that does nothing.Classcom.yammer.metrics.coreGiraph
NoOpGuageA Metrics Gauge implementation that always returns null.Classcom.yammer.metrics.coreGiraph
NoOpHistogramAn empty Metrics' Histogram that does nothing.Classcom.yammer.metrics.coreGiraph
NoOpMeterAn empty Metrics' Meter implementation that does nothing.Classcom.yammer.metrics.coreGiraph
NoOpMetricsRegistryAn empty MetricsRegistry, used to easily turn off all metrics without affecting client code.Classorg.apache.giraph.metricsGiraph
NoOpSuperstepOutputClass to use as SuperstepOutput when we don't have output during computation.Classorg.apache.giraph.io.superstep_outputGiraph
NoOpTimerAn empty Metrics' Timer implementation that does nothing.Classcom.yammer.metrics.coreGiraph
NormalizingLongDoubleDoubleTextInputFormatSimple text-based VertexInputFormat for unweighted graphs with long ids.Classorg.apache.giraph.examplesGiraph
OneMessagePerVertexStore message per vertex.Classorg.apache.giraph.comm.messagesGiraph
OneMessageToManyIdsIteratorVertexIdData iterator for ByteArrayOneMessageToManyIdsClassorg.apache.giraph.utilsGiraph
OnSameReduceOperationReduceOperation object when single object being reduced is of same type as reduced value.Classorg.apache.giraph.reducersGiraph
OutboundByteCounterKeep track of the bytes sent and provide some metrics when desired as part of the Netty Channel stack.Classorg.apache.giraph.comm.nettyGiraph
OutEdgesInterface for data structures that store out-edges for a vertex.Interfaceorg.apache.giraph.edgeGiraph
OwnerAggregatorServerDataClass for holding aggregators which current worker owns, and aggregating partial aggregator values from workers.Classorg.apache.giraph.comm.aggregatorsGiraph
PageRankBenchmarkClassorg.apache.giraph.benchmarkGiraph
PageRankComputation are floats, and graph is unweighted.Classorg.apache.giraph.benchmarkGiraph
PageRankComputationThe PageRank algorithm, with uniform transition probabilities on the edges http://en.Classorg.apache.giraph.examplesGiraph
PairListCollection to keep pairs in, without creating a wrapper object around each pair of objects.Classorg.apache.giraph.utilsGiraph
PartitionA generic container that stores vertices.Interfaceorg.apache.giraph.partitionGiraph
PartitionBalancerHelper class for balancing partitions across a set of workers.Classorg.apache.giraph.partitionGiraph
PartitionDiskBackedMessageStoreMessage storage with in-memory map of messages and with support for flushing all the messages to the disk.Classorg.apache.giraph.comm.messages.out_of_coreGiraph
PartitionExchangeDescribes what is required to send and wait for in a potential partition exchange between workers.Classorg.apache.giraph.partitionGiraph
PartitionMessageSmall wrapper that holds a reference to vertex message and knows partition id.Classorg.apache.giraph.comm.messages.queueGiraph
PartitionOwnerMetadata about ownership of a partition.Interfaceorg.apache.giraph.partitionGiraph
PartitionStatsUsed to keep track of statistics of every Partition.Classorg.apache.giraph.partitionGiraph
PartitionStoreStructure that stores partitions for a worker.Classorg.apache.giraph.partitionGiraph
PartitionUtilsHelper class for Partition related operations.Classorg.apache.giraph.partitionGiraph
PerGraphTypeBooleanClassorg.apache.giraph.confGiraph
PerGraphTypeBooleanConfOptionClassorg.apache.giraph.confGiraph
PerGraphTypeEnumClassorg.apache.giraph.confGiraph
PerGraphTypeEnumConfOptionClassorg.apache.giraph.confGiraph
PipelineUtilsClassorg.apache.giraph.utilsGiraph
PointerListMessagesIterableClassorg.apache.giraph.comm.messagesGiraph
PointerListPerVertexStore stored as a list of long pointers to extended data output objects Used when there is no combiner provided.Classorg.apache.giraph.comm.messagesGiraph
PredicateLockA lock with a predicate that was be used to synchronize events and keep the job context updated while waiting.Classorg.apache.giraph.zkGiraph
PrimitiveIdTypeOpsAdditional type operations to TypeOps for types that can be IDs, and so can be used as keys in maps and values in sets.Interfaceorg.apache.giraph.types.opsGiraph
PrimitiveTypeOpsType operations, allowing working generically with types, but still having efficient code.Interfaceorg.apache.giraph.types.opsGiraph
PrimitiveValueReaderClassorg.apache.giraph.hive.primitivesGiraph
PrimitiveValueWriterClassorg.apache.giraph.hive.primitivesGiraph
ProgressableUtilsClassorg.apache.giraph.utilsGiraph
PseudoRandomEdgeInputFormatThis EdgeInputFormat generates pseudo-random edges on the fly.Classorg.apache.giraph.io.formatsGiraph
PseudoRandomInputFormatConstantsContains constants for configuring pseudo-random input formats.Classorg.apache.giraph.io.formatsGiraph
PseudoRandomIntNullLocalEdgesHelperHelper class to generate pseudo-random local edges.Classorg.apache.giraph.io.formatsGiraph
PseudoRandomIntNullVertexInputFormatVertexInputFormat for large scale testing, like PseudoRandomVertexInputFormat, but for the unweighted graphsClassorg.apache.giraph.io.formatsGiraph
PseudoRandomLocalEdgesHelperHelper class to generate pseudo-random local edges.Classorg.apache.giraph.io.formatsGiraph
PseudoRandomUtilsClassorg.apache.giraph.io.formatsGiraph
PseudoRandomVertexInputFormatThis VertexInputFormat is meant for large scale testing.Classorg.apache.giraph.io.formatsGiraph
RandomMessageBenchmarkRandom Message Benchmark for evaluating the messaging performance.Classorg.apache.giraph.benchmarkGiraph
RandomWalkComputationClassorg.apache.giraph.examplesGiraph
RandomWalkVertexMasterComputeMaster compute associated with RandomWalkComputation.Classorg.apache.giraph.examplesGiraph
RandomWalkWithRestartComputationExecutes RandomWalkWithRestart, a random walk on the graph which is biased towards a source vertex.Classorg.apache.giraph.examplesGiraph
RandomWalkWorkerContextWorker context for random walks.Classorg.apache.giraph.examplesGiraph
ReactiveJMapHistoDumperAn observer for both worker and master that periodically checks if available memory on heap is below certain threshold, and if found to be the caseClassorg.apache.giraph.utilsGiraph
RecordReaderWrapperClassorg.apache.giraph.hive.inputGiraph
ReduceOperationReduce operations defining how to reduce single values passed on workers, into partial values on workers, and thenInterfaceorg.apache.giraph.reducersGiraph
ReducerObject responsible for performing reducing operation.Classorg.apache.giraph.reducersGiraph
ReducersBenchmarkBenchmark for reducers.Classorg.apache.giraph.benchmarkGiraph
ReflectionUtilsHelper methods to get type arguments to generic classes.Classorg.apache.giraph.utilsGiraph
RepresentativeByteStructIterableThe objects provided by the iterators generated from this object have lifetimes only until next() is called.Classorg.apache.giraph.utilsGiraph
RepresentativeByteStructIteratorThe objects provided by this iterator have lifetimes only until next() is called.Classorg.apache.giraph.utilsGiraph
RequestDecoderDecodes encoded requests from the client.Classorg.apache.giraph.comm.netty.handlerGiraph
RequestEncoderRequests have a request type and an encoded request.Classorg.apache.giraph.comm.netty.handlerGiraph
RequestInfoClassorg.apache.giraph.comm.netty.handlerGiraph
RequestServerHandlerGeneric handler of requests.Classorg.apache.giraph.comm.netty.handlerGiraph
RequestTypeClassorg.apache.giraph.comm.requestsGiraph
RequestUtilsClassorg.apache.giraph.utilsGiraph
ResetSuperstepMetricsObserverObserver for users of per-superstep counters.Interfaceorg.apache.giraph.metricsGiraph
ResettableIteratorDefines an iterator that can iterated over multiple times, by rewinding it via reset() function.Interfaceorg.apache.giraph.types.ops.collectionsGiraph
ResponseClientHandlerGeneric handler of responses.Classorg.apache.giraph.comm.netty.handlerGiraph
ResponseEncoderHow a server should respond to a client.Classorg.apache.giraph.comm.netty.handlerGiraph
RetryableJobProgressTrackerClientWrapper around JobProgressTracker which retires to connect and swallows exceptions so app wouldn't crash if something goes wrong with progressClassorg.apache.giraph.graphGiraph
ReusableEdgeA complete edge, the target vertex and the edge value.Interfaceorg.apache.giraph.edgeGiraph
ReuseObjectsOutEdgesEmpty interface to characterize OutEdges implementations that don't keep references to the Edge (or id and value) objects they are passed.Interfaceorg.apache.giraph.edgeGiraph
ReusesObjectsPartitionEmpty interface to characterize Partition implementations that don't keep references to the Vertex objects they are passed.Interfaceorg.apache.giraph.partitionGiraph
ReverseEdgeDuplicatorAn EdgeReader that creates the opposite direction edge for each edge read.Classorg.apache.giraph.ioGiraph
RexsterEdgeInputFormatAbstract class that users should subclass to use their own Rexster based vertex input format.Classorg.apache.giraph.rexster.ioGiraph
RexsterEdgeOutputFormatAbstract class that users should subclass to use their own Rexster based edge output format.Classorg.apache.giraph.rexster.ioGiraph
RexsterInputSplitA InputSplit that spans a set of vertices.Classorg.apache.giraph.rexster.ioGiraph
RexsterLongDoubleDoubleEdgeOutputFormatRexster Edge Output Format for Long ID's, Double Vertex values and Double edge values.Classorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongDoubleDoubleVertexInputFormatClassorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongDoubleDoubleVertexOutputFormatRexster Vertex Output Format for Long ID's, Double Vertex values and Double edge values.Classorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongDoubleEdgeInputFormatClassorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongDoubleFloatEdgeOutputFormatClassorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongDoubleFloatVertexInputFormatClassorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongDoubleFloatVertexOutputFormatClassorg.apache.giraph.rexster.io.formatsGiraph
RexsterLongFloatEdgeInputFormatClassorg.apache.giraph.rexster.io.formatsGiraph
RexsterUtilsClassorg.apache.giraph.rexster.utilsGiraph
RexsterVertexInputFormatAbstract class that users should subclass to use their own Rexster based vertex input format.Classorg.apache.giraph.rexster.ioGiraph
RexsterVertexOutputFormatAbstract class that users should subclass to use their own Rexster based vertex onput format.Classorg.apache.giraph.rexster.ioGiraph
SaslClientHandlerClassorg.apache.giraph.comm.netty.handlerGiraph
SaslCompleteRequestReply from server to client after SASL authentication completes.Classorg.apache.giraph.comm.requestsGiraph
SaslNettyClientClassorg.apache.giraph.comm.nettyGiraph
SaslNettyServerEncapsulates SASL server logic for Giraph BSP worker servers.Classorg.apache.giraph.comm.nettyGiraph
SaslServerHandlerGenerate SASL response tokens to client SASL tokens, allowing clients to authenticate themselves with this server.Classorg.apache.giraph.comm.netty.handlerGiraph
SaslTokenMessageRequestSend and receive SASL tokens.Classorg.apache.giraph.comm.requestsGiraph
SccComputationFinds strongly connected components of the graph.Classorg.apache.giraph.examples.sccGiraph
SccLongLongNullTextInputFormatSimple text-based VertexInputFormat for unweighted graphs with long ids.Classorg.apache.giraph.examples.sccGiraph
SccPhaseMasterComputeThis master compute keeps track of what phase is being currently executed by the Strongly Connected Components computation.Classorg.apache.giraph.examples.sccGiraph
SccVertexValueVertex value for the Strongly Connected Components algorithm.Classorg.apache.giraph.examples.sccGiraph
ScriptLoaderLoads scripts written by user in other languages, for example Jython.Classorg.apache.giraph.scriptingGiraph
SendAggregatorsToOwnerRequestClassorg.apache.giraph.comm.requestsGiraph
SendAggregatorsToWorkerRequestClassorg.apache.giraph.comm.requestsGiraph
SendDataCacheAn abstract structure for caching data by partitions to be sent to workers in bulk.Classorg.apache.giraph.commGiraph
SendEdgeCacheAggregates the edges to be sent to workers so they can be sent in bulk.Classorg.apache.giraph.commGiraph
SendGlobalCommCacheTakes and serializes global communication values and keeps them grouped by owner partition id, to be sent in bulk.Classorg.apache.giraph.comm.aggregatorsGiraph
SendMessageCacheAggregates the messages to be sent to workers so they can be sent in bulk.Classorg.apache.giraph.commGiraph
SendMutationsCacheClassorg.apache.giraph.commGiraph
SendOneMessageToManyCacheClassorg.apache.giraph.commGiraph
SendPartitionCacheCaches partition vertices prior to sending.Classorg.apache.giraph.commGiraph
SendPartitionCurrentMessagesRequestSend a collection of vertex messages for a partition.Classorg.apache.giraph.comm.requestsGiraph
SendPartitionMutationsRequestSend a collection of vertex mutations for a partition.Classorg.apache.giraph.comm.requestsGiraph
SendReducedToMasterRequestRequest to send final aggregated values from worker which owns aggregators to the masterClassorg.apache.giraph.comm.requestsGiraph
SendVertexIdDataCacheAn abstract structure for caching data indexed by vertex id, to be sent to workers in bulk.Classorg.apache.giraph.commGiraph
SendVertexRequestSend a collection of vertices for a partition.Classorg.apache.giraph.comm.requestsGiraph
SendWorkerAggregatorsRequestRequest to send partial aggregated values for current superstep (values which were computed by one worker's vertices)Classorg.apache.giraph.comm.requestsGiraph
SendWorkerDataRequestClassorg.apache.giraph.comm.requestsGiraph
SendWorkerEdgesRequestSend a collection of edges for a partition.Classorg.apache.giraph.comm.requestsGiraph
SendWorkerMessagesRequestSend a collection of vertex messages for a partition.Classorg.apache.giraph.comm.requestsGiraph
SendWorkerOneMessageToManyRequestSend a collection of ByteArrayOneMessageToManyIds messages to a worker.Classorg.apache.giraph.comm.requestsGiraph
SendWorkerToWorkerMessageRequestClassorg.apache.giraph.comm.requestsGiraph
SendWorkerVerticesRequestClassorg.apache.giraph.comm.requestsGiraph
SequenceFileVertexInputFormatSequence file vertex input format based on SequenceFileInputFormat.Classorg.apache.giraph.io.formatsGiraph
SequenceFileVertexOutputFormatSequence file vertex output format.Classorg.apache.giraph.io.formatsGiraph
SequentialFileMessageStoreUsed for writing and reading collection of messages to the disk.Classorg.apache.giraph.comm.messages.out_of_coreGiraph
ServerDataClassorg.apache.giraph.commGiraph
ShortestPathsBenchmarkSingle-source shortest paths benchmark.Classorg.apache.giraph.benchmarkGiraph
ShortestPathsComputationShortest paths algorithm.Classorg.apache.giraph.benchmarkGiraph
ShortToIntWritableWrapperClassorg.apache.giraph.typesGiraph
ShortToLongWritableWrapperClassorg.apache.giraph.typesGiraph
SimpleAggregatorWriterThis is a simple example for an aggregator writer.Classorg.apache.giraph.examplesGiraph
SimpleCheckpointAn example that simply uses its id, value, and edges to compute new data every iteration to verify that checkpoint restarting works.Classorg.apache.giraph.examplesGiraph
SimpleCombinerComputationTest whether messages can go through a combiner.Classorg.apache.giraph.examplesGiraph
SimpleEdgeStoreSimple in memory edge store which supports any type of ids.Classorg.apache.giraph.edgeGiraph
SimpleFailComputationClassorg.apache.giraph.examplesGiraph
SimpleHiveToEdgeClassorg.apache.giraph.hive.input.edgeGiraph
SimpleHiveToMappingClassorg.apache.giraph.hive.input.mappingGiraph
SimpleHiveToVertexClassorg.apache.giraph.hive.input.vertexGiraph
SimpleInDegreeCountComputationSimple function to return the out degree for each vertex.Classorg.apache.giraph.examplesGiraph
SimpleIntRangePartitionerFactoryFactory for simple range-based partitioners based on integer vertex ids.Classorg.apache.giraph.partitionGiraph
SimpleLongDoubleDoubleDoubleIdentityComputationA simple use of the Identity Vertex for taking care of Long, Double, Double, Double type Inputformat Good for use withClassorg.apache.giraph.examplesGiraph
SimpleLongRangePartitionerFactoryFactory for simple range-based partitioners based on long vertex ids.Classorg.apache.giraph.partitionGiraph
SimpleMasterComputeComputationClassorg.apache.giraph.examplesGiraph
SimpleMasterPartitionerAbstracts and implements all MasterGraphPartitioner logic on top of a single user function - getWorkerIndex.Classorg.apache.giraph.partitionGiraph
SimpleMessageStoreAbstract class for MessageStore which allows any kind of object to hold messages for one vertex.Classorg.apache.giraph.comm.messagesGiraph
SimpleMsgComputationTest whether messages can be sent and received by vertices.Classorg.apache.giraph.examplesGiraph
SimpleMutateGraphComputationVertex to allow unit testing of graph mutations.Classorg.apache.giraph.examplesGiraph
SimpleNoEdgesHiveToVertexSimple implementation of HiveToVertex when each vertex is in the one row of the input, and there are no edges in vertex input.Classorg.apache.giraph.hive.input.vertexGiraph
SimpleOutDegreeCountComputationSimple function to return the out degree for each vertex.Classorg.apache.giraph.examplesGiraph
SimplePageRankComputationDemonstrates the basic Pregel PageRank implementation.Classorg.apache.giraph.examplesGiraph
SimplePartitionA simple map-based container that stores vertices.Classorg.apache.giraph.partitionGiraph
SimplePartitionerFactoryAbstracts and implements all GraphPartitionerFactory logic on top of two functions which define partitioning scheme:Classorg.apache.giraph.partitionGiraph
SimplePartitionStoreA simple in-memory partition store.Classorg.apache.giraph.partitionGiraph
SimpleShortestPathsComputationDemonstrates the basic Pregel shortest paths implementation.Classorg.apache.giraph.examplesGiraph
SimpleSumMessageCombinerMessageCombiner which sums up IntWritable message values.Classorg.apache.giraph.combinerGiraph
SimpleSuperstepComputationClassorg.apache.giraph.examplesGiraph
SimpleTextVertexOutputFormatSimple text based vertex output format example.Classorg.apache.giraph.examplesGiraph
SimpleTriangleClosingComputationDemonstrates triangle closing in simple, unweighted graphs for Giraph.Classorg.apache.giraph.examplesGiraph
SimpleVertexToHiveSimple implementation of VertexToHive when each Vertex is stored to one row in the output.Classorg.apache.giraph.hive.outputGiraph
SimpleVertexWithWorkerContextFully runnable example of how to emit worker data to HDFS during a graphClassorg.apache.giraph.examplesGiraph
SimpleVertexWriterInterfaceorg.apache.giraph.ioGiraph
SimpleWorkerPartitionerAbstracts and implements all WorkerGraphPartitioner logic on top of a single user function - getPartitionIndex.Classorg.apache.giraph.partitionGiraph
SrcIdDstIdEdgeValueTextOutputFormatWrite out Edge Value with Source and Destination ID, but not the vertex This is a demostration output format to show the possibility to separatelyClassorg.apache.giraph.io.formatsGiraph
StrConfOptionClassorg.apache.giraph.confGiraph
StrictRandomAccessOutEdgesInterface for OutEdges implementations that provide efficient random access to the edges given the target vertex id.Interfaceorg.apache.giraph.edgeGiraph
SuperstepClassesHolds Computation and MessageCombiner class.Classorg.apache.giraph.masterGiraph
SuperstepHashPartitionerFactoryExample graph partitioner that builds on HashMasterPartitioner to send the partitions to the worker that matches the superstep.Classorg.apache.giraph.integrationGiraph
SuperstepMetricsRegistryWrapper around MetricsRegistry for per-superstep metrics.Classorg.apache.giraph.metricsGiraph
SuperstepOutputInterface for outputing data during the computation.Interfaceorg.apache.giraph.io.superstep_outputGiraph
SuperstepStateState of a coordinated superstepEnum Constant SummaryClassorg.apache.giraph.bspGiraph
SynchronizedSuperstepOutputClassorg.apache.giraph.io.superstep_outputGiraph
SystemTimeClassorg.apache.giraph.timeGiraph
TaskIdsPermitsBarrierThis barrier is used when we don't know how many events are we waiting on from the start.Classorg.apache.giraph.utilsGiraph
TaskInfoAbstract class for information about any task - worker or master.Classorg.apache.giraph.graphGiraph
TestComputationStateComputationClassorg.apache.giraph.examplesGiraph
TestGraphTestGraph class for in-memory testing.Classorg.apache.giraph.utilsGiraph
TestMessageValueFactoryClassorg.apache.giraph.factoriesGiraph
TextAggregatorWriterDefault implementation of AggregatorWriter.Classorg.apache.giraph.aggregatorsGiraph
TextAppendAggregatorClassorg.apache.giraph.aggregatorsGiraph
TextDoubleDoubleAdjacencyListVertexInputFormatClass to read graphs stored as adjacency lists with ids represented by Strings and values as doubles.Classorg.apache.giraph.io.formatsGiraph
TextEdgeInputFormatAbstract class that users should subclass to use their own text based edge output format.Classorg.apache.giraph.io.formatsGiraph
TextEdgeOutputFormatAbstract class that users should subclass to use their own text based edge output format.Classorg.apache.giraph.io.formatsGiraph
TextTypeOpsTypeOps implementation for working with Text typeEnum Constant SummaryClassorg.apache.giraph.types.opsGiraph
TextVertexInputFormatAbstract class that users should subclass to use their own text based vertex input format.Classorg.apache.giraph.io.formatsGiraph
TextVertexOutputFormatAbstract class that users should subclass to use their own text based vertex output format.Classorg.apache.giraph.io.formatsGiraph
TextVertexValueInputFormatAbstract class that users should subclass to use their own text based vertex value input format.Classorg.apache.giraph.io.formatsGiraph
ThreadUtilsUtility class for thread related functions.Classorg.apache.giraph.utilsGiraph
TimeInterfaceorg.apache.giraph.timeGiraph
TimedLoggerPrint log messages only if the time is met.Classorg.apache.giraph.utilsGiraph
TimesUtility methods for Time classes.Classorg.apache.giraph.timeGiraph
TranslateEdgeUsed to conduct expensive translation of edges during vertex input phaseInterfaceorg.apache.giraph.mapping.translateGiraph
TrimmableInterface for OutEdges and Vertex implementations capable to optimizeInterfaceorg.apache.giraph.utilsGiraph
TypeOpsType operations, allowing working generically with mutable types, but still having efficient code.Interfaceorg.apache.giraph.types.opsGiraph
TypeOpsUtilsUtility functions for getting TypeOps instances from class types.Classorg.apache.giraph.types.opsGiraph
TypesHolderInterface for classes that are parameterized by all of the Giraph types.Interfaceorg.apache.giraph.confGiraph
UnsafeArrayReadsClassorg.apache.giraph.utilsGiraph
UnsafeByteArrayInputStreamClassorg.apache.giraph.utilsGiraph
UnsafeByteArrayOutputStreamClassorg.apache.giraph.utilsGiraph
UnsafeReadsClassorg.apache.giraph.utilsGiraph
UnsafeReusableByteArrayInputUnsafeReusableByteArrayInput is a data structure to read from a byte buffer with a read pointer that can be moved to desired locationClassorg.apache.giraph.utilsGiraph
ValueFactoriesHolder for factories to create user types.Classorg.apache.giraph.factoriesGiraph
ValueFactoryInterfaceorg.apache.giraph.factoriesGiraph
ValueGaugeA Gauge that holds a value.Classorg.apache.giraph.metricsGiraph
VerboseByteStructMessageWriteClassorg.apache.giraph.utilsGiraph
VerifyMessageAn example that simply uses its id, value, and edges to compute new data every iteration to verify that messages are sent and received at theClassorg.apache.giraph.examplesGiraph
VertexClass which holds vertex id, data and edges.Interfaceorg.apache.giraph.graphGiraph
VertexChangesInterfaceorg.apache.giraph.graphGiraph
VertexEdgeCountSimple immutable structure for storing a final vertex and edge count.Classorg.apache.giraph.graphGiraph
VertexIdDataInterfaceorg.apache.giraph.utilsGiraph
VertexIdDataIteratorSpecial iterator that reuses vertex ids and data objects so that the lifetime of the object is only until next() is called.Interfaceorg.apache.giraph.utilsGiraph
VertexIdEdgeIteratorSpecial iterator that reuses vertex ids and edge objects so that the lifetime of the object is only until next() is called.Interfaceorg.apache.giraph.utilsGiraph
VertexIdEdgesInterfaceorg.apache.giraph.utilsGiraph
VertexIdFactoryFactory class to create default vertex IDs.Interfaceorg.apache.giraph.factoriesGiraph
VertexIdIteratorCommon implementation for VertexIdEdgeIterator, VertexIdMessageIterator and VertexIdMessageBytesIterator.Interfaceorg.apache.giraph.utilsGiraph
VertexIdMessageBytesIteratorSpecial iterator that reuses vertex ids and messages bytes so that the lifetime of the object is only until next() is called.Interfaceorg.apache.giraph.utilsGiraph
VertexIdMessageIteratorSpecial iterator that reuses vertex ids and message objects so that the lifetime of the object is only until next() is called.Interfaceorg.apache.giraph.utilsGiraph
VertexIdMessagesInterfaceorg.apache.giraph.utilsGiraph
VertexInputFilterFilters vertices on input.Interfaceorg.apache.giraph.io.filtersGiraph
VertexInputFormatUse this to load data for a BSP application.Classorg.apache.giraph.ioGiraph
VertexInputFormatDescriptionDescription of the vertex input format - holds vertex input format class and all parameters specifically set for that vertex input format.Classorg.apache.giraph.io.formats.multiGiraph
VertexInputSplitsCallableLoad as many vertex input splits as possible.Classorg.apache.giraph.workerGiraph
VertexInputSplitsCallableFactoryFactory for VertexInputSplitsCallables.Classorg.apache.giraph.workerGiraph
VertexIteratorIterates over vertices stored in an ExtendedDataOutput such that the ownership of the vertex id can be transferred to another object.Classorg.apache.giraph.utilsGiraph
VertexMutationsClassorg.apache.giraph.graphGiraph
VertexOutputFormat directly after the Hadoop OutputFormat.Classorg.apache.giraph.ioGiraph
VertexReaderAnalogous to Hadoop's RecordReader for vertices.Classorg.apache.giraph.ioGiraph
VertexReaderWrapperClassorg.apache.giraph.io.iterablesGiraph
VertexResolverHandles all the situations that can arise upon creation/removal of vertices and edges.Interfaceorg.apache.giraph.graphGiraph
VertexToHiveInterface for writing vertices to Hive.Interfaceorg.apache.giraph.hive.outputGiraph
VertexValueCombinerWhen vertex values with the same vertex id are loaded, this class specifies how to combine their vertex values.Interfaceorg.apache.giraph.graphGiraph
VertexValueFactoryFactory class to create default vertex values.Interfaceorg.apache.giraph.factoriesGiraph
VertexValueInputFormatVertex input format that only allows setting vertex id and value.Classorg.apache.giraph.ioGiraph
VertexValueReaderVertex reader for VertexValueInputFormat.Classorg.apache.giraph.ioGiraph
VertexWithDoubleValueDoubleEdgeTextOutputFormatSimple vertex output format for weighted graphs.Classorg.apache.giraph.examplesGiraph
VertexWithDoubleValueNullEdgeTextOutputFormatClassorg.apache.giraph.examplesGiraph
VertexWriterClassorg.apache.giraph.ioGiraph
WattsStrogatzVertexInputFormatGenerates a random Watts-Strogatz graph by re-wiring a ring lattice.Classorg.apache.giraph.io.formatsGiraph
WeightedPageRankBenchmarkClassorg.apache.giraph.benchmarkGiraph
WeightedPageRankComputationClassorg.apache.giraph.benchmarkGiraph
WorkerAggregatorDelegatorClass for delegating WorkerAggregatorUsage and WorkerGlobalCommUsage methods to corresponding interface.Classorg.apache.giraph.workerGiraph
WorkerAggregatorHandlerClassorg.apache.giraph.workerGiraph
WorkerAggregatorRequestProcessorInterfaceorg.apache.giraph.comm.aggregatorsGiraph
WorkerAggregatorUsageInterfaceorg.apache.giraph.workerGiraph
WorkerBroadcastUsageInterfaceorg.apache.giraph.workerGiraph
WorkerClientInterfaceorg.apache.giraph.commGiraph
WorkerClientRequestProcessorInterfaceorg.apache.giraph.commGiraph
WorkerContextWorkerContext allows for the execution of user code on a per-worker basis.Classorg.apache.giraph.workerGiraph
WorkerGlobalCommUsageMethods on worker can access broadcasted values and provide values to reduce through this interfaceInterfaceorg.apache.giraph.workerGiraph
WorkerGraphPartitionerStores the PartitionOwner objects from the master and provides the mapping of vertex to PartitionOwner.Interfaceorg.apache.giraph.partitionGiraph
WorkerInfoInformation about a worker that is sent to the master and other workers.Classorg.apache.giraph.workerGiraph
WorkerObserverObserver for worker.Interfaceorg.apache.giraph.workerGiraph
WorkerProgressStores information about a worker's progress that is periodically written to ZooKeeper with WorkerProgressWriter.Classorg.apache.giraph.workerGiraph
WorkerProgressWriterClassorg.apache.giraph.workerGiraph
WorkerReduceUsageInterfaceorg.apache.giraph.workerGiraph
WorkerRequestInterfaceorg.apache.giraph.comm.requestsGiraph
WorkerRequestReservedMapClassorg.apache.giraph.comm.netty.handlerGiraph
WorkerRequestServerHandlerClassorg.apache.giraph.comm.netty.handlerGiraph
WorkerServerInterface for message communication server.Interfaceorg.apache.giraph.commGiraph
WorkerSuperstepMetricsPer-superstep metrics for a Worker.Classorg.apache.giraph.metricsGiraph
WorkerThreadGlobalCommUsageWorkerAggregatorUsage which can be used in each of the computation threads.Interfaceorg.apache.giraph.workerGiraph
WrappedEdgeInputFormatFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedEdgeOutputFormatFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedEdgeReaderFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedMappingInputFormatFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedMappingReaderFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedVertexInputFormatFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedVertexOutputFormatFor internal use only.Classorg.apache.giraph.io.internalGiraph
WrappedVertexReaderFor internal use only.Classorg.apache.giraph.io.internalGiraph
WritableRequestClassorg.apache.giraph.comm.requestsGiraph
WritableUnwrapperInterfaceorg.apache.giraph.typesGiraph
WritableUnwrappersMapping of all the known Writable wrappers.Classorg.apache.giraph.typesGiraph
WritableUtilsHelper static methods for working with Writable objects.Classorg.apache.giraph.utilsGiraph
WritableWrapperInterfaceorg.apache.giraph.typesGiraph
WritableWrappersMapping of all the known Writable wrappers.Classorg.apache.giraph.typesGiraph
WritableWriterInterfaceorg.apache.giraph.types.ops.collectionsGiraph
YarnUtilsUtilities that can only compile with versions of Hadoop that support YARN, so they live here instead of o.Classorg.apache.giraph.yarnGiraph
YourKitContextConvenience context for profiling.Classorg.apache.giraph.utilsGiraph
YourKitProfilerHelper for YourKit profiling from within the code.Classorg.apache.giraph.utilsGiraph
ZooKeeperExtZooKeeper provides only atomic operations.Classorg.apache.giraph.zkGiraph
ZooKeeperManagerClassorg.apache.giraph.zkGiraph
ZooKeeperNodeCreatorClassorg.apache.giraph.zkGiraph