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

S

send(Serializable) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaBidiPipeConnection
 
send(Serializable) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaBidiPipeConnection_old
 
send(NodeInfo, Serializable) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaNetworkModule
 
send(String, Serializable) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaNetworkModule
 
send(Serializable) - Method in interface p2pMapReduce.networkModule.ConnectionIF
Used to send a serializable object through this connection
send(NodeInfo, Serializable) - Method in interface p2pMapReduce.networkModule.NetworkModuleIF
Send the object msg to the node specified by endPoint If no connection is already available to this node, try to create a new one using the provided NodeInfo
send(String, Serializable) - Method in interface p2pMapReduce.networkModule.NetworkModuleIF
Send the object msg to the node identified by destID.
SEPARATOR - Static variable in class p2pMapReduce.mapreduceModule.ID
 
SEPARATOR - Static variable in class p2pMapReduce.mapreduceModule.Path
The directory separator, a slash.
SEPARATOR_CHAR - Static variable in class p2pMapReduce.mapreduceModule.Path
 
Serialization<T> - Interface in p2pMapReduce.mapreduceModule.io.serializer
Encapsulates a Serializer/Deserializer pair.
SerializationFactory - Class in p2pMapReduce.mapreduceModule.io.serializer
A factory for Serializations.
SerializationFactory(Configuration) - Constructor for class p2pMapReduce.mapreduceModule.io.serializer.SerializationFactory
Serializations are found by reading the io.serializations property from conf, which is a comma-delimited list of classnames.
serialize(T) - Method in interface p2pMapReduce.mapreduceModule.io.serializer.Serializer
Serialize t to the underlying output stream.
Serializer<T> - Interface in p2pMapReduce.mapreduceModule.io.serializer
Provides a facility for serializing objects of type to an OutputStream.
set(String, String) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property.
set(String, Object) - Method in class p2pMapReduce.networkModule.NetworkConfiguration
 
setAssignedJob(HashMap<String, UserNode.UserJob>) - Method in class p2pMapReduce.nodeModule.UserNode
 
setAvailable(boolean) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setBackupMasterList(LinkedList<String>) - Method in class p2pMapReduce.entity.BackupJob
 
setBackupMasterList(LinkedList<String>) - Method in class p2pMapReduce.entity.PrimaryJob
 
setBoolean(String, boolean) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property to a boolean.
setBooleanIfUnset(String, boolean) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the given property, if it is currently unset.
setCancelDelegationTokenUponJobCompletion(boolean) - Method in class p2pMapReduce.mapreduceModule.Job
Sets the flag that will allow the JobTracker to cancel the HDFS delegation tokens upon job completion.
setClass(String, Class<?>, Class<?>) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property to the name of a theClass implementing the given interface xface.
setClassLoader(ClassLoader) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the class loader that will be used to load the various objects.
setCleanupProgress(float) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Sets the cleanup progress of this job
setCombinerClass(Class<? extends Reducer>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the combiner class for the job.
setCombinerClass(Class<? extends Reducer>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the user-defined combiner class used to combine map-outputs before being sent to the reducers.
setCompressMapOutput(boolean) - Method in class p2pMapReduce.mapreduceModule.JobConf
Should the map outputs be compressed before transfer?
setConf(Configuration) - Method in class p2pMapReduce.entity.Task
 
setConf(Configuration) - Method in interface p2pMapReduce.mapreduceModule.conf.Configurable
Set the configuration to be used by this object.
setConf(Configuration) - Method in class p2pMapReduce.mapreduceModule.conf.Configured
 
setConf(Object, Configuration) - Static method in class p2pMapReduce.mapreduceModule.util.ReflectionUtils
 
setCoordinatorID(String) - Method in class p2pMapReduce.impl.nodeModule.NodeModuleImpl
 
setCoordinatorID(String) - Method in interface p2pMapReduce.nodeModule.NodeModuleIF
 
setDisplayName(String) - Method in class p2pMapReduce.mapreduceModule.Counter
Deprecated. 
setEnum(String, T) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property to the given type.
setEventNotifier(EventNotifier) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaBidiPipeConnection
 
setEventNotifier(EventNotifier) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaBidiPipeConnection_old
 
setFinishTime(long) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Set the finish time of the job
setFloat(String, float) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property to a float.
setFtpPort(int) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setGroupingComparatorClass(Class<? extends RawComparator>) - Method in class p2pMapReduce.mapreduceModule.Job
Define the comparator that controls which keys are grouped together for a single call to Reducer#reduce(Object, Iterable, org.apache.hadoop.mapreduce.Reducer.Context)
setHistoryFile(String) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Set the job history file url for a completed job
setID(ID) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
sets the unique id
setIfUnset(String, String) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Sets a property if it is currently unset.
setInputFormat(Class<? extends InputFormat>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the InputFormat implementation for the map-reduce job.
setInputFormatClass(Class<? extends InputFormat>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the InputFormat for the job.
setInt(String, int) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property to an int.
setIpAddress(String) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setJar(String) - Method in class p2pMapReduce.mapreduceModule.Job
Set the job jar
setJar(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the user jar for the map-reduce job.
setJarByClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the Jar by finding where a given class came from.
setJarByClass(Class) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the job's jar file by finding an example class location.
setJob(Job) - Method in class p2pMapReduce.entity.BackupJob
 
setJob(Job) - Method in class p2pMapReduce.entity.PrimaryJob
 
setJob(Job) - Method in class p2pMapReduce.nodeModule.UserNode.UserJob
 
setJobCompletionAction(Runnable) - Method in class p2pMapReduce.nodeModule.UserNode.UserJob
 
setJobEndNotificationURI(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the uri to be invoked in-order to send a notification after the job has completed (success/failure).
setJobID(JobID) - Method in class p2pMapReduce.mapreduceModule.JobContextImpl
Set the JobID.
setJobName(String) - Method in class p2pMapReduce.mapreduceModule.Job
Set the user-specified job name.
setJobName(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the user-specified job name.
setJobSetupCleanupNeeded(boolean) - Method in class p2pMapReduce.mapreduceModule.Job
Specify whether job-setup and job-cleanup is needed for the job
setJobState(JobStatus.State) - Method in class p2pMapReduce.entity.BackupJob
 
setJobState(JobStatus.State) - Method in class p2pMapReduce.entity.PrimaryJob
 
setJobState(JobStatus.State) - Method in class p2pMapReduce.mapreduceModule.Job
 
setJobTaskList(LinkedList<JobTask>) - Method in class p2pMapReduce.entity.BackupJob
 
setJobTaskList(LinkedList<JobTask>) - Method in class p2pMapReduce.entity.PrimaryJob
 
setKeepFailedTaskFiles(boolean) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set whether the framework should keep the intermediate files for failed tasks.
setKeepTaskFilesPattern(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set a regular expression for task names that should be kept.
setLoad(double) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaNodeInfo
 
setLoad(double) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setLoad(double) - Method in interface p2pMapReduce.networkModule.NodeInfo
 
setLogging() - Static method in class p2pMapReduce.util.LoggingUtil
 
setLogging(String, String) - Static method in class p2pMapReduce.util.LoggingUtil
 
setLong(String, long) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the value of the name property to a long.
setMapDebugScript(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the debug script to run when the map tasks fail.
setMapOutputKeyClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the key class for the map output data.
setMapOutputKeyClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the key class for the map output data.
setMapOutputValueClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the value class for the map output data.
setMapOutputValueClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the value class for the map output data.
setMapperClass(Class<? extends Mapper>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the Mapper for the job.
setMapperClass(Class<? extends Mapper>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the Mapper class for the job.
setMapProgress(float) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Sets the map progress of this job
setMapSpeculativeExecution(boolean) - Method in class p2pMapReduce.mapreduceModule.Job
Turn speculative execution on or off for this job for map tasks.
setMapSpeculativeExecution(boolean) - Method in class p2pMapReduce.mapreduceModule.JobConf
Turn speculative execution on or off for this job for map tasks.
setMaxMapAttempts(int) - Method in class p2pMapReduce.mapreduceModule.Job
Expert: Set the number of maximum attempts that will be made to run a map task.
setMaxMapAttempts(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Expert: Set the number of maximum attempts that will be made to run a map task.
setMaxMapTaskFailuresPercent(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Expert: Set the maximum percentage of map tasks that can fail without the job being aborted.
setMaxReduceAttempts(int) - Method in class p2pMapReduce.mapreduceModule.Job
Expert: Set the number of maximum attempts that will be made to run a reduce task.
setMaxReduceAttempts(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Expert: Set the number of maximum attempts that will be made to run a reduce task.
setMaxReduceTaskFailuresPercent(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the maximum percentage of reduce tasks that can fail without the job being aborted.
setMaxTaskFailuresPerTracker(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the maximum no. of failures of a given job per tasktracker.
setMemoryForMapTask(long) - Method in class p2pMapReduce.mapreduceModule.JobConf
 
setMemoryForReduceTask(long) - Method in class p2pMapReduce.mapreduceModule.JobConf
 
setNodeADV(NodeAdvertisement) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaNodeInfo
 
setNodeModule(NodeModuleImpl) - Method in class p2pMapReduce.gui.GUIFrame
 
setNodeModule(NodeModuleIF) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaNetworkModule
 
setNodeModule(NodeModuleIF) - Method in interface p2pMapReduce.networkModule.NetworkModuleIF
 
setNumMapTasks(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the number of map tasks for this job.
setNumReduceTasks(int) - Method in class p2pMapReduce.mapreduceModule.Job
Set the number of reduce tasks for the job.
setNumReduceTasks(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the requisite number of reduce tasks for this job.
setNumTasksToExecutePerJvm(int) - Method in class p2pMapReduce.mapreduceModule.JobConf
Sets the number of tasks that a spawned task JVM should run before it exits
setOutputCommitter(Class<? extends OutputCommitter>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the OutputCommitter implementation for the map-reduce job.
setOutputFormat(Class<? extends OutputFormat>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the OutputFormat implementation for the map-reduce job.
setOutputFormatClass(Class<? extends OutputFormat>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the OutputFormat for the job.
setOutputKeyClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the key class for the job output data.
setOutputKeyClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the key class for the job output data.
setOutputKeyComparatorClass(Class<? extends RawComparator>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the RawComparator comparator used to compare keys.
setOutputRetrieved(boolean) - Method in class p2pMapReduce.entity.JobTask
 
setOutputValueClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the value class for job outputs.
setOutputValueClass(Class<?>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the value class for job outputs.
setOutputValueGroupingComparator(Class<? extends RawComparator>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the user defined RawComparator comparator for grouping keys in the input to the reduce.
setParams(Object...) - Method in interface p2pMapReduce.nodeModule.event.EventIF
 
setParams(Object...) - Method in class p2pMapReduce.nodeModule.event.InnerEvent
 
setParams(Object...) - Method in class p2pMapReduce.nodeModule.event.MessageEvent
 
setPartition(int) - Method in class p2pMapReduce.entity.Task
 
setPartitionerClass(Class<? extends Partitioner>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the Partitioner for the job.
setPartitionerClass(Class<? extends Partitioner>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the Partitioner class used to partition Mapper-outputs to be sent to the Reducers.
setPattern(String, Pattern) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the given property to Pattern.
setPeerID(String) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setPipeID(String) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setPrimaryID(String) - Method in class p2pMapReduce.entity.BackupJob
 
setPrimaryID(String) - Method in class p2pMapReduce.entity.SlaveTask
 
setPrimaryID(String) - Method in class p2pMapReduce.nodeModule.BackupJobManager
 
setPrimaryID(String) - Method in class p2pMapReduce.nodeModule.UserNode.UserJob
 
setProfileEnabled(boolean) - Method in class p2pMapReduce.mapreduceModule.Job
Set whether the system should collect profiler information for some of the tasks in this job?
setProfileEnabled(boolean) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set whether the system should collect profiler information for some of the tasks in this job?
setProfileParams(String) - Method in class p2pMapReduce.mapreduceModule.Job
Set the profiler configuration arguments.
setProfileParams(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the profiler configuration arguments.
setProfileTaskRange(boolean, String) - Method in class p2pMapReduce.mapreduceModule.Job
Set the ranges of maps or reduces to profile. setProfileEnabled(true) must also be called.
setProfileTaskRange(boolean, String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the ranges of maps or reduces to profile. setProfileEnabled(true) must also be called.
setQueueName(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the name of the queue to which this job should be submitted.
setQuietMode(boolean) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the quietness-mode.
setReduceDebugScript(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the debug script to run when the reduce tasks fail.
setReduceProgress(float) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Sets the reduce progress of this Job
setReducerClass(Class<? extends Reducer>) - Method in class p2pMapReduce.mapreduceModule.Job
Set the Reducer for the job.
setReducerClass(Class<? extends Reducer>) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the Reducer class for the job.
setReduceSpeculativeExecution(boolean) - Method in class p2pMapReduce.mapreduceModule.Job
Turn speculative execution on or off for this job for reduce tasks.
setReduceSpeculativeExecution(boolean) - Method in class p2pMapReduce.mapreduceModule.JobConf
Turn speculative execution on or off for this job for reduce tasks.
setRetired() - Method in class p2pMapReduce.mapreduceModule.JobStatus
Set the job retire flag to true.
setRole(int) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaNodeInfo
 
setRole(int) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setRole(int) - Method in interface p2pMapReduce.networkModule.NodeInfo
 
setSchedulingInfo(String) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Used to set the scheduling information associated to a particular Job.
setSessionId(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Deprecated. 
setSetupProgress(float) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Sets the setup progress of this job
setSlaveID(String) - Method in class p2pMapReduce.entity.JobTask
 
setSortComparatorClass(Class<? extends RawComparator>) - Method in class p2pMapReduce.mapreduceModule.Job
Define the comparator that controls how the keys are sorted before they are passed to the Reducer.
setSpeculativeExecution(boolean) - Method in class p2pMapReduce.mapreduceModule.Job
Turn speculative execution on or off for this job.
setSpeculativeExecution(boolean) - Method in class p2pMapReduce.mapreduceModule.JobConf
Turn speculative execution on or off for this job.
setStartTime(long) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Set the start time of the job
setState(JobStatus.State) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Change the current run state of the job.
setStatus(String) - Method in class p2pMapReduce.mapreduceModule.StatusReporter
 
setStatus(String) - Method in interface p2pMapReduce.mapreduceModule.TaskAttemptContext
Set the current status of the task to the given string.
setStatus(String) - Method in class p2pMapReduce.mapreduceModule.TaskAttemptContextImpl
Set the current status of the task to the given string.
setStatus(String) - Method in class p2pMapReduce.mapreduceModule.WrappedMapper.Context
 
setStatus(String) - Method in class p2pMapReduce.mapreduceModule.WrappedReducer.Context
 
setStrings(String, String...) - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Set the array of string values for the name property as as comma delimited values.
setSubittedJob(LinkedList<UserNode.UserJob>) - Method in class p2pMapReduce.nodeModule.UserNode
 
setTask(Task) - Method in class p2pMapReduce.entity.JobTask
 
setTask(Task) - Method in class p2pMapReduce.entity.SlaveTask
 
setTaskAttID(TaskAttemptID) - Method in class p2pMapReduce.entity.Task
 
setTaskAttID(String) - Method in class p2pMapReduce.entity.Task
 
setTaskOutputFilter(Configuration, Job.TaskStatusFilter) - Static method in class p2pMapReduce.mapreduceModule.Job
Modify the Configuration to set the task output filter.
setTaskStatus(Task.TaskStatus) - Method in class p2pMapReduce.entity.JobTask
 
setTaskStatus(Task.TaskStatus) - Method in class p2pMapReduce.entity.SlaveTask
 
setTitle(String) - Method in class p2pMapReduce.gui.GUIFrame
 
setTrackingUrl(String) - Method in class p2pMapReduce.mapreduceModule.JobStatus
Set the link to the web-ui for details of the job.
setType(EventType) - Method in class p2pMapReduce.nodeModule.event.AbstractEvent
Deprecated.  
setType(EventType) - Method in interface p2pMapReduce.nodeModule.event.EventIF
 
setType(EventType) - Method in class p2pMapReduce.nodeModule.event.InnerEvent
 
setType(EventType) - Method in class p2pMapReduce.nodeModule.event.MessageEvent
 
setup(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class p2pMapReduce.mapreduceModule.Mapper
Called once at the beginning of the task.
setup(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>.Context) - Method in class p2pMapReduce.mapreduceModule.Reducer
Called once at the start of the task.
SETUP_CLEANUP_NEEDED - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
setupJob(JobContext) - Method in class p2pMapReduce.mapreduceModule.OutputCommitter
For the framework to setup the job output during initialization
setupProgress() - Method in class p2pMapReduce.mapreduceModule.Job
Get the progress of the job's setup-tasks, as a float between 0.0 and 1.0.
setupTask(TaskAttemptContext) - Method in class p2pMapReduce.mapreduceModule.OutputCommitter
Sets up output for the task.
setUser(String) - Method in class p2pMapReduce.mapreduceModule.Job
Set the reported username for this job.
setUser(String) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the reported username for this job.
setUsername(String) - Method in class p2pMapReduce.mapreduceModule.JobStatus
 
setUserNodeInfo(NodeInfo) - Method in class p2pMapReduce.entity.BackupJob
 
setUserNodeInfo(NodeInfo) - Method in class p2pMapReduce.entity.PrimaryJob
 
setValue(int) - Method in class p2pMapReduce.mapreduceModule.io.IntWritable
 
setValue(long) - Method in class p2pMapReduce.mapreduceModule.io.LongWritable
 
setValue(String) - Method in class p2pMapReduce.mapreduceModule.io.StringWritable
 
setVersion(long) - Method in class p2pMapReduce.impl.networkModule.jxta.NodeAdvertisement
 
setWorkingDirectory(Path) - Method in class p2pMapReduce.mapreduceModule.Job
Set the current working directory for the default file system.
setWorkingDirectory(Path) - Method in class p2pMapReduce.mapreduceModule.JobConf
Set the current working directory for the default file system.
show(BackupJob, NodeFSM, GUIFrame) - Static method in class p2pMapReduce.gui.BackupJobViewer
 
show(PrimaryJob, NodeFSM, GUIFrame) - Static method in class p2pMapReduce.gui.PrimaryJobViewer
 
show(SlaveTask, NodeFSM, GUIFrame) - Static method in class p2pMapReduce.gui.TaskViewer
 
showADV(Enumeration<Advertisement>) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
 
showADV(DiscoveryService, Enumeration<Advertisement>) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
 
showAllLocalADV(DiscoveryService, int) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
Show on stout all the local adv of the specified type
showAllLocalADV(DiscoveryService, int, String, String) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
 
showEnumeration(Enumeration) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
 
SHUFFLE_CONNECT_TIMEOUT - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SHUFFLE_FETCH_FAILURES - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SHUFFLE_INPUT_BUFFER_PERCENT - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SHUFFLE_MERGE_EPRCENT - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SHUFFLE_NOTIFY_READERROR - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SHUFFLE_PARALLEL_COPIES - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SHUFFLE_READ_TIMEOUT - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
simpleHostname(String) - Static method in class p2pMapReduce.mapreduceModule.util.StringUtils
Given a full hostname, return the word upto the first dot.
size() - Method in class p2pMapReduce.mapreduceModule.conf.Configuration
Return the number of keys in the configuration.
SKIP_OUTDIR - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SKIP_RECORDS - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SKIP_START_ATTEMPTS - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SLAVE - Static variable in interface p2pMapReduce.nodeModule.Constants
Identify a slave node
slaveCheck(String) - Method in class p2pMapReduce.nodeModule.JobManager
 
slaveCheck(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.ManagementFSM
 
slaveCheck(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.Master
 
slaveCheck(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.NodeFSM
 
slaveCheck(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.NodeState
 
slaveFailure(String) - Method in class p2pMapReduce.nodeModule.JobManager
 
slaveFailure(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.ManagementFSM
 
slaveFailure(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.Master
 
slaveFailure(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.NodeFSM
 
slaveFailure(String) - Method in class p2pMapReduce.nodeModule.nodeFsm.NodeState
 
SlaveTask - Class in p2pMapReduce.entity
A slave view of a task.
SlaveTask(Task, String) - Constructor for class p2pMapReduce.entity.SlaveTask
 
sorter() - Static method in class p2pMapReduce.test.nodeModule.JobFactory
 
SorterInputBuilder - Class in p2pMapReduce.test
 
SorterInputBuilder() - Constructor for class p2pMapReduce.test.SorterInputBuilder
 
SorterOutputChecker - Class in p2pMapReduce.test
 
SorterOutputChecker() - Constructor for class p2pMapReduce.test.SorterOutputChecker
 
sortOutput() - Method in class p2pMapReduce.entity.MapTaskRunner
Reads the temporary map output, sort it by key and write the definitive map output in the map output dir
SPECULATIVE_SLOWNODE_THRESHOLD - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SPECULATIVE_SLOWTASK_THRESHOLD - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
SPECULATIVECAP - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
split(String) - Static method in class p2pMapReduce.mapreduceModule.util.StringUtils
Split a string using the default separator
split(String, char, char) - Static method in class p2pMapReduce.mapreduceModule.util.StringUtils
Split a string using the given separator
SPLIT_FILE - Static variable in interface p2pMapReduce.mapreduceModule.MRJobConfig
 
start() - Method in class p2pMapReduce.nodeModule.BackupJobManager
 
start() - Method in class p2pMapReduce.nodeModule.JobManager
 
start() - Method in class p2pMapReduce.nodeModule.TaskManager
 
startDefaultNetPeerGroup(String, NetworkManager.ConfigMode, String[], String, boolean) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
 
startDefaultNetPeerGroup(String, NetworkManager.ConfigMode, String[], String, int, boolean) - Static method in class p2pMapReduce.impl.networkModule.jxta.JxtaUtil
 
StartFrame - Class in p2pMapReduce.gui
 
StartFrame() - Constructor for class p2pMapReduce.gui.StartFrame
Creates new form StartFrame
startLocalServer() - Method in interface p2pMapReduce.ftp.FTPManager
Starts the local ftp server
startLocalServer() - Method in class p2pMapReduce.impl.ftp.FTPManagerImpl
 
startNode() - Static method in class p2pMapReduce.nodeModule.NodeModuleStarter
 
State - Class in p2pMapReduce.nodeModule.nodeFsm
Base class for a FSM state
State() - Constructor for class p2pMapReduce.nodeModule.nodeFsm.State
 
stateEvent(Object, int) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaBidiPipeConnection_old
Deprecated. non richiamato dal bidipipe quando il pipelistener รจ gia specificato
stateEvent(Object, int) - Method in class p2pMapReduce.impl.networkModule.jxta.JxtaBidiPipeConnectionHandler
Deprecated.  
StatusReporter - Class in p2pMapReduce.mapreduceModule
 
StatusReporter() - Constructor for class p2pMapReduce.mapreduceModule.StatusReporter
 
stop() - Method in class p2pMapReduce.nodeModule.BackupJobManager
 
stop() - Method in class p2pMapReduce.nodeModule.JobManager
 
stop() - Method in class p2pMapReduce.nodeModule.TaskManager
 
string2long(String) - Static method in enum p2pMapReduce.mapreduceModule.util.StringUtils.TraditionalBinaryPrefix
Convert a string to long.
stringifyException(Throwable) - Static method in class p2pMapReduce.mapreduceModule.util.StringUtils
Make a string representation of the exception.
stringToPath(String[]) - Static method in class p2pMapReduce.mapreduceModule.util.StringUtils
 
stringToURI(String[]) - Static method in class p2pMapReduce.mapreduceModule.util.StringUtils
 
StringUtils - Class in p2pMapReduce.mapreduceModule.util
General string utils
StringUtils() - Constructor for class p2pMapReduce.mapreduceModule.util.StringUtils
 
StringUtils.TraditionalBinaryPrefix - Enum in p2pMapReduce.mapreduceModule.util
The traditional binary prefixes, kilo, mega, ..., exa, which can be represented by a 64-bit integer.
StringWritable - Class in p2pMapReduce.mapreduceModule.io
A writable that represent a string.
StringWritable() - Constructor for class p2pMapReduce.mapreduceModule.io.StringWritable
 
StringWritable(String) - Constructor for class p2pMapReduce.mapreduceModule.io.StringWritable
 
submit(Job) - Method in class p2pMapReduce.nodeModule.UserNode
A way to submit a job through this user node
submit(Job, Runnable) - Method in class p2pMapReduce.nodeModule.UserNode
Submit the job through this user node.
submit(Job) - Static method in class p2pMapReduce.test.mapreduceModule.local.LocalExecutor
 
SUBMIT_REPLICATION - Static variable in class p2pMapReduce.mapreduceModule.Job
 
suffix(String) - Method in class p2pMapReduce.mapreduceModule.Path
Adds a suffix to the final name in the path.
symbol - Variable in enum p2pMapReduce.mapreduceModule.util.StringUtils.TraditionalBinaryPrefix
 

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