This project has retired. For details please refer to its
Attic page.
Class Hierarchy (Apache Giraph Parent 1.4.0-SNAPSHOT API)
Class Hierarchy
- java.lang.Object
- org.apache.giraph.block_app.framework.AbstractBlockFactory<S> (implements org.apache.giraph.block_app.framework.BlockFactory<S>)
- java.util.AbstractCollection<E> (implements java.util.Collection<E>)
- it.unimi.dsi.fastutil.booleans.AbstractBooleanCollection (implements it.unimi.dsi.fastutil.booleans.BooleanCollection)
- it.unimi.dsi.fastutil.booleans.AbstractBooleanList (implements it.unimi.dsi.fastutil.booleans.BooleanList, it.unimi.dsi.fastutil.booleans.BooleanStack)
- it.unimi.dsi.fastutil.bytes.AbstractByteCollection (implements it.unimi.dsi.fastutil.bytes.ByteCollection)
- it.unimi.dsi.fastutil.bytes.AbstractByteList (implements it.unimi.dsi.fastutil.bytes.ByteList, it.unimi.dsi.fastutil.bytes.ByteStack)
- it.unimi.dsi.fastutil.doubles.AbstractDoubleCollection (implements it.unimi.dsi.fastutil.doubles.DoubleCollection)
- it.unimi.dsi.fastutil.doubles.AbstractDoubleList (implements it.unimi.dsi.fastutil.doubles.DoubleList, it.unimi.dsi.fastutil.doubles.DoubleStack)
- it.unimi.dsi.fastutil.floats.AbstractFloatCollection (implements it.unimi.dsi.fastutil.floats.FloatCollection)
- it.unimi.dsi.fastutil.floats.AbstractFloatList (implements it.unimi.dsi.fastutil.floats.FloatList, it.unimi.dsi.fastutil.floats.FloatStack)
- it.unimi.dsi.fastutil.ints.AbstractIntCollection (implements it.unimi.dsi.fastutil.ints.IntCollection)
- it.unimi.dsi.fastutil.ints.AbstractIntList (implements it.unimi.dsi.fastutil.ints.IntList, it.unimi.dsi.fastutil.ints.IntStack)
- java.util.AbstractList<E> (implements java.util.List<E>)
- it.unimi.dsi.fastutil.longs.AbstractLongCollection (implements it.unimi.dsi.fastutil.longs.LongCollection)
- it.unimi.dsi.fastutil.longs.AbstractLongList (implements it.unimi.dsi.fastutil.longs.LongList, it.unimi.dsi.fastutil.longs.LongStack)
- org.apache.giraph.conf.AbstractConfOption (implements java.lang.Comparable<T>)
- org.apache.giraph.mapping.AbstractLongByteOps (implements org.apache.giraph.mapping.MappingStoreOps<I,B>)
- org.apache.giraph.block_app.framework.piece.AbstractPiece<I,V,E,M,WV,WM,S> (implements org.apache.giraph.block_app.framework.block.Block)
- org.apache.giraph.block_app.framework.piece.DefaultParentPiece<I,V,E,M,WV,WM,S>
- org.apache.giraph.block_app.framework.piece.Piece<I,V,E,M,S>
- org.apache.giraph.block_app.framework.piece.PieceWithWorkerContext<I,V,E,M,WV,WM,S>
- org.apache.giraph.block_app.framework.piece.delegate.DelegatePiece<I,V,E,M,WV,WM,S>
- org.apache.giraph.block_app.framework.piece.delegate.FilteringPiece<I,V,E,M,WV,WM,S>
- org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexReceiver (implements org.apache.giraph.block_app.framework.piece.interfaces.VertexPostprocessor, org.apache.giraph.block_app.framework.piece.interfaces.VertexReceiver<I,V,E,M>)
- org.apache.giraph.block_app.framework.piece.AbstractPiece.InnerVertexSender (implements org.apache.giraph.block_app.framework.piece.interfaces.VertexPostprocessor, org.apache.giraph.block_app.framework.piece.interfaces.VertexSender<I,V,E>)
- org.apache.giraph.utils.AbstractVertexIdData<I,T> (implements org.apache.giraph.utils.VertexIdData<I,T>)
- org.apache.giraph.graph.AddressesAndPartitionsWritable (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.metrics.AggregatedMetric<T>
- org.apache.giraph.metrics.AggregatedMetrics
- org.apache.giraph.master.AggregatorToGlobalCommTranslation (implements org.apache.giraph.master.MasterAggregatorUsage, org.apache.hadoop.io.Writable)
- org.apache.giraph.comm.aggregators.AggregatorUtils
- org.apache.giraph.comm.aggregators.AllAggregatorServerData
- org.apache.giraph.conf.AllOptions
- org.apache.giraph.worker.AllWorkersInfo
- org.apache.giraph.utils.AnnotationUtils
- org.apache.giraph.block_app.reducers.array.ArrayOfHandles<H> (implements org.apache.giraph.block_app.framework.piece.global_comm.array.ArrayHandle<T>)
- org.apache.giraph.block_app.reducers.array.ArrayReduce<S,R> (implements org.apache.giraph.reducers.ReduceOperation<S,R>)
- org.apache.giraph.utils.ArrayWritable<T> (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.comm.messages.queue.AsyncMessageStoreWrapper<I,M> (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.types.ops.collections.Basic2ObjectMap<K,V> (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.types.ops.collections.Basic2ObjectMap.ReusableIterator<Iter> (implements org.apache.giraph.types.ops.collections.ResettableIterator<T>)
- org.apache.giraph.aggregators.BasicAggregator<A> (implements org.apache.giraph.aggregators.Aggregator<A>)
- org.apache.giraph.block_app.reducers.array.BasicArrayReduce<S,R> (implements org.apache.giraph.reducers.ReduceOperation<S,R>)
- org.apache.giraph.types.ops.collections.BasicCollectionsUtils
- org.apache.giraph.master.input.BasicInputSplitsMasterOrganizer (implements org.apache.giraph.master.input.InputSplitsMasterOrganizer)
- org.apache.giraph.block_app.reducers.map.BasicMapReduce<K,S,R> (implements org.apache.giraph.reducers.ReduceOperation<S,R>)
- org.apache.giraph.partition.BasicPartition<I,V,E> (implements org.apache.giraph.partition.Partition<I,V,E>)
- org.apache.giraph.partition.BasicPartitionOwner (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.partition.PartitionOwner)
- org.apache.giraph.types.ops.collections.BasicSet.BasicIntOpenHashSet (implements org.apache.giraph.types.ops.collections.BasicSet<T>)
- org.apache.giraph.types.ops.collections.BasicSet.BasicLongOpenHashSet (implements org.apache.giraph.types.ops.collections.BasicSet<T>)
- org.apache.giraph.benchmark.BenchmarkOption
- org.apache.giraph.utils.io.BigDataInput (implements org.apache.giraph.utils.ExtendedDataInput)
- org.apache.giraph.utils.io.BigDataOutput (implements java.io.DataOutput, org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.framework.api.BlockApiHandle
- org.apache.giraph.block_app.framework.internal.BlockCounters
- org.apache.giraph.utils.BlockingElementsSet<T>
- org.apache.giraph.block_app.framework.internal.BlockMasterLogic<S>
- org.apache.giraph.block_app.framework.internal.BlockMasterLogic.TimeStatsPerEvent
- org.apache.giraph.block_app.framework.output.BlockOutputHandle (implements org.apache.giraph.block_app.framework.api.BlockOutputApi)
- org.apache.giraph.block_app.framework.output.BlockOutputOption<OD,OW>
- org.apache.giraph.block_app.framework.BlockUtils
- org.apache.giraph.block_app.framework.internal.BlockWorkerContextLogic
- org.apache.giraph.block_app.framework.internal.BlockWorkerLogic
- org.apache.giraph.block_app.framework.internal.BlockWorkerPieces<S>
- org.apache.giraph.types.BooleanToBooleanWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.BooleanWritableToBooleanUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.examples.utils.BrachaTouegDeadlockMessage (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.examples.utils.BrachaTouegDeadlockVertexValue (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.bsp.BspService<I,V,E> (implements org.apache.giraph.bsp.CentralizedService<I,V,E>, org.apache.zookeeper.Watcher)
- org.apache.giraph.master.BspServiceMaster<I,V,E> (implements org.apache.giraph.bsp.CentralizedServiceMaster<I,V,E>, org.apache.giraph.metrics.ResetSuperstepMetricsObserver)
- org.apache.giraph.worker.BspServiceWorker<I,V,E> (implements org.apache.giraph.bsp.CentralizedServiceWorker<I,V,E>, org.apache.giraph.metrics.ResetSuperstepMetricsObserver)
- org.apache.giraph.comm.messages.ByteArrayMessagesPerVertexStore.Factory<I,M> (implements org.apache.giraph.comm.messages.MessageStoreFactory<I,M,MS>)
- org.apache.giraph.comm.netty.ByteCounterDelegate (implements org.apache.giraph.comm.netty.ByteCounter)
- org.apache.giraph.utils.ByteStructIterable<T> (implements java.lang.Iterable<T>)
- org.apache.giraph.utils.ByteStructIterator<T> (implements java.util.Iterator<E>)
- org.apache.giraph.utils.ByteStructVertexIdIterator<I> (implements org.apache.giraph.utils.VertexIdIterator<I>)
- org.apache.giraph.types.ByteToByteWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.ByteToIntWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.ByteToLongWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.utils.ByteUtils
- org.apache.giraph.types.ByteWritableToByteUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.types.ByteWritableToIntUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.types.ByteWritableToLongUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.types.ByteWritableToShortUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- io.netty.channel.ChannelHandlerAdapter (implements io.netty.channel.ChannelHandler)
- io.netty.channel.ChannelInboundHandlerAdapter (implements io.netty.channel.ChannelInboundHandler)
- io.netty.channel.ChannelOutboundHandlerAdapter (implements io.netty.channel.ChannelOutboundHandler)
- org.apache.giraph.comm.netty.ChannelRotater
- org.apache.giraph.utils.CheckpointingUtils
- org.apache.giraph.comm.netty.handler.ClientRequestId
- org.apache.giraph.job.ClientThriftServer
- org.apache.giraph.utils.CollectionUtils
- org.apache.giraph.block_app.reducers.collect.CollectShardedTuplesOfPrimitivesReducerHandle.CollectShardedTuplesOfPrimitivesReduceBroadcast
- org.apache.giraph.zk.ComputationDoneName
- org.apache.giraph.graph.ComputeCallable<I,V,E,M1,M2> (implements java.util.concurrent.Callable<V>)
- org.apache.hadoop.conf.Configuration (implements java.lang.Iterable<T>, org.apache.hadoop.io.Writable)
- org.apache.giraph.utils.ConfigurationObjectUtils
- org.apache.giraph.utils.ConfigurationUtils
- com.yammer.metrics.core.Counter (implements com.yammer.metrics.core.Metric)
- org.apache.giraph.utils.CounterUtils
- org.apache.giraph.comm.aggregators.CountingCache
- org.apache.giraph.comm.aggregators.CountingOutputStream
- org.apache.giraph.block_app.framework.piece.global_comm.internal.CreateReducersApiWrapper (implements org.apache.giraph.block_app.framework.api.CreateReducersApi)
- org.apache.giraph.comm.flow_control.CreditBasedFlowControl (implements org.apache.giraph.comm.flow_control.FlowControl)
- org.apache.giraph.counters.CustomCounter (implements java.lang.Comparable<T>, org.apache.hadoop.io.Writable)
- org.apache.giraph.counters.CustomCounters
- org.apache.giraph.ooc.persistence.DataIndex
- org.apache.giraph.ooc.persistence.DataIndex.NumericIndexEntry (implements org.apache.giraph.ooc.persistence.DataIndex.DataIndexEntry)
- org.apache.giraph.utils.io.DataInputOutput (implements org.apache.giraph.utils.Factory<T>, org.apache.hadoop.io.Writable)
- org.apache.giraph.bsp.checkpoints.DefaultCheckpointSupportedChecker (implements org.apache.giraph.bsp.checkpoints.CheckpointSupportedChecker)
- com.esotericsoftware.kryo.util.DefaultClassResolver (implements com.esotericsoftware.kryo.ClassResolver)
- org.apache.giraph.factories.DefaultComputationFactory<I,V,E> (implements org.apache.giraph.factories.ComputationFactory<I,V,E,M1,M2>)
- org.apache.giraph.edge.DefaultCreateSourceVertexCallback<I> (implements org.apache.giraph.edge.CreateSourceVertexCallback<I>)
- org.apache.giraph.edge.DefaultEdge<I,E> (implements org.apache.giraph.edge.ReusableEdge<I,E>)
- org.apache.giraph.factories.DefaultEdgeValueFactory<E> (implements org.apache.giraph.factories.EdgeValueFactory<E>, org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>)
- org.apache.giraph.job.DefaultGiraphJobRetryChecker (implements org.apache.giraph.job.GiraphJobRetryChecker)
- org.apache.giraph.conf.DefaultImmutableClassesGiraphConfigurable<I,V,E> (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.edge.AbstractEdgeStore<I,V,E,K,Et> (implements org.apache.giraph.edge.EdgeStore<I,V,E>)
- org.apache.giraph.master.AggregatorBroadcast<A> (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.edge.ConfigurableOutEdges<I,E> (implements org.apache.giraph.edge.OutEdges<I,E>)
- org.apache.giraph.edge.ArrayListEdges<I,E> (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.edge.ByteArrayEdges<I,E> (implements org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.edge.HashMapEdges<I,E> (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.StrictRandomAccessOutEdges<I,E>)
- org.apache.giraph.edge.HashMultimapEdges<I,E> (implements org.apache.giraph.edge.MultiRandomAccessOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.edge.LongDiffNullArrayEdges (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.io.filters.DefaultEdgeInputFilter<I,E> (implements org.apache.giraph.io.filters.EdgeInputFilter<I,E>)
- org.apache.giraph.graph.DefaultVertex<I,V,E> (implements org.apache.giraph.utils.Trimmable, org.apache.giraph.graph.Vertex<I,V,E>)
- org.apache.giraph.io.filters.DefaultVertexInputFilter<I,V,E,M> (implements org.apache.giraph.io.filters.VertexInputFilter<I,V,E>)
- org.apache.giraph.graph.DefaultVertexResolver<I,V,E> (implements org.apache.giraph.graph.VertexResolver<I,V,E>)
- org.apache.giraph.io.EdgeWriter<I,V,E>
- org.apache.giraph.io.GiraphInputFormat<I,V,E>
- org.apache.giraph.io.EdgeInputFormat<I,E>
- org.apache.giraph.io.MappingInputFormat<I,V,E,B>
- org.apache.giraph.io.VertexInputFormat<I,V,E>
- org.apache.giraph.io.formats.GeneratedVertexInputFormat<I,V,E>
- org.apache.giraph.utils.InMemoryVertexInputFormat<I,V,E>
- org.apache.giraph.io.formats.multi.MultiVertexInputFormat<I,V,E>
- org.apache.giraph.io.formats.PseudoRandomIntNullVertexInputFormat
- org.apache.giraph.io.formats.PseudoRandomVertexInputFormat
- org.apache.giraph.io.formats.SequenceFileVertexInputFormat<I,V,E,X>
- org.apache.giraph.io.formats.TextVertexInputFormat<I,V,E>
- org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat<I,V,E>
- org.apache.giraph.examples.io.formats.BrachaTouegDeadlockInputFormat
- org.apache.giraph.io.formats.IntIntNullTextInputFormat
- org.apache.giraph.io.formats.IntIntNullTextVertexInputFormat
- org.apache.giraph.io.formats.IntNullNullTextInputFormat
- org.apache.giraph.io.formats.JsonBase64VertexInputFormat<I,V,E>
- org.apache.giraph.io.formats.JsonLongDoubleFloatDoubleVertexInputFormat
- org.apache.giraph.examples.LongDoubleDoubleTextInputFormat (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.examples.LongDoubleFloatTextInputFormat (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.examples.LongDoubleNullTextInputFormat (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.io.formats.LongLongNullTextInputFormat
- org.apache.giraph.examples.NormalizingLongDoubleDoubleTextInputFormat (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.examples.scc.SccLongLongNullTextInputFormat
- org.apache.giraph.io.VertexValueInputFormat<I,V>
- org.apache.giraph.io.formats.WattsStrogatzVertexInputFormat
- org.apache.giraph.io.internal.WrappedVertexInputFormat<I,V,E>
- org.apache.giraph.partition.GraphPartitionerFactory<I,V,E> (implements org.apache.giraph.partition.GraphPartitionerFactoryInterface<I,V,E>)
- org.apache.giraph.zk.InProcessZooKeeperRunner (implements org.apache.giraph.zk.ZooKeeperRunner)
- org.apache.giraph.jython.JythonComputation
- org.apache.giraph.worker.LocalData<I,V,E,B>
- org.apache.giraph.mapping.LongByteMappingStore (implements org.apache.giraph.mapping.MappingStore<I,B>)
- org.apache.giraph.mapping.translate.LongByteTranslateEdge<E> (implements org.apache.giraph.mapping.translate.TranslateEdge<I,E>)
- org.apache.giraph.master.MasterCompute (implements org.apache.giraph.master.MasterAggregatorUsage, org.apache.giraph.master.MasterGlobalCommUsage, org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.migration.MigrationMasterCompute (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.migration.MigrationWorkerContext (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.graph.OnlyIdVertex<I> (implements org.apache.giraph.graph.Vertex<I,V,E>)
- org.apache.giraph.io.OutputFormat<I,V,E>
- org.apache.giraph.io.EdgeOutputFormat<I,V,E>
- org.apache.giraph.io.VertexOutputFormat<I,V,E>
- org.apache.giraph.io.formats.InMemoryVertexOutputFormat<I,V,E>
- org.apache.giraph.io.formats.SequenceFileVertexOutputFormat<I,V,E,OK,OV>
- org.apache.giraph.io.formats.TextVertexOutputFormat<I,V,E>
- org.apache.giraph.io.internal.WrappedVertexOutputFormat<I,V,E>
- org.apache.giraph.utils.ReactiveJMapHistoDumper (implements org.apache.giraph.master.MasterObserver, org.apache.giraph.worker.WorkerObserver)
- org.apache.giraph.examples.SimpleAggregatorWriter (implements org.apache.giraph.aggregators.AggregatorWriter)
- org.apache.giraph.aggregators.TextAggregatorWriter (implements org.apache.giraph.aggregators.AggregatorWriter)
- org.apache.giraph.io.VertexWriter<I,V,E> (implements org.apache.giraph.io.SimpleVertexWriter<I,V,E>)
- org.apache.giraph.worker.WorkerAggregatorDelegator<I,V,E> (implements org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage)
- org.apache.giraph.graph.AbstractComputation<I,V,E,M1,M2> (implements org.apache.giraph.graph.Computation<I,V,E,M1,M2>)
- org.apache.giraph.io.EdgeReader<I,E>
- org.apache.giraph.io.MappingReader<I,V,E,B>
- org.apache.giraph.block_app.migration.MigrationAbstractComputation<I,V,E,M1,M2> (implements org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.hadoop.io.Writable)
- org.apache.giraph.io.VertexReader<I,V,E>
- org.apache.giraph.io.BasicVertexValueReader<I,V>
- org.apache.giraph.examples.GeneratedVertexReader<I,V,E>
- org.apache.giraph.io.formats.SequenceFileVertexInputFormat.SequenceFileVertexReader<I,V,E,X>
- org.apache.giraph.io.formats.TextVertexInputFormat.TextVertexReader
- org.apache.giraph.io.iterables.VertexReaderWrapper<I,V,E>
- org.apache.giraph.io.internal.WrappedVertexReader<I,V,E>
- org.apache.giraph.worker.WorkerContext (implements org.apache.giraph.worker.WorkerIndexUsage<I>, org.apache.hadoop.io.Writable)
- org.apache.giraph.factories.DefaultInputOutEdgesFactory<I,E> (implements org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>, org.apache.giraph.factories.OutEdgesFactory<I,E>)
- org.apache.giraph.job.DefaultJobObserver (implements org.apache.giraph.job.GiraphJobObserver, org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.job.DefaultJobProgressTrackerService (implements org.apache.giraph.job.JobProgressTrackerService)
- org.apache.giraph.master.DefaultMasterObserver (implements org.apache.giraph.master.MasterObserver)
- org.apache.giraph.conf.DefaultMessageClasses<I,M> (implements org.apache.giraph.conf.MessageClasses<I,M>)
- org.apache.giraph.factories.DefaultMessageValueFactory<M> (implements org.apache.giraph.factories.MessageValueFactory<M>)
- org.apache.giraph.factories.DefaultOutEdgesFactory<I,E> (implements org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>, org.apache.giraph.factories.OutEdgesFactory<I,E>)
- org.apache.giraph.factories.DefaultVertexIdFactory<I> (implements org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>, org.apache.giraph.factories.VertexIdFactory<I>)
- org.apache.giraph.graph.DefaultVertexValueCombiner<I,V,E> (implements org.apache.giraph.graph.VertexValueCombiner<V>)
- org.apache.giraph.factories.DefaultVertexValueFactory<V> (implements org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>, org.apache.giraph.factories.VertexValueFactory<V>)
- org.apache.giraph.worker.DefaultWorkerObserver (implements org.apache.giraph.worker.WorkerObserver)
- org.apache.giraph.scripting.DeployedScript
- org.apache.giraph.bsp.checkpoints.DisabledCheckpointSupportedChecker (implements org.apache.giraph.bsp.checkpoints.CheckpointSupportedChecker)
- org.apache.giraph.ooc.data.DiskBackedDataStore<T>
- org.apache.giraph.ooc.data.DiskBackedEdgeStore<I,V,E> (implements org.apache.giraph.edge.EdgeStore<I,V,E>)
- org.apache.giraph.ooc.data.DiskBackedMessageStore<I,M> (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.ooc.data.DiskBackedPartitionStore<I,V,E> (implements org.apache.giraph.partition.PartitionStore<I,V,E>)
- org.apache.giraph.utils.DistributedCacheUtils
- org.apache.giraph.aggregators.matrix.dense.DoubleDenseMatrix
- org.apache.giraph.aggregators.matrix.dense.DoubleDenseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.aggregators.matrix.sparse.DoubleSparseMatrix
- org.apache.giraph.aggregators.matrix.sparse.DoubleSparseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.combiner.DoubleSumMessageCombiner (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.types.DoubleToDoubleWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.DoubleWritableToDoubleUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.utils.DynamicChannelBufferInputStream (implements java.io.DataInput)
- org.apache.giraph.utils.DynamicChannelBufferOutputStream (implements java.io.DataOutput)
- org.apache.giraph.block_app.test_setup.graphs.EachVertexInit<I,V,E> (implements org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>)
- org.apache.giraph.utils.EdgeComparator<I,E> (implements java.util.Comparator<T>, java.io.Serializable)
- org.apache.giraph.edge.EdgeFactory
- org.apache.giraph.worker.EdgeInputSplitsCallableFactory<I,V,E> (implements org.apache.giraph.utils.CallableFactory<R>)
- org.apache.giraph.utils.EdgeIterables
- org.apache.giraph.edge.EdgeNoValue<I> (implements org.apache.giraph.edge.ReusableEdge<I,E>)
- org.apache.giraph.io.iterables.EdgeWithSource<I,E>
- org.apache.giraph.block_app.framework.block.EmptyBlock (implements org.apache.giraph.block_app.framework.block.Block)
- org.apache.giraph.utils.EmptyIterable<T> (implements java.lang.Iterable<T>)
- org.apache.giraph.utils.ExtendedByteArrayOutputBuffer
- org.apache.giraph.utils.ExtendedByteArrayOutputBuffer.IndexAndDataOut
- org.apache.giraph.conf.FacebookConfiguration (implements org.apache.giraph.conf.BulkConfigurator)
- org.apache.giraph.time.FakeTime (implements org.apache.giraph.time.Time)
- org.apache.giraph.io.formats.FileOutputFormatUtil
- org.apache.giraph.utils.FileUtils
- org.apache.giraph.block_app.framework.block.FilteringBlock<I,V,E> (implements org.apache.giraph.block_app.framework.block.Block)
- org.apache.giraph.types.heaps.FixedCapacityIntByteMinHeap (implements org.apache.giraph.types.heaps.Int2ByteMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityIntDoubleMinHeap (implements org.apache.giraph.types.heaps.Int2DoubleMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityIntFloatMinHeap (implements org.apache.giraph.types.heaps.Int2FloatMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityIntIntMinHeap (implements org.apache.giraph.types.heaps.Int2IntMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityIntLongMinHeap (implements org.apache.giraph.types.heaps.Int2LongMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityLongByteMinHeap (implements org.apache.giraph.types.heaps.Long2ByteMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityLongDoubleMinHeap (implements org.apache.giraph.types.heaps.Long2DoubleMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityLongFloatMinHeap (implements org.apache.giraph.types.heaps.Long2FloatMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityLongIntMinHeap (implements org.apache.giraph.types.heaps.Long2IntMapEntryIterable)
- org.apache.giraph.types.heaps.FixedCapacityLongLongMinHeap (implements org.apache.giraph.types.heaps.Long2LongMapEntryIterable)
- org.apache.giraph.ooc.policy.FixedPartitionsOracle (implements org.apache.giraph.ooc.policy.OutOfCoreOracle)
- org.apache.giraph.aggregators.matrix.dense.FloatDenseMatrix
- org.apache.giraph.aggregators.matrix.dense.FloatDenseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.aggregators.matrix.sparse.FloatSparseMatrix
- org.apache.giraph.aggregators.matrix.sparse.FloatSparseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.combiner.FloatSumMessageCombiner (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.types.FloatToDoubleWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.FloatToFloatWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.FloatWritableToDoubleUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.types.FloatWritableToFloatUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- com.yammer.metrics.core.Gauge<T> (implements com.yammer.metrics.core.Metric)
- org.apache.giraph.utils.GcTracker
- org.apache.giraph.yarn.GiraphApplicationMaster
- org.apache.giraph.benchmark.GiraphBenchmark (implements org.apache.hadoop.util.Tool)
- org.apache.giraph.conf.GiraphClasses<I,V,E> (implements org.apache.giraph.conf.GiraphConstants)
- org.apache.giraph.job.GiraphConfigurationValidator<I,V,E,M1,M2>
- org.apache.giraph.counters.GiraphCountersThriftStruct
- org.apache.giraph.utils.GiraphDepVersions
- org.apache.giraph.counters.GiraphHadoopCounter
- org.apache.giraph.job.GiraphJob
- org.apache.giraph.metrics.GiraphMetrics
- org.apache.giraph.metrics.GiraphMetricsRegistry
- org.apache.giraph.GiraphRunner (implements org.apache.hadoop.util.Tool)
- org.apache.giraph.metrics.GiraphTimerContext
- org.apache.giraph.graph.GiraphTransferRegulator
- org.apache.giraph.conf.GiraphTypes<I,V,E>
- org.apache.giraph.yarn.GiraphYarnClient
- org.apache.giraph.yarn.GiraphYarnTask<I,V,E>
- org.apache.giraph.zk.GiraphZooKeeperAdmin (implements org.apache.hadoop.util.Tool, org.apache.zookeeper.Watcher)
- org.apache.giraph.graph.GlobalStats (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.graph.GraphState
- org.apache.giraph.graph.GraphTaskManager<I,V,E> (implements org.apache.giraph.metrics.ResetSuperstepMetricsObserver)
- org.apache.giraph.graph.GraphTaskManager.FailWithEveryExceptionOccurred (implements org.apache.giraph.graph.GraphTaskManager.CheckerIfWorkerShouldFailAfterException)
- org.apache.giraph.counters.HadoopCountersBase (implements java.lang.Iterable<T>)
- org.apache.giraph.job.HadoopUtils
- org.apache.giraph.job.HaltApplicationUtils
- org.apache.giraph.job.HaltApplicationUtils.DefaultHaltInstructionsWriter (implements org.apache.giraph.job.HaltApplicationUtils.HaltInstructionsWriter)
- com.yammer.metrics.core.Histogram (implements com.yammer.metrics.core.Metric, com.yammer.metrics.core.Sampling, com.yammer.metrics.core.Summarizable)
- org.apache.giraph.block_app.reducers.array.HugeArrayUtils
- org.apache.giraph.edge.IdAndNullArrayEdges<I> (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>)
- org.apache.giraph.edge.IdAndValueArrayEdges<I,E> (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>)
- org.apache.giraph.comm.messages.primitives.IdByteArrayMessageStore<I,M> (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.comm.messages.primitives.IdOneMessagePerVertexStore<I,M> (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.block_app.framework.block.IfBlock (implements org.apache.giraph.block_app.framework.block.Block)
- org.apache.giraph.writable.kryo.serializers.ImmutableBiMapSerializerUtils
- org.apache.giraph.utils.IncreasingBitSet
- org.apache.giraph.ooc.persistence.InMemoryDataAccessor (implements org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor)
- org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataInputWrapper (implements org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataInputWrapper)
- org.apache.giraph.ooc.persistence.InMemoryDataAccessor.InMemoryDataOutputWrapper (implements org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataOutputWrapper)
- org.apache.giraph.edge.InMemoryEdgeStoreFactory<I,V,E> (implements org.apache.giraph.edge.EdgeStoreFactory<I,V,E>)
- org.apache.giraph.comm.messages.InMemoryMessageStoreFactory<I,M> (implements org.apache.giraph.comm.messages.MessageStoreFactory<I,M,MS>)
- org.apache.giraph.zk.InProcessZooKeeperRunner.ZooKeeperServerRunner
- org.apache.hadoop.mapreduce.InputFormat<K,V>
- org.apache.giraph.bsp.BspInputFormat
- org.apache.hadoop.mapreduce.lib.input.FileInputFormat<K,V>
- org.apache.giraph.io.formats.multi.InputFormatDescription<IF>
- org.apache.hadoop.mapreduce.InputSplit
- org.apache.giraph.bsp.BspInputSplit (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.worker.InputSplitsCallable<I,V,E> (implements java.util.concurrent.Callable<V>)
- java.io.InputStream (implements java.io.Closeable)
- org.apache.giraph.aggregators.matrix.dense.IntDenseMatrix
- org.apache.giraph.aggregators.matrix.dense.IntDenseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.utils.InternalVertexRunner
- org.apache.giraph.comm.messages.primitives.IntFloatMessageStore (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.edge.IntNullArrayEdges (implements org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.utils.IntPair
- org.apache.giraph.aggregators.matrix.sparse.IntSparseMatrix
- org.apache.giraph.aggregators.matrix.sparse.IntSparseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.types.IntToIntWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.IntToLongWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.IntWritableToIntUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.types.IntWritableToLongUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.ooc.command.IOCommand
- org.apache.giraph.block_app.library.iteration.IterationStageImpl (implements org.apache.giraph.block_app.library.iteration.IterationStage)
- org.apache.giraph.io.iterables.IteratorToReaderWrapper<T>
- org.apache.giraph.types.JavaWritablePair<W,J>
- org.apache.giraph.utils.JMap
- org.apache.giraph.utils.JMapHistoDumper (implements org.apache.giraph.master.MasterObserver, org.apache.giraph.worker.WorkerObserver)
- org.apache.giraph.graph.JobProgressTrackerClientNoOp (implements org.apache.giraph.graph.JobProgressTrackerClient)
- org.apache.giraph.io.formats.JsonBase64VertexFormat
- org.apache.giraph.jython.factories.JythonComputationFactory (implements org.apache.giraph.factories.ComputationFactory<I,V,E,M1,M2>)
- org.apache.giraph.jython.factories.JythonFactoryBase<W> (implements org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>, org.apache.giraph.factories.ValueFactory<W>)
- org.apache.giraph.jython.JythonJob
- org.apache.giraph.jython.JythonJob.InputBase
- org.apache.giraph.jython.JythonJob.TypeHolder
- org.apache.giraph.jython.JythonJob.VertexOutput
- org.apache.giraph.jython.JythonOptions
- org.apache.giraph.jython.JythonOptions.JythonGraphTypeOptions
- org.apache.giraph.jython.JythonUtils
- com.esotericsoftware.kryo.Kryo
- org.apache.giraph.writable.kryo.KryoSimpleWrapper<T> (implements org.apache.giraph.writable.kryo.Boxed<T>, org.apache.hadoop.io.Writable)
- org.apache.giraph.writable.kryo.KryoSimpleWritable (implements org.apache.giraph.writable.kryo.markers.KryoIgnoreWritable)
- org.apache.giraph.reducers.impl.KryoWrappedReduceOperation<S,R> (implements org.apache.giraph.reducers.ReduceOperation<S,R>)
- org.apache.giraph.writable.kryo.KryoWritable (implements org.apache.giraph.writable.kryo.markers.KryoIgnoreWritable)
- org.apache.giraph.writable.kryo.KryoWritableWrapper<T> (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.framework.api.local.LocalBlockRunner
- org.apache.giraph.ooc.persistence.LocalDiskDataAccessor (implements org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor)
- org.apache.giraph.master.input.LocalityAwareInputSplitsMasterOrganizer (implements org.apache.giraph.master.input.InputSplitsMasterOrganizer)
- org.apache.giraph.utils.LoggerUtils
- org.apache.giraph.utils.LogStacktraceCallable<V> (implements java.util.concurrent.Callable<V>)
- org.apache.giraph.utils.LogVersions (implements org.apache.giraph.master.MasterObserver, org.apache.giraph.worker.WorkerObserver)
- org.apache.giraph.comm.messages.primitives.long_id.LongAbstractStore<M,T> (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.metrics.LongAndTimeUnit
- org.apache.giraph.edge.LongByteHashMapEdges (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.edge.StrictRandomAccessOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.aggregators.matrix.dense.LongDenseMatrix
- org.apache.giraph.aggregators.matrix.dense.LongDenseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.edge.LongDiffArray (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.edge.LongDoubleArrayEdges (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.edge.LongDoubleHashMapEdges (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.edge.StrictRandomAccessOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.comm.messages.primitives.LongDoubleMessageStore (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.edge.LongNullArrayEdges (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.edge.LongNullHashSetEdges (implements org.apache.giraph.edge.MutableOutEdges<I,E>, org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>, org.apache.giraph.edge.StrictRandomAccessOutEdges<I,E>, org.apache.giraph.utils.Trimmable)
- org.apache.giraph.aggregators.matrix.sparse.LongSparseMatrix
- org.apache.giraph.aggregators.matrix.sparse.LongSparseVector (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.types.LongToLongWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.LongWritableToLongUnwrapper (implements org.apache.giraph.types.WritableUnwrapper<W,J>)
- org.apache.giraph.edge.MapMutableEdge<I,E> (implements org.apache.giraph.edge.MutableEdge<I,E>)
- org.apache.hadoop.mapreduce.Mapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT>
- org.apache.giraph.mapping.MappingEntry<I,B>
- org.apache.giraph.worker.MappingInputSplitsCallableFactory<I,V,E,B> (implements org.apache.giraph.utils.CallableFactory<R>)
- org.apache.giraph.master.input.MappingInputSplitsMasterOrganizer (implements org.apache.giraph.master.input.InputSplitsMasterOrganizer)
- org.apache.giraph.master.MasterAggregatorHandler (implements org.apache.giraph.master.MasterGlobalCommUsageAggregators, org.apache.hadoop.io.Writable)
- org.apache.giraph.master.MasterGlobalCommHandler (implements org.apache.giraph.master.MasterGlobalCommUsage)
- org.apache.giraph.partition.MasterGraphPartitionerImpl<I,V,E> (implements org.apache.giraph.partition.MasterGraphPartitioner<I,V,E>)
- org.apache.giraph.master.input.MasterInputSplitsHandler
- org.apache.giraph.utils.MasterLoggingAggregator
- org.apache.giraph.master.MasterProgress
- org.apache.giraph.comm.netty.handler.MasterRequestServerHandler.Factory (implements org.apache.giraph.comm.netty.handler.RequestServerHandler.Factory)
- org.apache.giraph.utils.MathUtils
- org.apache.giraph.aggregators.matrix.MatrixSumAggregator
- org.apache.giraph.combiner.MaxMessageCombiner<M> (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.ooc.policy.MemoryEstimatorOracle (implements org.apache.giraph.ooc.policy.OutOfCoreOracle)
- org.apache.giraph.worker.MemoryObserver
- org.apache.giraph.utils.MemoryUtils
- org.apache.giraph.ooc.data.MetaPartitionManager
- com.yammer.metrics.core.Meter (implements com.yammer.metrics.core.Metered, com.yammer.metrics.core.Stoppable)
- com.yammer.metrics.core.MetricsRegistry
- org.apache.giraph.metrics.MetricsRegistryDebugger (implements com.yammer.metrics.core.MetricsRegistryListener)
- org.apache.giraph.block_app.migration.MigrationSuperstepStageImpl (implements org.apache.giraph.block_app.migration.MigrationSuperstepStage)
- org.apache.giraph.combiner.MinimumDoubleMessageCombiner (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.combiner.MinimumIntMessageCombiner (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.combiner.MinMessageCombiner<I,M> (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.io.formats.multi.MultiInputUtils
- org.apache.giraph.object.MultiSizedReusable<T> (implements org.apache.giraph.function.primitive.Int2ObjFunction<T>)
- org.apache.giraph.io.superstep_output.MultiThreadedSuperstepOutput<I,V,E> (implements org.apache.giraph.io.superstep_output.SuperstepOutput<I,V,E>)
- org.apache.giraph.edge.MutableEdgesIterable<I,E> (implements java.lang.Iterable<T>)
- org.apache.giraph.edge.MutableEdgesWrapper<I,E> (implements org.apache.giraph.edge.OutEdges<I,E>)
- org.apache.giraph.comm.netty.NettyClient
- org.apache.giraph.comm.netty.NettyMasterClient (implements org.apache.giraph.comm.MasterClient)
- org.apache.giraph.comm.netty.NettyMasterServer (implements org.apache.giraph.comm.MasterServer)
- org.apache.giraph.comm.netty.NettyServer
- org.apache.giraph.comm.netty.NettyWorkerAggregatorRequestProcessor (implements org.apache.giraph.comm.aggregators.WorkerAggregatorRequestProcessor)
- org.apache.giraph.comm.netty.NettyWorkerClient<I,V,E> (implements org.apache.giraph.metrics.ResetSuperstepMetricsObserver, org.apache.giraph.comm.WorkerClient<I,V,E>)
- org.apache.giraph.comm.netty.NettyWorkerClientRequestProcessor<I,V,E> (implements org.apache.giraph.comm.WorkerClientRequestProcessor<I,V,E>)
- org.apache.giraph.comm.netty.NettyWorkerServer<I,V,E> (implements org.apache.giraph.comm.WorkerServer<I,V,E>)
- org.apache.giraph.types.NoMessage (implements org.apache.hadoop.io.Writable)
- com.yammer.metrics.core.NoOpExecutorService (implements java.util.concurrent.ScheduledExecutorService)
- org.apache.giraph.comm.flow_control.NoOpFlowControl (implements org.apache.giraph.comm.flow_control.FlowControl)
- org.apache.giraph.io.superstep_output.NoOpSuperstepOutput<I,V,E> (implements org.apache.giraph.io.superstep_output.SuperstepOutput<I,V,E>)
- org.apache.giraph.combiner.NullMessageCombiner (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.block_app.test_setup.NumericTestGraph<I,V,E>
- org.apache.giraph.function.ObjectHolder<T> (implements org.apache.giraph.function.Consumer<T>, org.apache.giraph.function.Supplier<T>)
- org.apache.giraph.function.ObjectNotifier<T> (implements org.apache.giraph.function.Consumer<T>, org.apache.giraph.function.Notifier<T>)
- org.apache.giraph.function.ObjectTransfer<T> (implements org.apache.giraph.function.Consumer<T>, org.apache.giraph.function.Supplier<T>)
- org.apache.giraph.utils.OneMessageToManyIdsIterator<I,M> (implements org.apache.giraph.utils.VertexIdMessageIterator<I,M>)
- org.apache.giraph.ooc.OutOfCoreEngine (implements org.apache.giraph.metrics.ResetSuperstepMetricsObserver)
- org.apache.giraph.ooc.OutOfCoreIOCallable (implements java.util.concurrent.Callable<V>, org.apache.giraph.metrics.ResetSuperstepMetricsObserver)
- org.apache.giraph.ooc.OutOfCoreIOCallableFactory
- org.apache.giraph.ooc.OutOfCoreIOScheduler
- org.apache.giraph.ooc.OutOfCoreIOStatistics
- org.apache.giraph.ooc.OutOfCoreIOStatistics.BytesDuration
- org.apache.hadoop.mapreduce.OutputCommitter
- org.apache.hadoop.mapreduce.OutputFormat<K,V>
- org.apache.giraph.bsp.BspOutputFormat
- org.apache.hadoop.mapreduce.lib.output.FileOutputFormat<K,V>
- org.apache.hadoop.mapreduce.lib.output.TextOutputFormat<K,V>
- java.io.OutputStream (implements java.io.Closeable, java.io.Flushable)
- org.apache.giraph.comm.aggregators.OwnerAggregatorServerData
- org.apache.commons.lang3.tuple.Pair<L,R> (implements java.lang.Comparable<T>, java.util.Map.Entry<K,V>, java.io.Serializable)
- org.apache.giraph.writable.tuple.PairWritable<L,R> (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.framework.internal.PairedPieceAndStage<S>
- org.apache.giraph.utils.PairList<U,V>
- org.apache.giraph.utils.PairList.Iterator
- org.apache.giraph.reducers.impl.PairReduce<S1,R1,S2,R2> (implements org.apache.giraph.reducers.ReduceOperation<S,R>)
- org.apache.giraph.partition.PartitionBalancer
- org.apache.giraph.partition.PartitionExchange
- org.apache.giraph.comm.messages.queue.PartitionMessage<I,M>
- org.apache.giraph.partition.PartitionStats (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.partition.PartitionUtils
- org.apache.giraph.conf.PerGraphTypeBoolean
- org.apache.giraph.conf.PerGraphTypeBooleanConfOption
- org.apache.giraph.conf.PerGraphTypeEnum<T>
- org.apache.giraph.conf.PerGraphTypeEnumConfOption<T>
- org.apache.giraph.block_app.framework.block.PieceCount
- org.apache.giraph.block_app.library.Pieces
- org.apache.giraph.utils.PipelineUtils
- org.apache.giraph.comm.messages.PointerListMessagesIterable<M> (implements java.lang.Iterable<T>)
- org.apache.giraph.zk.PredicateLock (implements org.apache.giraph.zk.BspEvent)
- org.apache.giraph.function.primitive.PrimitiveRefs.DoubleRef
- org.apache.giraph.function.primitive.PrimitiveRefs.FloatRef
- org.apache.giraph.function.primitive.PrimitiveRefs.IntRef
- org.apache.giraph.function.primitive.PrimitiveRefs.LongRef
- org.apache.giraph.function.primitive.PrimitiveRefs.ObjRef<O>
- org.apache.giraph.function.primitive.PrimitiveRefs.ShortRef
- org.apache.giraph.utils.ProgressableUtils
- org.apache.giraph.utils.ProgressCounter
- org.apache.giraph.io.formats.PseudoRandomInputFormatConstants
- org.apache.giraph.io.formats.PseudoRandomIntNullLocalEdgesHelper
- org.apache.giraph.io.formats.PseudoRandomLocalEdgesHelper
- org.apache.giraph.io.formats.PseudoRandomUtils
- org.python.core.PyObject (implements java.io.Serializable)
- org.apache.hadoop.mapreduce.RecordWriter<K,V>
- org.apache.giraph.reducers.Reducer<S,R>
- org.apache.giraph.block_app.framework.piece.global_comm.ReducerAndBroadcastWrapperHandle<S,R>
- org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler (implements org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver)
- org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.BroadcastHandleImpl<T> (implements org.apache.giraph.block_app.framework.piece.global_comm.BroadcastHandle<T>)
- org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.ReduceHandleImpl<S,R> (implements org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle<S,R>, org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver)
- org.apache.giraph.block_app.framework.piece.global_comm.internal.ReducersForPieceHandler.WrappedReducedValue<R> (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.reducers.ReduceSameTypeOperation<R> (implements org.apache.giraph.reducers.ReduceOperation<S,R>)
- org.apache.giraph.block_app.framework.piece.global_comm.ReduceUtilsObject
- org.apache.giraph.utils.ReflectionUtils
- org.apache.giraph.block_app.framework.block.RepeatBlock (implements org.apache.giraph.block_app.framework.block.Block)
- org.apache.giraph.block_app.framework.block.RepeatUntilBlock (implements org.apache.giraph.block_app.framework.block.Block)
- org.apache.giraph.comm.netty.handler.RequestInfo
- org.apache.giraph.utils.RequestUtils
- org.apache.giraph.graph.RetryableJobProgressTrackerClient (implements org.apache.giraph.graph.JobProgressTrackerClient)
- org.apache.giraph.comm.netty.SaslNettyClient
- org.apache.giraph.comm.netty.SaslNettyServer.SaslDigestCallbackHandler (implements javax.security.auth.callback.CallbackHandler)
- org.apache.hadoop.security.SaslRpcServer
- org.apache.giraph.comm.netty.handler.SaslServerHandler.Factory
- org.apache.giraph.examples.scc.SccVertexValue (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.scripting.ScriptLoader
- java.util.concurrent.Semaphore (implements java.io.Serializable)
- org.apache.giraph.comm.SendDataCache<D>
- org.apache.giraph.comm.SendMessageCache.TargetVertexIdIterator<I> (implements java.util.Iterator<E>)
- org.apache.giraph.block_app.library.SendMessageChain<I,V,E,P>
- org.apache.giraph.comm.SendMutationsCache<I,V,E>
- org.apache.giraph.block_app.framework.block.SequenceBlock (implements org.apache.giraph.block_app.framework.block.Block)
- com.esotericsoftware.kryo.Serializer<T>
- org.apache.giraph.comm.ServerData<I,V,E>
- org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle<S,R> (implements org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle<S,R>)
- org.apache.giraph.block_app.reducers.collect.ShardedReducerHandle.ShardedBroadcastHandle (implements org.apache.giraph.block_app.framework.piece.global_comm.BroadcastHandle<T>)
- org.apache.giraph.types.ShortToIntWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.types.ShortToLongWritableWrapper (implements org.apache.giraph.types.WritableWrapper<W,J>)
- org.apache.giraph.examples.SimpleCheckpoint (implements org.apache.hadoop.util.Tool)
- org.apache.giraph.ooc.policy.SimpleGCMonitoringOracle (implements org.apache.giraph.ooc.policy.OutOfCoreOracle)
- org.apache.giraph.comm.messages.SimpleMessageStore<I,M,T> (implements org.apache.giraph.comm.messages.MessageStore<I,M>)
- org.apache.giraph.partition.SimplePartitionStore<I,V,E> (implements org.apache.giraph.partition.PartitionStore<I,V,E>)
- org.apache.giraph.combiner.SimpleSumMessageCombiner (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.examples.SimpleTriangleClosingComputation.Pair (implements java.lang.Comparable<T>)
- org.apache.giraph.examples.SimpleVertexWithWorkerContext (implements org.apache.hadoop.util.Tool)
- org.apache.giraph.block_app.test_setup.graphs.Small1GraphInit<I,V,E> (implements org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>)
- org.apache.giraph.block_app.test_setup.graphs.Small2GraphInit<I,V,E> (implements org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>)
- org.apache.giraph.block_app.test_setup.graphs.SmallDirectedForestGraphInit<I,V,E> (implements org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>)
- org.apache.giraph.block_app.test_setup.graphs.SmallDirectedTreeGraphInit<I,V,E> (implements org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>)
- org.apache.giraph.comm.flow_control.StaticFlowControl (implements org.apache.giraph.comm.flow_control.FlowControl, org.apache.giraph.metrics.ResetSuperstepMetricsObserver)
- org.apache.giraph.block_app.library.striping.StripingUtils
- org.apache.giraph.combiner.SumMessageCombiner<M> (implements org.apache.giraph.combiner.MessageCombiner<I,M>)
- org.apache.giraph.master.SuperstepClasses (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.DefaultMessageFactorySupplierFromConf<M> (implements org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf<T>)
- org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf.SupplierFromConfByCopy<T> (implements org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf<T>)
- org.apache.giraph.io.superstep_output.SynchronizedSuperstepOutput<I,V,E> (implements org.apache.giraph.io.superstep_output.SuperstepOutput<I,V,E>)
- org.apache.giraph.block_app.test_setup.graphs.SyntheticGraphInit<I,V,E> (implements org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>)
- org.apache.giraph.time.SystemTime (implements org.apache.giraph.time.Time)
- org.apache.giraph.utils.TaskIdsPermitsBarrier
- org.apache.giraph.graph.TaskInfo (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.comm.netty.handler.TaskRequestIdGenerator
- org.apache.giraph.utils.TestGraph<I,V,E> (implements java.lang.Iterable<T>)
- org.apache.giraph.block_app.test_setup.TestGraphUtils
- org.apache.giraph.factories.TestMessageValueFactory<M> (implements org.apache.giraph.factories.MessageValueFactory<M>)
- java.lang.Thread (implements java.lang.Runnable)
- java.lang.ThreadLocal<T>
- org.apache.giraph.utils.ThreadUtils
- org.apache.giraph.ooc.policy.ThresholdBasedOracle (implements org.apache.giraph.ooc.policy.OutOfCoreOracle)
- org.apache.giraph.utils.TimedLogger
- com.yammer.metrics.core.Timer (implements com.yammer.metrics.core.Metered, com.yammer.metrics.core.Sampling, com.yammer.metrics.core.Stoppable, com.yammer.metrics.core.Summarizable)
- org.apache.giraph.time.Times
- org.apache.giraph.writable.kryo.TransientRandom
- org.apache.giraph.types.ops.TypeOpsUtils
- org.apache.giraph.factories.ValueFactories<I,V,E>
- org.apache.giraph.metrics.ValueWithHostname<T>
- org.apache.giraph.utils.Varint
- org.apache.giraph.utils.VerboseByteStructMessageWrite
- org.apache.giraph.examples.VerifyMessage
- org.apache.giraph.examples.VerifyMessage.VerifiableMessage (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.graph.VertexEdgeCount
- org.apache.giraph.worker.VertexInputSplitsCallableFactory<I,V,E> (implements org.apache.giraph.utils.CallableFactory<R>)
- org.apache.giraph.utils.VertexIterator<I,V,E>
- org.apache.giraph.graph.VertexMutations<I,V,E> (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.graph.VertexChanges<I,V,E>, org.apache.hadoop.io.Writable)
- org.apache.giraph.block_app.library.VertexSuppliers
- org.apache.giraph.worker.WorkerAggregatorHandler (implements org.apache.giraph.worker.WorkerThreadGlobalCommUsage)
- org.apache.giraph.worker.WorkerAggregatorHandler.ThreadLocalWorkerGlobalCommUsage (implements org.apache.giraph.worker.WorkerThreadGlobalCommUsage)
- org.apache.giraph.partition.WorkerGraphPartitionerImpl<I,V,E> (implements org.apache.giraph.partition.WorkerGraphPartitioner<I,V,E>)
- org.apache.giraph.worker.WorkerInputSplitsHandler
- org.apache.giraph.worker.WorkerProgressStats
- org.apache.giraph.worker.WorkerProgressWriter
- org.apache.giraph.comm.netty.handler.WorkerRequestReservedMap
- org.apache.giraph.comm.netty.handler.WorkerRequestServerHandler.Factory<I,V,E> (implements org.apache.giraph.comm.netty.handler.RequestServerHandler.Factory)
- org.apache.giraph.metrics.WorkerSuperstepMetrics (implements org.apache.hadoop.io.Writable)
- org.apache.giraph.comm.requests.WritableRequest<I,V,E> (implements org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.hadoop.io.Writable)
- org.apache.giraph.comm.requests.AddressesAndPartitionsRequest (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.AskForInputSplitRequest (implements org.apache.giraph.comm.requests.MasterRequest)
- org.apache.giraph.comm.requests.ByteArrayRequest
- org.apache.giraph.comm.requests.PartitionStatsRequest (implements org.apache.giraph.comm.requests.MasterRequest)
- org.apache.giraph.comm.requests.ReplyWithInputSplitRequest (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SaslCompleteRequest
- org.apache.giraph.comm.requests.SaslTokenMessageRequest
- org.apache.giraph.comm.requests.SendPartitionCurrentMessagesRequest<I,V,E,M> (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendPartitionMutationsRequest<I,V,E> (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendResumeRequest (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendVertexRequest<I,V,E> (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendWorkerDataRequest<I,T,B> (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendWorkerOneMessageToManyRequest<I,M> (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendWorkerToWorkerMessageRequest (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.comm.requests.SendWorkerVerticesRequest<I,V,E> (implements org.apache.giraph.comm.requests.WorkerRequest<I,V,E>)
- org.apache.giraph.types.WritableUnwrappers
- org.apache.giraph.utils.WritableUtils
- org.apache.giraph.types.WritableWrappers
- org.apache.giraph.yarn.YarnUtils
- org.apache.giraph.utils.YourKitContext
- org.apache.giraph.utils.YourKitProfiler
- org.apache.giraph.zk.ZookeeperConfig
- org.apache.giraph.zk.ZooKeeperExt
- org.apache.giraph.zk.ZooKeeperExt.PathStat
- org.apache.giraph.zk.ZooKeeperManager
- org.apache.giraph.zk.ZooKeeperNodeCreator (implements org.apache.hadoop.util.Tool, org.apache.zookeeper.Watcher)
Interface Hierarchy
- org.apache.giraph.io.formats.AdjacencyListTextVertexInputFormat.LineSanitizer
- org.apache.giraph.aggregators.Aggregator<A>
- org.apache.giraph.aggregators.AggregatorUsage
- org.apache.giraph.block_app.framework.api.BlockMasterApi (also extends org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.master.MasterAggregatorUsage, org.apache.giraph.master.MasterGlobalCommUsage, org.apache.giraph.block_app.framework.api.StatusReporter)
- org.apache.giraph.block_app.framework.api.BlockWorkerApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi<I,WM> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.master.MasterAggregatorUsage
- org.apache.giraph.worker.WorkerAggregatorUsage
- org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi<I,WM> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerGlobalCommUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.piece.global_comm.array.ArrayHandle<T>
- java.lang.AutoCloseable
- org.apache.giraph.block_app.framework.api.BlockConfApi
- org.apache.giraph.block_app.framework.api.BlockApi
- org.apache.giraph.block_app.framework.api.BlockMasterApi (also extends org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.master.MasterAggregatorUsage, org.apache.giraph.master.MasterGlobalCommUsage, org.apache.giraph.block_app.framework.api.StatusReporter)
- org.apache.giraph.block_app.framework.api.BlockWorkerApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi<I,WM> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.block_app.framework.api.BlockMasterApi (also extends org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.master.MasterAggregatorUsage, org.apache.giraph.master.MasterGlobalCommUsage, org.apache.giraph.block_app.framework.api.StatusReporter)
- org.apache.giraph.block_app.framework.api.BlockWorkerApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi<I,WM> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.block_app.framework.api.CreateReducersApi
- org.apache.giraph.block_app.framework.BlockFactory<S>
- org.apache.giraph.block_app.framework.api.BlockOutputApi
- org.apache.giraph.block_app.framework.api.BlockMasterApi (also extends org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.master.MasterAggregatorUsage, org.apache.giraph.master.MasterGlobalCommUsage, org.apache.giraph.block_app.framework.api.StatusReporter)
- org.apache.giraph.block_app.framework.api.BlockWorkerApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.StatusReporter, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.block_app.framework.output.BlockOutputDesc<OW>
- org.apache.giraph.block_app.framework.api.BlockOutputHandleAccessor
- org.apache.giraph.block_app.framework.api.BlockWorkerValueAccessor
- org.apache.giraph.writable.kryo.Boxed<T>
- org.apache.giraph.block_app.framework.piece.global_comm.BroadcastHandle<T>
- org.apache.giraph.zk.BspEvent
- org.apache.giraph.conf.BulkConfigurator
- org.apache.giraph.comm.netty.ByteCounter
- org.apache.giraph.utils.CallableFactory<R>
- org.apache.giraph.bsp.CentralizedService<I,V,E>
- org.apache.giraph.bsp.checkpoints.CheckpointSupportedChecker
- org.apache.giraph.factories.ComputationFactory<I,V,E,M1,M2>
- org.apache.giraph.conf.ContextSettable
- org.apache.giraph.block_app.framework.api.Counter
- org.apache.giraph.block_app.framework.api.CreateReducersApi.CreateReducerFunctionApi
- org.apache.giraph.ooc.persistence.DataIndex.DataIndexEntry
- java.io.DataInput
- java.io.DataOutput
- org.apache.giraph.edge.Edge<I,E>
- org.apache.giraph.io.filters.EdgeInputFilter<I,E>
- org.apache.giraph.edge.EdgeStore<I,V,E>
- org.apache.giraph.edge.EdgeStoreFactory<I,V,E>
- org.apache.giraph.utils.Factory<T>
- org.apache.giraph.comm.flow_control.FlowControl
- org.apache.giraph.utils.GcObserver
- org.apache.giraph.conf.GiraphConfigurationSettable<I,V,E>
- org.apache.giraph.aggregators.AggregatorWriter
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.edge.CreateSourceVertexCallback<I>
- org.apache.giraph.partition.GraphPartitionerFactoryInterface<I,V,E>
- org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>
- org.apache.giraph.aggregators.AggregatorWriter
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.partition.GraphPartitionerFactoryInterface<I,V,E>
- org.apache.giraph.mapping.MappingStore<I,B>
- org.apache.giraph.master.MasterObserver
- org.apache.giraph.partition.Partition<I,V,E> (also extends java.lang.Iterable<T>, org.apache.hadoop.io.Writable)
- org.apache.giraph.partition.ReusesObjectsPartition<I,V,E>
- org.apache.giraph.mapping.translate.TranslateEdge<I,E>
- org.apache.giraph.graph.Vertex<I,V,E>
- org.apache.giraph.utils.VertexIdData<I,T> (also extends org.apache.hadoop.io.Writable)
- org.apache.giraph.utils.VertexIdEdges<I,E>
- org.apache.giraph.utils.VertexIdMessages<I,M>
- org.apache.giraph.worker.WorkerObserver
- org.apache.giraph.zk.ZooKeeperRunner
- org.apache.giraph.mapping.MappingStore<I,B>
- org.apache.giraph.master.MasterObserver
- org.apache.giraph.partition.Partition<I,V,E> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, java.lang.Iterable<T>, org.apache.hadoop.io.Writable)
- org.apache.giraph.partition.ReusesObjectsPartition<I,V,E>
- org.apache.giraph.mapping.translate.TranslateEdge<I,E>
- org.apache.giraph.graph.Vertex<I,V,E>
- org.apache.giraph.utils.VertexIdData<I,T> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.hadoop.io.Writable)
- org.apache.giraph.utils.VertexIdEdges<I,E>
- org.apache.giraph.utils.VertexIdMessages<I,M>
- org.apache.giraph.worker.WorkerObserver
- org.apache.giraph.zk.ZooKeeperRunner
- org.apache.giraph.conf.GiraphConstants
- org.apache.giraph.job.GiraphJobObserver
- org.apache.giraph.job.GiraphJobRetryChecker
- org.apache.giraph.graph.GraphTaskManager.CheckerIfWorkerShouldFailAfterException
- org.apache.giraph.job.HaltApplicationUtils.HaltInstructionsWriter
- org.apache.giraph.master.input.InputSplitsMasterOrganizer
- java.lang.Iterable<T>
- org.apache.giraph.block_app.framework.block.Block
- org.apache.giraph.block_app.framework.block.BlockWithApiHandle
- it.unimi.dsi.fastutil.booleans.BooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanIterable, java.util.Collection<E>)
- it.unimi.dsi.fastutil.booleans.BooleanIterable
- it.unimi.dsi.fastutil.booleans.BooleanCollection (also extends java.util.Collection<E>)
- org.apache.giraph.types.ops.collections.WBooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- it.unimi.dsi.fastutil.bytes.ByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteIterable, java.util.Collection<E>)
- it.unimi.dsi.fastutil.bytes.ByteIterable
- it.unimi.dsi.fastutil.bytes.ByteCollection (also extends java.util.Collection<E>)
- org.apache.giraph.types.ops.collections.WByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- java.util.Collection<E>
- it.unimi.dsi.fastutil.booleans.BooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanIterable)
- it.unimi.dsi.fastutil.bytes.ByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteIterable)
- it.unimi.dsi.fastutil.doubles.DoubleCollection (also extends it.unimi.dsi.fastutil.doubles.DoubleIterable)
- it.unimi.dsi.fastutil.floats.FloatCollection (also extends it.unimi.dsi.fastutil.floats.FloatIterable)
- it.unimi.dsi.fastutil.ints.IntCollection (also extends it.unimi.dsi.fastutil.ints.IntIterable)
- it.unimi.dsi.fastutil.longs.LongCollection (also extends it.unimi.dsi.fastutil.longs.LongIterable)
- org.apache.giraph.types.ops.collections.WBooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WDoubleCollection (also extends it.unimi.dsi.fastutil.doubles.DoubleCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WFloatCollection (also extends it.unimi.dsi.fastutil.floats.FloatCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WIntCollection (also extends it.unimi.dsi.fastutil.ints.IntCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WLongCollection (also extends it.unimi.dsi.fastutil.longs.LongCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- it.unimi.dsi.fastutil.doubles.DoubleCollection (also extends java.util.Collection<E>, it.unimi.dsi.fastutil.doubles.DoubleIterable)
- it.unimi.dsi.fastutil.doubles.DoubleIterable
- it.unimi.dsi.fastutil.doubles.DoubleCollection (also extends java.util.Collection<E>)
- org.apache.giraph.types.ops.collections.WDoubleCollection (also extends it.unimi.dsi.fastutil.doubles.DoubleCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- it.unimi.dsi.fastutil.floats.FloatCollection (also extends java.util.Collection<E>, it.unimi.dsi.fastutil.floats.FloatIterable)
- it.unimi.dsi.fastutil.floats.FloatIterable
- it.unimi.dsi.fastutil.floats.FloatCollection (also extends java.util.Collection<E>)
- org.apache.giraph.types.ops.collections.WFloatCollection (also extends it.unimi.dsi.fastutil.floats.FloatCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.heaps.Int2ByteMapEntryIterable
- org.apache.giraph.types.heaps.Int2DoubleMapEntryIterable
- org.apache.giraph.types.heaps.Int2FloatMapEntryIterable
- org.apache.giraph.types.heaps.Int2IntMapEntryIterable
- org.apache.giraph.types.heaps.Int2LongMapEntryIterable
- it.unimi.dsi.fastutil.ints.IntCollection (also extends java.util.Collection<E>, it.unimi.dsi.fastutil.ints.IntIterable)
- it.unimi.dsi.fastutil.ints.IntIterable
- it.unimi.dsi.fastutil.ints.IntCollection (also extends java.util.Collection<E>)
- org.apache.giraph.types.ops.collections.WIntCollection (also extends it.unimi.dsi.fastutil.ints.IntCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.heaps.Long2ByteMapEntryIterable
- org.apache.giraph.types.heaps.Long2DoubleMapEntryIterable
- org.apache.giraph.types.heaps.Long2FloatMapEntryIterable
- org.apache.giraph.types.heaps.Long2IntMapEntryIterable
- org.apache.giraph.types.heaps.Long2LongMapEntryIterable
- it.unimi.dsi.fastutil.longs.LongCollection (also extends java.util.Collection<E>, it.unimi.dsi.fastutil.longs.LongIterable)
- it.unimi.dsi.fastutil.longs.LongIterable
- it.unimi.dsi.fastutil.longs.LongCollection (also extends java.util.Collection<E>)
- org.apache.giraph.types.ops.collections.WLongCollection (also extends it.unimi.dsi.fastutil.longs.LongCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.edge.MultiRandomAccessOutEdges<I,E>
- org.apache.giraph.edge.MutableOutEdges<I,E>
- it.unimi.dsi.fastutil.objects.ObjectIterable<K>
- org.apache.giraph.edge.OutEdges<I,E> (also extends org.apache.hadoop.io.Writable)
- org.apache.giraph.partition.Partition<I,V,E> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.hadoop.io.Writable)
- org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>
- org.apache.giraph.partition.ReusesObjectsPartition<I,V,E>
- org.apache.giraph.edge.StrictRandomAccessOutEdges<I,E>
- org.apache.giraph.types.ops.collections.WBooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WDoubleCollection (also extends it.unimi.dsi.fastutil.doubles.DoubleCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WFloatCollection (also extends it.unimi.dsi.fastutil.floats.FloatCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WIntCollection (also extends it.unimi.dsi.fastutil.ints.IntCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WLongCollection (also extends it.unimi.dsi.fastutil.longs.LongCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.block_app.library.iteration.IterationStage
- java.util.Iterator<E>
- org.apache.giraph.job.JobProgressTracker
- org.apache.giraph.block_app.framework.piece.global_comm.map.MapHandle<K,V>
- org.apache.giraph.graph.MapperObserver
- org.apache.giraph.mapping.MappingStoreOps<I,B>
- org.apache.giraph.comm.MasterClient
- org.apache.giraph.master.MasterGlobalCommUsageAggregators
- org.apache.giraph.partition.MasterGraphPartitioner<I,V,E>
- org.apache.giraph.comm.requests.MasterRequest
- org.apache.giraph.comm.MasterServer
- org.apache.giraph.combiner.MessageCombiner<I,M>
- org.apache.giraph.comm.messages.MessageStore<I,M>
- org.apache.giraph.comm.messages.MessageStoreFactory<I,M,MS>
- org.apache.giraph.metrics.MetricNames
- org.apache.giraph.block_app.migration.MigrationSuperstepStage
- org.apache.giraph.comm.NetworkMetrics
- org.apache.giraph.writable.kryo.markers.NonKryoWritable
- org.apache.giraph.block_app.framework.piece.interfaces.VertexPostprocessor
- org.apache.giraph.block_app.framework.piece.interfaces.VertexReceiver<I,V,E,M>
- org.apache.giraph.block_app.framework.piece.interfaces.VertexSender<I,V,E>
- org.apache.giraph.function.Notifier<T>
- org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor
- org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataInputWrapper
- org.apache.giraph.ooc.persistence.OutOfCoreDataAccessor.DataOutputWrapper
- org.apache.giraph.ooc.policy.OutOfCoreOracle
- org.apache.giraph.comm.messages.PartitionSplitInfo<I>
- org.apache.giraph.partition.PartitionStore<I,V,E>
- org.apache.giraph.function.primitive.PrimitiveRefs
- org.apache.giraph.block_app.framework.piece.global_comm.ReducerHandle<S,R>
- org.apache.giraph.comm.netty.handler.RequestServerHandler.Factory
- org.apache.giraph.metrics.ResetSuperstepMetricsObserver
- java.io.Serializable
- org.apache.giraph.function.primitive.Boolean2BooleanFunction
- org.apache.giraph.function.primitive.Boolean2ObjFunction<T>
- org.apache.giraph.function.primitive.pairs.BooleanBooleanConsumer
- org.apache.giraph.function.primitive.pairs.BooleanBooleanPredicate
- org.apache.giraph.function.primitive.pairs.BooleanByteConsumer
- org.apache.giraph.function.primitive.pairs.BooleanBytePredicate
- org.apache.giraph.function.primitive.BooleanConsumer
- org.apache.giraph.function.primitive.pairs.BooleanDoubleConsumer
- org.apache.giraph.function.primitive.pairs.BooleanDoublePredicate
- org.apache.giraph.function.primitive.pairs.BooleanFloatConsumer
- org.apache.giraph.function.primitive.pairs.BooleanFloatPredicate
- org.apache.giraph.function.primitive.pairs.BooleanIntConsumer
- org.apache.giraph.function.primitive.pairs.BooleanIntPredicate
- org.apache.giraph.function.primitive.pairs.BooleanLongConsumer
- org.apache.giraph.function.primitive.pairs.BooleanLongPredicate
- org.apache.giraph.function.primitive.BooleanPredicate
- org.apache.giraph.function.primitive.Byte2ByteFunction
- org.apache.giraph.function.primitive.Byte2ObjFunction<T>
- org.apache.giraph.function.primitive.pairs.ByteBooleanConsumer
- org.apache.giraph.function.primitive.pairs.ByteBooleanPredicate
- org.apache.giraph.function.primitive.pairs.ByteByteConsumer
- org.apache.giraph.function.primitive.pairs.ByteBytePredicate
- org.apache.giraph.function.primitive.ByteConsumer
- org.apache.giraph.function.primitive.pairs.ByteDoubleConsumer
- org.apache.giraph.function.primitive.pairs.ByteDoublePredicate
- org.apache.giraph.function.primitive.pairs.ByteFloatConsumer
- org.apache.giraph.function.primitive.pairs.ByteFloatPredicate
- org.apache.giraph.function.primitive.pairs.ByteIntConsumer
- org.apache.giraph.function.primitive.pairs.ByteIntPredicate
- org.apache.giraph.function.primitive.pairs.ByteLongConsumer
- org.apache.giraph.function.primitive.pairs.ByteLongPredicate
- org.apache.giraph.function.primitive.BytePredicate
- org.apache.giraph.function.Consumer<T>
- org.apache.giraph.function.vertex.ConsumerWithVertex<I,V,E,T> (also extends org.apache.giraph.function.PairConsumer<T1,T2>)
- org.apache.giraph.function.primitive.Double2DoubleFunction
- org.apache.giraph.function.primitive.Double2ObjFunction<T>
- org.apache.giraph.function.primitive.pairs.DoubleBooleanConsumer
- org.apache.giraph.function.primitive.pairs.DoubleBooleanPredicate
- org.apache.giraph.function.primitive.pairs.DoubleByteConsumer
- org.apache.giraph.function.primitive.pairs.DoubleBytePredicate
- org.apache.giraph.function.primitive.DoubleConsumer
- org.apache.giraph.function.primitive.pairs.DoubleDoubleConsumer
- org.apache.giraph.function.primitive.pairs.DoubleDoublePredicate
- org.apache.giraph.function.primitive.pairs.DoubleFloatConsumer
- org.apache.giraph.function.primitive.pairs.DoubleFloatPredicate
- org.apache.giraph.function.primitive.pairs.DoubleIntConsumer
- org.apache.giraph.function.primitive.pairs.DoubleIntPredicate
- org.apache.giraph.function.primitive.pairs.DoubleLongConsumer
- org.apache.giraph.function.primitive.pairs.DoubleLongPredicate
- org.apache.giraph.function.primitive.DoublePredicate
- org.apache.giraph.factories.EdgeValueFactory<E>
- org.apache.giraph.function.primitive.Float2FloatFunction
- org.apache.giraph.function.primitive.Float2ObjFunction<T>
- org.apache.giraph.function.primitive.pairs.FloatBooleanConsumer
- org.apache.giraph.function.primitive.pairs.FloatBooleanPredicate
- org.apache.giraph.function.primitive.pairs.FloatByteConsumer
- org.apache.giraph.function.primitive.pairs.FloatBytePredicate
- org.apache.giraph.function.primitive.FloatConsumer
- org.apache.giraph.function.primitive.pairs.FloatDoubleConsumer
- org.apache.giraph.function.primitive.pairs.FloatDoublePredicate
- org.apache.giraph.function.primitive.pairs.FloatFloatConsumer
- org.apache.giraph.function.primitive.pairs.FloatFloatPredicate
- org.apache.giraph.function.primitive.pairs.FloatIntConsumer
- org.apache.giraph.function.primitive.pairs.FloatIntPredicate
- org.apache.giraph.function.primitive.pairs.FloatLongConsumer
- org.apache.giraph.function.primitive.pairs.FloatLongPredicate
- org.apache.giraph.function.primitive.FloatPredicate
- org.apache.giraph.function.Function<F,T>
- org.apache.giraph.function.vertex.FunctionWithVertex<I,V,E,F,T> (also extends org.apache.giraph.function.PairFunction<F1,F2,T>)
- org.apache.giraph.function.primitive.Int2IntFunction
- org.apache.giraph.function.primitive.Int2ObjFunction<T>
- org.apache.giraph.function.primitive.pairs.IntBooleanConsumer
- org.apache.giraph.function.primitive.pairs.IntBooleanPredicate
- org.apache.giraph.function.primitive.pairs.IntByteConsumer
- org.apache.giraph.function.primitive.pairs.IntBytePredicate
- org.apache.giraph.function.primitive.IntConsumer
- org.apache.giraph.function.primitive.pairs.IntDoubleConsumer
- org.apache.giraph.function.primitive.pairs.IntDoublePredicate
- org.apache.giraph.function.primitive.pairs.IntFloatConsumer
- org.apache.giraph.function.primitive.pairs.IntFloatPredicate
- org.apache.giraph.function.primitive.pairs.IntIntConsumer
- org.apache.giraph.function.primitive.pairs.IntIntPredicate
- org.apache.giraph.function.primitive.pairs.IntLongConsumer
- org.apache.giraph.function.primitive.pairs.IntLongPredicate
- org.apache.giraph.function.primitive.IntPredicate
- org.apache.giraph.function.primitive.IntSupplier
- org.apache.giraph.function.primitive.Long2LongFunction
- org.apache.giraph.function.primitive.Long2ObjFunction<T>
- org.apache.giraph.function.primitive.pairs.LongBooleanConsumer
- org.apache.giraph.function.primitive.pairs.LongBooleanPredicate
- org.apache.giraph.function.primitive.pairs.LongByteConsumer
- org.apache.giraph.function.primitive.pairs.LongBytePredicate
- org.apache.giraph.function.primitive.LongConsumer
- org.apache.giraph.function.primitive.pairs.LongDoubleConsumer
- org.apache.giraph.function.primitive.pairs.LongDoublePredicate
- org.apache.giraph.function.primitive.pairs.LongFloatConsumer
- org.apache.giraph.function.primitive.pairs.LongFloatPredicate
- org.apache.giraph.function.primitive.pairs.LongIntConsumer
- org.apache.giraph.function.primitive.pairs.LongIntPredicate
- org.apache.giraph.function.primitive.pairs.LongLongConsumer
- org.apache.giraph.function.primitive.pairs.LongLongPredicate
- org.apache.giraph.function.primitive.LongPredicate
- org.apache.giraph.factories.MessageValueFactory<M>
- org.apache.giraph.function.primitive.Obj2BooleanFunction<T>
- org.apache.giraph.function.primitive.Obj2ByteFunction<T>
- org.apache.giraph.function.primitive.Obj2DoubleFunction<T>
- org.apache.giraph.function.primitive.Obj2FloatFunction<T>
- org.apache.giraph.function.primitive.Obj2IntFunction<T>
- org.apache.giraph.function.primitive.Obj2LongFunction<T>
- org.apache.giraph.function.primitive.Obj2ShortFunction<T>
- org.apache.giraph.factories.OutEdgesFactory<I,E>
- org.apache.giraph.function.PairConsumer<T1,T2>
- org.apache.giraph.function.PairFunction<F1,F2,T>
- org.apache.giraph.function.PairPredicate<T1,T2>
- org.apache.giraph.function.Predicate<T>
- org.apache.giraph.function.primitive.Short2ObjFunction<T>
- org.apache.giraph.function.primitive.Short2ShortFunction
- org.apache.giraph.function.primitive.ShortConsumer
- org.apache.giraph.function.primitive.ShortPredicate
- org.apache.giraph.function.Supplier<T>
- org.apache.giraph.block_app.framework.piece.messages.SupplierFromConf<T>
- org.apache.giraph.function.vertex.SupplierFromVertex<I,V,E,T>
- org.apache.giraph.function.TripleFunction<F1,F2,F3,T>
- org.apache.giraph.factories.ValueFactory<W>
- org.apache.giraph.factories.VertexIdFactory<I>
- org.apache.giraph.factories.VertexValueFactory<V>
- org.apache.giraph.io.SimpleVertexWriter<I,V,E>
- org.apache.giraph.block_app.framework.api.StatusReporter
- org.apache.giraph.block_app.framework.api.BlockMasterApi (also extends org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.master.MasterAggregatorUsage, org.apache.giraph.master.MasterGlobalCommUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi<I,WM> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.io.superstep_output.SuperstepOutput<I,V,E>
- org.apache.giraph.block_app.test_setup.TestGraphChecker<I,V,E>
- org.apache.giraph.block_app.test_setup.TestGraphModifier<I,V,E>
- org.apache.giraph.time.Time
- org.apache.giraph.utils.Trimmable
- org.apache.giraph.types.ops.TypeOps<T>
- org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>
- org.apache.giraph.graph.VertexChanges<I,V,E>
- org.apache.giraph.utils.VertexIdIterator<I>
- org.apache.giraph.io.filters.VertexInputFilter<I,V,E>
- org.apache.giraph.graph.VertexResolver<I,V,E>
- org.apache.giraph.block_app.framework.piece.global_comm.internal.VertexSenderObserver
- org.apache.giraph.graph.VertexValueCombiner<V>
- org.apache.giraph.comm.aggregators.WorkerAggregatorRequestProcessor
- org.apache.giraph.worker.WorkerBroadcastUsage
- org.apache.giraph.block_app.framework.api.BlockWorkerContextReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.worker.WorkerGlobalCommUsage (also extends org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.worker.WorkerThreadGlobalCommUsage
- org.apache.giraph.worker.WorkerThreadGlobalCommUsage
- org.apache.giraph.comm.WorkerClient<I,V,E>
- org.apache.giraph.comm.WorkerClientRequestProcessor<I,V,E>
- org.apache.giraph.partition.WorkerGraphPartitioner<I,V,E>
- org.apache.giraph.worker.WorkerIndexUsage<I>
- org.apache.giraph.block_app.framework.api.BlockWorkerApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.BlockOutputApi, org.apache.giraph.block_app.framework.api.StatusReporter)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I> (also extends org.apache.giraph.aggregators.AggregatorUsage, org.apache.giraph.block_app.framework.api.BlockApi, org.apache.giraph.block_app.framework.api.StatusReporter)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerContextSendApi<I,WM> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerContextApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerReceiveApi<I> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerReduceUsage)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage)
- org.apache.giraph.worker.WorkerReduceUsage
- org.apache.giraph.block_app.framework.api.BlockWorkerSendApi<I,V,E,M> (also extends org.apache.giraph.block_app.framework.api.BlockWorkerApi<I>, org.apache.giraph.worker.WorkerAggregatorUsage)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerGlobalCommUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.worker.WorkerGlobalCommUsage (also extends org.apache.giraph.worker.WorkerBroadcastUsage)
- org.apache.giraph.graph.Computation<I,V,E,M1,M2> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, org.apache.giraph.conf.TypesHolder<I,V,E,M1,M2>, org.apache.giraph.worker.WorkerAggregatorUsage, org.apache.giraph.worker.WorkerIndexUsage<I>)
- org.apache.giraph.worker.WorkerThreadGlobalCommUsage
- org.apache.giraph.worker.WorkerThreadGlobalCommUsage
- org.apache.giraph.comm.requests.WorkerRequest<I,V,E>
- org.apache.hadoop.io.Writable
- org.apache.giraph.types.ops.collections.BasicSet<T>
- org.apache.giraph.writable.kryo.markers.KryoIgnoreWritable
- org.apache.giraph.conf.MessageClasses<I,M>
- org.apache.giraph.edge.MultiRandomAccessOutEdges<I,E>
- org.apache.giraph.edge.MutableOutEdges<I,E>
- org.apache.giraph.edge.OutEdges<I,E> (also extends java.lang.Iterable<T>)
- org.apache.giraph.partition.Partition<I,V,E> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>, java.lang.Iterable<T>)
- org.apache.giraph.partition.PartitionOwner
- org.apache.giraph.reducers.ReduceOperation<S,R>
- org.apache.giraph.edge.ReuseObjectsOutEdges<I,E>
- org.apache.giraph.partition.ReusesObjectsPartition<I,V,E>
- org.apache.giraph.edge.StrictRandomAccessOutEdges<I,E>
- org.apache.giraph.utils.VertexIdData<I,T> (also extends org.apache.giraph.conf.ImmutableClassesGiraphConfigurable<I,V,E>)
- org.apache.giraph.utils.VertexIdEdges<I,E>
- org.apache.giraph.utils.VertexIdMessages<I,M>
- org.apache.giraph.types.ops.collections.array.WArrayList<T>
- org.apache.giraph.types.ops.collections.WBooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WCollection<T>
- org.apache.giraph.types.ops.collections.array.WArrayList<T>
- org.apache.giraph.types.ops.collections.WBooleanCollection (also extends it.unimi.dsi.fastutil.booleans.BooleanCollection)
- org.apache.giraph.types.ops.collections.WByteCollection (also extends it.unimi.dsi.fastutil.bytes.ByteCollection)
- org.apache.giraph.types.ops.collections.WDoubleCollection (also extends it.unimi.dsi.fastutil.doubles.DoubleCollection)
- org.apache.giraph.types.ops.collections.WFloatCollection (also extends it.unimi.dsi.fastutil.floats.FloatCollection)
- org.apache.giraph.types.ops.collections.WIntCollection (also extends it.unimi.dsi.fastutil.ints.IntCollection)
- org.apache.giraph.types.ops.collections.WLongCollection (also extends it.unimi.dsi.fastutil.longs.LongCollection)
- org.apache.giraph.types.ops.collections.WDoubleCollection (also extends it.unimi.dsi.fastutil.doubles.DoubleCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WFloatCollection (also extends it.unimi.dsi.fastutil.floats.FloatCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WIntCollection (also extends it.unimi.dsi.fastutil.ints.IntCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.ops.collections.WLongCollection (also extends it.unimi.dsi.fastutil.longs.LongCollection, org.apache.giraph.types.ops.collections.WCollection<T>)
- org.apache.giraph.types.WritableUnwrapper<W,J>
- org.apache.giraph.types.WritableWrapper<W,J>
- org.apache.giraph.types.ops.collections.WritableWriter<T>
Annotation Type Hierarchy
Enum Hierarchy
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.