Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W 

A

Acceptor - Class in edu.iu.harp.server
The Acceptor for handling the messages received from clients
Acceptor(ServerConn, EventQueue, DataMap, Workers, byte) - Constructor for class edu.iu.harp.server.Acceptor
 
Ack - Class in edu.iu.harp.util
The Ack class
Ack() - Constructor for class edu.iu.harp.util.Ack
 
acquire(Semaphore, int) - Static method in class edu.iu.harp.schdynamic.ComputeUtil
Acquires the given number of permits from this semaphore
acquire(Semaphore) - Static method in class edu.iu.harp.schdynamic.ComputeUtil
Acquires a permit from this semaphore
addDataToQueueOrMap(int, EventQueue, EventType, DataMap, Data) - Static method in class edu.iu.harp.io.DataUtil
Add the Data to EventQueue or DataMap.
addEdge(int, int, int) - Method in class edu.iu.harp.example.EdgeVal
 
addEdgeVal(EdgeVal) - Method in class edu.iu.harp.example.EdgeVal
 
addEvent(Event) - Method in class edu.iu.harp.io.EventQueue
Add a event to the queue
addKeyVal(int, int) - Method in class edu.iu.harp.keyval.Int2IntKVTable
Add a new key-value pair to the table.
addKeyVal(int, long) - Method in class edu.iu.harp.keyval.Int2LongKVTable
Add a new key-value pair to the table.
addKeyVal(int, V) - Method in class edu.iu.harp.keyval.Int2ValKVTable
Add a new key-value pair to the table.
addKeyVal(K, V) - Method in class edu.iu.harp.keyval.Key2ValKVTable
Add a new key-value pair to the table.
addKeyVal(long, double) - Method in class edu.iu.harp.keyval.Long2DoubleKVTable
Add a new key-value pair to the table.
addKeyVal(long, int) - Method in class edu.iu.harp.keyval.Long2IntKVTable
Add a new key-value pair to the table.
addPartition(Partition<P>) - Method in class edu.iu.harp.partition.Table
Add a partition into a table.
addPartitionsToTable(List<Transferable>, Table<P>) - Static method in class edu.iu.harp.partition.PartitionUtil
Add a list of partitions to table in parallel
aggregate(String, String, Table<P>, PT, PF, DataMap, Workers) - Static method in class edu.iu.harp.collective.RegroupCollective
 
allgather(String, String, Table<P>, DataMap, Workers) - Static method in class edu.iu.harp.collective.AllgatherCollective
Allgather communication operation
allgather(String, String, List<Transferable>, DataMap, Workers) - Static method in class edu.iu.harp.collective.Communication
Allgather collective communication operation
allgather(String, String, Table<P>) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Allgather partitions of the tables to all the local tables.
AllgatherCollective - Class in edu.iu.harp.collective
Allgather Collective communication
AllgatherCollective() - Constructor for class edu.iu.harp.collective.AllgatherCollective
 
allgatherPartitionSet(String, String, Table<P>, List<Transferable>, DataMap, Workers) - Static method in class edu.iu.harp.partition.PartitionUtil
Allgather the PartitionSet among workers
allreduce(String, String, Table<P>, DataMap, Workers) - Static method in class edu.iu.harp.collective.AllreduceCollective
Allreduce communication operation.
allreduce(String, String, Table<P>) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Allreduce partitions of the tables to all the local tables.
AllreduceCollective - Class in edu.iu.harp.collective
Allreduce Collective communication
AllreduceCollective() - Constructor for class edu.iu.harp.collective.AllreduceCollective
 
apply(WordCountPartition) - Method in class edu.iu.harp.example.WordAvgFunction
 
apply(T) - Method in class edu.iu.harp.partition.PartitionFunction
 
applyPartitionFunction(Table<P>, PF) - Static method in class edu.iu.harp.collective.RegroupCollective
Apply the function the each partition in the Table
Array<T> - Class in edu.iu.harp.resource
The abstract class of arrays.
Array(T, int, int) - Constructor for class edu.iu.harp.resource.Array
 
array - Variable in class edu.iu.harp.resource.Array
The array
ArrayPool<T> - Class in edu.iu.harp.resource
The abstract class of pools.
ArrayPool() - Constructor for class edu.iu.harp.resource.ArrayPool
 

B

barrier(String, String, DataMap, Workers) - Static method in class edu.iu.harp.collective.Communication
In barrier, each worker send a message to master.
Barrier - Class in edu.iu.harp.util
The Barrier class
Barrier() - Constructor for class edu.iu.harp.util.Barrier
 
barrier(String, String) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Synchronize workers through a barrier
BcastCollective - Class in edu.iu.harp.collective
Broadcast Collective communication
BcastCollective() - Constructor for class edu.iu.harp.collective.BcastCollective
 
broadcast(String, String, Table<P>, int, boolean, DataMap, Workers) - Static method in class edu.iu.harp.collective.BcastCollective
The broadcast communication operation
broadcast(String, String, Table<P>, int, boolean) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Broadcast the partitions of the table on a worker to other workers.
BUFFER_SIZE - Static variable in class edu.iu.harp.io.Constant
 
BYTE_ARRAY - Static variable in class edu.iu.harp.io.DataType
 
ByteArray - Class in edu.iu.harp.resource
ByteArray class for managing byte[] data.
ByteArray(byte[], int, int) - Constructor for class edu.iu.harp.resource.ByteArray
 
BytesPool - Class in edu.iu.harp.resource
A pool used for caching byte arrays.
BytesPool() - Constructor for class edu.iu.harp.resource.BytesPool
 

C

CHAIN_BCAST - Static variable in class edu.iu.harp.io.Constant
 
CHAIN_BCAST_DECODE - Static variable in class edu.iu.harp.io.Constant
 
chainBcast(String, int, String, List<Transferable>, Workers) - Static method in class edu.iu.harp.collective.Communication
The broadcast communication operation using chain method.
chainBcastAndRecv(String, int, String, List<Transferable>, Workers, DataMap) - Static method in class edu.iu.harp.collective.Communication
The broadcast communication operation using chain method.
clean() - Method in class edu.iu.harp.io.ConnPool
Clean all released connections
clean() - Method in class edu.iu.harp.io.DataMap
Clean the DataMap
clean() - Method in class edu.iu.harp.resource.ResourcePool
 
clean() - Method in class edu.iu.harp.resource.WritablePool
Clean all writables in freeQueue, namely remove all not-in-use writables.
cleanData(String) - Method in class edu.iu.harp.io.DataMap
Clean the Data related to the context Invoke this when the context is done.
cleanInputQueue() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Clean the input queue
cleanInputQueue() - Method in class edu.iu.harp.schstatic.StaticScheduler
Clean the queue of input
cleanOperationData(String, String) - Method in class edu.iu.harp.io.DataMap
Clean the data of the operation under the context
cleanup(Context) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Called once at the end of the task.
clear() - Method in class edu.iu.harp.example.EdgeVal
 
clear() - Method in class edu.iu.harp.example.IntCount
Clear the data
clear() - Method in class edu.iu.harp.example.IntVal
Clear the value
clear() - Method in class edu.iu.harp.example.StringKey
Clear the string
clear() - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Clear the partition.
clear() - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Clear the partition.
clear() - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Clear the partition.
clear() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Clear the partition.
clear() - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Clear the partition.
clear() - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Clear the partition.
clear() - Method in class edu.iu.harp.resource.Writable
Abstract method for clearing the Writable data
clear() - Method in class edu.iu.harp.util.Ack
Clear the data
clear() - Method in class edu.iu.harp.util.Barrier
Clear the data
clear() - Method in class edu.iu.harp.util.Join
Clear the data
clear() - Method in class edu.iu.harp.util.PartitionCount
Clear the data
clear() - Method in class edu.iu.harp.util.PartitionSet
Clear the parIDs
close(ClientProtocol) - Method in class org.apache.hadoop.mapred.MapCollectiveClientProtocolProvider
 
CollectiveMapper<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.hadoop.mapred
CollectiveMapper is extended from original mapper in Hadoop.
CollectiveMapper() - Constructor for class org.apache.hadoop.mapred.CollectiveMapper
 
CollectiveMapper.KeyValReader - Class in org.apache.hadoop.mapred
A Key-Value reader to read key-value inputs for this worker.
combine(DoubleArray, DoubleArray) - Method in class edu.iu.harp.example.DoubleArrPlus
Combine two DoubleArrays
combine(EdgeVal, EdgeVal) - Method in class edu.iu.harp.example.EdgeValCombiner
 
combine(IntArray, IntArray) - Method in class edu.iu.harp.example.IntArrPlus
Combine two DoubleArrays
combine(IntCount, IntCount) - Method in class edu.iu.harp.example.IntCountPlus
Combine two IntCountss
combine(IntVal, IntVal) - Method in class edu.iu.harp.example.IntPlus
 
combine(LongArray, LongArray) - Method in class edu.iu.harp.example.LongArrPlus
Combine two LongArrays
combine(double, double) - Method in class edu.iu.harp.keyval.TypeDoubleCombiner
Merge two double-type values
combine(int, int) - Method in class edu.iu.harp.keyval.TypeIntCombiner
Merge two int-type values
combine(long, long) - Method in class edu.iu.harp.keyval.TypeLongCombiner
Merge two long-type values
combine(V, V) - Method in class edu.iu.harp.keyval.ValCombiner
Combine two Values
combine(P, P) - Method in class edu.iu.harp.partition.PartitionCombiner
Defines how to merge two partitions.
Communication - Class in edu.iu.harp.collective
These methods are used for communicating non-partition transferable.
Communication() - Constructor for class edu.iu.harp.collective.Communication
 
compute() - Method in class edu.iu.harp.server.Decoder
The main computation performed by this task.
ComputeUtil - Class in edu.iu.harp.schdynamic
Some utils including acquiring semaphora and joining threads
ComputeUtil() - Constructor for class edu.iu.harp.schdynamic.ComputeUtil
 
CONNECT_MAX_WAIT_TIME - Static variable in class edu.iu.harp.io.Constant
 
Connection - Class in edu.iu.harp.io
The connection object as a client
CONNECTION_END - Static variable in class edu.iu.harp.io.Constant
 
ConnPool - Class in edu.iu.harp.io
This class manages connection objects
Constant - Class in edu.iu.harp.io
This class defines the constants used in Harp
Constant() - Constructor for class edu.iu.harp.io.Constant
 
create(String, int, boolean) - Static method in class edu.iu.harp.io.Connection
Get a connection from the ConnPool
create(int, boolean) - Static method in class edu.iu.harp.resource.ByteArray
Create an array.
create(int, boolean) - Static method in class edu.iu.harp.resource.DoubleArray
Create an array.
create(int, boolean) - Static method in class edu.iu.harp.resource.FloatArray
Create an array.
create(int, boolean) - Static method in class edu.iu.harp.resource.IntArray
Create an array.
create(int, boolean) - Static method in class edu.iu.harp.resource.LongArray
Create an array.
create(int, boolean) - Static method in class edu.iu.harp.resource.ShortArray
Create an array.
create(Class<W>) - Static method in class edu.iu.harp.resource.Writable
Get a writable from ResourcePool
create(Configuration) - Method in class org.apache.hadoop.mapred.MapCollectiveClientProtocolProvider
 
create(InetSocketAddress, Configuration) - Method in class org.apache.hadoop.mapred.MapCollectiveClientProtocolProvider
 
createApplicationSubmissionContext(Configuration, String, Credentials) - Method in class org.apache.hadoop.mapred.MapCollectiveRunner
 
createContainerAllocator(ClientService, AppContext) - Method in class org.apache.hadoop.mapreduce.v2.app.MapCollectiveAppMaster
 
createContainerLauncher(AppContext) - Method in class org.apache.hadoop.mapreduce.v2.app.MapCollectiveAppMaster
 
createEventProcessor(ContainerLauncherEvent) - Method in class org.apache.hadoop.mapreduce.v2.app.launcher.MapCollectiveContainerLauncherImpl
 
createNewArray(int) - Method in class edu.iu.harp.resource.ArrayPool
Create a new array of the size.
createNewArray(int) - Method in class edu.iu.harp.resource.BytesPool
New a byte array of the size
createNewArray(int) - Method in class edu.iu.harp.resource.DoublesPool
New a double array of the size
createNewArray(int) - Method in class edu.iu.harp.resource.FloatsPool
New a float array of the size
createNewArray(int) - Method in class edu.iu.harp.resource.IntsPool
New a int array of the size
createNewArray(int) - Method in class edu.iu.harp.resource.LongsPool
New a long-type array of the size
createNewArray(int) - Method in class edu.iu.harp.resource.ShortsPool
New a short-type array of the size
createSendOrder(Workers) - Static method in class edu.iu.harp.partition.PartitionUtil
Define the order of workers to send.

D

Data - Class in edu.iu.harp.io
The wrapper of data used in communication.
Data(byte, String, int, List<Transferable>, int) - Constructor for class edu.iu.harp.io.Data
Construct a data
Data(byte, String, int, List<Transferable>, int, String) - Constructor for class edu.iu.harp.io.Data
Construct an operation data
Data(byte, String, int, List<Transferable>, int, String, int) - Constructor for class edu.iu.harp.io.Data
Construct a partition data in an operation
Data(ByteArray) - Constructor for class edu.iu.harp.io.Data
 
Data(ByteArray, ByteArray) - Constructor for class edu.iu.harp.io.Data
 
DATA_MAX_WAIT_TIME - Static variable in class edu.iu.harp.io.Constant
 
DataChainBcastReceiver - Class in edu.iu.harp.server
The actual receiver for receiving the broadcasted data using chain method.
DataChainBcastReceiver(int, ServerConn, EventQueue, DataMap, Workers, byte) - Constructor for class edu.iu.harp.server.DataChainBcastReceiver
Throw exception when failing to initialize
DataChainBcastSender - Class in edu.iu.harp.client
The actual sender for broadcasting the data using chain method We don't allow the worker broadcasts to itself.
DataChainBcastSender(Data, Workers, byte) - Constructor for class edu.iu.harp.client.DataChainBcastSender
 
DataMap - Class in edu.iu.harp.io
A wrapper for operations on queues associated with communication contextName and operationName.
DataMap() - Constructor for class edu.iu.harp.io.DataMap
 
DataMSTBcastReceiver - Class in edu.iu.harp.server
The actual receiver for receiving the broadcasted data using MST method.
DataMSTBcastReceiver(int, ServerConn, EventQueue, DataMap, Workers, byte) - Constructor for class edu.iu.harp.server.DataMSTBcastReceiver
Throw exception when failing to initialize
DataMSTBcastSender - Class in edu.iu.harp.client
The actual sender for broadcasting the data using MST method We don't allow the worker broadcasts to itself.
DataMSTBcastSender(Data, Workers, byte) - Constructor for class edu.iu.harp.client.DataMSTBcastSender
 
DataReceiver - Class in edu.iu.harp.server
The actual receiver for receiving the data.
DataReceiver(int, ServerConn, EventQueue, DataMap, byte) - Constructor for class edu.iu.harp.server.DataReceiver
 
DataSender - Class in edu.iu.harp.client
The actual sender for sending the data.
DataSender(Data, int, Workers, byte) - Constructor for class edu.iu.harp.client.DataSender
 
DataSender(Data, String, int, byte) - Constructor for class edu.iu.harp.client.DataSender
 
DataStatus - Enum in edu.iu.harp.io
The statuses of the Data
DataType - Class in edu.iu.harp.io
The types of the Data
DataType() - Constructor for class edu.iu.harp.io.DataType
 
DataUtil - Class in edu.iu.harp.io
The operations, including deserialization, decoding and encoding on various type of data
DataUtil() - Constructor for class edu.iu.harp.io.DataUtil
 
decodeBodyArray() - Method in class edu.iu.harp.io.Data
Decode the bodyArray as the body
decodeHeadArray() - Method in class edu.iu.harp.io.Data
Decode the headArray as the head
decodePartitionList(ByteArray) - Static method in class edu.iu.harp.io.DataUtil
Decode the ByteArray as a list of Partitions
Decoder - Class in edu.iu.harp.server
The recursive resultless Fork-Join task for decoding the data.
Decoder(Data, int, EventType, EventQueue, DataMap) - Constructor for class edu.iu.harp.server.Decoder
 
decodeSimpleList(ByteArray) - Static method in class edu.iu.harp.io.DataUtil
Decode the ByteArray as a list of Transferable objects
DEFAULT_WORKER_POART_BASE - Static variable in class edu.iu.harp.io.Constant
 
Depl - Class in edu.iu.harp.depl
Some tools including command execution, and getting rack information
Depl() - Constructor for class edu.iu.harp.depl.Depl
 
deserializeByteArray(Deserializer) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a ByteArray
deserializeDoubleArray(Deserializer) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a DoubleArray
deserializeFloatArray(Deserializer) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a FloatArray
deserializeIntArray(Deserializer) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a IntArray
deserializeLongArray(Deserializer) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a LongArray
Deserializer - Class in edu.iu.harp.io
A class for Deserialization implemented DataInput interface
Deserializer(ByteArray) - Constructor for class edu.iu.harp.io.Deserializer
 
Deserializer(byte[], int, int) - Constructor for class edu.iu.harp.io.Deserializer
 
deserializeShortArray(Deserializer) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a ShortArray
deserializeWritable(DataInput) - Static method in class edu.iu.harp.io.DataUtil
Deserialize the data from a Deserializer as a Writable
DOUBLE_ARRAY - Static variable in class edu.iu.harp.io.DataType
 
DoubleArray - Class in edu.iu.harp.resource
ByteArray class for managing double[] data.
DoubleArray(double[], int, int) - Constructor for class edu.iu.harp.resource.DoubleArray
 
DoubleArrPlus - Class in edu.iu.harp.example
Combiner for DoubleArray
DoubleArrPlus() - Constructor for class edu.iu.harp.example.DoubleArrPlus
 
DoublesPool - Class in edu.iu.harp.resource
A pool used for caching double arrays.
DoublesPool() - Constructor for class edu.iu.harp.resource.DoublesPool
 
Driver - Class in edu.iu.harp.collective
Test collective communication
Driver() - Constructor for class edu.iu.harp.collective.Driver
 
DynamicScheduler<I,O,T extends Task<I,O>> - Class in edu.iu.harp.schdynamic
The dynamic scheduler
DynamicScheduler(List<T>) - Constructor for class edu.iu.harp.schdynamic.DynamicScheduler
 

E

EdgePartition - Class in edu.iu.harp.example
 
EdgePartition() - Constructor for class edu.iu.harp.example.EdgePartition
 
EdgeTable - Class in edu.iu.harp.example
 
EdgeTable(int) - Constructor for class edu.iu.harp.example.EdgeTable
 
EdgeVal - Class in edu.iu.harp.example
 
EdgeVal() - Constructor for class edu.iu.harp.example.EdgeVal
 
EdgeValCombiner - Class in edu.iu.harp.example
 
EdgeValCombiner() - Constructor for class edu.iu.harp.example.EdgeValCombiner
 
edu.iu.harp.client - package edu.iu.harp.client
harp collective communication client
edu.iu.harp.collective - package edu.iu.harp.collective
harp collective communication implementations
edu.iu.harp.depl - package edu.iu.harp.depl
harp node deployment
edu.iu.harp.example - package edu.iu.harp.example
harp data structure examples
edu.iu.harp.io - package edu.iu.harp.io
Generic i/o code for use
edu.iu.harp.keyval - package edu.iu.harp.keyval
harp keyval data structure definition
edu.iu.harp.partition - package edu.iu.harp.partition
harp partition and table definition
edu.iu.harp.resource - package edu.iu.harp.resource
harp resources and data structure definitions
edu.iu.harp.schdynamic - package edu.iu.harp.schdynamic
harp dynamic scheduler
edu.iu.harp.schstatic - package edu.iu.harp.schstatic
harp static scheduler
edu.iu.harp.server - package edu.iu.harp.server
harp collective communication server
edu.iu.harp.util - package edu.iu.harp.util
harp utils
edu.iu.harp.worker - package edu.iu.harp.worker
harp workers
encode(DataOutput) - Method in class edu.iu.harp.partition.Partition
Encode the partition data as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.ByteArray
Encode the array as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.DoubleArray
Encode the array as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.FloatArray
Encode the array as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.IntArray
Encode the array as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.LongArray
Encode the array as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.ShortArray
Encode the array as DataOutput
encode(DataOutput) - Method in class edu.iu.harp.resource.Transferable
Encode the data as DataOutPut
encode(DataOutput) - Method in class edu.iu.harp.resource.Writable
Encode the writable as DataOutput
encodeBody() - Method in class edu.iu.harp.io.Data
Encode the body as a ByteArray
encodeHead() - Method in class edu.iu.harp.io.Data
Encode the head as a ByteArray
encodeTransList(List<Transferable>) - Static method in class edu.iu.harp.io.DataUtil
Serialize multiple Transferable with different data types
encodeTransList(List<Transferable>, int, DataOutput) - Static method in class edu.iu.harp.io.DataUtil
Encode the data to DataOutput
equals(Object) - Method in class edu.iu.harp.example.StringKey
The overridden equals function
equals(Object) - Method in class edu.iu.harp.keyval.Key
The equals function to be overridden
Event - Class in edu.iu.harp.client
An event includes the event type, the context name, the source ID, the target ID and the event body.
Event(EventType, String, int, int, Simple) - Constructor for class edu.iu.harp.client.Event
 
EventCollective - Class in edu.iu.harp.collective
 
EventCollective() - Constructor for class edu.iu.harp.collective.EventCollective
 
EventQueue - Class in edu.iu.harp.io
The queue for Events
EventQueue() - Constructor for class edu.iu.harp.io.EventQueue
 
EventType - Enum in edu.iu.harp.client
There are three event types.
execute() - Method in class edu.iu.harp.client.Sender
Send the data
executeCMDandForward(String[]) - Static method in class edu.iu.harp.depl.Depl
Just do execution.
executeCMDandNoWait(String[]) - Static method in class edu.iu.harp.depl.Depl
Execute the command and doesn't wait for outputs

F

FAIL_TO_REGROUP_PARTITION_SET - Static variable in class edu.iu.harp.partition.PartitionUtil
The status indicates the failure of regrouping partition set
FLOAT_ARRAY - Static variable in class edu.iu.harp.io.DataType
 
FloatArray - Class in edu.iu.harp.resource
ByteArray class for managing float[] data.
FloatArray(float[], int, int) - Constructor for class edu.iu.harp.resource.FloatArray
 
FloatsPool - Class in edu.iu.harp.resource
A pool used for caching float arrays.
FloatsPool() - Constructor for class edu.iu.harp.resource.FloatsPool
 
forClass(String) - Static method in class edu.iu.harp.resource.Writable
Get the Class object associated with the class or interface with the given string name.
free() - Method in class edu.iu.harp.io.Connection
Free the connection object
free() - Method in class edu.iu.harp.partition.Partition
Free and reset the partition
free() - Method in class edu.iu.harp.partition.Table
Free the partitions
free() - Method in class edu.iu.harp.resource.ByteArray
Free the array from the ResourcePool
free() - Method in class edu.iu.harp.resource.DoubleArray
Free the array from the ResourcePool
free() - Method in class edu.iu.harp.resource.FloatArray
Free the array from the ResourcePool
free() - Method in class edu.iu.harp.resource.IntArray
Free the array from the ResourcePool
free() - Method in class edu.iu.harp.resource.LongArray
Free the array from the ResourcePool
free() - Method in class edu.iu.harp.resource.ShortArray
Free the array from the ResourcePool
free() - Method in class edu.iu.harp.resource.Transferable
Free the data
free() - Method in class edu.iu.harp.resource.Writable
Free the writable from the ResourcePool
freeConn() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Free the connections cached in the pool.
freeMemory() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Free the objects cached in the pool.
freeWritable(W) - Method in class edu.iu.harp.resource.WritablePool
Free the writable by removing it from the inUseMap.

G

gather(String, String, List<Transferable>, int, DataMap, Workers) - Static method in class edu.iu.harp.collective.Communication
Gather collective communication operation
gatherPartitionSet(String, String, Table<P>, List<Transferable>, DataMap, Workers) - Static method in class edu.iu.harp.partition.PartitionUtil
Gather the PartitionSet from workers
get() - Static method in class edu.iu.harp.io.ConnPool
Singleton pattern.
get() - Method in class edu.iu.harp.partition.Partition
Get the partition body
get() - Method in class edu.iu.harp.resource.Array
Get the array body.
get() - Static method in class edu.iu.harp.resource.ResourcePool
 
getBinDirectory() - Static method in class edu.iu.harp.depl.Depl
Return the bin directory
getBody() - Method in class edu.iu.harp.client.Event
Get the body of the event
getBody() - Method in class edu.iu.harp.io.Data
Get the body
getBodyArray() - Method in class edu.iu.harp.io.Data
Get the body array
getBodySize() - Method in class edu.iu.harp.io.Data
Get the size of the body
getBodyStatus() - Method in class edu.iu.harp.io.Data
Get the DataStatus of the body
getBodyType() - Method in class edu.iu.harp.io.Data
Get the type of the body
getCombiner() - Method in class edu.iu.harp.partition.Table
Get the combiner
getCommand() - Method in class edu.iu.harp.client.Sender
Get the command
getCommandType() - Method in class edu.iu.harp.server.Receiver
Get the type of the command
getContextName() - Method in class edu.iu.harp.client.Event
Get the name of the context
getContextName() - Method in class edu.iu.harp.io.Data
Get the name of the context
getCount() - Method in class edu.iu.harp.example.IntCount
Get the count
getCurrentKey() - Method in class org.apache.hadoop.mapred.CollectiveMapper.KeyValReader
Get the current key
getCurrentValue() - Method in class org.apache.hadoop.mapred.CollectiveMapper.KeyValReader
Get the current value
getDataMap() - Method in class edu.iu.harp.server.Receiver
Get the DataMap
getDest() - Method in class edu.iu.harp.example.EdgeVal
 
getDestWorkerID() - Method in class edu.iu.harp.client.Sender
Get the ID of the destination worker
getEvent() - Method in class edu.iu.harp.io.EventQueue
Retrieves and removes the head of this queue, or returns null if this queue is empty.
getEvent() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Get an event from the event queue.
getEventQueue() - Method in class edu.iu.harp.server.Receiver
Get the EventQueue
getEventType() - Method in class edu.iu.harp.client.Event
Get the type of the event
getExeOutput() - Method in class edu.iu.harp.depl.Output
Get the output from the command execution
getExeStatus() - Method in class edu.iu.harp.depl.Output
Get the status of the execution
getHeadArray() - Method in class edu.iu.harp.io.Data
Get the head array
getHeadSize(Data) - Method in class edu.iu.harp.client.DataSender
Get the size of the head array
getHeadStatus() - Method in class edu.iu.harp.io.Data
Get the DataStatus of the head
getID() - Method in class edu.iu.harp.worker.WorkerInfo
Get the id
getInput() - Method in class edu.iu.harp.schdynamic.Input
Get the input object
getInputDtream() - Method in class edu.iu.harp.io.Connection
Get the InputStream
getInt() - Method in class edu.iu.harp.example.IntCount
Get the value
getInt() - Method in class edu.iu.harp.example.IntVal
Get the value
getJavaHomePath() - Static method in class edu.iu.harp.depl.Depl
Return the java home path
getKeyClass() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Get the class of the keys
getKVMap() - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Get the Int2IntOpenHashMap
getKVMap() - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Get the Int2LongOpenHashMap
getKVMap() - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Get the Int2ObjectOpenHashMap
getKVMap() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Get the Object2ObjectOpenHashMap
getKVMap() - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Get the Long2DoubleOpenHashMap
getKVMap() - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Get the Long2IntOpenHashMap
getKVPartitionID(int) - Method in class edu.iu.harp.keyval.Int2IntKVTable
Get the partition Id by key
getKVPartitionID(int) - Method in class edu.iu.harp.keyval.Int2LongKVTable
Get the partition Id by key
getKVPartitionID(int) - Method in class edu.iu.harp.keyval.Int2ValKVTable
Get the partition Id by key
getKVPartitionID(K) - Method in class edu.iu.harp.keyval.Key2ValKVTable
Get the partition Id by key
getLength() - Method in class edu.iu.harp.io.Deserializer
Get the length
getLength() - Method in class edu.iu.harp.io.Serializer
Get the length
getLength(T) - Method in class edu.iu.harp.resource.ArrayPool
Get the length of the array
getLength(byte[]) - Method in class edu.iu.harp.resource.BytesPool
Get the length of the array
getLength(double[]) - Method in class edu.iu.harp.resource.DoublesPool
Get the length of the array
getLength(float[]) - Method in class edu.iu.harp.resource.FloatsPool
Get the length of the array
getLength(int[]) - Method in class edu.iu.harp.resource.IntsPool
Get the length of the array
getLength(long[]) - Method in class edu.iu.harp.resource.LongsPool
Get the length of the array
getLength(short[]) - Method in class edu.iu.harp.resource.ShortsPool
Get the length of the array
getMasterID() - Method in class edu.iu.harp.worker.Workers
Get the ID of the master
getMasterID() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Get the ID of the master worker.
getMasterInfo() - Method in class edu.iu.harp.worker.Workers
Get the WorkerInfo of the master
getMaxID() - Method in class edu.iu.harp.worker.Workers
Get the maximum ID among all the workers
getMaxID() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Get the maximum worker ID
getMiddleID() - Method in class edu.iu.harp.worker.Workers
Get the middle ID among all the workers
getMinID() - Method in class edu.iu.harp.worker.Workers
Get the minimum ID among all the workers
getMinID() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Get the minimum worker ID.
getNextID() - Method in class edu.iu.harp.worker.Workers
Get the next ID of this worker
getNextInfo() - Method in class edu.iu.harp.worker.Workers
Get the WorkerInfo of the next worker
getNode() - Method in class edu.iu.harp.io.Connection
Get the host
getNode() - Method in class edu.iu.harp.worker.WorkerInfo
Get the hostname or IP
getNodeList() - Method in class edu.iu.harp.worker.Nodes
Get the list of all the nodes
getNodes() - Method in class edu.iu.harp.worker.Nodes
Get the map from rackID to its associated nodes
getNumEdges() - Method in class edu.iu.harp.example.EdgeVal
 
getNumEnocdeBytes() - Method in class edu.iu.harp.partition.Partition
Get the number bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.ByteArray
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.DoubleArray
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.FloatArray
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.IntArray
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.LongArray
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.ShortArray
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.Transferable
Get the number of Bytes of encoded data.
getNumEnocdeBytes() - Method in class edu.iu.harp.resource.Writable
Get the number of Bytes of encoded data.
getNumPartitions() - Method in class edu.iu.harp.partition.Table
Get the number of partitions in this table
getNumPhysicalNodes() - Method in class edu.iu.harp.worker.Nodes
Get the number of physical nodes
getNumTasks() - Method in class edu.iu.harp.schstatic.Task
Get the number of the task
getNumTransListBytes(List<Transferable>) - Static method in class edu.iu.harp.io.DataUtil
Get the size in bytes of the encoded data
getNumWorkers() - Method in class edu.iu.harp.partition.Partitioner
 
getNumWorkers() - Method in class edu.iu.harp.worker.Workers
Get the number of the workers
getNumWorkers() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Get the total number of workers.
getNumWriteBytes() - Method in class edu.iu.harp.example.EdgeVal
 
getNumWriteBytes() - Method in class edu.iu.harp.example.IntCount
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.example.IntVal
Get the number of bytes of the data
getNumWriteBytes() - Method in class edu.iu.harp.example.StringKey
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.resource.Writable
Abstract method for getting the number of bytes of the Writable data
getNumWriteBytes() - Method in class edu.iu.harp.util.Ack
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.util.Barrier
Get the number of bytes of the encoded data
getNumWriteBytes() - Method in class edu.iu.harp.util.Join
Get the number of bytes of encoded data
getNumWriteBytes() - Method in class edu.iu.harp.util.PartitionCount
Get the number of bytes of the encoded data
getNumWriteBytes() - Method in class edu.iu.harp.util.PartitionSet
Get the number of bytes of encoded data 4 for storing worker ID, 4 for storing the size of parIDs, the rest for storing the parIDs
getOPByteArray(int) - Method in class edu.iu.harp.client.DataChainBcastSender
Get the ByteArray storing the size of the head array
getOPByteArray(int) - Method in class edu.iu.harp.client.DataMSTBcastSender
Get the ByteArray storing the size of the head array
getOPByteArray(int) - Method in class edu.iu.harp.client.DataSender
Get the ByteArray storing the size of the head array
getOperationName() - Method in class edu.iu.harp.io.Data
Get the name of the operation
getOutput() - Method in class edu.iu.harp.schdynamic.Output
Get the output object
getOutputStream() - Method in class edu.iu.harp.io.Connection
Get the OutputStream
getParSet() - Method in class edu.iu.harp.util.PartitionSet
Get the partition ID set
getPartition(int) - Method in class edu.iu.harp.partition.Table
Get the partition by partitionID
getPartitionCount() - Method in class edu.iu.harp.util.PartitionCount
Get the count of partitions
getPartitionID() - Method in class edu.iu.harp.io.Data
Get the ID of the partition
getPartitionIDs() - Method in class edu.iu.harp.partition.Table
Get the IDs of the partitions in this table
getPartitions() - Method in class edu.iu.harp.partition.Table
Get the partitions in this table
getPartitionSet(Table<P>) - Static method in class edu.iu.harp.partition.PartitionUtil
Get the partition ID set from the table
getParToWorkerMap() - Method in class edu.iu.harp.util.Join
Get the parToWorkerMap
getPort() - Method in class edu.iu.harp.io.Connection
Get the port
getPort() - Method in class edu.iu.harp.worker.WorkerInfo
Get the port
getPos() - Method in class edu.iu.harp.io.Deserializer
Get the current position
getPos() - Method in class edu.iu.harp.io.Serializer
Get the current position
getProjectHomePath() - Static method in class edu.iu.harp.depl.Depl
Return the project home path
getRack() - Method in class edu.iu.harp.worker.WorkerInfo
Get the rack id
getRackID(String) - Static method in class edu.iu.harp.depl.Depl
Get the rack ID from the string
getRackList() - Method in class edu.iu.harp.worker.Nodes
Get the list of the racks
getSelfID() - Method in class edu.iu.harp.worker.Workers
Get the ID of this worker
getSelfID() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Get the ID of this worker.
getSelfInfo() - Method in class edu.iu.harp.worker.Workers
Get the WorkerInfo of this worker
getSourceID() - Method in class edu.iu.harp.client.Event
Get the ID of the source
getSrc() - Method in class edu.iu.harp.example.EdgeVal
 
getStatus() - Method in class edu.iu.harp.util.Barrier
Get the status
getStringKey() - Method in class edu.iu.harp.example.StringKey
Get the string
getSubmitter() - Method in class edu.iu.harp.schstatic.Task
Get the Submitter of this task
getTableID() - Method in class edu.iu.harp.partition.Table
Get the table ID
getTargetID() - Method in class edu.iu.harp.client.Event
Get the ID of the target
getTask(int) - Method in class edu.iu.harp.schstatic.StaticScheduler
Get the Task by its ID
getTaskID() - Method in class edu.iu.harp.schstatic.Task
Get the ID of the task
getTasks() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Get the list of tasks
getVal() - Method in class edu.iu.harp.example.EdgeVal
 
getVal(int) - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Get the associated value of the key
getVal(int) - Method in class edu.iu.harp.keyval.Int2IntKVTable
Get the value associated with the key
getVal(int) - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Get the associated value of the key
getVal(int) - Method in class edu.iu.harp.keyval.Int2LongKVTable
Get the value associated with the key
getVal(int) - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Get the associated value of the key
getVal(int) - Method in class edu.iu.harp.keyval.Int2ValKVTable
Get the value associated with the key
getVal(K) - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Get the associated value of the key
getVal(K) - Method in class edu.iu.harp.keyval.Key2ValKVTable
Get the value associated with the key
getVal(long) - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Get the associated value of the key
getVal(long) - Method in class edu.iu.harp.keyval.Long2DoubleKVTable
Get the value associated with the key
getVal(long) - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Get the associated value of the key
getVal(long) - Method in class edu.iu.harp.keyval.Long2IntKVTable
Get the value associated with the key
getVClass() - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Get the class of the values
getVClass() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Get the class of the values
getWorkerID() - Method in class edu.iu.harp.io.Data
Get the ID of the Worker
getWorkerID(int) - Method in class edu.iu.harp.partition.Partitioner
 
getWorkerID() - Method in class edu.iu.harp.util.PartitionCount
Get the ID of the worker
getWorkerID() - Method in class edu.iu.harp.util.PartitionSet
Get the worker ID
getWorkerInfo(int) - Method in class edu.iu.harp.worker.Workers
Get the WorkerInfo of the worker
getWorkerInfoList() - Method in class edu.iu.harp.worker.Workers
Get the iterable class of the WorkerInfos
getWorkerParCountMap() - Method in class edu.iu.harp.util.Join
Get the workerParCountMap
getWorkers() - Method in class edu.iu.harp.client.Sender
Get the workers
GraphCollective - Class in edu.iu.harp.collective
Graph Collective communication
GraphCollective() - Constructor for class edu.iu.harp.collective.GraphCollective
 
GroupByKeyCollective - Class in edu.iu.harp.collective
Group By Key Collective communication
GroupByKeyCollective() - Constructor for class edu.iu.harp.collective.GroupByKeyCollective
 

H

handleData(Connection, Data) - Method in class edu.iu.harp.client.DataSender
This method defines how to handle the data
handleData(Connection, Data) - Method in class edu.iu.harp.client.Sender
Abstract method for handling the data
handleData(ServerConn) - Method in class edu.iu.harp.server.DataChainBcastReceiver
Defines how to handle the Data
handleData(ServerConn) - Method in class edu.iu.harp.server.DataMSTBcastReceiver
Defines how to handle the Data
handleData(ServerConn) - Method in class edu.iu.harp.server.DataReceiver
Defines how to handle the Data
handleData(ServerConn) - Method in class edu.iu.harp.server.Receiver
Abstract method for handling the data
handleEvent(ContainerAllocatorEvent) - Method in class org.apache.hadoop.mapreduce.v2.app.rm.MapCollectiveContainerAllocator
How the event is generated in TaskAttemptImpl: RequestContainerTransition taskAttempt.eventHandler.handle(new ContainerRequestEvent( taskAttempt.attemptId, taskAttempt.resourceCapability, taskAttempt.dataLocalHosts.toArray( new String[taskAttempt.dataLocalHosts.size()]), taskAttempt.dataLocalRacks.toArray( new String[taskAttempt.dataLocalRacks.size()])));
hasError() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Check if has errors or not
hasError(int) - Method in class edu.iu.harp.schstatic.StaticScheduler
Check if has errors on this task
hashCode() - Method in class edu.iu.harp.example.StringKey
The overridden hashCode function
hashCode() - Method in class edu.iu.harp.keyval.Key
The hashCode function to be overridden
hasNext() - Method in class edu.iu.harp.worker.Workers.WorkerInfoIterator
The overridden hasNext() method
hasOutput() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Check if has a new output
hasOutput(int) - Method in class edu.iu.harp.schstatic.StaticScheduler
Check if has a new output

I

id() - Method in class edu.iu.harp.partition.Partition
Get the partition ID
initialize() - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Initialization
initialize() - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Initialization
initialize(Class<V>) - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Initialization
initialize(Class<K>, Class<V>) - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Initialize the partition
initialize() - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Initialization
initialize() - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Initialization
Input<I> - Class in edu.iu.harp.schdynamic
The input class for tasks
Input(I, boolean, boolean) - Constructor for class edu.iu.harp.schdynamic.Input
 
insertPartition(Partition<P>) - Method in class edu.iu.harp.partition.Table
Insert a partition to this table
Int2IntKVPartition - Class in edu.iu.harp.keyval
Int2IntKVPartition manages key-value pairs in which the key and the value are int-type
Int2IntKVPartition() - Constructor for class edu.iu.harp.keyval.Int2IntKVPartition
 
Int2IntKVTable - Class in edu.iu.harp.keyval
A KVTable manages Int2IntKVPartitions
Int2IntKVTable(int, TypeIntCombiner) - Constructor for class edu.iu.harp.keyval.Int2IntKVTable
 
Int2LongKVPartition - Class in edu.iu.harp.keyval
Int2LongKVPartition manages key-value pairs in which the key is int-type and the value is long-type
Int2LongKVPartition() - Constructor for class edu.iu.harp.keyval.Int2LongKVPartition
 
Int2LongKVTable - Class in edu.iu.harp.keyval
A KVTable manages Int2LongKVPartition
Int2LongKVTable(int, TypeLongCombiner) - Constructor for class edu.iu.harp.keyval.Int2LongKVTable
 
Int2ValKVPartition<V extends Value> - Class in edu.iu.harp.keyval
Int2ValKVPartition manages key-value pairs in which the key is int-type and the value is object
Int2ValKVPartition() - Constructor for class edu.iu.harp.keyval.Int2ValKVPartition
 
Int2ValKVTable<V extends Value,P extends Int2ValKVPartition<V>> - Class in edu.iu.harp.keyval
A KVTable manages Int2ValKVPartitions
Int2ValKVTable(int, ValCombiner<V>, Class<V>, Class<P>) - Constructor for class edu.iu.harp.keyval.Int2ValKVTable
 
INT_ARRAY - Static variable in class edu.iu.harp.io.DataType
 
IntArray - Class in edu.iu.harp.resource
ByteArray class for managing int[] data.
IntArray(int[], int, int) - Constructor for class edu.iu.harp.resource.IntArray
 
IntArrPlus - Class in edu.iu.harp.example
Combiner for IntArray
IntArrPlus() - Constructor for class edu.iu.harp.example.IntArrPlus
 
IntCount - Class in edu.iu.harp.example
IntCount-type Value, storing the count of the associate int value.
IntCount() - Constructor for class edu.iu.harp.example.IntCount
 
IntCount(int, int) - Constructor for class edu.iu.harp.example.IntCount
 
IntCountPlus - Class in edu.iu.harp.example
Combiner for IntCount
IntCountPlus() - Constructor for class edu.iu.harp.example.IntCountPlus
 
IntPlus - Class in edu.iu.harp.example
 
IntPlus() - Constructor for class edu.iu.harp.example.IntPlus
 
IntsPool - Class in edu.iu.harp.resource
A pool used for caching int arrays.
IntsPool() - Constructor for class edu.iu.harp.resource.IntsPool
 
IntVal - Class in edu.iu.harp.example
Int-type Value
IntVal() - Constructor for class edu.iu.harp.example.IntVal
 
IntVal(int) - Constructor for class edu.iu.harp.example.IntVal
 
IOUtil - Class in edu.iu.harp.io
Some utils for IO operations
IOUtil() - Constructor for class edu.iu.harp.io.IOUtil
 
isData() - Method in class edu.iu.harp.io.Data
Check if this is Data Data > Operation Data > Partition Data
isEmpty() - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Indicates if the partition is empty or not
isEmpty() - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Indicates if the partition is empty or not
isEmpty() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Indicates if the partition is empty or not
isEmpty() - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Indicates if the partition is empty or not
isEmpty() - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Indicates if the partition is empty or not
isEmpty() - Method in class edu.iu.harp.partition.Table
If this table is empty, return true; else, return false.
isError() - Method in class edu.iu.harp.schdynamic.Output
Check if it's an error or not
isMaster() - Method in class edu.iu.harp.worker.Workers
Check if this is the master or not
isMaster() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Check if this worker is the master worker.
isMax() - Method in class edu.iu.harp.worker.Workers
Check if the ID of this worker is the maximum among all the workers
isOperationData() - Method in class edu.iu.harp.io.Data
Check if this is an operation data
isPartitionData() - Method in class edu.iu.harp.io.Data
Check if this is a partition data
isPause() - Method in class edu.iu.harp.schdynamic.Input
Check if the input is paused or not
isRack(String) - Static method in class edu.iu.harp.depl.Depl
Check if this string is a tag of rack or not
isSelfInWorker() - Method in class edu.iu.harp.worker.Workers
Check if this worker is in the Workers
isStop() - Method in class edu.iu.harp.schdynamic.Input
Check if the input is stopped or not
isTheOnlyWorker() - Method in class edu.iu.harp.worker.Workers
Check if this is the only worker or not
iterator() - Method in class edu.iu.harp.worker.Workers.WorkerInfoList
Get the iterator

J

join(String, String, Table<P1>, Partitioner, Table<P2>, DataMap, Workers) - Static method in class edu.iu.harp.collective.GraphCollective
The Join communication operation
Join - Class in edu.iu.harp.util
This class records the destinations of each partition.
Join() - Constructor for class edu.iu.harp.util.Join
 
joinThread(Thread) - Static method in class edu.iu.harp.schdynamic.ComputeUtil
Join the thread

K

Key - Class in edu.iu.harp.keyval
The abstract class of Key
Key() - Constructor for class edu.iu.harp.keyval.Key
 
Key2ValKVPartition<K extends Key,V extends Value> - Class in edu.iu.harp.keyval
Key2ValKVPartition manages key-value pairs in which the key and the value are objects
Key2ValKVPartition() - Constructor for class edu.iu.harp.keyval.Key2ValKVPartition
 
Key2ValKVTable<K extends Key,V extends Value,P extends Key2ValKVPartition<K,V>> - Class in edu.iu.harp.keyval
An abstract class of Key-Vale tables
Key2ValKVTable(int, ValCombiner<V>, Class<K>, Class<V>, Class<P>) - Constructor for class edu.iu.harp.keyval.Key2ValKVTable
 
KeyValReader(Context) - Constructor for class org.apache.hadoop.mapred.CollectiveMapper.KeyValReader
 
KVPartition - Class in edu.iu.harp.keyval
KVPartition manage key-value pairs
KVPartition() - Constructor for class edu.iu.harp.keyval.KVPartition
 
KVTable<P extends KVPartition> - Class in edu.iu.harp.keyval
KVTable is a table storing key-value pairs
KVTable(int, PartitionCombiner<P>) - Constructor for class edu.iu.harp.keyval.KVTable
 

L

LARGE_RETRY_COUNT - Static variable in class edu.iu.harp.io.Constant
 
LocalGlobalSyncCollective - Class in edu.iu.harp.collective
Local-Global synchronization Collective communication
LocalGlobalSyncCollective() - Constructor for class edu.iu.harp.collective.LocalGlobalSyncCollective
 
LOG - Static variable in class edu.iu.harp.client.SyncClient
 
LOG - Static variable in class edu.iu.harp.client.SyncQueue
 
LOG - Static variable in class edu.iu.harp.collective.BcastCollective
 
LOG - Static variable in class edu.iu.harp.collective.Communication
 
LOG - Static variable in class edu.iu.harp.collective.EventCollective
Class logger
LOG - Static variable in class edu.iu.harp.collective.GroupByKeyCollective
 
LOG - Static variable in class edu.iu.harp.collective.RegroupCollective
 
log() - Method in class edu.iu.harp.io.ConnPool
 
log() - Method in class edu.iu.harp.resource.ResourcePool
 
LOG - Static variable in class edu.iu.harp.schdynamic.ComputeUtil
 
LOG - Static variable in class edu.iu.harp.schdynamic.DynamicScheduler
 
LOG - Static variable in class edu.iu.harp.schdynamic.TaskMonitor
 
LOG - Static variable in class edu.iu.harp.schstatic.StaticScheduler
 
LOG - Static variable in class edu.iu.harp.schstatic.TaskMonitor
 
LOG - Static variable in class org.apache.hadoop.mapred.CollectiveMapper
 
logGCTime() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Log Garbage collection time
logMemUsage() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Log memory usage
Long2DoubleKVPartition - Class in edu.iu.harp.keyval
Long2DoubleKVPartition manages key-value pairs in which the key is long-type and the value is double-type
Long2DoubleKVPartition() - Constructor for class edu.iu.harp.keyval.Long2DoubleKVPartition
 
Long2DoubleKVTable - Class in edu.iu.harp.keyval
A KVTable manages Long2DoubleKVPartition
Long2DoubleKVTable(int, TypeDoubleCombiner) - Constructor for class edu.iu.harp.keyval.Long2DoubleKVTable
 
Long2IntKVPartition - Class in edu.iu.harp.keyval
Long2IntKVPartition manages key-value pairs in which the key is long-type and the value is int-type
Long2IntKVPartition() - Constructor for class edu.iu.harp.keyval.Long2IntKVPartition
 
Long2IntKVTable - Class in edu.iu.harp.keyval
A KVTable manages Long2IntKVPartition
Long2IntKVTable(int, TypeIntCombiner) - Constructor for class edu.iu.harp.keyval.Long2IntKVTable
 
LONG_ARRAY - Static variable in class edu.iu.harp.io.DataType
 
LONG_SLEEP - Static variable in class edu.iu.harp.io.Constant
 
LongArray - Class in edu.iu.harp.resource
ByteArray class for managing long[] data.
LongArray(long[], int, int) - Constructor for class edu.iu.harp.resource.LongArray
 
LongArrPlus - Class in edu.iu.harp.example
Combiner for LongArray
LongArrPlus() - Constructor for class edu.iu.harp.example.LongArrPlus
 
LongsPool - Class in edu.iu.harp.resource
A pool used for caching long-type arrays.
LongsPool() - Constructor for class edu.iu.harp.resource.LongsPool
 

M

main(String[]) - Static method in class edu.iu.harp.collective.AllgatherCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.AllreduceCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.BcastCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.Driver
 
main(String[]) - Static method in class edu.iu.harp.collective.EventCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.GraphCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.GroupByKeyCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.LocalGlobalSyncCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.ReduceCollective
 
main(String[]) - Static method in class edu.iu.harp.collective.RegroupCollective
 
main(String[]) - Static method in class edu.iu.harp.depl.Depl
 
main(String[]) - Static method in class org.apache.hadoop.mapreduce.v2.app.MapCollectiveAppMaster
 
MAP_COLLECTIVE_FRAMEWORK_NAME - Static variable in class org.apache.hadoop.mapred.MapCollectiveClientProtocolProvider
 
mapCollective(CollectiveMapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.KeyValReader, Context) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Most applications should override this.
MapCollectiveAppMaster - Class in org.apache.hadoop.mapreduce.v2.app
The Map-Reduce Application Master.
MapCollectiveAppMaster(ApplicationAttemptId, ContainerId, String, int, int, long) - Constructor for class org.apache.hadoop.mapreduce.v2.app.MapCollectiveAppMaster
 
MapCollectiveClientProtocolProvider - Class in org.apache.hadoop.mapred
A new ClientProtocalProvider to support map-collective job, modified from YarnClientProtocolProvider
MapCollectiveClientProtocolProvider() - Constructor for class org.apache.hadoop.mapred.MapCollectiveClientProtocolProvider
 
MapCollectiveContainerAllocator - Class in org.apache.hadoop.mapreduce.v2.app.rm
This class is modified from RMContainerAllocator.
MapCollectiveContainerAllocator(ClientService, AppContext) - Constructor for class org.apache.hadoop.mapreduce.v2.app.rm.MapCollectiveContainerAllocator
 
MapCollectiveContainerLauncherImpl - Class in org.apache.hadoop.mapreduce.v2.app.launcher
This class is modified from ContainerLauncherImpl.
MapCollectiveContainerLauncherImpl(AppContext) - Constructor for class org.apache.hadoop.mapreduce.v2.app.launcher.MapCollectiveContainerLauncherImpl
 
MapCollectiveRunner - Class in org.apache.hadoop.mapred
This class is modified from YARNRunner for submitting map-collective jobs.
MapCollectiveRunner(Configuration) - Constructor for class org.apache.hadoop.mapred.MapCollectiveRunner
 
MAX_ARRAY_SIZE - Static variable in class edu.iu.harp.io.Constant
 
MessagePartition - Class in edu.iu.harp.example
 
MessagePartition() - Constructor for class edu.iu.harp.example.MessagePartition
 
MessageTable - Class in edu.iu.harp.example
 
MessageTable(int) - Constructor for class edu.iu.harp.example.MessageTable
 
MST_BCAST - Static variable in class edu.iu.harp.io.Constant
 
MST_BCAST_DECODE - Static variable in class edu.iu.harp.io.Constant
 
mstBcast(String, int, String, List<Transferable>, Workers) - Static method in class edu.iu.harp.collective.Communication
The broadcast communication operation using MST method.
mstBcastAndRecv(String, int, String, List<Transferable>, Workers, DataMap) - Static method in class edu.iu.harp.collective.Communication
The broadcast communication operation using MST method.

N

newInstance(Class<W>) - Static method in class edu.iu.harp.resource.Writable
Get a new instance of the class
next() - Method in class edu.iu.harp.worker.Workers.WorkerInfoIterator
The overridden next() method
nextKeyValue() - Method in class org.apache.hadoop.mapred.CollectiveMapper.KeyValReader
Get the next key-value
Nodes - Class in edu.iu.harp.worker
The information of the nodes
Nodes() - Constructor for class edu.iu.harp.worker.Nodes
 
Nodes(BufferedReader) - Constructor for class edu.iu.harp.worker.Nodes
 
nodes_file - Static variable in class edu.iu.harp.depl.Depl
 
NUM_THREADS - Static variable in class edu.iu.harp.io.Constant
 

O

org.apache.hadoop.mapred - package org.apache.hadoop.mapred
MapCollective interfaces
org.apache.hadoop.mapreduce.v2.app - package org.apache.hadoop.mapreduce.v2.app
MapCollective Application master
org.apache.hadoop.mapreduce.v2.app.launcher - package org.apache.hadoop.mapreduce.v2.app.launcher
MapCollective container launcher
org.apache.hadoop.mapreduce.v2.app.rm - package org.apache.hadoop.mapreduce.v2.app.rm
MapCollective resource container allocator
Output - Class in edu.iu.harp.depl
The wrapper class of the outputs from command execution
Output<O> - Class in edu.iu.harp.schdynamic
The output class for tasks
Output(O, boolean) - Constructor for class edu.iu.harp.schdynamic.Output
 

P

Partition<P extends Simple> - Class in edu.iu.harp.partition
Partition provides a wrapper on an array or an object.
Partition(int, P) - Constructor for class edu.iu.harp.partition.Partition
 
PARTITION_LIST - Static variable in class edu.iu.harp.io.DataType
 
PartitionCombiner<P extends Simple> - Class in edu.iu.harp.partition
A PartitionCombiner defines how to merge two partitions
PartitionCombiner() - Constructor for class edu.iu.harp.partition.PartitionCombiner
 
PartitionCount - Class in edu.iu.harp.util
PartitionCount records the number of partitions on the worker
PartitionCount() - Constructor for class edu.iu.harp.util.PartitionCount
 
Partitioner - Class in edu.iu.harp.partition
A Partitioner defines how to distribute the partitions to workers.
Partitioner(int) - Constructor for class edu.iu.harp.partition.Partitioner
 
PartitionFunction<T extends Transferable> - Class in edu.iu.harp.partition
The abstract class defining function which can be applied to partitions
PartitionFunction() - Constructor for class edu.iu.harp.partition.PartitionFunction
 
PartitionSet - Class in edu.iu.harp.util
PartitionSet is the set of partition IDs on the worker
PartitionSet() - Constructor for class edu.iu.harp.util.PartitionSet
 
PartitionStatus - Enum in edu.iu.harp.partition
Defines the partition status
PartitionUtil - Class in edu.iu.harp.partition
Utils used on partitions, including receive, regroup, rotate, gather, allgather operations and etc.
PartitionUtil() - Constructor for class edu.iu.harp.partition.PartitionUtil
 
pause() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Pause the task
pause() - Method in class edu.iu.harp.schstatic.StaticScheduler
Pause the scheduling
pauseNow() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Pause the task immediately
PIPELINE_SIZE - Static variable in class edu.iu.harp.io.Constant
 
printToNodesFile() - Method in class edu.iu.harp.worker.Nodes
print the rack and the nodes information
pull(String, String, Table<P>, Table<P>, boolean, DataMap, Workers) - Static method in class edu.iu.harp.collective.LocalGlobalSyncCollective
The pull communication operation.
pull(String, String, Table<P>, Table<P>, boolean) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Pull partitions in the global table to the local tables.
pullGlobalToLocal(String, String, Table<P>, Table<P>, boolean, DataMap, Workers) - Static method in class edu.iu.harp.collective.LocalGlobalSyncCollective
The pull communication operation.
push(String, String, Table<P>, Table<P>, PT, DataMap, Workers) - Static method in class edu.iu.harp.collective.LocalGlobalSyncCollective
The push communication operation.
push(String, String, Table<P>, Table<P>, PT) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Push the partitions of local tables to the global table.
pushLocalToGlobal(String, String, Table<P>, Table<P>, PT, DataMap, Workers) - Static method in class edu.iu.harp.collective.LocalGlobalSyncCollective
The push communication operation.
putData(Data) - Method in class edu.iu.harp.io.DataMap
Put the Data to the DataMap
putKeyVal(int, int, TypeIntCombiner) - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Put the new key-value pair to the partition.
putKeyVal(int, long, TypeLongCombiner) - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Put the new key-value pair to the partition.
putKeyVal(int, V, ValCombiner<V>) - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Put the new key-value pair to the partition.
putKeyVal(K, V, ValCombiner<V>) - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Put the new key-value pair to the partition.
putKeyVal(long, double, TypeDoubleCombiner) - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Put the new key-value pair to the partition.
putKeyVal(long, int, TypeIntCombiner) - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Put the new key-value pair to the partition.

R

read(DataInput) - Method in class edu.iu.harp.example.EdgeVal
 
read(DataInput) - Method in class edu.iu.harp.example.IntCount
Read the data from DataInput
read(DataInput) - Method in class edu.iu.harp.example.IntVal
Read the value from DataInput
read(DataInput) - Method in class edu.iu.harp.example.StringKey
Read the string from DataInput
read(DataInput) - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.resource.Writable
Abstract method for reading Writable data from DataInput
read(DataInput) - Method in class edu.iu.harp.util.Ack
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.util.Barrier
Read the status from DataInput
read(DataInput) - Method in class edu.iu.harp.util.Join
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.util.PartitionCount
Read this from DataInput
read(DataInput) - Method in class edu.iu.harp.util.PartitionSet
Read PartitionSet from DataInput
readBoolean() - Method in class edu.iu.harp.io.Deserializer
Read the boolean value
readByte() - Method in class edu.iu.harp.io.Deserializer
Read the byte value
readChar() - Method in class edu.iu.harp.io.Deserializer
Read the char value
readDouble() - Method in class edu.iu.harp.io.Deserializer
Read the double value
readFloat() - Method in class edu.iu.harp.io.Deserializer
Read the float value
readFully(byte[]) - Method in class edu.iu.harp.io.Deserializer
Read from the input stream to the byte[]
readFully(byte[], int, int) - Method in class edu.iu.harp.io.Deserializer
Read from the input stream to the byte[]
readInt() - Method in class edu.iu.harp.io.Deserializer
Read the int value
readLine() - Method in class edu.iu.harp.io.Deserializer
Read the String value
readLong() - Method in class edu.iu.harp.io.Deserializer
Read the long value
readShort() - Method in class edu.iu.harp.io.Deserializer
Read the short value
readUnsignedByte() - Method in class edu.iu.harp.io.Deserializer
Read the unsigned byte value
readUnsignedShort() - Method in class edu.iu.harp.io.Deserializer
Read the unsigned short value
readUTF() - Method in class edu.iu.harp.io.Deserializer
Read the String value
receiveBytes(InputStream, byte[], int, int) - Static method in class edu.iu.harp.io.IOUtil
Get byte[] from the InputStream
receivePartitions(String, String, Table<P>, int, IntArrayList, DataMap) - Static method in class edu.iu.harp.partition.PartitionUtil
 
Receiver - Class in edu.iu.harp.server
The abstract class for receiving the data
Receiver(ServerConn, EventQueue, DataMap, byte) - Constructor for class edu.iu.harp.server.Receiver
 
reduce(String, String, Table<P>, int, DataMap, Workers) - Static method in class edu.iu.harp.collective.ReduceCollective
Reduce communication operation
reduce(String, String, Table<P>, int) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Reduce the partitions of the tables to one of them.
ReduceCollective - Class in edu.iu.harp.collective
Reduce Collective communication
ReduceCollective() - Constructor for class edu.iu.harp.collective.ReduceCollective
 
regroup(String, String, Table<P>, PT) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Regroup the partitions of the tables based on a partitioner.
regroupAggregate(String, String, Table<P>, PT, PF, DataMap, Workers) - Static method in class edu.iu.harp.collective.RegroupCollective
 
RegroupCollective - Class in edu.iu.harp.collective
Regroup Collective communication
RegroupCollective() - Constructor for class edu.iu.harp.collective.RegroupCollective
 
regroupCombine(String, String, Table<P>, Partitioner, DataMap, Workers) - Static method in class edu.iu.harp.collective.RegroupCollective
The regroup communication operation
regroupPartitionCount(String, String, Table<P>, List<Transferable>, Int2IntOpenHashMap, Partitioner, DataMap, Workers) - Static method in class edu.iu.harp.partition.PartitionUtil
 
regroupPartitionSet(String, String, Table<P>, List<Transferable>, Int2IntOpenHashMap, Partitioner, DataMap, Workers) - Static method in class edu.iu.harp.partition.PartitionUtil
 
release() - Method in class edu.iu.harp.io.Connection
Release the connection object
release() - Method in class edu.iu.harp.io.Data
Release the Data
release() - Method in class edu.iu.harp.partition.Partition
Release and reset the partition
release() - Method in class edu.iu.harp.partition.Table
Release the partitions
release() - Method in class edu.iu.harp.resource.ByteArray
Release the array from the ResourcePool
release() - Method in class edu.iu.harp.resource.DoubleArray
Release the array from the ResourcePool
release() - Method in class edu.iu.harp.resource.FloatArray
Release the array from the ResourcePool
release() - Method in class edu.iu.harp.resource.IntArray
Release the array from the ResourcePool
release() - Method in class edu.iu.harp.resource.LongArray
Release the array from the ResourcePool
release() - Method in class edu.iu.harp.resource.ShortArray
Release the array from the ResourcePool
release() - Method in class edu.iu.harp.resource.Transferable
Release the data
release() - Method in class edu.iu.harp.resource.Writable
Release the writable from the ResourcePool
releaseBodyArray() - Method in class edu.iu.harp.io.Data
Release the data body array.
releaseHeadArray() - Method in class edu.iu.harp.io.Data
Release the head array.
releaseTransList(List<Transferable>) - Static method in class edu.iu.harp.io.DataUtil
Transferable List may include different types Identify each of them and release
remove() - Method in class edu.iu.harp.worker.Workers.WorkerInfoIterator
The overridden remove() method
removePartition(int) - Method in class edu.iu.harp.partition.Table
Remove the partition from this table
removeVal(int) - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Removes this key and the associated value from this function if it is present.
removeVal(int) - Method in class edu.iu.harp.keyval.Int2ValKVTable
Remove the value associated with the key
removeVal(K) - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Removes this key and the associated value from this function if it is present.
removeVal(K) - Method in class edu.iu.harp.keyval.Key2ValKVTable
Remove the value associated with the key
reportToDriver(String, String, int, String, int) - Static method in class edu.iu.harp.collective.Driver
Report to driver that worker
reset() - Method in class edu.iu.harp.resource.Array
Reset the array
ResourcePool - Class in edu.iu.harp.resource
 
rotate(String, String, Table<P>, Int2IntMap, DataMap, Workers) - Static method in class edu.iu.harp.collective.LocalGlobalSyncCollective
 
rotate(String, String, Table<P>, Int2IntMap) - Method in class org.apache.hadoop.mapred.CollectiveMapper
The rotation communication.
rotatePartitionCount(String, String, Table<P>, List<Transferable>, int, DataMap, Workers) - Static method in class edu.iu.harp.partition.PartitionUtil
 
run() - Method in class edu.iu.harp.client.SyncClient
Main process by this client Go through each queue, drain the queue and send/broadcast
run(I) - Method in interface edu.iu.harp.schdynamic.Task
The main computation of the task
run() - Method in class edu.iu.harp.schdynamic.TaskMonitor
The main process of monitoring and managing tasks
run(I) - Method in class edu.iu.harp.schstatic.Task
The main computation of the task
run() - Method in class edu.iu.harp.schstatic.TaskMonitor
The main process of monitoring and managing tasks
run() - Method in class edu.iu.harp.server.Acceptor
The overridden run function for handling the messages received from a client
run() - Method in class edu.iu.harp.server.Receiver
The execution method
run() - Method in class edu.iu.harp.server.Server
The overridden run function for receiving data from clients
run(Context) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Override this method to support collective communications among Mappers
runByteArrayChainBcast(String, int, int, int, DataMap, Workers) - Static method in class edu.iu.harp.collective.BcastCollective
 
runChainBcast(String, int, int, int, DataMap, Workers) - Static method in class edu.iu.harp.collective.BcastCollective
Test for broadcasting using chain method
runDoubleArrayTableBcast(String, int, int, int, DataMap, Workers) - Static method in class edu.iu.harp.collective.BcastCollective
 

S

SEND - Static variable in class edu.iu.harp.io.Constant
 
SEND_DECODE - Static variable in class edu.iu.harp.io.Constant
 
sendBytes(OutputStream, byte[], int, int) - Static method in class edu.iu.harp.io.IOUtil
Sent the byte[] to OutputStream
sendDataBytes(Connection, ByteArray, Data) - Method in class edu.iu.harp.client.DataMSTBcastSender
Broadcast the data
sendDataBytes(Connection, ByteArray, Data) - Method in class edu.iu.harp.client.DataSender
Send the data
Sender - Class in edu.iu.harp.client
The abstract class for sending the data
Sender(Data, int, Workers, byte) - Constructor for class edu.iu.harp.client.Sender
To send data between workers, sender and receiver must both have valid IDs.
Sender(Data, String, int, byte) - Constructor for class edu.iu.harp.client.Sender
Use host and port directly do send between any to processes It can send data from a process other than workers or send data from a worker to a process outside.
sendEvent(Event) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Send an event to the local (local event), to a remote worker (message event), or to the rest workers (collective event).
Serializer - Class in edu.iu.harp.io
A class for serialization implemented DataOutput interface
Serializer(ByteArray) - Constructor for class edu.iu.harp.io.Serializer
 
Serializer(byte[], int, int) - Constructor for class edu.iu.harp.io.Serializer
Serialize on bytes which starts from bytes[0] to bytes[len - 1], with pos between 0 ~ (len - 1)
Server - Class in edu.iu.harp.server
The server for communication
Server(String, int, EventQueue, DataMap, Workers) - Constructor for class edu.iu.harp.server.Server
Initialization
SERVER_QUIT - Static variable in class edu.iu.harp.io.Constant
 
ServerConn - Class in edu.iu.harp.server
The connection object for Server
serviceInit(Configuration) - Method in class org.apache.hadoop.mapreduce.v2.app.launcher.MapCollectiveContainerLauncherImpl
 
serviceInit(Configuration) - Method in class org.apache.hadoop.mapreduce.v2.app.MapCollectiveAppMaster
 
serviceInit(Configuration) - Method in class org.apache.hadoop.mapreduce.v2.app.rm.MapCollectiveContainerAllocator
 
setCount(int) - Method in class edu.iu.harp.example.IntCount
Set the count
setInt(int) - Method in class edu.iu.harp.example.IntCount
Set the value
setInt(int) - Method in class edu.iu.harp.example.IntVal
Set the value
setParSet(IntArrayList) - Method in class edu.iu.harp.util.PartitionSet
Set the partition ID set
setPartitionCount(int) - Method in class edu.iu.harp.util.PartitionCount
Set the count of partitions
setParToWorkerMap(<any>) - Method in class edu.iu.harp.util.Join
Set the parToWorkerMap
setServerSocketOptions(ServerSocket) - Static method in class edu.iu.harp.io.IOUtil
Set the options for the ServerSocket
setSocketOptions(Socket) - Static method in class edu.iu.harp.io.IOUtil
Set the options for the Socket
setStatus(boolean) - Method in class edu.iu.harp.util.Barrier
Set the status
setStringKey(String) - Method in class edu.iu.harp.example.StringKey
Set string
setup(Context) - Method in class org.apache.hadoop.mapred.CollectiveMapper
Called once at the beginning of the task.
setWorkerID(int) - Method in class edu.iu.harp.util.PartitionCount
Set the workerID
setWorkerID(int) - Method in class edu.iu.harp.util.PartitionSet
Set the worker ID
setWorkerParCountMap(Int2IntOpenHashMap) - Method in class edu.iu.harp.util.Join
Set the workerPartitionCountMap
SHORT_ARRAY - Static variable in class edu.iu.harp.io.DataType
 
SHORT_SLEEP - Static variable in class edu.iu.harp.io.Constant
 
ShortArray - Class in edu.iu.harp.resource
ByteArray class for managing short[] data.
ShortArray(short[], int, int) - Constructor for class edu.iu.harp.resource.ShortArray
 
ShortsPool - Class in edu.iu.harp.resource
A pool used for caching short-type arrays.
ShortsPool() - Constructor for class edu.iu.harp.resource.ShortsPool
 
Simple - Class in edu.iu.harp.resource
The abstract class of data structures.
Simple() - Constructor for class edu.iu.harp.resource.Simple
 
SIMPLE_LIST - Static variable in class edu.iu.harp.io.DataType
 
size() - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Get the number of key-value pairs
size() - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Get the number of key-value pairs
size() - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Get the number of key-value pairs
size() - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Get the number of key-value pairs
size() - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Get the number of key-value pairs
size - Variable in class edu.iu.harp.resource.Array
Size of the array data, -1 by default
size() - Method in class edu.iu.harp.resource.Array
Get the size of the array.
skipBytes(int) - Method in class edu.iu.harp.io.Deserializer
Skip n number of bytes
SMALL_RETRY_COUNT - Static variable in class edu.iu.harp.io.Constant
 
sortRacks() - Method in class edu.iu.harp.worker.Nodes
Sorting the racks based on the number of the nodes associated with the racks in descending order
start() - Method in class edu.iu.harp.client.SyncClient
Start the client
start - Variable in class edu.iu.harp.resource.Array
Start position in the array data, -1 by default
start() - Method in class edu.iu.harp.resource.Array
Get the start index of the array
start() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Start scheduling
start() - Method in class edu.iu.harp.schstatic.StaticScheduler
Start to schedule tasks
start() - Method in class edu.iu.harp.server.Server
Start the server
StaticScheduler<I,O,T extends Task<I,O>> - Class in edu.iu.harp.schstatic
The static scheduler
StaticScheduler(List<T>) - Constructor for class edu.iu.harp.schstatic.StaticScheduler
 
stop() - Method in class edu.iu.harp.client.SyncClient
Send StopSign to the execution threads
stop() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Stop submission Send stop signal to the queue based on the number of tasks
stop() - Method in class edu.iu.harp.schstatic.StaticScheduler
Stop scheduling
stop() - Method in class edu.iu.harp.server.Server
Stop the server.
StringKey - Class in edu.iu.harp.example
String-type Key
StringKey() - Constructor for class edu.iu.harp.example.StringKey
 
StringKey(String) - Constructor for class edu.iu.harp.example.StringKey
 
submit(I) - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Submit the input
submit(int, I) - Method in class edu.iu.harp.schstatic.StaticScheduler
Submit the input to task
submit(int, I) - Method in class edu.iu.harp.schstatic.Submitter
Submit the task
submitAll(Collection<I>) - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Submit a collection of inputs
submitAll(I[]) - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Submit an array of inputs
submitCollectiveEvent(Event) - Method in class edu.iu.harp.client.SyncClient
Submit a collective event (broadcast)
submitMessageEvent(Event) - Method in class edu.iu.harp.client.SyncClient
Submit a message event
Submitter<I> - Class in edu.iu.harp.schstatic
The Submitter is used for submitting tasks
Submitter(TaskMonitor<I, ?, ? extends Task<I, ?>>[]) - Constructor for class edu.iu.harp.schstatic.Submitter
 
SyncClient - Class in edu.iu.harp.client
Synchronous client
SyncClient(Workers) - Constructor for class edu.iu.harp.client.SyncClient
 
SyncQueue - Class in edu.iu.harp.client
Synchronous queue

T

Table<P extends Simple> - Class in edu.iu.harp.partition
The abstraction of distributed dataset.
Table(int, PartitionCombiner<P>) - Constructor for class edu.iu.harp.partition.Table
Constructor.
Table(int, PartitionCombiner<P>, int) - Constructor for class edu.iu.harp.partition.Table
 
Task<I,O> - Interface in edu.iu.harp.schdynamic
The abstract class for task definition
Task<I,O> - Class in edu.iu.harp.schstatic
The abstract class for task definition
Task() - Constructor for class edu.iu.harp.schstatic.Task
 
TaskMonitor<I,O,T extends Task<I,O>> - Class in edu.iu.harp.schdynamic
Monitor and manage tasks
TaskMonitor<I,O,T extends Task<I,O>> - Class in edu.iu.harp.schstatic
Monitor and manage tasks
TERMINATION_TIMEOUT - Static variable in class edu.iu.harp.io.Constant
 
Transferable - Class in edu.iu.harp.resource
The abstract class of transferable data structures.
Transferable() - Constructor for class edu.iu.harp.resource.Transferable
 
TypeDoubleCombiner - Class in edu.iu.harp.keyval
Combiner for merging double-type Values
TypeDoubleCombiner() - Constructor for class edu.iu.harp.keyval.TypeDoubleCombiner
 
TypeIntCombiner - Class in edu.iu.harp.keyval
Combiner for merging int-type Values
TypeIntCombiner() - Constructor for class edu.iu.harp.keyval.TypeIntCombiner
 
TypeLongCombiner - Class in edu.iu.harp.keyval
Combiner for merging long-type Values
TypeLongCombiner() - Constructor for class edu.iu.harp.keyval.TypeLongCombiner
 

U

UNKNOWN_CMD - Static variable in class edu.iu.harp.io.Constant
 
UNKNOWN_DATA_TYPE - Static variable in class edu.iu.harp.io.DataType
 
UNKNOWN_PARTITION_ID - Static variable in class edu.iu.harp.io.Constant
 
UNKNOWN_PORT - Static variable in class edu.iu.harp.io.Constant
 
UNKNOWN_WORKER_ID - Static variable in class edu.iu.harp.io.Constant
 

V

ValCombiner<V extends Value> - Class in edu.iu.harp.keyval
The abstract class of Combiners for Values
ValCombiner() - Constructor for class edu.iu.harp.keyval.ValCombiner
 
ValStatus - Enum in edu.iu.harp.keyval
Defines the status after operating on Values
Value - Class in edu.iu.harp.keyval
The abstract class of Value
Value() - Constructor for class edu.iu.harp.keyval.Value
 
valueOf(String) - Static method in enum edu.iu.harp.client.EventType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.iu.harp.io.DataStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.iu.harp.keyval.ValStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum edu.iu.harp.partition.PartitionStatus
Returns the enum constant of this type with the specified name.
values() - Static method in enum edu.iu.harp.client.EventType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.iu.harp.io.DataStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.iu.harp.keyval.ValStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum edu.iu.harp.partition.PartitionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
VertexPartition - Class in edu.iu.harp.example
 
VertexPartition() - Constructor for class edu.iu.harp.example.VertexPartition
 
VertexTable - Class in edu.iu.harp.example
 
VertexTable(int) - Constructor for class edu.iu.harp.example.VertexTable
 

W

waitAndGet(DataMap, String, String) - Static method in class edu.iu.harp.io.IOUtil
Wait and get a data from DataMap for collective communication
waitAndGetData(String, String, long) - Method in class edu.iu.harp.io.DataMap
Wait and get the data from the queue of the operation under the context
waitEvent() - Method in class edu.iu.harp.io.EventQueue
Retrieves and removes the head of this queue, waiting if necessary until an element becomes available.
waitEvent() - Method in class org.apache.hadoop.mapred.CollectiveMapper
Wait for an event from the queue
waitForOutput() - Method in class edu.iu.harp.schdynamic.DynamicScheduler
Blocked and wait for outputs Invoke as while(hasOutput()) { waitForOutput(); }
waitForOutput(int) - Method in class edu.iu.harp.schstatic.StaticScheduler
Blocked and wait for output.
WordAvgFunction - Class in edu.iu.harp.example
 
WordAvgFunction() - Constructor for class edu.iu.harp.example.WordAvgFunction
 
WordCountPartition - Class in edu.iu.harp.example
 
WordCountPartition() - Constructor for class edu.iu.harp.example.WordCountPartition
 
WordCountTable - Class in edu.iu.harp.example
 
WordCountTable(int) - Constructor for class edu.iu.harp.example.WordCountTable
 
workerID - Variable in class edu.iu.harp.worker.Workers.WorkerInfoIterator
 
WorkerInfo - Class in edu.iu.harp.worker
The information of the worker
WorkerInfo(int, String, int, int) - Constructor for class edu.iu.harp.worker.WorkerInfo
 
WorkerInfoIterator() - Constructor for class edu.iu.harp.worker.Workers.WorkerInfoIterator
 
WorkerInfoList() - Constructor for class edu.iu.harp.worker.Workers.WorkerInfoList
 
Workers - Class in edu.iu.harp.worker
The information of the workers.
Workers() - Constructor for class edu.iu.harp.worker.Workers
 
Workers(int) - Constructor for class edu.iu.harp.worker.Workers
 
Workers(BufferedReader, int) - Constructor for class edu.iu.harp.worker.Workers
Initialization the workers.
Workers.WorkerInfoIterator - Class in edu.iu.harp.worker
The iterator class of WorkerInfo.
Workers.WorkerInfoList - Class in edu.iu.harp.worker
The iterable list of WorkerInfo.
WRITABLE - Static variable in class edu.iu.harp.io.DataType
 
Writable - Class in edu.iu.harp.resource
ByteArray class for managing writable objects.
Writable() - Constructor for class edu.iu.harp.resource.Writable
 
WritablePool - Class in edu.iu.harp.resource
A pool used for caching writable objects
WritablePool() - Constructor for class edu.iu.harp.resource.WritablePool
 
write(DataOutput) - Method in class edu.iu.harp.example.EdgeVal
 
write(DataOutput) - Method in class edu.iu.harp.example.IntCount
Write the data to DataOutput
write(DataOutput) - Method in class edu.iu.harp.example.IntVal
Write the value to DataOutput
write(DataOutput) - Method in class edu.iu.harp.example.StringKey
Write the string to DataOutput
write(int) - Method in class edu.iu.harp.io.Serializer
Write the value to the output stream
write(byte[]) - Method in class edu.iu.harp.io.Serializer
Write the byte[] to the output stream
write(byte[], int, int) - Method in class edu.iu.harp.io.Serializer
Write the byte[] of the length beginning from the off to the output stream
write(DataOutput) - Method in class edu.iu.harp.keyval.Int2IntKVPartition
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.keyval.Int2LongKVPartition
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.keyval.Int2ValKVPartition
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.keyval.Key2ValKVPartition
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.keyval.Long2DoubleKVPartition
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.keyval.Long2IntKVPartition
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.resource.Writable
Abstract method for writing Writable data to DataOutPut
write(DataOutput) - Method in class edu.iu.harp.util.Ack
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.util.Barrier
Write the status to DataOutput
write(DataOutput) - Method in class edu.iu.harp.util.Join
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.util.PartitionCount
Write this to DataOutput
write(DataOutput) - Method in class edu.iu.harp.util.PartitionSet
Write the PartitionSet to DataOutput
writeBoolean(boolean) - Method in class edu.iu.harp.io.Serializer
Write the boolean value to the output stream
writeByte(int) - Method in class edu.iu.harp.io.Serializer
Write the byte value to the output stream
writeBytes(String) - Method in class edu.iu.harp.io.Serializer
Write the String value to the output stream
writeChar(int) - Method in class edu.iu.harp.io.Serializer
Write the char value to the output stream
writeChars(String) - Method in class edu.iu.harp.io.Serializer
Write the String value to the output stream
writeDouble(double) - Method in class edu.iu.harp.io.Serializer
Write the double value to the output stream
writeFloat(float) - Method in class edu.iu.harp.io.Serializer
Write the float value to the output stream
writeInt(int) - Method in class edu.iu.harp.io.Serializer
Write the int value to the output stream
writeLong(long) - Method in class edu.iu.harp.io.Serializer
Write the long value to the output stream
writeShort(int) - Method in class edu.iu.harp.io.Serializer
Write the short value to the output stream
writeUTF(String) - Method in class edu.iu.harp.io.Serializer
Write the String value to the output stream
A B C D E F G H I J K L M N O P R S T U V W 
Skip navigation links