Package | Description |
---|---|
org.apache.giraph.block_app.framework |
Block application abstraction package.
|
org.apache.giraph.block_app.framework.api |
Interfaces representing full API to the underlying graph processing system.
|
org.apache.giraph.block_app.framework.internal |
Implementation of execution logic, guiding internal execution of
Block Application.
|
org.apache.giraph.block_app.framework.piece |
Single execution object - Piece, and related classes.
|
org.apache.giraph.block_app.framework.piece.delegate |
Pieces that delegate their work to a set of one or multiple other Pieces.
|
org.apache.giraph.block_app.framework.piece.global_comm.internal |
Reducer and Broadcast Handles internal implementation for automatic handling
of global communication within Pieces, hiding a lot of it's complexities.
|
org.apache.giraph.block_app.framework.piece.messages |
Utility classes for handling of messages within Pieces
|
org.apache.giraph.block_app.library.internal |
Internal implementation of Pieces needed for Pieces utility class.
|
org.apache.giraph.block_app.migration |
Migration utility for transforming standard Giraph applications, into
Block Applications.
|
org.apache.giraph.block_app.test_setup |
Utilities for unit tests.
|
org.apache.giraph.bsp |
Package of generic bulk synchronous processing objects.
|
org.apache.giraph.comm |
Package of communication related objects, IPC service.
|
org.apache.giraph.comm.aggregators |
Package for classes which are used to handle aggregators.
|
org.apache.giraph.comm.flow_control |
Package for flow-control policies.
|
org.apache.giraph.comm.messages |
Package of classes for storing messages.
|
org.apache.giraph.comm.messages.primitives |
Package of message stores specialized for a certain type of vertex ids,
messages and combiner.
|
org.apache.giraph.comm.messages.primitives.long_id |
Message store based off of primitives when I = LongWritable
|
org.apache.giraph.comm.netty |
Package for netty implementations.
|
org.apache.giraph.comm.netty.handler |
Package for classes which handle requests and responses.
|
org.apache.giraph.comm.requests |
Package for requests.
|
org.apache.giraph.conf |
Package of Giraph configuration related things.
|
org.apache.giraph.edge |
Package of Vertex implementations.
|
org.apache.giraph.edge.primitives |
Package of edge stores specialized for certain type of vertex ids.
|
org.apache.giraph.examples |
Package of Giraph examples.
|
org.apache.giraph.factories |
Package of factories for creating types, for example the user's graph types.
|
org.apache.giraph.graph |
Package of all the graph related objects, built on the
org.apache.bsp package.
|
org.apache.giraph.io.formats |
Package of reusable library Giraph objects.
|
org.apache.giraph.io.formats.multi |
Package for Input formats which wrap several input formats and allow
reading data from multiple sources.
|
org.apache.giraph.io.internal |
Input/Output classes for internal use only.
|
org.apache.giraph.io.iterables |
Iterable wrappers for IO readers/writers
|
org.apache.giraph.io.superstep_output |
Classes related to output during computation
|
org.apache.giraph.job |
Package of all the classes involved in job launch.
|
org.apache.giraph.jython.factories |
Jython factories.
|
org.apache.giraph.master |
Package of all the master related things.
|
org.apache.giraph.ooc |
Package of out-of-core related classes.
|
org.apache.giraph.ooc.data |
Package of classes related to data structures used for an out-of-core
mechanism
|
org.apache.giraph.ooc.persistence |
Package of classes related to IO abstraction or persistence layer used for
out-of-core mechanism
|
org.apache.giraph.ooc.policy |
Package of classes related to out-of-core policy
|
org.apache.giraph.partition |
Package of partitioning related objects.
|
org.apache.giraph.reducers |
Package of Giraph reducers.
|
org.apache.giraph.utils |
Package of all generic utility classes.
|
org.apache.giraph.utils.io |
Package of utility classes which add the functionality to the ones from
java.io package.
|
org.apache.giraph.worker |
Package of all the worker related things
|
org.apache.giraph.zk |
Package of
ZooKeeper related objects. |
Modifier and Type | Method and Description |
---|---|
static void |
BlockUtils.checkBlockTypes(Block executionBlock,
Object executionStage,
ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,V,E> |
BlockWorkerSendApi.getConf() |
ImmutableClassesGiraphConfiguration<I,?,?> |
BlockWorkerApi.getConf() |
ImmutableClassesGiraphConfiguration<?,?,?> |
BlockConfApi.getConf()
Return the configuration used by this object.
|
Modifier and Type | Method and Description |
---|---|
MessageClasses |
BlockWorkerPieces.getOutgoingMessageClasses(ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
MessageClasses<I,M> |
DefaultParentPiece.getMessageClasses(ImmutableClassesGiraphConfiguration conf) |
abstract MessageClasses<I,M> |
AbstractPiece.getMessageClasses(ImmutableClassesGiraphConfiguration conf)
Returns MessageClasses definition for messages being sent by this Piece.
|
protected MessageCombiner<? super I,M> |
DefaultParentPiece.getMessageCombiner(ImmutableClassesGiraphConfiguration conf)
Override to specify message combiner to be used, if any.
|
protected MessageValueFactory<M> |
DefaultParentPiece.getMessageFactory(ImmutableClassesGiraphConfiguration conf)
Override to specify message value factory to be used,
which creates objects into which messages will be deserialized.
|
Modifier and Type | Method and Description |
---|---|
MessageClasses<I,M> |
DelegatePiece.getMessageClasses(ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<?,?,?> |
CreateReducersApiWrapper.getConf() |
Modifier and Type | Method and Description |
---|---|
T |
SupplierFromConf.SupplierFromConfByCopy.apply(ImmutableClassesGiraphConfiguration conf) |
MessageValueFactory<M> |
SupplierFromConf.DefaultMessageFactorySupplierFromConf.apply(ImmutableClassesGiraphConfiguration conf) |
MessageCombiner<? super I,M> |
ObjectMessageClasses.createMessageCombiner(ImmutableClassesGiraphConfiguration<I,? extends org.apache.hadoop.io.Writable,? extends org.apache.hadoop.io.Writable> conf) |
MessageValueFactory<M> |
ObjectMessageClasses.createMessageValueFactory(ImmutableClassesGiraphConfiguration conf) |
void |
ObjectMessageClasses.verifyConsistent(ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
MessageCombiner<? super I,M> |
SendMessageWithCombinerPiece.getMessageCombiner(ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
MessageClasses<I,M> |
MigrationPiece.getMessageClasses(ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,V,E> |
NumericTestGraph.getConf() |
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,V,E> |
CentralizedService.getConfiguration()
Get configuration
|
ImmutableClassesGiraphConfiguration<I,V,E> |
BspService.getConfiguration() |
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
SendDataCache.getConf() |
Modifier and Type | Method and Description |
---|---|
static String |
AggregatorUtils.getUnregisteredAggregatorMessage(String aggregatorName,
boolean hasRegisteredAggregators,
ImmutableClassesGiraphConfiguration conf)
Get the warning message about usage of unregistered aggregator to be
printed to user.
|
static String |
AggregatorUtils.getUnregisteredBroadcastMessage(String broadcastName,
boolean hasBroadcasted,
ImmutableClassesGiraphConfiguration conf)
Get the warning message when user tries to access broadcast, without
previously setting it, to be printed to user.
|
static String |
AggregatorUtils.getUnregisteredReducerMessage(String reducerName,
boolean hasRegisteredReducers,
ImmutableClassesGiraphConfiguration conf)
Get the warning message about usage of unregistered reducer to be
printed to user.
|
static boolean |
AggregatorUtils.useThreadLocalAggregators(ImmutableClassesGiraphConfiguration conf)
Check if we should use thread local aggregators.
|
Constructor and Description |
---|
AllAggregatorServerData(org.apache.hadoop.util.Progressable progressable,
ImmutableClassesGiraphConfiguration conf)
Constructor
|
Constructor and Description |
---|
CreditBasedFlowControl(ImmutableClassesGiraphConfiguration conf,
NettyClient nettyClient,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor
|
StaticFlowControl(ImmutableClassesGiraphConfiguration conf,
NettyClient nettyClient)
Constructor
|
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration<I,?,?> |
InMemoryMessageStoreFactory.conf
Hadoop configuration
|
protected ImmutableClassesGiraphConfiguration<I,?,?> |
SimpleMessageStore.config
Giraph configuration
|
Modifier and Type | Method and Description |
---|---|
void |
InMemoryMessageStoreFactory.initialize(PartitionSplitInfo<I> partitionInfo,
ImmutableClassesGiraphConfiguration<I,?,?> conf) |
void |
ByteArrayMessagesPerVertexStore.Factory.initialize(PartitionSplitInfo<I> partitionInfo,
ImmutableClassesGiraphConfiguration<I,?,?> conf) |
void |
MessageStoreFactory.initialize(PartitionSplitInfo<I> partitionInfo,
ImmutableClassesGiraphConfiguration<I,?,?> conf)
Implementation class should use this method of initialization
of any required internal state.
|
static <I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
OneMessagePerVertexStore.newFactory(CentralizedServiceWorker<I,?,?> service,
ImmutableClassesGiraphConfiguration<I,?,?> config)
Create new factory for this message store
|
static <I extends org.apache.hadoop.io.WritableComparable,M extends org.apache.hadoop.io.Writable> |
ByteArrayMessagesPerVertexStore.newFactory(CentralizedServiceWorker<I,?,?> service,
ImmutableClassesGiraphConfiguration<I,?,?> config)
Create new factory for this message store
|
Constructor and Description |
---|
IdByteArrayMessageStore(MessageValueFactory<M> messageValueFactory,
PartitionSplitInfo<I> partitionInfo,
ImmutableClassesGiraphConfiguration<I,?,?> config)
Constructor
|
IdOneMessagePerVertexStore(MessageValueFactory<M> messageValueFactory,
PartitionSplitInfo<I> partitionInfo,
MessageCombiner<? super I,M> messageCombiner,
ImmutableClassesGiraphConfiguration<I,?,?> config)
Constructor
|
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,?,?> |
LongAbstractStore.config
Giraph configuration
|
Constructor and Description |
---|
LongAbstractListStore(MessageValueFactory<M> messageValueFactory,
PartitionSplitInfo<org.apache.hadoop.io.LongWritable> partitionInfo,
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Writable,org.apache.hadoop.io.Writable> config)
Constructor
|
LongAbstractStore(MessageValueFactory<M> messageValueFactory,
PartitionSplitInfo<org.apache.hadoop.io.LongWritable> partitionInfo,
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Writable,org.apache.hadoop.io.Writable> config)
Constructor
|
LongPointerListPerVertexStore(MessageValueFactory<M> messageValueFactory,
PartitionSplitInfo<org.apache.hadoop.io.LongWritable> partitionInfo,
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Writable,org.apache.hadoop.io.Writable> config)
Constructor
|
Constructor and Description |
---|
NettyClient(org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
Thread.UncaughtExceptionHandler exceptionHandler)
Only constructor
|
NettyMasterClient(org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration configuration,
CentralizedServiceMaster<?,?,?> service,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor
|
NettyMasterServer(ImmutableClassesGiraphConfiguration conf,
CentralizedServiceMaster<?,?,?> service,
org.apache.hadoop.util.Progressable progressable,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor
|
NettyServer(ImmutableClassesGiraphConfiguration conf,
RequestServerHandler.Factory requestServerHandlerFactory,
TaskInfo myTaskInfo,
org.apache.hadoop.util.Progressable progressable,
SaslServerHandler.Factory saslServerHandlerFactory,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor for creating the server
|
NettyServer(ImmutableClassesGiraphConfiguration conf,
RequestServerHandler.Factory requestServerHandlerFactory,
TaskInfo myTaskInfo,
org.apache.hadoop.util.Progressable progressable,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor for creating the server
|
NettyWorkerAggregatorRequestProcessor(org.apache.hadoop.util.Progressable progressable,
ImmutableClassesGiraphConfiguration<?,?,?> configuration,
CentralizedServiceWorker<?,?,?> serviceWorker)
Constructor.
|
NettyWorkerClient(org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
CentralizedServiceWorker<I,V,E> service,
Thread.UncaughtExceptionHandler exceptionHandler)
Only constructor.
|
NettyWorkerClientRequestProcessor(org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> conf,
CentralizedServiceWorker<I,V,E> serviceWorker,
boolean useOneMessageToManyIdsEncoding)
Constructor.
|
NettyWorkerServer(ImmutableClassesGiraphConfiguration<I,V,E> conf,
CentralizedServiceWorker<I,V,E> service,
org.apache.hadoop.mapreduce.Mapper.Context context,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor to start the server.
|
Modifier and Type | Method and Description |
---|---|
RequestServerHandler |
WorkerRequestServerHandler.Factory.newHandler(WorkerRequestReservedMap workerRequestReservedMap,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
Thread.UncaughtExceptionHandler exceptionHandler) |
RequestServerHandler |
MasterRequestServerHandler.Factory.newHandler(WorkerRequestReservedMap workerRequestReservedMap,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
Thread.UncaughtExceptionHandler exceptionHandler) |
RequestServerHandler |
RequestServerHandler.Factory.newHandler(WorkerRequestReservedMap workerRequestReservedMap,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
Thread.UncaughtExceptionHandler exceptionHandler)
Create new
RequestServerHandler |
Constructor and Description |
---|
MasterRequestServerHandler(WorkerRequestReservedMap workerRequestReservedMap,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
MasterGlobalCommHandler commHandler,
Thread.UncaughtExceptionHandler exceptionHandler,
FlowControl flowControl)
Constructor
|
RequestDecoder(ImmutableClassesGiraphConfiguration conf,
InboundByteCounter byteCounter)
Constructor.
|
RequestServerHandler(WorkerRequestReservedMap workerRequestReservedMap,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
Thread.UncaughtExceptionHandler exceptionHandler)
Constructor
|
WorkerRequestServerHandler(ServerData<I,V,E> serverData,
WorkerRequestReservedMap workerRequestReservedMap,
ImmutableClassesGiraphConfiguration conf,
TaskInfo myTaskInfo,
Thread.UncaughtExceptionHandler exceptionHandler,
FlowControl flowControl)
Constructor with external server data
|
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration<I,V,E> |
WritableRequest.conf
Configuration
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,V,E> |
WritableRequest.getConf() |
Modifier and Type | Method and Description |
---|---|
void |
WritableRequest.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
Constructor and Description |
---|
SendWorkerOneMessageToManyRequest(ByteArrayOneMessageToManyIds<I,M> oneMessageToManyIds,
ImmutableClassesGiraphConfiguration conf)
Constructor used to send request.
|
SendWorkerVerticesRequest(ImmutableClassesGiraphConfiguration<I,V,E> conf,
PairList<Integer,ExtendedDataOutput> workerPartitions)
Constructor for sending a request.
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,V,E> |
ImmutableClassesGiraphConfigurable.getConf()
Return the configuration used by this object.
|
ImmutableClassesGiraphConfiguration<I,V,E> |
DefaultImmutableClassesGiraphConfigurable.getConf() |
Modifier and Type | Method and Description |
---|---|
MessageCombiner<? super I,M> |
DefaultMessageClasses.createMessageCombiner(ImmutableClassesGiraphConfiguration conf) |
MessageCombiner<? super I,M> |
MessageClasses.createMessageCombiner(ImmutableClassesGiraphConfiguration<I,? extends org.apache.hadoop.io.Writable,? extends org.apache.hadoop.io.Writable> conf)
Create new instance of MessageCombiner
|
MessageValueFactory<M> |
DefaultMessageClasses.createMessageValueFactory(ImmutableClassesGiraphConfiguration conf) |
MessageValueFactory<M> |
MessageClasses.createMessageValueFactory(ImmutableClassesGiraphConfiguration conf)
Create new instance of MessageValueFactory
|
void |
GiraphConfigurationSettable.setConf(ImmutableClassesGiraphConfiguration<I,V,E> configuration)
Set the configuration to be used by this object.
|
void |
DefaultImmutableClassesGiraphConfigurable.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
DefaultMessageClasses.verifyConsistent(ImmutableClassesGiraphConfiguration conf) |
void |
MessageClasses.verifyConsistent(ImmutableClassesGiraphConfiguration conf)
Verify if types are internally consistent
|
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration<I,V,E> |
InMemoryEdgeStoreFactory.conf
Giraph configuration.
|
protected ImmutableClassesGiraphConfiguration<I,V,E> |
AbstractEdgeStore.configuration
Giraph configuration.
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,org.apache.hadoop.io.NullWritable> |
IdAndNullArrayEdges.getConf() |
ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> |
IdAndValueArrayEdges.getConf() |
Modifier and Type | Method and Description |
---|---|
void |
InMemoryEdgeStoreFactory.initialize(CentralizedServiceWorker<I,V,E> service,
ImmutableClassesGiraphConfiguration<I,V,E> conf,
org.apache.hadoop.util.Progressable progressable) |
void |
EdgeStoreFactory.initialize(CentralizedServiceWorker<I,V,E> service,
ImmutableClassesGiraphConfiguration<I,V,E> conf,
org.apache.hadoop.util.Progressable progressable)
Implementation class should use this method of initialization
of any required internal state.
|
void |
DefaultCreateSourceVertexCallback.setConf(ImmutableClassesGiraphConfiguration configuration) |
void |
IdAndValueArrayEdges.setConf(ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> conf) |
void |
IdAndNullArrayEdges.setConf(ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,org.apache.hadoop.io.NullWritable> conf) |
void |
LongDiffNullArrayEdges.setConf(ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.Writable,org.apache.hadoop.io.NullWritable> conf) |
static <I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> |
MutableEdgesWrapper.wrap(OutEdges<I,E> edges,
ImmutableClassesGiraphConfiguration<I,?,E> conf)
Factory method to create a new wrapper over the existing out-edges.
|
Constructor and Description |
---|
AbstractEdgeStore(CentralizedServiceWorker<I,V,E> service,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
org.apache.hadoop.util.Progressable progressable)
Constructor.
|
SimpleEdgeStore(CentralizedServiceWorker<I,V,E> service,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
org.apache.hadoop.util.Progressable progressable)
Constructor.
|
Constructor and Description |
---|
IntEdgeStore(CentralizedServiceWorker<org.apache.hadoop.io.IntWritable,V,E> service,
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.IntWritable,V,E> configuration,
org.apache.hadoop.util.Progressable progressable)
Constructor.
|
LongEdgeStore(CentralizedServiceWorker<org.apache.hadoop.io.LongWritable,V,E> service,
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,V,E> configuration,
org.apache.hadoop.util.Progressable progressable)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.NullWritable> |
LongDoubleNullTextInputFormat.getConf() |
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> |
NormalizingLongDoubleDoubleTextInputFormat.getConf() |
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> |
LongDoubleDoubleTextInputFormat.getConf() |
ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> |
LongDoubleFloatTextInputFormat.getConf() |
Modifier and Type | Method and Description |
---|---|
void |
NormalizingLongDoubleDoubleTextInputFormat.setConf(ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> configuration) |
void |
LongDoubleDoubleTextInputFormat.setConf(ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.DoubleWritable> configuration) |
void |
LongDoubleFloatTextInputFormat.setConf(ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.FloatWritable> configuration) |
void |
LongDoubleNullTextInputFormat.setConf(ImmutableClassesGiraphConfiguration<org.apache.hadoop.io.LongWritable,org.apache.hadoop.io.DoubleWritable,org.apache.hadoop.io.NullWritable> configuration) |
Modifier and Type | Method and Description |
---|---|
void |
DefaultComputationFactory.checkConfiguration(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
ComputationFactory.checkConfiguration(ImmutableClassesGiraphConfiguration<I,V,E> conf)
Check that the Configuration passed in is setup correctly to run a job.
|
Computation<I,V,E,org.apache.hadoop.io.Writable,org.apache.hadoop.io.Writable> |
DefaultComputationFactory.createComputation(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
Computation<I,V,E,M1,M2> |
ComputationFactory.createComputation(ImmutableClassesGiraphConfiguration<I,V,E> conf)
Get Computation object
|
void |
DefaultComputationFactory.initialize(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
ComputationFactory.initialize(ImmutableClassesGiraphConfiguration<I,V,E> conf)
One time initialization before compute calls.
|
void |
DefaultVertexIdFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
DefaultOutEdgesFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
DefaultEdgeValueFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
DefaultVertexValueFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
DefaultInputOutEdgesFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
Constructor and Description |
---|
DefaultMessageValueFactory(Class<M> messageValueClass,
ImmutableClassesGiraphConfiguration conf)
Constructor
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
VertexMutations.getConf() |
ImmutableClassesGiraphConfiguration<I,V,E> |
GraphTaskManager.getConf() |
Modifier and Type | Method and Description |
---|---|
abstract <T extends org.apache.hadoop.io.Writable> |
GraphType.factory(ImmutableClassesGiraphConfiguration conf)
Get factory for creating this graph type
|
abstract <T extends org.apache.hadoop.io.Writable> |
GraphType.get(ImmutableClassesGiraphConfiguration conf)
Get class set by user for this option
|
<T extends org.apache.hadoop.io.Writable> |
GraphType.newInstance(ImmutableClassesGiraphConfiguration conf)
Create a new instance of this value type from configuration
|
void |
VertexMutations.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
DefaultVertexResolver.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
Constructor and Description |
---|
ComputeCallable(org.apache.hadoop.mapreduce.Mapper.Context context,
GraphState graphState,
MessageStore<I,M1> messageStore,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
CentralizedServiceWorker<I,V,E> serviceWorker)
Constructor
|
Constructor and Description |
---|
PseudoRandomIntNullLocalEdgesHelper(int numVertices,
ImmutableClassesGiraphConfiguration conf)
Constructor.
|
PseudoRandomLocalEdgesHelper(long numVertices,
float minLocalEdgesRatio,
ImmutableClassesGiraphConfiguration conf)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
static <I extends org.apache.hadoop.io.WritableComparable,E extends org.apache.hadoop.io.Writable> |
EdgeInputFormatDescription.createEdgeInputFormats(ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> conf)
Create all edge input formats
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable,B extends org.apache.hadoop.io.Writable> |
MappingInputFormatDescription.createMappingInputFormats(ImmutableClassesGiraphConfiguration<I,V,E> conf)
Create all mapping input formats
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
VertexInputFormatDescription.createVertexInputFormats(ImmutableClassesGiraphConfiguration<I,V,E> conf)
Create all vertex input formats
|
void |
MultiVertexInputFormat.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
MultiMappingInputFormat.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
MultiEdgeInputFormat.setConf(ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> conf) |
Modifier and Type | Method and Description |
---|---|
void |
WrappedMappingReader.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
WrappedVertexReader.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
WrappedEdgeReader.setConf(ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> conf) |
Constructor and Description |
---|
WrappedEdgeReader(EdgeReader<I,E> baseEdgeReader,
ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> conf)
Constructor
|
WrappedMappingReader(MappingReader<I,V,E,B> baseMappingReader,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Constructor
|
WrappedVertexReader(VertexReader<I,V,E> baseVertexReader,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Constructor
|
Modifier and Type | Method and Description |
---|---|
void |
VertexReaderWrapper.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
MappingReaderWrapper.setConf(ImmutableClassesGiraphConfiguration<I,V,E> conf) |
void |
EdgeReaderWrapper.setConf(ImmutableClassesGiraphConfiguration<I,org.apache.hadoop.io.Writable,E> conf) |
Constructor and Description |
---|
MultiThreadedSuperstepOutput(ImmutableClassesGiraphConfiguration<I,V,E> conf,
org.apache.hadoop.mapreduce.Mapper.Context context)
Constructor
|
SynchronizedSuperstepOutput(ImmutableClassesGiraphConfiguration<I,V,E> conf,
org.apache.hadoop.mapreduce.Mapper.Context context)
Constructor
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
DefaultJobObserver.getConf() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultJobObserver.setConf(ImmutableClassesGiraphConfiguration configuration) |
Modifier and Type | Method and Description |
---|---|
void |
JythonComputationFactory.checkConfiguration(ImmutableClassesGiraphConfiguration conf) |
Computation |
JythonComputationFactory.createComputation(ImmutableClassesGiraphConfiguration conf) |
void |
JythonComputationFactory.initialize(ImmutableClassesGiraphConfiguration conf) |
void |
JythonFactoryBase.setConf(ImmutableClassesGiraphConfiguration conf) |
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
DefaultMasterObserver.getConf() |
Modifier and Type | Method and Description |
---|---|
static SuperstepClasses |
SuperstepClasses.createAndExtractTypes(ImmutableClassesGiraphConfiguration conf)
Create superstep classes by initiazling from current state
in configuration
|
static SuperstepClasses |
SuperstepClasses.createToRead(ImmutableClassesGiraphConfiguration conf)
Create empty superstep classes, readFields needs to be called afterwards
|
void |
DefaultMasterObserver.setConf(ImmutableClassesGiraphConfiguration configuration) |
void |
AggregatorReduceOperation.setConf(ImmutableClassesGiraphConfiguration conf) |
Constructor and Description |
---|
AggregatorReduceOperation(Class<? extends Aggregator<A>> aggregatorClass,
ImmutableClassesGiraphConfiguration<?,?,?> conf)
Constructor
|
AggregatorToGlobalCommTranslation(ImmutableClassesGiraphConfiguration<?,?,?> conf,
MasterGlobalCommUsage globalComm)
Constructor
|
MasterAggregatorHandler(ImmutableClassesGiraphConfiguration<?,?,?> conf,
org.apache.hadoop.util.Progressable progressable)
Constructor
|
SuperstepClasses(ImmutableClassesGiraphConfiguration conf,
Class<? extends Computation> computationClass,
MessageClasses<? extends org.apache.hadoop.io.WritableComparable,? extends org.apache.hadoop.io.Writable> incomingMessageClasses,
MessageClasses<? extends org.apache.hadoop.io.WritableComparable,? extends org.apache.hadoop.io.Writable> outgoingMessageClasses)
Constructor
|
Constructor and Description |
---|
OutOfCoreEngine(ImmutableClassesGiraphConfiguration<?,?,?> conf,
CentralizedServiceWorker<?,?,?> service,
NetworkMetrics networkMetrics)
Constructor
|
OutOfCoreIOStatistics(ImmutableClassesGiraphConfiguration conf,
int numIOThreads)
Constructor
|
Constructor and Description |
---|
DiskBackedEdgeStore(EdgeStore<I,V,E> edgeStore,
ImmutableClassesGiraphConfiguration<I,V,E> conf,
OutOfCoreEngine oocEngine)
Constructor
|
DiskBackedMessageStore(ImmutableClassesGiraphConfiguration<I,?,?> config,
OutOfCoreEngine oocEngine,
MessageStore<I,M> messageStore,
boolean useMessageCombiner,
long superstep)
Constructor
|
DiskBackedPartitionStore(PartitionStore<I,V,E> partitionStore,
ImmutableClassesGiraphConfiguration<I,V,E> conf,
org.apache.hadoop.mapreduce.Mapper.Context context,
OutOfCoreEngine oocEngine)
Constructor.
|
Constructor and Description |
---|
InMemoryDataAccessor(ImmutableClassesGiraphConfiguration<?,?,?> conf)
Constructor
|
LocalDiskDataAccessor(ImmutableClassesGiraphConfiguration<?,?,?> conf)
Constructor
|
Constructor and Description |
---|
FixedPartitionsOracle(ImmutableClassesGiraphConfiguration conf,
OutOfCoreEngine oocEngine)
Constructor
|
MemoryEstimatorOracle(ImmutableClassesGiraphConfiguration conf,
OutOfCoreEngine oocEngine)
Constructor.
|
SimpleGCMonitoringOracle(ImmutableClassesGiraphConfiguration conf,
OutOfCoreEngine oocEngine)
Constructor
|
ThresholdBasedOracle(ImmutableClassesGiraphConfiguration conf,
OutOfCoreEngine oocEngine)
Constructor
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration<I,V,E> |
BasicPartition.getConf() |
ImmutableClassesGiraphConfiguration |
BasicPartitionOwner.getConf() |
Modifier and Type | Method and Description |
---|---|
static int |
PartitionUtils.computePartitionCount(int availableWorkerCount,
ImmutableClassesGiraphConfiguration conf)
Compute the number of partitions, based on the configuration.
|
void |
SimpleLongRangePartitionerFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
SimpleIntRangePartitionerFactory.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
BasicPartitionOwner.setConf(ImmutableClassesGiraphConfiguration conf) |
void |
BasicPartition.setConf(ImmutableClassesGiraphConfiguration<I,V,E> configuration) |
Constructor and Description |
---|
MasterGraphPartitionerImpl(ImmutableClassesGiraphConfiguration<I,V,E> conf)
Constructor.
|
SimplePartitionStore(ImmutableClassesGiraphConfiguration<I,V,E> conf,
org.apache.hadoop.mapreduce.Mapper.Context context)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
void |
Reducer.readFields(DataInput in,
ImmutableClassesGiraphConfiguration conf)
Deserialize the fields of this object from
in . |
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration<I,V,E> |
TestGraph.conf
The configuration
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
LogVersions.getConf() |
ImmutableClassesGiraphConfiguration<I,?,E> |
ByteArrayVertexIdEdges.getConf()
Cast the
ImmutableClassesGiraphConfiguration so it can be used
to generate edge objects. |
ImmutableClassesGiraphConfiguration<I,?,?> |
AbstractVertexIdData.getConf() |
ImmutableClassesGiraphConfiguration |
JMapHistoDumper.getConf() |
ImmutableClassesGiraphConfiguration<I,V,E> |
TestGraph.getConf() |
Modifier and Type | Method and Description |
---|---|
static void |
ConfigurationUtils.configureIfPossible(Object object,
ImmutableClassesGiraphConfiguration configuration)
Configure an object with an
ImmutableClassesGiraphConfiguration
if that objects supports it. |
static <T extends org.apache.hadoop.io.Writable> |
WritableUtils.createCopy(T original,
Class<? extends T> outputClass,
ImmutableClassesGiraphConfiguration conf)
Create a copy of Writable object, by serializing and deserializing it.
|
static <T extends org.apache.hadoop.io.Writable> |
WritableUtils.createCopy(T original,
ValueFactory<T> classFactory,
ImmutableClassesGiraphConfiguration conf)
Create a copy of Writable object, by serializing and deserializing it.
|
static <T extends org.apache.hadoop.io.Writable> |
WritableUtils.createCopy(UnsafeByteArrayOutputStream reusableOut,
UnsafeReusableByteArrayInput reusableIn,
T original,
ImmutableClassesGiraphConfiguration conf)
Create a copy of Writable object, by serializing and deserializing it.
|
static <W extends org.apache.hadoop.io.Writable> |
WritableUtils.createWritable(Class<W> klass,
ImmutableClassesGiraphConfiguration configuration)
Instantiate a new Writable, checking for NullWritable along the way.
|
static <T> T |
ReflectionUtils.newInstance(Class<T> theClass,
ImmutableClassesGiraphConfiguration configuration)
Instantiate classes that are ImmutableClassesGiraphConfigurable
|
static <T> T |
ReflectionUtils.newInstance(Class<T> theClass,
ImmutableClassesGiraphConfiguration configuration,
org.apache.hadoop.mapreduce.Mapper.Context context)
Instantiate classes that are ImmutableClassesGiraphConfigurable,
and optionally set context on them if they are ContextSettable
|
static ExtendedDataOutput |
WritableUtils.readExtendedDataOutput(DataInput in,
ImmutableClassesGiraphConfiguration conf)
Read ExtendedDataOutput from DataInput
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.readVertexFromDataInput(DataInput input,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Reads data from input stream to initialize Vertex.
|
static <T extends org.apache.hadoop.io.Writable> |
WritableUtils.readWritableObject(DataInput input,
ImmutableClassesGiraphConfiguration conf)
Reads object from input stream
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.reinitializeVertexFromByteArray(byte[] byteArray,
Vertex<I,V,E> vertex,
boolean unsafe,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Read vertex data from byteArray to a Writeable object, skipping the size.
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.reinitializeVertexFromDataInput(DataInput input,
Vertex<I,V,E> vertex,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Reads data from input stream to initialize Vertex.
|
void |
LogVersions.setConf(ImmutableClassesGiraphConfiguration configuration) |
void |
ReactiveJMapHistoDumper.setConf(ImmutableClassesGiraphConfiguration configuration) |
void |
AbstractVertexIdData.setConf(ImmutableClassesGiraphConfiguration configuration) |
void |
JMapHistoDumper.setConf(ImmutableClassesGiraphConfiguration configuration) |
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.writeVertexToByteArray(Vertex<I,V,E> vertex,
boolean unsafe,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Write vertex data to byte array with the first 4 bytes as the size of the
entire buffer (including the size).
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.writeVertexToByteArray(Vertex<I,V,E> vertex,
byte[] buffer,
boolean unsafe,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Write vertex data to byte array with the first 4 bytes as the size of the
entire buffer (including the size).
|
static <I extends org.apache.hadoop.io.WritableComparable,V extends org.apache.hadoop.io.Writable,E extends org.apache.hadoop.io.Writable> |
WritableUtils.writeVertexToDataOutput(DataOutput output,
Vertex<I,V,E> vertex,
ImmutableClassesGiraphConfiguration<I,V,E> conf)
Writes Vertex data to output stream.
|
Constructor and Description |
---|
ByteStructVertexIdIterator(ExtendedDataOutput extendedDataOutput,
ImmutableClassesGiraphConfiguration<I,?,?> conf)
Constructor.
|
ExtendedByteArrayOutputBuffer(ImmutableClassesGiraphConfiguration<?,?,?> config)
Constructor
|
VertexIterator(ExtendedDataOutput extendedDataOutput,
ImmutableClassesGiraphConfiguration<I,V,E> configuration)
Constructor.
|
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration |
BigDataOutput.conf
Configuration
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
BigDataOutput.getConf() |
Constructor and Description |
---|
BigDataInputOutput(ImmutableClassesGiraphConfiguration conf)
Constructor
|
BigDataOutput(ImmutableClassesGiraphConfiguration conf)
Constructor
|
BigDataOutput(int initialSize,
ImmutableClassesGiraphConfiguration conf)
Constructor
|
ExtendedDataInputOutput(ImmutableClassesGiraphConfiguration conf)
Constructor
|
Modifier and Type | Field and Description |
---|---|
protected ImmutableClassesGiraphConfiguration<I,V,E> |
InputSplitsCallable.configuration
Configuration
|
Modifier and Type | Method and Description |
---|---|
ImmutableClassesGiraphConfiguration |
DefaultWorkerObserver.getConf() |
Modifier and Type | Method and Description |
---|---|
void |
DefaultWorkerObserver.setConf(ImmutableClassesGiraphConfiguration configuration) |
Constructor and Description |
---|
EdgeInputSplitsCallable(EdgeInputFormat<I,E> edgeInputFormat,
org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor.
|
EdgeInputSplitsCallableFactory(EdgeInputFormat<I,E> edgeInputFormat,
org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor.
|
InputSplitsCallable(org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor.
|
LocalData(ImmutableClassesGiraphConfiguration<I,V,E> conf)
Constructor
Set configuration, create & initialize mapping store
|
MappingInputSplitsCallable(MappingInputFormat<I,V,E,B> mappingInputFormat,
org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor
|
MappingInputSplitsCallableFactory(MappingInputFormat<I,V,E,B> mappingInputFormat,
org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor.
|
VertexInputSplitsCallable(VertexInputFormat<I,V,E> vertexInputFormat,
org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor.
|
VertexInputSplitsCallableFactory(VertexInputFormat<I,V,E> vertexInputFormat,
org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration<I,V,E> configuration,
BspServiceWorker<I,V,E> bspServiceWorker,
WorkerInputSplitsHandler splitsHandler)
Constructor.
|
WorkerAggregatorHandler(CentralizedServiceWorker<?,?,?> serviceWorker,
ImmutableClassesGiraphConfiguration conf,
org.apache.hadoop.util.Progressable progressable)
Constructor
|
Constructor and Description |
---|
ZooKeeperManager(org.apache.hadoop.mapreduce.Mapper.Context context,
ImmutableClassesGiraphConfiguration configuration)
Constructor with context.
|
Copyright © 2011-2020 The Apache Software Foundation. All Rights Reserved.